Package | Description |
---|---|
org.apache.hadoop.hbase | |
org.apache.hadoop.hbase.client |
Provides HBase Client
|
org.apache.hadoop.hbase.master | |
org.apache.hadoop.hbase.master.assignment | |
org.apache.hadoop.hbase.master.normalizer |
The Region Normalizer subsystem is responsible for coaxing all the regions in a table toward
a "normal" size, according to their storefile size.
|
org.apache.hadoop.hbase.rsgroup | |
org.apache.hadoop.hbase.zookeeper |
Modifier and Type | Field and Description |
---|---|
private List<RegionState> |
ClusterMetricsBuilder.regionsInTransition |
private List<RegionState> |
ClusterMetricsBuilder.ClusterMetricsImpl.regionsInTransition |
Modifier and Type | Method and Description |
---|---|
List<RegionState> |
ClusterStatus.getRegionStatesInTransition()
Deprecated.
|
List<RegionState> |
ClusterMetrics.getRegionStatesInTransition() |
List<RegionState> |
ClusterMetricsBuilder.ClusterMetricsImpl.getRegionStatesInTransition() |
Modifier and Type | Method and Description |
---|---|
static String |
HRegionInfo.getDescriptiveNameFromRegionStateForDisplay(RegionState state,
org.apache.hadoop.conf.Configuration conf)
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use
RegionInfoDisplay#getDescriptiveNameFromRegionStateForDisplay(RegionState,
Configuration) over in hbase-server module.
|
Modifier and Type | Method and Description |
---|---|
ClusterMetricsBuilder |
ClusterMetricsBuilder.setRegionsInTransition(List<RegionState> value) |
Constructor and Description |
---|
ClusterMetricsImpl(String hbaseVersion,
List<ServerName> deadServerNames,
List<ServerName> unknownServerNames,
Map<ServerName,ServerMetrics> liveServerMetrics,
ServerName masterName,
List<ServerName> backupMasterNames,
List<RegionState> regionsInTransition,
String clusterId,
List<String> masterCoprocessorNames,
Boolean balancerOn,
int masterInfoPort,
List<ServerName> serversName,
Map<TableName,RegionStatesCount> tableRegionStatesCount,
List<ServerTask> masterTasks) |
ClusterStatus(String hbaseVersion,
String clusterid,
Map<ServerName,ServerLoad> servers,
Collection<ServerName> deadServers,
ServerName master,
Collection<ServerName> backupMasters,
List<RegionState> rit,
String[] masterCoprocessors,
Boolean balancerOn,
int masterInfoPort)
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0
|
Modifier and Type | Method and Description |
---|---|
static String |
RegionInfoDisplay.getDescriptiveNameFromRegionStateForDisplay(RegionState state,
org.apache.hadoop.conf.Configuration conf)
Get the descriptive name as
RegionState does it but with hidden startkey optionally |
Modifier and Type | Method and Description |
---|---|
static RegionState |
RegionState.convert(org.apache.hadoop.hbase.shaded.protobuf.generated.ClusterStatusProtos.RegionState proto)
Convert a protobuf HBaseProtos.RegionState to a RegionState
|
static RegionState |
RegionState.createForTesting(RegionInfo region,
RegionState.State state) |
Modifier and Type | Field and Description |
---|---|
private HashMap<String,RegionState> |
AssignmentManager.RegionInTransitionStat.ritsOverThreshold |
Modifier and Type | Method and Description |
---|---|
RegionState |
RegionStates.getRegionState(RegionInfo regionInfo) |
RegionState |
RegionStates.getRegionState(String encodedRegionName) |
RegionState |
RegionStates.getRegionTransitionState(RegionInfo hri) |
RegionState |
RegionStateNode.toRegionState() |
Modifier and Type | Method and Description |
---|---|
List<RegionState> |
RegionStates.getRegionFailedOpen() |
Collection<RegionState> |
AssignmentManager.RegionInTransitionStat.getRegionOverThreshold() |
SortedSet<RegionState> |
RegionStates.getRegionsInTransitionOrderedByTimestamp() |
List<RegionState> |
RegionStates.getRegionsStateInTransition() |
ArrayList<RegionState> |
RegionStates.getRegionStates()
Returns A snapshot of region state nodes for all the regions.
|
(package private) ArrayList<RegionState> |
RegionStates.getTableRegionStates(TableName tableName) |
Modifier and Type | Method and Description |
---|---|
int |
RegionStates.RegionStateStampComparator.compare(RegionState l,
RegionState r) |
private boolean |
MergeTableRegionsProcedure.isMergeable(MasterProcedureEnv env,
RegionState rs) |
Modifier and Type | Method and Description |
---|---|
private void |
AssignmentManager.RegionInTransitionStat.update(Collection<RegionState> regions,
long currentTime) |
Modifier and Type | Method and Description |
---|---|
private static boolean |
SimpleRegionNormalizer.skipForSplit(RegionState state,
RegionInfo regionInfo)
Determine if a region in
RegionState should be considered for a split operation. |
Modifier and Type | Method and Description |
---|---|
private Map<String,RegionState> |
RSGroupAdminServer.rsGroupGetRegionsInTransition(String groupName) |
Modifier and Type | Method and Description |
---|---|
static RegionState |
MetaTableLocator.getMetaRegionState(ZKWatcher zkw)
Load the meta region state from the meta server ZNode.
|
static RegionState |
MetaTableLocator.getMetaRegionState(ZKWatcher zkw,
int replicaId)
Load the meta region state from the meta region server ZNode.
|
Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.