Uses of Class
org.apache.hadoop.hbase.snapshot.SnapshotManifest

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

    Methods in org.apache.hadoop.hbase.mapreduce that return org.apache.hadoop.hbase.snapshot.SnapshotManifest in in
    Modifier and Type
    Method
    Description
    static org.apache.hadoop.hbase.snapshot.SnapshotManifest
    TableSnapshotInputFormatImpl.getSnapshotManifest(org.apache.hadoop.conf.Configuration conf, String snapshotName, org.apache.hadoop.fs.Path rootDir, org.apache.hadoop.fs.FileSystem fs)
     
    Methods in org.apache.hadoop.hbase.mapreduce with parameters of type org.apache.hadoop.hbase.snapshot.SnapshotManifest in in
    Modifier and Type
    Method
    Description
    static List<org.apache.hadoop.hbase.HRegionInfo>
    TableSnapshotInputFormatImpl.getRegionInfosFromManifest(org.apache.hadoop.hbase.snapshot.SnapshotManifest manifest)
     
    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)
     
    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)
     
  • Uses of org.apache.hadoop.hbase.snapshot.SnapshotManifest in org.apache.hadoop.hbase.snapshot

    Methods in org.apache.hadoop.hbase.snapshot that return org.apache.hadoop.hbase.snapshot.SnapshotManifest in in
    Modifier and Type
    Method
    Description
    static org.apache.hadoop.hbase.snapshot.SnapshotManifest
    SnapshotManifest.create(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.fs.Path workingDir, org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotDescription desc, org.apache.hadoop.hbase.errorhandling.ForeignExceptionSnare monitor)
    Return a SnapshotManifest instance, used for writing a snapshot.
    static org.apache.hadoop.hbase.snapshot.SnapshotManifest
    SnapshotManifest.create(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.fs.Path workingDir, org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotDescription desc, org.apache.hadoop.hbase.errorhandling.ForeignExceptionSnare monitor, org.apache.hadoop.hbase.monitoring.MonitoredTask statusTask)
     
    static org.apache.hadoop.hbase.snapshot.SnapshotManifest
    SnapshotManifest.open(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.fs.Path workingDir, org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotDescription desc)
    Return a SnapshotManifest instance with the information already loaded in-memory.
    Methods in org.apache.hadoop.hbase.snapshot with parameters of type org.apache.hadoop.hbase.snapshot.SnapshotManifest in in
    Modifier and Type
    Method
    Description
    static void
    SnapshotReferenceUtil.concurrentVisitReferencedFiles(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.hbase.snapshot.SnapshotManifest manifest, String desc, org.apache.hadoop.hbase.snapshot.SnapshotReferenceUtil.StoreFileVisitor visitor)
     
    static void
    SnapshotReferenceUtil.concurrentVisitReferencedFiles(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.hbase.snapshot.SnapshotManifest manifest, ExecutorService exec, org.apache.hadoop.hbase.snapshot.SnapshotReferenceUtil.StoreFileVisitor visitor)
     
    static void
    SnapshotReferenceUtil.verifySnapshot(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.hbase.snapshot.SnapshotManifest manifest)
    Verify the validity of the snapshot
    static void
    SnapshotReferenceUtil.verifySnapshot(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.hbase.snapshot.SnapshotManifest manifest, org.apache.hadoop.hbase.snapshot.SnapshotReferenceUtil.StoreFileVisitor visitor)
    Verify the validity of the snapshot.
    Constructors in org.apache.hadoop.hbase.snapshot with parameters of type org.apache.hadoop.hbase.snapshot.SnapshotManifest in in
    Modifier
    Constructor
    Description
     
    RestoreSnapshotHelper(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.hbase.snapshot.SnapshotManifest manifest, org.apache.hadoop.hbase.client.TableDescriptor tableDescriptor, org.apache.hadoop.fs.Path rootDir, org.apache.hadoop.hbase.errorhandling.ForeignExceptionDispatcher monitor, org.apache.hadoop.hbase.monitoring.MonitoredTask status)
     
     
    RestoreSnapshotHelper(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.hbase.snapshot.SnapshotManifest manifest, org.apache.hadoop.hbase.client.TableDescriptor tableDescriptor, org.apache.hadoop.fs.Path rootDir, org.apache.hadoop.hbase.errorhandling.ForeignExceptionDispatcher monitor, org.apache.hadoop.hbase.monitoring.MonitoredTask status, boolean createBackRefs)