@InterfaceAudience.Private public class MetricsTableLatenciesImpl extends BaseSourceImpl implements MetricsTableLatencies
MetricsTableLatencies
to track latencies for one table in a
RegionServer.Modifier and Type | Class and Description |
---|---|
static class |
MetricsTableLatenciesImpl.TableHistograms |
Modifier and Type | Field and Description |
---|---|
private HashMap<TableName,MetricsTableLatenciesImpl.TableHistograms> |
histogramsByTable |
metricsAdapter, metricsContext, metricsDescription, metricsJmxContext, metricsName, metricsRegistry, registry
APPEND_TIME, CHECK_AND_DELETE_TIME, CHECK_AND_MUTATE_TIME, CHECK_AND_PUT_TIME, DELETE_BATCH_TIME, DELETE_TIME, GET_TIME, INCREMENT_TIME, METRICS_CONTEXT, METRICS_DESCRIPTION, METRICS_JMX_CONTEXT, METRICS_NAME, PUT_BATCH_TIME, PUT_TIME, SCAN_SIZE, SCAN_TIME
HBASE_METRICS_SYSTEM_NAME
Constructor and Description |
---|
MetricsTableLatenciesImpl() |
MetricsTableLatenciesImpl(String metricsName,
String metricsDescription,
String metricsContext,
String metricsJmxContext) |
Modifier and Type | Method and Description |
---|---|
void |
getMetrics(org.apache.hadoop.metrics2.MetricsCollector metricsCollector,
boolean all) |
MetricsTableLatenciesImpl.TableHistograms |
getOrCreateTableHistogram(String tableName) |
static String |
qualifyMetricsName(TableName tableName,
String metric) |
void |
updateAppend(String tableName,
long t)
Update the Append time histogram.
|
void |
updateCheckAndDelete(String tableName,
long time)
Update the CheckAndDelete time histogram.
|
void |
updateCheckAndMutate(String tableName,
long time)
Update the CheckAndMutate time histogram.
|
void |
updateCheckAndPut(String tableName,
long time)
Update the CheckAndPut time histogram.
|
void |
updateDelete(String tableName,
long t)
Update the Delete time histogram
|
void |
updateDeleteBatch(String tableName,
long t)
Update the batch Delete time histogram
|
void |
updateGet(String tableName,
long t)
Update the Get time histogram .
|
void |
updateIncrement(String tableName,
long t)
Update the Increment time histogram.
|
void |
updatePut(String tableName,
long t)
Update the Put time histogram
|
void |
updatePutBatch(String tableName,
long t)
Update the batch Put time histogram
|
void |
updateScanSize(String tableName,
long scanSize)
Update the scan size.
|
void |
updateScanTime(String tableName,
long t)
Update the scan time.
|
decGauge, getMetricsContext, getMetricsDescription, getMetricsJmxContext, getMetricsName, getMetricsRegistry, incCounters, incGauge, init, removeMetric, setGauge, updateHistogram
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
getMetricRegistryInfo
private final HashMap<TableName,MetricsTableLatenciesImpl.TableHistograms> histogramsByTable
public MetricsTableLatenciesImpl()
public MetricsTableLatenciesImpl(String metricsName, String metricsDescription, String metricsContext, String metricsJmxContext)
public static String qualifyMetricsName(TableName tableName, String metric)
public MetricsTableLatenciesImpl.TableHistograms getOrCreateTableHistogram(String tableName)
public void updatePut(String tableName, long t)
MetricsTableLatencies
updatePut
in interface MetricsTableLatencies
tableName
- The table the metric is fort
- time it tookpublic void updatePutBatch(String tableName, long t)
MetricsTableLatencies
updatePutBatch
in interface MetricsTableLatencies
tableName
- The table the metric is fort
- time it tookpublic void updateDelete(String tableName, long t)
MetricsTableLatencies
updateDelete
in interface MetricsTableLatencies
tableName
- The table the metric is fort
- time it tookpublic void updateDeleteBatch(String tableName, long t)
MetricsTableLatencies
updateDeleteBatch
in interface MetricsTableLatencies
tableName
- The table the metric is fort
- time it tookpublic void updateGet(String tableName, long t)
MetricsTableLatencies
updateGet
in interface MetricsTableLatencies
tableName
- The table the metric is fort
- time it tookpublic void updateIncrement(String tableName, long t)
MetricsTableLatencies
updateIncrement
in interface MetricsTableLatencies
tableName
- The table the metric is fort
- time it tookpublic void updateAppend(String tableName, long t)
MetricsTableLatencies
updateAppend
in interface MetricsTableLatencies
tableName
- The table the metric is fort
- time it tookpublic void updateScanSize(String tableName, long scanSize)
MetricsTableLatencies
updateScanSize
in interface MetricsTableLatencies
tableName
- The table the metric is forscanSize
- size of the scanpublic void updateScanTime(String tableName, long t)
MetricsTableLatencies
updateScanTime
in interface MetricsTableLatencies
tableName
- The table the metric is fort
- time it tookpublic void updateCheckAndDelete(String tableName, long time)
MetricsTableLatencies
updateCheckAndDelete
in interface MetricsTableLatencies
tableName
- The table the metric is fortime
- time it tookpublic void updateCheckAndPut(String tableName, long time)
MetricsTableLatencies
updateCheckAndPut
in interface MetricsTableLatencies
tableName
- The table the metric is fortime
- time it tookpublic void updateCheckAndMutate(String tableName, long time)
MetricsTableLatencies
updateCheckAndMutate
in interface MetricsTableLatencies
tableName
- The table the metric is fortime
- time it tookpublic void getMetrics(org.apache.hadoop.metrics2.MetricsCollector metricsCollector, boolean all)
getMetrics
in interface org.apache.hadoop.metrics2.MetricsSource
getMetrics
in class BaseSourceImpl
Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.