Uses of Interface
org.apache.storm.cluster.IStormClusterState
Packages that use IStormClusterState
Package
Description
- 
Uses of IStormClusterState in org.apache.stormMethods in org.apache.storm that return IStormClusterStateModifier and TypeMethodDescriptionILocalCluster.getClusterState()This is intended for internal testing only.LocalCluster.getClusterState()Methods in org.apache.storm with parameters of type IStormClusterStateModifier and TypeMethodDescriptionLocalCluster.Builder.withClusterState(IStormClusterState clusterState) Use the following clusterState instead of the one in the config.
- 
Uses of IStormClusterState in org.apache.storm.clusterClasses in org.apache.storm.cluster that implement IStormClusterStateMethods in org.apache.storm.cluster that return IStormClusterStateModifier and TypeMethodDescriptionstatic IStormClusterStateClusterUtils.mkStormClusterState(Object stateStorage, ILocalAssignmentsBackend backend, ClusterStateContext context) static IStormClusterStateClusterUtils.mkStormClusterState(Object stateStorage, ClusterStateContext context) ClusterUtils.mkStormClusterStateImpl(Object stateStorage, ILocalAssignmentsBackend backend, ClusterStateContext context) 
- 
Uses of IStormClusterState in org.apache.storm.daemon.nimbusMethods in org.apache.storm.daemon.nimbus with parameters of type IStormClusterStateModifier and TypeMethodDescriptionNimbus.topoIdsToClean(IStormClusterState state, BlobStore store, Map<String, Object> conf) Constructors in org.apache.storm.daemon.nimbus with parameters of type IStormClusterStateModifierConstructorDescriptionNimbus(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.supervisorMethods in org.apache.storm.daemon.supervisor that return IStormClusterStateMethods in org.apache.storm.daemon.supervisor with parameters of type IStormClusterStateModifier and TypeMethodDescriptionprotected Map<String,Assignment> ReadClusterState.getAssignmentsSnapshot(IStormClusterState stormClusterState) protected Map<String,List<ProfileRequest>> ReadClusterState.getProfileActions(IStormClusterState stormClusterState, List<String> stormIds) Constructors in org.apache.storm.daemon.supervisor with parameters of type IStormClusterStateModifierConstructorDescriptionSlot(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.timerMethods in org.apache.storm.daemon.supervisor.timer with parameters of type IStormClusterStateModifier and TypeMethodDescriptionvoidSynchronizeAssignments.getAssignmentsFromMaster(Map conf, IStormClusterState clusterState, String node) Used bySupervisorto fetch assignments when start up.
- 
Uses of IStormClusterState in org.apache.storm.daemon.workerConstructors in org.apache.storm.daemon.worker with parameters of type IStormClusterStateModifierConstructorDescriptionWorkerState(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.executorFields in org.apache.storm.executor declared as IStormClusterStateMethods in org.apache.storm.executor that return IStormClusterState
- 
Uses of IStormClusterState in org.apache.storm.executor.errorConstructors in org.apache.storm.executor.error with parameters of type IStormClusterStateModifierConstructorDescriptionReportError(Map<String, Object> topoConf, IStormClusterState stormClusterState, String stormId, String componentId, WorkerTopologyContext workerTopologyContext) 
- 
Uses of IStormClusterState in org.apache.storm.nimbusConstructors in org.apache.storm.nimbus with parameters of type IStormClusterStateModifierConstructorDescriptionLeaderListenerCallback(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.workertokenConstructors in org.apache.storm.security.auth.workertoken with parameters of type IStormClusterStateModifierConstructorDescriptionWorkerTokenManager(Map<String, Object> daemonConf, IStormClusterState state) Constructor.
- 
Uses of IStormClusterState in org.apache.storm.statsMethods in org.apache.storm.stats with parameters of type IStormClusterStateModifier and TypeMethodDescriptionstatic TopologyPageInfoStatsUtil.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.zookeeperMethods in org.apache.storm.zookeeper with parameters of type IStormClusterStateModifier and TypeMethodDescriptionstatic ILeaderElectorZookeeper.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 ILeaderElectorZookeeper.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) Constructors in org.apache.storm.zookeeper with parameters of type IStormClusterStateModifierConstructorDescriptionLeaderListenerCallbackFactory(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)