Package | Description |
---|---|
org.apache.storm.generated | |
org.apache.storm.scheduler | |
org.apache.storm.scheduler.resource.normalization | |
org.apache.storm.stats |
Modifier and Type | Method and Description |
---|---|
WorkerResources |
WorkerResources.deepCopy() |
WorkerResources |
LocalAssignment.get_resources() |
Modifier and Type | Method and Description |
---|---|
Map<NodeInfo,WorkerResources> |
Assignment.get_worker_resources() |
Modifier and Type | Method and Description |
---|---|
int |
WorkerResources.compareTo(WorkerResources other) |
boolean |
WorkerResources.equals(WorkerResources that) |
void |
Assignment.put_to_worker_resources(NodeInfo key,
WorkerResources val) |
void |
LocalAssignment.set_resources(WorkerResources resources) |
Modifier and Type | Method and Description |
---|---|
void |
Assignment.set_worker_resources(Map<NodeInfo,WorkerResources> worker_resources) |
Constructor and Description |
---|
WorkerResources(WorkerResources other)
Performs a deep copy on other.
|
Modifier and Type | Method and Description |
---|---|
WorkerResources |
Cluster.getWorkerResources(WorkerSlot ws) |
WorkerResources |
ISchedulingState.getWorkerResources(WorkerSlot ws)
Get the resources for a given slot.
|
Modifier and Type | Method and Description |
---|---|
Map<WorkerSlot,WorkerResources> |
SchedulerAssignment.getScheduledResources()
Get the slot to resource mapping.
|
Map<WorkerSlot,WorkerResources> |
SchedulerAssignmentImpl.getScheduledResources() |
Map<String,Map<WorkerSlot,WorkerResources>> |
Cluster.getWorkerResourcesMap() |
Map<String,Map<WorkerSlot,WorkerResources>> |
ISchedulingState.getWorkerResourcesMap()
Gets the reference to the full topology->worker resource map.
|
Modifier and Type | Method and Description |
---|---|
SupervisorResources |
SupervisorResources.add(WorkerResources wr) |
void |
SchedulerAssignmentImpl.assign(WorkerSlot slot,
Collection<ExecutorDetails> executors,
WorkerResources slotResources)
Assign the slot to executors.
|
Constructor and Description |
---|
SchedulerAssignmentImpl(String topologyId,
Map<ExecutorDetails,WorkerSlot> executorToSlot,
Map<WorkerSlot,WorkerResources> resources,
Map<String,Double> nodeIdToTotalSharedOffHeap)
Create a new assignment.
|
Modifier and Type | Method and Description |
---|---|
void |
NormalizedResources.add(WorkerResources value)
Add the resources from a worker to this.
|
void |
NormalizedResourceRequest.add(WorkerResources value)
Add the resources from a worker to those in this.
|
boolean |
NormalizedResources.remove(WorkerResources value)
Remove the resources of a worker from this.
|
boolean |
NormalizedResourceOffer.remove(WorkerResources other,
ResourceMetrics resourceMetrics)
Remove the resources in other from this.
|
Modifier and Type | Method and Description |
---|---|
static List<WorkerSummary> |
StatsUtil.aggWorkerStats(String stormId,
String stormName,
Map<Integer,String> task2Component,
Map<List<Integer>,Map<String,Object>> beats,
Map<List<Long>,List<Object>> exec2NodePort,
Map<String,String> nodeHost,
Map<WorkerSlot,WorkerResources> worker2Resources,
boolean includeSys,
boolean userAuthorized,
String filterSupervisor,
String owner)
aggregate statistics per worker for a topology.
|
Copyright © 2022 The Apache Software Foundation. All rights reserved.