public class TestReplicationEmptyWALRecovery extends TestReplicationBase
TestReplicationBase.ReplicationEndpointTest
Modifier and Type | Field and Description |
---|---|
static HBaseClassTestRule |
CLASS_RULE |
(package private) static org.apache.hadoop.hbase.client.RegionInfo |
info |
(package private) org.apache.hadoop.hbase.regionserver.MultiVersionConcurrencyControl |
mvcc |
(package private) NavigableMap<byte[],Integer> |
scopes |
admin, 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 and Description |
---|
TestReplicationEmptyWALRecovery() |
Modifier and Type | Method and Description |
---|---|
private void |
appendEntriesToWal(int numEntries,
org.apache.hadoop.hbase.wal.WAL wal) |
protected org.apache.hadoop.hbase.wal.WALKeyImpl |
getWalKeyImpl() |
private void |
injectEmptyWAL(int numRs,
List<org.apache.hadoop.fs.Path> emptyWalPaths) |
private void |
rollWalsAndWaitForDeque(int numRs) |
void |
setUp() |
void |
testEmptyWALRecovery() |
void |
testReplicationOfEmptyWALFollowedByNonEmptyWAL()
Test empty WAL along with non empty WALs in the same batch.
|
void |
testReplicationOfEmptyWALFollowingNonEmptyWAL()
Test empty WAL along with non empty WALs in the same batch.
|
void |
testReplicationOfEmptyWALSurroundedNonEmptyWAL()
This test make sure we replicate all the enties from the non empty WALs which are surrounding
the empty WALs
|
private void |
verifyNumberOfLogsInQueue(int numQueues,
int numRs) |
private void |
waitForLogAdvance(int numRs)
Waits until there is only one log(the current writing one) in the replication queue
|
addPeer, cleanUp, configureClusters, createTable, isSerialPeer, loadData, loadData, removePeer, restartSourceCluster, restartTargetHBaseCluster, runSimplePutDeleteTest, runSmallBatchTest, setUpBase, setUpBeforeClass, setupConfig, tearDownAfterClass, tearDownBase, waitForReplication, waitForReplication
org.apache.hadoop.hbase.regionserver.MultiVersionConcurrencyControl mvcc
static final org.apache.hadoop.hbase.client.RegionInfo info
NavigableMap<byte[],Integer> scopes
public static final HBaseClassTestRule CLASS_RULE
public TestReplicationEmptyWALRecovery()
public void setUp() throws IOException, InterruptedException
IOException
InterruptedException
private void waitForLogAdvance(int numRs)
numRs
- number of region serversprivate void verifyNumberOfLogsInQueue(int numQueues, int numRs)
public void testEmptyWALRecovery() throws Exception
Exception
public void testReplicationOfEmptyWALFollowingNonEmptyWAL() throws Exception
Exception
- throws any exceptionpublic void testReplicationOfEmptyWALFollowedByNonEmptyWAL() throws Exception
Exception
- throws any exceptionpublic void testReplicationOfEmptyWALSurroundedNonEmptyWAL() throws Exception
Exception
- throws exceptionprivate void injectEmptyWAL(int numRs, List<org.apache.hadoop.fs.Path> emptyWalPaths) throws IOException
IOException
protected org.apache.hadoop.hbase.wal.WALKeyImpl getWalKeyImpl()
private void rollWalsAndWaitForDeque(int numRs) throws IOException
IOException
private void appendEntriesToWal(int numEntries, org.apache.hadoop.hbase.wal.WAL wal) throws IOException
IOException
Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.