@InterfaceAudience.Private public interface MetricsRegionServerWrapper
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
|
String getServerName()
String getClusterId()
String getZookeeperQuorum()
String getCoprocessors()
long getStartCode()
long getNumOnlineRegions()
long getNumStores()
long getNumWALFiles()
long getWALFileSize()
List<String> getWALExcludeDNs()
long getNumWALSlowAppend()
long getNumStoreFiles()
long getMaxStoreFiles()
long getMemStoreSize()
long getOnHeapMemStoreSize()
long getOffHeapMemStoreSize()
long getStoreFileSize()
long getMaxStoreFileAge()
long getMinStoreFileAge()
long getAvgStoreFileAge()
long getNumReferenceFiles()
double getRequestsPerSecond()
long getTotalRequestCount()
long getReadRequestsCount()
double getReadRequestsRatePerSecond()
long getFilteredReadRequestsCount()
long getWriteRequestsCount()
double getWriteRequestsRatePerSecond()
long getCheckAndMutateChecksFailed()
long getCheckAndMutateChecksPassed()
long getStoreFileIndexSize()
long getTotalStaticIndexSize()
long getTotalStaticBloomSize()
long getBloomFilterRequestsCount()
long getBloomFilterNegativeResultsCount()
long getBloomFilterEligibleRequestsCount()
long getNumMutationsWithoutWAL()
long getDataInMemoryWithoutWAL()
double getPercentFileLocal()
double getPercentFileLocalSecondaryRegions()
int getSplitQueueSize()
int getCompactionQueueSize()
int getSmallCompactionQueueSize()
int getLargeCompactionQueueSize()
int getFlushQueueSize()
long getMemStoreLimit()
long getOnHeapMemStoreLimit()
long getOffHeapMemStoreLimit()
long getBlockCacheFreeSize()
long getBlockCacheCount()
long getBlockCacheDataBlockCount()
long getBlockCacheSize()
long getBlockCacheHitCount()
long getBlockCachePrimaryHitCount()
long getBlockCacheMissCount()
long getBlockCachePrimaryMissCount()
long getBlockCacheEvictedCount()
long getBlockCachePrimaryEvictedCount()
double getBlockCacheHitPercent()
double getBlockCacheHitCachingPercent()
long getBlockCacheFailedInsertions()
long getL1CacheSize()
long getL1CacheFreeSize()
long getL1CacheCount()
long getL1CacheEvictedCount()
long getL1CacheHitCount()
long getL1CacheMissCount()
double getL1CacheHitRatio()
double getL1CacheMissRatio()
long getL2CacheSize()
long getL2CacheFreeSize()
long getL2CacheCount()
long getL2CacheEvictedCount()
long getL2CacheHitCount()
long getL2CacheMissCount()
double getL2CacheHitRatio()
double getL2CacheMissRatio()
void forceRecompute()
long getUpdatesBlockedTime()
long getFlushedCellsCount()
long getCompactedCellsCount()
long getMajorCompactedCellsCount()
long getFlushedCellsSize()
long getCompactedCellsSize()
long getMajorCompactedCellsSize()
long getCellsCountCompactedToMob()
long getCellsCountCompactedFromMob()
long getCellsSizeCompactedToMob()
long getCellsSizeCompactedFromMob()
long getMobFlushCount()
long getMobFlushedCellsCount()
long getMobFlushedCellsSize()
long getMobScanCellsCount()
long getMobScanCellsSize()
long getMobFileCacheAccessCount()
long getMobFileCacheMissCount()
long getMobFileCacheEvictedCount()
long getMobFileCacheCount()
double getMobFileCacheHitPercent()
long getHedgedReadOps()
long getHedgedReadWins()
long getHedgedReadOpsInCurThread()
long getTotalBytesRead()
long getLocalBytesRead()
long getShortCircuitBytesRead()
long getZeroCopyBytesRead()
long getBlockedRequestsCount()
long getRpcGetRequestsCount()
long getRpcScanRequestsCount()
long getRpcFullScanRequestsCount()
long getRpcMultiRequestsCount()
long getRpcMutateRequestsCount()
long getAverageRegionSize()
long getDataMissCount()
long getLeafIndexMissCount()
long getBloomChunkMissCount()
long getMetaMissCount()
long getRootIndexMissCount()
long getIntermediateIndexMissCount()
long getFileInfoMissCount()
long getGeneralBloomMetaMissCount()
long getDeleteFamilyBloomMissCount()
long getTrailerMissCount()
long getDataHitCount()
long getLeafIndexHitCount()
long getBloomChunkHitCount()
long getMetaHitCount()
long getRootIndexHitCount()
long getIntermediateIndexHitCount()
long getFileInfoHitCount()
long getGeneralBloomMetaHitCount()
long getDeleteFamilyBloomHitCount()
long getTrailerHitCount()
long getTotalRowActionRequestCount()
long getByteBuffAllocatorHeapAllocationBytes()
long getByteBuffAllocatorPoolAllocationBytes()
double getByteBuffAllocatorHeapAllocRatio()
long getByteBuffAllocatorTotalBufferCount()
long getByteBuffAllocatorUsedBufferCount()
int getActiveScanners()
Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.