public class TestTableSnapshotInputFormat extends TableSnapshotInputFormatTestBase
Modifier and Type | Class and Description |
---|---|
static class |
TestTableSnapshotInputFormat.TestTableSnapshotCounters |
static class |
TestTableSnapshotInputFormat.TestTableSnapshotMapper |
static class |
TestTableSnapshotInputFormat.TestTableSnapshotReducer |
Modifier and Type | Field and Description |
---|---|
private static byte[] |
bbb |
private static byte[] |
bbc |
static HBaseClassTestRule |
CLASS_RULE |
private static org.slf4j.Logger |
LOG |
org.junit.rules.TestName |
name |
private static byte[] |
yya |
private static byte[] |
yyy |
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() |
private org.apache.hadoop.hbase.client.Scan |
serializeAndReturn(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.hbase.client.Scan s)
Serializes and deserializes the given scan in the same manner that TableSnapshotInputFormat
does.
|
void |
testCleanRestoreDir() |
void |
testGetBestLocations() |
void |
testInitTableSnapshotMapperJobConfig() |
void |
testNoDuplicateResultsWhenSplitting() |
void |
testRestoreSnapshotDoesNotCreateBackRefLinksInit(org.apache.hadoop.hbase.TableName tableName,
String snapshotName,
org.apache.hadoop.fs.Path tmpTableDir) |
void |
testScanLimit() |
void |
testScannerReadTypeConfiguration() |
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 |
testWithMockedMapReduce(HBaseTestingUtility util,
String snapshotName,
int numRegions,
int numSplitsPerRegion,
int expectedNumSplits,
boolean setLocalityEnabledTo) |
void |
testWithMockedMapReduceSingleRegionByRegionLocation() |
void |
testWithMockedMapReduceWithNoStartRowStopRow() |
void |
testWithMockedMapReduceWithSplitsPerRegion() |
private void |
verifyWithMockedMapReduce(org.apache.hadoop.mapreduce.Job job,
int numRegions,
int expectedNumSplits,
byte[] startRow,
byte[] stopRow) |
createTableAndSnapshot, setupCluster, tearDownCluster, testRestoreSnapshotDoesNotCreateBackRefLinks, testWithMapReduce, testWithMapReduceAndOfflineHBaseMultiRegion, testWithMapReduceMultiRegion, testWithMapReduceSingleRegion, testWithMockedMapReduceMultiRegion, testWithMockedMapReduceSingleRegion, verifyRowFromMap
public static final HBaseClassTestRule CLASS_RULE
private static final org.slf4j.Logger LOG
private static final byte[] bbb
private static final byte[] yyy
private static final byte[] bbc
private static final byte[] yya
public org.junit.rules.TestName name
public TestTableSnapshotInputFormat()
protected byte[] getStartRow()
getStartRow
in class TableSnapshotInputFormatTestBase
protected byte[] getEndRow()
getEndRow
in class TableSnapshotInputFormatTestBase
public void testGetBestLocations() throws IOException
IOException
public void testInitTableSnapshotMapperJobConfig() throws Exception
Exception
public void testWithMockedMapReduceSingleRegionByRegionLocation() throws Exception
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
public void testWithMockedMapReduce(HBaseTestingUtility util, String snapshotName, int numRegions, int numSplitsPerRegion, int expectedNumSplits, boolean setLocalityEnabledTo) throws Exception
testWithMockedMapReduce
in class TableSnapshotInputFormatTestBase
Exception
public void testWithMockedMapReduceWithSplitsPerRegion() throws Exception
Exception
public void testWithMockedMapReduceWithNoStartRowStopRow() throws Exception
Exception
public void testScanLimit() throws Exception
Exception
public void testNoDuplicateResultsWhenSplitting() throws Exception
Exception
public void testScannerReadTypeConfiguration() throws IOException
IOException
private org.apache.hadoop.hbase.client.Scan serializeAndReturn(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.client.Scan s) throws IOException
IOException
private void verifyWithMockedMapReduce(org.apache.hadoop.mapreduce.Job 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
public void testCleanRestoreDir() throws Exception
Exception
Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.