Uses of Interface
org.apache.storm.cluster.IStormClusterState
Package
Description
-
Uses of IStormClusterState in org.apache.storm
Modifier and TypeMethodDescriptionILocalCluster.getClusterState()
This is intended for internal testing only.LocalCluster.getClusterState()
Modifier and TypeMethodDescriptionLocalCluster.Builder.withClusterState
(IStormClusterState clusterState) Use the following clusterState instead of the one in the config. -
Uses of IStormClusterState in org.apache.storm.cluster
Modifier and TypeMethodDescriptionstatic IStormClusterState
ClusterUtils.mkStormClusterState
(Object stateStorage, ILocalAssignmentsBackend backend, ClusterStateContext context) static IStormClusterState
ClusterUtils.mkStormClusterState
(Object stateStorage, ClusterStateContext context) ClusterUtils.mkStormClusterStateImpl
(Object stateStorage, ILocalAssignmentsBackend backend, ClusterStateContext context) -
Uses of IStormClusterState in org.apache.storm.daemon.nimbus
Modifier and TypeMethodDescriptionNimbus.topoIdsToClean
(IStormClusterState state, BlobStore store, Map<String, Object> conf) ModifierConstructorDescriptionNimbus
(Map<String, Object> conf, INimbus inimbus, IStormClusterState stormClusterState, NimbusInfo hostPortInfo, BlobStore blobStore, TopoCache topoCache, ILeaderElector leaderElector, IGroupMappingServiceProvider groupMapper, StormMetricsRegistry metricsRegistry) Nimbus
(Map<String, Object> conf, INimbus inimbus, IStormClusterState stormClusterState, NimbusInfo hostPortInfo, BlobStore blobStore, ILeaderElector leaderElector, IGroupMappingServiceProvider groupMapper, StormMetricsRegistry metricsRegistry) -
Uses of IStormClusterState in org.apache.storm.daemon.supervisor
Modifier and TypeMethodDescriptionprotected Map<String,
Assignment> ReadClusterState.getAssignmentsSnapshot
(IStormClusterState stormClusterState) protected Map<String,
List<ProfileRequest>> ReadClusterState.getProfileActions
(IStormClusterState stormClusterState, List<String> stormIds) ModifierConstructorDescriptionSlot
(AsyncLocalizer localizer, Map<String, Object> conf, ContainerLauncher containerLauncher, String host, int port, LocalState localState, IStormClusterState clusterState, ISupervisor supervisor, AtomicReference<Map<Long, LocalAssignment>> cachedCurrentAssignments, OnlyLatestExecutor<Integer> metricsExec, WorkerMetricsProcessor metricsProcessor, org.apache.storm.daemon.supervisor.SlotMetrics slotMetrics) -
Uses of IStormClusterState in org.apache.storm.daemon.supervisor.timer
Modifier and TypeMethodDescriptionvoid
SynchronizeAssignments.getAssignmentsFromMaster
(Map conf, IStormClusterState clusterState, String node) Used bySupervisor
to fetch assignments when start up. -
Uses of IStormClusterState in org.apache.storm.daemon.worker
ModifierConstructorDescriptionWorkerState
(Map<String, Object> conf, IContext mqContext, String topologyId, String assignmentId, Supplier<SupervisorIfaceFactory> supervisorIfaceSupplier, int port, String workerId, Map<String, Object> topologyConf, IStateStorage stateStorage, IStormClusterState stormClusterState, Collection<IAutoCredentials> autoCredentials, StormMetricRegistry metricRegistry, Credentials initialCredentials) -
Uses of IStormClusterState in org.apache.storm.executor
-
Uses of IStormClusterState in org.apache.storm.executor.error
ModifierConstructorDescriptionReportError
(Map<String, Object> topoConf, IStormClusterState stormClusterState, String stormId, String componentId, WorkerTopologyContext workerTopologyContext) -
Uses of IStormClusterState in org.apache.storm.nimbus
ModifierConstructorDescriptionLeaderListenerCallback
(Map conf, org.apache.storm.shade.org.apache.curator.framework.CuratorFramework zk, BlobStore blobStore, ILeaderElector leaderElector, TopoCache tc, IStormClusterState clusterState, List<org.apache.storm.shade.org.apache.zookeeper.data.ACL> acls, StormMetricsRegistry metricsRegistry) Creates aLeaderListenerCallback
. -
Uses of IStormClusterState in org.apache.storm.security.auth.workertoken
ModifierConstructorDescriptionWorkerTokenManager
(Map<String, Object> daemonConf, IStormClusterState state) Constructor. -
Uses of IStormClusterState in org.apache.storm.stats
Modifier and TypeMethodDescriptionstatic TopologyPageInfo
StatsUtil.aggTopoExecsStats
(String topologyId, Map exec2nodePort, Map task2component, Map<List<Integer>, Map<String, Object>> beats, StormTopology topology, String window, boolean includeSys, IStormClusterState clusterState) aggregate topo executors stats. -
Uses of IStormClusterState in org.apache.storm.zookeeper
Modifier and TypeMethodDescriptionstatic ILeaderElector
Zookeeper.zkLeaderElector
(Map<String, Object> conf, org.apache.storm.shade.org.apache.curator.framework.CuratorFramework zkClient, BlobStore blobStore, TopoCache tc, IStormClusterState clusterState, List<org.apache.storm.shade.org.apache.zookeeper.data.ACL> acls, StormMetricsRegistry metricsRegistry, Object submitLock) Get master leader elector.protected ILeaderElector
Zookeeper.zkLeaderElectorImpl
(Map<String, Object> conf, org.apache.storm.shade.org.apache.curator.framework.CuratorFramework zk, BlobStore blobStore, TopoCache tc, IStormClusterState clusterState, List<org.apache.storm.shade.org.apache.zookeeper.data.ACL> acls, StormMetricsRegistry metricsRegistry, Object submitLock) ModifierConstructorDescriptionLeaderListenerCallbackFactory
(Map<String, Object> conf, org.apache.storm.shade.org.apache.curator.framework.CuratorFramework zk, BlobStore blobStore, TopoCache tc, IStormClusterState clusterState, List<org.apache.storm.shade.org.apache.zookeeper.data.ACL> acls, StormMetricsRegistry metricsRegistry, Object submitLock)