@InterfaceAudience.Private class MetricsRegionServerWrapperImpl extends Object implements MetricsRegionServerWrapper
Modifier and Type | Class and Description |
---|---|
class |
MetricsRegionServerWrapperImpl.RegionServerMetricsWrapperRunnable
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.
|
Constructor and Description |
---|
MetricsRegionServerWrapperImpl(HRegionServer regionServer) |
Modifier and Type | Method and Description |
---|---|
void |
forceRecompute()
Force a re-computation of the metrics.
|
int |
getActiveScanners() |
long |
getAverageRegionSize()
Get the average region size to this region server.
|
long |
getAvgStoreFileAge()
Returns Average age of store files hosted on this region server
|
long |
getBlockCacheCount()
Get the number of items in the block cache.
|
long |
getBlockCacheDataBlockCount()
Get the number of DATA blocks in the block cache.
|
long |
getBlockCacheEvictedCount()
Get the number of items evicted from the block cache.
|
long |
getBlockCacheFailedInsertions()
Number of cache insertions that failed.
|
long |
getBlockCacheFreeSize()
Get the size (in bytes) of the block cache that is free.
|
double |
getBlockCacheHitCachingPercent()
Get the percent of requests with the block cache turned on that hit the block cache.
|
long |
getBlockCacheHitCount()
Get the count of hits to the block cache
|
double |
getBlockCacheHitPercent()
Get the percent of all requests that hit the block cache.
|
long |
getBlockCacheMissCount()
Get the count of misses to the block cache.
|
long |
getBlockCachePrimaryEvictedCount()
Get the number of items evicted from primary replica in the block cache.
|
long |
getBlockCachePrimaryHitCount()
Get the count of hits to primary replica in the block cache
|
long |
getBlockCachePrimaryMissCount()
Get the count of misses to primary replica in the block cache.
|
long |
getBlockCacheSize()
Get the total size (in bytes) of the block cache.
|
long |
getBlockedRequestsCount()
Returns Count of requests blocked because the memstore size is larger than blockingMemStoreSize
|
long |
getBloomChunkHitCount() |
long |
getBloomChunkMissCount() |
long |
getBloomFilterEligibleRequestsCount()
Count of requests which could have used bloom filters, but they weren't configured or loaded.
|
long |
getBloomFilterNegativeResultsCount()
Count of bloom filter requests which return a negative result.
|
long |
getBloomFilterRequestsCount()
Count of bloom filter requests.
|
long |
getByteBuffAllocatorHeapAllocationBytes() |
double |
getByteBuffAllocatorHeapAllocRatio() |
long |
getByteBuffAllocatorPoolAllocationBytes() |
long |
getByteBuffAllocatorTotalBufferCount() |
long |
getByteBuffAllocatorUsedBufferCount() |
long |
getCellsCountCompactedFromMob()
Gets the number of cells moved from mob during compaction.
|
long |
getCellsCountCompactedToMob()
Gets the number of cells moved to mob during compaction.
|
long |
getCellsSizeCompactedFromMob()
Gets the total amount of cells moved from mob during compaction, in bytes.
|
long |
getCellsSizeCompactedToMob()
Gets the total amount of cells moved to mob during compaction, in bytes.
|
long |
getCheckAndMutateChecksFailed()
Get the number of CAS operations that failed.
|
long |
getCheckAndMutateChecksPassed()
Get the number of CAS operations that passed.
|
String |
getClusterId()
Get the Cluster ID
|
long |
getCompactedCellsCount()
Get the number of cells processed during minor compactions.
|
long |
getCompactedCellsSize()
Get the total amount of data processed during minor compactions, in bytes.
|
int |
getCompactionQueueSize()
Get the size of the compaction queue
|
String |
getCoprocessors()
Get the co-processors
|
long |
getDataHitCount() |
long |
getDataInMemoryWithoutWAL()
Ammount of data in the memstore but not in the WAL because mutations explicitly had their WAL
turned off.
|
long |
getDataMissCount() |
long |
getDeleteFamilyBloomHitCount() |
long |
getDeleteFamilyBloomMissCount() |
long |
getFileInfoHitCount() |
long |
getFileInfoMissCount() |
long |
getFilteredReadRequestsCount()
Get the number of filtered read requests to regions hosted on this region server.
|
long |
getFlushedCellsCount()
Get the number of cells flushed to disk.
|
long |
getFlushedCellsSize()
Get the total amount of data flushed to disk, in bytes.
|
int |
getFlushQueueSize()
Get the size of the flush queue.
|
long |
getGeneralBloomMetaHitCount() |
long |
getGeneralBloomMetaMissCount() |
long |
getHedgedReadOps()
Returns Count of hedged read operations
|
long |
getHedgedReadOpsInCurThread()
Returns Count of times a hedged read executes in current thread
|
long |
getHedgedReadWins()
Returns Count of times a hedged read beat out the primary read.
|
long |
getIntermediateIndexHitCount() |
long |
getIntermediateIndexMissCount() |
long |
getL1CacheCount()
Number of blocks in L1 cache
|
long |
getL1CacheEvictedCount()
Number of blocks evicted from L1 cache
|
long |
getL1CacheFreeSize()
Free cache size (bytes) of L1 cache
|
long |
getL1CacheHitCount()
Hit count of L1 cache.
|
double |
getL1CacheHitRatio()
Hit ratio of L1 cache.
|
long |
getL1CacheMissCount()
Miss count of L1 cache.
|
double |
getL1CacheMissRatio()
Miss ratio of L1 cache.
|
long |
getL1CacheSize()
Cache size (bytes) of L1 cache
|
long |
getL2CacheCount()
Number of blocks in L2 cache
|
long |
getL2CacheEvictedCount()
Number of blocks evicted from L2 cache
|
long |
getL2CacheFreeSize()
Free cache size (bytes) of L2 cache
|
long |
getL2CacheHitCount()
Hit count of L2 cache.
|
double |
getL2CacheHitRatio()
Hit ratio of L2 cache.
|
long |
getL2CacheMissCount()
Miss count of L2 cache.
|
double |
getL2CacheMissRatio()
Miss ratio of L2 cache.
|
long |
getL2CacheSize()
Cache size (bytes) of L2 cache
|
int |
getLargeCompactionQueueSize() |
long |
getLeafIndexHitCount() |
long |
getLeafIndexMissCount() |
long |
getLocalBytesRead()
Returns Number of bytes read from the local HDFS DataNode.
|
long |
getMajorCompactedCellsCount()
Get the number of cells processed during major compactions.
|
long |
getMajorCompactedCellsSize()
Get the total amount of data processed during major compactions, in bytes.
|
long |
getMaxStoreFileAge()
Returns Max age of store files hosted on this region server
|
long |
getMaxStoreFiles()
Get the max number of store files across all regions of this region server.
|
long |
getMemStoreLimit()
Get the limit size of the off heap memstore (if enabled), otherwise get the limit size of the
on heap memstore.
|
long |
getMemStoreSize()
Get the size of the memstore on this region server.
|
long |
getMetaHitCount() |
long |
getMetaMissCount() |
long |
getMinStoreFileAge()
Returns Min age of store files hosted on this region server
|
long |
getMobFileCacheAccessCount()
Gets the count of accesses to the mob file cache.
|
long |
getMobFileCacheCount()
Gets the count of cached mob files.
|
long |
getMobFileCacheEvictedCount()
Gets the number of items evicted from the mob file cache.
|
double |
getMobFileCacheHitPercent()
Gets the hit percent to the mob file cache.
|
long |
getMobFileCacheMissCount()
Gets the count of misses to the mob file cache.
|
long |
getMobFlushCount()
Gets the number of the flushes in mob-enabled stores.
|
long |
getMobFlushedCellsCount()
Gets the number of mob cells flushed to disk.
|
long |
getMobFlushedCellsSize()
Gets the total amount of mob cells flushed to disk, in bytes.
|
long |
getMobScanCellsCount()
Gets the number of scanned mob cells.
|
long |
getMobScanCellsSize()
Gets the total amount of scanned mob cells, in bytes.
|
long |
getNumMutationsWithoutWAL()
Number of mutations received with WAL explicitly turned off.
|
long |
getNumOnlineRegions()
The number of online regions
|
long |
getNumReferenceFiles()
Returns Number of reference files on this region server
|
long |
getNumStoreFiles()
Get the number of store files hosted on this region server.
|
long |
getNumStores()
Get the number of stores hosted on this region server.
|
long |
getNumWALFiles()
Get the number of WAL files of this region server.
|
long |
getNumWALSlowAppend()
Get the number of WAL files with slow appends for this region server.
|
long |
getOffHeapMemStoreLimit()
Get the limit size of the off heap memstore.
|
long |
getOffHeapMemStoreSize()
Get the size of the off heap memstore on this region server.
|
long |
getOnHeapMemStoreLimit()
Get the limit size of the on heap memstore.
|
long |
getOnHeapMemStoreSize()
Get the size of the on heap memstore on this region server.
|
double |
getPercentFileLocal()
Get the percent of HFiles' that are local.
|
double |
getPercentFileLocalSecondaryRegions()
Get the percent of HFiles' that are local for secondary region replicas.
|
long |
getReadRequestsCount()
Get the number of read requests to regions hosted on this region server.
|
double |
getReadRequestsRatePerSecond()
Get the rate of read requests per second to regions hosted on this region server.
|
double |
getRequestsPerSecond()
Get the number of requests per second.
|
long |
getRootIndexHitCount() |
long |
getRootIndexMissCount() |
long |
getRpcFullScanRequestsCount()
Get the number of full region rpc scan requests to this region server.
|
long |
getRpcGetRequestsCount()
Get the number of rpc get requests to this region server.
|
long |
getRpcMultiRequestsCount()
Get the number of rpc multi requests to this region server.
|
long |
getRpcMutateRequestsCount()
Get the number of rpc mutate requests to this region server.
|
long |
getRpcScanRequestsCount()
Get the number of rpc scan requests to this region server.
|
String |
getServerName()
Get ServerName
|
long |
getShortCircuitBytesRead()
Returns Number of bytes read locally through HDFS short circuit.
|
int |
getSmallCompactionQueueSize() |
int |
getSplitQueueSize()
Get the size of the split queue
|
long |
getStartCode()
Get HRegionServer start time
|
long |
getStoreFileIndexSize()
Get the Size (in bytes) of indexes in storefiles on disk.
|
long |
getStoreFileSize()
Get the total size of the store files this region server is serving from.
|
long |
getTotalBytesRead()
Returns Number of total bytes read from HDFS.
|
long |
getTotalRequestCount()
Get the total number of requests per second.
|
long |
getTotalRowActionRequestCount() |
long |
getTotalStaticBloomSize()
Get the size (in bytes) of the static bloom filters.
|
long |
getTotalStaticIndexSize()
Get the size (in bytes) of of the static indexes including the roots.
|
long |
getTrailerHitCount() |
long |
getTrailerMissCount() |
long |
getUpdatesBlockedTime()
Get the amount of time that updates were blocked.
|
List<String> |
getWALExcludeDNs()
Get the excluded datanodes in the cache of this region server.
|
long |
getWALFileSize()
Get the size of WAL files of this region server.
|
long |
getWriteRequestsCount()
Get the number of write requests to regions hosted on this region server.
|
double |
getWriteRequestsRatePerSecond()
Get the rate of write requests per second to regions hosted on this region server.
|
long |
getZeroCopyBytesRead()
Returns Number of bytes read locally through HDFS zero copy.
|
String |
getZookeeperQuorum()
Get the ZooKeeper Quorum Info
|
private void |
initBlockCache() |
private void |
initMobFileCache()
Initializes the mob file cache.
|
private static final org.slf4j.Logger LOG
private final HRegionServer regionServer
private final MetricsWALSource metricsWALSource
private final ByteBuffAllocator allocator
private BlockCache blockCache
private BlockCache l1Cache
private BlockCache l2Cache
private MobFileCache mobFileCache
private CacheStats cacheStats
private CacheStats l1Stats
private CacheStats l2Stats
private volatile long numStores
private volatile long numWALFiles
private volatile long walFileSize
private volatile long numStoreFiles
private volatile long memstoreSize
private volatile long onHeapMemstoreSize
private volatile long offHeapMemstoreSize
private volatile long storeFileSize
private volatile long maxStoreFileCount
private volatile long maxStoreFileAge
private volatile long minStoreFileAge
private volatile long avgStoreFileAge
private volatile long numReferenceFiles
private volatile double requestsPerSecond
private volatile long readRequestsCount
private volatile double readRequestsRatePerSecond
private volatile long filteredReadRequestsCount
private volatile long writeRequestsCount
private volatile double writeRequestsRatePerSecond
private volatile long checkAndMutateChecksFailed
private volatile long checkAndMutateChecksPassed
private volatile long storefileIndexSize
private volatile long totalStaticIndexSize
private volatile long totalStaticBloomSize
private volatile long bloomFilterRequestsCount
private volatile long bloomFilterNegativeResultsCount
private volatile long bloomFilterEligibleRequestsCount
private volatile long numMutationsWithoutWAL
private volatile long dataInMemoryWithoutWAL
private volatile double percentFileLocal
private volatile double percentFileLocalSecondaryRegions
private volatile long flushedCellsCount
private volatile long compactedCellsCount
private volatile long majorCompactedCellsCount
private volatile long flushedCellsSize
private volatile long compactedCellsSize
private volatile long majorCompactedCellsSize
private volatile long cellsCountCompactedToMob
private volatile long cellsCountCompactedFromMob
private volatile long cellsSizeCompactedToMob
private volatile long cellsSizeCompactedFromMob
private volatile long mobFlushCount
private volatile long mobFlushedCellsCount
private volatile long mobFlushedCellsSize
private volatile long mobScanCellsCount
private volatile long mobScanCellsSize
private volatile long mobFileCacheAccessCount
private volatile long mobFileCacheMissCount
private volatile double mobFileCacheHitRatio
private volatile long mobFileCacheEvictedCount
private volatile long mobFileCacheCount
private volatile long blockedRequestsCount
private volatile long averageRegionSize
protected final Map<String,ArrayList<Long>> requestsCountCache
private ScheduledExecutorService executor
private long period
private org.apache.hadoop.hdfs.DFSHedgedReadMetrics dfsHedgedReadMetrics
private final ExcludeDatanodeManager excludeDatanodeManager
public MetricsRegionServerWrapperImpl(HRegionServer regionServer)
private void initBlockCache()
private void initMobFileCache()
public String getClusterId()
MetricsRegionServerWrapper
getClusterId
in interface MetricsRegionServerWrapper
public long getStartCode()
MetricsRegionServerWrapper
getStartCode
in interface MetricsRegionServerWrapper
public String getZookeeperQuorum()
MetricsRegionServerWrapper
getZookeeperQuorum
in interface MetricsRegionServerWrapper
public String getCoprocessors()
MetricsRegionServerWrapper
getCoprocessors
in interface MetricsRegionServerWrapper
public String getServerName()
MetricsRegionServerWrapper
getServerName
in interface MetricsRegionServerWrapper
public long getNumOnlineRegions()
MetricsRegionServerWrapper
getNumOnlineRegions
in interface MetricsRegionServerWrapper
public long getTotalRequestCount()
MetricsRegionServerWrapper
getTotalRequestCount
in interface MetricsRegionServerWrapper
public long getTotalRowActionRequestCount()
getTotalRowActionRequestCount
in interface MetricsRegionServerWrapper
public int getSplitQueueSize()
MetricsRegionServerWrapper
getSplitQueueSize
in interface MetricsRegionServerWrapper
public int getCompactionQueueSize()
MetricsRegionServerWrapper
getCompactionQueueSize
in interface MetricsRegionServerWrapper
public int getSmallCompactionQueueSize()
getSmallCompactionQueueSize
in interface MetricsRegionServerWrapper
public int getLargeCompactionQueueSize()
getLargeCompactionQueueSize
in interface MetricsRegionServerWrapper
public int getFlushQueueSize()
MetricsRegionServerWrapper
getFlushQueueSize
in interface MetricsRegionServerWrapper
public long getBlockCacheCount()
MetricsRegionServerWrapper
getBlockCacheCount
in interface MetricsRegionServerWrapper
public long getBlockCacheDataBlockCount()
MetricsRegionServerWrapper
getBlockCacheDataBlockCount
in interface MetricsRegionServerWrapper
public long getMemStoreLimit()
MetricsRegionServerWrapper
getMemStoreLimit
in interface MetricsRegionServerWrapper
public long getOnHeapMemStoreLimit()
MetricsRegionServerWrapper
getOnHeapMemStoreLimit
in interface MetricsRegionServerWrapper
public long getOffHeapMemStoreLimit()
MetricsRegionServerWrapper
getOffHeapMemStoreLimit
in interface MetricsRegionServerWrapper
public long getBlockCacheSize()
MetricsRegionServerWrapper
getBlockCacheSize
in interface MetricsRegionServerWrapper
public long getBlockCacheFreeSize()
MetricsRegionServerWrapper
getBlockCacheFreeSize
in interface MetricsRegionServerWrapper
public long getBlockCacheHitCount()
MetricsRegionServerWrapper
getBlockCacheHitCount
in interface MetricsRegionServerWrapper
public long getBlockCachePrimaryHitCount()
MetricsRegionServerWrapper
getBlockCachePrimaryHitCount
in interface MetricsRegionServerWrapper
public long getBlockCacheMissCount()
MetricsRegionServerWrapper
getBlockCacheMissCount
in interface MetricsRegionServerWrapper
public long getBlockCachePrimaryMissCount()
MetricsRegionServerWrapper
getBlockCachePrimaryMissCount
in interface MetricsRegionServerWrapper
public long getBlockCacheEvictedCount()
MetricsRegionServerWrapper
getBlockCacheEvictedCount
in interface MetricsRegionServerWrapper
public long getBlockCachePrimaryEvictedCount()
MetricsRegionServerWrapper
getBlockCachePrimaryEvictedCount
in interface MetricsRegionServerWrapper
public double getBlockCacheHitPercent()
MetricsRegionServerWrapper
getBlockCacheHitPercent
in interface MetricsRegionServerWrapper
public double getBlockCacheHitCachingPercent()
MetricsRegionServerWrapper
getBlockCacheHitCachingPercent
in interface MetricsRegionServerWrapper
public long getBlockCacheFailedInsertions()
MetricsRegionServerWrapper
getBlockCacheFailedInsertions
in interface MetricsRegionServerWrapper
public long getL1CacheSize()
MetricsRegionServerWrapper
getL1CacheSize
in interface MetricsRegionServerWrapper
public long getL1CacheFreeSize()
MetricsRegionServerWrapper
getL1CacheFreeSize
in interface MetricsRegionServerWrapper
public long getL1CacheCount()
MetricsRegionServerWrapper
getL1CacheCount
in interface MetricsRegionServerWrapper
public long getL1CacheEvictedCount()
MetricsRegionServerWrapper
getL1CacheEvictedCount
in interface MetricsRegionServerWrapper
public long getL2CacheSize()
MetricsRegionServerWrapper
getL2CacheSize
in interface MetricsRegionServerWrapper
public long getL2CacheFreeSize()
MetricsRegionServerWrapper
getL2CacheFreeSize
in interface MetricsRegionServerWrapper
public long getL2CacheCount()
MetricsRegionServerWrapper
getL2CacheCount
in interface MetricsRegionServerWrapper
public long getL2CacheEvictedCount()
MetricsRegionServerWrapper
getL2CacheEvictedCount
in interface MetricsRegionServerWrapper
public long getL1CacheHitCount()
MetricsRegionServerWrapper
getL1CacheHitCount
in interface MetricsRegionServerWrapper
public long getL1CacheMissCount()
MetricsRegionServerWrapper
getL1CacheMissCount
in interface MetricsRegionServerWrapper
public double getL1CacheHitRatio()
MetricsRegionServerWrapper
getL1CacheHitRatio
in interface MetricsRegionServerWrapper
public double getL1CacheMissRatio()
MetricsRegionServerWrapper
getL1CacheMissRatio
in interface MetricsRegionServerWrapper
public long getL2CacheHitCount()
MetricsRegionServerWrapper
getL2CacheHitCount
in interface MetricsRegionServerWrapper
public long getL2CacheMissCount()
MetricsRegionServerWrapper
getL2CacheMissCount
in interface MetricsRegionServerWrapper
public double getL2CacheHitRatio()
MetricsRegionServerWrapper
getL2CacheHitRatio
in interface MetricsRegionServerWrapper
public double getL2CacheMissRatio()
MetricsRegionServerWrapper
getL2CacheMissRatio
in interface MetricsRegionServerWrapper
public void forceRecompute()
MetricsRegionServerWrapper
forceRecompute
in interface MetricsRegionServerWrapper
public long getNumStores()
MetricsRegionServerWrapper
getNumStores
in interface MetricsRegionServerWrapper
public long getNumWALFiles()
MetricsRegionServerWrapper
getNumWALFiles
in interface MetricsRegionServerWrapper
public long getWALFileSize()
MetricsRegionServerWrapper
getWALFileSize
in interface MetricsRegionServerWrapper
public List<String> getWALExcludeDNs()
MetricsRegionServerWrapper
getWALExcludeDNs
in interface MetricsRegionServerWrapper
public long getNumWALSlowAppend()
MetricsRegionServerWrapper
getNumWALSlowAppend
in interface MetricsRegionServerWrapper
public long getNumStoreFiles()
MetricsRegionServerWrapper
getNumStoreFiles
in interface MetricsRegionServerWrapper
public long getMaxStoreFiles()
MetricsRegionServerWrapper
getMaxStoreFiles
in interface MetricsRegionServerWrapper
public long getMaxStoreFileAge()
MetricsRegionServerWrapper
getMaxStoreFileAge
in interface MetricsRegionServerWrapper
public long getMinStoreFileAge()
MetricsRegionServerWrapper
getMinStoreFileAge
in interface MetricsRegionServerWrapper
public long getAvgStoreFileAge()
MetricsRegionServerWrapper
getAvgStoreFileAge
in interface MetricsRegionServerWrapper
public long getNumReferenceFiles()
MetricsRegionServerWrapper
getNumReferenceFiles
in interface MetricsRegionServerWrapper
public long getMemStoreSize()
MetricsRegionServerWrapper
getMemStoreSize
in interface MetricsRegionServerWrapper
public long getOnHeapMemStoreSize()
MetricsRegionServerWrapper
getOnHeapMemStoreSize
in interface MetricsRegionServerWrapper
public long getOffHeapMemStoreSize()
MetricsRegionServerWrapper
getOffHeapMemStoreSize
in interface MetricsRegionServerWrapper
public long getStoreFileSize()
MetricsRegionServerWrapper
getStoreFileSize
in interface MetricsRegionServerWrapper
public double getRequestsPerSecond()
MetricsRegionServerWrapper
getRequestsPerSecond
in interface MetricsRegionServerWrapper
public long getReadRequestsCount()
MetricsRegionServerWrapper
getReadRequestsCount
in interface MetricsRegionServerWrapper
public double getReadRequestsRatePerSecond()
MetricsRegionServerWrapper
getReadRequestsRatePerSecond
in interface MetricsRegionServerWrapper
public long getFilteredReadRequestsCount()
MetricsRegionServerWrapper
getFilteredReadRequestsCount
in interface MetricsRegionServerWrapper
public long getWriteRequestsCount()
MetricsRegionServerWrapper
getWriteRequestsCount
in interface MetricsRegionServerWrapper
public double getWriteRequestsRatePerSecond()
MetricsRegionServerWrapper
getWriteRequestsRatePerSecond
in interface MetricsRegionServerWrapper
public long getRpcGetRequestsCount()
MetricsRegionServerWrapper
getRpcGetRequestsCount
in interface MetricsRegionServerWrapper
public long getRpcScanRequestsCount()
MetricsRegionServerWrapper
getRpcScanRequestsCount
in interface MetricsRegionServerWrapper
public long getRpcFullScanRequestsCount()
MetricsRegionServerWrapper
getRpcFullScanRequestsCount
in interface MetricsRegionServerWrapper
public long getRpcMultiRequestsCount()
MetricsRegionServerWrapper
getRpcMultiRequestsCount
in interface MetricsRegionServerWrapper
public long getRpcMutateRequestsCount()
MetricsRegionServerWrapper
getRpcMutateRequestsCount
in interface MetricsRegionServerWrapper
public long getCheckAndMutateChecksFailed()
MetricsRegionServerWrapper
getCheckAndMutateChecksFailed
in interface MetricsRegionServerWrapper
public long getCheckAndMutateChecksPassed()
MetricsRegionServerWrapper
getCheckAndMutateChecksPassed
in interface MetricsRegionServerWrapper
public long getStoreFileIndexSize()
MetricsRegionServerWrapper
getStoreFileIndexSize
in interface MetricsRegionServerWrapper
public long getTotalStaticIndexSize()
MetricsRegionServerWrapper
getTotalStaticIndexSize
in interface MetricsRegionServerWrapper
public long getTotalStaticBloomSize()
MetricsRegionServerWrapper
getTotalStaticBloomSize
in interface MetricsRegionServerWrapper
public long getBloomFilterRequestsCount()
MetricsRegionServerWrapper
getBloomFilterRequestsCount
in interface MetricsRegionServerWrapper
public long getBloomFilterNegativeResultsCount()
MetricsRegionServerWrapper
getBloomFilterNegativeResultsCount
in interface MetricsRegionServerWrapper
public long getBloomFilterEligibleRequestsCount()
MetricsRegionServerWrapper
getBloomFilterEligibleRequestsCount
in interface MetricsRegionServerWrapper
public long getNumMutationsWithoutWAL()
MetricsRegionServerWrapper
getNumMutationsWithoutWAL
in interface MetricsRegionServerWrapper
public long getDataInMemoryWithoutWAL()
MetricsRegionServerWrapper
getDataInMemoryWithoutWAL
in interface MetricsRegionServerWrapper
public double getPercentFileLocal()
MetricsRegionServerWrapper
getPercentFileLocal
in interface MetricsRegionServerWrapper
public double getPercentFileLocalSecondaryRegions()
MetricsRegionServerWrapper
getPercentFileLocalSecondaryRegions
in interface MetricsRegionServerWrapper
public long getUpdatesBlockedTime()
MetricsRegionServerWrapper
getUpdatesBlockedTime
in interface MetricsRegionServerWrapper
public long getFlushedCellsCount()
MetricsRegionServerWrapper
getFlushedCellsCount
in interface MetricsRegionServerWrapper
public long getCompactedCellsCount()
MetricsRegionServerWrapper
getCompactedCellsCount
in interface MetricsRegionServerWrapper
public long getMajorCompactedCellsCount()
MetricsRegionServerWrapper
getMajorCompactedCellsCount
in interface MetricsRegionServerWrapper
public long getFlushedCellsSize()
MetricsRegionServerWrapper
getFlushedCellsSize
in interface MetricsRegionServerWrapper
public long getCompactedCellsSize()
MetricsRegionServerWrapper
getCompactedCellsSize
in interface MetricsRegionServerWrapper
public long getMajorCompactedCellsSize()
MetricsRegionServerWrapper
getMajorCompactedCellsSize
in interface MetricsRegionServerWrapper
public long getCellsCountCompactedFromMob()
MetricsRegionServerWrapper
getCellsCountCompactedFromMob
in interface MetricsRegionServerWrapper
public long getCellsCountCompactedToMob()
MetricsRegionServerWrapper
getCellsCountCompactedToMob
in interface MetricsRegionServerWrapper
public long getCellsSizeCompactedFromMob()
MetricsRegionServerWrapper
getCellsSizeCompactedFromMob
in interface MetricsRegionServerWrapper
public long getCellsSizeCompactedToMob()
MetricsRegionServerWrapper
getCellsSizeCompactedToMob
in interface MetricsRegionServerWrapper
public long getMobFlushCount()
MetricsRegionServerWrapper
getMobFlushCount
in interface MetricsRegionServerWrapper
public long getMobFlushedCellsCount()
MetricsRegionServerWrapper
getMobFlushedCellsCount
in interface MetricsRegionServerWrapper
public long getMobFlushedCellsSize()
MetricsRegionServerWrapper
getMobFlushedCellsSize
in interface MetricsRegionServerWrapper
public long getMobScanCellsCount()
MetricsRegionServerWrapper
getMobScanCellsCount
in interface MetricsRegionServerWrapper
public long getMobScanCellsSize()
MetricsRegionServerWrapper
getMobScanCellsSize
in interface MetricsRegionServerWrapper
public long getMobFileCacheAccessCount()
MetricsRegionServerWrapper
getMobFileCacheAccessCount
in interface MetricsRegionServerWrapper
public long getMobFileCacheMissCount()
MetricsRegionServerWrapper
getMobFileCacheMissCount
in interface MetricsRegionServerWrapper
public long getMobFileCacheCount()
MetricsRegionServerWrapper
getMobFileCacheCount
in interface MetricsRegionServerWrapper
public long getMobFileCacheEvictedCount()
MetricsRegionServerWrapper
getMobFileCacheEvictedCount
in interface MetricsRegionServerWrapper
public double getMobFileCacheHitPercent()
MetricsRegionServerWrapper
getMobFileCacheHitPercent
in interface MetricsRegionServerWrapper
public int getActiveScanners()
getActiveScanners
in interface MetricsRegionServerWrapper
public long getHedgedReadOps()
MetricsRegionServerWrapper
getHedgedReadOps
in interface MetricsRegionServerWrapper
public long getHedgedReadWins()
MetricsRegionServerWrapper
getHedgedReadWins
in interface MetricsRegionServerWrapper
public long getHedgedReadOpsInCurThread()
MetricsRegionServerWrapper
getHedgedReadOpsInCurThread
in interface MetricsRegionServerWrapper
public long getTotalBytesRead()
MetricsRegionServerWrapper
getTotalBytesRead
in interface MetricsRegionServerWrapper
public long getLocalBytesRead()
MetricsRegionServerWrapper
getLocalBytesRead
in interface MetricsRegionServerWrapper
public long getShortCircuitBytesRead()
MetricsRegionServerWrapper
getShortCircuitBytesRead
in interface MetricsRegionServerWrapper
public long getZeroCopyBytesRead()
MetricsRegionServerWrapper
getZeroCopyBytesRead
in interface MetricsRegionServerWrapper
public long getBlockedRequestsCount()
MetricsRegionServerWrapper
getBlockedRequestsCount
in interface MetricsRegionServerWrapper
public long getAverageRegionSize()
MetricsRegionServerWrapper
getAverageRegionSize
in interface MetricsRegionServerWrapper
public long getDataMissCount()
getDataMissCount
in interface MetricsRegionServerWrapper
public long getLeafIndexMissCount()
getLeafIndexMissCount
in interface MetricsRegionServerWrapper
public long getBloomChunkMissCount()
getBloomChunkMissCount
in interface MetricsRegionServerWrapper
public long getMetaMissCount()
getMetaMissCount
in interface MetricsRegionServerWrapper
public long getRootIndexMissCount()
getRootIndexMissCount
in interface MetricsRegionServerWrapper
public long getIntermediateIndexMissCount()
getIntermediateIndexMissCount
in interface MetricsRegionServerWrapper
public long getFileInfoMissCount()
getFileInfoMissCount
in interface MetricsRegionServerWrapper
public long getGeneralBloomMetaMissCount()
getGeneralBloomMetaMissCount
in interface MetricsRegionServerWrapper
public long getDeleteFamilyBloomMissCount()
getDeleteFamilyBloomMissCount
in interface MetricsRegionServerWrapper
public long getTrailerMissCount()
getTrailerMissCount
in interface MetricsRegionServerWrapper
public long getDataHitCount()
getDataHitCount
in interface MetricsRegionServerWrapper
public long getLeafIndexHitCount()
getLeafIndexHitCount
in interface MetricsRegionServerWrapper
public long getBloomChunkHitCount()
getBloomChunkHitCount
in interface MetricsRegionServerWrapper
public long getMetaHitCount()
getMetaHitCount
in interface MetricsRegionServerWrapper
public long getRootIndexHitCount()
getRootIndexHitCount
in interface MetricsRegionServerWrapper
public long getIntermediateIndexHitCount()
getIntermediateIndexHitCount
in interface MetricsRegionServerWrapper
public long getFileInfoHitCount()
getFileInfoHitCount
in interface MetricsRegionServerWrapper
public long getGeneralBloomMetaHitCount()
getGeneralBloomMetaHitCount
in interface MetricsRegionServerWrapper
public long getDeleteFamilyBloomHitCount()
getDeleteFamilyBloomHitCount
in interface MetricsRegionServerWrapper
public long getTrailerHitCount()
getTrailerHitCount
in interface MetricsRegionServerWrapper
public long getByteBuffAllocatorHeapAllocationBytes()
getByteBuffAllocatorHeapAllocationBytes
in interface MetricsRegionServerWrapper
public long getByteBuffAllocatorPoolAllocationBytes()
getByteBuffAllocatorPoolAllocationBytes
in interface MetricsRegionServerWrapper
public double getByteBuffAllocatorHeapAllocRatio()
getByteBuffAllocatorHeapAllocRatio
in interface MetricsRegionServerWrapper
public long getByteBuffAllocatorTotalBufferCount()
getByteBuffAllocatorTotalBufferCount
in interface MetricsRegionServerWrapper
public long getByteBuffAllocatorUsedBufferCount()
getByteBuffAllocatorUsedBufferCount
in interface MetricsRegionServerWrapper
Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.