public class TestSimpleRegionNormalizer extends Object
SimpleRegionNormalizer
.Modifier and Type | Field and Description |
---|---|
static HBaseClassTestRule |
CLASS_RULE |
private org.apache.hadoop.conf.Configuration |
conf |
private org.apache.hadoop.hbase.master.MasterServices |
masterServices |
org.junit.rules.TestName |
name |
private org.apache.hadoop.hbase.master.normalizer.SimpleRegionNormalizer |
normalizer |
Constructor and Description |
---|
TestSimpleRegionNormalizer() |
Modifier and Type | Method and Description |
---|---|
void |
before() |
private static org.apache.hadoop.hbase.client.RegionInfo |
createRegionInfo(org.apache.hadoop.hbase.TableName tableName,
byte[] startKey,
byte[] endKey) |
private static List<org.apache.hadoop.hbase.client.RegionInfo> |
createRegionInfos(org.apache.hadoop.hbase.TableName tableName,
byte[][] splitKeys) |
private static List<org.apache.hadoop.hbase.client.RegionInfo> |
createRegionInfos(org.apache.hadoop.hbase.TableName tableName,
int length)
Create a list of
RegionInfo s that represent a region chain of the specified length. |
private static Map<byte[],Integer> |
createRegionSizesMap(List<org.apache.hadoop.hbase.client.RegionInfo> regionInfos,
int... sizes) |
private static long |
generateRegionId() |
private void |
noNormalizationOnTransitioningRegions(org.apache.hadoop.hbase.master.RegionState.State state) |
private void |
setupMocksForNormalizer(Map<byte[],Integer> regionSizes,
List<org.apache.hadoop.hbase.client.RegionInfo> regionInfoList) |
void |
testHonorsMergeEnabled() |
void |
testHonorsMergeMinRegionAge() |
void |
testHonorsMergeMinRegionSize() |
void |
testHonorsMinimumRegionCount() |
void |
testHonorsSplitEnabled() |
void |
testMergeOfSecondSmallestRegions() |
void |
testMergeOfSmallNonAdjacentRegions() |
void |
testMergeOfSmallRegions() |
void |
testNoNormalizationForMetaTable() |
void |
testNoNormalizationIfTooFewRegions() |
void |
testNoNormalizationOnMergedRegions() |
void |
testNoNormalizationOnMergingNewRegions() |
void |
testNoNormalizationOnMergingRegions() |
void |
testNoNormalizationOnNormalizedCluster() |
void |
testNoNormalizationOnSplitRegions() |
void |
testNoNormalizationOnSplittingNewRegions() |
void |
testNoNormalizationOnSplittingRegions() |
void |
testNormalizerCannotMergeNonAdjacentRegions() |
void |
testSplitOfLargeRegion() |
void |
testSplitWithTargetRegionCount() |
void |
testSplitWithTargetRegionSize() |
public static final HBaseClassTestRule CLASS_RULE
private org.apache.hadoop.conf.Configuration conf
private org.apache.hadoop.hbase.master.normalizer.SimpleRegionNormalizer normalizer
private org.apache.hadoop.hbase.master.MasterServices masterServices
public org.junit.rules.TestName name
public TestSimpleRegionNormalizer()
public void before()
public void testNoNormalizationForMetaTable()
public void testNoNormalizationIfTooFewRegions()
public void testNoNormalizationOnNormalizedCluster()
private void noNormalizationOnTransitioningRegions(org.apache.hadoop.hbase.master.RegionState.State state)
public void testNoNormalizationOnMergingNewRegions()
public void testNoNormalizationOnMergingRegions()
public void testNoNormalizationOnMergedRegions()
public void testNoNormalizationOnSplittingNewRegions()
public void testNoNormalizationOnSplittingRegions()
public void testNoNormalizationOnSplitRegions()
public void testMergeOfSmallRegions()
public void testMergeOfSecondSmallestRegions()
public void testMergeOfSmallNonAdjacentRegions()
public void testSplitOfLargeRegion()
public void testSplitWithTargetRegionCount() throws Exception
Exception
public void testSplitWithTargetRegionSize() throws Exception
Exception
public void testHonorsSplitEnabled()
public void testHonorsMergeEnabled()
public void testHonorsMinimumRegionCount()
public void testHonorsMergeMinRegionAge()
public void testHonorsMergeMinRegionSize()
public void testNormalizerCannotMergeNonAdjacentRegions()
private void setupMocksForNormalizer(Map<byte[],Integer> regionSizes, List<org.apache.hadoop.hbase.client.RegionInfo> regionInfoList)
private static List<org.apache.hadoop.hbase.client.RegionInfo> createRegionInfos(org.apache.hadoop.hbase.TableName tableName, int length)
RegionInfo
s that represent a region chain of the specified length.private static org.apache.hadoop.hbase.client.RegionInfo createRegionInfo(org.apache.hadoop.hbase.TableName tableName, byte[] startKey, byte[] endKey)
private static long generateRegionId()
private static List<org.apache.hadoop.hbase.client.RegionInfo> createRegionInfos(org.apache.hadoop.hbase.TableName tableName, byte[][] splitKeys)
private static Map<byte[],Integer> createRegionSizesMap(List<org.apache.hadoop.hbase.client.RegionInfo> regionInfos, int... sizes)
Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.