public class TestTableSnapshotInputFormat extends TableSnapshotInputFormatTestBase
Modifier and Type | Class and Description |
---|---|
(package private) static class |
TestTableSnapshotInputFormat.TestTableSnapshotMapper |
static class |
TestTableSnapshotInputFormat.TestTableSnapshotReducer |
Modifier and Type | Field and Description |
---|---|
private static byte[] |
aaa |
private static byte[] |
after_zzz |
static HBaseClassTestRule |
CLASS_RULE |
private static String |
COLUMNS |
org.junit.rules.TestName |
name |
FAMILIES, fs, NUM_REGION_SERVERS, rootDir, UTIL
Constructor and Description |
---|
TestTableSnapshotInputFormat() |
Modifier and Type | Method and Description |
---|---|
static void |
doTestWithMapReduce(HBaseTestingUtility util,
org.apache.hadoop.hbase.TableName tableName,
String snapshotName,
byte[] startRow,
byte[] endRow,
org.apache.hadoop.fs.Path tableDir,
int numRegions,
int numSplitsPerRegion,
int expectedNumSplits,
boolean shutdownCluster) |
protected byte[] |
getEndRow() |
protected byte[] |
getStartRow() |
void |
testInitTableSnapshotMapperJobConfig() |
void |
testRestoreSnapshotDoesNotCreateBackRefLinksInit(org.apache.hadoop.hbase.TableName tableName,
String snapshotName,
org.apache.hadoop.fs.Path tmpTableDir) |
void |
testWithMapReduceAndOfflineHBaseMultiRegion() |
protected void |
testWithMapReduceImpl(HBaseTestingUtility util,
org.apache.hadoop.hbase.TableName tableName,
String snapshotName,
org.apache.hadoop.fs.Path tableDir,
int numRegions,
int numSplitsPerRegion,
int expectedNumSplits,
boolean shutdownCluster) |
void |
testWithMapReduceMultipleMappersPerRegion() |
void |
testWithMapReduceMultiRegion() |
protected void |
testWithMockedMapReduce(HBaseTestingUtility util,
String snapshotName,
int numRegions,
int numSplitsPerRegion,
int expectedNumSplits,
boolean setLocalityEnabledTo) |
void |
testWithMockedMapReduceMultiRegion() |
private void |
verifyWithMockedMapReduce(org.apache.hadoop.mapred.JobConf job,
int numRegions,
int expectedNumSplits,
byte[] startRow,
byte[] stopRow) |
createTableAndSnapshot, setupCluster, tearDownCluster, testRestoreSnapshotDoesNotCreateBackRefLinks, testWithMapReduce, testWithMapReduceSingleRegion, testWithMockedMapReduceSingleRegion, verifyRowFromMap
public static final HBaseClassTestRule CLASS_RULE
private static final byte[] aaa
private static final byte[] after_zzz
public org.junit.rules.TestName name
public TestTableSnapshotInputFormat()
protected byte[] getStartRow()
getStartRow
in class TableSnapshotInputFormatTestBase
protected byte[] getEndRow()
getEndRow
in class TableSnapshotInputFormatTestBase
public void testInitTableSnapshotMapperJobConfig() throws Exception
Exception
public void testWithMockedMapReduceMultiRegion() throws Exception
testWithMockedMapReduceMultiRegion
in class TableSnapshotInputFormatTestBase
Exception
public void testWithMapReduceMultiRegion() throws Exception
testWithMapReduceMultiRegion
in class TableSnapshotInputFormatTestBase
Exception
public void testWithMapReduceAndOfflineHBaseMultiRegion() throws Exception
testWithMapReduceAndOfflineHBaseMultiRegion
in class TableSnapshotInputFormatTestBase
Exception
public void testRestoreSnapshotDoesNotCreateBackRefLinksInit(org.apache.hadoop.hbase.TableName tableName, String snapshotName, org.apache.hadoop.fs.Path tmpTableDir) throws Exception
testRestoreSnapshotDoesNotCreateBackRefLinksInit
in class TableSnapshotInputFormatTestBase
Exception
protected void testWithMockedMapReduce(HBaseTestingUtility util, String snapshotName, int numRegions, int numSplitsPerRegion, int expectedNumSplits, boolean setLocalityEnabledTo) throws Exception
testWithMockedMapReduce
in class TableSnapshotInputFormatTestBase
Exception
private void verifyWithMockedMapReduce(org.apache.hadoop.mapred.JobConf job, int numRegions, int expectedNumSplits, byte[] startRow, byte[] stopRow) throws IOException, InterruptedException
IOException
InterruptedException
protected void testWithMapReduceImpl(HBaseTestingUtility util, org.apache.hadoop.hbase.TableName tableName, String snapshotName, org.apache.hadoop.fs.Path tableDir, int numRegions, int numSplitsPerRegion, int expectedNumSplits, boolean shutdownCluster) throws Exception
testWithMapReduceImpl
in class TableSnapshotInputFormatTestBase
Exception
public static void doTestWithMapReduce(HBaseTestingUtility util, org.apache.hadoop.hbase.TableName tableName, String snapshotName, byte[] startRow, byte[] endRow, org.apache.hadoop.fs.Path tableDir, int numRegions, int numSplitsPerRegion, int expectedNumSplits, boolean shutdownCluster) throws Exception
Exception
public void testWithMapReduceMultipleMappersPerRegion() throws Exception
Exception
Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.