Uses of Interface
org.apache.hadoop.hbase.util.RegionSplitter.SplitAlgorithm

Packages that use org.apache.hadoop.hbase.util.RegionSplitter.SplitAlgorithm
Package
Description
Provides HBase MapReduce Input/OutputFormats, a table indexing MapReduce job, and utility methods.
Provides HBase MapReduce Input/OutputFormats, a table indexing MapReduce job, and utility methods.
 
  • Uses of org.apache.hadoop.hbase.util.RegionSplitter.SplitAlgorithm in org.apache.hadoop.hbase.mapred

    Methods in org.apache.hadoop.hbase.mapred with parameters of type org.apache.hadoop.hbase.util.RegionSplitter.SplitAlgorithm in in
    Modifier and Type
    Method
    Description
    static void
    TableMapReduceUtil.initTableSnapshotMapJob(String snapshotName, String columns, Class<? extends org.apache.hadoop.hbase.mapred.TableMap> mapper, Class<?> outputKeyClass, Class<?> outputValueClass, org.apache.hadoop.mapred.JobConf jobConf, boolean addDependencyJars, org.apache.hadoop.fs.Path tmpRestoreDir, org.apache.hadoop.hbase.util.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, org.apache.hadoop.hbase.util.RegionSplitter.SplitAlgorithm splitAlgo, int numSplitsPerRegion)
    Configures the job to use TableSnapshotInputFormat to read from a snapshot.
  • Uses of org.apache.hadoop.hbase.util.RegionSplitter.SplitAlgorithm in org.apache.hadoop.hbase.mapreduce

    Methods in org.apache.hadoop.hbase.mapreduce that return org.apache.hadoop.hbase.util.RegionSplitter.SplitAlgorithm in in
    Modifier and Type
    Method
    Description
    static org.apache.hadoop.hbase.util.RegionSplitter.SplitAlgorithm
    TableSnapshotInputFormatImpl.getSplitAlgo(org.apache.hadoop.conf.Configuration conf)
     
    Methods in org.apache.hadoop.hbase.mapreduce with parameters of type org.apache.hadoop.hbase.util.RegionSplitter.SplitAlgorithm in in
    Modifier and Type
    Method
    Description
    static List<org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl.InputSplit>
    TableSnapshotInputFormatImpl.getSplits(org.apache.hadoop.hbase.client.Scan scan, org.apache.hadoop.hbase.snapshot.SnapshotManifest manifest, List<org.apache.hadoop.hbase.HRegionInfo> regionManifests, org.apache.hadoop.fs.Path restoreDir, org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.util.RegionSplitter.SplitAlgorithm sa, int numSplits)
     
    static void
    TableMapReduceUtil.initTableSnapshotMapperJob(String snapshotName, org.apache.hadoop.hbase.client.Scan scan, Class<? extends org.apache.hadoop.hbase.mapreduce.TableMapper> mapper, Class<?> outputKeyClass, Class<?> outputValueClass, org.apache.hadoop.mapreduce.Job job, boolean addDependencyJars, org.apache.hadoop.fs.Path tmpRestoreDir, org.apache.hadoop.hbase.util.RegionSplitter.SplitAlgorithm splitAlgo, int numSplitsPerRegion)
    Sets up the job for reading from a table snapshot.
    static void
    TableSnapshotInputFormat.setInput(org.apache.hadoop.mapreduce.Job job, String snapshotName, org.apache.hadoop.fs.Path restoreDir, org.apache.hadoop.hbase.util.RegionSplitter.SplitAlgorithm splitAlgo, int numSplitsPerRegion)
    Configures the job to use TableSnapshotInputFormat to read from a snapshot.
    static void
    TableSnapshotInputFormatImpl.setInput(org.apache.hadoop.conf.Configuration conf, String snapshotName, org.apache.hadoop.fs.Path restoreDir, org.apache.hadoop.hbase.util.RegionSplitter.SplitAlgorithm splitAlgo, int numSplitsPerRegion)
    Configures the job to use TableSnapshotInputFormat to read from a snapshot.
  • Uses of org.apache.hadoop.hbase.util.RegionSplitter.SplitAlgorithm in org.apache.hadoop.hbase.util

    Classes in org.apache.hadoop.hbase.util that implement org.apache.hadoop.hbase.util.RegionSplitter.SplitAlgorithm in in
    Modifier and Type
    Class
    Description
    static class 
    org.apache.hadoop.hbase.util.RegionSplitter.DecimalStringSplit
    The format of a DecimalStringSplit region boundary is the ASCII representation of reversed sequential number, or any other uniformly distributed decimal value.
    static class 
    org.apache.hadoop.hbase.util.RegionSplitter.HexStringSplit
    HexStringSplit is a well-known RegionSplitter.SplitAlgorithm for choosing region boundaries.
    static class 
    org.apache.hadoop.hbase.util.RegionSplitter.NumberStringSplit
     
    static class 
    org.apache.hadoop.hbase.util.RegionSplitter.UniformSplit
    A SplitAlgorithm that divides the space of possible keys evenly.
    Methods in org.apache.hadoop.hbase.util that return org.apache.hadoop.hbase.util.RegionSplitter.SplitAlgorithm in in
    Modifier and Type
    Method
    Description
    static org.apache.hadoop.hbase.util.RegionSplitter.SplitAlgorithm
    RegionSplitter.newSplitAlgoInstance(org.apache.hadoop.conf.Configuration conf, String splitClassName)