| Package | Description | 
|---|---|
| org.apache.hadoop.hbase.mapreduce | Provides HBase MapReduce
Input/OutputFormats, a table indexing MapReduce job, and utility methods. | 
| org.apache.hadoop.hbase.master.snapshot | |
| org.apache.hadoop.hbase.quotas | |
| org.apache.hadoop.hbase.snapshot | 
| Modifier and Type | Method and Description | 
|---|---|
| static SnapshotManifest | TableSnapshotInputFormatImpl. getSnapshotManifest(org.apache.hadoop.conf.Configuration conf,
                   String snapshotName,
                   org.apache.hadoop.fs.Path rootDir,
                   org.apache.hadoop.fs.FileSystem fs) | 
| Modifier and Type | Method and Description | 
|---|---|
| static List<HRegionInfo> | TableSnapshotInputFormatImpl. getRegionInfosFromManifest(SnapshotManifest manifest) | 
| 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) | 
| 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) | 
| Modifier and Type | Field and Description | 
|---|---|
| protected SnapshotManifest | TakeSnapshotHandler. snapshotManifest | 
| Modifier and Type | Method and Description | 
|---|---|
| private void | MasterSnapshotVerifier. verifyRegions(SnapshotManifest manifest)Check that all the regions in the snapshot are valid, and accounted for. | 
| private void | MasterSnapshotVerifier. verifyTableInfo(SnapshotManifest manifest)Check that the table descriptor for the snapshot is a valid table descriptor | 
| Modifier and Type | Method and Description | 
|---|---|
| (package private) Set<FileArchiverNotifierImpl.StoreFileReference> | FileArchiverNotifierImpl. getStoreFilesFromSnapshot(SnapshotManifest manifest,
                         Predicate<String> filter)Extracts the names of the store files referenced by this snapshot which satisfy the given
 predicate (the predicate returns  true). | 
| Modifier and Type | Field and Description | 
|---|---|
| private SnapshotManifest | SnapshotInfo. snapshotManifest | 
| private SnapshotManifest | RestoreSnapshotHelper. snapshotManifest | 
| Modifier and Type | Method and Description | 
|---|---|
| static 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,
      ForeignExceptionSnare monitor)Return a SnapshotManifest instance, used for writing a snapshot. | 
| static 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,
      ForeignExceptionSnare monitor,
      MonitoredTask statusTask) | 
| static 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. | 
| Modifier and Type | Method and Description | 
|---|---|
| static void | SnapshotReferenceUtil. concurrentVisitReferencedFiles(org.apache.hadoop.conf.Configuration conf,
                              org.apache.hadoop.fs.FileSystem fs,
                              SnapshotManifest manifest,
                              ExecutorService exec,
                              SnapshotReferenceUtil.StoreFileVisitor visitor) | 
| static void | SnapshotReferenceUtil. concurrentVisitReferencedFiles(org.apache.hadoop.conf.Configuration conf,
                              org.apache.hadoop.fs.FileSystem fs,
                              SnapshotManifest manifest,
                              String desc,
                              SnapshotReferenceUtil.StoreFileVisitor visitor) | 
| static void | SnapshotReferenceUtil. verifySnapshot(org.apache.hadoop.conf.Configuration conf,
              org.apache.hadoop.fs.FileSystem fs,
              SnapshotManifest manifest)Verify the validity of the snapshot | 
| Constructor and Description | 
|---|
| RestoreSnapshotHelper(org.apache.hadoop.conf.Configuration conf,
                     org.apache.hadoop.fs.FileSystem fs,
                     SnapshotManifest manifest,
                     TableDescriptor tableDescriptor,
                     org.apache.hadoop.fs.Path rootDir,
                     ForeignExceptionDispatcher monitor,
                     MonitoredTask status) | 
| RestoreSnapshotHelper(org.apache.hadoop.conf.Configuration conf,
                     org.apache.hadoop.fs.FileSystem fs,
                     SnapshotManifest manifest,
                     TableDescriptor tableDescriptor,
                     org.apache.hadoop.fs.Path rootDir,
                     ForeignExceptionDispatcher monitor,
                     MonitoredTask status,
                     boolean createBackRefs) | 
Copyright © 2007–2021 The Apache Software Foundation. All rights reserved.