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
Nested ClassesModifier and TypeClassDescriptionprivate static final classclassThis 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
FieldsModifier and TypeFieldDescriptionprivate final ByteBuffAllocatorprivate BlockCacheprivate CacheStatsprivate org.apache.hadoop.hdfs.DFSHedgedReadMetricsCan be null if not on hdfs.private final ExcludeDatanodeManagerprivate ScheduledExecutorServiceprivate BlockCacheprivate CacheStatsprivate BlockCacheprivate CacheStatsprivate static final org.slf4j.Loggerprivate final MetricsWALSourceprivate MobFileCacheprivate longprivate longprivate longprivate doubleprivate longprivate longprivate longprivate final HRegionServerprivate Runnableprivate long -
Constructor Summary
Constructors -
Method Summary
Modifier and TypeMethodDescriptionvoidForce a re-computation of the metrics.intlongGet the average region size to this region server.longReturns Average age of store files hosted on this region serverlongGet the number of items in the block cache.longGet the number of DATA blocks in the block cache.longGet the number of items evicted from the block cache.longNumber of cache insertions that failed.longGet the size (in bytes) of the block cache that is free.longGet the count of hits to the block cache, for cacheable requests only.doubleGet the percent of requests with the block cache turned on that hit the block cache.longGet the count of hits to the block cachedoubleGet the percent of all requests that hit the block cache.longGet the count of misses to the block cache, for cacheable requests only.longGet the count of misses to the block cache.longGet the number of items evicted from primary replica in the block cache.longGet the count of hits to primary replica in the block cachelongGet the count of misses to primary replica in the block cache.longGet the total size (in bytes) of the block cache.longReturns Count of requests blocked because the memstore size is larger than blockingMemStoreSizelonglonglongCount of requests which could have used bloom filters, but they weren't configured or loaded.longCount of bloom filter requests which return a negative result.longCount of bloom filter requests.longdoublelonglonglonglongGets the number of cells moved from mob during compaction.longGets the number of cells moved to mob during compaction.longGets the total amount of cells moved from mob during compaction, in bytes.longGets the total amount of cells moved to mob during compaction, in bytes.longGet the number of CAS operations that failed.longGet the number of CAS operations that passed.Get the Cluster IDlongGet the number of cells processed during minor compactions.longGet the total amount of data processed during minor compactions, in bytes.intGet the size of the compaction queueGet the co-processorslongGet the number of coprocessor requests to regions hosted on this region server.longlongAmmount of data in the memstore but not in the WAL because mutations explicitly had their WAL turned off.longlonglonglonglonglongGet the number of filtered read requests to regions hosted on this region server.longGet the number of cells flushed to disk.longGet the total amount of data flushed to disk, in bytes.intGet the size of the flush queue.longlonglongReturns Count of hedged read operationslongReturns Count of times a hedged read executes in current threadlongReturns Count of times a hedged read beat out the primary read.longlonglongNumber of blocks in L1 cachelongNumber of blocks evicted from L1 cachelongFree cache size (bytes) of L1 cachelongHit count of L1 cache.doubleHit ratio of L1 cache.longMiss count of L1 cache.doubleMiss ratio of L1 cache.longCache size (bytes) of L1 cachelongNumber of blocks in L2 cachelongNumber of blocks evicted from L2 cachelongFree cache size (bytes) of L2 cachelongHit count of L2 cache.doubleHit ratio of L2 cache.longMiss count of L2 cache.doubleMiss ratio of L2 cache.longCache size (bytes) of L2 cacheintlonglonglongReturns Number of bytes read from the local HDFS DataNode.longGet the number of cells processed during major compactions.longGet the total amount of data processed during major compactions, in bytes.longReturns Max age of store files hosted on this region serverlongGet the max number of store files across all regions of this region server.longGet the limit size of the off heap memstore (if enabled), otherwise get the limit size of the on heap memstore.longGet the size of the memstore on this region server.longlonglongReturns Min age of store files hosted on this region serverlongGets the count of accesses to the mob file cache.longGets the count of cached mob files.longGets the number of items evicted from the mob file cache.doubleGets the hit percent to the mob file cache.longGets the count of misses to the mob file cache.longGets the number of the flushes in mob-enabled stores.longGets the number of mob cells flushed to disk.longGets the total amount of mob cells flushed to disk, in bytes.longGets the number of scanned mob cells.longGets the total amount of scanned mob cells, in bytes.longNumber of mutations received with WAL explicitly turned off.longThe number of online regionslongReturns Number of reference files on this region serverlongGet the number of store files hosted on this region server.longGet the number of stores hosted on this region server.longGet the number of WAL files of this region server.longGet the number of WAL files with slow appends for this region server.longGet the limit size of the off heap memstore.longGet the size of the off heap memstore on this region server.longGet the limit size of the on heap memstore.longGet the size of the on heap memstore on this region server.doubleGet the percent of HFiles' that are local.doubleGet the percent of HFiles' that are local for primary region replicas.doubleGet the percent of HFiles' that are local for secondary region replicas.(package private) longlongGet the number of read requests to regions hosted on this region server.doubleGet the rate of read requests per second to regions hosted on this region server.doubleGet the number of requests per second.longlonglongGet the number of full region rpc scan requests to this region server.longGet the number of rpc get requests to this region server.longGet the number of rpc multi requests to this region server.longGet the number of rpc mutate requests to this region server.longGet the number of rpc scan requests to this region server.Get ServerNamelongReturns Number of bytes read locally through HDFS short circuit.intintGet the size of the split queuelongGet HRegionServer start timelongGet the Size (in bytes) of indexes in storefiles on disk.longGet the total size of the store files this region server is serving from.doubleGet the growth rate of the store files this region server is serving from.longReturns Number of total bytes read from HDFS.longGet the total number of requests per second.longlongGet the size (in bytes) of the static bloom filters.longGet the size (in bytes) of of the static indexes including the roots.longlonglongGet the amount of time that updates were blocked.Get the excluded datanodes in the cache of this region server.longGet the size of WAL files of this region server.longGet the number of write requests to regions hosted on this region server.doubleGet the rate of write requests per second to regions hosted on this region server.longReturns Number of bytes read locally through HDFS zero copy.Get the ZooKeeper Quorum Infoprivate voidprivate voidInitializes 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:MetricsRegionServerWrapperGet the Cluster ID- Specified by:
getClusterIdin interfaceMetricsRegionServerWrapper- Returns:
- Cluster ID
-
getStartCode
Description copied from interface:MetricsRegionServerWrapperGet HRegionServer start time- Specified by:
getStartCodein interfaceMetricsRegionServerWrapper- Returns:
- Start time of RegionServer in milliseconds
-
getZookeeperQuorum
Description copied from interface:MetricsRegionServerWrapperGet the ZooKeeper Quorum Info- Specified by:
getZookeeperQuorumin interfaceMetricsRegionServerWrapper- Returns:
- ZooKeeper Quorum Info
-
getCoprocessors
Description copied from interface:MetricsRegionServerWrapperGet the co-processors- Specified by:
getCoprocessorsin interfaceMetricsRegionServerWrapper- Returns:
- Co-processors
-
getServerName
Description copied from interface:MetricsRegionServerWrapperGet ServerName- Specified by:
getServerNamein interfaceMetricsRegionServerWrapper
-
getNumOnlineRegions
Description copied from interface:MetricsRegionServerWrapperThe number of online regions- Specified by:
getNumOnlineRegionsin interfaceMetricsRegionServerWrapper
-
getTotalRequestCount
Description copied from interface:MetricsRegionServerWrapperGet the total number of requests per second.- Specified by:
getTotalRequestCountin interfaceMetricsRegionServerWrapper
-
getTotalRowActionRequestCount
- Specified by:
getTotalRowActionRequestCountin interfaceMetricsRegionServerWrapper
-
getSplitQueueSize
Description copied from interface:MetricsRegionServerWrapperGet the size of the split queue- Specified by:
getSplitQueueSizein interfaceMetricsRegionServerWrapper
-
getCompactionQueueSize
Description copied from interface:MetricsRegionServerWrapperGet the size of the compaction queue- Specified by:
getCompactionQueueSizein interfaceMetricsRegionServerWrapper
-
getSmallCompactionQueueSize
- Specified by:
getSmallCompactionQueueSizein interfaceMetricsRegionServerWrapper
-
getLargeCompactionQueueSize
- Specified by:
getLargeCompactionQueueSizein interfaceMetricsRegionServerWrapper
-
getFlushQueueSize
Description copied from interface:MetricsRegionServerWrapperGet the size of the flush queue.- Specified by:
getFlushQueueSizein interfaceMetricsRegionServerWrapper
-
getBlockCacheCount
Description copied from interface:MetricsRegionServerWrapperGet the number of items in the block cache.- Specified by:
getBlockCacheCountin interfaceMetricsRegionServerWrapper
-
getBlockCacheDataBlockCount
Description copied from interface:MetricsRegionServerWrapperGet the number of DATA blocks in the block cache.- Specified by:
getBlockCacheDataBlockCountin interfaceMetricsRegionServerWrapper
-
getMemStoreLimit
Description copied from interface:MetricsRegionServerWrapperGet the limit size of the off heap memstore (if enabled), otherwise get the limit size of the on heap memstore.- Specified by:
getMemStoreLimitin interfaceMetricsRegionServerWrapper
-
getOnHeapMemStoreLimit
Description copied from interface:MetricsRegionServerWrapperGet the limit size of the on heap memstore.- Specified by:
getOnHeapMemStoreLimitin interfaceMetricsRegionServerWrapper
-
getOffHeapMemStoreLimit
Description copied from interface:MetricsRegionServerWrapperGet the limit size of the off heap memstore.- Specified by:
getOffHeapMemStoreLimitin interfaceMetricsRegionServerWrapper
-
getBlockCacheSize
Description copied from interface:MetricsRegionServerWrapperGet the total size (in bytes) of the block cache.- Specified by:
getBlockCacheSizein interfaceMetricsRegionServerWrapper
-
getBlockCacheFreeSize
Description copied from interface:MetricsRegionServerWrapperGet the size (in bytes) of the block cache that is free.- Specified by:
getBlockCacheFreeSizein interfaceMetricsRegionServerWrapper
-
getBlockCacheHitCount
Description copied from interface:MetricsRegionServerWrapperGet the count of hits to the block cache- Specified by:
getBlockCacheHitCountin interfaceMetricsRegionServerWrapper
-
getBlockCachePrimaryHitCount
Description copied from interface:MetricsRegionServerWrapperGet the count of hits to primary replica in the block cache- Specified by:
getBlockCachePrimaryHitCountin interfaceMetricsRegionServerWrapper
-
getBlockCacheHitCachingCount
Description copied from interface:MetricsRegionServerWrapperGet the count of hits to the block cache, for cacheable requests only.- Specified by:
getBlockCacheHitCachingCountin interfaceMetricsRegionServerWrapper
-
getBlockCacheMissCount
Description copied from interface:MetricsRegionServerWrapperGet the count of misses to the block cache.- Specified by:
getBlockCacheMissCountin interfaceMetricsRegionServerWrapper
-
getBlockCachePrimaryMissCount
Description copied from interface:MetricsRegionServerWrapperGet the count of misses to primary replica in the block cache.- Specified by:
getBlockCachePrimaryMissCountin interfaceMetricsRegionServerWrapper
-
getBlockCacheMissCachingCount
Description copied from interface:MetricsRegionServerWrapperGet the count of misses to the block cache, for cacheable requests only.- Specified by:
getBlockCacheMissCachingCountin interfaceMetricsRegionServerWrapper
-
getBlockCacheEvictedCount
Description copied from interface:MetricsRegionServerWrapperGet the number of items evicted from the block cache.- Specified by:
getBlockCacheEvictedCountin interfaceMetricsRegionServerWrapper
-
getBlockCachePrimaryEvictedCount
Description copied from interface:MetricsRegionServerWrapperGet the number of items evicted from primary replica in the block cache.- Specified by:
getBlockCachePrimaryEvictedCountin interfaceMetricsRegionServerWrapper
-
getBlockCacheHitPercent
Description copied from interface:MetricsRegionServerWrapperGet the percent of all requests that hit the block cache.- Specified by:
getBlockCacheHitPercentin interfaceMetricsRegionServerWrapper
-
getBlockCacheHitCachingPercent
Description copied from interface:MetricsRegionServerWrapperGet the percent of requests with the block cache turned on that hit the block cache.- Specified by:
getBlockCacheHitCachingPercentin interfaceMetricsRegionServerWrapper
-
getBlockCacheFailedInsertions
Description copied from interface:MetricsRegionServerWrapperNumber of cache insertions that failed.- Specified by:
getBlockCacheFailedInsertionsin interfaceMetricsRegionServerWrapper
-
getL1CacheSize
Description copied from interface:MetricsRegionServerWrapperCache size (bytes) of L1 cache- Specified by:
getL1CacheSizein interfaceMetricsRegionServerWrapper
-
getL1CacheFreeSize
Description copied from interface:MetricsRegionServerWrapperFree cache size (bytes) of L1 cache- Specified by:
getL1CacheFreeSizein interfaceMetricsRegionServerWrapper
-
getL1CacheCount
Description copied from interface:MetricsRegionServerWrapperNumber of blocks in L1 cache- Specified by:
getL1CacheCountin interfaceMetricsRegionServerWrapper
-
getL1CacheEvictedCount
Description copied from interface:MetricsRegionServerWrapperNumber of blocks evicted from L1 cache- Specified by:
getL1CacheEvictedCountin interfaceMetricsRegionServerWrapper
-
getL2CacheSize
Description copied from interface:MetricsRegionServerWrapperCache size (bytes) of L2 cache- Specified by:
getL2CacheSizein interfaceMetricsRegionServerWrapper
-
getL2CacheFreeSize
Description copied from interface:MetricsRegionServerWrapperFree cache size (bytes) of L2 cache- Specified by:
getL2CacheFreeSizein interfaceMetricsRegionServerWrapper
-
getL2CacheCount
Description copied from interface:MetricsRegionServerWrapperNumber of blocks in L2 cache- Specified by:
getL2CacheCountin interfaceMetricsRegionServerWrapper
-
getL2CacheEvictedCount
Description copied from interface:MetricsRegionServerWrapperNumber of blocks evicted from L2 cache- Specified by:
getL2CacheEvictedCountin interfaceMetricsRegionServerWrapper
-
getL1CacheHitCount
Description copied from interface:MetricsRegionServerWrapperHit count of L1 cache.- Specified by:
getL1CacheHitCountin interfaceMetricsRegionServerWrapper
-
getL1CacheMissCount
Description copied from interface:MetricsRegionServerWrapperMiss count of L1 cache.- Specified by:
getL1CacheMissCountin interfaceMetricsRegionServerWrapper
-
getL1CacheHitRatio
Description copied from interface:MetricsRegionServerWrapperHit ratio of L1 cache.- Specified by:
getL1CacheHitRatioin interfaceMetricsRegionServerWrapper
-
getL1CacheMissRatio
Description copied from interface:MetricsRegionServerWrapperMiss ratio of L1 cache.- Specified by:
getL1CacheMissRatioin interfaceMetricsRegionServerWrapper
-
getL2CacheHitCount
Description copied from interface:MetricsRegionServerWrapperHit count of L2 cache.- Specified by:
getL2CacheHitCountin interfaceMetricsRegionServerWrapper
-
getL2CacheMissCount
Description copied from interface:MetricsRegionServerWrapperMiss count of L2 cache.- Specified by:
getL2CacheMissCountin interfaceMetricsRegionServerWrapper
-
getL2CacheHitRatio
Description copied from interface:MetricsRegionServerWrapperHit ratio of L2 cache.- Specified by:
getL2CacheHitRatioin interfaceMetricsRegionServerWrapper
-
getL2CacheMissRatio
Description copied from interface:MetricsRegionServerWrapperMiss ratio of L2 cache.- Specified by:
getL2CacheMissRatioin interfaceMetricsRegionServerWrapper
-
forceRecompute
Description copied from interface:MetricsRegionServerWrapperForce a re-computation of the metrics.- Specified by:
forceRecomputein interfaceMetricsRegionServerWrapper
-
getNumStores
Description copied from interface:MetricsRegionServerWrapperGet the number of stores hosted on this region server.- Specified by:
getNumStoresin interfaceMetricsRegionServerWrapper
-
getNumWALFiles
Description copied from interface:MetricsRegionServerWrapperGet the number of WAL files of this region server.- Specified by:
getNumWALFilesin interfaceMetricsRegionServerWrapper
-
getWALFileSize
Description copied from interface:MetricsRegionServerWrapperGet the size of WAL files of this region server.- Specified by:
getWALFileSizein interfaceMetricsRegionServerWrapper
-
getWALExcludeDNs
Description copied from interface:MetricsRegionServerWrapperGet the excluded datanodes in the cache of this region server.- Specified by:
getWALExcludeDNsin interfaceMetricsRegionServerWrapper
-
getNumWALSlowAppend
Description copied from interface:MetricsRegionServerWrapperGet the number of WAL files with slow appends for this region server.- Specified by:
getNumWALSlowAppendin interfaceMetricsRegionServerWrapper
-
getNumStoreFiles
Description copied from interface:MetricsRegionServerWrapperGet the number of store files hosted on this region server.- Specified by:
getNumStoreFilesin interfaceMetricsRegionServerWrapper
-
getMaxStoreFiles
Description copied from interface:MetricsRegionServerWrapperGet the max number of store files across all regions of this region server.- Specified by:
getMaxStoreFilesin interfaceMetricsRegionServerWrapper
-
getMaxStoreFileAge
Description copied from interface:MetricsRegionServerWrapperReturns Max age of store files hosted on this region server- Specified by:
getMaxStoreFileAgein interfaceMetricsRegionServerWrapper
-
getMinStoreFileAge
Description copied from interface:MetricsRegionServerWrapperReturns Min age of store files hosted on this region server- Specified by:
getMinStoreFileAgein interfaceMetricsRegionServerWrapper
-
getAvgStoreFileAge
Description copied from interface:MetricsRegionServerWrapperReturns Average age of store files hosted on this region server- Specified by:
getAvgStoreFileAgein interfaceMetricsRegionServerWrapper
-
getNumReferenceFiles
Description copied from interface:MetricsRegionServerWrapperReturns Number of reference files on this region server- Specified by:
getNumReferenceFilesin interfaceMetricsRegionServerWrapper
-
getMemStoreSize
Description copied from interface:MetricsRegionServerWrapperGet the size of the memstore on this region server.- Specified by:
getMemStoreSizein interfaceMetricsRegionServerWrapper
-
getOnHeapMemStoreSize
Description copied from interface:MetricsRegionServerWrapperGet the size of the on heap memstore on this region server.- Specified by:
getOnHeapMemStoreSizein interfaceMetricsRegionServerWrapper
-
getOffHeapMemStoreSize
Description copied from interface:MetricsRegionServerWrapperGet the size of the off heap memstore on this region server.- Specified by:
getOffHeapMemStoreSizein interfaceMetricsRegionServerWrapper
-
getStoreFileSize
Description copied from interface:MetricsRegionServerWrapperGet the total size of the store files this region server is serving from.- Specified by:
getStoreFileSizein interfaceMetricsRegionServerWrapper
-
getStoreFileSizeGrowthRate
Description copied from interface:MetricsRegionServerWrapperGet the growth rate of the store files this region server is serving from.- Specified by:
getStoreFileSizeGrowthRatein interfaceMetricsRegionServerWrapper
-
getRequestsPerSecond
Description copied from interface:MetricsRegionServerWrapperGet the number of requests per second.- Specified by:
getRequestsPerSecondin interfaceMetricsRegionServerWrapper
-
getReadRequestsCount
Description copied from interface:MetricsRegionServerWrapperGet the number of read requests to regions hosted on this region server.- Specified by:
getReadRequestsCountin interfaceMetricsRegionServerWrapper
-
getCpRequestsCount
Description copied from interface:MetricsRegionServerWrapperGet the number of coprocessor requests to regions hosted on this region server.- Specified by:
getCpRequestsCountin interfaceMetricsRegionServerWrapper
-
getReadRequestsRatePerSecond
Description copied from interface:MetricsRegionServerWrapperGet the rate of read requests per second to regions hosted on this region server.- Specified by:
getReadRequestsRatePerSecondin interfaceMetricsRegionServerWrapper
-
getFilteredReadRequestsCount
Description copied from interface:MetricsRegionServerWrapperGet the number of filtered read requests to regions hosted on this region server.- Specified by:
getFilteredReadRequestsCountin interfaceMetricsRegionServerWrapper
-
getWriteRequestsCount
Description copied from interface:MetricsRegionServerWrapperGet the number of write requests to regions hosted on this region server.- Specified by:
getWriteRequestsCountin interfaceMetricsRegionServerWrapper
-
getWriteRequestsRatePerSecond
Description copied from interface:MetricsRegionServerWrapperGet the rate of write requests per second to regions hosted on this region server.- Specified by:
getWriteRequestsRatePerSecondin interfaceMetricsRegionServerWrapper
-
getRpcGetRequestsCount
Description copied from interface:MetricsRegionServerWrapperGet the number of rpc get requests to this region server.- Specified by:
getRpcGetRequestsCountin interfaceMetricsRegionServerWrapper
-
getRpcScanRequestsCount
Description copied from interface:MetricsRegionServerWrapperGet the number of rpc scan requests to this region server.- Specified by:
getRpcScanRequestsCountin interfaceMetricsRegionServerWrapper
-
getRpcFullScanRequestsCount
Description copied from interface:MetricsRegionServerWrapperGet the number of full region rpc scan requests to this region server.- Specified by:
getRpcFullScanRequestsCountin interfaceMetricsRegionServerWrapper
-
getRpcMultiRequestsCount
Description copied from interface:MetricsRegionServerWrapperGet the number of rpc multi requests to this region server.- Specified by:
getRpcMultiRequestsCountin interfaceMetricsRegionServerWrapper
-
getRpcMutateRequestsCount
Description copied from interface:MetricsRegionServerWrapperGet the number of rpc mutate requests to this region server.- Specified by:
getRpcMutateRequestsCountin interfaceMetricsRegionServerWrapper
-
getCheckAndMutateChecksFailed
Description copied from interface:MetricsRegionServerWrapperGet the number of CAS operations that failed.- Specified by:
getCheckAndMutateChecksFailedin interfaceMetricsRegionServerWrapper
-
getCheckAndMutateChecksPassed
Description copied from interface:MetricsRegionServerWrapperGet the number of CAS operations that passed.- Specified by:
getCheckAndMutateChecksPassedin interfaceMetricsRegionServerWrapper
-
getStoreFileIndexSize
Description copied from interface:MetricsRegionServerWrapperGet the Size (in bytes) of indexes in storefiles on disk.- Specified by:
getStoreFileIndexSizein interfaceMetricsRegionServerWrapper
-
getTotalStaticIndexSize
Description copied from interface:MetricsRegionServerWrapperGet the size (in bytes) of of the static indexes including the roots.- Specified by:
getTotalStaticIndexSizein interfaceMetricsRegionServerWrapper
-
getTotalStaticBloomSize
Description copied from interface:MetricsRegionServerWrapperGet the size (in bytes) of the static bloom filters.- Specified by:
getTotalStaticBloomSizein interfaceMetricsRegionServerWrapper
-
getBloomFilterRequestsCount
Description copied from interface:MetricsRegionServerWrapperCount of bloom filter requests.- Specified by:
getBloomFilterRequestsCountin interfaceMetricsRegionServerWrapper
-
getBloomFilterNegativeResultsCount
Description copied from interface:MetricsRegionServerWrapperCount of bloom filter requests which return a negative result.- Specified by:
getBloomFilterNegativeResultsCountin interfaceMetricsRegionServerWrapper
-
getBloomFilterEligibleRequestsCount
Description copied from interface:MetricsRegionServerWrapperCount of requests which could have used bloom filters, but they weren't configured or loaded.- Specified by:
getBloomFilterEligibleRequestsCountin interfaceMetricsRegionServerWrapper
-
getNumMutationsWithoutWAL
Description copied from interface:MetricsRegionServerWrapperNumber of mutations received with WAL explicitly turned off.- Specified by:
getNumMutationsWithoutWALin interfaceMetricsRegionServerWrapper
-
getDataInMemoryWithoutWAL
Description copied from interface:MetricsRegionServerWrapperAmmount of data in the memstore but not in the WAL because mutations explicitly had their WAL turned off.- Specified by:
getDataInMemoryWithoutWALin interfaceMetricsRegionServerWrapper
-
getPercentFileLocal
Description copied from interface:MetricsRegionServerWrapperGet the percent of HFiles' that are local.- Specified by:
getPercentFileLocalin interfaceMetricsRegionServerWrapper
-
getPercentFileLocalPrimaryRegions
Description copied from interface:MetricsRegionServerWrapperGet the percent of HFiles' that are local for primary region replicas.- Specified by:
getPercentFileLocalPrimaryRegionsin interfaceMetricsRegionServerWrapper
-
getPercentFileLocalSecondaryRegions
Description copied from interface:MetricsRegionServerWrapperGet the percent of HFiles' that are local for secondary region replicas.- Specified by:
getPercentFileLocalSecondaryRegionsin interfaceMetricsRegionServerWrapper
-
getUpdatesBlockedTime
Description copied from interface:MetricsRegionServerWrapperGet the amount of time that updates were blocked.- Specified by:
getUpdatesBlockedTimein interfaceMetricsRegionServerWrapper
-
getFlushedCellsCount
Description copied from interface:MetricsRegionServerWrapperGet the number of cells flushed to disk.- Specified by:
getFlushedCellsCountin interfaceMetricsRegionServerWrapper
-
getCompactedCellsCount
Description copied from interface:MetricsRegionServerWrapperGet the number of cells processed during minor compactions.- Specified by:
getCompactedCellsCountin interfaceMetricsRegionServerWrapper
-
getMajorCompactedCellsCount
Description copied from interface:MetricsRegionServerWrapperGet the number of cells processed during major compactions.- Specified by:
getMajorCompactedCellsCountin interfaceMetricsRegionServerWrapper
-
getFlushedCellsSize
Description copied from interface:MetricsRegionServerWrapperGet the total amount of data flushed to disk, in bytes.- Specified by:
getFlushedCellsSizein interfaceMetricsRegionServerWrapper
-
getCompactedCellsSize
Description copied from interface:MetricsRegionServerWrapperGet the total amount of data processed during minor compactions, in bytes.- Specified by:
getCompactedCellsSizein interfaceMetricsRegionServerWrapper
-
getMajorCompactedCellsSize
Description copied from interface:MetricsRegionServerWrapperGet the total amount of data processed during major compactions, in bytes.- Specified by:
getMajorCompactedCellsSizein interfaceMetricsRegionServerWrapper
-
getCellsCountCompactedFromMob
Description copied from interface:MetricsRegionServerWrapperGets the number of cells moved from mob during compaction.- Specified by:
getCellsCountCompactedFromMobin interfaceMetricsRegionServerWrapper
-
getCellsCountCompactedToMob
Description copied from interface:MetricsRegionServerWrapperGets the number of cells moved to mob during compaction.- Specified by:
getCellsCountCompactedToMobin interfaceMetricsRegionServerWrapper
-
getCellsSizeCompactedFromMob
Description copied from interface:MetricsRegionServerWrapperGets the total amount of cells moved from mob during compaction, in bytes.- Specified by:
getCellsSizeCompactedFromMobin interfaceMetricsRegionServerWrapper
-
getCellsSizeCompactedToMob
Description copied from interface:MetricsRegionServerWrapperGets the total amount of cells moved to mob during compaction, in bytes.- Specified by:
getCellsSizeCompactedToMobin interfaceMetricsRegionServerWrapper
-
getMobFlushCount
Description copied from interface:MetricsRegionServerWrapperGets the number of the flushes in mob-enabled stores.- Specified by:
getMobFlushCountin interfaceMetricsRegionServerWrapper
-
getMobFlushedCellsCount
Description copied from interface:MetricsRegionServerWrapperGets the number of mob cells flushed to disk.- Specified by:
getMobFlushedCellsCountin interfaceMetricsRegionServerWrapper
-
getMobFlushedCellsSize
Description copied from interface:MetricsRegionServerWrapperGets the total amount of mob cells flushed to disk, in bytes.- Specified by:
getMobFlushedCellsSizein interfaceMetricsRegionServerWrapper
-
getMobScanCellsCount
Description copied from interface:MetricsRegionServerWrapperGets the number of scanned mob cells.- Specified by:
getMobScanCellsCountin interfaceMetricsRegionServerWrapper
-
getMobScanCellsSize
Description copied from interface:MetricsRegionServerWrapperGets the total amount of scanned mob cells, in bytes.- Specified by:
getMobScanCellsSizein interfaceMetricsRegionServerWrapper
-
getMobFileCacheAccessCount
Description copied from interface:MetricsRegionServerWrapperGets the count of accesses to the mob file cache.- Specified by:
getMobFileCacheAccessCountin interfaceMetricsRegionServerWrapper
-
getMobFileCacheMissCount
Description copied from interface:MetricsRegionServerWrapperGets the count of misses to the mob file cache.- Specified by:
getMobFileCacheMissCountin interfaceMetricsRegionServerWrapper
-
getMobFileCacheCount
Description copied from interface:MetricsRegionServerWrapperGets the count of cached mob files.- Specified by:
getMobFileCacheCountin interfaceMetricsRegionServerWrapper
-
getMobFileCacheEvictedCount
Description copied from interface:MetricsRegionServerWrapperGets the number of items evicted from the mob file cache.- Specified by:
getMobFileCacheEvictedCountin interfaceMetricsRegionServerWrapper
-
getMobFileCacheHitPercent
Description copied from interface:MetricsRegionServerWrapperGets the hit percent to the mob file cache.- Specified by:
getMobFileCacheHitPercentin interfaceMetricsRegionServerWrapper
-
getActiveScanners
- Specified by:
getActiveScannersin interfaceMetricsRegionServerWrapper
-
getHedgedReadOps
Description copied from interface:MetricsRegionServerWrapperReturns Count of hedged read operations- Specified by:
getHedgedReadOpsin interfaceMetricsRegionServerWrapper
-
getHedgedReadWins
Description copied from interface:MetricsRegionServerWrapperReturns Count of times a hedged read beat out the primary read.- Specified by:
getHedgedReadWinsin interfaceMetricsRegionServerWrapper
-
getHedgedReadOpsInCurThread
Description copied from interface:MetricsRegionServerWrapperReturns Count of times a hedged read executes in current thread- Specified by:
getHedgedReadOpsInCurThreadin interfaceMetricsRegionServerWrapper
-
getTotalBytesRead
Description copied from interface:MetricsRegionServerWrapperReturns Number of total bytes read from HDFS.- Specified by:
getTotalBytesReadin interfaceMetricsRegionServerWrapper
-
getLocalBytesRead
Description copied from interface:MetricsRegionServerWrapperReturns Number of bytes read from the local HDFS DataNode.- Specified by:
getLocalBytesReadin interfaceMetricsRegionServerWrapper
-
getShortCircuitBytesRead
Description copied from interface:MetricsRegionServerWrapperReturns Number of bytes read locally through HDFS short circuit.- Specified by:
getShortCircuitBytesReadin interfaceMetricsRegionServerWrapper
-
getZeroCopyBytesRead
Description copied from interface:MetricsRegionServerWrapperReturns Number of bytes read locally through HDFS zero copy.- Specified by:
getZeroCopyBytesReadin interfaceMetricsRegionServerWrapper
-
getBlockedRequestsCount
Description copied from interface:MetricsRegionServerWrapperReturns Count of requests blocked because the memstore size is larger than blockingMemStoreSize- Specified by:
getBlockedRequestsCountin interfaceMetricsRegionServerWrapper
-
getAverageRegionSize
Description copied from interface:MetricsRegionServerWrapperGet the average region size to this region server.- Specified by:
getAverageRegionSizein interfaceMetricsRegionServerWrapper
-
getDataMissCount
- Specified by:
getDataMissCountin interfaceMetricsRegionServerWrapper
-
getLeafIndexMissCount
- Specified by:
getLeafIndexMissCountin interfaceMetricsRegionServerWrapper
-
getBloomChunkMissCount
- Specified by:
getBloomChunkMissCountin interfaceMetricsRegionServerWrapper
-
getMetaMissCount
- Specified by:
getMetaMissCountin interfaceMetricsRegionServerWrapper
-
getRootIndexMissCount
- Specified by:
getRootIndexMissCountin interfaceMetricsRegionServerWrapper
-
getIntermediateIndexMissCount
- Specified by:
getIntermediateIndexMissCountin interfaceMetricsRegionServerWrapper
-
getFileInfoMissCount
- Specified by:
getFileInfoMissCountin interfaceMetricsRegionServerWrapper
-
getGeneralBloomMetaMissCount
- Specified by:
getGeneralBloomMetaMissCountin interfaceMetricsRegionServerWrapper
-
getDeleteFamilyBloomMissCount
- Specified by:
getDeleteFamilyBloomMissCountin interfaceMetricsRegionServerWrapper
-
getTrailerMissCount
- Specified by:
getTrailerMissCountin interfaceMetricsRegionServerWrapper
-
getDataHitCount
- Specified by:
getDataHitCountin interfaceMetricsRegionServerWrapper
-
getLeafIndexHitCount
- Specified by:
getLeafIndexHitCountin interfaceMetricsRegionServerWrapper
-
getBloomChunkHitCount
- Specified by:
getBloomChunkHitCountin interfaceMetricsRegionServerWrapper
-
getMetaHitCount
- Specified by:
getMetaHitCountin interfaceMetricsRegionServerWrapper
-
getRootIndexHitCount
- Specified by:
getRootIndexHitCountin interfaceMetricsRegionServerWrapper
-
getIntermediateIndexHitCount
- Specified by:
getIntermediateIndexHitCountin interfaceMetricsRegionServerWrapper
-
getFileInfoHitCount
- Specified by:
getFileInfoHitCountin interfaceMetricsRegionServerWrapper
-
getGeneralBloomMetaHitCount
- Specified by:
getGeneralBloomMetaHitCountin interfaceMetricsRegionServerWrapper
-
getDeleteFamilyBloomHitCount
- Specified by:
getDeleteFamilyBloomHitCountin interfaceMetricsRegionServerWrapper
-
getTrailerHitCount
- Specified by:
getTrailerHitCountin interfaceMetricsRegionServerWrapper
-
getByteBuffAllocatorHeapAllocationBytes
- Specified by:
getByteBuffAllocatorHeapAllocationBytesin interfaceMetricsRegionServerWrapper
-
getByteBuffAllocatorPoolAllocationBytes
- Specified by:
getByteBuffAllocatorPoolAllocationBytesin interfaceMetricsRegionServerWrapper
-
getByteBuffAllocatorHeapAllocRatio
- Specified by:
getByteBuffAllocatorHeapAllocRatioin interfaceMetricsRegionServerWrapper
-
getByteBuffAllocatorTotalBufferCount
- Specified by:
getByteBuffAllocatorTotalBufferCountin interfaceMetricsRegionServerWrapper
-
getByteBuffAllocatorUsedBufferCount
- Specified by:
getByteBuffAllocatorUsedBufferCountin interfaceMetricsRegionServerWrapper
-
getPeriod
long getPeriod()
-