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.
|
List<WorkerSlot> |
Cluster.getAssignableSlots() |
List<WorkerSlot> |
Cluster.getAssignableSlots(SupervisorDetails supervisor) |
List<WorkerSlot> |
Cluster.getAvailableSlots() |
List<WorkerSlot> |
Cluster.getAvailableSlots(SupervisorDetails supervisor)
Return all the available slots on this supervisor.
|
Map<ExecutorDetails,WorkerSlot> |
SchedulerAssignmentImpl.getExecutorToSlot() |
Map<ExecutorDetails,WorkerSlot> |
SchedulerAssignment.getExecutorToSlot()
get the executor -> slot map.
|
Set<WorkerSlot> |
SchedulerAssignmentImpl.getSlots() |
Set<WorkerSlot> |
SchedulerAssignment.getSlots() |
Map<WorkerSlot,Collection<ExecutorDetails>> |
SchedulerAssignmentImpl.getSlotToExecutors() |
Map<WorkerSlot,Collection<ExecutorDetails>> |
SchedulerAssignment.getSlotToExecutors() |
Collection<WorkerSlot> |
Cluster.getUsedSlots() |
Collection<WorkerSlot> |
Cluster.getUsedSlotsByTopologyId(String topologyId)
get slots used by a topology
|
Map<String,Map<WorkerSlot,Double[]>> |
Cluster.getWorkerResourcesMap()
Gets the reference to the full topology->worker resource map.
|
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.
|
void |
Cluster.freeSlot(WorkerSlot slot)
Free the specified slot.
|
boolean |
SchedulerAssignmentImpl.isSlotOccupied(WorkerSlot slot) |
boolean |
SchedulerAssignment.isSlotOccupied(WorkerSlot slot)
Does this slot occupied by this assignment?
|
boolean |
Cluster.isSlotOccupied(WorkerSlot slot) |
void |
SchedulerAssignmentImpl.unassignBySlot(WorkerSlot slot)
Release the slot occupied by this assignment.
|
Modifier and Type | Method and Description |
---|---|
void |
INimbus.assignSlots(Topologies topologies,
Map<String,Collection<WorkerSlot>> newSlotsByTopologyId)
this is called after the assignment is changed in ZK
|
void |
Cluster.freeSlots(Collection<WorkerSlot> slots)
free the slots.
|
void |
Cluster.setWorkerResources(String topologyId,
Map<WorkerSlot,Double[]> resources)
Set the worker resources map for a specific topologyId
|
void |
Cluster.setWorkerResourcesMap(Map<String,Map<WorkerSlot,Double[]>> resources)
Set the worker resources map for all topologies in source
|
Constructor and Description |
---|
SchedulerAssignmentImpl(String topologyId,
Map<ExecutorDetails,WorkerSlot> executorToSlots) |
Modifier and Type | Method and Description |
---|---|
void |
Node.free(WorkerSlot ws,
Cluster cluster,
boolean forceFree)
Frees a single slot in this node
|
Modifier and Type | Method and Description |
---|---|
Collection<WorkerSlot> |
RAS_Node.getFreeSlots() |
Map<WorkerSlot,Collection<ExecutorDetails>> |
SchedulingResult.getSchedulingResultMap() |
Collection<WorkerSlot> |
RAS_Node.getUsedSlots() |
Collection<WorkerSlot> |
RAS_Node.getUsedSlots(String topId) |
Modifier and Type | Method and Description |
---|---|
void |
RAS_Node.assign(WorkerSlot target,
TopologyDetails td,
Collection<ExecutorDetails> executors)
Assigns a worker to a node
|
TopologyDetails |
RAS_Node.findTopologyUsingWorker(WorkerSlot ws)
Find a which topology is running on a worker slot
|
void |
RAS_Node.free(WorkerSlot ws)
Frees a single slot in this node
|
double |
RAS_Node.getCpuUsedByWorker(WorkerSlot ws)
get the amount of cpu used by a worker
|
static Collection<ExecutorDetails> |
RAS_Node.getExecutors(WorkerSlot ws,
Cluster cluster) |
double |
RAS_Node.getMemoryUsedByWorker(WorkerSlot ws)
get the amount of memory used by a worker
|
Modifier and Type | Method and Description |
---|---|
void |
RAS_Nodes.freeSlots(Collection<WorkerSlot> workerSlots) |
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.