Package | Description |
---|---|
org.apache.storm.scheduler | |
org.apache.storm.scheduler.multitenant | |
org.apache.storm.scheduler.resource |
Modifier and Type | Method and Description |
---|---|
void |
TopologyDetails.addResourcesForExec(ExecutorDetails exec,
Map<String,Double> resourceList)
add resource requirements for a executor
|
Double |
TopologyDetails.getOffHeapMemoryRequirement(ExecutorDetails exec)
Gets the off heap memory requirement for a certain task within a topology
|
Double |
TopologyDetails.getOnHeapMemoryRequirement(ExecutorDetails exec)
Gets the on heap memory requirement for a certain task within a topology
|
Map<String,Double> |
TopologyDetails.getTaskResourceReqList(ExecutorDetails exec)
get the resources requirements for a executor
|
Double |
TopologyDetails.getTotalCpuReqTask(ExecutorDetails exec)
Get the total CPU requirement for executor
|
Double |
TopologyDetails.getTotalMemReqTask(ExecutorDetails exec)
Gets the total memory requirement for a task
|
boolean |
TopologyDetails.hasExecInTopo(ExecutorDetails exec)
Checks if a executor is part of this topology
|
boolean |
SchedulerAssignmentImpl.isExecutorAssigned(ExecutorDetails executor) |
boolean |
SchedulerAssignment.isExecutorAssigned(ExecutorDetails executor)
is the executor assigned?
|
Modifier and Type | Method and Description |
---|---|
void |
SchedulerAssignmentImpl.assign(WorkerSlot slot,
Collection<ExecutorDetails> executors)
Assign the slot to executors.
|
void |
Cluster.assign(WorkerSlot slot,
String topologyId,
Collection<ExecutorDetails> executors)
Assign the slot to the executors for this topology.
|
Map<ExecutorDetails,String> |
TopologyDetails.selectExecutorToComponent(Collection<ExecutorDetails> executors) |
Constructor and Description |
---|
SchedulerAssignmentImpl(String topologyId,
Map<ExecutorDetails,WorkerSlot> executorToSlots) |
TopologyDetails(String topologyId,
Map topologyConf,
StormTopology topology,
int numWorkers,
Map<ExecutorDetails,String> executorToComponents,
int launchTime,
String owner) |
TopologyDetails(String topologyId,
Map topologyConf,
StormTopology topology,
int numWorkers,
Map<ExecutorDetails,String> executorToComponents,
String owner) |
Modifier and Type | Method and Description |
---|---|
void |
Node.assign(String topId,
Collection<ExecutorDetails> executors,
Cluster cluster)
Assign a free slot on the node to the following topology and executors.
|
Modifier and Type | Field and Description |
---|---|
List<ExecutorDetails> |
Component.execs |
Modifier and Type | Method and Description |
---|---|
static Collection<ExecutorDetails> |
RAS_Node.getExecutors(WorkerSlot ws,
Cluster cluster) |
Map<WorkerSlot,Collection<ExecutorDetails>> |
SchedulingResult.getSchedulingResultMap() |
Modifier and Type | Method and Description |
---|---|
void |
RAS_Node.consumeResourcesforTask(ExecutorDetails exec,
TopologyDetails topo)
Consumes a certain amount of resources for a executor in a topology.
|
void |
RAS_Node.freeResourcesForTask(ExecutorDetails exec,
TopologyDetails topo)
frees the amount of resources for a executor in a topology.
|
Modifier and Type | Method and Description |
---|---|
void |
RAS_Node.assign(WorkerSlot target,
TopologyDetails td,
Collection<ExecutorDetails> executors)
Assigns a worker to a node
|
static SchedulingResult |
SchedulingResult.success(Map<WorkerSlot,Collection<ExecutorDetails>> schedulingResultMap) |
static SchedulingResult |
SchedulingResult.successWithMsg(Map<WorkerSlot,Collection<ExecutorDetails>> schedulingResultMap,
String message) |
Constructor and Description |
---|
RAS_Node(String nodeId,
SupervisorDetails sup,
Cluster cluster,
Topologies topologies,
Map<String,WorkerSlot> workerIdToWorker,
Map<String,Map<String,Collection<ExecutorDetails>>> assignmentMap) |
Copyright © 2019 The Apache Software Foundation. All Rights Reserved.