Package | Description |
---|---|
org.apache.storm.cluster | |
org.apache.storm.daemon.ui | |
org.apache.storm.generated | |
org.apache.storm.stats |
Modifier and Type | Method and Description |
---|---|
static Map<ExecutorInfo,ExecutorBeat> |
ClusterUtils.convertExecutorBeats(List<ExecutorInfo> executors,
ClusterWorkerHeartbeat workerHeartbeat)
Ensures that we only return heartbeats for executors assigned to this worker.
|
Map<ExecutorInfo,ExecutorBeat> |
StormClusterStateImpl.executorBeats(String stormId,
Map<List<Long>,NodeInfo> executorNodePort)
need to take executor->node+port in explicitly so that we don’t run into a situation where a long dead worker with a skewed clock overrides all the timestamps.
|
Map<ExecutorInfo,ExecutorBeat> |
IStormClusterState.executorBeats(String stormId,
Map<List<Long>,NodeInfo> executorNodePort) |
Modifier and Type | Method and Description |
---|---|
static Map<ExecutorInfo,ExecutorBeat> |
ClusterUtils.convertExecutorBeats(List<ExecutorInfo> executors,
ClusterWorkerHeartbeat workerHeartbeat)
Ensures that we only return heartbeats for executors assigned to this worker.
|
Modifier and Type | Method and Description |
---|---|
static String |
UIHelpers.prettyExecutorInfo(ExecutorInfo e)
Prettified executor info.
|
Modifier and Type | Method and Description |
---|---|
ExecutorInfo |
ExecutorInfo.deepCopy() |
ExecutorInfo |
ExecutorSummary.get_executor_info() |
Modifier and Type | Method and Description |
---|---|
Map<ExecutorInfo,ExecutorStats> |
ClusterWorkerHeartbeat.get_executor_stats() |
Iterator<ExecutorInfo> |
LSWorkerHeartbeat.get_executors_iterator() |
Iterator<ExecutorInfo> |
SupervisorWorkerHeartbeat.get_executors_iterator() |
Iterator<ExecutorInfo> |
LocalAssignment.get_executors_iterator() |
List<ExecutorInfo> |
LSWorkerHeartbeat.get_executors() |
List<ExecutorInfo> |
SupervisorWorkerHeartbeat.get_executors() |
List<ExecutorInfo> |
LocalAssignment.get_executors() |
Modifier and Type | Method and Description |
---|---|
void |
LSWorkerHeartbeat.add_to_executors(ExecutorInfo elem) |
void |
SupervisorWorkerHeartbeat.add_to_executors(ExecutorInfo elem) |
void |
LocalAssignment.add_to_executors(ExecutorInfo elem) |
int |
ExecutorInfo.compareTo(ExecutorInfo other) |
boolean |
ExecutorInfo.equals(ExecutorInfo that) |
void |
ClusterWorkerHeartbeat.put_to_executor_stats(ExecutorInfo key,
ExecutorStats val) |
void |
ExecutorSummary.set_executor_info(ExecutorInfo executor_info) |
Modifier and Type | Method and Description |
---|---|
void |
ClusterWorkerHeartbeat.set_executor_stats(Map<ExecutorInfo,ExecutorStats> executor_stats) |
void |
LSWorkerHeartbeat.set_executors(List<ExecutorInfo> executors) |
void |
SupervisorWorkerHeartbeat.set_executors(List<ExecutorInfo> executors) |
void |
LocalAssignment.set_executors(List<ExecutorInfo> executors) |
Constructor and Description |
---|
ExecutorInfo(ExecutorInfo other)
Performs a deep copy on other.
|
ExecutorSummary(ExecutorInfo executor_info,
String component_id,
String host,
int port,
int uptime_secs) |
Constructor and Description |
---|
ClusterWorkerHeartbeat(String storm_id,
Map<ExecutorInfo,ExecutorStats> executor_stats,
int time_secs,
int uptime_secs) |
LocalAssignment(String topology_id,
List<ExecutorInfo> executors) |
LSWorkerHeartbeat(int time_secs,
String topology_id,
List<ExecutorInfo> executors,
int port) |
SupervisorWorkerHeartbeat(String storm_id,
List<ExecutorInfo> executors,
int time_secs) |
Modifier and Type | Method and Description |
---|---|
static Map<List<Integer>,Map<String,Object>> |
StatsUtil.convertExecutorBeats(Map<ExecutorInfo,ExecutorBeat> beats)
convert thrift executor heartbeats into a java HashMap.
|
static Map<List<Integer>,ExecutorStats> |
StatsUtil.convertExecutorsStats(Map<ExecutorInfo,ExecutorStats> stats)
convert executors stats into a HashMap, note that ExecutorStats are remained unchanged.
|
Copyright © 2022 The Apache Software Foundation. All rights reserved.