Package | Description |
---|---|
org.apache.hadoop.hbase.client |
Provides HBase Client
|
org.apache.hadoop.hbase.shaded.protobuf | |
org.apache.hadoop.hbase.snapshot |
Modifier and Type | Method and Description |
---|---|
List<SnapshotDescription> |
HBaseAdmin.listSnapshots() |
default CompletableFuture<List<SnapshotDescription>> |
AsyncAdmin.listSnapshots()
List completed snapshots.
|
List<SnapshotDescription> |
Admin.listSnapshots()
List completed snapshots.
|
CompletableFuture<List<SnapshotDescription>> |
RawAsyncHBaseAdmin.listSnapshots(Optional<Pattern> pattern) |
CompletableFuture<List<SnapshotDescription>> |
AsyncHBaseAdmin.listSnapshots(Optional<Pattern> pattern) |
CompletableFuture<List<SnapshotDescription>> |
AsyncAdmin.listSnapshots(Optional<Pattern> pattern)
List all the completed snapshots matching the given pattern.
|
List<SnapshotDescription> |
HBaseAdmin.listSnapshots(Pattern pattern) |
List<SnapshotDescription> |
Admin.listSnapshots(Pattern pattern)
List all the completed snapshots matching the given pattern.
|
List<SnapshotDescription> |
HBaseAdmin.listSnapshots(String regex) |
List<SnapshotDescription> |
Admin.listSnapshots(String regex)
List all the completed snapshots matching the given regular expression.
|
CompletableFuture<List<SnapshotDescription>> |
RawAsyncHBaseAdmin.listTableSnapshots(Pattern tableNamePattern,
Pattern snapshotNamePattern) |
List<SnapshotDescription> |
HBaseAdmin.listTableSnapshots(Pattern tableNamePattern,
Pattern snapshotNamePattern) |
CompletableFuture<List<SnapshotDescription>> |
AsyncHBaseAdmin.listTableSnapshots(Pattern tableNamePattern,
Pattern snapshotNamePattern) |
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.
|
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.
|
List<SnapshotDescription> |
HBaseAdmin.listTableSnapshots(String tableNameRegex,
String snapshotNameRegex) |
List<SnapshotDescription> |
Admin.listTableSnapshots(String tableNameRegex,
String snapshotNameRegex)
List all the completed snapshots matching the given table name regular expression and snapshot
name regular expression.
|
Modifier and Type | Method and Description |
---|---|
CompletableFuture<Boolean> |
RawAsyncHBaseAdmin.isSnapshotFinished(SnapshotDescription snapshot) |
boolean |
HBaseAdmin.isSnapshotFinished(SnapshotDescription snapshotDesc) |
CompletableFuture<Boolean> |
AsyncHBaseAdmin.isSnapshotFinished(SnapshotDescription snapshot) |
CompletableFuture<Boolean> |
AsyncAdmin.isSnapshotFinished(SnapshotDescription snapshot)
Check the current state of the passed snapshot.
|
boolean |
Admin.isSnapshotFinished(SnapshotDescription snapshot)
Check the current state of the passed snapshot.
|
CompletableFuture<Void> |
RawAsyncHBaseAdmin.snapshot(SnapshotDescription snapshotDesc) |
void |
HBaseAdmin.snapshot(SnapshotDescription snapshotDesc) |
CompletableFuture<Void> |
AsyncHBaseAdmin.snapshot(SnapshotDescription snapshot) |
CompletableFuture<Void> |
AsyncAdmin.snapshot(SnapshotDescription snapshot)
Take a snapshot and wait for the server to complete that snapshot asynchronously.
|
void |
Admin.snapshot(SnapshotDescription snapshot)
Take a snapshot and wait for the server to complete that snapshot (blocking).
|
void |
HBaseAdmin.takeSnapshotAsync(SnapshotDescription snapshotDesc) |
void |
Admin.takeSnapshotAsync(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.
|
Modifier and Type | Method and Description |
---|---|
static SnapshotDescription |
ProtobufUtil.createSnapshotDesc(org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotDescription snapshotDesc)
Convert from
HBaseProtos.SnapshotDescription to
SnapshotDescription |
Modifier and Type | Method and Description |
---|---|
static org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotDescription |
ProtobufUtil.createHBaseProtosSnapshotDesc(SnapshotDescription snapshotDesc)
Convert from
SnapshotDescription to
HBaseProtos.SnapshotDescription |
Modifier and Type | Method and Description |
---|---|
SnapshotDescription |
HBaseSnapshotException.getSnapshotDescription() |
Constructor and Description |
---|
CorruptedSnapshotException(String message,
SnapshotDescription snapshot)
Snapshot was corrupt for some reason
|
HBaseSnapshotException(String msg,
SnapshotDescription desc)
Exception for the given snapshot that has no previous root cause
|
HBaseSnapshotException(String msg,
Throwable cause,
SnapshotDescription desc)
Exception for the given snapshot due to another exception
|
RestoreSnapshotException(String msg,
SnapshotDescription desc) |
RestoreSnapshotException(String msg,
Throwable cause,
SnapshotDescription desc) |
SnapshotCreationException(String msg,
SnapshotDescription desc)
Failure to create the specified snapshot
|
SnapshotCreationException(String msg,
Throwable cause,
SnapshotDescription desc)
Failure to create the specified snapshot due to an external cause
|
SnapshotDoesNotExistException(SnapshotDescription desc) |
SnapshotExistsException(String msg,
SnapshotDescription desc)
Failure due to the snapshot already existing
|
Copyright © 2007–2017 The Apache Software Foundation. All rights reserved.