Class TestTableInputFormatBase.TableInputFormatForMergeTesting

java.lang.Object
org.apache.hadoop.mapreduce.InputFormat<org.apache.hadoop.hbase.io.ImmutableBytesWritable,org.apache.hadoop.hbase.client.Result>
org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
org.apache.hadoop.hbase.mapreduce.TableInputFormat
org.apache.hadoop.hbase.mapreduce.TestTableInputFormatBase.TableInputFormatForMergeTesting
All Implemented Interfaces:
org.apache.hadoop.conf.Configurable
Enclosing class:
TestTableInputFormatBase

private static class TestTableInputFormatBase.TableInputFormatForMergeTesting extends org.apache.hadoop.hbase.mapreduce.TableInputFormat
Subclass of TableInputFormat to use in TestTableInputFormatBase.testNonSuccessiveSplitsAreNotMerged(). This class overrides TableInputFormatBase.includeRegionInSplit(byte[], byte[]) to exclude specific splits.
  • Field Summary

    Fields
    Modifier and Type
    Field
    Description
    private byte[]
     
    private byte[]
     
    private org.apache.hadoop.hbase.mapreduce.RegionSizeCalculator
     

    Fields inherited from class org.apache.hadoop.hbase.mapreduce.TableInputFormat

    INPUT_TABLE, SCAN, SCAN_BATCHSIZE, SCAN_CACHEBLOCKS, SCAN_CACHEDROWS, SCAN_COLUMN_FAMILY, SCAN_COLUMNS, SCAN_MAXVERSIONS, SCAN_ROW_START, SCAN_ROW_STOP, SCAN_TIMERANGE_END, SCAN_TIMERANGE_START, SCAN_TIMESTAMP, SHUFFLE_MAPS

    Fields inherited from class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase

    MAPREDUCE_INPUT_AUTOBALANCE, MAX_AVERAGE_REGION_SIZE, NUM_MAPPERS_PER_REGION
  • Constructor Summary

    Constructors
    Modifier
    Constructor
    Description
    private
     
  • Method Summary

    Modifier and Type
    Method
    Description
    protected org.apache.hadoop.hbase.mapreduce.RegionSizeCalculator
    createRegionSizeCalculator(org.apache.hadoop.hbase.client.RegionLocator locator, org.apache.hadoop.hbase.client.Admin admin)
     
    protected boolean
    includeRegionInSplit(byte[] startKey, byte[] endKey)
    Exclude regions which contain rows starting with "b".
    protected void
    initializeTable(org.apache.hadoop.hbase.client.Connection connection, org.apache.hadoop.hbase.TableName tableName)
     

    Methods inherited from class org.apache.hadoop.hbase.mapreduce.TableInputFormat

    addColumns, configureSplitTable, createScanFromConfiguration, getConf, getSplits, getStartEndKeys, initialize, setConf

    Methods inherited from class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase

    calculateAutoBalancedSplits, closeTable, createNInputSplitsUniform, createRecordReader, getAdmin, getRegionLocator, getScan, getTable, reverseDNS, setScan, setTableRecordReader

    Methods inherited from class java.lang.Object

    clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
  • Field Details

  • Constructor Details

  • Method Details

    • includeRegionInSplit

      protected boolean includeRegionInSplit(byte[] startKey, byte[] endKey)
      Exclude regions which contain rows starting with "b".
      Overrides:
      includeRegionInSplit in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
    • initializeTable

      protected void initializeTable(org.apache.hadoop.hbase.client.Connection connection, org.apache.hadoop.hbase.TableName tableName) throws IOException
      Overrides:
      initializeTable in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
      Throws:
      IOException
    • createRegionSizeCalculator

      protected org.apache.hadoop.hbase.mapreduce.RegionSizeCalculator createRegionSizeCalculator(org.apache.hadoop.hbase.client.RegionLocator locator, org.apache.hadoop.hbase.client.Admin admin) throws IOException
      Overrides:
      createRegionSizeCalculator in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
      Throws:
      IOException