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, verifyRowFromMappublic 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 TableSnapshotInputFormatTestBaseprotected byte[] getEndRow()
getEndRow in class TableSnapshotInputFormatTestBasepublic void testInitTableSnapshotMapperJobConfig() throws Exception
Exceptionpublic void testWithMockedMapReduceMultiRegion() throws Exception
testWithMockedMapReduceMultiRegion in class TableSnapshotInputFormatTestBaseExceptionpublic void testWithMapReduceMultiRegion() throws Exception
testWithMapReduceMultiRegion in class TableSnapshotInputFormatTestBaseExceptionpublic void testWithMapReduceAndOfflineHBaseMultiRegion() throws Exception
testWithMapReduceAndOfflineHBaseMultiRegion in class TableSnapshotInputFormatTestBaseExceptionpublic void testRestoreSnapshotDoesNotCreateBackRefLinksInit(org.apache.hadoop.hbase.TableName tableName, String snapshotName, org.apache.hadoop.fs.Path tmpTableDir) throws Exception
testRestoreSnapshotDoesNotCreateBackRefLinksInit in class TableSnapshotInputFormatTestBaseExceptionprotected void testWithMockedMapReduce(HBaseTestingUtility util, String snapshotName, int numRegions, int numSplitsPerRegion, int expectedNumSplits, boolean setLocalityEnabledTo) throws Exception
testWithMockedMapReduce in class TableSnapshotInputFormatTestBaseExceptionprivate void verifyWithMockedMapReduce(org.apache.hadoop.mapred.JobConf job, int numRegions, int expectedNumSplits, byte[] startRow, byte[] stopRow) throws IOException, InterruptedException
IOExceptionInterruptedExceptionprotected 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 TableSnapshotInputFormatTestBaseExceptionpublic 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
Exceptionpublic void testWithMapReduceMultipleMappersPerRegion() throws Exception
ExceptionCopyright © 2007–2021 The Apache Software Foundation. All rights reserved.