RegionMetrics
instead.@InterfaceAudience.Public @Deprecated public class RegionLoad extends Object implements RegionMetrics
Modifier and Type | Field and Description |
---|---|
private RegionMetrics |
metrics
Deprecated.
|
protected org.apache.hadoop.hbase.shaded.protobuf.generated.ClusterStatusProtos.RegionLoad |
regionLoadPB
Deprecated.
|
Constructor and Description |
---|
RegionLoad(org.apache.hadoop.hbase.shaded.protobuf.generated.ClusterStatusProtos.RegionLoad regionLoadPB)
Deprecated.
|
RegionLoad(RegionMetrics metrics)
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
long |
getBlocksLocalWeight()
Deprecated.
Returns the data at local weight of this region in the regionserver
|
long |
getBlocksLocalWithSsdWeight()
Deprecated.
Different from blocksLocalWeight,this metric's numerator only include the data stored on ssd
|
long |
getBlocksTotalWeight()
Deprecated.
Returns the block total weight of this region
|
Size |
getBloomFilterSize()
Deprecated.
Returns The total size of all Bloom filter blocks, not just loaded into the block cache
|
long |
getCompactedCellCount()
Deprecated.
Returns the number of already compacted kvs in current compaction
|
long |
getCompactingCellCount()
Deprecated.
Returns the total number of cells in current compaction
|
CompactionState |
getCompactionState()
Deprecated.
Returns the compaction state of this region
|
long |
getCompletedSequenceId()
Deprecated.
This does not really belong inside RegionLoad but its being done in the name of expediency.
|
long |
getCompleteSequenceId()
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use
getCompletedSequenceId() instead. |
long |
getCurrentCompactedKVs()
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use
getCompactedCellCount() instead. |
float |
getDataLocality()
Deprecated.
Returns the data locality of region in the regionserver.
|
float |
getDataLocalityForSsd()
Deprecated.
Different from dataLocality,this metric's numerator only include the data stored on ssd
|
long |
getFilteredReadRequestCount()
Deprecated.
Returns the number of filtered read requests made to region
|
long |
getFilteredReadRequestsCount()
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use
getFilteredReadRequestCount() instead. |
long |
getLastMajorCompactionTimestamp()
Deprecated.
Returns the timestamp of the oldest hfile for any store of this region.
|
long |
getLastMajorCompactionTs()
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use
getLastMajorCompactionTimestamp() instead. |
int |
getMaxCompactedStoreFileRefCount()
Deprecated.
Returns the max reference count for any store file among all compacted stores files of this
region
|
Size |
getMemStoreSize()
Deprecated.
Returns the memstore size
|
int |
getMemStoreSizeMB()
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use
getMemStoreSize() instead. |
byte[] |
getName()
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use
getRegionName()
instead. |
long |
getReadRequestCount()
Deprecated.
Returns the number of read requests made to region
|
long |
getReadRequestsCount()
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use
getReadRequestCount() instead. |
byte[] |
getRegionName()
Deprecated.
Returns the region name
|
long |
getRequestsCount()
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use
RegionMetrics.getRequestCount() instead. |
int |
getRootIndexSizeKB()
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use
getStoreFileRootLevelIndexSize() instead. |
List<org.apache.hadoop.hbase.shaded.protobuf.generated.ClusterStatusProtos.StoreSequenceId> |
getStoreCompleteSequenceId()
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use
getStoreSequenceId() instead. |
int |
getStoreCount()
Deprecated.
Returns the number of stores
|
int |
getStoreFileCount()
Deprecated.
Returns the number of storefiles
|
Size |
getStoreFileIndexSize()
Deprecated.
TODO: why we pass the same value to different counters? Currently, the value from
getStoreFileIndexSize() is same with getStoreFileRootLevelIndexSize() see
HRegionServer#createRegionLoad.
|
int |
getStorefileIndexSizeKB()
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use
getStoreFileRootLevelIndexSize() instead. |
int |
getStorefileIndexSizeMB()
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0
((HBASE-3935)). Use
getStoreFileRootLevelIndexSize() instead. |
Size |
getStoreFileRootLevelIndexSize()
Deprecated.
Returns The current total size of root-level indexes for the region
|
int |
getStorefiles()
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use
getStoreFileCount() instead. |
Size |
getStoreFileSize()
Deprecated.
Returns the total size of the storefiles
|
int |
getStorefileSizeMB()
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use
getStoreFileSize() instead. |
Size |
getStoreFileUncompressedDataIndexSize()
Deprecated.
Returns The total size of all index blocks, not just the root level
|
int |
getStoreRefCount()
Deprecated.
Returns the reference count for the stores of this region
|
int |
getStores()
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use
getStoreCount()
instead. |
Map<byte[],Long> |
getStoreSequenceId()
Deprecated.
Returns completed sequence id per store.
|
int |
getStoreUncompressedSizeMB()
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use
getUncompressedStoreFileSize() instead. |
long |
getTotalCompactingKVs()
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use
getCompactingCellCount() instead. |
int |
getTotalStaticBloomSizeKB()
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use
getBloomFilterSize() instead. |
int |
getTotalStaticIndexSizeKB()
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use
getStoreFileUncompressedDataIndexSize() instead. |
Size |
getUncompressedStoreFileSize()
Deprecated.
Returns the uncompressed size of the storefiles
|
long |
getWriteRequestCount()
Deprecated.
Returns the number of write requests made to region
|
long |
getWriteRequestsCount()
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use
getWriteRequestCount() instead. |
String |
toString()
Deprecated.
|
clone, equals, finalize, getClass, hashCode, notify, notifyAll, wait, wait, wait
getNameAsString, getRequestCount
protected org.apache.hadoop.hbase.shaded.protobuf.generated.ClusterStatusProtos.RegionLoad regionLoadPB
private final RegionMetrics metrics
public RegionLoad(org.apache.hadoop.hbase.shaded.protobuf.generated.ClusterStatusProtos.RegionLoad regionLoadPB)
RegionLoad(RegionMetrics metrics)
@Deprecated public byte[] getName()
getRegionName()
instead.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 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 Size getStoreFileIndexSize()
RegionMetrics
getStoreFileIndexSize
in interface RegionMetrics
public long getWriteRequestCount()
RegionMetrics
getWriteRequestCount
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
@Deprecated public int getStores()
getStoreCount()
instead.@Deprecated public int getStorefiles()
getStoreFileCount()
instead.@Deprecated public int getStorefileSizeMB()
getStoreFileSize()
instead.@Deprecated public int getMemStoreSizeMB()
getMemStoreSize()
instead.@Deprecated public int getStorefileIndexSizeMB()
getStoreFileRootLevelIndexSize()
instead.@Deprecated public int getStorefileIndexSizeKB()
getStoreFileRootLevelIndexSize()
instead.@Deprecated public long getRequestsCount()
RegionMetrics.getRequestCount()
instead.@Deprecated public long getReadRequestsCount()
getReadRequestCount()
instead.@Deprecated public long getFilteredReadRequestsCount()
getFilteredReadRequestCount()
instead.@Deprecated public long getWriteRequestsCount()
getWriteRequestCount()
instead.@Deprecated public int getRootIndexSizeKB()
getStoreFileRootLevelIndexSize()
instead.@Deprecated public int getTotalStaticIndexSizeKB()
getStoreFileUncompressedDataIndexSize()
instead.@Deprecated public int getTotalStaticBloomSizeKB()
getBloomFilterSize()
instead.@Deprecated public long getTotalCompactingKVs()
getCompactingCellCount()
instead.@Deprecated public long getCurrentCompactedKVs()
getCompactedCellCount()
instead.@Deprecated public long getCompleteSequenceId()
getCompletedSequenceId()
instead.@Deprecated public List<org.apache.hadoop.hbase.shaded.protobuf.generated.ClusterStatusProtos.StoreSequenceId> getStoreCompleteSequenceId()
getStoreSequenceId()
instead.@Deprecated public int getStoreUncompressedSizeMB()
getUncompressedStoreFileSize()
instead.public float getDataLocality()
getDataLocality
in interface RegionMetrics
public long getLastMajorCompactionTimestamp()
RegionMetrics
getLastMajorCompactionTimestamp
in interface RegionMetrics
@Deprecated public long getLastMajorCompactionTs()
getLastMajorCompactionTimestamp()
instead.public int getStoreRefCount()
getStoreRefCount
in interface RegionMetrics
public int getMaxCompactedStoreFileRefCount()
RegionMetrics
getMaxCompactedStoreFileRefCount
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
public String toString()
toString
in class Object
Object.toString()
Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.