public class TestReplicationSyncUpToolWithBulkLoadedData extends TestReplicationSyncUpTool
| Modifier and Type | Field and Description | 
|---|---|
| static HBaseClassTestRule | CLASS_RULE | 
| private static org.slf4j.Logger | LOG | 
famName, ht1Source, ht1TargetAtPeer1, ht2Source, ht2TargetAtPeer1, noRepfamNameadmin, CONF_WITH_LOCALFS, conf1, conf2, hbaseAdmin, htable1, htable2, NB_RETRIES, NB_ROWS_IN_BATCH, NB_ROWS_IN_BIG_BATCH, PEER_ID2, row, scopes, SLEEP_TIME, tableName, utility1, utility2, zkw1, zkw2| Constructor and Description | 
|---|
| TestReplicationSyncUpToolWithBulkLoadedData() | 
| Modifier and Type | Method and Description | 
|---|---|
| private void | loadAndReplicateHFiles(boolean verifyReplicationOnSlave,
                      Iterator<String> randomHFileRangeListIterator) | 
| private void | loadAndValidateHFileReplication(String testName,
                               byte[] row,
                               byte[] fam,
                               org.apache.hadoop.hbase.client.Table source,
                               byte[][][] hfileRanges,
                               int numOfRows) | 
| private void | mimicSyncUpAfterBulkLoad(Iterator<String> randomHFileRangeListIterator) | 
| static void | setUpBeforeClass() | 
| void | testSyncUpTool()Add a row to a table in each cluster, check it's replicated, delete it,
 check's gone Also check the puts and deletes are not replicated back to
 the originating cluster. | 
| private void | wait(org.apache.hadoop.hbase.client.Table target,
    int expectedCount,
    String msg) | 
setUp, setupReplication, syncUp, tearDownBasecleanUp, isSerialPeer, loadData, loadData, runSimplePutDeleteTest, runSmallBatchTest, setUpBase, tearDownAfterClass, waitForReplicationpublic static final HBaseClassTestRule CLASS_RULE
private static final org.slf4j.Logger LOG
public TestReplicationSyncUpToolWithBulkLoadedData()
public static void setUpBeforeClass() throws Exception
Exceptionpublic void testSyncUpTool() throws Exception
TestReplicationSyncUpTooltestSyncUpTool in class TestReplicationSyncUpToolExceptionprivate void mimicSyncUpAfterBulkLoad(Iterator<String> randomHFileRangeListIterator) throws Exception
Exceptionprivate void loadAndReplicateHFiles(boolean verifyReplicationOnSlave, Iterator<String> randomHFileRangeListIterator) throws Exception
Exceptionprivate void loadAndValidateHFileReplication(String testName, byte[] row, byte[] fam, org.apache.hadoop.hbase.client.Table source, byte[][][] hfileRanges, int numOfRows) throws Exception
Exceptionprivate void wait(org.apache.hadoop.hbase.client.Table target, int expectedCount, String msg) throws IOException, InterruptedException
IOExceptionInterruptedExceptionCopyright © 2007–2020 The Apache Software Foundation. All rights reserved.