Class MetricsRegionServerWrapperImpl
java.lang.Object
org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
- All Implemented Interfaces:
MetricsRegionServerWrapper
Impl for exposing HRegionServer Information through Hadoop's metrics 2 system.
-
Nested Class Summary
Modifier and TypeClassDescriptionprivate static final class
class
This is the runnable that will be executed on the executor every PERIOD number of seconds It will take metrics/numbers from all of the regions and use them to compute point in time metrics. -
Field Summary
Modifier and TypeFieldDescriptionprivate final ByteBuffAllocator
private BlockCache
private CacheStats
private org.apache.hadoop.hdfs.DFSHedgedReadMetrics
Can be null if not on hdfs.private final ExcludeDatanodeManager
private ScheduledExecutorService
private BlockCache
private CacheStats
private BlockCache
private CacheStats
private static final org.slf4j.Logger
private final MetricsWALSource
private MobFileCache
private long
private long
private long
private double
private long
private long
private long
private final HRegionServer
private Runnable
private long
-
Constructor Summary
-
Method Summary
Modifier and TypeMethodDescriptionvoid
Force a re-computation of the metrics.int
long
Get the average region size to this region server.long
Returns Average age of store files hosted on this region serverlong
Get the number of items in the block cache.long
Get the number of DATA blocks in the block cache.long
Get the number of items evicted from the block cache.long
Number of cache insertions that failed.long
Get the size (in bytes) of the block cache that is free.long
Get the count of hits to the block cache, for cacheable requests only.double
Get the percent of requests with the block cache turned on that hit the block cache.long
Get the count of hits to the block cachedouble
Get the percent of all requests that hit the block cache.long
Get the count of misses to the block cache, for cacheable requests only.long
Get the count of misses to the block cache.long
Get the number of items evicted from primary replica in the block cache.long
Get the count of hits to primary replica in the block cachelong
Get the count of misses to primary replica in the block cache.long
Get the total size (in bytes) of the block cache.long
Returns Count of requests blocked because the memstore size is larger than blockingMemStoreSizelong
long
long
Count of requests which could have used bloom filters, but they weren't configured or loaded.long
Count of bloom filter requests which return a negative result.long
Count of bloom filter requests.long
double
long
long
long
long
Gets the number of cells moved from mob during compaction.long
Gets the number of cells moved to mob during compaction.long
Gets the total amount of cells moved from mob during compaction, in bytes.long
Gets the total amount of cells moved to mob during compaction, in bytes.long
Get the number of CAS operations that failed.long
Get the number of CAS operations that passed.Get the Cluster IDlong
Get the number of cells processed during minor compactions.long
Get the total amount of data processed during minor compactions, in bytes.int
Get the size of the compaction queueGet the co-processorslong
Get the number of coprocessor requests to regions hosted on this region server.long
long
Ammount of data in the memstore but not in the WAL because mutations explicitly had their WAL turned off.long
long
long
long
long
long
Get the number of filtered read requests to regions hosted on this region server.long
Get the number of cells flushed to disk.long
Get the total amount of data flushed to disk, in bytes.int
Get the size of the flush queue.long
long
long
Returns Count of hedged read operationslong
Returns Count of times a hedged read executes in current threadlong
Returns Count of times a hedged read beat out the primary read.long
long
long
Number of blocks in L1 cachelong
Number of blocks evicted from L1 cachelong
Free cache size (bytes) of L1 cachelong
Hit count of L1 cache.double
Hit ratio of L1 cache.long
Miss count of L1 cache.double
Miss ratio of L1 cache.long
Cache size (bytes) of L1 cachelong
Number of blocks in L2 cachelong
Number of blocks evicted from L2 cachelong
Free cache size (bytes) of L2 cachelong
Hit count of L2 cache.double
Hit ratio of L2 cache.long
Miss count of L2 cache.double
Miss ratio of L2 cache.long
Cache size (bytes) of L2 cacheint
long
long
long
Returns Number of bytes read from the local HDFS DataNode.long
Get the number of cells processed during major compactions.long
Get the total amount of data processed during major compactions, in bytes.long
Returns Max age of store files hosted on this region serverlong
Get the max number of store files across all regions of this region server.long
Get the limit size of the off heap memstore (if enabled), otherwise get the limit size of the on heap memstore.long
Get the size of the memstore on this region server.long
long
long
Returns Min age of store files hosted on this region serverlong
Gets the count of accesses to the mob file cache.long
Gets the count of cached mob files.long
Gets the number of items evicted from the mob file cache.double
Gets the hit percent to the mob file cache.long
Gets the count of misses to the mob file cache.long
Gets the number of the flushes in mob-enabled stores.long
Gets the number of mob cells flushed to disk.long
Gets the total amount of mob cells flushed to disk, in bytes.long
Gets the number of scanned mob cells.long
Gets the total amount of scanned mob cells, in bytes.long
Number of mutations received with WAL explicitly turned off.long
The number of online regionslong
Returns Number of reference files on this region serverlong
Get the number of store files hosted on this region server.long
Get the number of stores hosted on this region server.long
Get the number of WAL files of this region server.long
Get the number of WAL files with slow appends for this region server.long
Get the limit size of the off heap memstore.long
Get the size of the off heap memstore on this region server.long
Get the limit size of the on heap memstore.long
Get the size of the on heap memstore on this region server.double
Get the percent of HFiles' that are local.double
Get the percent of HFiles' that are local for secondary region replicas.(package private) long
long
Get the number of read requests to regions hosted on this region server.double
Get the rate of read requests per second to regions hosted on this region server.double
Get the number of requests per second.long
long
long
Get the number of full region rpc scan requests to this region server.long
Get the number of rpc get requests to this region server.long
Get the number of rpc multi requests to this region server.long
Get the number of rpc mutate requests to this region server.long
Get the number of rpc scan requests to this region server.Get ServerNamelong
Returns Number of bytes read locally through HDFS short circuit.int
int
Get the size of the split queuelong
Get HRegionServer start timelong
Get the Size (in bytes) of indexes in storefiles on disk.long
Get the total size of the store files this region server is serving from.double
Get the growth rate of the store files this region server is serving from.long
Returns Number of total bytes read from HDFS.long
Get the total number of requests per second.long
long
Get the size (in bytes) of the static bloom filters.long
Get the size (in bytes) of of the static indexes including the roots.long
long
long
Get the amount of time that updates were blocked.Get the excluded datanodes in the cache of this region server.long
Get the size of WAL files of this region server.long
Get the number of write requests to regions hosted on this region server.double
Get the rate of write requests per second to regions hosted on this region server.long
Returns Number of bytes read locally through HDFS zero copy.Get the ZooKeeper Quorum Infoprivate void
private void
Initializes the mob file cache.
-
Field Details
-
LOG
-
regionServer
-
metricsWALSource
-
allocator
-
blockCache
-
l1Cache
-
l2Cache
-
mobFileCache
-
cacheStats
-
l1Stats
-
l2Stats
-
numWALFiles
-
walFileSize
-
mobFileCacheAccessCount
-
mobFileCacheMissCount
-
mobFileCacheHitRatio
-
mobFileCacheEvictedCount
-
mobFileCacheCount
-
aggregate
-
requestsCountCache
-
executor
-
runnable
-
period
-
dfsHedgedReadMetrics
Can be null if not on hdfs. -
excludeDatanodeManager
-
-
Constructor Details
-
MetricsRegionServerWrapperImpl
-
-
Method Details
-
initBlockCache
-
initMobFileCache
Initializes the mob file cache. -
getClusterId
Description copied from interface:MetricsRegionServerWrapper
Get the Cluster ID- Specified by:
getClusterId
in interfaceMetricsRegionServerWrapper
- Returns:
- Cluster ID
-
getStartCode
Description copied from interface:MetricsRegionServerWrapper
Get HRegionServer start time- Specified by:
getStartCode
in interfaceMetricsRegionServerWrapper
- Returns:
- Start time of RegionServer in milliseconds
-
getZookeeperQuorum
Description copied from interface:MetricsRegionServerWrapper
Get the ZooKeeper Quorum Info- Specified by:
getZookeeperQuorum
in interfaceMetricsRegionServerWrapper
- Returns:
- ZooKeeper Quorum Info
-
getCoprocessors
Description copied from interface:MetricsRegionServerWrapper
Get the co-processors- Specified by:
getCoprocessors
in interfaceMetricsRegionServerWrapper
- Returns:
- Co-processors
-
getServerName
Description copied from interface:MetricsRegionServerWrapper
Get ServerName- Specified by:
getServerName
in interfaceMetricsRegionServerWrapper
-
getNumOnlineRegions
Description copied from interface:MetricsRegionServerWrapper
The number of online regions- Specified by:
getNumOnlineRegions
in interfaceMetricsRegionServerWrapper
-
getTotalRequestCount
Description copied from interface:MetricsRegionServerWrapper
Get the total number of requests per second.- Specified by:
getTotalRequestCount
in interfaceMetricsRegionServerWrapper
-
getTotalRowActionRequestCount
- Specified by:
getTotalRowActionRequestCount
in interfaceMetricsRegionServerWrapper
-
getSplitQueueSize
Description copied from interface:MetricsRegionServerWrapper
Get the size of the split queue- Specified by:
getSplitQueueSize
in interfaceMetricsRegionServerWrapper
-
getCompactionQueueSize
Description copied from interface:MetricsRegionServerWrapper
Get the size of the compaction queue- Specified by:
getCompactionQueueSize
in interfaceMetricsRegionServerWrapper
-
getSmallCompactionQueueSize
- Specified by:
getSmallCompactionQueueSize
in interfaceMetricsRegionServerWrapper
-
getLargeCompactionQueueSize
- Specified by:
getLargeCompactionQueueSize
in interfaceMetricsRegionServerWrapper
-
getFlushQueueSize
Description copied from interface:MetricsRegionServerWrapper
Get the size of the flush queue.- Specified by:
getFlushQueueSize
in interfaceMetricsRegionServerWrapper
-
getBlockCacheCount
Description copied from interface:MetricsRegionServerWrapper
Get the number of items in the block cache.- Specified by:
getBlockCacheCount
in interfaceMetricsRegionServerWrapper
-
getBlockCacheDataBlockCount
Description copied from interface:MetricsRegionServerWrapper
Get the number of DATA blocks in the block cache.- Specified by:
getBlockCacheDataBlockCount
in interfaceMetricsRegionServerWrapper
-
getMemStoreLimit
Description copied from interface:MetricsRegionServerWrapper
Get the limit size of the off heap memstore (if enabled), otherwise get the limit size of the on heap memstore.- Specified by:
getMemStoreLimit
in interfaceMetricsRegionServerWrapper
-
getOnHeapMemStoreLimit
Description copied from interface:MetricsRegionServerWrapper
Get the limit size of the on heap memstore.- Specified by:
getOnHeapMemStoreLimit
in interfaceMetricsRegionServerWrapper
-
getOffHeapMemStoreLimit
Description copied from interface:MetricsRegionServerWrapper
Get the limit size of the off heap memstore.- Specified by:
getOffHeapMemStoreLimit
in interfaceMetricsRegionServerWrapper
-
getBlockCacheSize
Description copied from interface:MetricsRegionServerWrapper
Get the total size (in bytes) of the block cache.- Specified by:
getBlockCacheSize
in interfaceMetricsRegionServerWrapper
-
getBlockCacheFreeSize
Description copied from interface:MetricsRegionServerWrapper
Get the size (in bytes) of the block cache that is free.- Specified by:
getBlockCacheFreeSize
in interfaceMetricsRegionServerWrapper
-
getBlockCacheHitCount
Description copied from interface:MetricsRegionServerWrapper
Get the count of hits to the block cache- Specified by:
getBlockCacheHitCount
in interfaceMetricsRegionServerWrapper
-
getBlockCachePrimaryHitCount
Description copied from interface:MetricsRegionServerWrapper
Get the count of hits to primary replica in the block cache- Specified by:
getBlockCachePrimaryHitCount
in interfaceMetricsRegionServerWrapper
-
getBlockCacheHitCachingCount
Description copied from interface:MetricsRegionServerWrapper
Get the count of hits to the block cache, for cacheable requests only.- Specified by:
getBlockCacheHitCachingCount
in interfaceMetricsRegionServerWrapper
-
getBlockCacheMissCount
Description copied from interface:MetricsRegionServerWrapper
Get the count of misses to the block cache.- Specified by:
getBlockCacheMissCount
in interfaceMetricsRegionServerWrapper
-
getBlockCachePrimaryMissCount
Description copied from interface:MetricsRegionServerWrapper
Get the count of misses to primary replica in the block cache.- Specified by:
getBlockCachePrimaryMissCount
in interfaceMetricsRegionServerWrapper
-
getBlockCacheMissCachingCount
Description copied from interface:MetricsRegionServerWrapper
Get the count of misses to the block cache, for cacheable requests only.- Specified by:
getBlockCacheMissCachingCount
in interfaceMetricsRegionServerWrapper
-
getBlockCacheEvictedCount
Description copied from interface:MetricsRegionServerWrapper
Get the number of items evicted from the block cache.- Specified by:
getBlockCacheEvictedCount
in interfaceMetricsRegionServerWrapper
-
getBlockCachePrimaryEvictedCount
Description copied from interface:MetricsRegionServerWrapper
Get the number of items evicted from primary replica in the block cache.- Specified by:
getBlockCachePrimaryEvictedCount
in interfaceMetricsRegionServerWrapper
-
getBlockCacheHitPercent
Description copied from interface:MetricsRegionServerWrapper
Get the percent of all requests that hit the block cache.- Specified by:
getBlockCacheHitPercent
in interfaceMetricsRegionServerWrapper
-
getBlockCacheHitCachingPercent
Description copied from interface:MetricsRegionServerWrapper
Get the percent of requests with the block cache turned on that hit the block cache.- Specified by:
getBlockCacheHitCachingPercent
in interfaceMetricsRegionServerWrapper
-
getBlockCacheFailedInsertions
Description copied from interface:MetricsRegionServerWrapper
Number of cache insertions that failed.- Specified by:
getBlockCacheFailedInsertions
in interfaceMetricsRegionServerWrapper
-
getL1CacheSize
Description copied from interface:MetricsRegionServerWrapper
Cache size (bytes) of L1 cache- Specified by:
getL1CacheSize
in interfaceMetricsRegionServerWrapper
-
getL1CacheFreeSize
Description copied from interface:MetricsRegionServerWrapper
Free cache size (bytes) of L1 cache- Specified by:
getL1CacheFreeSize
in interfaceMetricsRegionServerWrapper
-
getL1CacheCount
Description copied from interface:MetricsRegionServerWrapper
Number of blocks in L1 cache- Specified by:
getL1CacheCount
in interfaceMetricsRegionServerWrapper
-
getL1CacheEvictedCount
Description copied from interface:MetricsRegionServerWrapper
Number of blocks evicted from L1 cache- Specified by:
getL1CacheEvictedCount
in interfaceMetricsRegionServerWrapper
-
getL2CacheSize
Description copied from interface:MetricsRegionServerWrapper
Cache size (bytes) of L2 cache- Specified by:
getL2CacheSize
in interfaceMetricsRegionServerWrapper
-
getL2CacheFreeSize
Description copied from interface:MetricsRegionServerWrapper
Free cache size (bytes) of L2 cache- Specified by:
getL2CacheFreeSize
in interfaceMetricsRegionServerWrapper
-
getL2CacheCount
Description copied from interface:MetricsRegionServerWrapper
Number of blocks in L2 cache- Specified by:
getL2CacheCount
in interfaceMetricsRegionServerWrapper
-
getL2CacheEvictedCount
Description copied from interface:MetricsRegionServerWrapper
Number of blocks evicted from L2 cache- Specified by:
getL2CacheEvictedCount
in interfaceMetricsRegionServerWrapper
-
getL1CacheHitCount
Description copied from interface:MetricsRegionServerWrapper
Hit count of L1 cache.- Specified by:
getL1CacheHitCount
in interfaceMetricsRegionServerWrapper
-
getL1CacheMissCount
Description copied from interface:MetricsRegionServerWrapper
Miss count of L1 cache.- Specified by:
getL1CacheMissCount
in interfaceMetricsRegionServerWrapper
-
getL1CacheHitRatio
Description copied from interface:MetricsRegionServerWrapper
Hit ratio of L1 cache.- Specified by:
getL1CacheHitRatio
in interfaceMetricsRegionServerWrapper
-
getL1CacheMissRatio
Description copied from interface:MetricsRegionServerWrapper
Miss ratio of L1 cache.- Specified by:
getL1CacheMissRatio
in interfaceMetricsRegionServerWrapper
-
getL2CacheHitCount
Description copied from interface:MetricsRegionServerWrapper
Hit count of L2 cache.- Specified by:
getL2CacheHitCount
in interfaceMetricsRegionServerWrapper
-
getL2CacheMissCount
Description copied from interface:MetricsRegionServerWrapper
Miss count of L2 cache.- Specified by:
getL2CacheMissCount
in interfaceMetricsRegionServerWrapper
-
getL2CacheHitRatio
Description copied from interface:MetricsRegionServerWrapper
Hit ratio of L2 cache.- Specified by:
getL2CacheHitRatio
in interfaceMetricsRegionServerWrapper
-
getL2CacheMissRatio
Description copied from interface:MetricsRegionServerWrapper
Miss ratio of L2 cache.- Specified by:
getL2CacheMissRatio
in interfaceMetricsRegionServerWrapper
-
forceRecompute
Description copied from interface:MetricsRegionServerWrapper
Force a re-computation of the metrics.- Specified by:
forceRecompute
in interfaceMetricsRegionServerWrapper
-
getNumStores
Description copied from interface:MetricsRegionServerWrapper
Get the number of stores hosted on this region server.- Specified by:
getNumStores
in interfaceMetricsRegionServerWrapper
-
getNumWALFiles
Description copied from interface:MetricsRegionServerWrapper
Get the number of WAL files of this region server.- Specified by:
getNumWALFiles
in interfaceMetricsRegionServerWrapper
-
getWALFileSize
Description copied from interface:MetricsRegionServerWrapper
Get the size of WAL files of this region server.- Specified by:
getWALFileSize
in interfaceMetricsRegionServerWrapper
-
getWALExcludeDNs
Description copied from interface:MetricsRegionServerWrapper
Get the excluded datanodes in the cache of this region server.- Specified by:
getWALExcludeDNs
in interfaceMetricsRegionServerWrapper
-
getNumWALSlowAppend
Description copied from interface:MetricsRegionServerWrapper
Get the number of WAL files with slow appends for this region server.- Specified by:
getNumWALSlowAppend
in interfaceMetricsRegionServerWrapper
-
getNumStoreFiles
Description copied from interface:MetricsRegionServerWrapper
Get the number of store files hosted on this region server.- Specified by:
getNumStoreFiles
in interfaceMetricsRegionServerWrapper
-
getMaxStoreFiles
Description copied from interface:MetricsRegionServerWrapper
Get the max number of store files across all regions of this region server.- Specified by:
getMaxStoreFiles
in interfaceMetricsRegionServerWrapper
-
getMaxStoreFileAge
Description copied from interface:MetricsRegionServerWrapper
Returns Max age of store files hosted on this region server- Specified by:
getMaxStoreFileAge
in interfaceMetricsRegionServerWrapper
-
getMinStoreFileAge
Description copied from interface:MetricsRegionServerWrapper
Returns Min age of store files hosted on this region server- Specified by:
getMinStoreFileAge
in interfaceMetricsRegionServerWrapper
-
getAvgStoreFileAge
Description copied from interface:MetricsRegionServerWrapper
Returns Average age of store files hosted on this region server- Specified by:
getAvgStoreFileAge
in interfaceMetricsRegionServerWrapper
-
getNumReferenceFiles
Description copied from interface:MetricsRegionServerWrapper
Returns Number of reference files on this region server- Specified by:
getNumReferenceFiles
in interfaceMetricsRegionServerWrapper
-
getMemStoreSize
Description copied from interface:MetricsRegionServerWrapper
Get the size of the memstore on this region server.- Specified by:
getMemStoreSize
in interfaceMetricsRegionServerWrapper
-
getOnHeapMemStoreSize
Description copied from interface:MetricsRegionServerWrapper
Get the size of the on heap memstore on this region server.- Specified by:
getOnHeapMemStoreSize
in interfaceMetricsRegionServerWrapper
-
getOffHeapMemStoreSize
Description copied from interface:MetricsRegionServerWrapper
Get the size of the off heap memstore on this region server.- Specified by:
getOffHeapMemStoreSize
in interfaceMetricsRegionServerWrapper
-
getStoreFileSize
Description copied from interface:MetricsRegionServerWrapper
Get the total size of the store files this region server is serving from.- Specified by:
getStoreFileSize
in interfaceMetricsRegionServerWrapper
-
getStoreFileSizeGrowthRate
Description copied from interface:MetricsRegionServerWrapper
Get the growth rate of the store files this region server is serving from.- Specified by:
getStoreFileSizeGrowthRate
in interfaceMetricsRegionServerWrapper
-
getRequestsPerSecond
Description copied from interface:MetricsRegionServerWrapper
Get the number of requests per second.- Specified by:
getRequestsPerSecond
in interfaceMetricsRegionServerWrapper
-
getReadRequestsCount
Description copied from interface:MetricsRegionServerWrapper
Get the number of read requests to regions hosted on this region server.- Specified by:
getReadRequestsCount
in interfaceMetricsRegionServerWrapper
-
getCpRequestsCount
Description copied from interface:MetricsRegionServerWrapper
Get the number of coprocessor requests to regions hosted on this region server.- Specified by:
getCpRequestsCount
in interfaceMetricsRegionServerWrapper
-
getReadRequestsRatePerSecond
Description copied from interface:MetricsRegionServerWrapper
Get the rate of read requests per second to regions hosted on this region server.- Specified by:
getReadRequestsRatePerSecond
in interfaceMetricsRegionServerWrapper
-
getFilteredReadRequestsCount
Description copied from interface:MetricsRegionServerWrapper
Get the number of filtered read requests to regions hosted on this region server.- Specified by:
getFilteredReadRequestsCount
in interfaceMetricsRegionServerWrapper
-
getWriteRequestsCount
Description copied from interface:MetricsRegionServerWrapper
Get the number of write requests to regions hosted on this region server.- Specified by:
getWriteRequestsCount
in interfaceMetricsRegionServerWrapper
-
getWriteRequestsRatePerSecond
Description copied from interface:MetricsRegionServerWrapper
Get the rate of write requests per second to regions hosted on this region server.- Specified by:
getWriteRequestsRatePerSecond
in interfaceMetricsRegionServerWrapper
-
getRpcGetRequestsCount
Description copied from interface:MetricsRegionServerWrapper
Get the number of rpc get requests to this region server.- Specified by:
getRpcGetRequestsCount
in interfaceMetricsRegionServerWrapper
-
getRpcScanRequestsCount
Description copied from interface:MetricsRegionServerWrapper
Get the number of rpc scan requests to this region server.- Specified by:
getRpcScanRequestsCount
in interfaceMetricsRegionServerWrapper
-
getRpcFullScanRequestsCount
Description copied from interface:MetricsRegionServerWrapper
Get the number of full region rpc scan requests to this region server.- Specified by:
getRpcFullScanRequestsCount
in interfaceMetricsRegionServerWrapper
-
getRpcMultiRequestsCount
Description copied from interface:MetricsRegionServerWrapper
Get the number of rpc multi requests to this region server.- Specified by:
getRpcMultiRequestsCount
in interfaceMetricsRegionServerWrapper
-
getRpcMutateRequestsCount
Description copied from interface:MetricsRegionServerWrapper
Get the number of rpc mutate requests to this region server.- Specified by:
getRpcMutateRequestsCount
in interfaceMetricsRegionServerWrapper
-
getCheckAndMutateChecksFailed
Description copied from interface:MetricsRegionServerWrapper
Get the number of CAS operations that failed.- Specified by:
getCheckAndMutateChecksFailed
in interfaceMetricsRegionServerWrapper
-
getCheckAndMutateChecksPassed
Description copied from interface:MetricsRegionServerWrapper
Get the number of CAS operations that passed.- Specified by:
getCheckAndMutateChecksPassed
in interfaceMetricsRegionServerWrapper
-
getStoreFileIndexSize
Description copied from interface:MetricsRegionServerWrapper
Get the Size (in bytes) of indexes in storefiles on disk.- Specified by:
getStoreFileIndexSize
in interfaceMetricsRegionServerWrapper
-
getTotalStaticIndexSize
Description copied from interface:MetricsRegionServerWrapper
Get the size (in bytes) of of the static indexes including the roots.- Specified by:
getTotalStaticIndexSize
in interfaceMetricsRegionServerWrapper
-
getTotalStaticBloomSize
Description copied from interface:MetricsRegionServerWrapper
Get the size (in bytes) of the static bloom filters.- Specified by:
getTotalStaticBloomSize
in interfaceMetricsRegionServerWrapper
-
getBloomFilterRequestsCount
Description copied from interface:MetricsRegionServerWrapper
Count of bloom filter requests.- Specified by:
getBloomFilterRequestsCount
in interfaceMetricsRegionServerWrapper
-
getBloomFilterNegativeResultsCount
Description copied from interface:MetricsRegionServerWrapper
Count of bloom filter requests which return a negative result.- Specified by:
getBloomFilterNegativeResultsCount
in interfaceMetricsRegionServerWrapper
-
getBloomFilterEligibleRequestsCount
Description copied from interface:MetricsRegionServerWrapper
Count of requests which could have used bloom filters, but they weren't configured or loaded.- Specified by:
getBloomFilterEligibleRequestsCount
in interfaceMetricsRegionServerWrapper
-
getNumMutationsWithoutWAL
Description copied from interface:MetricsRegionServerWrapper
Number of mutations received with WAL explicitly turned off.- Specified by:
getNumMutationsWithoutWAL
in interfaceMetricsRegionServerWrapper
-
getDataInMemoryWithoutWAL
Description copied from interface:MetricsRegionServerWrapper
Ammount of data in the memstore but not in the WAL because mutations explicitly had their WAL turned off.- Specified by:
getDataInMemoryWithoutWAL
in interfaceMetricsRegionServerWrapper
-
getPercentFileLocal
Description copied from interface:MetricsRegionServerWrapper
Get the percent of HFiles' that are local.- Specified by:
getPercentFileLocal
in interfaceMetricsRegionServerWrapper
-
getPercentFileLocalSecondaryRegions
Description copied from interface:MetricsRegionServerWrapper
Get the percent of HFiles' that are local for secondary region replicas.- Specified by:
getPercentFileLocalSecondaryRegions
in interfaceMetricsRegionServerWrapper
-
getUpdatesBlockedTime
Description copied from interface:MetricsRegionServerWrapper
Get the amount of time that updates were blocked.- Specified by:
getUpdatesBlockedTime
in interfaceMetricsRegionServerWrapper
-
getFlushedCellsCount
Description copied from interface:MetricsRegionServerWrapper
Get the number of cells flushed to disk.- Specified by:
getFlushedCellsCount
in interfaceMetricsRegionServerWrapper
-
getCompactedCellsCount
Description copied from interface:MetricsRegionServerWrapper
Get the number of cells processed during minor compactions.- Specified by:
getCompactedCellsCount
in interfaceMetricsRegionServerWrapper
-
getMajorCompactedCellsCount
Description copied from interface:MetricsRegionServerWrapper
Get the number of cells processed during major compactions.- Specified by:
getMajorCompactedCellsCount
in interfaceMetricsRegionServerWrapper
-
getFlushedCellsSize
Description copied from interface:MetricsRegionServerWrapper
Get the total amount of data flushed to disk, in bytes.- Specified by:
getFlushedCellsSize
in interfaceMetricsRegionServerWrapper
-
getCompactedCellsSize
Description copied from interface:MetricsRegionServerWrapper
Get the total amount of data processed during minor compactions, in bytes.- Specified by:
getCompactedCellsSize
in interfaceMetricsRegionServerWrapper
-
getMajorCompactedCellsSize
Description copied from interface:MetricsRegionServerWrapper
Get the total amount of data processed during major compactions, in bytes.- Specified by:
getMajorCompactedCellsSize
in interfaceMetricsRegionServerWrapper
-
getCellsCountCompactedFromMob
Description copied from interface:MetricsRegionServerWrapper
Gets the number of cells moved from mob during compaction.- Specified by:
getCellsCountCompactedFromMob
in interfaceMetricsRegionServerWrapper
-
getCellsCountCompactedToMob
Description copied from interface:MetricsRegionServerWrapper
Gets the number of cells moved to mob during compaction.- Specified by:
getCellsCountCompactedToMob
in interfaceMetricsRegionServerWrapper
-
getCellsSizeCompactedFromMob
Description copied from interface:MetricsRegionServerWrapper
Gets the total amount of cells moved from mob during compaction, in bytes.- Specified by:
getCellsSizeCompactedFromMob
in interfaceMetricsRegionServerWrapper
-
getCellsSizeCompactedToMob
Description copied from interface:MetricsRegionServerWrapper
Gets the total amount of cells moved to mob during compaction, in bytes.- Specified by:
getCellsSizeCompactedToMob
in interfaceMetricsRegionServerWrapper
-
getMobFlushCount
Description copied from interface:MetricsRegionServerWrapper
Gets the number of the flushes in mob-enabled stores.- Specified by:
getMobFlushCount
in interfaceMetricsRegionServerWrapper
-
getMobFlushedCellsCount
Description copied from interface:MetricsRegionServerWrapper
Gets the number of mob cells flushed to disk.- Specified by:
getMobFlushedCellsCount
in interfaceMetricsRegionServerWrapper
-
getMobFlushedCellsSize
Description copied from interface:MetricsRegionServerWrapper
Gets the total amount of mob cells flushed to disk, in bytes.- Specified by:
getMobFlushedCellsSize
in interfaceMetricsRegionServerWrapper
-
getMobScanCellsCount
Description copied from interface:MetricsRegionServerWrapper
Gets the number of scanned mob cells.- Specified by:
getMobScanCellsCount
in interfaceMetricsRegionServerWrapper
-
getMobScanCellsSize
Description copied from interface:MetricsRegionServerWrapper
Gets the total amount of scanned mob cells, in bytes.- Specified by:
getMobScanCellsSize
in interfaceMetricsRegionServerWrapper
-
getMobFileCacheAccessCount
Description copied from interface:MetricsRegionServerWrapper
Gets the count of accesses to the mob file cache.- Specified by:
getMobFileCacheAccessCount
in interfaceMetricsRegionServerWrapper
-
getMobFileCacheMissCount
Description copied from interface:MetricsRegionServerWrapper
Gets the count of misses to the mob file cache.- Specified by:
getMobFileCacheMissCount
in interfaceMetricsRegionServerWrapper
-
getMobFileCacheCount
Description copied from interface:MetricsRegionServerWrapper
Gets the count of cached mob files.- Specified by:
getMobFileCacheCount
in interfaceMetricsRegionServerWrapper
-
getMobFileCacheEvictedCount
Description copied from interface:MetricsRegionServerWrapper
Gets the number of items evicted from the mob file cache.- Specified by:
getMobFileCacheEvictedCount
in interfaceMetricsRegionServerWrapper
-
getMobFileCacheHitPercent
Description copied from interface:MetricsRegionServerWrapper
Gets the hit percent to the mob file cache.- Specified by:
getMobFileCacheHitPercent
in interfaceMetricsRegionServerWrapper
-
getActiveScanners
- Specified by:
getActiveScanners
in interfaceMetricsRegionServerWrapper
-
getHedgedReadOps
Description copied from interface:MetricsRegionServerWrapper
Returns Count of hedged read operations- Specified by:
getHedgedReadOps
in interfaceMetricsRegionServerWrapper
-
getHedgedReadWins
Description copied from interface:MetricsRegionServerWrapper
Returns Count of times a hedged read beat out the primary read.- Specified by:
getHedgedReadWins
in interfaceMetricsRegionServerWrapper
-
getHedgedReadOpsInCurThread
Description copied from interface:MetricsRegionServerWrapper
Returns Count of times a hedged read executes in current thread- Specified by:
getHedgedReadOpsInCurThread
in interfaceMetricsRegionServerWrapper
-
getTotalBytesRead
Description copied from interface:MetricsRegionServerWrapper
Returns Number of total bytes read from HDFS.- Specified by:
getTotalBytesRead
in interfaceMetricsRegionServerWrapper
-
getLocalBytesRead
Description copied from interface:MetricsRegionServerWrapper
Returns Number of bytes read from the local HDFS DataNode.- Specified by:
getLocalBytesRead
in interfaceMetricsRegionServerWrapper
-
getShortCircuitBytesRead
Description copied from interface:MetricsRegionServerWrapper
Returns Number of bytes read locally through HDFS short circuit.- Specified by:
getShortCircuitBytesRead
in interfaceMetricsRegionServerWrapper
-
getZeroCopyBytesRead
Description copied from interface:MetricsRegionServerWrapper
Returns Number of bytes read locally through HDFS zero copy.- Specified by:
getZeroCopyBytesRead
in interfaceMetricsRegionServerWrapper
-
getBlockedRequestsCount
Description copied from interface:MetricsRegionServerWrapper
Returns Count of requests blocked because the memstore size is larger than blockingMemStoreSize- Specified by:
getBlockedRequestsCount
in interfaceMetricsRegionServerWrapper
-
getAverageRegionSize
Description copied from interface:MetricsRegionServerWrapper
Get the average region size to this region server.- Specified by:
getAverageRegionSize
in interfaceMetricsRegionServerWrapper
-
getDataMissCount
- Specified by:
getDataMissCount
in interfaceMetricsRegionServerWrapper
-
getLeafIndexMissCount
- Specified by:
getLeafIndexMissCount
in interfaceMetricsRegionServerWrapper
-
getBloomChunkMissCount
- Specified by:
getBloomChunkMissCount
in interfaceMetricsRegionServerWrapper
-
getMetaMissCount
- Specified by:
getMetaMissCount
in interfaceMetricsRegionServerWrapper
-
getRootIndexMissCount
- Specified by:
getRootIndexMissCount
in interfaceMetricsRegionServerWrapper
-
getIntermediateIndexMissCount
- Specified by:
getIntermediateIndexMissCount
in interfaceMetricsRegionServerWrapper
-
getFileInfoMissCount
- Specified by:
getFileInfoMissCount
in interfaceMetricsRegionServerWrapper
-
getGeneralBloomMetaMissCount
- Specified by:
getGeneralBloomMetaMissCount
in interfaceMetricsRegionServerWrapper
-
getDeleteFamilyBloomMissCount
- Specified by:
getDeleteFamilyBloomMissCount
in interfaceMetricsRegionServerWrapper
-
getTrailerMissCount
- Specified by:
getTrailerMissCount
in interfaceMetricsRegionServerWrapper
-
getDataHitCount
- Specified by:
getDataHitCount
in interfaceMetricsRegionServerWrapper
-
getLeafIndexHitCount
- Specified by:
getLeafIndexHitCount
in interfaceMetricsRegionServerWrapper
-
getBloomChunkHitCount
- Specified by:
getBloomChunkHitCount
in interfaceMetricsRegionServerWrapper
-
getMetaHitCount
- Specified by:
getMetaHitCount
in interfaceMetricsRegionServerWrapper
-
getRootIndexHitCount
- Specified by:
getRootIndexHitCount
in interfaceMetricsRegionServerWrapper
-
getIntermediateIndexHitCount
- Specified by:
getIntermediateIndexHitCount
in interfaceMetricsRegionServerWrapper
-
getFileInfoHitCount
- Specified by:
getFileInfoHitCount
in interfaceMetricsRegionServerWrapper
-
getGeneralBloomMetaHitCount
- Specified by:
getGeneralBloomMetaHitCount
in interfaceMetricsRegionServerWrapper
-
getDeleteFamilyBloomHitCount
- Specified by:
getDeleteFamilyBloomHitCount
in interfaceMetricsRegionServerWrapper
-
getTrailerHitCount
- Specified by:
getTrailerHitCount
in interfaceMetricsRegionServerWrapper
-
getByteBuffAllocatorHeapAllocationBytes
- Specified by:
getByteBuffAllocatorHeapAllocationBytes
in interfaceMetricsRegionServerWrapper
-
getByteBuffAllocatorPoolAllocationBytes
- Specified by:
getByteBuffAllocatorPoolAllocationBytes
in interfaceMetricsRegionServerWrapper
-
getByteBuffAllocatorHeapAllocRatio
- Specified by:
getByteBuffAllocatorHeapAllocRatio
in interfaceMetricsRegionServerWrapper
-
getByteBuffAllocatorTotalBufferCount
- Specified by:
getByteBuffAllocatorTotalBufferCount
in interfaceMetricsRegionServerWrapper
-
getByteBuffAllocatorUsedBufferCount
- Specified by:
getByteBuffAllocatorUsedBufferCount
in interfaceMetricsRegionServerWrapper
-
getPeriod
long getPeriod()
-