@InterfaceAudience.Private public class MetricsHeapMemoryManagerSourceImpl extends BaseSourceImpl implements MetricsHeapMemoryManagerSource
Modifier and Type | Field and Description |
---|---|
private MutableFastCounter |
aboveHeapOccupancyLowWatermarkCounter |
private org.apache.hadoop.metrics2.lib.MutableGaugeLong |
blockCacheSizeGauge |
private org.apache.hadoop.metrics2.lib.MutableGaugeLong |
blockedFlushGauge |
private MetricHistogram |
blockedFlushHistogram |
private MetricHistogram |
decBlockCacheSizeHistogram |
private MetricHistogram |
decMemStoreSizeHistogram |
private MutableFastCounter |
doNothingCounter |
private MetricHistogram |
incBlockCacheSizeHistogram |
private MetricHistogram |
incMemStoreSizeHistogram |
private org.apache.hadoop.metrics2.lib.MutableGaugeLong |
memStoreSizeGauge |
private org.apache.hadoop.metrics2.lib.MutableGaugeLong |
unblockedFlushGauge |
private MetricHistogram |
unblockedFlushHistogram |
metricsAdapter, metricsContext, metricsDescription, metricsJmxContext, metricsName, metricsRegistry, registry
ABOVE_HEAP_LOW_WATERMARK_COUNTER_DESC, ABOVE_HEAP_LOW_WATERMARK_COUNTER_NAME, BLOCKCACHE_SIZE_GAUGE_DESC, BLOCKCACHE_SIZE_GAUGE_NAME, BLOCKED_FLUSH_DESC, BLOCKED_FLUSH_GAUGE_DESC, BLOCKED_FLUSH_GAUGE_NAME, BLOCKED_FLUSH_NAME, DEC_BLOCKCACHE_TUNING_DESC, DEC_BLOCKCACHE_TUNING_NAME, DEC_MEMSTORE_TUNING_DESC, DEC_MEMSTORE_TUNING_NAME, DO_NOTHING_COUNTER_DESC, DO_NOTHING_COUNTER_NAME, INC_BLOCKCACHE_TUNING_DESC, INC_BLOCKCACHE_TUNING_NAME, INC_MEMSTORE_TUNING_DESC, INC_MEMSTORE_TUNING_NAME, MEMSTORE_SIZE_GAUGE_DESC, MEMSTORE_SIZE_GAUGE_NAME, METRICS_CONTEXT, METRICS_DESCRIPTION, METRICS_JMX_CONTEXT, METRICS_NAME, UNBLOCKED_FLUSH_DESC, UNBLOCKED_FLUSH_GAUGE_DESC, UNBLOCKED_FLUSH_GAUGE_NAME, UNBLOCKED_FLUSH_NAME
HBASE_METRICS_SYSTEM_NAME
Constructor and Description |
---|
MetricsHeapMemoryManagerSourceImpl() |
MetricsHeapMemoryManagerSourceImpl(String metricsName,
String metricsDescription,
String metricsContext,
String metricsJmxContext) |
Modifier and Type | Method and Description |
---|---|
void |
increaseAboveHeapOccupancyLowWatermarkCounter()
Increase the counter for heap occupancy percent above low watermark
|
void |
increaseTunerDoNothingCounter()
Increase the counter for tuner neither expanding memstore global size limit nor expanding
blockcache max size.
|
void |
setCurBlockCacheSizeGauge(long blockcacheSize)
Set the current blockcache size used gauge
|
void |
setCurMemStoreSizeGauge(long memstoreSize)
Set the current global memstore size used gauge
|
void |
updateBlockCacheDeltaSizeHistogram(int blockCacheDeltaSize)
Update the increase/decrease blockcache size histogram
|
void |
updateBlockedFlushCount(long blockedFlushCount)
Update/Set the blocked flush count histogram/gauge
|
void |
updateMemStoreDeltaSizeHistogram(int memStoreDeltaSize)
Update the increase/decrease memstore size histogram
|
void |
updateUnblockedFlushCount(long unblockedFlushCount)
Update/Set the unblocked flush count histogram/gauge
|
decGauge, getMetrics, getMetricsContext, getMetricsDescription, getMetricsJmxContext, getMetricsName, getMetricsRegistry, incCounters, incGauge, init, removeMetric, setGauge, updateHistogram
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
decGauge, getMetricRegistryInfo, getMetricsContext, getMetricsDescription, getMetricsJmxContext, getMetricsName, incCounters, incGauge, init, removeMetric, setGauge, updateHistogram
private final MetricHistogram blockedFlushHistogram
private final MetricHistogram unblockedFlushHistogram
private final MetricHistogram incMemStoreSizeHistogram
private final MetricHistogram decMemStoreSizeHistogram
private final MetricHistogram incBlockCacheSizeHistogram
private final MetricHistogram decBlockCacheSizeHistogram
private final org.apache.hadoop.metrics2.lib.MutableGaugeLong blockedFlushGauge
private final org.apache.hadoop.metrics2.lib.MutableGaugeLong unblockedFlushGauge
private final org.apache.hadoop.metrics2.lib.MutableGaugeLong memStoreSizeGauge
private final org.apache.hadoop.metrics2.lib.MutableGaugeLong blockCacheSizeGauge
private final MutableFastCounter doNothingCounter
private final MutableFastCounter aboveHeapOccupancyLowWatermarkCounter
public MetricsHeapMemoryManagerSourceImpl()
public MetricsHeapMemoryManagerSourceImpl(String metricsName, String metricsDescription, String metricsContext, String metricsJmxContext)
public void updateBlockedFlushCount(long blockedFlushCount)
MetricsHeapMemoryManagerSource
updateBlockedFlushCount
in interface MetricsHeapMemoryManagerSource
blockedFlushCount
- the number of blocked flush since last tuning.public void updateUnblockedFlushCount(long unblockedFlushCount)
MetricsHeapMemoryManagerSource
updateUnblockedFlushCount
in interface MetricsHeapMemoryManagerSource
unblockedFlushCount
- the number of unblocked flush since last tuning.public void setCurBlockCacheSizeGauge(long blockcacheSize)
MetricsHeapMemoryManagerSource
setCurBlockCacheSizeGauge
in interface MetricsHeapMemoryManagerSource
blockcacheSize
- the current memory usage in blockcache, in bytes.public void setCurMemStoreSizeGauge(long memstoreSize)
MetricsHeapMemoryManagerSource
setCurMemStoreSizeGauge
in interface MetricsHeapMemoryManagerSource
memstoreSize
- the current memory usage in memstore, in bytes.public void updateMemStoreDeltaSizeHistogram(int memStoreDeltaSize)
MetricsHeapMemoryManagerSource
updateMemStoreDeltaSizeHistogram
in interface MetricsHeapMemoryManagerSource
memStoreDeltaSize
- the tuning result of memstore.public void updateBlockCacheDeltaSizeHistogram(int blockCacheDeltaSize)
MetricsHeapMemoryManagerSource
updateBlockCacheDeltaSizeHistogram
in interface MetricsHeapMemoryManagerSource
blockCacheDeltaSize
- the tuning result of blockcache.public void increaseTunerDoNothingCounter()
MetricsHeapMemoryManagerSource
increaseTunerDoNothingCounter
in interface MetricsHeapMemoryManagerSource
public void increaseAboveHeapOccupancyLowWatermarkCounter()
MetricsHeapMemoryManagerSource
increaseAboveHeapOccupancyLowWatermarkCounter
in interface MetricsHeapMemoryManagerSource
Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.