Uses of Enum Class
org.apache.hadoop.hbase.master.RegionState.State
Package
Description
Provides HBase Client
Multi Cluster Replication
-
Uses of RegionState.State in org.apache.hadoop.hbase
Modifier and TypeMethodDescriptionstatic Put
MetaTableAccessor.addRegionStateToPut
(Put put, int replicaId, RegionState.State state) static void
MetaTableAccessor.updateRegionState
(Connection connection, RegionInfo ri, RegionState.State state) Update state column in hbase:meta. -
Uses of RegionState.State in org.apache.hadoop.hbase.client
Modifier and TypeMethodDescriptionprivate Pair<RegionState.State,
ServerName> ZKConnectionRegistry.getStateAndServerName
(org.apache.hadoop.hbase.shaded.protobuf.generated.ZooKeeperProtos.MetaRegionServer proto) Deprecated.HBaseHbck.setRegionStateInMeta
(Map<String, RegionState.State> nameOrEncodedName2State) Hbck.setRegionStateInMeta
(Map<String, RegionState.State> nameOrEncodedName2State) Update region state in Meta only.Modifier and TypeMethodDescriptionHBaseHbck.setRegionStateInMeta
(Map<String, RegionState.State> nameOrEncodedName2State) Hbck.setRegionStateInMeta
(Map<String, RegionState.State> nameOrEncodedName2State) Update region state in Meta only. -
Uses of RegionState.State in org.apache.hadoop.hbase.master
Modifier and TypeMethodDescriptionstatic RegionState.State
RegionState.State.convert
(org.apache.hadoop.hbase.shaded.protobuf.generated.ClusterStatusProtos.RegionState.State protoState) Convert a protobuf HBaseProtos.RegionState.State to a RegionState.StateRegionState.getState()
static RegionState.State
Returns the enum constant of this class with the specified name.static RegionState.State[]
RegionState.State.values()
Returns an array containing the constants of this enum class, in the order they are declared.Modifier and TypeMethodDescriptionstatic RegionState
RegionState.createForTesting
(RegionInfo region, RegionState.State state) static boolean
RegionState.isUnassignable
(RegionState.State state) Check if a region state is one of offline states that can't transition to pending_close/closing (unassign/offline)boolean
RegionState.State.matches
(RegionState.State... expected) ModifierConstructorDescriptionRegionState
(RegionInfo region, RegionState.State state, long stamp, ServerName serverName) RegionState
(RegionInfo region, RegionState.State state, long stamp, ServerName serverName, long ritDuration) RegionState
(RegionInfo region, RegionState.State state, ServerName serverName) -
Uses of RegionState.State in org.apache.hadoop.hbase.master.assignment
Modifier and TypeFieldDescriptionprivate static final RegionState.State[]
SplitTableRegionProcedure.EXPECTED_SPLIT_STATES
private RegionState.State
RegionStateNode.state
A Region-in-Transition (RIT) moves through states.private static final RegionState.State[]
AssignmentManager.STATES_EXPECTED_ON_ASSIGN
private static final RegionState.State[]
AssignmentManager.STATES_EXPECTED_ON_CLOSED
private static final RegionState.State[]
AssignmentManager.STATES_EXPECTED_ON_CLOSING
private static final RegionState.State[]
AssignmentManager.STATES_EXPECTED_ON_OPEN
private static final RegionState.State[]
AssignmentManager.STATES_EXPECTED_ON_UNASSIGN_OR_MOVE
Modifier and TypeMethodDescriptionstatic RegionState.State
RegionStateStore.getRegionState
(Result r, RegionInfo regionInfo) Pull the region state from a catalog tableResult
.RegionStateNode.getState()
Modifier and TypeMethodDescriptionboolean
RegionStateNode.isInState
(RegionState.State... expected) Notice that, we will return true ifexpected
is empty.boolean
RegionStates.isRegionInState
(RegionInfo regionInfo, RegionState.State... state) private void
RegionStateStore.mirrorMetaLocation
(RegionInfo regionInfo, ServerName serverName, RegionState.State state) private void
AssignmentManager.preTransitCheck
(RegionStateNode regionNode, RegionState.State[] expectedStates) boolean
RegionStateNode.setState
(RegionState.State update, RegionState.State... expected) void
RegionStateNode.transitionState
(RegionState.State update, RegionState.State... expected) Set newRegionState.State
but only if currently inexpected
State (if not, throwUnexpectedStateException
.private CompletableFuture<Void>
AssignmentManager.transitStateAndUpdate
(RegionStateNode regionNode, RegionState.State newState, RegionState.State... expectedStates) private CompletableFuture<Void>
RegionStateStore.updateRegionLocation
(RegionInfo regionInfo, RegionState.State state, Put put) void
RegionStates.updateRegionState
(RegionInfo regionInfo, RegionState.State state) void
AssignmentManager.RegionMetaLoadingVisitor.visitRegionState
(Result result, RegionInfo regionInfo, RegionState.State state, ServerName regionLocation, ServerName lastHost, long openSeqNum) void
RegionStateStore.RegionStateVisitor.visitRegionState
(Result result, RegionInfo regionInfo, RegionState.State state, ServerName regionLocation, ServerName lastHost, long openSeqNum) -
Uses of RegionState.State in org.apache.hadoop.hbase.master.http
Modifier and TypeFieldDescriptionprivate final RegionState.State
RegionReplicaInfo.regionState
private final RegionState.State
MetaBrowser.scanRegionState
Modifier and TypeMethodDescriptionRegionReplicaInfo.getRegionState()
MetaBrowser.getScanRegionState()
private RegionState.State
MetaBrowser.resolveScanRegionState
(javax.servlet.http.HttpServletRequest request) Modifier and TypeMethodDescriptionprivate static Filter
MetaBrowser.buildScanRegionStateFilter
(RegionState.State state) -
Uses of RegionState.State in org.apache.hadoop.hbase.replication
Modifier and TypeFieldDescriptionprivate final RegionState.State
ReplicationBarrierFamilyFormat.ReplicationBarrierResult.state
Modifier and TypeMethodDescriptionReplicationBarrierFamilyFormat.ReplicationBarrierResult.getState()
ModifierConstructorDescription(package private)
ReplicationBarrierResult
(long[] barriers, RegionState.State state, List<byte[]> parentRegionNames) -
Uses of RegionState.State in org.apache.hadoop.hbase.zookeeper
Modifier and TypeMethodDescriptionstatic void
MetaTableLocator.setMetaLocation
(ZKWatcher zookeeper, ServerName serverName, int replicaId, RegionState.State state) Sets the location ofhbase:meta
in ZooKeeper to the specified server address.static void
MetaTableLocator.setMetaLocation
(ZKWatcher zookeeper, ServerName serverName, RegionState.State state) Sets the location ofhbase:meta
in ZooKeeper to the specified server address.