Uses of Class
org.apache.storm.metric.StormMetricsRegistry
Packages that use StormMetricsRegistry
Package
Description
- 
Uses of StormMetricsRegistry in org.apache.stormMethods in org.apache.storm that return StormMetricsRegistryModifier and TypeMethodDescriptionLocalCluster.getMetricRegistry()Reference to metrics registry.Constructors in org.apache.storm with parameters of type StormMetricsRegistryModifierConstructorDescriptionLocalDRPC(StormMetricsRegistry metricsRegistry) Creates a LocalDRPC with the specified metrics registry.
- 
Uses of StormMetricsRegistry in org.apache.storm.daemon.drpcConstructors in org.apache.storm.daemon.drpc with parameters of type StormMetricsRegistryModifierConstructorDescriptionDRPC(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.webappMethods in org.apache.storm.daemon.drpc.webapp with parameters of type StormMetricsRegistryModifier and TypeMethodDescriptionstatic voidDRPCApplication.setup(DRPC drpc, StormMetricsRegistry metricsRegistry) Constructors in org.apache.storm.daemon.drpc.webapp with parameters of type StormMetricsRegistry
- 
Uses of StormMetricsRegistry in org.apache.storm.daemon.logviewerConstructors in org.apache.storm.daemon.logviewer with parameters of type StormMetricsRegistryModifierConstructorDescriptionLogviewerServer(Map<String, Object> conf, StormMetricsRegistry metricsRegistry) Constructor.
- 
Uses of StormMetricsRegistry in org.apache.storm.daemon.logviewer.handlerConstructors in org.apache.storm.daemon.logviewer.handler with parameters of type StormMetricsRegistryModifierConstructorDescriptionLogviewerLogDownloadHandler(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.utilsMethods in org.apache.storm.daemon.logviewer.utils with parameters of type StormMetricsRegistryModifier and TypeMethodDescriptionstatic voidExceptionMeterNames.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 StormMetricsRegistryModifierConstructorDescriptionDirectoryCleaner(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.webappMethods in org.apache.storm.daemon.logviewer.webapp with parameters of type StormMetricsRegistryModifier and TypeMethodDescriptionstatic voidLogviewerApplication.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 StormMetricsRegistryModifierConstructorDescriptionLogviewerResource(LogviewerLogPageHandler logviewerParam, LogviewerProfileHandler profileHandler, LogviewerLogDownloadHandler logDownloadHandler, LogviewerLogSearchHandler logSearchHandler, IHttpCredentialsPlugin httpCredsHandler, StormMetricsRegistry metricsRegistry) Constructor.
- 
Uses of StormMetricsRegistry in org.apache.storm.daemon.nimbusConstructors in org.apache.storm.daemon.nimbus with parameters of type StormMetricsRegistryModifierConstructorDescriptionNimbus(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.supervisorMethods in org.apache.storm.daemon.supervisor that return StormMetricsRegistryMethods in org.apache.storm.daemon.supervisor with parameters of type StormMetricsRegistryModifier and TypeMethodDescriptionstatic ContainerLauncherContainerLauncher.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 StormMetricsRegistryModifierConstructorDescriptionBasicContainer(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) protectedContainer(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.filtersConstructors in org.apache.storm.daemon.ui.filters with parameters of type StormMetricsRegistryModifierConstructorDescriptionHeaderResponseFilter(StormMetricsRegistry metricsRegistry) HeaderResponseServletFilter(StormMetricsRegistry metricsRegistry) 
- 
Uses of StormMetricsRegistry in org.apache.storm.daemon.ui.resourcesConstructors in org.apache.storm.daemon.ui.resources with parameters of type StormMetricsRegistry
- 
Uses of StormMetricsRegistry in org.apache.storm.healthcheckMethods in org.apache.storm.healthcheck with parameters of type StormMetricsRegistryModifier and TypeMethodDescriptionstatic intHealthChecker.healthCheck(Map<String, Object> conf, StormMetricsRegistry metricRegistry) 
- 
Uses of StormMetricsRegistry in org.apache.storm.localizerConstructors in org.apache.storm.localizer with parameters of type StormMetricsRegistryModifierConstructorDescriptionAsyncLocalizer(Map<String, Object> conf, StormMetricsRegistry metricsRegistry) protectedLocallyCachedBlob(String blobDescription, String blobKey, StormMetricsRegistry metricsRegistry) Create a new LocallyCachedBlob.protectedLocallyCachedTopologyBlob(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.metricstoreMethods in org.apache.storm.metricstore with parameters of type StormMetricsRegistryModifier and TypeMethodDescriptionstatic MetricStoreMetricStoreConfig.configure(Map<String, Object> conf, StormMetricsRegistry metricsRegistry) Configures metrics store (running on Nimbus) to use the class specified in the conf.voidMetricStore.prepare(Map<String, Object> config, StormMetricsRegistry metricsRegistry) Create metric store instance using the configurations provided via the config map.voidNoOpMetricStore.prepare(Map<String, Object> config, StormMetricsRegistry metricsRegistry) 
- 
Uses of StormMetricsRegistry in org.apache.storm.metricstore.rocksdbMethods in org.apache.storm.metricstore.rocksdb with parameters of type StormMetricsRegistryModifier and TypeMethodDescriptionvoidRocksDbStore.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.nimbusMethods in org.apache.storm.nimbus with parameters of type StormMetricsRegistryModifier and TypeMethodDescriptionvoidAssignmentDistributionService.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 StormMetricsRegistryModifierConstructorDescriptionLeaderListenerCallback(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.pacemakerConstructors in org.apache.storm.pacemaker with parameters of type StormMetricsRegistryModifierConstructorDescriptionPacemaker(Map<String, Object> conf, StormMetricsRegistry metricsRegistry) 
- 
Uses of StormMetricsRegistry in org.apache.storm.schedulerMethods in org.apache.storm.scheduler with parameters of type StormMetricsRegistryModifier and TypeMethodDescriptionvoidDefaultScheduler.prepare(Map<String, Object> conf, StormMetricsRegistry metricsRegistry) voidEvenScheduler.prepare(Map<String, Object> conf, StormMetricsRegistry metricsRegistry) voidIScheduler.prepare(Map<String, Object> conf, StormMetricsRegistry metricsRegistry) voidIsolationScheduler.prepare(Map<String, Object> conf, StormMetricsRegistry metricsRegistry) 
- 
Uses of StormMetricsRegistry in org.apache.storm.scheduler.blacklistMethods in org.apache.storm.scheduler.blacklist with parameters of type StormMetricsRegistryModifier and TypeMethodDescriptionvoidBlacklistScheduler.prepare(Map<String, Object> conf, StormMetricsRegistry metricsRegistry) 
- 
Uses of StormMetricsRegistry in org.apache.storm.scheduler.multitenantMethods in org.apache.storm.scheduler.multitenant with parameters of type StormMetricsRegistryModifier and TypeMethodDescriptionvoidMultitenantScheduler.prepare(Map<String, Object> conf, StormMetricsRegistry metricsRegistry) 
- 
Uses of StormMetricsRegistry in org.apache.storm.scheduler.resourceMethods in org.apache.storm.scheduler.resource with parameters of type StormMetricsRegistryModifier and TypeMethodDescriptionvoidResourceAwareScheduler.prepare(Map<String, Object> conf, StormMetricsRegistry metricsRegistry) 
- 
Uses of StormMetricsRegistry in org.apache.storm.scheduler.resource.normalizationConstructors in org.apache.storm.scheduler.resource.normalization with parameters of type StormMetricsRegistry
- 
Uses of StormMetricsRegistry in org.apache.storm.zookeeperMethods in org.apache.storm.zookeeper with parameters of type StormMetricsRegistryModifier and TypeMethodDescriptionstatic ILeaderElectorZookeeper.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 ILeaderElectorZookeeper.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 StormMetricsRegistryModifierConstructorDescriptionLeaderListenerCallbackFactory(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)