Package | Description |
---|---|
org.apache.hadoop.hbase.client |
Provides HBase Client
|
org.apache.hadoop.hbase.coprocessor |
Table of Contents
|
org.apache.hadoop.hbase.master | |
org.apache.hadoop.hbase.rsgroup | |
org.apache.hadoop.hbase.security.access | |
org.apache.hadoop.hbase.snapshot | |
org.apache.hadoop.hbase.thrift2.client |
Modifier and Type | Method and Description |
---|---|
private CompletableFuture<List<SnapshotDescription>> |
RawAsyncHBaseAdmin.getCompletedSnapshots(Pattern pattern) |
private CompletableFuture<List<SnapshotDescription>> |
RawAsyncHBaseAdmin.getCompletedSnapshots(Pattern tableNamePattern,
Pattern snapshotNamePattern) |
List<SnapshotDescription> |
Admin.listSnapshots()
List completed snapshots.
|
CompletableFuture<List<SnapshotDescription>> |
AsyncAdmin.listSnapshots()
List completed snapshots.
|
CompletableFuture<List<SnapshotDescription>> |
RawAsyncHBaseAdmin.listSnapshots() |
CompletableFuture<List<SnapshotDescription>> |
AsyncHBaseAdmin.listSnapshots() |
List<SnapshotDescription> |
HBaseAdmin.listSnapshots() |
List<SnapshotDescription> |
Admin.listSnapshots(Pattern pattern)
List all the completed snapshots matching the given pattern.
|
CompletableFuture<List<SnapshotDescription>> |
AsyncAdmin.listSnapshots(Pattern pattern)
List all the completed snapshots matching the given pattern.
|
CompletableFuture<List<SnapshotDescription>> |
RawAsyncHBaseAdmin.listSnapshots(Pattern pattern) |
CompletableFuture<List<SnapshotDescription>> |
AsyncHBaseAdmin.listSnapshots(Pattern pattern) |
List<SnapshotDescription> |
HBaseAdmin.listSnapshots(Pattern pattern) |
List<SnapshotDescription> |
Admin.listSnapshots(String regex)
Deprecated.
since 2.0 version and will be removed in 3.0 version.
Use
Admin.listSnapshots(Pattern) instead. |
List<SnapshotDescription> |
HBaseAdmin.listSnapshots(String regex) |
CompletableFuture<List<SnapshotDescription>> |
AsyncAdmin.listTableSnapshots(Pattern tableNamePattern)
List all the completed snapshots matching the given table name pattern.
|
CompletableFuture<List<SnapshotDescription>> |
RawAsyncHBaseAdmin.listTableSnapshots(Pattern tableNamePattern) |
CompletableFuture<List<SnapshotDescription>> |
AsyncHBaseAdmin.listTableSnapshots(Pattern tableNamePattern) |
List<SnapshotDescription> |
Admin.listTableSnapshots(Pattern tableNamePattern,
Pattern snapshotNamePattern)
List all the completed snapshots matching the given table name regular expression and snapshot
name regular expression.
|
CompletableFuture<List<SnapshotDescription>> |
AsyncAdmin.listTableSnapshots(Pattern tableNamePattern,
Pattern snapshotNamePattern)
List all the completed snapshots matching the given table name regular expression and snapshot
name regular expression.
|
CompletableFuture<List<SnapshotDescription>> |
RawAsyncHBaseAdmin.listTableSnapshots(Pattern tableNamePattern,
Pattern snapshotNamePattern) |
CompletableFuture<List<SnapshotDescription>> |
AsyncHBaseAdmin.listTableSnapshots(Pattern tableNamePattern,
Pattern snapshotNamePattern) |
List<SnapshotDescription> |
HBaseAdmin.listTableSnapshots(Pattern tableNamePattern,
Pattern snapshotNamePattern) |
List<SnapshotDescription> |
Admin.listTableSnapshots(String tableNameRegex,
String snapshotNameRegex)
Deprecated.
since 2.0 version and will be removed in 3.0 version.
Use
Admin.listTableSnapshots(Pattern, Pattern) instead. |
List<SnapshotDescription> |
HBaseAdmin.listTableSnapshots(String tableNameRegex,
String snapshotNameRegex) |
Modifier and Type | Method and Description |
---|---|
private CompletableFuture<Void> |
RawAsyncHBaseAdmin.internalDeleteSnapshot(SnapshotDescription snapshot) |
private void |
HBaseAdmin.internalDeleteSnapshot(SnapshotDescription snapshot) |
boolean |
Admin.isSnapshotFinished(SnapshotDescription snapshot)
Check the current state of the passed snapshot.
|
CompletableFuture<Boolean> |
AsyncAdmin.isSnapshotFinished(SnapshotDescription snapshot)
Check the current state of the passed snapshot.
|
CompletableFuture<Boolean> |
RawAsyncHBaseAdmin.isSnapshotFinished(SnapshotDescription snapshot) |
CompletableFuture<Boolean> |
AsyncHBaseAdmin.isSnapshotFinished(SnapshotDescription snapshot) |
boolean |
HBaseAdmin.isSnapshotFinished(SnapshotDescription snapshotDesc) |
void |
Admin.snapshot(SnapshotDescription snapshot)
Take a snapshot and wait for the server to complete that snapshot (blocking).
|
CompletableFuture<Void> |
AsyncAdmin.snapshot(SnapshotDescription snapshot)
Take a snapshot and wait for the server to complete that snapshot asynchronously.
|
CompletableFuture<Void> |
RawAsyncHBaseAdmin.snapshot(SnapshotDescription snapshotDesc) |
CompletableFuture<Void> |
AsyncHBaseAdmin.snapshot(SnapshotDescription snapshot) |
void |
HBaseAdmin.snapshot(SnapshotDescription snapshotDesc) |
void |
Admin.snapshotAsync(SnapshotDescription snapshot)
Take a snapshot without waiting for the server to complete that snapshot (asynchronous) Only a
single snapshot should be taken at a time, or results may be undefined.
|
void |
HBaseAdmin.snapshotAsync(SnapshotDescription snapshotDesc) |
default void |
Admin.takeSnapshotAsync(SnapshotDescription snapshot)
Deprecated.
Since 2.0.0. Will be removed in 3.0.0. Use
Admin.snapshotAsync(SnapshotDescription) instead. |
Modifier and Type | Method and Description |
---|---|
default void |
MasterObserver.postCloneSnapshot(ObserverContext<MasterCoprocessorEnvironment> ctx,
SnapshotDescription snapshot,
TableDescriptor tableDescriptor)
Called after a snapshot clone operation has been requested.
|
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.
|
Modifier and Type | Method and Description |
---|---|
void |
MasterCoprocessorHost.postCloneSnapshot(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) |
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) |
Modifier and Type | Method and Description |
---|---|
void |
RSGroupAdminEndpoint.preCloneSnapshot(ObserverContext<MasterCoprocessorEnvironment> ctx,
SnapshotDescription snapshot,
TableDescriptor desc) |
Modifier and Type | Method and Description |
---|---|
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) |
Modifier and Type | Field and Description |
---|---|
private SnapshotDescription |
HBaseSnapshotException.description |
Modifier and Type | Method and Description |
---|---|
SnapshotDescription |
HBaseSnapshotException.getSnapshotDescription() |
SnapshotDescription |
SnapshotInfo.SnapshotStats.getSnapshotDescription() |
Modifier and Type | Method and Description |
---|---|
static List<SnapshotDescription> |
SnapshotInfo.getSnapshotList(org.apache.hadoop.conf.Configuration conf)
Returns the list of available snapshots in the specified location
|
Modifier and Type | Method and Description |
---|---|
private 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 snapshot
|
static SnapshotInfo.SnapshotStats |
SnapshotInfo.getSnapshotStats(org.apache.hadoop.conf.Configuration conf,
SnapshotDescription snapshot)
Returns the snapshot stats
|
static boolean |
SnapshotDescriptionUtils.isSnapshotOwner(SnapshotDescription snapshot,
User user)
Check if the user is this table snapshot's owner
|
Constructor and Description |
---|
CorruptedSnapshotException(String message,
SnapshotDescription snapshotDescription)
Snapshot was corrupt for some reason.
|
HBaseSnapshotException(String message,
SnapshotDescription snapshotDescription)
Exception for the given snapshot that has no previous root cause.
|
HBaseSnapshotException(String message,
Throwable cause,
SnapshotDescription snapshotDescription)
Exception for the given snapshot due to another exception.
|
RestoreSnapshotException(String message,
SnapshotDescription snapshotDescription) |
RestoreSnapshotException(String message,
Throwable cause,
SnapshotDescription snapshotDescription) |
SnapshotCreationException(String message,
SnapshotDescription snapshotDescription)
Failure to create the specified snapshot.
|
SnapshotCreationException(String message,
Throwable cause,
SnapshotDescription snapshotDescription)
Failure to create the specified snapshot due to an external cause.
|
SnapshotDoesNotExistException(SnapshotDescription snapshotDescription) |
SnapshotExistsException(String message,
SnapshotDescription snapshotDescription)
Failure due to the snapshot already existing.
|
SnapshotStats(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
SnapshotDescription snapshot) |
Modifier and Type | Method and Description |
---|---|
List<SnapshotDescription> |
ThriftAdmin.listSnapshots() |
List<SnapshotDescription> |
ThriftAdmin.listSnapshots(Pattern pattern) |
List<SnapshotDescription> |
ThriftAdmin.listSnapshots(String regex) |
List<SnapshotDescription> |
ThriftAdmin.listTableSnapshots(Pattern tableNamePattern,
Pattern snapshotNamePattern) |
List<SnapshotDescription> |
ThriftAdmin.listTableSnapshots(String tableNameRegex,
String snapshotNameRegex) |
Modifier and Type | Method and Description |
---|---|
boolean |
ThriftAdmin.isSnapshotFinished(SnapshotDescription snapshot) |
void |
ThriftAdmin.snapshot(SnapshotDescription snapshot) |
void |
ThriftAdmin.snapshotAsync(SnapshotDescription snapshot) |
Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.