Modifier and Type | Method and Description |
---|---|
List<HBaseProtos.SnapshotDescription> |
HBaseAdmin.listSnapshots()
List completed snapshots.
|
List<HBaseProtos.SnapshotDescription> |
Admin.listSnapshots()
List completed snapshots.
|
List<HBaseProtos.SnapshotDescription> |
HBaseAdmin.listSnapshots(Pattern pattern)
List all the completed snapshots matching the given pattern.
|
List<HBaseProtos.SnapshotDescription> |
Admin.listSnapshots(Pattern pattern)
List all the completed snapshots matching the given pattern.
|
List<HBaseProtos.SnapshotDescription> |
HBaseAdmin.listSnapshots(String regex)
List all the completed snapshots matching the given regular expression.
|
List<HBaseProtos.SnapshotDescription> |
Admin.listSnapshots(String regex)
List all the completed snapshots matching the given regular expression.
|
Modifier and Type | Method and Description |
---|---|
boolean |
HBaseAdmin.isSnapshotFinished(HBaseProtos.SnapshotDescription snapshot)
Check the current state of the passed snapshot.
|
boolean |
Admin.isSnapshotFinished(HBaseProtos.SnapshotDescription snapshot)
Check the current state of the passed snapshot.
|
void |
HBaseAdmin.snapshot(HBaseProtos.SnapshotDescription snapshot)
Take a snapshot and wait for the server to complete that snapshot (blocking).
|
void |
Admin.snapshot(HBaseProtos.SnapshotDescription snapshot)
Take a snapshot and wait for the server to complete that snapshot (blocking).
|
MasterProtos.SnapshotResponse |
HBaseAdmin.takeSnapshotAsync(HBaseProtos.SnapshotDescription snapshot)
Take a snapshot without waiting for the server to complete that snapshot (asynchronous)
|
MasterProtos.SnapshotResponse |
Admin.takeSnapshotAsync(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 |
---|---|
HBaseProtos.SnapshotDescription |
SnapshotSentinel.getSnapshot() |
Modifier and Type | Field and Description |
---|---|
protected HBaseProtos.SnapshotDescription |
TakeSnapshotHandler.snapshot |
Modifier and Type | Method and Description |
---|---|
HBaseProtos.SnapshotDescription |
TakeSnapshotHandler.getSnapshot() |
HBaseProtos.SnapshotDescription |
RestoreSnapshotHandler.getSnapshot() |
HBaseProtos.SnapshotDescription |
CloneSnapshotHandler.getSnapshot() |
Modifier and Type | Method and Description |
---|---|
List<HBaseProtos.SnapshotDescription> |
SnapshotManager.getCompletedSnapshots()
Gets the list of all completed snapshots.
|
Modifier and Type | Method and Description |
---|---|
void |
SnapshotManager.deleteSnapshot(HBaseProtos.SnapshotDescription snapshot)
Delete the specified snapshot
|
boolean |
SnapshotManager.isRestoreDone(HBaseProtos.SnapshotDescription snapshot)
Returns the status of a restore operation.
|
boolean |
SnapshotManager.isSnapshotDone(HBaseProtos.SnapshotDescription expected)
Check if the specified snapshot is done
|
void |
SnapshotManager.restoreSnapshot(HBaseProtos.SnapshotDescription reqSnapshot)
Restore the specified snapshot
|
void |
SnapshotManager.takeSnapshot(HBaseProtos.SnapshotDescription snapshot)
Take a snapshot based on the enabled/disabled state of the table.
|
Constructor and Description |
---|
CloneSnapshotHandler(MasterServices masterServices,
HBaseProtos.SnapshotDescription snapshot,
HTableDescriptor hTableDescriptor) |
DisabledTableSnapshotHandler(HBaseProtos.SnapshotDescription snapshot,
MasterServices masterServices) |
EnabledTableSnapshotHandler(HBaseProtos.SnapshotDescription snapshot,
MasterServices master,
SnapshotManager manager) |
MasterSnapshotVerifier(MasterServices services,
HBaseProtos.SnapshotDescription snapshot,
org.apache.hadoop.fs.Path rootDir) |
RestoreSnapshotHandler(MasterServices masterServices,
HBaseProtos.SnapshotDescription snapshot,
HTableDescriptor htd) |
TakeSnapshotHandler(HBaseProtos.SnapshotDescription snapshot,
MasterServices masterServices) |
Modifier and Type | Field and Description |
---|---|
static com.google.protobuf.Parser<HBaseProtos.SnapshotDescription> |
HBaseProtos.SnapshotDescription.PARSER |
Modifier and Type | Method and Description |
---|---|
HBaseProtos.SnapshotDescription |
HBaseProtos.SnapshotDescription.Builder.build() |
HBaseProtos.SnapshotDescription |
HBaseProtos.SnapshotDescription.Builder.buildPartial() |
static HBaseProtos.SnapshotDescription |
HBaseProtos.SnapshotDescription.getDefaultInstance() |
HBaseProtos.SnapshotDescription |
HBaseProtos.SnapshotDescription.getDefaultInstanceForType() |
HBaseProtos.SnapshotDescription |
HBaseProtos.SnapshotDescription.Builder.getDefaultInstanceForType() |
HBaseProtos.SnapshotDescription |
MasterProtos.SnapshotRequestOrBuilder.getSnapshot()
required .SnapshotDescription snapshot = 1; |
HBaseProtos.SnapshotDescription |
MasterProtos.SnapshotRequest.getSnapshot()
required .SnapshotDescription snapshot = 1; |
HBaseProtos.SnapshotDescription |
MasterProtos.SnapshotRequest.Builder.getSnapshot()
required .SnapshotDescription snapshot = 1; |
HBaseProtos.SnapshotDescription |
MasterProtos.DeleteSnapshotRequestOrBuilder.getSnapshot()
required .SnapshotDescription snapshot = 1; |
HBaseProtos.SnapshotDescription |
MasterProtos.DeleteSnapshotRequest.getSnapshot()
required .SnapshotDescription snapshot = 1; |
HBaseProtos.SnapshotDescription |
MasterProtos.DeleteSnapshotRequest.Builder.getSnapshot()
required .SnapshotDescription snapshot = 1; |
HBaseProtos.SnapshotDescription |
MasterProtos.RestoreSnapshotRequestOrBuilder.getSnapshot()
required .SnapshotDescription snapshot = 1; |
HBaseProtos.SnapshotDescription |
MasterProtos.RestoreSnapshotRequest.getSnapshot()
required .SnapshotDescription snapshot = 1; |
HBaseProtos.SnapshotDescription |
MasterProtos.RestoreSnapshotRequest.Builder.getSnapshot()
required .SnapshotDescription snapshot = 1; |
HBaseProtos.SnapshotDescription |
MasterProtos.IsSnapshotDoneRequestOrBuilder.getSnapshot()
optional .SnapshotDescription snapshot = 1; |
HBaseProtos.SnapshotDescription |
MasterProtos.IsSnapshotDoneRequest.getSnapshot()
optional .SnapshotDescription snapshot = 1; |
HBaseProtos.SnapshotDescription |
MasterProtos.IsSnapshotDoneRequest.Builder.getSnapshot()
optional .SnapshotDescription snapshot = 1; |
HBaseProtos.SnapshotDescription |
MasterProtos.IsSnapshotDoneResponseOrBuilder.getSnapshot()
optional .SnapshotDescription snapshot = 2; |
HBaseProtos.SnapshotDescription |
MasterProtos.IsSnapshotDoneResponse.getSnapshot()
optional .SnapshotDescription snapshot = 2; |
HBaseProtos.SnapshotDescription |
MasterProtos.IsSnapshotDoneResponse.Builder.getSnapshot()
optional .SnapshotDescription snapshot = 2; |
HBaseProtos.SnapshotDescription |
MasterProtos.IsRestoreSnapshotDoneRequestOrBuilder.getSnapshot()
optional .SnapshotDescription snapshot = 1; |
HBaseProtos.SnapshotDescription |
MasterProtos.IsRestoreSnapshotDoneRequest.getSnapshot()
optional .SnapshotDescription snapshot = 1; |
HBaseProtos.SnapshotDescription |
MasterProtos.IsRestoreSnapshotDoneRequest.Builder.getSnapshot()
optional .SnapshotDescription snapshot = 1; |
HBaseProtos.SnapshotDescription |
MasterProtos.GetCompletedSnapshotsResponseOrBuilder.getSnapshots(int index)
repeated .SnapshotDescription snapshots = 1; |
HBaseProtos.SnapshotDescription |
MasterProtos.GetCompletedSnapshotsResponse.getSnapshots(int index)
repeated .SnapshotDescription snapshots = 1; |
HBaseProtos.SnapshotDescription |
MasterProtos.GetCompletedSnapshotsResponse.Builder.getSnapshots(int index)
repeated .SnapshotDescription snapshots = 1; |
static HBaseProtos.SnapshotDescription |
HBaseProtos.SnapshotDescription.parseDelimitedFrom(InputStream input) |
static HBaseProtos.SnapshotDescription |
HBaseProtos.SnapshotDescription.parseDelimitedFrom(InputStream input,
com.google.protobuf.ExtensionRegistryLite extensionRegistry) |
static HBaseProtos.SnapshotDescription |
HBaseProtos.SnapshotDescription.parseFrom(byte[] data) |
static HBaseProtos.SnapshotDescription |
HBaseProtos.SnapshotDescription.parseFrom(byte[] data,
com.google.protobuf.ExtensionRegistryLite extensionRegistry) |
static HBaseProtos.SnapshotDescription |
HBaseProtos.SnapshotDescription.parseFrom(com.google.protobuf.ByteString data) |
static HBaseProtos.SnapshotDescription |
HBaseProtos.SnapshotDescription.parseFrom(com.google.protobuf.ByteString data,
com.google.protobuf.ExtensionRegistryLite extensionRegistry) |
static HBaseProtos.SnapshotDescription |
HBaseProtos.SnapshotDescription.parseFrom(com.google.protobuf.CodedInputStream input) |
static HBaseProtos.SnapshotDescription |
HBaseProtos.SnapshotDescription.parseFrom(com.google.protobuf.CodedInputStream input,
com.google.protobuf.ExtensionRegistryLite extensionRegistry) |
static HBaseProtos.SnapshotDescription |
HBaseProtos.SnapshotDescription.parseFrom(InputStream input) |
static HBaseProtos.SnapshotDescription |
HBaseProtos.SnapshotDescription.parseFrom(InputStream input,
com.google.protobuf.ExtensionRegistryLite extensionRegistry) |
Modifier and Type | Method and Description |
---|---|
com.google.protobuf.Parser<HBaseProtos.SnapshotDescription> |
HBaseProtos.SnapshotDescription.getParserForType() |
List<HBaseProtos.SnapshotDescription> |
MasterProtos.GetCompletedSnapshotsResponseOrBuilder.getSnapshotsList()
repeated .SnapshotDescription snapshots = 1; |
List<HBaseProtos.SnapshotDescription> |
MasterProtos.GetCompletedSnapshotsResponse.getSnapshotsList()
repeated .SnapshotDescription snapshots = 1; |
List<HBaseProtos.SnapshotDescription> |
MasterProtos.GetCompletedSnapshotsResponse.Builder.getSnapshotsList()
repeated .SnapshotDescription snapshots = 1; |
Modifier and Type | Method and Description |
---|---|
MasterProtos.GetCompletedSnapshotsResponse.Builder |
MasterProtos.GetCompletedSnapshotsResponse.Builder.addSnapshots(HBaseProtos.SnapshotDescription value)
repeated .SnapshotDescription snapshots = 1; |
MasterProtos.GetCompletedSnapshotsResponse.Builder |
MasterProtos.GetCompletedSnapshotsResponse.Builder.addSnapshots(int index,
HBaseProtos.SnapshotDescription value)
repeated .SnapshotDescription snapshots = 1; |
HBaseProtos.SnapshotDescription.Builder |
HBaseProtos.SnapshotDescription.Builder.mergeFrom(HBaseProtos.SnapshotDescription other) |
MasterProtos.SnapshotRequest.Builder |
MasterProtos.SnapshotRequest.Builder.mergeSnapshot(HBaseProtos.SnapshotDescription value)
required .SnapshotDescription snapshot = 1; |
MasterProtos.DeleteSnapshotRequest.Builder |
MasterProtos.DeleteSnapshotRequest.Builder.mergeSnapshot(HBaseProtos.SnapshotDescription value)
required .SnapshotDescription snapshot = 1; |
MasterProtos.RestoreSnapshotRequest.Builder |
MasterProtos.RestoreSnapshotRequest.Builder.mergeSnapshot(HBaseProtos.SnapshotDescription value)
required .SnapshotDescription snapshot = 1; |
MasterProtos.IsSnapshotDoneRequest.Builder |
MasterProtos.IsSnapshotDoneRequest.Builder.mergeSnapshot(HBaseProtos.SnapshotDescription value)
optional .SnapshotDescription snapshot = 1; |
MasterProtos.IsSnapshotDoneResponse.Builder |
MasterProtos.IsSnapshotDoneResponse.Builder.mergeSnapshot(HBaseProtos.SnapshotDescription value)
optional .SnapshotDescription snapshot = 2; |
MasterProtos.IsRestoreSnapshotDoneRequest.Builder |
MasterProtos.IsRestoreSnapshotDoneRequest.Builder.mergeSnapshot(HBaseProtos.SnapshotDescription value)
optional .SnapshotDescription snapshot = 1; |
static HBaseProtos.SnapshotDescription.Builder |
HBaseProtos.SnapshotDescription.newBuilder(HBaseProtos.SnapshotDescription prototype) |
MasterProtos.SnapshotRequest.Builder |
MasterProtos.SnapshotRequest.Builder.setSnapshot(HBaseProtos.SnapshotDescription value)
required .SnapshotDescription snapshot = 1; |
MasterProtos.DeleteSnapshotRequest.Builder |
MasterProtos.DeleteSnapshotRequest.Builder.setSnapshot(HBaseProtos.SnapshotDescription value)
required .SnapshotDescription snapshot = 1; |
MasterProtos.RestoreSnapshotRequest.Builder |
MasterProtos.RestoreSnapshotRequest.Builder.setSnapshot(HBaseProtos.SnapshotDescription value)
required .SnapshotDescription snapshot = 1; |
MasterProtos.IsSnapshotDoneRequest.Builder |
MasterProtos.IsSnapshotDoneRequest.Builder.setSnapshot(HBaseProtos.SnapshotDescription value)
optional .SnapshotDescription snapshot = 1; |
MasterProtos.IsSnapshotDoneResponse.Builder |
MasterProtos.IsSnapshotDoneResponse.Builder.setSnapshot(HBaseProtos.SnapshotDescription value)
optional .SnapshotDescription snapshot = 2; |
MasterProtos.IsRestoreSnapshotDoneRequest.Builder |
MasterProtos.IsRestoreSnapshotDoneRequest.Builder.setSnapshot(HBaseProtos.SnapshotDescription value)
optional .SnapshotDescription snapshot = 1; |
MasterProtos.GetCompletedSnapshotsResponse.Builder |
MasterProtos.GetCompletedSnapshotsResponse.Builder.setSnapshots(int index,
HBaseProtos.SnapshotDescription value)
repeated .SnapshotDescription snapshots = 1; |
Modifier and Type | Method and Description |
---|---|
MasterProtos.GetCompletedSnapshotsResponse.Builder |
MasterProtos.GetCompletedSnapshotsResponse.Builder.addAllSnapshots(Iterable<? extends HBaseProtos.SnapshotDescription> values)
repeated .SnapshotDescription snapshots = 1; |
Modifier and Type | Method and Description |
---|---|
void |
HRegion.addRegionToSnapshot(HBaseProtos.SnapshotDescription desc,
ForeignExceptionSnare exnSnare)
Complete taking the snapshot on the region.
|
Modifier and Type | Method and Description |
---|---|
Subprocedure |
RegionServerSnapshotManager.buildSubprocedure(HBaseProtos.SnapshotDescription snapshot)
If in a running state, creates the specified subprocedure for handling an online snapshot.
|
Constructor and Description |
---|
FlushSnapshotSubprocedure(ProcedureMember member,
ForeignExceptionDispatcher errorListener,
long wakeFrequency,
long timeout,
List<Region> regions,
HBaseProtos.SnapshotDescription snapshot,
org.apache.hadoop.hbase.regionserver.snapshot.RegionServerSnapshotManager.SnapshotSubprocedurePool taskManager) |
Modifier and Type | Method and Description |
---|---|
void |
AccessController.preCloneSnapshot(ObserverContext<MasterCoprocessorEnvironment> ctx,
HBaseProtos.SnapshotDescription snapshot,
HTableDescriptor hTableDescriptor) |
void |
AccessController.preDeleteSnapshot(ObserverContext<MasterCoprocessorEnvironment> ctx,
HBaseProtos.SnapshotDescription snapshot) |
void |
AccessController.preListSnapshot(ObserverContext<MasterCoprocessorEnvironment> ctx,
HBaseProtos.SnapshotDescription snapshot) |
void |
AccessController.preRestoreSnapshot(ObserverContext<MasterCoprocessorEnvironment> ctx,
HBaseProtos.SnapshotDescription snapshot,
HTableDescriptor hTableDescriptor) |
void |
AccessController.preSnapshot(ObserverContext<MasterCoprocessorEnvironment> ctx,
HBaseProtos.SnapshotDescription snapshot,
HTableDescriptor hTableDescriptor) |
Modifier and Type | Method and Description |
---|---|
HBaseProtos.SnapshotDescription |
SnapshotManifest.getSnapshotDescription()
Get the SnapshotDescription
|
HBaseProtos.SnapshotDescription |
SnapshotInfo.SnapshotStats.getSnapshotDescription() |
HBaseProtos.SnapshotDescription |
HBaseSnapshotException.getSnapshotDescription() |
static HBaseProtos.SnapshotDescription |
SnapshotDescriptionUtils.readSnapshotInfo(org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.fs.Path snapshotDir)
Read in the
HBaseProtos.SnapshotDescription stored for the snapshot in the passed directory |
static HBaseProtos.SnapshotDescription |
SnapshotDescriptionUtils.validate(HBaseProtos.SnapshotDescription snapshot,
org.apache.hadoop.conf.Configuration conf)
Convert the passed snapshot description into a 'full' snapshot description based on default
parameters, if none have been supplied.
|
Modifier and Type | Method and Description |
---|---|
static List<HBaseProtos.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 |
---|---|
static void |
ClientSnapshotDescriptionUtils.assertSnapshotRequestIsValid(HBaseProtos.SnapshotDescription snapshot)
Check to make sure that the description of the snapshot requested is valid
|
static void |
SnapshotDescriptionUtils.completeSnapshot(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'.
|
static SnapshotManifest |
SnapshotManifest.create(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.fs.Path workingDir,
HBaseProtos.SnapshotDescription desc,
ForeignExceptionSnare monitor)
Return a SnapshotManifest instance, used for writing a snapshot.
|
static org.apache.hadoop.fs.Path |
SnapshotDescriptionUtils.getCompletedSnapshotDir(HBaseProtos.SnapshotDescription snapshot,
org.apache.hadoop.fs.Path rootDir)
Get the directory for a specified snapshot.
|
static SnapshotInfo.SnapshotStats |
SnapshotInfo.getSnapshotStats(org.apache.hadoop.conf.Configuration conf,
HBaseProtos.SnapshotDescription snapshot)
Returns the snapshot stats
|
static org.apache.hadoop.fs.Path |
SnapshotDescriptionUtils.getWorkingSnapshotDir(HBaseProtos.SnapshotDescription snapshot,
org.apache.hadoop.fs.Path rootDir)
Get the directory to build a snapshot, before it is finalized
|
static boolean |
SnapshotDescriptionUtils.isSnapshotOwner(HBaseProtos.SnapshotDescription snapshot,
User user)
Check if the user is this table snapshot's owner
|
static SnapshotManifest |
SnapshotManifest.open(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.fs.Path workingDir,
HBaseProtos.SnapshotDescription desc)
Return a SnapshotManifest instance with the information already loaded in-memory.
|
static String |
ClientSnapshotDescriptionUtils.toString(HBaseProtos.SnapshotDescription ssd)
Returns a single line (no \n) representation of snapshot metadata.
|
static HBaseProtos.SnapshotDescription |
SnapshotDescriptionUtils.validate(HBaseProtos.SnapshotDescription snapshot,
org.apache.hadoop.conf.Configuration conf)
Convert the passed snapshot description into a 'full' snapshot description based on default
parameters, if none have been supplied.
|
static void |
SnapshotReferenceUtil.verifySnapshot(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.fs.Path snapshotDir,
HBaseProtos.SnapshotDescription snapshotDesc)
Verify the validity of the snapshot
|
static void |
SnapshotReferenceUtil.visitReferencedFiles(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.fs.Path snapshotDir,
HBaseProtos.SnapshotDescription desc,
SnapshotReferenceUtil.SnapshotVisitor visitor)
Iterate over the snapshot store files, restored.edits and logs
|
static void |
SnapshotDescriptionUtils.writeSnapshotInfo(HBaseProtos.SnapshotDescription snapshot,
org.apache.hadoop.fs.Path workingDir,
org.apache.hadoop.fs.FileSystem fs)
Write the snapshot description into the working directory of a snapshot
|
Copyright © 2007-2016 The Apache Software Foundation. All Rights Reserved.