Class TableSnapshotInputFormatTestBase
java.lang.Object
org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatTestBase
- Direct Known Subclasses:
TestTableSnapshotInputFormat,TestTableSnapshotInputFormat
-
Field Summary
FieldsModifier and TypeFieldDescriptionprotected static final byte[][]protected org.apache.hadoop.fs.FileSystemprivate static final org.slf4j.Loggerprotected static final intprotected org.apache.hadoop.fs.Pathprotected final HBaseTestingUtil -
Constructor Summary
Constructors -
Method Summary
Modifier and TypeMethodDescriptionprotected static voidcreateTableAndSnapshot(HBaseTestingUtil util, org.apache.hadoop.hbase.TableName tableName, String snapshotName, byte[] startRow, byte[] endRow, int numRegions) protected abstract byte[]protected abstract byte[]voidprivate static voidsetupConf(org.apache.hadoop.conf.Configuration conf) voidvoidabstract voidtestRestoreSnapshotDoesNotCreateBackRefLinksInit(org.apache.hadoop.hbase.TableName tableName, String snapshotName, org.apache.hadoop.fs.Path tmpTableDir) protected voidtestWithMapReduce(HBaseTestingUtil util, String snapshotName, int numRegions, int numSplitsPerRegion, int expectedNumSplits, boolean shutdownCluster) voidprotected abstract voidtestWithMapReduceImpl(HBaseTestingUtil util, org.apache.hadoop.hbase.TableName tableName, String snapshotName, org.apache.hadoop.fs.Path tableDir, int numRegions, int numSplitsPerRegion, int expectedNumSplits, boolean shutdownCluster) voidvoidprotected abstract voidtestWithMockedMapReduce(HBaseTestingUtil util, String snapshotName, int numRegions, int numSplitsPerRegion, int expectedNumSplits, boolean setLocalityEnabledTo) voidvoidprotected static voidverifyRowFromMap(org.apache.hadoop.hbase.io.ImmutableBytesWritable key, org.apache.hadoop.hbase.client.Result result)
-
Field Details
-
LOG
-
UTIL
-
NUM_REGION_SERVERS
- See Also:
-
FAMILIES
-
fs
-
rootDir
-
-
Constructor Details
-
TableSnapshotInputFormatTestBase
public TableSnapshotInputFormatTestBase()
-
-
Method Details
-
setupCluster
- Throws:
Exception
-
tearDownCluster
- Throws:
Exception
-
setupConf
-
testWithMockedMapReduce
protected abstract void testWithMockedMapReduce(HBaseTestingUtil util, String snapshotName, int numRegions, int numSplitsPerRegion, int expectedNumSplits, boolean setLocalityEnabledTo) throws Exception - Throws:
Exception
-
testWithMapReduceImpl
protected abstract void testWithMapReduceImpl(HBaseTestingUtil 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 - Throws:
Exception
-
getStartRow
-
getEndRow
-
testWithMockedMapReduceSingleRegion
- Throws:
Exception
-
testWithMockedMapReduceMultiRegion
- Throws:
Exception
-
testWithMapReduceSingleRegion
- Throws:
Exception
-
testWithMapReduceMultiRegion
- Throws:
Exception
-
testWithMapReduceAndOfflineHBaseMultiRegion
- Throws:
Exception
-
testRestoreSnapshotDoesNotCreateBackRefLinks
- Throws:
Exception
-
testRestoreSnapshotDoesNotCreateBackRefLinksInit
public abstract void testRestoreSnapshotDoesNotCreateBackRefLinksInit(org.apache.hadoop.hbase.TableName tableName, String snapshotName, org.apache.hadoop.fs.Path tmpTableDir) throws Exception - Throws:
Exception
-
testWithMapReduce
protected void testWithMapReduce(HBaseTestingUtil util, String snapshotName, int numRegions, int numSplitsPerRegion, int expectedNumSplits, boolean shutdownCluster) throws Exception - Throws:
Exception
-
verifyRowFromMap
protected static void verifyRowFromMap(org.apache.hadoop.hbase.io.ImmutableBytesWritable key, org.apache.hadoop.hbase.client.Result result) throws IOException - Throws:
IOException
-
createTableAndSnapshot
protected static void createTableAndSnapshot(HBaseTestingUtil util, org.apache.hadoop.hbase.TableName tableName, String snapshotName, byte[] startRow, byte[] endRow, int numRegions) throws Exception - Throws:
Exception
-