Uses of Class
org.apache.hadoop.hbase.errorhandling.ForeignException
Packages that use ForeignException
Package
Description
-
Uses of ForeignException in org.apache.hadoop.hbase.backup.regionserver
Methods in org.apache.hadoop.hbase.backup.regionserver that throw ForeignExceptionModifier and TypeMethodDescriptionbyte[]LogRollBackupSubprocedure.insideBarrier()do a log roll.private voidLogRollBackupSubprocedure.rolllog()booleanLogRollBackupSubprocedurePool.waitForOutstandingTasks()Wait for all of the currently outstanding tasks submitted viaLogRollBackupSubprocedurePool.submitTask(Callable) -
Uses of ForeignException in org.apache.hadoop.hbase.errorhandling
Fields in org.apache.hadoop.hbase.errorhandling declared as ForeignExceptionMethods in org.apache.hadoop.hbase.errorhandling that return ForeignExceptionModifier and TypeMethodDescriptionstatic ForeignExceptionForeignException.deserialize(byte[] bytes) Takes a series of bytes and tries to generate an ForeignException instance for it.ForeignExceptionDispatcher.getException()ForeignExceptionSnare.getException()Get the value of the captured exception.Methods in org.apache.hadoop.hbase.errorhandling with parameters of type ForeignExceptionModifier and TypeMethodDescriptionprivate voidForeignExceptionDispatcher.dispatch(ForeignException e) Sends an exception to all listeners.voidForeignExceptionDispatcher.receive(ForeignException e) voidForeignExceptionListener.receive(ForeignException e) Receive a ForeignException.Methods in org.apache.hadoop.hbase.errorhandling that throw ForeignExceptionModifier and TypeMethodDescriptionvoidForeignExceptionDispatcher.rethrowException()voidForeignExceptionSnare.rethrowException()Rethrow an exception currently held by theForeignExceptionSnare. -
Uses of ForeignException in org.apache.hadoop.hbase.master
Methods in org.apache.hadoop.hbase.master that return ForeignExceptionModifier and TypeMethodDescriptionSnapshotSentinel.getExceptionIfFailed()Get the exception that caused the snapshot to fail, if the snapshot has failed.Methods in org.apache.hadoop.hbase.master that throw ForeignExceptionModifier and TypeMethodDescriptionvoidSnapshotSentinel.rethrowExceptionIfFailed()Rethrow the exception returned bySnapshotSentinel.getExceptionIfFailed(). -
Uses of ForeignException in org.apache.hadoop.hbase.master.snapshot
Methods in org.apache.hadoop.hbase.master.snapshot that return ForeignExceptionModifier and TypeMethodDescriptionTakeSnapshotHandler.getException()TakeSnapshotHandler.getExceptionIfFailed()Methods in org.apache.hadoop.hbase.master.snapshot that throw ForeignExceptionModifier and TypeMethodDescriptionvoidTakeSnapshotHandler.rethrowException()voidTakeSnapshotHandler.rethrowExceptionIfFailed() -
Uses of ForeignException in org.apache.hadoop.hbase.procedure
Methods in org.apache.hadoop.hbase.procedure with parameters of type ForeignExceptionModifier and TypeMethodDescriptionvoidProcedureCoordinator.abortProcedure(String procName, ForeignException reason) Abort the procedure with the given namevoidProcedure.receive(ForeignException e) A callback that handles incoming ForeignExceptions.voidProcedureMember.receiveAbortProcedure(String procName, ForeignException ee) Send abort to the specified procedurevoidProcedureCoordinatorRpcs.sendAbortToMembers(Procedure procName, ForeignException cause) Notify the members that the coordinator has aborted the procedure and that it should release barrier resources.final voidZKProcedureCoordinator.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.voidProcedureMemberRpcs.sendMemberAborted(Subprocedure sub, ForeignException cause) Notify the coordinator that we aborted the specifiedSubprocedurevoidZKProcedureMemberRpcs.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.Methods in org.apache.hadoop.hbase.procedure that throw ForeignExceptionModifier and TypeMethodDescriptionabstract voidSubprocedure.acquireBarrier()The implementation of this method should gather and hold required resources (locks, disk space, etc) to satisfy the Procedures barrier condition.voidSubprocedure.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()booleanProcedure.isCompleted()Check if the entire procedure has globally completed, or has been aborted.private voidSubprocedure.rethrowException()voidProcedure.sendGlobalBarrierReached()Sends a message to all members that the global barrier condition has been satisfied.voidProcedure.sendGlobalBarrierStart()Sends a message to Members to create a newSubprocedurefor this Procedure and execute theSubprocedure.acquireBarrier()step.voidProcedure.waitForCompleted()Waits until the entire procedure has globally completed, or has been aborted.Procedure.waitForCompletedWithRet()Waits until the entire procedure has globally completed, or has been aborted.static voidProcedure.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 errorsvoidSubprocedure.waitForLocallyCompleted()Waits until the entire procedure has globally completed, or has been aborted.(package private) voidSubprocedure.waitForReachedGlobalBarrier()Wait for the reached global barrier notification. -
Uses of ForeignException in org.apache.hadoop.hbase.procedure.flush
Methods in org.apache.hadoop.hbase.procedure.flush that throw ForeignExceptionModifier and TypeMethodDescriptionvoidFlushTableSubprocedure.acquireBarrier()Flush the online regions on this rs for the target table.private voidFlushTableSubprocedure.flushRegions()byte[]FlushTableSubprocedure.insideBarrier()(package private) booleanRegionServerFlushTableProcedureManager.FlushTableSubprocedurePool.waitForOutstandingTasks()Wait for all of the currently outstanding tasks submitted viaRegionServerFlushTableProcedureManager.FlushTableSubprocedurePool.submitTask(Callable). -
Uses of ForeignException in org.apache.hadoop.hbase.regionserver.snapshot
Methods in org.apache.hadoop.hbase.regionserver.snapshot that throw ForeignExceptionModifier and TypeMethodDescriptionvoidFlushSnapshotSubprocedure.acquireBarrier()do nothing, core of snapshot is executed inFlushSnapshotSubprocedure.insideBarrier()step.private voidFlushSnapshotSubprocedure.flushSnapshot()byte[]FlushSnapshotSubprocedure.insideBarrier()do a flush snapshot of every region on this rs from the target table.(package private) booleanRegionServerSnapshotManager.SnapshotSubprocedurePool.waitForOutstandingTasks()Wait for all of the currently outstanding tasks submitted viaRegionServerSnapshotManager.SnapshotSubprocedurePool.submitTask(Callable).