Interface MetricsRegionServerWrapper
- All Known Implementing Classes:
MetricsRegionServerWrapperImpl
This is the interface that will expose RegionServer information to hadoop1/hadoop2
implementations of the MetricsRegionServerSource.
-
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.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 Info
-
Method Details
-
getServerName
Get ServerName -
getClusterId
Get the Cluster ID- Returns:
- Cluster ID
-
getZookeeperQuorum
Get the ZooKeeper Quorum Info- Returns:
- ZooKeeper Quorum Info
-
getCoprocessors
Get the co-processors- Returns:
- Co-processors
-
getStartCode
long getStartCode()Get HRegionServer start time- Returns:
- Start time of RegionServer in milliseconds
-
getNumOnlineRegions
long getNumOnlineRegions()The number of online regions -
getNumStores
long getNumStores()Get the number of stores hosted on this region server. -
getNumWALFiles
long getNumWALFiles()Get the number of WAL files of this region server. -
getWALFileSize
long getWALFileSize()Get the size of WAL files of this region server. -
getWALExcludeDNs
Get the excluded datanodes in the cache of this region server. -
getNumWALSlowAppend
long getNumWALSlowAppend()Get the number of WAL files with slow appends for this region server. -
getNumStoreFiles
long getNumStoreFiles()Get the number of store files hosted on this region server. -
getMaxStoreFiles
long getMaxStoreFiles()Get the max number of store files across all regions of this region server. -
getMemStoreSize
long getMemStoreSize()Get the size of the memstore on this region server. -
getOnHeapMemStoreSize
long getOnHeapMemStoreSize()Get the size of the on heap memstore on this region server. -
getOffHeapMemStoreSize
long getOffHeapMemStoreSize()Get the size of the off heap memstore on this region server. -
getStoreFileSize
long getStoreFileSize()Get the total size of the store files this region server is serving from. -
getStoreFileSizeGrowthRate
double getStoreFileSizeGrowthRate()Get the growth rate of the store files this region server is serving from. -
getMaxStoreFileAge
long getMaxStoreFileAge()Returns Max age of store files hosted on this region server -
getMinStoreFileAge
long getMinStoreFileAge()Returns Min age of store files hosted on this region server -
getAvgStoreFileAge
long getAvgStoreFileAge()Returns Average age of store files hosted on this region server -
getNumReferenceFiles
long getNumReferenceFiles()Returns Number of reference files on this region server -
getRequestsPerSecond
double getRequestsPerSecond()Get the number of requests per second. -
getTotalRequestCount
long getTotalRequestCount()Get the total number of requests per second. -
getReadRequestsCount
long getReadRequestsCount()Get the number of read requests to regions hosted on this region server. -
getCpRequestsCount
long getCpRequestsCount()Get the number of coprocessor requests to regions hosted on this region server. -
getReadRequestsRatePerSecond
double getReadRequestsRatePerSecond()Get the rate of read requests per second to regions hosted on this region server. -
getFilteredReadRequestsCount
long getFilteredReadRequestsCount()Get the number of filtered read requests to regions hosted on this region server. -
getWriteRequestsCount
long getWriteRequestsCount()Get the number of write requests to regions hosted on this region server. -
getWriteRequestsRatePerSecond
double getWriteRequestsRatePerSecond()Get the rate of write requests per second to regions hosted on this region server. -
getCheckAndMutateChecksFailed
Get the number of CAS operations that failed. -
getCheckAndMutateChecksPassed
Get the number of CAS operations that passed. -
getStoreFileIndexSize
long getStoreFileIndexSize()Get the Size (in bytes) of indexes in storefiles on disk. -
getTotalStaticIndexSize
long getTotalStaticIndexSize()Get the size (in bytes) of of the static indexes including the roots. -
getTotalStaticBloomSize
long getTotalStaticBloomSize()Get the size (in bytes) of the static bloom filters. -
getBloomFilterRequestsCount
long getBloomFilterRequestsCount()Count of bloom filter requests. -
getBloomFilterNegativeResultsCount
Count of bloom filter requests which return a negative result. -
getBloomFilterEligibleRequestsCount
Count of requests which could have used bloom filters, but they weren't configured or loaded. -
getNumMutationsWithoutWAL
long getNumMutationsWithoutWAL()Number of mutations received with WAL explicitly turned off. -
getDataInMemoryWithoutWAL
long getDataInMemoryWithoutWAL()Ammount of data in the memstore but not in the WAL because mutations explicitly had their WAL turned off. -
getPercentFileLocal
double getPercentFileLocal()Get the percent of HFiles' that are local. -
getPercentFileLocalSecondaryRegions
double getPercentFileLocalSecondaryRegions()Get the percent of HFiles' that are local for secondary region replicas. -
getSplitQueueSize
int getSplitQueueSize()Get the size of the split queue -
getCompactionQueueSize
int getCompactionQueueSize()Get the size of the compaction queue -
getSmallCompactionQueueSize
-
getLargeCompactionQueueSize
-
getFlushQueueSize
int getFlushQueueSize()Get the size of the flush queue. -
getMemStoreLimit
long getMemStoreLimit()Get the limit size of the off heap memstore (if enabled), otherwise get the limit size of the on heap memstore. -
getOnHeapMemStoreLimit
long getOnHeapMemStoreLimit()Get the limit size of the on heap memstore. -
getOffHeapMemStoreLimit
long getOffHeapMemStoreLimit()Get the limit size of the off heap memstore. -
getBlockCacheFreeSize
long getBlockCacheFreeSize()Get the size (in bytes) of the block cache that is free. -
getBlockCacheCount
long getBlockCacheCount()Get the number of items in the block cache. -
getBlockCacheDataBlockCount
long getBlockCacheDataBlockCount()Get the number of DATA blocks in the block cache. -
getBlockCacheSize
long getBlockCacheSize()Get the total size (in bytes) of the block cache. -
getBlockCacheHitCount
long getBlockCacheHitCount()Get the count of hits to the block cache -
getBlockCachePrimaryHitCount
long getBlockCachePrimaryHitCount()Get the count of hits to primary replica in the block cache -
getBlockCacheHitCachingCount
long getBlockCacheHitCachingCount()Get the count of hits to the block cache, for cacheable requests only. -
getBlockCacheMissCount
long getBlockCacheMissCount()Get the count of misses to the block cache. -
getBlockCachePrimaryMissCount
Get the count of misses to primary replica in the block cache. -
getBlockCacheMissCachingCount
Get the count of misses to the block cache, for cacheable requests only. -
getBlockCacheEvictedCount
long getBlockCacheEvictedCount()Get the number of items evicted from the block cache. -
getBlockCachePrimaryEvictedCount
Get the number of items evicted from primary replica in the block cache. -
getBlockCacheHitPercent
double getBlockCacheHitPercent()Get the percent of all requests that hit the block cache. -
getBlockCacheHitCachingPercent
double getBlockCacheHitCachingPercent()Get the percent of requests with the block cache turned on that hit the block cache. -
getBlockCacheFailedInsertions
Number of cache insertions that failed. -
getL1CacheSize
long getL1CacheSize()Cache size (bytes) of L1 cache -
getL1CacheFreeSize
long getL1CacheFreeSize()Free cache size (bytes) of L1 cache -
getL1CacheCount
long getL1CacheCount()Number of blocks in L1 cache -
getL1CacheEvictedCount
long getL1CacheEvictedCount()Number of blocks evicted from L1 cache -
getL1CacheHitCount
long getL1CacheHitCount()Hit count of L1 cache. -
getL1CacheMissCount
long getL1CacheMissCount()Miss count of L1 cache. -
getL1CacheHitRatio
double getL1CacheHitRatio()Hit ratio of L1 cache. -
getL1CacheMissRatio
double getL1CacheMissRatio()Miss ratio of L1 cache. -
getL2CacheSize
long getL2CacheSize()Cache size (bytes) of L2 cache -
getL2CacheFreeSize
long getL2CacheFreeSize()Free cache size (bytes) of L2 cache -
getL2CacheCount
long getL2CacheCount()Number of blocks in L2 cache -
getL2CacheEvictedCount
long getL2CacheEvictedCount()Number of blocks evicted from L2 cache -
getL2CacheHitCount
long getL2CacheHitCount()Hit count of L2 cache. -
getL2CacheMissCount
long getL2CacheMissCount()Miss count of L2 cache. -
getL2CacheHitRatio
double getL2CacheHitRatio()Hit ratio of L2 cache. -
getL2CacheMissRatio
double getL2CacheMissRatio()Miss ratio of L2 cache. -
forceRecompute
void forceRecompute()Force a re-computation of the metrics. -
getUpdatesBlockedTime
long getUpdatesBlockedTime()Get the amount of time that updates were blocked. -
getFlushedCellsCount
long getFlushedCellsCount()Get the number of cells flushed to disk. -
getCompactedCellsCount
long getCompactedCellsCount()Get the number of cells processed during minor compactions. -
getMajorCompactedCellsCount
long getMajorCompactedCellsCount()Get the number of cells processed during major compactions. -
getFlushedCellsSize
long getFlushedCellsSize()Get the total amount of data flushed to disk, in bytes. -
getCompactedCellsSize
long getCompactedCellsSize()Get the total amount of data processed during minor compactions, in bytes. -
getMajorCompactedCellsSize
long getMajorCompactedCellsSize()Get the total amount of data processed during major compactions, in bytes. -
getCellsCountCompactedToMob
long getCellsCountCompactedToMob()Gets the number of cells moved to mob during compaction. -
getCellsCountCompactedFromMob
Gets the number of cells moved from mob during compaction. -
getCellsSizeCompactedToMob
long getCellsSizeCompactedToMob()Gets the total amount of cells moved to mob during compaction, in bytes. -
getCellsSizeCompactedFromMob
long getCellsSizeCompactedFromMob()Gets the total amount of cells moved from mob during compaction, in bytes. -
getMobFlushCount
long getMobFlushCount()Gets the number of the flushes in mob-enabled stores. -
getMobFlushedCellsCount
long getMobFlushedCellsCount()Gets the number of mob cells flushed to disk. -
getMobFlushedCellsSize
long getMobFlushedCellsSize()Gets the total amount of mob cells flushed to disk, in bytes. -
getMobScanCellsCount
long getMobScanCellsCount()Gets the number of scanned mob cells. -
getMobScanCellsSize
long getMobScanCellsSize()Gets the total amount of scanned mob cells, in bytes. -
getMobFileCacheAccessCount
long getMobFileCacheAccessCount()Gets the count of accesses to the mob file cache. -
getMobFileCacheMissCount
long getMobFileCacheMissCount()Gets the count of misses to the mob file cache. -
getMobFileCacheEvictedCount
long getMobFileCacheEvictedCount()Gets the number of items evicted from the mob file cache. -
getMobFileCacheCount
long getMobFileCacheCount()Gets the count of cached mob files. -
getMobFileCacheHitPercent
double getMobFileCacheHitPercent()Gets the hit percent to the mob file cache. -
getHedgedReadOps
long getHedgedReadOps()Returns Count of hedged read operations -
getHedgedReadWins
long getHedgedReadWins()Returns Count of times a hedged read beat out the primary read. -
getHedgedReadOpsInCurThread
long getHedgedReadOpsInCurThread()Returns Count of times a hedged read executes in current thread -
getTotalBytesRead
long getTotalBytesRead()Returns Number of total bytes read from HDFS. -
getLocalBytesRead
long getLocalBytesRead()Returns Number of bytes read from the local HDFS DataNode. -
getShortCircuitBytesRead
long getShortCircuitBytesRead()Returns Number of bytes read locally through HDFS short circuit. -
getZeroCopyBytesRead
long getZeroCopyBytesRead()Returns Number of bytes read locally through HDFS zero copy. -
getBlockedRequestsCount
long getBlockedRequestsCount()Returns Count of requests blocked because the memstore size is larger than blockingMemStoreSize -
getRpcGetRequestsCount
long getRpcGetRequestsCount()Get the number of rpc get requests to this region server. -
getRpcScanRequestsCount
long getRpcScanRequestsCount()Get the number of rpc scan requests to this region server. -
getRpcFullScanRequestsCount
long getRpcFullScanRequestsCount()Get the number of full region rpc scan requests to this region server. -
getRpcMultiRequestsCount
long getRpcMultiRequestsCount()Get the number of rpc multi requests to this region server. -
getRpcMutateRequestsCount
long getRpcMutateRequestsCount()Get the number of rpc mutate requests to this region server. -
getAverageRegionSize
long getAverageRegionSize()Get the average region size to this region server. -
getDataMissCount
long getDataMissCount() -
getLeafIndexMissCount
long getLeafIndexMissCount() -
getBloomChunkMissCount
long getBloomChunkMissCount() -
getMetaMissCount
long getMetaMissCount() -
getRootIndexMissCount
long getRootIndexMissCount() -
getIntermediateIndexMissCount
-
getFileInfoMissCount
long getFileInfoMissCount() -
getGeneralBloomMetaMissCount
long getGeneralBloomMetaMissCount() -
getDeleteFamilyBloomMissCount
-
getTrailerMissCount
long getTrailerMissCount() -
getDataHitCount
long getDataHitCount() -
getLeafIndexHitCount
long getLeafIndexHitCount() -
getBloomChunkHitCount
long getBloomChunkHitCount() -
getMetaHitCount
long getMetaHitCount() -
getRootIndexHitCount
long getRootIndexHitCount() -
getIntermediateIndexHitCount
long getIntermediateIndexHitCount() -
getFileInfoHitCount
long getFileInfoHitCount() -
getGeneralBloomMetaHitCount
long getGeneralBloomMetaHitCount() -
getDeleteFamilyBloomHitCount
long getDeleteFamilyBloomHitCount() -
getTrailerHitCount
long getTrailerHitCount() -
getTotalRowActionRequestCount
-
getByteBuffAllocatorHeapAllocationBytes
-
getByteBuffAllocatorPoolAllocationBytes
-
getByteBuffAllocatorHeapAllocRatio
double getByteBuffAllocatorHeapAllocRatio() -
getByteBuffAllocatorTotalBufferCount
-
getByteBuffAllocatorUsedBufferCount
-
getActiveScanners
int getActiveScanners()
-