HBASE-25124 Support changing region replica count without disabling table (#2497)

Signed-off-by: stack <stack@apache.org>
This commit is contained in:
Duo Zhang 2020-10-08 21:35:29 +08:00 committed by GitHub
parent aff8bbf0cb
commit 0d63318f10
No known key found for this signature in database
GPG Key ID: 4AEE18F83AFDEB23
10 changed files with 161 additions and 257 deletions

View File

@ -72,6 +72,8 @@ enum ModifyTableState {
MODIFY_TABLE_DELETE_FS_LAYOUT = 5; MODIFY_TABLE_DELETE_FS_LAYOUT = 5;
MODIFY_TABLE_POST_OPERATION = 6; MODIFY_TABLE_POST_OPERATION = 6;
MODIFY_TABLE_REOPEN_ALL_REGIONS = 7; MODIFY_TABLE_REOPEN_ALL_REGIONS = 7;
MODIFY_TABLE_CLOSE_EXCESS_REPLICAS = 8;
MODIFY_TABLE_ASSIGN_NEW_REPLICAS = 9;
} }
message ModifyTableStateData { message ModifyTableStateData {

View File

@ -870,32 +870,47 @@ public class AssignmentManager {
.sorted(AssignmentManager::compare).toArray(TransitRegionStateProcedure[]::new); .sorted(AssignmentManager::compare).toArray(TransitRegionStateProcedure[]::new);
} }
/** // for creating unassign TRSP when disabling a table or closing excess region replicas
* Called by DisableTableProcedure to unassign all the regions for a table. private TransitRegionStateProcedure forceCreateUnssignProcedure(RegionStateNode regionNode) {
*/
public TransitRegionStateProcedure[] createUnassignProceduresForDisabling(TableName tableName) {
return regionStates.getTableRegionStateNodes(tableName).stream().map(regionNode -> {
regionNode.lock(); regionNode.lock();
try { try {
if (!regionStates.include(regionNode, false) || if (!regionStates.include(regionNode, false) ||
regionStates.isRegionOffline(regionNode.getRegionInfo())) { regionStates.isRegionOffline(regionNode.getRegionInfo())) {
return null; return null;
} }
// As in DisableTableProcedure, we will hold the xlock for table, so we can make sure that // As in DisableTableProcedure or ModifyTableProcedure, we will hold the xlock for table, so
// this procedure has not been executed yet, as TRSP will hold the shared lock for table all // we can make sure that this procedure has not been executed yet, as TRSP will hold the
// the time. So here we will unset it and when it is actually executed, it will find that // shared lock for table all the time. So here we will unset it and when it is actually
// the attach procedure is not itself and quit immediately. // executed, it will find that the attach procedure is not itself and quit immediately.
if (regionNode.getProcedure() != null) { if (regionNode.getProcedure() != null) {
regionNode.unsetProcedure(regionNode.getProcedure()); regionNode.unsetProcedure(regionNode.getProcedure());
} }
TransitRegionStateProcedure proc = TransitRegionStateProcedure return regionNode.setProcedure(TransitRegionStateProcedure.unassign(getProcedureEnvironment(),
.unassign(getProcedureEnvironment(), regionNode.getRegionInfo()); regionNode.getRegionInfo()));
regionNode.setProcedure(proc);
return proc;
} finally { } finally {
regionNode.unlock(); regionNode.unlock();
} }
}).filter(p -> p != null).toArray(TransitRegionStateProcedure[]::new); }
/**
* Called by DisableTableProcedure to unassign all the regions for a table.
*/
public TransitRegionStateProcedure[] createUnassignProceduresForDisabling(TableName tableName) {
return regionStates.getTableRegionStateNodes(tableName).stream()
.map(this::forceCreateUnssignProcedure).filter(p -> p != null)
.toArray(TransitRegionStateProcedure[]::new);
}
/**
* Called by ModifyTableProcedures to unassign all the excess region replicas
* for a table.
*/
public TransitRegionStateProcedure[] createUnassignProceduresForClosingExcessRegionReplicas(
TableName tableName, int newReplicaCount) {
return regionStates.getTableRegionStateNodes(tableName).stream()
.filter(regionNode -> regionNode.getRegionInfo().getReplicaId() >= newReplicaCount)
.map(this::forceCreateUnssignProcedure).filter(p -> p != null)
.toArray(TransitRegionStateProcedure[]::new);
} }
public SplitTableRegionProcedure createSplitProcedure(final RegionInfo regionToSplit, public SplitTableRegionProcedure createSplitProcedure(final RegionInfo regionToSplit,

View File

@ -547,25 +547,12 @@ public class RegionStateStore {
LOG.debug("Overwritten regions: {} ", regionInfos); LOG.debug("Overwritten regions: {} ", regionInfos);
} }
/**
* Update region replicas if necessary by adding new replica locations or removing unused region
* replicas
*/
public void updateRegionReplicas(TableName tableName, int oldReplicaCount, int newReplicaCount)
throws IOException {
if (newReplicaCount < oldReplicaCount) {
removeRegionReplicas(tableName, oldReplicaCount, newReplicaCount);
} else if (newReplicaCount > oldReplicaCount) {
addRegionReplicas(tableName, oldReplicaCount, newReplicaCount);
}
}
private Scan getScanForUpdateRegionReplicas(TableName tableName) { private Scan getScanForUpdateRegionReplicas(TableName tableName) {
return MetaTableAccessor.getScanForTableName(master.getConfiguration(), tableName) return MetaTableAccessor.getScanForTableName(master.getConfiguration(), tableName)
.addColumn(HConstants.CATALOG_FAMILY, HConstants.REGIONINFO_QUALIFIER); .addColumn(HConstants.CATALOG_FAMILY, HConstants.REGIONINFO_QUALIFIER);
} }
private void removeRegionReplicas(TableName tableName, int oldReplicaCount, int newReplicaCount) public void removeRegionReplicas(TableName tableName, int oldReplicaCount, int newReplicaCount)
throws IOException { throws IOException {
Scan scan = getScanForUpdateRegionReplicas(tableName); Scan scan = getScanForUpdateRegionReplicas(tableName);
List<Delete> deletes = new ArrayList<>(); List<Delete> deletes = new ArrayList<>();
@ -598,32 +585,6 @@ public class RegionStateStore {
} }
} }
private void addRegionReplicas(TableName tableName, int oldReplicaCount, int newReplicaCount)
throws IOException {
Scan scan = getScanForUpdateRegionReplicas(tableName);
List<Put> puts = new ArrayList<>();
long now = EnvironmentEdgeManager.currentTime();
try (Table metaTable = getMetaTable(); ResultScanner scanner = metaTable.getScanner(scan)) {
for (;;) {
Result result = scanner.next();
if (result == null) {
break;
}
RegionInfo primaryRegionInfo = CatalogFamilyFormat.getRegionInfo(result);
if (primaryRegionInfo == null || primaryRegionInfo.isSplitParent()) {
continue;
}
Put put = new Put(result.getRow(), now);
for (int i = oldReplicaCount; i < newReplicaCount; i++) {
MetaTableAccessor.addEmptyLocation(put, i);
}
puts.add(put);
}
debugLogMutations(puts);
metaTable.put(puts);
}
}
// ========================================================================== // ==========================================================================
// Table Descriptors helpers // Table Descriptors helpers
// ========================================================================== // ==========================================================================

