private static class RegionMetricsBuilder.RegionMetricsImpl extends Object implements RegionMetrics
Modifier and Type | Field and Description |
---|---|
private long |
blocksLocalWeight |
private long |
blocksLocalWithSsdWeight |
private long |
blocksTotalWeight |
private Size |
bloomFilterSize |
private long |
compactedCellCount |
private long |
compactingCellCount |
private CompactionState |
compactionState |
private long |
completedSequenceId |
private float |
dataLocality |
private float |
dataLocalityForSsd |
private long |
filteredReadRequestCount |
private Size |
indexSize |
private long |
lastMajorCompactionTimestamp |
private int |
maxCompactedStoreFileRefCount |
private Size |
memStoreSize |
private byte[] |
name |
private long |
readRequestCount |
private Size |
rootLevelIndexSize |
private int |
storeCount |
private int |
storeFileCount |
private Size |
storeFileSize |
private int |
storeRefCount |
private Map<byte[],Long> |
storeSequenceIds |
private Size |
uncompressedDataIndexSize |
private Size |
uncompressedStoreFileSize |
private long |
writeRequestCount |
Constructor and Description |
---|
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 filteredReadRequestCount,
long completedSequenceId,
Map<byte[],Long> storeSequenceIds,
float dataLocality,
long lastMajorCompactionTimestamp,
float dataLocalityForSsd,
long blocksLocalWeight,
long blocksLocalWithSsdWeight,
long blocksTotalWeight,
CompactionState compactionState) |
Modifier and Type | Method and Description |
---|---|
long |
getBlocksLocalWeight()
Returns the data at local weight of this region in the regionserver
|
long |
getBlocksLocalWithSsdWeight()
Different from blocksLocalWeight,this metric's numerator only include the data stored on ssd
|
long |
getBlocksTotalWeight()
Returns the block total weight of this region
|
Size |
getBloomFilterSize()
Returns The total size of all Bloom filter blocks, not just loaded into the block cache
|
long |
getCompactedCellCount()
Returns the number of already compacted kvs in current compaction
|
long |
getCompactingCellCount()
Returns the total number of cells in current compaction
|
CompactionState |
getCompactionState()
Returns the compaction state of this region
|
long |
getCompletedSequenceId()
This does not really belong inside RegionLoad but its being done in the name of expediency.
|
float |
getDataLocality()
Returns the data locality of region in the regionserver.
|
float |
getDataLocalityForSsd()
Different from dataLocality,this metric's numerator only include the data stored on ssd
|
long |
getFilteredReadRequestCount()
Returns the number of filtered read requests made to region
|
long |
getLastMajorCompactionTimestamp()
Returns the timestamp of the oldest hfile for any store of this region.
|
int |
getMaxCompactedStoreFileRefCount()
Returns the max reference count for any store file among all compacted stores files of this
region
|
Size |
getMemStoreSize()
Returns the memstore size
|
long |
getReadRequestCount()
Returns the number of read requests made to region
|
byte[] |
getRegionName()
Returns the region name
|
int |
getStoreCount()
Returns the number of stores
|
int |
getStoreFileCount()
Returns the number of storefiles
|
Size |
getStoreFileIndexSize()
TODO: why we pass the same value to different counters? Currently, the value from
getStoreFileIndexSize() is same with getStoreFileRootLevelIndexSize() see
HRegionServer#createRegionLoad.
|
Size |
getStoreFileRootLevelIndexSize()
Returns The current total size of root-level indexes for the region
|
Size |
getStoreFileSize()
Returns the total size of the storefiles
|
Size |
getStoreFileUncompressedDataIndexSize()
Returns The total size of all index blocks, not just the root level
|
int |
getStoreRefCount()
Returns the reference count for the stores of this region
|
Map<byte[],Long> |
getStoreSequenceId()
Returns completed sequence id per store.
|
Size |
getUncompressedStoreFileSize()
Returns the uncompressed size of the storefiles
|
long |
getWriteRequestCount()
Returns the number of write requests made to region
|
String |
toString() |
clone, equals, finalize, getClass, hashCode, notify, notifyAll, wait, wait, wait
getNameAsString, getRequestCount
private final byte[] name
private final int storeCount
private final int storeFileCount
private final int storeRefCount
private final int maxCompactedStoreFileRefCount
private final long compactingCellCount
private final long compactedCellCount
private final Size storeFileSize
private final Size memStoreSize
private final Size rootLevelIndexSize
private final Size uncompressedDataIndexSize
private final Size bloomFilterSize
private final Size uncompressedStoreFileSize
private final long writeRequestCount
private final long readRequestCount
private final long filteredReadRequestCount
private final long completedSequenceId
private final Map<byte[],Long> storeSequenceIds
private final float dataLocality
private final long lastMajorCompactionTimestamp
private final float dataLocalityForSsd
private final long blocksLocalWeight
private final long blocksLocalWithSsdWeight
private final long blocksTotalWeight
private final CompactionState compactionState
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 filteredReadRequestCount, long completedSequenceId, Map<byte[],Long> storeSequenceIds, float dataLocality, long lastMajorCompactionTimestamp, float dataLocalityForSsd, long blocksLocalWeight, long blocksLocalWithSsdWeight, long blocksTotalWeight, CompactionState compactionState)
public byte[] getRegionName()
RegionMetrics
getRegionName
in interface RegionMetrics
public int getStoreCount()
RegionMetrics
getStoreCount
in interface RegionMetrics
public int getStoreFileCount()
RegionMetrics
getStoreFileCount
in interface RegionMetrics
public int getStoreRefCount()
RegionMetrics
getStoreRefCount
in interface RegionMetrics
public int getMaxCompactedStoreFileRefCount()
RegionMetrics
getMaxCompactedStoreFileRefCount
in interface RegionMetrics
public Size getStoreFileSize()
RegionMetrics
getStoreFileSize
in interface RegionMetrics
public Size getMemStoreSize()
RegionMetrics
getMemStoreSize
in interface RegionMetrics
public long getReadRequestCount()
RegionMetrics
getReadRequestCount
in interface RegionMetrics
public long getFilteredReadRequestCount()
RegionMetrics
getFilteredReadRequestCount
in interface RegionMetrics
public long getWriteRequestCount()
RegionMetrics
getWriteRequestCount
in interface RegionMetrics
public Size getStoreFileIndexSize()
RegionMetrics
getStoreFileIndexSize
in interface RegionMetrics
public Size getStoreFileRootLevelIndexSize()
RegionMetrics
getStoreFileRootLevelIndexSize
in interface RegionMetrics
public Size getStoreFileUncompressedDataIndexSize()
RegionMetrics
getStoreFileUncompressedDataIndexSize
in interface RegionMetrics
public Size getBloomFilterSize()
RegionMetrics
getBloomFilterSize
in interface RegionMetrics
public long getCompactingCellCount()
RegionMetrics
getCompactingCellCount
in interface RegionMetrics
public long getCompactedCellCount()
RegionMetrics
getCompactedCellCount
in interface RegionMetrics
public long getCompletedSequenceId()
RegionMetrics
getCompletedSequenceId
in interface RegionMetrics
public Map<byte[],Long> getStoreSequenceId()
RegionMetrics
getStoreSequenceId
in interface RegionMetrics
public Size getUncompressedStoreFileSize()
RegionMetrics
getUncompressedStoreFileSize
in interface RegionMetrics
public float getDataLocality()
RegionMetrics
getDataLocality
in interface RegionMetrics
public long getLastMajorCompactionTimestamp()
RegionMetrics
getLastMajorCompactionTimestamp
in interface RegionMetrics
public float getDataLocalityForSsd()
RegionMetrics
getDataLocalityForSsd
in interface RegionMetrics
public long getBlocksLocalWeight()
RegionMetrics
getBlocksLocalWeight
in interface RegionMetrics
public long getBlocksLocalWithSsdWeight()
RegionMetrics
getBlocksLocalWithSsdWeight
in interface RegionMetrics
public long getBlocksTotalWeight()
RegionMetrics
getBlocksTotalWeight
in interface RegionMetrics
public CompactionState getCompactionState()
RegionMetrics
getCompactionState
in interface RegionMetrics
Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.