Package | Description |
---|---|
org.apache.storm.metricstore | |
org.apache.storm.metricstore.rocksdb |
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.
|
static WorkerMetricsProcessor |
MetricStoreConfig.configureMetricProcessor(Map conf)
Configures metric processor (running on supervisor) to use the class specified in the conf.
|
void |
MetricStore.insert(Metric metric)
Stores a metric in the store.
|
boolean |
MetricStore.populateValue(Metric metric)
Fill out the numeric values for a metric.
|
void |
NimbusMetricProcessor.prepare(Map<String,Object> config) |
void |
WorkerMetricsProcessor.prepare(Map<String,Object> config)
Prepares the metric processor.
|
void |
MetricStore.prepare(Map<String,Object> config,
StormMetricsRegistry metricsRegistry)
Create metric store instance using the configurations provided via the config map.
|
void |
NimbusMetricProcessor.processWorkerMetrics(Map<String,Object> conf,
WorkerMetrics metrics) |
void |
WorkerMetricsProcessor.processWorkerMetrics(Map<String,Object> conf,
WorkerMetrics metrics)
Process insertion of worker metrics.
|
void |
MetricStore.scan(FilterOptions filter,
MetricStore.ScanCallback scanCallback)
Scans all metrics in the store and returns the ones matching the specified filtering options.
|
void |
Metric.setAggLevel(AggLevel aggLevel)
Set the aggLevel.
|
void |
FilterOptions.setAggLevels(Set<AggLevel> levels)
Set the aggregation levels to search for.
|
Constructor and Description |
---|
Metric(String name,
Long timestamp,
String topologyId,
double value,
String componentId,
String executorId,
String hostname,
String streamId,
int port,
AggLevel aggLevel)
Metric constructor.
|
Modifier and Type | Method and Description |
---|---|
void |
RocksDbStore.insert(Metric metric)
Stores metrics in the store.
|
boolean |
RocksDbStore.populateValue(Metric metric)
Fill out the numeric values for a metric.
|
void |
RocksDbStore.prepare(Map<String,Object> config,
StormMetricsRegistry metricsRegistry)
Create metric store instance using the configurations provided via the config map.
|
void |
StringMetadataCache.put(String s,
org.apache.storm.metricstore.rocksdb.StringMetadata stringMetadata,
boolean newEntry)
Add the string metadata to the cache.
|
void |
WritableStringMetadataCache.put(String s,
org.apache.storm.metricstore.rocksdb.StringMetadata stringMetadata,
boolean newEntry)
Add the string metadata to the cache.
|
void |
RocksDbStore.scan(FilterOptions filter,
MetricStore.ScanCallback scanCallback)
Scans all metrics in the store and returns the ones matching the specified filtering options.
|
Copyright © 2022 The Apache Software Foundation. All rights reserved.