Class VerifyReplicationTestBase
java.lang.Object
org.apache.hadoop.hbase.replication.TestReplicationBase
org.apache.hadoop.hbase.replication.VerifyReplicationTestBase
- Direct Known Subclasses:
TestVerifyReplicationRpcConnectionUri
,TestVerifyReplicationZkClusterKey
,TestVerifyReplicationZkConnectionUri
-
Nested Class Summary
Nested classes/interfaces inherited from class org.apache.hadoop.hbase.replication.TestReplicationBase
TestReplicationBase.ReplicationEndpointTest
-
Field Summary
Modifier and TypeFieldDescriptionprivate static org.apache.hadoop.hbase.client.Table
private static final org.slf4j.Logger
org.junit.rules.TestName
private static final String
private static final org.apache.hadoop.hbase.TableName
Fields inherited from class org.apache.hadoop.hbase.replication.TestReplicationBase
CONF_WITH_LOCALFS, CONF1, CONF2, connection1, connection2, famName, hbaseAdmin, htable1, htable2, NB_RETRIES, NB_ROWS_IN_BATCH, NB_ROWS_IN_BIG_BATCH, noRepfamName, NUM_SLAVES1, NUM_SLAVES2, PEER_ID2, replicateCount, replicatedEntries, row, SLEEP_TIME, tableName, UTIL1, UTIL2
-
Constructor Summary
-
Method Summary
Modifier and TypeMethodDescription(package private) static void
checkRestoreTmpDir
(org.apache.hadoop.conf.Configuration conf, String restoreTmpDir, int expectedCount) (package private) static void
(package private) static org.apache.hadoop.mapreduce.Counters
runVerifyReplication
(String[] args, int expectedGoodRows, int expectedBadRows) void
setUp()
static void
static void
void
void
Do a small loading into a table, make sure the data is really the same, then run the VerifyReplication job to check the results.void
void
void
void
void
Load a row into a table, make sure the data is really the same, delete the row, make sure the delete marker is replicated, run verify replication with and without raw to check the results.void
void
Methods inherited from class org.apache.hadoop.hbase.replication.TestReplicationBase
addPeer, cleanUp, configureClusters, createTable, getClusterKey, isSerialPeer, isSyncPeer, loadData, loadData, removePeer, restartSourceCluster, restartTargetHBaseCluster, runSimplePutDeleteTest, runSmallBatchTest, setUpBase, setupConfig, stopAllRegionServers, tearDownBase, waitForReplication, waitForReplication
-
Field Details
-
LOG
-
PEER_ID
- See Also:
-
peerTableName
-
htable3
-
name
-
-
Constructor Details
-
VerifyReplicationTestBase
public VerifyReplicationTestBase()
-
-
Method Details
-
setUp
- Throws:
Exception
-
setUpBeforeClass
- Throws:
Exception
-
runVerifyReplication
static org.apache.hadoop.mapreduce.Counters runVerifyReplication(String[] args, int expectedGoodRows, int expectedBadRows) throws IOException, InterruptedException, ClassNotFoundException -
testVerifyRepJob
Do a small loading into a table, make sure the data is really the same, then run the VerifyReplication job to check the results. Do a second comparison where all the cells are different.- Throws:
Exception
-
testVerifyRepJobWithRawOptions
Load a row into a table, make sure the data is really the same, delete the row, make sure the delete marker is replicated, run verify replication with and without raw to check the results.- Throws:
Exception
-
checkRestoreTmpDir
static void checkRestoreTmpDir(org.apache.hadoop.conf.Configuration conf, String restoreTmpDir, int expectedCount) throws IOException - Throws:
IOException
-
testVerifyRepJobWithQuorumAddress
- Throws:
Exception
-
testVerifyRepJobWithQuorumAddressAndSnapshotSupport
- Throws:
Exception
-
runBatchCopyTest
- Throws:
Exception
-
testVerifyRepJobWithPeerTableName
- Throws:
Exception
-
testVerifyRepJobWithPeerTableNameAndSnapshotSupport
- Throws:
Exception
-
testVerifyReplicationThreadedRecompares
- Throws:
Exception
-
testFailsRemainingComparesAfterShutdown
- Throws:
Exception
-
testVerifyReplicationSynchronousRecompares
- Throws:
Exception
-
tearDownAfterClass
- Throws:
Exception
-