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, noRepfamName
admin, CONF_WITH_LOCALFS, conf1, conf2, hbaseAdmin, htable1, htable2, NB_RETRIES, NB_ROWS_IN_BATCH, NB_ROWS_IN_BIG_BATCH, row, scopes, seperateOldWALs, 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
cleanUp, loadData, params, runSimplePutDeleteTest, runSmallBatchTest, tearDownAfterClass, waitForReplication
public static final HBaseClassTestRule CLASS_RULE
private static final org.slf4j.Logger LOG
public TestReplicationSyncUpToolWithBulkLoadedData()
public static void setUpBeforeClass() throws Exception
Exception
public void testSyncUpTool() throws Exception
TestReplicationSyncUpTool
testSyncUpTool
in class TestReplicationSyncUpTool
Exception
private void mimicSyncUpAfterBulkLoad(Iterator<String> randomHFileRangeListIterator) throws Exception
Exception
private void loadAndReplicateHFiles(boolean verifyReplicationOnSlave, Iterator<String> randomHFileRangeListIterator) throws Exception
Exception
private void loadAndValidateHFileReplication(String testName, byte[] row, byte[] fam, org.apache.hadoop.hbase.client.Table source, byte[][][] hfileRanges, int numOfRows) throws Exception
Exception
private void wait(org.apache.hadoop.hbase.client.Table target, int expectedCount, String msg) throws IOException, InterruptedException
IOException
InterruptedException
Copyright © 2007–2019 The Apache Software Foundation. All rights reserved.