Modifier and Type | Method and Description |
---|---|
IStormClusterState |
LocalCluster.getClusterState() |
IStormClusterState |
ILocalCluster.getClusterState()
This is intended for internal testing only.
|
Modifier and Type | Method and Description |
---|---|
LocalCluster.Builder |
LocalCluster.Builder.withClusterState(IStormClusterState clusterState)
Use the following clusterState instead of the one in the config.
|
Modifier and Type | Class and Description |
---|---|
class |
StormClusterStateImpl |
Modifier and Type | Method and Description |
---|---|
static IStormClusterState |
ClusterUtils.mkStormClusterState(Object stateStorage,
ClusterStateContext context) |
static IStormClusterState |
ClusterUtils.mkStormClusterState(Object stateStorage,
ILocalAssignmentsBackend backend,
ClusterStateContext context) |
IStormClusterState |
ClusterUtils.mkStormClusterStateImpl(Object stateStorage,
ILocalAssignmentsBackend backend,
ClusterStateContext context) |
Modifier and Type | Method and Description |
---|---|
static Set<String> |
Nimbus.topoIdsToClean(IStormClusterState state,
BlobStore store,
Map<String,Object> conf) |
Constructor and Description |
---|
Nimbus(Map<String,Object> conf,
INimbus inimbus,
IStormClusterState stormClusterState,
NimbusInfo hostPortInfo,
BlobStore blobStore,
ILeaderElector leaderElector,
IGroupMappingServiceProvider groupMapper,
StormMetricsRegistry metricsRegistry) |
Nimbus(Map<String,Object> conf,
INimbus inimbus,
IStormClusterState stormClusterState,
NimbusInfo hostPortInfo,
BlobStore blobStore,
TopoCache topoCache,
ILeaderElector leaderElector,
IGroupMappingServiceProvider groupMapper,
StormMetricsRegistry metricsRegistry) |
Modifier and Type | Method and Description |
---|---|
IStormClusterState |
Supervisor.getStormClusterState() |
Modifier and Type | Method and Description |
---|---|
protected Map<String,Assignment> |
ReadClusterState.getAssignmentsSnapshot(IStormClusterState stormClusterState) |
protected Map<String,List<ProfileRequest>> |
ReadClusterState.getProfileActions(IStormClusterState stormClusterState,
List<String> stormIds) |
Constructor and 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) |
Modifier and Type | Method and Description |
---|---|
void |
SynchronizeAssignments.getAssignmentsFromMaster(Map conf,
IStormClusterState clusterState,
String node)
Used by
Supervisor to fetch assignments when start up. |
Constructor and 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) |
Modifier and Type | Field and Description |
---|---|
protected IStormClusterState |
Executor.stormClusterState |
Modifier and Type | Method and Description |
---|---|
IStormClusterState |
Executor.getStormClusterState() |
Constructor and Description |
---|
ReportError(Map<String,Object> topoConf,
IStormClusterState stormClusterState,
String stormId,
String componentId,
WorkerTopologyContext workerTopologyContext) |
Constructor and 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)
Constructor for .
|
Constructor and Description |
---|
WorkerTokenManager(Map<String,Object> daemonConf,
IStormClusterState state)
Constructor.
|
Modifier and Type | Method and 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.
|
Modifier and Type | Method and 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)
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) |
Constructor and 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) |
Copyright © 2022 The Apache Software Foundation. All rights reserved.