Package org.apache.hadoop.hbase
Class RegionMetricsBuilder.RegionMetricsImpl
java.lang.Object
org.apache.hadoop.hbase.RegionMetricsBuilder.RegionMetricsImpl
- All Implemented Interfaces:
RegionMetrics
- Enclosing class:
- RegionMetricsBuilder
-
Field Summary
FieldsModifier and TypeFieldDescriptionprivate final longprivate final longprivate final longprivate final Sizeprivate final longprivate final longprivate final CompactionStateprivate final longprivate final longprivate final floatprivate final floatprivate final floatprivate final longprivate final Sizeprivate final longprivate final intprivate final Sizeprivate final byte[]private final longprivate final Sizeprivate final Sizeprivate final intprivate final intprivate final Sizeprivate final intprivate final Sizeprivate final Sizeprivate final long -
Constructor Summary
ConstructorsConstructorDescriptionRegionMetricsImpl(byte[] name, int storeCount, int storeFileCount, int storeRefCount, int maxCompactedStoreFileRefCount, long compactingCellCount, long compactedCellCount, Size storeFileSize, Size memStoreSize, Size indexSize, Size rootLevelIndexSize, Size uncompressedDataIndexSize, Size bloomFilterSize, Size uncompressedStoreFileSize, long writeRequestCount, long readRequestCount, long cpRequestCount, long filteredReadRequestCount, long completedSequenceId, Map<byte[], Long> storeSequenceIds, float dataLocality, long lastMajorCompactionTimestamp, float dataLocalityForSsd, long blocksLocalWeight, long blocksLocalWithSsdWeight, long blocksTotalWeight, CompactionState compactionState, Size regionSizeMB, float currentRegionCachedRatio) -
Method Summary
Modifier and TypeMethodDescriptionlongReturns the data at local weight of this region in the regionserverlongDifferent from blocksLocalWeight,this metric's numerator only include the data stored on ssdlongReturns the block total weight of this regionReturns The total size of all Bloom filter blocks, not just loaded into the block cachelongReturns the number of already compacted kvs in current compactionlongReturns the total number of cells in current compactionReturns the compaction state of this regionlongThis does not really belong inside RegionLoad but its being done in the name of expediency.longReturns the number of coprocessor service requests made to regionfloatReturns current prefetch ratio of this region on this serverfloatReturns the data locality of region in the regionserver.floatDifferent from dataLocality,this metric's numerator only include the data stored on ssdlongReturns the number of filtered read requests made to regionlongReturns the timestamp of the oldest hfile for any store of this region.intReturns the max reference count for any store file among all compacted stores files of this regionReturns the memstore sizelongReturns the number of read requests made to regionbyte[]Returns the region nameReturns the total size of the hfiles in the regionintReturns the number of storesintReturns the number of storefilesTODO: why we pass the same value to different counters? Currently, the value from getStoreFileIndexSize() is same with getStoreFileRootLevelIndexSize() see HRegionServer#createRegionLoad.Returns The current total size of root-level indexes for the regionReturns the total size of the storefilesReturns The total size of all index blocks, not just the root levelintReturns the reference count for the stores of this regionReturns completed sequence id per store.Returns the uncompressed size of the storefileslongReturns the number of write requests made to regiontoString()Methods inherited from class java.lang.Object
clone, equals, finalize, getClass, hashCode, notify, notifyAll, wait, wait, waitMethods inherited from interface org.apache.hadoop.hbase.RegionMetrics
getNameAsString, getRequestCount
-
Field Details
-
name
-
storeCount
-
storeFileCount
-
storeRefCount
-
maxCompactedStoreFileRefCount
-
compactingCellCount
-
compactedCellCount
-
storeFileSize
-
memStoreSize
-
indexSize
-
rootLevelIndexSize
-
uncompressedDataIndexSize
-
bloomFilterSize
-
uncompressedStoreFileSize
-
writeRequestCount
-
readRequestCount
-
cpRequestCount
-
filteredReadRequestCount
-
completedSequenceId
-
storeSequenceIds
-
dataLocality
-
lastMajorCompactionTimestamp
-
dataLocalityForSsd
-
blocksLocalWeight
-
blocksLocalWithSsdWeight
-
blocksTotalWeight
-
compactionState
-
regionSizeMB
-
currentRegionCachedRatio
-
-
Constructor Details
-
RegionMetricsImpl
RegionMetricsImpl(byte[] name, int storeCount, int storeFileCount, int storeRefCount, int maxCompactedStoreFileRefCount, long compactingCellCount, long compactedCellCount, Size storeFileSize, Size memStoreSize, Size indexSize, Size rootLevelIndexSize, Size uncompressedDataIndexSize, Size bloomFilterSize, Size uncompressedStoreFileSize, long writeRequestCount, long readRequestCount, long cpRequestCount, long filteredReadRequestCount, long completedSequenceId, Map<byte[], Long> storeSequenceIds, float dataLocality, long lastMajorCompactionTimestamp, float dataLocalityForSsd, long blocksLocalWeight, long blocksLocalWithSsdWeight, long blocksTotalWeight, CompactionState compactionState, Size regionSizeMB, float currentRegionCachedRatio)
-
-
Method Details
-
getRegionName
Description copied from interface:RegionMetricsReturns the region name- Specified by:
getRegionNamein interfaceRegionMetrics
-
getStoreCount
Description copied from interface:RegionMetricsReturns the number of stores- Specified by:
getStoreCountin interfaceRegionMetrics
-
getStoreFileCount
Description copied from interface:RegionMetricsReturns the number of storefiles- Specified by:
getStoreFileCountin interfaceRegionMetrics
-
getStoreRefCount
Description copied from interface:RegionMetricsReturns the reference count for the stores of this region- Specified by:
getStoreRefCountin interfaceRegionMetrics
-
getMaxCompactedStoreFileRefCount
Description copied from interface:RegionMetricsReturns the max reference count for any store file among all compacted stores files of this region- Specified by:
getMaxCompactedStoreFileRefCountin interfaceRegionMetrics
-
getStoreFileSize
Description copied from interface:RegionMetricsReturns the total size of the storefiles- Specified by:
getStoreFileSizein interfaceRegionMetrics
-
getMemStoreSize
Description copied from interface:RegionMetricsReturns the memstore size- Specified by:
getMemStoreSizein interfaceRegionMetrics
-
getReadRequestCount
Description copied from interface:RegionMetricsReturns the number of read requests made to region- Specified by:
getReadRequestCountin interfaceRegionMetrics
-
getCpRequestCount
Description copied from interface:RegionMetricsReturns the number of coprocessor service requests made to region- Specified by:
getCpRequestCountin interfaceRegionMetrics
-
getFilteredReadRequestCount
Description copied from interface:RegionMetricsReturns the number of filtered read requests made to region- Specified by:
getFilteredReadRequestCountin interfaceRegionMetrics
-
getWriteRequestCount
Description copied from interface:RegionMetricsReturns the number of write requests made to region- Specified by:
getWriteRequestCountin interfaceRegionMetrics
-
getStoreFileIndexSize
Description copied from interface:RegionMetricsTODO: why we pass the same value to different counters? Currently, the value from getStoreFileIndexSize() is same with getStoreFileRootLevelIndexSize() see HRegionServer#createRegionLoad.- Specified by:
getStoreFileIndexSizein interfaceRegionMetrics- Returns:
- The current total size of root-level indexes for the region
-
getStoreFileRootLevelIndexSize
Description copied from interface:RegionMetricsReturns The current total size of root-level indexes for the region- Specified by:
getStoreFileRootLevelIndexSizein interfaceRegionMetrics
-
getStoreFileUncompressedDataIndexSize
Description copied from interface:RegionMetricsReturns The total size of all index blocks, not just the root level- Specified by:
getStoreFileUncompressedDataIndexSizein interfaceRegionMetrics
-
getBloomFilterSize
Description copied from interface:RegionMetricsReturns The total size of all Bloom filter blocks, not just loaded into the block cache- Specified by:
getBloomFilterSizein interfaceRegionMetrics
-
getCompactingCellCount
Description copied from interface:RegionMetricsReturns the total number of cells in current compaction- Specified by:
getCompactingCellCountin interfaceRegionMetrics
-
getCompactedCellCount
Description copied from interface:RegionMetricsReturns the number of already compacted kvs in current compaction- Specified by:
getCompactedCellCountin interfaceRegionMetrics
-
getCompletedSequenceId
Description copied from interface:RegionMetricsThis does not really belong inside RegionLoad but its being done in the name of expediency.- Specified by:
getCompletedSequenceIdin interfaceRegionMetrics- Returns:
- the completed sequence Id for the region
-
getStoreSequenceId
Description copied from interface:RegionMetricsReturns completed sequence id per store.- Specified by:
getStoreSequenceIdin interfaceRegionMetrics
-
getUncompressedStoreFileSize
Description copied from interface:RegionMetricsReturns the uncompressed size of the storefiles- Specified by:
getUncompressedStoreFileSizein interfaceRegionMetrics
-
getDataLocality
Description copied from interface:RegionMetricsReturns the data locality of region in the regionserver.- Specified by:
getDataLocalityin interfaceRegionMetrics
-
getLastMajorCompactionTimestamp
Description copied from interface:RegionMetricsReturns the timestamp of the oldest hfile for any store of this region.- Specified by:
getLastMajorCompactionTimestampin interfaceRegionMetrics
-
getDataLocalityForSsd
Description copied from interface:RegionMetricsDifferent from dataLocality,this metric's numerator only include the data stored on ssd- Specified by:
getDataLocalityForSsdin interfaceRegionMetrics- Returns:
- the data locality for ssd of region in the regionserver
-
getBlocksLocalWeight
Description copied from interface:RegionMetricsReturns the data at local weight of this region in the regionserver- Specified by:
getBlocksLocalWeightin interfaceRegionMetrics
-
getBlocksLocalWithSsdWeight
Description copied from interface:RegionMetricsDifferent from blocksLocalWeight,this metric's numerator only include the data stored on ssd- Specified by:
getBlocksLocalWithSsdWeightin interfaceRegionMetrics- Returns:
- the data at local with ssd weight of this region in the regionserver
-
getBlocksTotalWeight
Description copied from interface:RegionMetricsReturns the block total weight of this region- Specified by:
getBlocksTotalWeightin interfaceRegionMetrics
-
getCompactionState
Description copied from interface:RegionMetricsReturns the compaction state of this region- Specified by:
getCompactionStatein interfaceRegionMetrics
-
getRegionSizeMB
Description copied from interface:RegionMetricsReturns the total size of the hfiles in the region- Specified by:
getRegionSizeMBin interfaceRegionMetrics
-
getCurrentRegionCachedRatio
Description copied from interface:RegionMetricsReturns current prefetch ratio of this region on this server- Specified by:
getCurrentRegionCachedRatioin interfaceRegionMetrics
-
toString
-