Package | Description |
---|---|
org.apache.hadoop.hbase | |
org.apache.hadoop.hbase.client |
Provides HBase Client
|
org.apache.hadoop.hbase.master | |
org.apache.hadoop.hbase.regionserver | |
org.apache.hadoop.hbase.thrift2.client |
Modifier and Type | Field and Description |
---|---|
private CompactionState |
RegionMetricsBuilder.compactionState |
private CompactionState |
RegionMetricsBuilder.RegionMetricsImpl.compactionState |
Modifier and Type | Method and Description |
---|---|
CompactionState |
RegionMetricsBuilder.RegionMetricsImpl.getCompactionState() |
CompactionState |
RegionLoad.getCompactionState()
Deprecated.
|
CompactionState |
RegionMetrics.getCompactionState()
Returns the compaction state of this region
|
Modifier and Type | Method and Description |
---|---|
RegionMetricsBuilder |
RegionMetricsBuilder.setCompactionState(CompactionState compactionState) |
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 |
---|---|
CompactionState |
Admin.getCompactionState(TableName tableName)
Get the current compaction state of a table.
|
CompactionState |
HBaseAdmin.getCompactionState(TableName tableName) |
CompactionState |
Admin.getCompactionState(TableName tableName,
CompactType compactType)
Get the current compaction state of a table.
|
CompactionState |
HBaseAdmin.getCompactionState(TableName tableName,
CompactType compactType)
Get the current compaction state of a table.
|
CompactionState |
Admin.getCompactionStateForRegion(byte[] regionName)
Get the current compaction state of region.
|
CompactionState |
HBaseAdmin.getCompactionStateForRegion(byte[] regionName) |
static CompactionState |
CompactionState.valueOf(String name)
Returns the enum constant of this type with the specified name.
|
static CompactionState[] |
CompactionState.values()
Returns an array containing the constants of this enum type, in
the order they are declared.
|
Modifier and Type | Method and Description |
---|---|
default CompletableFuture<CompactionState> |
AsyncAdmin.getCompactionState(TableName tableName)
Get the current compaction state of a table.
|
CompletableFuture<CompactionState> |
AsyncAdmin.getCompactionState(TableName tableName,
CompactType compactType)
Get the current compaction state of a table.
|
CompletableFuture<CompactionState> |
RawAsyncHBaseAdmin.getCompactionState(TableName tableName,
CompactType compactType) |
CompletableFuture<CompactionState> |
AsyncHBaseAdmin.getCompactionState(TableName tableName,
CompactType compactType) |
CompletableFuture<CompactionState> |
AsyncAdmin.getCompactionStateForRegion(byte[] regionName)
Get the current compaction state of region.
|
CompletableFuture<CompactionState> |
RawAsyncHBaseAdmin.getCompactionStateForRegion(byte[] regionName) |
CompletableFuture<CompactionState> |
AsyncHBaseAdmin.getCompactionStateForRegion(byte[] regionName) |
Modifier and Type | Method and Description |
---|---|
CompactionState |
HMaster.getCompactionState(TableName tableName)
Get the compaction state of the table
|
Modifier and Type | Method and Description |
---|---|
CompactionState |
Region.getCompactionState()
Returns if a given region is in compaction now.
|
CompactionState |
HRegion.getCompactionState() |
Modifier and Type | Method and Description |
---|---|
CompactionState |
ThriftAdmin.getCompactionState(TableName tableName) |
CompactionState |
ThriftAdmin.getCompactionState(TableName tableName,
CompactType compactType) |
CompactionState |
ThriftAdmin.getCompactionStateForRegion(byte[] regionName) |
Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.