Modifier and Type | Method and Description |
---|---|
StormMetricsRegistry |
LocalCluster.getMetricRegistry()
Reference to metrics registry.
|
Constructor and Description |
---|
LocalDRPC(StormMetricsRegistry metricsRegistry)
Creates a LocalDRPC with the specified metrics registry.
|
Constructor and Description |
---|
DRPC(StormMetricsRegistry metricsRegistry,
IAuthorizer auth,
long timeoutMs) |
DRPC(StormMetricsRegistry metricsRegistry,
Map<String,Object> conf) |
DRPCServer(Map<String,Object> conf,
StormMetricsRegistry metricsRegistry)
Constructor.
|
Modifier and Type | Method and Description |
---|---|
static void |
DRPCApplication.setup(DRPC drpc,
StormMetricsRegistry metricsRegistry) |
Constructor and Description |
---|
DRPCResource(DRPC drpc,
StormMetricsRegistry metricsRegistry) |
Constructor and Description |
---|
LogviewerServer(Map<String,Object> conf,
StormMetricsRegistry metricsRegistry)
Constructor.
|
Constructor and Description |
---|
LogviewerLogDownloadHandler(String logRoot,
String daemonLogRoot,
WorkerLogs workerLogs,
ResourceAuthorizer resourceAuthorizer,
StormMetricsRegistry metricsRegistry)
Constructor.
|
LogviewerLogPageHandler(String logRoot,
String daemonLogRoot,
WorkerLogs workerLogs,
ResourceAuthorizer resourceAuthorizer,
StormMetricsRegistry metricsRegistry)
Constructor.
|
LogviewerLogSearchHandler(Map<String,Object> stormConf,
Path logRoot,
Path daemonLogRoot,
ResourceAuthorizer resourceAuthorizer,
StormMetricsRegistry metricsRegistry)
Constructor.
|
LogviewerProfileHandler(String logRoot,
ResourceAuthorizer resourceAuthorizer,
StormMetricsRegistry metricsRegistry)
Constructor.
|
Modifier and Type | Method and Description |
---|---|
static void |
ExceptionMeterNames.registerMeters(StormMetricsRegistry registry)
It may be helpful to register these meters up front, so they are output even if their values are zero.
|
Constructor and Description |
---|
DirectoryCleaner(StormMetricsRegistry metricsRegistry) |
LogCleaner(Map<String,Object> stormConf,
WorkerLogs workerLogs,
DirectoryCleaner directoryCleaner,
Path logRootDir,
StormMetricsRegistry metricsRegistry)
Constuctor.
|
LogFileDownloader(String logRoot,
String daemonLogRoot,
ResourceAuthorizer resourceAuthorizer,
StormMetricsRegistry metricsRegistry)
Constructor.
|
WorkerLogs(Map<String,Object> stormConf,
Path logRootDir,
StormMetricsRegistry metricsRegistry)
Constructor.
|
Modifier and Type | Method and Description |
---|---|
static void |
LogviewerApplication.setup(Map<String,Object> stormConf,
StormMetricsRegistry metricRegistry)
Spot to inject storm configuration before initializing LogviewerApplication instance.
|
Constructor and Description |
---|
LogviewerResource(LogviewerLogPageHandler logviewerParam,
LogviewerProfileHandler profileHandler,
LogviewerLogDownloadHandler logDownloadHandler,
LogviewerLogSearchHandler logSearchHandler,
IHttpCredentialsPlugin httpCredsHandler,
StormMetricsRegistry metricsRegistry)
Constructor.
|
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) |
Nimbus(Map<String,Object> conf,
INimbus inimbus,
StormMetricsRegistry metricsRegistry) |
Modifier and Type | Method and Description |
---|---|
StormMetricsRegistry |
Supervisor.getMetricsRegistry() |
Modifier and Type | Method and Description |
---|---|
static ContainerLauncher |
ContainerLauncher.make(Map<String,Object> conf,
String supervisorId,
int supervisorPort,
IContext sharedContext,
StormMetricsRegistry metricsRegistry,
ContainerMemoryTracker containerMemoryTracker,
Supervisor.Iface localSupervisor)
Factory to create the right container launcher for the config and the environment.
|
Constructor and Description |
---|
BasicContainer(Container.ContainerType type,
Map<String,Object> conf,
String supervisorId,
int supervisorPort,
int port,
LocalAssignment assignment,
ResourceIsolationInterface resourceIsolationManager,
LocalState localState,
String workerId,
StormMetricsRegistry metricsRegistry,
ContainerMemoryTracker containerMemoryTracker)
Create a new BasicContainer.
|
BasicContainerLauncher(Map<String,Object> conf,
String supervisorId,
int supervisorPort,
ResourceIsolationInterface resourceIsolationManager,
StormMetricsRegistry metricsRegistry,
ContainerMemoryTracker containerMemoryTracker) |
Container(Container.ContainerType type,
Map<String,Object> conf,
String supervisorId,
int supervisorPort,
int port,
LocalAssignment assignment,
ResourceIsolationInterface resourceIsolationManager,
String workerId,
Map<String,Object> topoConf,
AdvancedFSOps ops,
StormMetricsRegistry metricsRegistry,
ContainerMemoryTracker containerMemoryTracker)
Create a new Container.
|
ContainerMemoryTracker(StormMetricsRegistry metricsRegistry) |
LocalContainer(Map<String,Object> conf,
String supervisorId,
int supervisorPort,
int port,
LocalAssignment assignment,
IContext sharedContext,
StormMetricsRegistry metricsRegistry,
ContainerMemoryTracker containerMemoryTracker,
Supervisor.Iface localSupervisor) |
LocalContainerLauncher(Map<String,Object> conf,
String supervisorId,
int supervisorPort,
IContext sharedContext,
StormMetricsRegistry metricsRegistry,
ContainerMemoryTracker containerMemoryTracker,
Supervisor.Iface localSupervisor) |
Supervisor(Map<String,Object> conf,
IContext sharedContext,
ISupervisor iSupervisor,
StormMetricsRegistry metricsRegistry)
Constructor for supervisor daemon.
|
Constructor and Description |
---|
HeaderResponseFilter(StormMetricsRegistry metricsRegistry) |
HeaderResponseServletFilter(StormMetricsRegistry metricsRegistry) |
Constructor and Description |
---|
StormApiResource(StormMetricsRegistry metricsRegistry) |
Modifier and Type | Method and Description |
---|---|
static int |
HealthChecker.healthCheck(Map<String,Object> conf,
StormMetricsRegistry metricRegistry) |
Constructor and Description |
---|
AsyncLocalizer(Map<String,Object> conf,
StormMetricsRegistry metricsRegistry) |
LocallyCachedBlob(String blobDescription,
String blobKey,
StormMetricsRegistry metricsRegistry)
Create a new LocallyCachedBlob.
|
LocallyCachedTopologyBlob(String topologyId,
boolean isLocalMode,
Map<String,Object> conf,
AdvancedFSOps fsOps,
LocallyCachedTopologyBlob.TopologyBlobType type,
String owner,
StormMetricsRegistry metricsRegistry)
Create a new LocallyCachedBlob.
|
Modifier and Type | Method and Description |
---|---|
static MetricStore |
MetricStoreConfig.configure(Map<String,Object> conf,
StormMetricsRegistry metricsRegistry)
Configures metrics store (running on Nimbus) to use the class specified in the conf.
|
void |
NoOpMetricStore.prepare(Map<String,Object> config,
StormMetricsRegistry metricsRegistry) |
void |
MetricStore.prepare(Map<String,Object> config,
StormMetricsRegistry metricsRegistry)
Create metric store instance using the configurations provided via the config map.
|
Modifier and Type | Method and Description |
---|---|
void |
RocksDbStore.prepare(Map<String,Object> config,
StormMetricsRegistry metricsRegistry)
Create metric store instance using the configurations provided via the config map.
|
Modifier and Type | Method and Description |
---|---|
void |
AssignmentDistributionService.addAssignmentsForNode(String node,
String host,
Integer serverPort,
SupervisorAssignments assignments,
StormMetricsRegistry metricsRegistry)
Add an assignments for a node/supervisor for distribution.
|
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 |
---|
Pacemaker(Map<String,Object> conf,
StormMetricsRegistry metricsRegistry) |
Modifier and Type | Method and Description |
---|---|
void |
DefaultScheduler.prepare(Map<String,Object> conf,
StormMetricsRegistry metricsRegistry) |
void |
IScheduler.prepare(Map<String,Object> conf,
StormMetricsRegistry metricsRegistry) |
void |
IsolationScheduler.prepare(Map<String,Object> conf,
StormMetricsRegistry metricsRegistry) |
void |
EvenScheduler.prepare(Map<String,Object> conf,
StormMetricsRegistry metricsRegistry) |
Modifier and Type | Method and Description |
---|---|
void |
BlacklistScheduler.prepare(Map<String,Object> conf,
StormMetricsRegistry metricsRegistry) |
Modifier and Type | Method and Description |
---|---|
void |
MultitenantScheduler.prepare(Map<String,Object> conf,
StormMetricsRegistry metricsRegistry) |
Modifier and Type | Method and Description |
---|---|
void |
ResourceAwareScheduler.prepare(Map<String,Object> conf,
StormMetricsRegistry metricsRegistry) |
Constructor and Description |
---|
ResourceMetrics(StormMetricsRegistry metricsRegistry) |
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.