public abstract class TableSnapshotInputFormatTestBase extends Object
Modifier and Type | Field and Description |
---|---|
protected static byte[][] |
FAMILIES |
protected org.apache.hadoop.fs.FileSystem |
fs |
private static org.slf4j.Logger |
LOG |
protected static int |
NUM_REGION_SERVERS |
protected org.apache.hadoop.fs.Path |
rootDir |
protected HBaseTestingUtility |
UTIL |
Constructor and Description |
---|
TableSnapshotInputFormatTestBase() |
Modifier and Type | Method and Description |
---|---|
protected static void |
createTableAndSnapshot(HBaseTestingUtility util,
org.apache.hadoop.hbase.TableName tableName,
String snapshotName,
byte[] startRow,
byte[] endRow,
int numRegions) |
protected abstract byte[] |
getEndRow() |
protected abstract byte[] |
getStartRow() |
void |
setupCluster() |
private static void |
setupConf(org.apache.hadoop.conf.Configuration conf) |
void |
tearDownCluster() |
void |
testRestoreSnapshotDoesNotCreateBackRefLinks() |
abstract void |
testRestoreSnapshotDoesNotCreateBackRefLinksInit(org.apache.hadoop.hbase.TableName tableName,
String snapshotName,
org.apache.hadoop.fs.Path tmpTableDir) |
protected void |
testWithMapReduce(HBaseTestingUtility util,
String snapshotName,
int numRegions,
int numSplitsPerRegion,
int expectedNumSplits,
boolean shutdownCluster) |
void |
testWithMapReduceAndOfflineHBaseMultiRegion() |
protected abstract 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 |
testWithMapReduceMultiRegion() |
void |
testWithMapReduceSingleRegion() |
protected abstract void |
testWithMockedMapReduce(HBaseTestingUtility util,
String snapshotName,
int numRegions,
int numSplitsPerRegion,
int expectedNumSplits,
boolean setLocalityEnabledTo) |
void |
testWithMockedMapReduceMultiRegion() |
void |
testWithMockedMapReduceSingleRegion() |
protected static void |
verifyRowFromMap(org.apache.hadoop.hbase.io.ImmutableBytesWritable key,
org.apache.hadoop.hbase.client.Result result) |
private static final org.slf4j.Logger LOG
protected final HBaseTestingUtility UTIL
protected static final int NUM_REGION_SERVERS
protected static final byte[][] FAMILIES
protected org.apache.hadoop.fs.FileSystem fs
protected org.apache.hadoop.fs.Path rootDir
public TableSnapshotInputFormatTestBase()
public void setupCluster() throws Exception
Exception
public void tearDownCluster() throws Exception
Exception
private static void setupConf(org.apache.hadoop.conf.Configuration conf)
protected abstract void testWithMockedMapReduce(HBaseTestingUtility util, String snapshotName, int numRegions, int numSplitsPerRegion, int expectedNumSplits, boolean setLocalityEnabledTo) throws Exception
Exception
protected abstract 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
Exception
protected abstract byte[] getStartRow()
protected abstract byte[] getEndRow()
public void testWithMockedMapReduceSingleRegion() throws Exception
Exception
public void testWithMockedMapReduceMultiRegion() throws Exception
Exception
public void testWithMapReduceSingleRegion() throws Exception
Exception
public void testWithMapReduceMultiRegion() throws Exception
Exception
public void testWithMapReduceAndOfflineHBaseMultiRegion() throws Exception
Exception
public void testRestoreSnapshotDoesNotCreateBackRefLinks() throws Exception
Exception
public abstract void testRestoreSnapshotDoesNotCreateBackRefLinksInit(org.apache.hadoop.hbase.TableName tableName, String snapshotName, org.apache.hadoop.fs.Path tmpTableDir) throws Exception
Exception
protected void testWithMapReduce(HBaseTestingUtility util, String snapshotName, int numRegions, int numSplitsPerRegion, int expectedNumSplits, boolean shutdownCluster) throws Exception
Exception
protected static void verifyRowFromMap(org.apache.hadoop.hbase.io.ImmutableBytesWritable key, org.apache.hadoop.hbase.client.Result result) throws IOException
IOException
protected static void createTableAndSnapshot(HBaseTestingUtility util, org.apache.hadoop.hbase.TableName tableName, String snapshotName, byte[] startRow, byte[] endRow, int numRegions) throws Exception
Exception
Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.