@InterfaceAudience.Private @InterfaceStability.Evolving public class DisabledTableSnapshotHandler extends TakeSnapshotHandler
Table must exist when taking the snapshot, or results are undefined.
Modifier and Type | Field and Description |
---|---|
private static org.slf4j.Logger |
LOG |
conf, htd, master, metricsSnapshot, monitor, rootDir, rootFs, snapshot, snapshotManager, snapshotManifest, snapshotTable, status, workingDir, workingDirFs
eventType, seqids, server, waitingTimeForEvents
Constructor and Description |
---|
DisabledTableSnapshotHandler(org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotDescription snapshot,
MasterServices masterServices,
SnapshotManager snapshotManager) |
Modifier and Type | Method and Description |
---|---|
protected boolean |
downgradeToSharedTableLock()
When taking snapshot, first we must acquire the exclusive table lock to confirm that there are
no ongoing merge/split procedures.
|
DisabledTableSnapshotHandler |
prepare()
Event handlers should do all the necessary checks in this method (rather than in the
constructor, or in process()) so that the caller, which is mostly executed in the ipc context
can fail fast.
|
void |
snapshotRegions(List<Pair<RegionInfo,ServerName>> regionsAndLocations)
Snapshot the specified regions
|
cancel, getCompletionTimestamp, getException, getExceptionIfFailed, getSnapshot, hasException, isFinished, process, rethrowException, rethrowExceptionIfFailed, snapshotDisabledRegion
compareTo, getEventType, getInformativeName, getPriority, getSeqid, handleException, run, toString
private static final org.slf4j.Logger LOG
public DisabledTableSnapshotHandler(org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotDescription snapshot, MasterServices masterServices, SnapshotManager snapshotManager) throws IOException
snapshot
- descriptor of the snapshot to takemasterServices
- master services providerIOException
- if it cannot access the filesystem of the snapshot temporary directorypublic DisabledTableSnapshotHandler prepare() throws Exception
EventHandler
prepare
in class TakeSnapshotHandler
Exception
- when something goes wrongpublic void snapshotRegions(List<Pair<RegionInfo,ServerName>> regionsAndLocations) throws IOException, org.apache.zookeeper.KeeperException
TakeSnapshotHandler
snapshotRegions
in class TakeSnapshotHandler
IOException
org.apache.zookeeper.KeeperException
protected boolean downgradeToSharedTableLock()
TakeSnapshotHandler
downgradeToSharedTableLock
in class TakeSnapshotHandler
Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.