Uses of Class
org.apache.hadoop.hbase.client.SnapshotDescription
Package
Description
Provides HBase Client
Table of Contents
-
Uses of SnapshotDescription in org.apache.hadoop.hbase.client
Modifier and TypeMethodDescriptionprivate CompletableFuture<List<SnapshotDescription>>
RawAsyncHBaseAdmin.getCompletedSnapshots
(Pattern pattern) private CompletableFuture<List<SnapshotDescription>>
RawAsyncHBaseAdmin.getCompletedSnapshots
(Pattern tableNamePattern, Pattern snapshotNamePattern) Admin.listSnapshots()
List completed snapshots.Admin.listSnapshots
(Pattern pattern) List all the completed snapshots matching the given pattern.AdminOverAsyncAdmin.listSnapshots()
AdminOverAsyncAdmin.listSnapshots
(Pattern pattern) AsyncAdmin.listSnapshots()
List completed snapshots.AsyncAdmin.listSnapshots
(Pattern pattern) List all the completed snapshots matching the given pattern.AsyncHBaseAdmin.listSnapshots()
AsyncHBaseAdmin.listSnapshots
(Pattern pattern) RawAsyncHBaseAdmin.listSnapshots()
RawAsyncHBaseAdmin.listSnapshots
(Pattern pattern) Admin.listTableSnapshots
(Pattern tableNamePattern, Pattern snapshotNamePattern) List all the completed snapshots matching the given table name regular expression and snapshot name regular expression.AdminOverAsyncAdmin.listTableSnapshots
(Pattern tableNamePattern, Pattern snapshotNamePattern) AsyncAdmin.listTableSnapshots
(Pattern tableNamePattern) List all the completed snapshots matching the given table name pattern.AsyncAdmin.listTableSnapshots
(Pattern tableNamePattern, Pattern snapshotNamePattern) List all the completed snapshots matching the given table name regular expression and snapshot name regular expression.AsyncHBaseAdmin.listTableSnapshots
(Pattern tableNamePattern) AsyncHBaseAdmin.listTableSnapshots
(Pattern tableNamePattern, Pattern snapshotNamePattern) RawAsyncHBaseAdmin.listTableSnapshots
(Pattern tableNamePattern) RawAsyncHBaseAdmin.listTableSnapshots
(Pattern tableNamePattern, Pattern snapshotNamePattern) Modifier and TypeMethodDescriptionprivate CompletableFuture<Void>
RawAsyncHBaseAdmin.internalDeleteSnapshot
(SnapshotDescription snapshot) boolean
Admin.isSnapshotFinished
(SnapshotDescription snapshot) Check the current state of the passed snapshot.boolean
AdminOverAsyncAdmin.isSnapshotFinished
(SnapshotDescription snapshot) AsyncAdmin.isSnapshotFinished
(SnapshotDescription snapshot) Check the current state of the passed snapshot.AsyncHBaseAdmin.isSnapshotFinished
(SnapshotDescription snapshot) RawAsyncHBaseAdmin.isSnapshotFinished
(SnapshotDescription snapshot) void
Admin.snapshot
(SnapshotDescription snapshot) Take a snapshot and wait for the server to complete that snapshot (blocking).void
AdminOverAsyncAdmin.snapshot
(SnapshotDescription snapshot) AsyncAdmin.snapshot
(SnapshotDescription snapshot) Take a snapshot and wait for the server to complete that snapshot asynchronously.AsyncHBaseAdmin.snapshot
(SnapshotDescription snapshot) RawAsyncHBaseAdmin.snapshot
(SnapshotDescription snapshotDesc) Admin.snapshotAsync
(SnapshotDescription snapshot) Take a snapshot without waiting for the server to complete that snapshot (asynchronous).AdminOverAsyncAdmin.snapshotAsync
(SnapshotDescription snapshot) private void
RawAsyncHBaseAdmin.waitSnapshotFinish
(SnapshotDescription snapshot, CompletableFuture<Void> future, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.SnapshotResponse resp) -
Uses of SnapshotDescription in org.apache.hadoop.hbase.coprocessor
Modifier and TypeMethodDescriptiondefault void
MasterObserver.postCloneSnapshot
(ObserverContext<MasterCoprocessorEnvironment> ctx, SnapshotDescription snapshot, TableDescriptor tableDescriptor) Called after a snapshot clone operation has been requested.default void
MasterObserver.postCompletedSnapshotAction
(ObserverContext<MasterCoprocessorEnvironment> ctx, SnapshotDescription snapshot, TableDescriptor tableDescriptor) Called after the snapshot operation has been completed.default void
MasterObserver.postDeleteSnapshot
(ObserverContext<MasterCoprocessorEnvironment> ctx, SnapshotDescription snapshot) Called after the delete snapshot operation has been requested.default void
MasterObserver.postListSnapshot
(ObserverContext<MasterCoprocessorEnvironment> ctx, SnapshotDescription snapshot) Called after listSnapshots request has been processed.default void
MasterObserver.postRestoreSnapshot
(ObserverContext<MasterCoprocessorEnvironment> ctx, SnapshotDescription snapshot, TableDescriptor tableDescriptor) Called after a snapshot restore operation has been requested.default void
MasterObserver.postSnapshot
(ObserverContext<MasterCoprocessorEnvironment> ctx, SnapshotDescription snapshot, TableDescriptor tableDescriptor) Called after the snapshot operation has been requested.default void
MasterObserver.preCloneSnapshot
(ObserverContext<MasterCoprocessorEnvironment> ctx, SnapshotDescription snapshot, TableDescriptor tableDescriptor) Called before a snapshot is cloned.default void
MasterObserver.preDeleteSnapshot
(ObserverContext<MasterCoprocessorEnvironment> ctx, SnapshotDescription snapshot) Called before a snapshot is deleted.default void
MasterObserver.preListSnapshot
(ObserverContext<MasterCoprocessorEnvironment> ctx, SnapshotDescription snapshot) Called before listSnapshots request has been processed.default void
MasterObserver.preRestoreSnapshot
(ObserverContext<MasterCoprocessorEnvironment> ctx, SnapshotDescription snapshot, TableDescriptor tableDescriptor) Called before a snapshot is restored.default void
MasterObserver.preSnapshot
(ObserverContext<MasterCoprocessorEnvironment> ctx, SnapshotDescription snapshot, TableDescriptor tableDescriptor) Called before a new snapshot is taken. -
Uses of SnapshotDescription in org.apache.hadoop.hbase.master
Modifier and TypeMethodDescriptionvoid
MasterCoprocessorHost.postCloneSnapshot
(SnapshotDescription snapshot, TableDescriptor hTableDescriptor) void
MasterCoprocessorHost.postCompletedSnapshotAction
(SnapshotDescription snapshot, TableDescriptor hTableDescriptor) void
MasterCoprocessorHost.postDeleteSnapshot
(SnapshotDescription snapshot) void
MasterCoprocessorHost.postListSnapshot
(SnapshotDescription snapshot) void
MasterCoprocessorHost.postRestoreSnapshot
(SnapshotDescription snapshot, TableDescriptor hTableDescriptor) void
MasterCoprocessorHost.postSnapshot
(SnapshotDescription snapshot, TableDescriptor hTableDescriptor, User user) void
MasterCoprocessorHost.preCloneSnapshot
(SnapshotDescription snapshot, TableDescriptor hTableDescriptor) void
MasterCoprocessorHost.preDeleteSnapshot
(SnapshotDescription snapshot) void
MasterCoprocessorHost.preListSnapshot
(SnapshotDescription snapshot) void
MasterCoprocessorHost.preRestoreSnapshot
(SnapshotDescription snapshot, TableDescriptor hTableDescriptor) void
MasterCoprocessorHost.preSnapshot
(SnapshotDescription snapshot, TableDescriptor hTableDescriptor, User user) -
Uses of SnapshotDescription in org.apache.hadoop.hbase.security.access
Modifier and TypeMethodDescriptionvoid
SnapshotScannerHDFSAclController.postCompletedSnapshotAction
(ObserverContext<MasterCoprocessorEnvironment> c, SnapshotDescription snapshot, TableDescriptor tableDescriptor) void
AccessController.preCloneSnapshot
(ObserverContext<MasterCoprocessorEnvironment> ctx, SnapshotDescription snapshot, TableDescriptor hTableDescriptor) void
AccessController.preDeleteSnapshot
(ObserverContext<MasterCoprocessorEnvironment> ctx, SnapshotDescription snapshot) void
AccessController.preListSnapshot
(ObserverContext<MasterCoprocessorEnvironment> ctx, SnapshotDescription snapshot) void
AccessController.preRestoreSnapshot
(ObserverContext<MasterCoprocessorEnvironment> ctx, SnapshotDescription snapshot, TableDescriptor hTableDescriptor) void
AccessController.preSnapshot
(ObserverContext<MasterCoprocessorEnvironment> ctx, SnapshotDescription snapshot, TableDescriptor hTableDescriptor) boolean
SnapshotScannerHDFSAclHelper.snapshotAcl
(SnapshotDescription snapshot) Set acl when take a snapshot -
Uses of SnapshotDescription in org.apache.hadoop.hbase.snapshot
Modifier and TypeMethodDescriptionHBaseSnapshotException.getSnapshotDescription()
Returns the description of the snapshot that is being failedSnapshotInfo.SnapshotStats.getSnapshotDescription()
Returns the snapshot descriptorModifier and TypeMethodDescriptionstatic List<SnapshotDescription>
SnapshotInfo.getSnapshotList
(org.apache.hadoop.conf.Configuration conf) Returns the list of available snapshots in the specified locationModifier and TypeMethodDescriptionprivate static void
SnapshotInfo.getSnapshotFilesMap
(org.apache.hadoop.conf.Configuration conf, SnapshotDescription snapshot, ExecutorService exec, ConcurrentHashMap<org.apache.hadoop.fs.Path, Integer> filesMap, AtomicLong uniqueHFilesArchiveSize, AtomicLong uniqueHFilesSize, AtomicLong uniqueHFilesMobSize) Gets the store files map for snapshotstatic SnapshotInfo.SnapshotStats
SnapshotInfo.getSnapshotStats
(org.apache.hadoop.conf.Configuration conf, SnapshotDescription snapshot) Returns the snapshot statsstatic boolean
SnapshotDescriptionUtils.isSnapshotOwner
(SnapshotDescription snapshot, User user) Check if the user is this table snapshot's ownerModifierConstructorDescriptionCorruptedSnapshotException
(String message, SnapshotDescription snapshotDescription) Snapshot was corrupt for some reason.HBaseSnapshotException
(String message, Throwable cause, SnapshotDescription snapshotDescription) Exception for the given snapshot due to another exception.HBaseSnapshotException
(String message, SnapshotDescription snapshotDescription) Exception for the given snapshot that has no previous root cause.RestoreSnapshotException
(String message, Throwable cause, SnapshotDescription snapshotDescription) RestoreSnapshotException
(String message, SnapshotDescription snapshotDescription) SnapshotCreationException
(String message, Throwable cause, SnapshotDescription snapshotDescription) Failure to create the specified snapshot due to an external cause.SnapshotCreationException
(String message, SnapshotDescription snapshotDescription) Failure to create the specified snapshot.SnapshotDoesNotExistException
(SnapshotDescription snapshotDescription) SnapshotExistsException
(String message, SnapshotDescription snapshotDescription) Failure due to the snapshot already existing.(package private)
SnapshotStats
(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.fs.FileSystem fs, SnapshotDescription snapshot) SnapshotTTLExpiredException
(SnapshotDescription snapshotDescription) Failure when the ttl for snapshot has already expired. -
Uses of SnapshotDescription in org.apache.hadoop.hbase.thrift2.client
Modifier and TypeMethodDescriptionThriftAdmin.listSnapshots()
ThriftAdmin.listSnapshots
(Pattern pattern) ThriftAdmin.listTableSnapshots
(Pattern tableNamePattern, Pattern snapshotNamePattern) Modifier and TypeMethodDescriptionboolean
ThriftAdmin.isSnapshotFinished
(SnapshotDescription snapshot) void
ThriftAdmin.snapshot
(SnapshotDescription snapshot) ThriftAdmin.snapshotAsync
(SnapshotDescription snapshot)