Package | Description |
---|---|
org.apache.hadoop.hbase.client |
Provides HBase Client
|
org.apache.hadoop.hbase.master.snapshot | |
org.apache.hadoop.hbase.snapshot |
Modifier and Type | Method and Description |
---|---|
void |
HBaseAdmin.snapshot(byte[] snapshotName,
byte[] tableName) |
void |
HBaseAdmin.snapshot(byte[] snapshotName,
byte[] tableName,
org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Type flushType)
Create snapshot for the given table of given flush type.
|
void |
HBaseAdmin.snapshot(byte[] snapshotName,
TableName tableName)
public void snapshot(final String snapshotName,
Create a timestamp consistent snapshot for the given table.
|
void |
Admin.snapshot(byte[] snapshotName,
TableName tableName)
public void snapshot(final String snapshotName, Create a timestamp consistent snapshot for the
given table.
|
void |
HBaseAdmin.snapshot(org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription snapshot)
Take a snapshot and wait for the server to complete that snapshot (blocking).
|
void |
Admin.snapshot(org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription snapshot)
Take a snapshot and wait for the server to complete that snapshot (blocking).
|
void |
HBaseAdmin.snapshot(String snapshotName,
byte[] tableName,
org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Type type) |
void |
HBaseAdmin.snapshot(String snapshotName,
String tableName) |
void |
HBaseAdmin.snapshot(String snapshotName,
String tableName,
org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Type type) |
void |
HBaseAdmin.snapshot(String snapshotName,
TableName tableName)
Take a snapshot for the given table.
|
void |
Admin.snapshot(String snapshotName,
TableName tableName)
Take a snapshot for the given table.
|
void |
HBaseAdmin.snapshot(String snapshotName,
TableName tableName,
org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Type type)
Create typed snapshot of the table.
|
void |
Admin.snapshot(String snapshotName,
TableName tableName,
org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Type type)
Create typed snapshot of the table.
|
org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SnapshotResponse |
HBaseAdmin.takeSnapshotAsync(org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription snapshot)
Take a snapshot without waiting for the server to complete that snapshot (asynchronous)
|
org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SnapshotResponse |
Admin.takeSnapshotAsync(org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.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 |
---|---|
void |
TakeSnapshotHandler.completeSnapshot(org.apache.hadoop.fs.Path snapshotDir,
org.apache.hadoop.fs.Path workingDir,
org.apache.hadoop.fs.FileSystem fs)
Reset the manager to allow another snapshot to proceed
|
Modifier and Type | Method and Description |
---|---|
static void |
SnapshotDescriptionUtils.completeSnapshot(org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription snapshot,
org.apache.hadoop.fs.Path rootdir,
org.apache.hadoop.fs.Path workingDir,
org.apache.hadoop.fs.FileSystem fs)
Move the finished snapshot to its final, publicly visible directory - this marks the snapshot
as 'complete'.
|
Copyright © 2007–2019 The Apache Software Foundation. All rights reserved.