public class TestAdmin1 extends Object
Modifier and Type | Field and Description |
---|---|
private org.apache.hadoop.hbase.client.Admin |
admin |
static HBaseClassTestRule |
CLASS_RULE |
private static org.slf4j.Logger |
LOG |
org.junit.rules.TestName |
name |
private static HBaseTestingUtility |
TEST_UTIL |
Constructor and Description |
---|
TestAdmin1() |
Modifier and Type | Method and Description |
---|---|
private org.apache.hadoop.hbase.client.TableState.State |
getStateFromMeta(org.apache.hadoop.hbase.TableName table) |
void |
setUp() |
static void |
setUpBeforeClass() |
(package private) void |
splitTest(byte[] splitPoint,
byte[][] familyNames,
int[] rowCounts,
int numVersions,
int blockSize,
boolean async) |
void |
tearDown() |
static void |
tearDownAfterClass() |
void |
testCompactionTimestamps() |
void |
testCreateTable() |
void |
testCreateTableNumberOfRegions() |
void |
testCreateTableWithEmptyRowInTheSplitKeys() |
void |
testCreateTableWithOnlyEmptyStartRow() |
void |
testCreateTableWithRegions() |
void |
testDeleteEditUnknownColumnFamilyAndOrTable() |
void |
testDeleteLastColumnFamily() |
void |
testDisableAndEnableTable() |
void |
testDisableAndEnableTables() |
void |
testEnableDisableAddColumnDeleteColumn() |
void |
testEnableTableRetainAssignment()
Test retain assignment on enableTable.
|
void |
testForceSplit()
Tests forcing split from client and having scanners successfully ride over split.
|
void |
testForceSplitMultiFamily()
Multi-family scenario.
|
void |
testGetTableDescriptor() |
void |
testHColumnValidName() |
void |
testHFileReplication() |
void |
testInvalidHColumnDescriptor() |
void |
testMergeRegions() |
void |
testModifyRegionReplicasEnabledTable() |
void |
testModifyTableOnTableWithRegionReplicas() |
void |
testOnlineChangeTableSchema()
Verify schema modification takes.
|
void |
testReadOnlyTableModify()
Verify schema change for read only table
|
void |
testSplitAndMergeWithReplicaTable() |
void |
testSplitFlushCompactUnknownTable() |
void |
testSplitShouldNotHappenIfSplitIsDisabledForTable() |
void |
testTableAvailableWithRandomSplitKeys() |
void |
testTableExist() |
void |
testTruncateTable() |
private void |
testTruncateTable(org.apache.hadoop.hbase.TableName tableName,
boolean preserveSplits) |
void |
testTruncateTablePreservingSplits() |
protected void |
verifyRoundRobinDistribution(org.apache.hadoop.hbase.client.ClusterConnection c,
org.apache.hadoop.hbase.client.RegionLocator regionLocator,
int expectedRegions) |
public static final HBaseClassTestRule CLASS_RULE
private static final org.slf4j.Logger LOG
private static final HBaseTestingUtility TEST_UTIL
private org.apache.hadoop.hbase.client.Admin admin
public org.junit.rules.TestName name
public TestAdmin1()
public static void setUpBeforeClass() throws Exception
Exception
public static void tearDownAfterClass() throws Exception
Exception
public void testSplitFlushCompactUnknownTable() throws InterruptedException
InterruptedException
public void testDeleteEditUnknownColumnFamilyAndOrTable() throws IOException
IOException
public void testDisableAndEnableTable() throws IOException
IOException
private org.apache.hadoop.hbase.client.TableState.State getStateFromMeta(org.apache.hadoop.hbase.TableName table) throws IOException
IOException
public void testDisableAndEnableTables() throws IOException
IOException
public void testCreateTable() throws IOException
IOException
public void testTruncateTable() throws IOException
IOException
public void testTruncateTablePreservingSplits() throws IOException
IOException
private void testTruncateTable(org.apache.hadoop.hbase.TableName tableName, boolean preserveSplits) throws IOException
IOException
public void testGetTableDescriptor() throws IOException
IOException
public void testCompactionTimestamps() throws Exception
Exception
public void testHColumnValidName()
public void testReadOnlyTableModify() throws IOException, InterruptedException
IOException
InterruptedException
public void testModifyRegionReplicasEnabledTable() throws Exception
Exception
public void testOnlineChangeTableSchema() throws IOException, InterruptedException
IOException
InterruptedException
protected void verifyRoundRobinDistribution(org.apache.hadoop.hbase.client.ClusterConnection c, org.apache.hadoop.hbase.client.RegionLocator regionLocator, int expectedRegions) throws IOException
IOException
public void testCreateTableNumberOfRegions() throws IOException, InterruptedException
IOException
InterruptedException
public void testCreateTableWithRegions() throws IOException, InterruptedException
IOException
InterruptedException
public void testTableAvailableWithRandomSplitKeys() throws Exception
Exception
public void testCreateTableWithOnlyEmptyStartRow() throws IOException
IOException
public void testCreateTableWithEmptyRowInTheSplitKeys() throws IOException
IOException
public void testTableExist() throws IOException
IOException
public void testForceSplit() throws Exception
Exception
IOException
public void testEnableTableRetainAssignment() throws IOException
IOException
public void testForceSplitMultiFamily() throws Exception
Exception
IOException
void splitTest(byte[] splitPoint, byte[][] familyNames, int[] rowCounts, int numVersions, int blockSize, boolean async) throws Exception
Exception
public void testSplitAndMergeWithReplicaTable() throws Exception
Exception
public void testInvalidHColumnDescriptor() throws IOException
IOException
public void testEnableDisableAddColumnDeleteColumn() throws Exception
Exception
public void testDeleteLastColumnFamily() throws Exception
Exception
public void testHFileReplication() throws Exception
Exception
public void testMergeRegions() throws Exception
Exception
public void testSplitShouldNotHappenIfSplitIsDisabledForTable() throws Exception
Exception
public void testModifyTableOnTableWithRegionReplicas() throws Exception
Exception
Copyright © 2007–2019 The Apache Software Foundation. All rights reserved.