Modifier and Type | Method and Description |
---|---|
void |
TableStateManager.checkAndRemoveTableState(TableName tableName,
org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Table.State states,
boolean deletePermanentState)
If the table is found in the given state the in-memory state is removed.
|
Set<TableName> |
TableStateManager.getTablesInStates(org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Table.State... states) |
TableStateManager |
CoordinatedStateManager.getTableStateManager()
Returns implementation of TableStateManager.
|
void |
TableStateManager.setDeletedTable(TableName tableName)
Mark table as deleted.
|
void |
TableStateManager.setTableState(TableName tableName,
org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Table.State state)
Sets the table into desired state.
|
boolean |
TableStateManager.setTableStateIfInStates(TableName tableName,
org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Table.State newState,
org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Table.State... states)
Sets the specified table into the newState, but only if the table is already in
one of the possibleCurrentStates (otherwise no operation is performed).
|
boolean |
TableStateManager.setTableStateIfNotInStates(TableName tableName,
org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Table.State newState,
org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Table.State... states)
Sets the specified table into the newState, but only if the table is NOT in
one of the possibleCurrentStates (otherwise no operation is performed).
|
Modifier and Type | Method and Description |
---|---|
abstract TableStateManager |
BaseCoordinatedStateManager.getTableStateManager() |
TableStateManager |
ZkCoordinatedStateManager.getTableStateManager() |
Modifier and Type | Method and Description |
---|---|
boolean |
HMaster.normalizeRegions()
Perform normalization of cluster (invoked by
RegionNormalizerChore ). |
Constructor and Description |
---|
AssignmentManager(MasterServices server,
ServerManager serverManager,
LoadBalancer balancer,
ExecutorService service,
MetricsMaster metricsMaster,
TableLockManager tableLockManager)
Constructs a new assignment manager.
|
Modifier and Type | Method and Description |
---|---|
protected abstract void |
TableEventHandler.handleTableOperation(List<HRegionInfo> regions) |
Modifier and Type | Method and Description |
---|---|
protected static void |
ProcedureSyncWait.waitRegionInTransition(MasterProcedureEnv env,
List<HRegionInfo> regions) |
Modifier and Type | Method and Description |
---|---|
void |
ZKTableStateManager.checkAndRemoveTableState(TableName tableName,
org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Table.State states,
boolean deletePermanentState)
If the table is found in the given state the in-memory state is removed.
|
Set<TableName> |
ZKTableStateManager.getTablesInStates(org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Table.State... states)
Gets a list of all the tables set as disabling in zookeeper.
|
void |
ZKTableStateManager.setDeletedTable(TableName tableName)
Deletes the table in zookeeper.
|
void |
ZKTableStateManager.setTableState(TableName tableName,
org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Table.State state)
Sets table state in ZK.
|
boolean |
ZKTableStateManager.setTableStateIfInStates(TableName tableName,
org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Table.State newState,
org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Table.State... states)
Checks and sets table state in ZK.
|
boolean |
ZKTableStateManager.setTableStateIfNotInStates(TableName tableName,
org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Table.State newState,
org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Table.State... states)
Checks and sets table state in ZK.
|
Copyright © 2007–2019 The Apache Software Foundation. All rights reserved.