| Package | Description | 
|---|---|
| org.apache.hadoop.hbase.mapred | Provides HBase MapReduce
Input/OutputFormats, a table indexing MapReduce job, and utility methods. | 
| org.apache.hadoop.hbase.mapreduce | Provides HBase MapReduce
Input/OutputFormats, a table indexing MapReduce job, and utility methods. | 
| org.apache.hadoop.hbase.util | 
| Modifier and Type | Method and Description | 
|---|---|
| static void | TableMapReduceUtil. initTableSnapshotMapJob(String snapshotName,
                       String columns,
                       Class<? extends TableMap> mapper,
                       Class<?> outputKeyClass,
                       Class<?> outputValueClass,
                       org.apache.hadoop.mapred.JobConf jobConf,
                       boolean addDependencyJars,
                       org.apache.hadoop.fs.Path tmpRestoreDir,
                       RegionSplitter.SplitAlgorithm splitAlgo,
                       int numSplitsPerRegion)Sets up the job for reading from a table snapshot. | 
| static void | TableSnapshotInputFormat. setInput(org.apache.hadoop.mapred.JobConf job,
        String snapshotName,
        org.apache.hadoop.fs.Path restoreDir,
        RegionSplitter.SplitAlgorithm splitAlgo,
        int numSplitsPerRegion)Configures the job to use TableSnapshotInputFormat to read from a snapshot. | 
| Modifier and Type | Method and Description | 
|---|---|
| static RegionSplitter.SplitAlgorithm | TableSnapshotInputFormatImpl. getSplitAlgo(org.apache.hadoop.conf.Configuration conf) | 
| Modifier and Type | Method and Description | 
|---|---|
| static List<TableSnapshotInputFormatImpl.InputSplit> | TableSnapshotInputFormatImpl. getSplits(Scan scan,
         SnapshotManifest manifest,
         List<HRegionInfo> regionManifests,
         org.apache.hadoop.fs.Path restoreDir,
         org.apache.hadoop.conf.Configuration conf,
         RegionSplitter.SplitAlgorithm sa,
         int numSplits) | 
| static void | TableMapReduceUtil. initTableSnapshotMapperJob(String snapshotName,
                          Scan scan,
                          Class<? extends TableMapper> mapper,
                          Class<?> outputKeyClass,
                          Class<?> outputValueClass,
                          org.apache.hadoop.mapreduce.Job job,
                          boolean addDependencyJars,
                          org.apache.hadoop.fs.Path tmpRestoreDir,
                          RegionSplitter.SplitAlgorithm splitAlgo,
                          int numSplitsPerRegion)Sets up the job for reading from a table snapshot. | 
| static void | TableSnapshotInputFormatImpl. setInput(org.apache.hadoop.conf.Configuration conf,
        String snapshotName,
        org.apache.hadoop.fs.Path restoreDir,
        RegionSplitter.SplitAlgorithm splitAlgo,
        int numSplitsPerRegion)Configures the job to use TableSnapshotInputFormat to read from a snapshot. | 
| static void | TableSnapshotInputFormat. setInput(org.apache.hadoop.mapreduce.Job job,
        String snapshotName,
        org.apache.hadoop.fs.Path restoreDir,
        RegionSplitter.SplitAlgorithm splitAlgo,
        int numSplitsPerRegion)Configures the job to use TableSnapshotInputFormat to read from a snapshot. | 
| Modifier and Type | Class and Description | 
|---|---|
| static class  | RegionSplitter.DecimalStringSplitThe format of a DecimalStringSplit region boundary is the ASCII representation of
 reversed sequential number, or any other uniformly distributed decimal value. | 
| static class  | RegionSplitter.HexStringSplitHexStringSplit is a well-known  RegionSplitter.SplitAlgorithmfor choosing region
 boundaries. | 
| static class  | RegionSplitter.NumberStringSplit | 
| static class  | RegionSplitter.UniformSplitA SplitAlgorithm that divides the space of possible keys evenly. | 
| Modifier and Type | Method and Description | 
|---|---|
| static RegionSplitter.SplitAlgorithm | RegionSplitter. newSplitAlgoInstance(org.apache.hadoop.conf.Configuration conf,
                    String splitClassName) | 
| Modifier and Type | Method and Description | 
|---|---|
| (package private) static void | RegionSplitter. createPresplitTable(TableName tableName,
                   RegionSplitter.SplitAlgorithm splitAlgo,
                   String[] columnFamilies,
                   org.apache.hadoop.conf.Configuration conf) | 
| (package private) static LinkedList<Pair<byte[],byte[]>> | RegionSplitter. getSplits(Connection connection,
         TableName tableName,
         RegionSplitter.SplitAlgorithm splitAlgo) | 
| (package private) static void | RegionSplitter. rollingSplit(TableName tableName,
            RegionSplitter.SplitAlgorithm splitAlgo,
            org.apache.hadoop.conf.Configuration conf) | 
| (package private) static LinkedList<Pair<byte[],byte[]>> | RegionSplitter. splitScan(LinkedList<Pair<byte[],byte[]>> regionList,
         Connection connection,
         TableName tableName,
         RegionSplitter.SplitAlgorithm splitAlgo) | 
Copyright © 2007–2019 The Apache Software Foundation. All rights reserved.