Package | Description |
---|---|
org.apache.storm.daemon.nimbus | |
org.apache.storm.scheduler | |
org.apache.storm.scheduler.resource |
Modifier and Type | Method and Description |
---|---|
Collection<WorkerSlot> |
Nimbus.StandaloneINimbus.allSlotsAvailableForScheduling(Collection<SupervisorDetails> supervisors,
Topologies topologies,
Set<String> topologiesMissingAssignments) |
String |
Nimbus.StandaloneINimbus.getHostName(Map<String,SupervisorDetails> supervisors,
String nodeId) |
Modifier and Type | Method and Description |
---|---|
SupervisorDetails |
Cluster.getSupervisorById(String nodeId) |
SupervisorDetails |
ISchedulingState.getSupervisorById(String nodeId)
Get a specific supervisor with the
nodeId . |
Modifier and Type | Method and Description |
---|---|
Map<String,SupervisorDetails> |
Cluster.getSupervisors() |
Map<String,SupervisorDetails> |
ISchedulingState.getSupervisors()
Get all the supervisors.
|
List<SupervisorDetails> |
Cluster.getSupervisorsByHost(String host) |
List<SupervisorDetails> |
ISchedulingState.getSupervisorsByHost(String host)
Get all the supervisors on the specified
host . |
Modifier and Type | Method and Description |
---|---|
Set<Integer> |
Cluster.getAssignablePorts(SupervisorDetails supervisor) |
Set<Integer> |
ISchedulingState.getAssignablePorts(SupervisorDetails supervisor)
Get the ports that are not blacklisted.
|
List<WorkerSlot> |
Cluster.getAssignableSlots(SupervisorDetails supervisor) |
List<WorkerSlot> |
ISchedulingState.getAssignableSlots(SupervisorDetails supervisor)
Return all non-blacklisted slots on this supervisor.
|
Set<Integer> |
Cluster.getAvailablePorts(SupervisorDetails supervisor) |
Set<Integer> |
ISchedulingState.getAvailablePorts(SupervisorDetails supervisor)
Return the available ports of this supervisor.
|
NormalizedResourceOffer |
Cluster.getAvailableResources(SupervisorDetails sd) |
NormalizedResourceOffer |
ISchedulingState.getAvailableResources(SupervisorDetails sd)
Get the resources on the supervisor that are available to be scheduled.
|
List<WorkerSlot> |
Cluster.getAvailableSlots(SupervisorDetails supervisor) |
List<WorkerSlot> |
ISchedulingState.getAvailableSlots(SupervisorDetails supervisor)
Return all the available slots on this supervisor.
|
Set<Integer> |
Cluster.getUsedPorts(SupervisorDetails supervisor) |
Set<Integer> |
ISchedulingState.getUsedPorts(SupervisorDetails supervisor)
Get all the used ports of this supervisor.
|
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.
|
String |
INimbus.getHostName(Map<String,SupervisorDetails> existingSupervisors,
String nodeId)
map from node id to supervisor details.
|
Constructor and Description |
---|
Cluster(INimbus nimbus,
ResourceMetrics resourceMetrics,
Map<String,SupervisorDetails> supervisors,
Map<String,? extends SchedulerAssignment> map,
Topologies topologies,
Map<String,Object> conf) |
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.
|
Copyright © 2022 The Apache Software Foundation. All rights reserved.