Uses of Class
org.apache.storm.metric.StormMetricsRegistry
Package
Description
-
Uses of StormMetricsRegistry in org.apache.storm
Modifier and TypeMethodDescriptionLocalCluster.getMetricRegistry()
Reference to metrics registry.ModifierConstructorDescriptionLocalDRPC
(StormMetricsRegistry metricsRegistry) Creates a LocalDRPC with the specified metrics registry. -
Uses of StormMetricsRegistry in org.apache.storm.daemon.drpc
ModifierConstructorDescriptionDRPC
(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
Modifier and TypeMethodDescriptionstatic void
DRPCApplication.setup
(DRPC drpc, StormMetricsRegistry metricsRegistry) -
Uses of StormMetricsRegistry in org.apache.storm.daemon.logviewer
ModifierConstructorDescriptionLogviewerServer
(Map<String, Object> conf, StormMetricsRegistry metricsRegistry) Constructor. -
Uses of StormMetricsRegistry in org.apache.storm.daemon.logviewer.handler
ModifierConstructorDescriptionLogviewerLogDownloadHandler
(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
Modifier and TypeMethodDescriptionstatic 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.ModifierConstructorDescriptionDirectoryCleaner
(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
Modifier and TypeMethodDescriptionstatic void
LogviewerApplication.setup
(Map<String, Object> stormConf, StormMetricsRegistry metricRegistry) Spot to inject storm configuration before initializing LogviewerApplication instance.ModifierConstructorDescriptionLogviewerResource
(LogviewerLogPageHandler logviewerParam, LogviewerProfileHandler profileHandler, LogviewerLogDownloadHandler logDownloadHandler, LogviewerLogSearchHandler logSearchHandler, IHttpCredentialsPlugin httpCredsHandler, StormMetricsRegistry metricsRegistry) Constructor. -
Uses of StormMetricsRegistry in org.apache.storm.daemon.nimbus
ModifierConstructorDescriptionNimbus
(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 StormMetricsRegistry in org.apache.storm.daemon.supervisor
Modifier and TypeMethodDescriptionstatic 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.ModifierConstructorDescriptionBasicContainer
(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) protected
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
ModifierConstructorDescriptionHeaderResponseFilter
(StormMetricsRegistry metricsRegistry) HeaderResponseServletFilter
(StormMetricsRegistry metricsRegistry) -
Uses of StormMetricsRegistry in org.apache.storm.daemon.ui.resources
-
Uses of StormMetricsRegistry in org.apache.storm.healthcheck
Modifier and TypeMethodDescriptionstatic int
HealthChecker.healthCheck
(Map<String, Object> conf, StormMetricsRegistry metricRegistry) -
Uses of StormMetricsRegistry in org.apache.storm.localizer
ModifierConstructorDescriptionAsyncLocalizer
(Map<String, Object> conf, StormMetricsRegistry metricsRegistry) protected
LocallyCachedBlob
(String blobDescription, String blobKey, StormMetricsRegistry metricsRegistry) Create a new LocallyCachedBlob.protected
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
Modifier and TypeMethodDescriptionstatic 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
Modifier and TypeMethodDescriptionvoid
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
Modifier and TypeMethodDescriptionvoid
AssignmentDistributionService.addAssignmentsForNode
(String node, String host, Integer serverPort, SupervisorAssignments assignments, StormMetricsRegistry metricsRegistry) Add an assignments for a node/supervisor for distribution.ModifierConstructorDescriptionLeaderListenerCallback
(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
ModifierConstructorDescriptionPacemaker
(Map<String, Object> conf, StormMetricsRegistry metricsRegistry) -
Uses of StormMetricsRegistry in org.apache.storm.scheduler
Modifier and TypeMethodDescriptionvoid
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
Modifier and TypeMethodDescriptionvoid
BlacklistScheduler.prepare
(Map<String, Object> conf, StormMetricsRegistry metricsRegistry) -
Uses of StormMetricsRegistry in org.apache.storm.scheduler.multitenant
Modifier and TypeMethodDescriptionvoid
MultitenantScheduler.prepare
(Map<String, Object> conf, StormMetricsRegistry metricsRegistry) -
Uses of StormMetricsRegistry in org.apache.storm.scheduler.resource
Modifier and TypeMethodDescriptionvoid
ResourceAwareScheduler.prepare
(Map<String, Object> conf, StormMetricsRegistry metricsRegistry) -
Uses of StormMetricsRegistry in org.apache.storm.scheduler.resource.normalization
-
Uses of StormMetricsRegistry in org.apache.storm.zookeeper
Modifier and TypeMethodDescriptionstatic 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) ModifierConstructorDescriptionLeaderListenerCallbackFactory
(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)