Modifier and Type | Method and Description |
---|---|
void |
TopologyDetails.addResourcesForExec(ExecutorDetails exec,
NormalizedResourceRequest resourceList)
add resource requirements for a executor.
|
String |
TopologyDetails.getComponentFromExecutor(ExecutorDetails exec) |
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.
|
NormalizedResourceRequest |
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.
|
NormalizedResourceRequest |
TopologyDetails.getTotalResources(ExecutorDetails exec)
Get the total resource requirement for an executor.
|
boolean |
TopologyDetails.hasExecInTopo(ExecutorDetails exec)
Checks if a executor is part of this topology.
|
boolean |
SchedulerAssignment.isExecutorAssigned(ExecutorDetails executor)
Is the executor assigned or not.
|
boolean |
SchedulerAssignmentImpl.isExecutorAssigned(ExecutorDetails executor) |
boolean |
Cluster.wouldFit(WorkerSlot ws,
ExecutorDetails exec,
TopologyDetails td,
NormalizedResourceOffer resourcesAvailable,
double maxHeap) |
boolean |
ISchedulingState.wouldFit(WorkerSlot ws,
ExecutorDetails exec,
TopologyDetails td,
NormalizedResourceOffer resourcesAvailable,
double maxHeap)
Would scheduling exec on ws fit? With a heap <= maxHeap total memory added <= memoryAvailable and cpu added <= cpuAvailable.
|
Modifier and Type | Method and Description |
---|---|
void |
SchedulerAssignmentImpl.assign(WorkerSlot slot,
Collection<ExecutorDetails> executors)
Deprecated.
|
void |
SchedulerAssignmentImpl.assign(WorkerSlot slot,
Collection<ExecutorDetails> executors,
WorkerResources slotResources)
Assign the slot to executors.
|
void |
Cluster.assign(WorkerSlot slot,
String topologyId,
Collection<ExecutorDetails> executors)
Assign the slot to the executors for this topology.
|
NormalizedResourceRequest |
TopologyDetails.getApproximateResources(Set<ExecutorDetails> execs)
Get approximate resources for given topology executors.
|
Set<SharedMemory> |
TopologyDetails.getSharedMemoryRequests(Collection<ExecutorDetails> executors)
Gets the total memory resource list for a set of tasks that is part of a topology.
|
Map<ExecutorDetails,String> |
TopologyDetails.selectExecutorToComponent(Collection<ExecutorDetails> executors) |
Constructor and Description |
---|
Component(ComponentType type,
String compId,
List<ExecutorDetails> execs,
Map<GlobalStreamId,Grouping> inputs)
Create a new component.
|
SchedulerAssignmentImpl(String topologyId,
Map<ExecutorDetails,WorkerSlot> executorToSlot,
Map<WorkerSlot,WorkerResources> resources,
Map<String,Double> nodeIdToTotalSharedOffHeap)
Create a new assignment.
|
TopologyDetails(String topologyId,
Map<String,Object> topologyConf,
StormTopology topology,
int numWorkers,
Map<ExecutorDetails,String> executorToComponents,
int launchTime,
String owner) |
TopologyDetails(String topologyId,
Map<String,Object> 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 | Method and Description |
---|---|
void |
RasNode.assignSingleExecutor(WorkerSlot ws,
ExecutorDetails exec,
TopologyDetails td)
Assign a single executor to a slot, even if other things are in the slot.
|
boolean |
RasNode.couldEverFit(ExecutorDetails exec,
TopologyDetails td)
Is there any possibility that exec could ever fit on this node.
|
void |
RasNode.freeSingleExecutor(ExecutorDetails exec,
TopologyDetails topo)
frees a single executor.
|
boolean |
RasNode.wouldFit(WorkerSlot ws,
ExecutorDetails exec,
TopologyDetails td)
Would scheduling exec in ws fit with the current resource constraints.
|
Modifier and Type | Method and Description |
---|---|
void |
RasNode.assign(WorkerSlot target,
TopologyDetails td,
Collection<ExecutorDetails> executors)
Assigns a worker to a node.
|
Constructor and Description |
---|
RasNode(String nodeId,
SupervisorDetails sup,
Cluster cluster,
Map<String,WorkerSlot> workerIdToWorker,
Map<String,Map<String,Collection<ExecutorDetails>>> assignmentMap)
Create a new node.
|
Modifier and Type | Method and Description |
---|---|
ExecutorDetails |
ConstraintSolverStrategy.SearcherState.currentExec() |
Modifier and Type | Method and Description |
---|---|
protected List<ExecutorDetails> |
BaseResourceAwareStrategy.orderExecutors(TopologyDetails td,
Collection<ExecutorDetails> unassignedExecutors) |
Modifier and Type | Method and Description |
---|---|
void |
ConstraintSolverStrategy.SearcherState.backtrack(Map<ExecutorDetails,String> execToComp,
RasNode node,
WorkerSlot workerSlot) |
protected List<ExecutorDetails> |
BaseResourceAwareStrategy.orderExecutors(TopologyDetails td,
Collection<ExecutorDetails> unassignedExecutors) |
protected boolean |
BaseResourceAwareStrategy.scheduleExecutor(ExecutorDetails exec,
TopologyDetails td,
Collection<ExecutorDetails> scheduledTasks,
Iterable<String> sortedNodes)
Schedule executor exec from topology td.
|
void |
ConstraintSolverStrategy.SearcherState.tryToSchedule(Map<ExecutorDetails,String> execToComp,
RasNode node,
WorkerSlot workerSlot)
Assign executor to worker and node.
|
Copyright © 2022 The Apache Software Foundation. All rights reserved.