Uses of Interface
org.apache.storm.cluster.IStormClusterState
-
-
Uses of IStormClusterState in org.apache.storm
Methods in org.apache.storm that return IStormClusterState Modifier and Type Method Description IStormClusterState
ILocalCluster. getClusterState()
This is intended for internal testing only.IStormClusterState
LocalCluster. getClusterState()
Methods in org.apache.storm with parameters of type IStormClusterState Modifier and Type Method Description LocalCluster.Builder
LocalCluster.Builder. withClusterState(IStormClusterState clusterState)
Use the following clusterState instead of the one in the config. -
Uses of IStormClusterState in org.apache.storm.cluster
Classes in org.apache.storm.cluster that implement IStormClusterState Modifier and Type Class Description class
StormClusterStateImpl
Methods in org.apache.storm.cluster that return IStormClusterState Modifier and Type Method Description static IStormClusterState
ClusterUtils. mkStormClusterState(Object stateStorage, ILocalAssignmentsBackend backend, ClusterStateContext context)
static IStormClusterState
ClusterUtils. mkStormClusterState(Object stateStorage, ClusterStateContext context)
IStormClusterState
ClusterUtils. mkStormClusterStateImpl(Object stateStorage, ILocalAssignmentsBackend backend, ClusterStateContext context)
-
Uses of IStormClusterState in org.apache.storm.daemon.nimbus
Methods in org.apache.storm.daemon.nimbus with parameters of type IStormClusterState Modifier and Type Method Description static Set<String>
Nimbus. topoIdsToClean(IStormClusterState state, BlobStore store, Map<String,Object> conf)
Constructors in org.apache.storm.daemon.nimbus with parameters of type IStormClusterState Constructor Description Nimbus(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
Methods in org.apache.storm.daemon.supervisor that return IStormClusterState Modifier and Type Method Description IStormClusterState
Supervisor. getStormClusterState()
Methods in org.apache.storm.daemon.supervisor with parameters of type IStormClusterState Modifier and Type Method Description protected 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 IStormClusterState Constructor Description Slot(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
Methods in org.apache.storm.daemon.supervisor.timer with parameters of type IStormClusterState Modifier and Type Method Description void
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
Constructors in org.apache.storm.daemon.worker with parameters of type IStormClusterState Constructor Description WorkerState(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
Fields in org.apache.storm.executor declared as IStormClusterState Modifier and Type Field Description protected IStormClusterState
Executor. stormClusterState
Methods in org.apache.storm.executor that return IStormClusterState Modifier and Type Method Description IStormClusterState
Executor. getStormClusterState()
-
Uses of IStormClusterState in org.apache.storm.executor.error
Constructors in org.apache.storm.executor.error with parameters of type IStormClusterState Constructor Description ReportError(Map<String,Object> topoConf, IStormClusterState stormClusterState, String stormId, String componentId, WorkerTopologyContext workerTopologyContext)
-
Uses of IStormClusterState in org.apache.storm.nimbus
Constructors in org.apache.storm.nimbus with parameters of type IStormClusterState Constructor Description LeaderListenerCallback(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
Constructors in org.apache.storm.security.auth.workertoken with parameters of type IStormClusterState Constructor Description WorkerTokenManager(Map<String,Object> daemonConf, IStormClusterState state)
Constructor. -
Uses of IStormClusterState in org.apache.storm.stats
Methods in org.apache.storm.stats with parameters of type IStormClusterState Modifier and Type Method Description static 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
Methods in org.apache.storm.zookeeper with parameters of type IStormClusterState Modifier and Type Method Description static 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)
Constructors in org.apache.storm.zookeeper with parameters of type IStormClusterState Constructor Description LeaderListenerCallbackFactory(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)
-