Uses of Class
org.apache.storm.generated.NodeInfo
-
Packages that use NodeInfo Package Description org.apache.storm.cluster org.apache.storm.daemon org.apache.storm.daemon.worker org.apache.storm.generated org.apache.storm.task org.apache.storm.utils -
-
Uses of NodeInfo in org.apache.storm.cluster
Methods in org.apache.storm.cluster with parameters of type NodeInfo Modifier and Type Method Description List<ProfileRequest>
IStormClusterState. getWorkerProfileRequests(String stormId, NodeInfo nodeInfo)
List<ProfileRequest>
StormClusterStateImpl. getWorkerProfileRequests(String stormId, NodeInfo nodeInfo)
Method parameters in org.apache.storm.cluster with type arguments of type NodeInfo Modifier and Type Method Description Map<ExecutorInfo,ExecutorBeat>
IStormClusterState. executorBeats(String stormId, Map<List<Long>,NodeInfo> executorNodePort)
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. -
Uses of NodeInfo in org.apache.storm.daemon
Methods in org.apache.storm.daemon that return types with arguments of type NodeInfo Modifier and Type Method Description static Map<Integer,NodeInfo>
StormCommon. taskToNodeport(Map<List<Long>,NodeInfo> executorToNodePort)
Method parameters in org.apache.storm.daemon with type arguments of type NodeInfo Modifier and Type Method Description static Map<Integer,NodeInfo>
StormCommon. taskToNodeport(Map<List<Long>,NodeInfo> executorToNodePort)
-
Uses of NodeInfo in org.apache.storm.daemon.worker
Methods in org.apache.storm.daemon.worker that return types with arguments of type NodeInfo Modifier and Type Method Description AtomicReference<Map<NodeInfo,IConnection>>
WorkerState. getCachedNodeToPortSocket()
-
Uses of NodeInfo in org.apache.storm.generated
Methods in org.apache.storm.generated that return NodeInfo Modifier and Type Method Description NodeInfo
NodeInfo. deepCopy()
NodeInfo
ProfileRequest. get_nodeInfo()
Methods in org.apache.storm.generated that return types with arguments of type NodeInfo Modifier and Type Method Description Map<List<Long>,NodeInfo>
Assignment. get_executor_node_port()
Map<NodeInfo,WorkerResources>
Assignment. get_worker_resources()
Methods in org.apache.storm.generated with parameters of type NodeInfo Modifier and Type Method Description int
NodeInfo. compareTo(NodeInfo other)
boolean
NodeInfo. equals(NodeInfo that)
void
Assignment. put_to_executor_node_port(List<Long> key, NodeInfo val)
void
Assignment. put_to_worker_resources(NodeInfo key, WorkerResources val)
void
ProfileRequest. set_nodeInfo(NodeInfo nodeInfo)
Method parameters in org.apache.storm.generated with type arguments of type NodeInfo Modifier and Type Method Description void
Assignment. set_executor_node_port(Map<List<Long>,NodeInfo> executor_node_port)
void
Assignment. set_worker_resources(Map<NodeInfo,WorkerResources> worker_resources)
Constructors in org.apache.storm.generated with parameters of type NodeInfo Constructor Description NodeInfo(NodeInfo other)
Performs a deep copy on other.ProfileRequest(NodeInfo nodeInfo, ProfileAction action)
-
Uses of NodeInfo in org.apache.storm.task
Methods in org.apache.storm.task that return types with arguments of type NodeInfo Modifier and Type Method Description AtomicReference<Map<Integer,NodeInfo>>
WorkerTopologyContext. getTaskToNodePort()
Get a map from task Id to NodePort.Constructor parameters in org.apache.storm.task with type arguments of type NodeInfo Constructor Description WorkerTopologyContext(StormTopology topology, Map<String,Object> topoConf, Map<Integer,String> taskToComponent, Map<String,List<Integer>> componentToSortedTasks, Map<String,Map<String,Fields>> componentToStreamToFields, String stormId, String codeDir, String pidDir, Integer workerPort, List<Integer> workerTasks, Map<String,Object> defaultResources, Map<String,Object> userResources, AtomicReference<Map<Integer,NodeInfo>> taskToNodePort, String assignmentId, AtomicReference<Map<String,String>> nodeToHost)
WorkerUserContext(StormTopology topology, Map<String,Object> topoConf, Map<Integer,String> taskToComponent, Map<String,List<Integer>> componentToSortedTasks, Map<String,Map<String,Fields>> componentToStreamToFields, String stormId, String codeDir, String pidDir, Integer workerPort, List<Integer> workerTasks, Map<String,Object> defaultResources, Map<String,Object> userResources, AtomicReference<Map<Integer,NodeInfo>> taskToNodePort, String assignmentId, AtomicReference<Map<String,String>> nodeToHost)
-
Uses of NodeInfo in org.apache.storm.utils
Method parameters in org.apache.storm.utils with type arguments of type NodeInfo Modifier and Type Method Description void
TransferDrainer. send(Map<Integer,NodeInfo> taskToNode, Map<NodeInfo,IConnection> connections)
-