001/* 002 * Licensed to the Apache Software Foundation (ASF) under one 003 * or more contributor license agreements. See the NOTICE file 004 * distributed with this work for additional information 005 * regarding copyright ownership. The ASF licenses this file 006 * to you under the Apache License, Version 2.0 (the 007 * "License"); you may not use this file except in compliance 008 * with the License. You may obtain a copy of the License at 009 * 010 * http://www.apache.org/licenses/LICENSE-2.0 011 * 012 * Unless required by applicable law or agreed to in writing, software 013 * distributed under the License is distributed on an "AS IS" BASIS, 014 * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. 015 * See the License for the specific language governing permissions and 016 * limitations under the License. 017 */ 018package org.apache.hadoop.hbase.master.balancer; 019 020import static org.apache.hadoop.hbase.master.balancer.CandidateGeneratorTestUtil.isTableIsolated; 021import static org.apache.hadoop.hbase.master.balancer.CandidateGeneratorTestUtil.runBalancerToExhaustion; 022 023import java.util.ArrayList; 024import java.util.HashMap; 025import java.util.List; 026import java.util.Map; 027import java.util.Random; 028import java.util.Set; 029import org.apache.hadoop.conf.Configuration; 030import org.apache.hadoop.hbase.HBaseClassTestRule; 031import org.apache.hadoop.hbase.ServerName; 032import org.apache.hadoop.hbase.TableName; 033import org.apache.hadoop.hbase.client.RegionInfo; 034import org.apache.hadoop.hbase.client.RegionInfoBuilder; 035import org.apache.hadoop.hbase.testclassification.MasterTests; 036import org.apache.hadoop.hbase.testclassification.MediumTests; 037import org.junit.BeforeClass; 038import org.junit.ClassRule; 039import org.junit.Test; 040import org.junit.experimental.categories.Category; 041import org.slf4j.Logger; 042import org.slf4j.LoggerFactory; 043 044@Category({ MediumTests.class, MasterTests.class }) 045public class TestLargeClusterBalancingTableIsolationAndReplicaDistribution { 046 047 @ClassRule 048 public static final HBaseClassTestRule CLASS_RULE = HBaseClassTestRule 049 .forClass(TestLargeClusterBalancingTableIsolationAndReplicaDistribution.class); 050 051 private static final Logger LOG = 052 LoggerFactory.getLogger(TestLargeClusterBalancingTableIsolationAndReplicaDistribution.class); 053 private static final TableName SYSTEM_TABLE_NAME = TableName.valueOf("hbase:system"); 054 private static final TableName NON_ISOLATED_TABLE_NAME = TableName.valueOf("userTable"); 055 056 private static final int NUM_SERVERS = 500; 057 private static final int NUM_REGIONS = 2_500; 058 private static final int NUM_REPLICAS = 3; 059 060 private static final ServerName[] servers = new ServerName[NUM_SERVERS]; 061 private static final Map<ServerName, List<RegionInfo>> serverToRegions = new HashMap<>(); 062 063 @BeforeClass 064 public static void setup() { 065 // Initialize servers 066 for (int i = 0; i < NUM_SERVERS; i++) { 067 servers[i] = ServerName.valueOf("server" + i, i, System.currentTimeMillis()); 068 serverToRegions.put(servers[i], new ArrayList<>()); 069 } 070 071 // Create primary regions and their replicas 072 for (int i = 0; i < NUM_REGIONS; i++) { 073 TableName tableName; 074 if (i < 1) { 075 tableName = TableName.META_TABLE_NAME; 076 } else if (i < 10) { 077 tableName = SYSTEM_TABLE_NAME; 078 } else { 079 tableName = NON_ISOLATED_TABLE_NAME; 080 } 081 082 // Define startKey and endKey for the region 083 byte[] startKey = new byte[1]; 084 startKey[0] = (byte) i; 085 byte[] endKey = new byte[1]; 086 endKey[0] = (byte) (i + 1); 087 088 Random random = new Random(); 089 // Create 3 replicas for each primary region 090 for (int replicaId = 0; replicaId < NUM_REPLICAS; replicaId++) { 091 RegionInfo regionInfo = RegionInfoBuilder.newBuilder(tableName).setStartKey(startKey) 092 .setEndKey(endKey).setReplicaId(replicaId).build(); 093 // Assign region to random server 094 int randomServer = random.nextInt(servers.length); 095 serverToRegions.get(servers[randomServer]).add(regionInfo); 096 } 097 } 098 } 099 100 @Test 101 public void testTableIsolationAndReplicaDistribution() { 102 Configuration conf = new Configuration(false); 103 conf.setBoolean(BalancerConditionals.ISOLATE_META_TABLE_KEY, true); 104 conf.setBoolean(BalancerConditionals.ISOLATE_SYSTEM_TABLES_KEY, true); 105 DistributeReplicasTestConditional.enableConditionalReplicaDistributionForTest(conf); 106 107 runBalancerToExhaustion(conf, serverToRegions, Set.of(this::isMetaTableIsolated, 108 this::isSystemTableIsolated, CandidateGeneratorTestUtil::areAllReplicasDistributed), 10.0f, 109 60_000); 110 LOG.info("Meta table regions are successfully isolated, " 111 + "and region replicas are appropriately distributed."); 112 } 113 114 /** 115 * Validates whether all meta table regions are isolated. 116 */ 117 private boolean isMetaTableIsolated(BalancerClusterState cluster) { 118 return isTableIsolated(cluster, TableName.META_TABLE_NAME, "Meta"); 119 } 120 121 /** 122 * Validates whether all meta table regions are isolated. 123 */ 124 private boolean isSystemTableIsolated(BalancerClusterState cluster) { 125 return isTableIsolated(cluster, SYSTEM_TABLE_NAME, "System"); 126 } 127}