Package | Description |
---|---|
org.apache.storm.scheduler | |
org.apache.storm.scheduler.multitenant | |
org.apache.storm.scheduler.resource |
Modifier and Type | Method and Description |
---|---|
Collection<WorkerSlot> |
INimbus.allSlotsAvailableForScheduling(Collection<SupervisorDetails> existingSupervisors,
Topologies topologies,
Set<String> topologiesMissingAssignments)
Returns all slots that are available for the next round of scheduling.
|
void |
INimbus.assignSlots(Topologies topologies,
Map<String,Collection<WorkerSlot>> newSlotsByTopologyId)
this is called after the assignment is changed in ZK
|
List<TopologyDetails> |
Cluster.needsSchedulingTopologies(Topologies topologies) |
void |
IScheduler.schedule(Topologies topologies,
Cluster cluster)
Set assignments for the topologies which needs scheduling.
|
void |
Cluster.updateAssignedCpuForTopologyAndSupervisor(Topologies topologies)
Update CPU usage for each topology and each supervisor node
|
void |
Cluster.updateAssignedMemoryForTopologyAndSupervisor(Topologies topologies) |
Constructor and Description |
---|
Topologies(Topologies src)
copy constructor
|
Modifier and Type | Method and Description |
---|---|
void |
MultitenantScheduler.schedule(Topologies topologies,
Cluster cluster) |
Modifier and Type | Field and Description |
---|---|
Topologies |
SchedulingState.topologies |
Modifier and Type | Method and Description |
---|---|
static Map<String,RAS_Node> |
RAS_Nodes.getAllNodesFrom(Cluster cluster,
Topologies topologies) |
static String |
ResourceUtils.printScheduling(Cluster cluster,
Topologies topologies)
print scheduling for debug purposes
|
void |
ResourceAwareScheduler.schedule(Topologies topologies,
Cluster cluster) |
Constructor and Description |
---|
RAS_Node(String nodeId,
SupervisorDetails sup,
Cluster cluster,
Topologies topologies,
Map<String,WorkerSlot> workerIdToWorker,
Map<String,Map<String,Collection<ExecutorDetails>>> assignmentMap) |
RAS_Nodes(Cluster cluster,
Topologies topologies) |
SchedulingState(Map<String,User> userMap,
Cluster cluster,
Topologies topologies,
Map conf) |
Copyright © 2022 The Apache Software Foundation. All Rights Reserved.