View File

@ -20,17 +20,11 @@ package org.apache.hadoop.hbase.master.procedure;
import java.io.IOException; import java.io.IOException;
import java.util.ArrayList; import java.util.ArrayList;
import java.util.List; import java.util.List;
import org.apache.hadoop.hbase.CatalogFamilyFormat;
import org.apache.hadoop.hbase.Cell;
import org.apache.hadoop.hbase.HConstants;
import org.apache.hadoop.hbase.MetaTableAccessor;
import org.apache.hadoop.hbase.TableName; import org.apache.hadoop.hbase.TableName;
import org.apache.hadoop.hbase.TableNotDisabledException; import org.apache.hadoop.hbase.TableNotDisabledException;
import org.apache.hadoop.hbase.TableNotFoundException; import org.apache.hadoop.hbase.TableNotFoundException;
import org.apache.hadoop.hbase.client.Connection;
import org.apache.hadoop.hbase.client.RegionInfo; import org.apache.hadoop.hbase.client.RegionInfo;
import org.apache.hadoop.hbase.client.RegionReplicaUtil; import org.apache.hadoop.hbase.client.RegionReplicaUtil;
import org.apache.hadoop.hbase.client.Result;
import org.apache.hadoop.hbase.client.TableDescriptor; import org.apache.hadoop.hbase.client.TableDescriptor;
import org.apache.hadoop.hbase.client.TableState; import org.apache.hadoop.hbase.client.TableState;
import org.apache.hadoop.hbase.master.MasterCoprocessorHost; import org.apache.hadoop.hbase.master.MasterCoprocessorHost;
@ -100,7 +94,6 @@ public class EnableTableProcedure
case ENABLE_TABLE_MARK_REGIONS_ONLINE: case ENABLE_TABLE_MARK_REGIONS_ONLINE:
// Get the region replica count. If changed since disable, need to do // Get the region replica count. If changed since disable, need to do
// more work assigning. // more work assigning.
Connection connection = env.getMasterServices().getConnection();
TableDescriptor tableDescriptor = TableDescriptor tableDescriptor =
env.getMasterServices().getTableDescriptors().get(tableName); env.getMasterServices().getTableDescriptors().get(tableName);
int configuredReplicaCount = tableDescriptor.getRegionReplication(); int configuredReplicaCount = tableDescriptor.getRegionReplication();
@ -111,25 +104,16 @@ public class EnableTableProcedure
// How many replicas do we currently have? Check regions returned from // How many replicas do we currently have? Check regions returned from
// in-memory state. // in-memory state.
int currentMaxReplica = getMaxReplicaId(regionsOfTable); int currentMaxReplica = getMaxReplicaId(regionsOfTable);
if (currentMaxReplica == configuredReplicaCount - 1) {
// Read the META table to know the number of replicas the table currently has.
// If there was a table modification on region replica count then need to
// adjust replica counts here.
int replicasFound = TableName.isMetaTableName(this.tableName)?
0: // TODO: Figure better what to do here for hbase:meta replica.
getReplicaCountInMeta(connection, configuredReplicaCount, regionsOfTable);
LOG.info("replicasFound={} (configuredReplicaCount={} for {}", replicasFound,
configuredReplicaCount, tableName.getNameAsString());
if (currentMaxReplica == (configuredReplicaCount - 1)) {
if (LOG.isDebugEnabled()) {
LOG.debug("No change in number of region replicas (configuredReplicaCount={});" LOG.debug("No change in number of region replicas (configuredReplicaCount={});"
+ " assigning.", configuredReplicaCount); + " assigning.", configuredReplicaCount);
}
} else if (currentMaxReplica > (configuredReplicaCount - 1)) { } else if (currentMaxReplica > (configuredReplicaCount - 1)) {
// We have additional regions as the replica count has been decreased. Delete // We have additional regions as the replica count has been decreased. Delete
// those regions because already the table is in the unassigned state // those regions because already the table is in the unassigned state
LOG.info("The number of replicas " + (currentMaxReplica + 1) LOG.warn(
+ " is more than the region replica count " + configuredReplicaCount); "The number of replicas {} is more than the region replica count {}" +
", usually this should not happen as we will delete them in ModifyTableProcedure",
currentMaxReplica + 1, configuredReplicaCount);
List<RegionInfo> copyOfRegions = new ArrayList<RegionInfo>(regionsOfTable); List<RegionInfo> copyOfRegions = new ArrayList<RegionInfo>(regionsOfTable);
for (RegionInfo regionInfo : copyOfRegions) { for (RegionInfo regionInfo : copyOfRegions) {
if (regionInfo.getReplicaId() > (configuredReplicaCount - 1)) { if (regionInfo.getReplicaId() > (configuredReplicaCount - 1)) {
@ -140,11 +124,11 @@ public class EnableTableProcedure
regionsOfTable.remove(regionInfo); regionsOfTable.remove(regionInfo);
} }
} }
} else { } else if (currentMaxReplica < configuredReplicaCount - 1) {
// the replicasFound is less than the regionReplication // the replicasFound is less than the regionReplication
LOG.info("Number of replicas has increased for {}. Assigning new region replicas." + LOG.info("Number of replicas has increased for {}. Assigning new region replicas." +
"The previous replica count was {}. The current replica count is {}.", "The previous replica count was {}. The current replica count is {}.",
this.tableName, (currentMaxReplica + 1), configuredReplicaCount); this.tableName, currentMaxReplica + 1, configuredReplicaCount);
regionsOfTable = RegionReplicaUtil.addReplicas(regionsOfTable, regionsOfTable = RegionReplicaUtil.addReplicas(regionsOfTable,
currentMaxReplica + 1, configuredReplicaCount); currentMaxReplica + 1, configuredReplicaCount);
} }
@ -174,25 +158,6 @@ public class EnableTableProcedure
return Flow.HAS_MORE_STATE; return Flow.HAS_MORE_STATE;
} }
/**
* @return Count of replicas found reading hbase:meta Region row or zk if
* asking about the hbase:meta table itself..
*/
private int getReplicaCountInMeta(Connection connection, int regionReplicaCount,
List<RegionInfo> regionsOfTable) throws IOException {
Result r = MetaTableAccessor.getCatalogFamilyRow(connection, regionsOfTable.get(0));
int replicasFound = 0;
for (int i = 1; i < regionReplicaCount; i++) {
// Since we have already added the entries to the META we will be getting only that here
List<Cell> columnCells =
r.getColumnCells(HConstants.CATALOG_FAMILY, CatalogFamilyFormat.getServerColumn(i));
if (!columnCells.isEmpty()) {
replicasFound++;
}
}
return replicasFound;
}
@Override @Override
protected void rollbackState(final MasterProcedureEnv env, final EnableTableState state) protected void rollbackState(final MasterProcedureEnv env, final EnableTableState state)
throws IOException { throws IOException {

View File

@ -24,16 +24,17 @@ import java.util.Collections;
import java.util.List; import java.util.List;
import java.util.Set; import java.util.Set;
import java.util.function.Supplier; import java.util.function.Supplier;
import java.util.stream.Collectors;
import java.util.stream.IntStream;
import org.apache.hadoop.hbase.ConcurrentTableModificationException; import org.apache.hadoop.hbase.ConcurrentTableModificationException;
import org.apache.hadoop.hbase.DoNotRetryIOException; import org.apache.hadoop.hbase.DoNotRetryIOException;
import org.apache.hadoop.hbase.HBaseIOException; import org.apache.hadoop.hbase.HBaseIOException;
import org.apache.hadoop.hbase.HConstants; import org.apache.hadoop.hbase.HConstants;
import org.apache.hadoop.hbase.TableName; import org.apache.hadoop.hbase.TableName;
import org.apache.hadoop.hbase.TableNotDisabledException;
import org.apache.hadoop.hbase.TableNotFoundException; import org.apache.hadoop.hbase.TableNotFoundException;
import org.apache.hadoop.hbase.client.RegionInfo; import org.apache.hadoop.hbase.client.RegionInfo;
import org.apache.hadoop.hbase.client.RegionReplicaUtil;
import org.apache.hadoop.hbase.client.TableDescriptor; import org.apache.hadoop.hbase.client.TableDescriptor;
import org.apache.hadoop.hbase.client.TableState;
import org.apache.hadoop.hbase.master.MasterCoprocessorHost; import org.apache.hadoop.hbase.master.MasterCoprocessorHost;
import org.apache.hadoop.hbase.procedure2.ProcedureStateSerializer; import org.apache.hadoop.hbase.procedure2.ProcedureStateSerializer;
import org.apache.hadoop.hbase.replication.ReplicationException; import org.apache.hadoop.hbase.replication.ReplicationException;
@ -128,6 +129,12 @@ public class ModifyTableProcedure
break; break;
case MODIFY_TABLE_PRE_OPERATION: case MODIFY_TABLE_PRE_OPERATION:
preModify(env, state); preModify(env, state);
setNextState(ModifyTableState.MODIFY_TABLE_CLOSE_EXCESS_REPLICAS);
break;
case MODIFY_TABLE_CLOSE_EXCESS_REPLICAS:
if (isTableEnabled(env)) {
closeExcessReplicasIfNeeded(env);
}
setNextState(ModifyTableState.MODIFY_TABLE_UPDATE_TABLE_DESCRIPTOR); setNextState(ModifyTableState.MODIFY_TABLE_UPDATE_TABLE_DESCRIPTOR);
break; break;
case MODIFY_TABLE_UPDATE_TABLE_DESCRIPTOR: case MODIFY_TABLE_UPDATE_TABLE_DESCRIPTOR:
@ -135,7 +142,7 @@ public class ModifyTableProcedure
setNextState(ModifyTableState.MODIFY_TABLE_REMOVE_REPLICA_COLUMN); setNextState(ModifyTableState.MODIFY_TABLE_REMOVE_REPLICA_COLUMN);
break; break;
case MODIFY_TABLE_REMOVE_REPLICA_COLUMN: case MODIFY_TABLE_REMOVE_REPLICA_COLUMN:
updateReplicaColumnsIfNeeded(env, unmodifiedTableDescriptor, modifiedTableDescriptor); removeReplicaColumnsIfNeeded(env);
setNextState(ModifyTableState.MODIFY_TABLE_POST_OPERATION); setNextState(ModifyTableState.MODIFY_TABLE_POST_OPERATION);
break; break;
case MODIFY_TABLE_POST_OPERATION: case MODIFY_TABLE_POST_OPERATION:
@ -146,6 +153,10 @@ public class ModifyTableProcedure
if (isTableEnabled(env)) { if (isTableEnabled(env)) {
addChildProcedure(new ReopenTableRegionsProcedure(getTableName())); addChildProcedure(new ReopenTableRegionsProcedure(getTableName()));
} }
setNextState(ModifyTableState.MODIFY_TABLE_ASSIGN_NEW_REPLICAS);
break;
case MODIFY_TABLE_ASSIGN_NEW_REPLICAS:
assignNewReplicasIfNeeded(env);
if (deleteColumnFamilyInModify) { if (deleteColumnFamilyInModify) {
setNextState(ModifyTableState.MODIFY_TABLE_DELETE_FS_LAYOUT); setNextState(ModifyTableState.MODIFY_TABLE_DELETE_FS_LAYOUT);
} else { } else {
@ -297,14 +308,6 @@ public class ModifyTableProcedure
env.getMasterServices().getTableDescriptors().get(getTableName()); env.getMasterServices().getTableDescriptors().get(getTableName());
} }
if (env.getMasterServices().getTableStateManager()
.isTableState(getTableName(), TableState.State.ENABLED)) {
if (modifiedTableDescriptor.getRegionReplication() != unmodifiedTableDescriptor
.getRegionReplication()) {
throw new TableNotDisabledException(
"REGION_REPLICATION change is not supported for enabled tables");
}
}
this.deleteColumnFamilyInModify = isDeleteColumnFamily(unmodifiedTableDescriptor, this.deleteColumnFamilyInModify = isDeleteColumnFamily(unmodifiedTableDescriptor,
modifiedTableDescriptor); modifiedTableDescriptor);
if (!unmodifiedTableDescriptor.getRegionServerGroup() if (!unmodifiedTableDescriptor.getRegionServerGroup()
@ -375,17 +378,36 @@ public class ModifyTableProcedure
} }
/** /**
* update replica column families if necessary. * remove replica columns if necessary.
*/ */
private void updateReplicaColumnsIfNeeded(MasterProcedureEnv env, private void removeReplicaColumnsIfNeeded(MasterProcedureEnv env) throws IOException {
TableDescriptor oldTableDescriptor, TableDescriptor newTableDescriptor) throws IOException { final int oldReplicaCount = unmodifiedTableDescriptor.getRegionReplication();
final int oldReplicaCount = oldTableDescriptor.getRegionReplication(); final int newReplicaCount = modifiedTableDescriptor.getRegionReplication();
final int newReplicaCount = newTableDescriptor.getRegionReplication(); if (newReplicaCount >= oldReplicaCount) {
env.getAssignmentManager().getRegionStateStore().updateRegionReplicas(getTableName(), return;
}
env.getAssignmentManager().getRegionStateStore().removeRegionReplicas(getTableName(),
oldReplicaCount, newReplicaCount); oldReplicaCount, newReplicaCount);
if (newReplicaCount > oldReplicaCount && oldReplicaCount <= 1) { env.getAssignmentManager().getRegionStates().getRegionsOfTable(getTableName()).stream()
// The table has been newly enabled for replica. So check if we need to setup .filter(r -> r.getReplicaId() >= newReplicaCount)
// region replication .forEach(env.getAssignmentManager().getRegionStates()::deleteRegion);
}
private void assignNewReplicasIfNeeded(MasterProcedureEnv env) throws IOException {
final int oldReplicaCount = unmodifiedTableDescriptor.getRegionReplication();
final int newReplicaCount = modifiedTableDescriptor.getRegionReplication();
if (newReplicaCount <= oldReplicaCount) {
return;
}
if (isTableEnabled(env)) {
List<RegionInfo> newReplicas = env.getAssignmentManager().getRegionStates()
.getRegionsOfTable(getTableName()).stream().filter(RegionReplicaUtil::isDefaultReplica)
.flatMap(primaryRegion -> IntStream.range(oldReplicaCount, newReplicaCount).mapToObj(
replicaId -> RegionReplicaUtil.getRegionInfoForReplica(primaryRegion, replicaId)))
.collect(Collectors.toList());
addChildProcedure(env.getAssignmentManager().createAssignProcedures(newReplicas));
}
if (oldReplicaCount <= 1) {
try { try {
ServerRegionReplicaUtil.setupRegionReplicaReplication(env.getMasterServices()); ServerRegionReplicaUtil.setupRegionReplicaReplication(env.getMasterServices());
} catch (ReplicationException e) { } catch (ReplicationException e) {
@ -394,6 +416,16 @@ public class ModifyTableProcedure
} }
} }
private void closeExcessReplicasIfNeeded(MasterProcedureEnv env) {
final int oldReplicaCount = unmodifiedTableDescriptor.getRegionReplication();
final int newReplicaCount = modifiedTableDescriptor.getRegionReplication();
if (newReplicaCount >= oldReplicaCount) {
return;
}
addChildProcedure(env.getAssignmentManager()
.createUnassignProceduresForClosingExcessRegionReplicas(getTableName(), newReplicaCount));
}
/** /**
* Action after modifying table. * Action after modifying table.
* @param env MasterProcedureEnv * @param env MasterProcedureEnv

View File

@ -1846,11 +1846,9 @@ public class HBaseTestingUtility extends HBaseZKTestingUtility {
*/ */
public static void setReplicas(Admin admin, TableName table, int replicaCount) public static void setReplicas(Admin admin, TableName table, int replicaCount)
throws IOException, InterruptedException { throws IOException, InterruptedException {
admin.disableTable(table);
TableDescriptor desc = TableDescriptorBuilder.newBuilder(admin.getDescriptor(table)) TableDescriptor desc = TableDescriptorBuilder.newBuilder(admin.getDescriptor(table))
.setRegionReplication(replicaCount).build(); .setRegionReplication(replicaCount).build();
admin.modifyTable(desc); admin.modifyTable(desc);
admin.enableTable(table);
} }
/** /**

View File

@ -263,26 +263,6 @@ public class TestAdmin3 extends TestAdminBase {
assertFalse(ADMIN.tableExists(tableName)); assertFalse(ADMIN.tableExists(tableName));
} }
@Test(expected = TableNotDisabledException.class)
public void testModifyRegionReplicasEnabledTable() throws Exception {
final TableName tableName = TableName.valueOf(name.getMethodName());
TEST_UTIL.createTable(tableName, HConstants.CATALOG_FAMILY).close();
// Modify region replication count
TableDescriptor htd = TableDescriptorBuilder.newBuilder(ADMIN.getDescriptor(tableName))
.setRegionReplication(3).build();
try {
// try to modify the region replication count without disabling the table
ADMIN.modifyTable(htd);
fail("Expected an exception");
} finally {
// Delete the table
ADMIN.disableTable(tableName);
ADMIN.deleteTable(tableName);
assertFalse(ADMIN.tableExists(tableName));
}
}
@Test @Test
public void testDeleteLastColumnFamily() throws Exception { public void testDeleteLastColumnFamily() throws Exception {
final TableName tableName = TableName.valueOf(name.getMethodName()); final TableName tableName = TableName.valueOf(name.getMethodName());

View File

@ -408,7 +408,7 @@ public class TestRegionStateStore {
MetaTableAccessor.addRegionsToMeta(UTIL.getConnection(), regionInfos, 3); MetaTableAccessor.addRegionsToMeta(UTIL.getConnection(), regionInfos, 3);
final RegionStateStore regionStateStore = final RegionStateStore regionStateStore =
UTIL.getHBaseCluster().getMaster().getAssignmentManager().getRegionStateStore(); UTIL.getHBaseCluster().getMaster().getAssignmentManager().getRegionStateStore();
regionStateStore.updateRegionReplicas(tableName, 3, 1); regionStateStore.removeRegionReplicas(tableName, 3, 1);
Get get = new Get(primary.getRegionName()); Get get = new Get(primary.getRegionName());
Result result = meta.get(get); Result result = meta.get(get);
for (int replicaId = 0; replicaId < 3; replicaId++) { for (int replicaId = 0; replicaId < 3; replicaId++) {

View File

@ -371,7 +371,7 @@ public class TestModifyTableProcedure extends TestTableDDLProcedureBase {
long procId = long procId =
procExec.submitProcedure(new ModifyTableProcedure(procExec.getEnvironment(), newTd)); procExec.submitProcedure(new ModifyTableProcedure(procExec.getEnvironment(), newTd));
int lastStep = 3; // failing before MODIFY_TABLE_UPDATE_TABLE_DESCRIPTOR int lastStep = 8; // failing before MODIFY_TABLE_UPDATE_TABLE_DESCRIPTOR
MasterProcedureTestingUtility.testRollbackAndDoubleExecution(procExec, procId, lastStep); MasterProcedureTestingUtility.testRollbackAndDoubleExecution(procExec, procId, lastStep);
// cf2 should not be present // cf2 should not be present
@ -404,7 +404,7 @@ public class TestModifyTableProcedure extends TestTableDDLProcedureBase {
new ModifyTableProcedure(procExec.getEnvironment(), newTd)); new ModifyTableProcedure(procExec.getEnvironment(), newTd));
// Restart the executor and rollback the step twice // Restart the executor and rollback the step twice
int lastStep = 3; // failing before MODIFY_TABLE_UPDATE_TABLE_DESCRIPTOR int lastStep = 8; // failing before MODIFY_TABLE_UPDATE_TABLE_DESCRIPTOR
MasterProcedureTestingUtility.testRollbackAndDoubleExecution(procExec, procId, lastStep); MasterProcedureTestingUtility.testRollbackAndDoubleExecution(procExec, procId, lastStep);
// cf2 should not be present // cf2 should not be present

View File

@ -20,27 +20,33 @@ package org.apache.hadoop.hbase.regionserver;
import static org.junit.Assert.assertEquals; import static org.junit.Assert.assertEquals;
import java.io.IOException; import java.io.IOException;
import java.util.Arrays;
import java.util.List; import java.util.List;
import org.apache.hadoop.conf.Configuration; import org.apache.hadoop.conf.Configuration;
import org.apache.hadoop.hbase.HBaseClassTestRule; import org.apache.hadoop.hbase.HBaseClassTestRule;
import org.apache.hadoop.hbase.HBaseTestingUtility; import org.apache.hadoop.hbase.HBaseTestingUtility;
import org.apache.hadoop.hbase.HConstants; import org.apache.hadoop.hbase.HConstants;
import org.apache.hadoop.hbase.TableName; import org.apache.hadoop.hbase.TableName;
import org.apache.hadoop.hbase.client.Table; import org.apache.hadoop.hbase.TableNameTestRule;
import org.apache.hadoop.hbase.client.TableDescriptor; import org.apache.hadoop.hbase.client.TableDescriptor;
import org.apache.hadoop.hbase.client.TableDescriptorBuilder; import org.apache.hadoop.hbase.client.TableDescriptorBuilder;
import org.apache.hadoop.hbase.testclassification.MediumTests; import org.apache.hadoop.hbase.testclassification.MediumTests;
import org.apache.hadoop.hbase.testclassification.RegionServerTests; import org.apache.hadoop.hbase.testclassification.RegionServerTests;
import org.apache.hadoop.hbase.util.Bytes; import org.apache.hadoop.hbase.util.Bytes;
import org.apache.hadoop.hbase.util.RegionSplitter; import org.apache.hadoop.hbase.util.RegionSplitter;
import org.junit.After;
import org.junit.AfterClass; import org.junit.AfterClass;
import org.junit.BeforeClass; import org.junit.BeforeClass;
import org.junit.ClassRule; import org.junit.ClassRule;
import org.junit.Rule; import org.junit.Rule;
import org.junit.Test; import org.junit.Test;
import org.junit.experimental.categories.Category; import org.junit.experimental.categories.Category;
import org.junit.rules.TestName; import org.junit.runner.RunWith;
import org.junit.runners.Parameterized;
import org.junit.runners.Parameterized.Parameter;
import org.junit.runners.Parameterized.Parameters;
@RunWith(Parameterized.class)
@Category({ RegionServerTests.class, MediumTests.class }) @Category({ RegionServerTests.class, MediumTests.class })
public class TestRegionReplicasWithModifyTable { public class TestRegionReplicasWithModifyTable {
@ -49,22 +55,29 @@ public class TestRegionReplicasWithModifyTable {
HBaseClassTestRule.forClass(TestRegionReplicasWithModifyTable.class); HBaseClassTestRule.forClass(TestRegionReplicasWithModifyTable.class);
private static final int NB_SERVERS = 3; private static final int NB_SERVERS = 3;
private static Table table;
private static final HBaseTestingUtility HTU = new HBaseTestingUtility(); private static final HBaseTestingUtility HTU = new HBaseTestingUtility();
private static final byte[] f = HConstants.CATALOG_FAMILY; private static final byte[] f = HConstants.CATALOG_FAMILY;
@Parameter
public boolean disableBeforeModifying;
@Rule @Rule
public TestName name = new TestName(); public TableNameTestRule name = new TableNameTestRule();
@Parameters
public static List<Object[]> params() {
return Arrays.asList(new Object[] { true }, new Object[] { false });
}
@BeforeClass @BeforeClass
public static void before() throws Exception { public static void before() throws Exception {
HTU.startMiniCluster(NB_SERVERS); HTU.startMiniCluster(NB_SERVERS);
} }
private static void enableReplicationByModification(final TableName tableName, private void enableReplicationByModification(boolean withReplica, int initialReplicaCount,
boolean withReplica, int initialReplicaCount, int enableReplicaCount, int splitCount) int enableReplicaCount, int splitCount) throws IOException, InterruptedException {
throws IOException, InterruptedException { TableName tableName = name.getTableName();
TableDescriptorBuilder builder = TableDescriptorBuilder.newBuilder(tableName); TableDescriptorBuilder builder = TableDescriptorBuilder.newBuilder(tableName);
if (withReplica) { if (withReplica) {
builder.setRegionReplication(initialReplicaCount); builder.setRegionReplication(initialReplicaCount);
@ -72,14 +85,25 @@ public class TestRegionReplicasWithModifyTable {
TableDescriptor htd = builder.build(); TableDescriptor htd = builder.build();
if (splitCount > 0) { if (splitCount > 0) {
byte[][] splits = getSplits(splitCount); byte[][] splits = getSplits(splitCount);
table = HTU.createTable(htd, new byte[][] { f }, splits, HTU.createTable(htd, new byte[][] { f }, splits, new Configuration(HTU.getConfiguration()));
new Configuration(HTU.getConfiguration()));
} else { } else {
table = HTU.createTable(htd, new byte[][] { f }, (byte[][]) null, HTU.createTable(htd, new byte[][] { f }, (byte[][]) null,
new Configuration(HTU.getConfiguration())); new Configuration(HTU.getConfiguration()));
} }
HBaseTestingUtility.setReplicas(HTU.getAdmin(), table.getName(), enableReplicaCount); if (disableBeforeModifying) {
HTU.getAdmin().disableTable(tableName);
}
HBaseTestingUtility.setReplicas(HTU.getAdmin(), tableName, enableReplicaCount);
if (disableBeforeModifying) {
HTU.getAdmin().enableTable(tableName);
}
int expectedRegionCount;
if (splitCount > 0) {
expectedRegionCount = enableReplicaCount * splitCount;
} else {
expectedRegionCount = enableReplicaCount;
}
assertTotalRegions(expectedRegionCount);
} }
private static byte[][] getSplits(int numRegions) { private static byte[][] getSplits(int numRegions) {
@ -91,123 +115,50 @@ public class TestRegionReplicasWithModifyTable {
@AfterClass @AfterClass
public static void afterClass() throws Exception { public static void afterClass() throws Exception {
HRegionServer.TEST_SKIP_REPORTING_TRANSITION = false;
table.close();
HTU.shutdownMiniCluster(); HTU.shutdownMiniCluster();
} }
private HRegionServer getRS() { @After
return HTU.getMiniHBaseCluster().getRegionServer(0); public void tearDown() throws IOException {
} TableName tableName = name.getTableName();
private HRegionServer getSecondaryRS() {
return HTU.getMiniHBaseCluster().getRegionServer(1);
}
private HRegionServer getTertiaryRS() {
return HTU.getMiniHBaseCluster().getRegionServer(2);
}
@Test
public void testRegionReplicasUsingEnableTable() throws Exception {
TableName tableName = null;
try {
tableName = TableName.valueOf(name.getMethodName());
enableReplicationByModification(tableName, false, 0, 3, 0);
List<HRegion> onlineRegions = getRS().getRegions(tableName);
List<HRegion> onlineRegions2 = getSecondaryRS().getRegions(tableName);
List<HRegion> onlineRegions3 = getTertiaryRS().getRegions(tableName);
int totalRegions = onlineRegions.size() + onlineRegions2.size() + onlineRegions3.size();
assertEquals("the number of regions should be more than 1", 3, totalRegions);
} finally {
disableAndDeleteTable(tableName);
}
}
private void disableAndDeleteTable(TableName tableName) throws IOException {
HTU.getAdmin().disableTable(tableName); HTU.getAdmin().disableTable(tableName);
HTU.getAdmin().deleteTable(tableName); HTU.getAdmin().deleteTable(tableName);
} }
private void assertTotalRegions(int expected) {
int actual = HTU.getHBaseCluster().getRegions(name.getTableName()).size();
assertEquals(expected, actual);
}
@Test
public void testRegionReplicasUsingEnableTable() throws Exception {
enableReplicationByModification(false, 0, 3, 0);
}
@Test @Test
public void testRegionReplicasUsingEnableTableForMultipleRegions() throws Exception { public void testRegionReplicasUsingEnableTableForMultipleRegions() throws Exception {
TableName tableName = null; enableReplicationByModification(false, 0, 3, 10);
try {
tableName = TableName.valueOf(name.getMethodName());
enableReplicationByModification(tableName, false, 0, 3, 10);
List<HRegion> onlineRegions = getRS().getRegions(tableName);
List<HRegion> onlineRegions2 = getSecondaryRS().getRegions(tableName);
List<HRegion> onlineRegions3 = getTertiaryRS().getRegions(tableName);
int totalRegions = onlineRegions.size() + onlineRegions2.size() + onlineRegions3.size();
assertEquals("the number of regions should be equal to 30", 30, totalRegions);
} finally {
disableAndDeleteTable(tableName);
}
} }
@Test @Test
public void testRegionReplicasByEnableTableWhenReplicaCountIsIncreased() throws Exception { public void testRegionReplicasByEnableTableWhenReplicaCountIsIncreased() throws Exception {
TableName tableName = null; enableReplicationByModification(true, 2, 3, 0);
try {
tableName = TableName.valueOf(name.getMethodName());
enableReplicationByModification(tableName, true, 2, 3, 0);
List<HRegion> onlineRegions = getRS().getRegions(tableName);
List<HRegion> onlineRegions2 = getSecondaryRS().getRegions(tableName);
List<HRegion> onlineRegions3 = getTertiaryRS().getRegions(tableName);
int totalRegions = onlineRegions.size() + onlineRegions2.size() + onlineRegions3.size();
assertEquals("the number of regions should be 3", 3, totalRegions);
} finally {
disableAndDeleteTable(tableName);
}
} }
@Test @Test
public void testRegionReplicasByEnableTableWhenReplicaCountIsDecreased() throws Exception { public void testRegionReplicasByEnableTableWhenReplicaCountIsDecreased() throws Exception {
TableName tableName = null; enableReplicationByModification(true, 3, 2, 0);
try {
tableName = TableName.valueOf(name.getMethodName());
enableReplicationByModification(tableName, true, 3, 2, 0);
List<HRegion> onlineRegions = getRS().getRegions(tableName);
List<HRegion> onlineRegions2 = getSecondaryRS().getRegions(tableName);
List<HRegion> onlineRegions3 = getTertiaryRS().getRegions(tableName);
int totalRegions = onlineRegions.size() + onlineRegions2.size() + onlineRegions3.size();
assertEquals("the number of regions should be reduced to 2", 2, totalRegions);
} finally {
disableAndDeleteTable(tableName);
}
} }
@Test @Test
public void testRegionReplicasByEnableTableWhenReplicaCountIsDecreasedWithMultipleRegions() public void testRegionReplicasByEnableTableWhenReplicaCountIsDecreasedWithMultipleRegions()
throws Exception { throws Exception {
TableName tableName = null; enableReplicationByModification(true, 3, 2, 20);
try {
tableName = TableName.valueOf(name.getMethodName());
enableReplicationByModification(tableName, true, 3, 2, 20);
List<HRegion> onlineRegions = getRS().getRegions(tableName);
List<HRegion> onlineRegions2 = getSecondaryRS().getRegions(tableName);
List<HRegion> onlineRegions3 = getTertiaryRS().getRegions(tableName);
int totalRegions = onlineRegions.size() + onlineRegions2.size() + onlineRegions3.size();
assertEquals("the number of regions should be reduced to 40", 40, totalRegions);
} finally {
disableAndDeleteTable(tableName);
}
} }
@Test @Test
public void testRegionReplicasByEnableTableWhenReplicaCountIsIncreasedWithmultipleRegions() public void testRegionReplicasByEnableTableWhenReplicaCountIsIncreasedWithmultipleRegions()
throws Exception { throws Exception {
TableName tableName = null; enableReplicationByModification(true, 2, 3, 15);
try {
tableName = TableName.valueOf(name.getMethodName());
enableReplicationByModification(tableName, true, 2, 3, 15);
List<HRegion> onlineRegions = getRS().getRegions(tableName);
List<HRegion> onlineRegions2 = getSecondaryRS().getRegions(tableName);
List<HRegion> onlineRegions3 = getTertiaryRS().getRegions(tableName);
int totalRegions = onlineRegions.size() + onlineRegions2.size() + onlineRegions3.size();
assertEquals("the number of regions should be equal to 45", 3 * 15, totalRegions);
} finally {
disableAndDeleteTable(tableName);
}
} }
} }