Uses of Class
org.apache.storm.metric.StormMetricsRegistry
-
-
Uses of StormMetricsRegistry in org.apache.storm
Methods in org.apache.storm that return StormMetricsRegistry Modifier and Type Method Description StormMetricsRegistry
LocalCluster. getMetricRegistry()
Reference to metrics registry.Constructors in org.apache.storm with parameters of type StormMetricsRegistry Constructor Description LocalDRPC(StormMetricsRegistry metricsRegistry)
Creates a LocalDRPC with the specified metrics registry. -
Uses of StormMetricsRegistry in org.apache.storm.daemon.drpc
Constructors in org.apache.storm.daemon.drpc with parameters of type StormMetricsRegistry Constructor Description DRPC(StormMetricsRegistry metricsRegistry, Map<String,Object> conf)
DRPC(StormMetricsRegistry metricsRegistry, IAuthorizer auth, long timeoutMs)
DRPCServer(Map<String,Object> conf, StormMetricsRegistry metricsRegistry)
Constructor. -
Uses of StormMetricsRegistry in org.apache.storm.daemon.drpc.webapp
Methods in org.apache.storm.daemon.drpc.webapp with parameters of type StormMetricsRegistry Modifier and Type Method Description static void
DRPCApplication. setup(DRPC drpc, StormMetricsRegistry metricsRegistry)
Constructors in org.apache.storm.daemon.drpc.webapp with parameters of type StormMetricsRegistry Constructor Description DRPCResource(DRPC drpc, StormMetricsRegistry metricsRegistry)
-
Uses of StormMetricsRegistry in org.apache.storm.daemon.logviewer
Constructors in org.apache.storm.daemon.logviewer with parameters of type StormMetricsRegistry Constructor Description LogviewerServer(Map<String,Object> conf, StormMetricsRegistry metricsRegistry)
Constructor. -
Uses of StormMetricsRegistry in org.apache.storm.daemon.logviewer.handler
Constructors in org.apache.storm.daemon.logviewer.handler with parameters of type StormMetricsRegistry Constructor 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. -
Uses of StormMetricsRegistry in org.apache.storm.daemon.logviewer.utils
Methods in org.apache.storm.daemon.logviewer.utils with parameters of type StormMetricsRegistry Modifier and Type Method 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.Constructors in org.apache.storm.daemon.logviewer.utils with parameters of type StormMetricsRegistry Constructor 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. -
Uses of StormMetricsRegistry in org.apache.storm.daemon.logviewer.webapp
Methods in org.apache.storm.daemon.logviewer.webapp with parameters of type StormMetricsRegistry Modifier and Type Method Description static void
LogviewerApplication. setup(Map<String,Object> stormConf, StormMetricsRegistry metricRegistry)
Spot to inject storm configuration before initializing LogviewerApplication instance.Constructors in org.apache.storm.daemon.logviewer.webapp with parameters of type StormMetricsRegistry Constructor Description LogviewerResource(LogviewerLogPageHandler logviewerParam, LogviewerProfileHandler profileHandler, LogviewerLogDownloadHandler logDownloadHandler, LogviewerLogSearchHandler logSearchHandler, IHttpCredentialsPlugin httpCredsHandler, StormMetricsRegistry metricsRegistry)
Constructor. -
Uses of StormMetricsRegistry in org.apache.storm.daemon.nimbus
Constructors in org.apache.storm.daemon.nimbus with parameters of type StormMetricsRegistry 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)
Nimbus(Map<String,Object> conf, INimbus inimbus, StormMetricsRegistry metricsRegistry)
-
Uses of StormMetricsRegistry in org.apache.storm.daemon.supervisor
Methods in org.apache.storm.daemon.supervisor that return StormMetricsRegistry Modifier and Type Method Description StormMetricsRegistry
Supervisor. getMetricsRegistry()
Methods in org.apache.storm.daemon.supervisor with parameters of type StormMetricsRegistry Modifier and Type Method 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.Constructors in org.apache.storm.daemon.supervisor with parameters of type StormMetricsRegistry Constructor 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. -
Uses of StormMetricsRegistry in org.apache.storm.daemon.ui.filters
Constructors in org.apache.storm.daemon.ui.filters with parameters of type StormMetricsRegistry Constructor Description HeaderResponseFilter(StormMetricsRegistry metricsRegistry)
HeaderResponseServletFilter(StormMetricsRegistry metricsRegistry)
-
Uses of StormMetricsRegistry in org.apache.storm.daemon.ui.resources
Constructors in org.apache.storm.daemon.ui.resources with parameters of type StormMetricsRegistry Constructor Description StormApiResource(StormMetricsRegistry metricsRegistry)
-
Uses of StormMetricsRegistry in org.apache.storm.healthcheck
Methods in org.apache.storm.healthcheck with parameters of type StormMetricsRegistry Modifier and Type Method Description static int
HealthChecker. healthCheck(Map<String,Object> conf, StormMetricsRegistry metricRegistry)
-
Uses of StormMetricsRegistry in org.apache.storm.localizer
Constructors in org.apache.storm.localizer with parameters of type StormMetricsRegistry Constructor 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. -
Uses of StormMetricsRegistry in org.apache.storm.metricstore
Methods in org.apache.storm.metricstore with parameters of type StormMetricsRegistry Modifier and Type Method 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
MetricStore. prepare(Map<String,Object> config, StormMetricsRegistry metricsRegistry)
Create metric store instance using the configurations provided via the config map.void
NoOpMetricStore. prepare(Map<String,Object> config, StormMetricsRegistry metricsRegistry)
-
Uses of StormMetricsRegistry in org.apache.storm.metricstore.rocksdb
Methods in org.apache.storm.metricstore.rocksdb with parameters of type StormMetricsRegistry Modifier and Type Method Description void
RocksDbStore. prepare(Map<String,Object> config, StormMetricsRegistry metricsRegistry)
Create metric store instance using the configurations provided via the config map. -
Uses of StormMetricsRegistry in org.apache.storm.nimbus
Methods in org.apache.storm.nimbus with parameters of type StormMetricsRegistry Modifier and Type Method Description void
AssignmentDistributionService. addAssignmentsForNode(String node, String host, Integer serverPort, SupervisorAssignments assignments, StormMetricsRegistry metricsRegistry)
Add an assignments for a node/supervisor for distribution.Constructors in org.apache.storm.nimbus with parameters of type StormMetricsRegistry 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 StormMetricsRegistry in org.apache.storm.pacemaker
Constructors in org.apache.storm.pacemaker with parameters of type StormMetricsRegistry Constructor Description Pacemaker(Map<String,Object> conf, StormMetricsRegistry metricsRegistry)
-
Uses of StormMetricsRegistry in org.apache.storm.scheduler
Methods in org.apache.storm.scheduler with parameters of type StormMetricsRegistry Modifier and Type Method Description void
DefaultScheduler. prepare(Map<String,Object> conf, StormMetricsRegistry metricsRegistry)
void
EvenScheduler. 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)
-
Uses of StormMetricsRegistry in org.apache.storm.scheduler.blacklist
Methods in org.apache.storm.scheduler.blacklist with parameters of type StormMetricsRegistry Modifier and Type Method Description void
BlacklistScheduler. prepare(Map<String,Object> conf, StormMetricsRegistry metricsRegistry)
-
Uses of StormMetricsRegistry in org.apache.storm.scheduler.multitenant
Methods in org.apache.storm.scheduler.multitenant with parameters of type StormMetricsRegistry Modifier and Type Method Description void
MultitenantScheduler. prepare(Map<String,Object> conf, StormMetricsRegistry metricsRegistry)
-
Uses of StormMetricsRegistry in org.apache.storm.scheduler.resource
Methods in org.apache.storm.scheduler.resource with parameters of type StormMetricsRegistry Modifier and Type Method Description void
ResourceAwareScheduler. prepare(Map<String,Object> conf, StormMetricsRegistry metricsRegistry)
-
Uses of StormMetricsRegistry in org.apache.storm.scheduler.resource.normalization
Constructors in org.apache.storm.scheduler.resource.normalization with parameters of type StormMetricsRegistry Constructor Description ResourceMetrics(StormMetricsRegistry metricsRegistry)
-
Uses of StormMetricsRegistry in org.apache.storm.zookeeper
Methods in org.apache.storm.zookeeper with parameters of type StormMetricsRegistry 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 StormMetricsRegistry 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)
-