Modifier and Type | Field and Description |
---|---|
private ForeignException |
ForeignExceptionDispatcher.exception |
Modifier and Type | Method and Description |
---|---|
static ForeignException |
ForeignException.deserialize(byte[] bytes)
Takes a series of bytes and tries to generate an ForeignException instance for it.
|
ForeignException |
ForeignExceptionDispatcher.getException() |
ForeignException |
ForeignExceptionSnare.getException()
Get the value of the captured exception.
|
Modifier and Type | Method and Description |
---|---|
private void |
ForeignExceptionDispatcher.dispatch(ForeignException e)
Sends an exception to all listeners.
|
void |
ForeignExceptionDispatcher.receive(ForeignException e) |
void |
ForeignExceptionListener.receive(ForeignException e)
Receive a ForeignException.
|
Modifier and Type | Method and Description |
---|---|
void |
ForeignExceptionDispatcher.rethrowException() |
void |
ForeignExceptionSnare.rethrowException()
Rethrow an exception currently held by the
ForeignExceptionSnare . |
Modifier and Type | Method and Description |
---|---|
ForeignException |
SnapshotSentinel.getExceptionIfFailed()
Get the exception that caused the snapshot to fail, if the snapshot has failed.
|
Modifier and Type | Method and Description |
---|---|
void |
SnapshotSentinel.rethrowExceptionIfFailed()
Rethrow the exception returned by
SnapshotSentinel.getExceptionIfFailed() . |
Modifier and Type | Method and Description |
---|---|
ForeignException |
TakeSnapshotHandler.getException() |
ForeignException |
TakeSnapshotHandler.getExceptionIfFailed() |
Modifier and Type | Method and Description |
---|---|
void |
TakeSnapshotHandler.rethrowException() |
void |
TakeSnapshotHandler.rethrowExceptionIfFailed() |
Modifier and Type | Method and Description |
---|---|
void |
ProcedureCoordinator.abortProcedure(String procName,
ForeignException reason)
Abort the procedure with the given name
|
void |
Procedure.receive(ForeignException e)
A callback that handles incoming ForeignExceptions.
|
void |
ProcedureMember.receiveAbortProcedure(String procName,
ForeignException ee)
Send abort to the specified procedure
|
void |
ZKProcedureCoordinator.sendAbortToMembers(Procedure proc,
ForeignException ee)
This is the abort message being sent by the coordinator to member
TODO this code isn't actually used but can be used to issue a cancellation from the
coordinator.
|
void |
ProcedureCoordinatorRpcs.sendAbortToMembers(Procedure procName,
ForeignException cause)
Notify the members that the coordinator has aborted the procedure and that it should release
barrier resources.
|
void |
ProcedureMemberRpcs.sendMemberAborted(Subprocedure sub,
ForeignException cause)
Notify the coordinator that we aborted the specified
Subprocedure |
void |
ZKProcedureMemberRpcs.sendMemberAborted(Subprocedure sub,
ForeignException ee)
This should be called by the member and should write a serialized root cause exception as
to the abort znode.
|
Modifier and Type | Method and Description |
---|---|
abstract void |
Subprocedure.acquireBarrier()
The implementation of this method should gather and hold required resources (locks, disk
space, etc) to satisfy the Procedures barrier condition.
|
void |
Subprocedure.SubprocedureImpl.acquireBarrier() |
abstract byte[] |
Subprocedure.insideBarrier()
The implementation of this method should act with the assumption that the barrier condition
has been satisfied.
|
byte[] |
Subprocedure.SubprocedureImpl.insideBarrier() |
boolean |
Procedure.isCompleted()
Check if the entire procedure has globally completed, or has been aborted.
|
private void |
Subprocedure.rethrowException() |
void |
Procedure.sendGlobalBarrierReached()
Sends a message to all members that the global barrier condition has been satisfied.
|
void |
Procedure.sendGlobalBarrierStart()
Sends a message to Members to create a new
Subprocedure for this Procedure and execute
the Subprocedure.acquireBarrier() step. |
void |
Procedure.waitForCompleted()
Waits until the entire procedure has globally completed, or has been aborted.
|
HashMap<String,byte[]> |
Procedure.waitForCompletedWithRet()
Waits until the entire procedure has globally completed, or has been aborted.
|
static void |
Procedure.waitForLatch(CountDownLatch latch,
ForeignExceptionSnare monitor,
long wakeFrequency,
String latchDescription)
Wait for latch to count to zero, ignoring any spurious wake-ups, but waking periodically to
check for errors
|
void |
Subprocedure.waitForLocallyCompleted()
Waits until the entire procedure has globally completed, or has been aborted.
|
(package private) void |
Subprocedure.waitForReachedGlobalBarrier()
Wait for the reached global barrier notification.
|
Modifier and Type | Method and Description |
---|---|
void |
FlushTableSubprocedure.acquireBarrier()
Flush the online regions on this rs for the target table.
|
private void |
FlushTableSubprocedure.flushRegions() |
byte[] |
FlushTableSubprocedure.insideBarrier() |
(package private) boolean |
RegionServerFlushTableProcedureManager.FlushTableSubprocedurePool.waitForOutstandingTasks()
Wait for all of the currently outstanding tasks submitted via
RegionServerFlushTableProcedureManager.FlushTableSubprocedurePool.submitTask(Callable) . |
Modifier and Type | Method and Description |
---|---|
void |
FlushSnapshotSubprocedure.acquireBarrier()
do nothing, core of snapshot is executed in
FlushSnapshotSubprocedure.insideBarrier() step. |
private void |
FlushSnapshotSubprocedure.flushSnapshot() |
byte[] |
FlushSnapshotSubprocedure.insideBarrier()
do a flush snapshot of every region on this rs from the target table.
|
(package private) boolean |
RegionServerSnapshotManager.SnapshotSubprocedurePool.waitForOutstandingTasks()
Wait for all of the currently outstanding tasks submitted via
RegionServerSnapshotManager.SnapshotSubprocedurePool.submitTask(Callable) . |
Copyright © 2007–2019 The Apache Software Foundation. All rights reserved.