Uses of Class
org.apache.hadoop.hbase.procedure2.Procedure
Package
Description
-
Uses of Procedure in org.apache.hadoop.hbase.master
Modifier and TypeMethodDescriptionSplitWALManager.createSplitWALProcedures
(List<org.apache.hadoop.fs.FileStatus> splittingWALs, ServerName crashedServer) HMaster.getProcedures()
MasterServices.getProcedures()
Get proceduresSplitWALManager.splitWALs
(ServerName crashedServer, boolean splitMeta) Modifier and TypeMethodDescriptionSplitWALManager.acquireSplitWALWorker
(Procedure<?> procedure) Acquire a split WAL workerprivate long
ClusterSchemaServiceImpl.submitProcedure
(Procedure<MasterProcedureEnv> procedure, NonceKey nonceKey) void
Modifier and TypeMethodDescriptionvoid
MasterCoprocessorHost.postGetProcedures
(List<Procedure<?>> procInfoList) -
Uses of Procedure in org.apache.hadoop.hbase.master.assignment
Modifier and TypeClassDescriptionprivate static class
private static class
class
Deprecated.Do not use any more.class
The remote procedure used to close a region.class
Deprecated.2.3.0 UseGCMultipleMergedRegionsProcedure
.class
GC regions that have been Merged.class
GC a Region that is no longer in use.class
The procedure to Merge regions in a table.class
Deprecated.Do not use any more.class
The remote procedure used to open a region.class
The base class for the remote procedures used to open/close a region.class
Deprecated.Do not use any more.class
The procedure to split a region in a table.class
The procedure to deal with the state transition of a region.class
Deprecated.Do not use any more.Modifier and TypeMethodDescriptionprotected Procedure<MasterProcedureEnv>[]
RegionRemoteProcedureBase.execute
(MasterProcedureEnv env) protected Procedure[]
RegionTransitionProcedure.execute
(MasterProcedureEnv env) Deprecated.protected Procedure[]
TransitRegionStateProcedure.execute
(MasterProcedureEnv env) Modifier and TypeMethodDescriptionboolean
RegionStateNode.isLockedBy
(Procedure<?> proc) void
(package private) void
Lock by a procedure.boolean
(package private) boolean
TryLock by a procedure.void
(package private) void
Unlock by a procedure.boolean
AssignmentManager.waitMetaAssigned
(Procedure<?> proc, RegionInfo regionInfo) Notice that this event does not mean the AM has already finished region state rebuilding.boolean
AssignmentManager.waitMetaLoaded
(Procedure<?> proc) Wait until AM finishes the meta loading, i.e, the region states rebuilding. -
Uses of Procedure in org.apache.hadoop.hbase.master.locking
Modifier and TypeClassDescriptionfinal class
Procedure to allow blessed clients and external admin tools to take our internal Schema locks used by the procedure framework isolating procedures doing creates/deletes etc.Modifier and TypeMethodDescriptionprotected Procedure<MasterProcedureEnv>[]
LockProcedure.execute
(MasterProcedureEnv env) -
Uses of Procedure in org.apache.hadoop.hbase.master.procedure
Modifier and TypeClassDescriptionclass
AbstractCloseTableRegionsProcedure<TState extends Enum<?>>
Base class for unassigning table regions.class
Base class for all the Namespace procedures that want to use a StateMachineProcedure.class
Base class for all the Region procedures that want to use a StateMachine.class
Base class for all the Table procedures that want to use a StateMachineProcedure.class
class
Procedure for close excess region replicas.class
Procedure for closing all regions for a table.class
The procedure to create a new namespace.class
class
The procedure to remove a namespace.class
class
class
class
class
class
Acts like the super class in all cases except when no Regions found in the current Master in-memory context.class
This procedure is used to initialize meta table for a new hbase deploy.class
Migrate the namespace data to meta table's namespace family while upgradingclass
The procedure to add a namespace to an existing table.class
The procedure will only update the table descriptor without reopening all the regions.class
class
Deprecated.Do not use any more, leave it here only for compatible.class
Used for reopening the regions for a table.class
class
Handle crashed server.class
class
A procedure used to take snapshot on tables.class
A remote procedure which is used to send region snapshot request to region server.class
A remote procedure which is used to send verify snapshot request to region server.class
The procedure is to split a WAL.class
A remote procedure which is used to send split WAL request to region server.class
The procedure to switch rpc throttleclass
The procedure to switch rpc throttle on region serverclass
class
Modifier and TypeFieldDescriptionprivate Procedure<?>
TableProcedureWaitingQueue.enqueuedProc
private final Procedure<?>
ProcedureSyncWait.ProcedureFuture.proc
Modifier and TypeFieldDescriptionMasterProcedureScheduler.procedureRetriever
SchemaLocking.procedureRetriever
TableProcedureWaitingQueue.procedureRetriever
TableProcedureWaitingQueue.queue
Modifier and TypeMethodDescriptionprivate Procedure<MasterProcedureEnv>[]
SnapshotProcedure.createRemoteSnapshotProcedures
(MasterProcedureEnv env) private Procedure[]
ServerCrashProcedure.createSplittingWalProcedures
(MasterProcedureEnv env, boolean splitMeta) protected Procedure
MasterProcedureScheduler.dequeue()
private <T extends Comparable<T>>
Procedure<?>protected Procedure<MasterProcedureEnv>[]
FlushRegionProcedure.execute
(MasterProcedureEnv env) protected Procedure<MasterProcedureEnv>[]
ServerRemoteProcedure.execute
(MasterProcedureEnv env) protected Procedure<MasterProcedureEnv>[]
SnapshotRegionProcedure.execute
(MasterProcedureEnv env) protected Procedure<MasterProcedureEnv>[]
SnapshotVerifyProcedure.execute
(MasterProcedureEnv env) Procedure<?>
Queue.peek()
Procedure<?>
Queue.poll()
Modifier and TypeMethodDescriptionTableProcedureWaitingQueue.procedureCompleted
(Procedure<?> proc) Return the next procedure which can be enqueued to ProcedureScheduler.Modifier and TypeMethodDescriptionvoid
void
MasterProcedureScheduler.completionCleanup
(Procedure proc) protected void
protected abstract void
protected void
static String
static String
ProcedureDescriber.describeParameters
(Procedure<?> proc) private <T extends Comparable<T>>
voidMasterProcedureScheduler.doAdd
(FairQueue<T> fairq, Queue<T> queue, Procedure<?> proc, boolean addFront) protected void
private static String
MasterProcedureScheduler.getGlobalId
(Procedure<?> proc) private static String
private static ServerName
MasterProcedureScheduler.getServerName
(Procedure<?> proc) private static TableName
MasterProcedureScheduler.getTableName
(Procedure<?> proc) private static boolean
MasterProcedureScheduler.isGlobalProcedure
(Procedure<?> proc) private <T extends Comparable<T>>
booleanMasterProcedureScheduler.isLockReady
(Procedure<?> proc, Queue<T> rq) private static boolean
MasterProcedureScheduler.isMetaProcedure
(Procedure<?> proc) private static boolean
MasterProcedureScheduler.isPeerProcedure
(Procedure<?> proc) private static boolean
MasterProcedureScheduler.isServerProcedure
(Procedure<?> proc) private boolean
TableProcedureWaitingQueue.isSubProcedure
(Procedure<?> proc) private static boolean
MasterProcedureScheduler.isTableProcedure
(Procedure<?> proc) (package private) boolean
MasterProcedureScheduler.markTableAsDeleted
(TableName table, Procedure<?> procedure) Tries to remove the queue and the table-lock of the specified table.private static Object
ProcedureDescriber.parametersToObject
(Procedure<?> proc) TableProcedureWaitingQueue.procedureCompleted
(Procedure<?> proc) Return the next procedure which can be enqueued to ProcedureScheduler.(package private) boolean
TableProcedureWaitingQueue.procedureSubmitted
(Procedure<?> proc) Return whether we can enqueue this procedure to ProcedureScheduler.static void
ProcedurePrepareLatch.releaseLatch
(ProcedurePrepareLatch latch, Procedure proc) (package private) boolean
GlobalQueue.requireExclusiveLock
(Procedure<?> proc) (package private) boolean
MetaQueue.requireExclusiveLock
(Procedure<?> proc) Deprecated.boolean
PeerQueue.requireExclusiveLock
(Procedure<?> proc) (package private) abstract boolean
Queue.requireExclusiveLock
(Procedure<?> proc) boolean
ServerQueue.requireExclusiveLock
(Procedure<?> proc) boolean
TableQueue.requireExclusiveLock
(Procedure<?> proc) static byte[]
ProcedureSyncWait.submitAndWaitProcedure
(ProcedureExecutor<MasterProcedureEnv> procExec, Procedure<MasterProcedureEnv> proc) protected long
MasterProcedureUtil.NonceProcedureRunnable.submitProcedure
(Procedure<MasterProcedureEnv> proc) static Future<byte[]>
ProcedureSyncWait.submitProcedure
(ProcedureExecutor<MasterProcedureEnv> procExec, Procedure<MasterProcedureEnv> proc) private void
MasterProcedureScheduler.tryCleanupGlobalQueue
(String globalId, Procedure<?> procedure) private void
MasterProcedureScheduler.tryCleanupPeerQueue
(String peerId, Procedure<?> procedure) private void
MasterProcedureScheduler.tryCleanupServerQueue
(ServerName serverName, Procedure<?> proc) static IOException
MasterProcedureUtil.unwrapRemoteIOException
(Procedure<?> proc) This is a version of unwrapRemoteIOException that can do DoNotRetryIOE.static byte[]
ProcedureSyncWait.waitForProcedureToComplete
(ProcedureExecutor<MasterProcedureEnv> procExec, Procedure<?> proc, long timeout) static byte[]
ProcedureSyncWait.waitForProcedureToCompleteIOE
(ProcedureExecutor<MasterProcedureEnv> procExec, Procedure<?> proc, long timeout) boolean
MasterProcedureScheduler.waitGlobalExclusiveLock
(Procedure<?> procedure, String globalId) Try to acquire the share lock on global.boolean
MasterProcedureEnv.waitInitialized
(Procedure<?> proc) boolean
MasterProcedureScheduler.waitMetaExclusiveLock
(Procedure<?> procedure) Deprecated.only used forRecoverMetaProcedure
.boolean
MasterProcedureScheduler.waitNamespaceExclusiveLock
(Procedure<?> procedure, String namespace) Suspend the procedure if the specified namespace is already locked.boolean
MasterProcedureScheduler.waitPeerExclusiveLock
(Procedure<?> procedure, String peerId) Try to acquire the exclusive lock on the specified peer.boolean
MasterProcedureScheduler.waitRegion
(Procedure<?> procedure, RegionInfo regionInfo) Suspend the procedure if the specified region is already locked.boolean
MasterProcedureScheduler.waitRegions
(Procedure<?> procedure, TableName table, RegionInfo... regionInfos) Suspend the procedure if the specified set of regions are already locked.boolean
MasterProcedureScheduler.waitServerExclusiveLock
(Procedure<?> procedure, ServerName serverName) Try to acquire the exclusive lock on the specified server.boolean
MasterProcedureScheduler.waitTableExclusiveLock
(Procedure<?> procedure, TableName table) Suspend the procedure if the specified table is already locked.private TableQueue
MasterProcedureScheduler.waitTableQueueSharedLock
(Procedure<?> procedure, TableName table) boolean
MasterProcedureScheduler.waitTableSharedLock
(Procedure<?> procedure, TableName table) Suspend the procedure if the specified table is already locked.void
MasterProcedureScheduler.wakeGlobalExclusiveLock
(Procedure<?> procedure, String globalId) Wake the procedures waiting for global.void
MasterProcedureScheduler.wakeMetaExclusiveLock
(Procedure<?> procedure) Deprecated.only used forRecoverMetaProcedure
.void
MasterProcedureScheduler.wakeNamespaceExclusiveLock
(Procedure<?> procedure, String namespace) Wake the procedures waiting for the specified namespacevoid
MasterProcedureScheduler.wakePeerExclusiveLock
(Procedure<?> procedure, String peerId) Wake the procedures waiting for the specified peervoid
MasterProcedureScheduler.wakeRegion
(Procedure<?> procedure, RegionInfo regionInfo) Wake the procedures waiting for the specified regionvoid
MasterProcedureScheduler.wakeRegions
(Procedure<?> procedure, TableName table, RegionInfo... regionInfos) Wake the procedures waiting for the specified regionsvoid
MasterProcedureScheduler.wakeServerExclusiveLock
(Procedure<?> procedure, ServerName serverName) Wake the procedures waiting for the specified servervoid
MasterProcedureScheduler.wakeTableExclusiveLock
(Procedure<?> procedure, TableName table) Wake the procedures waiting for the specified tablevoid
MasterProcedureScheduler.wakeTableSharedLock
(Procedure<?> procedure, TableName table) Wake the procedures waiting for the specified tablevoid
ModifierConstructorDescriptionProcedureFuture
(ProcedureExecutor<MasterProcedureEnv> procExec, Procedure<?> proc) ModifierConstructorDescriptionMasterProcedureScheduler
(Function<Long, Procedure<?>> procedureRetriever) SchemaLocking
(Function<Long, Procedure<?>> procedureRetriever) (package private)
TableProcedureWaitingQueue
(Function<Long, Procedure<?>> procedureRetriever) -
Uses of Procedure in org.apache.hadoop.hbase.master.replication
Modifier and TypeClassDescriptionclass
AbstractPeerNoLockProcedure<TState>
Base class for replication peer related procedures which do not need to hold locks(for most of the sub procedures).class
AbstractPeerProcedure<TState>
The base class for all replication peer related procedure.class
The procedure for adding a new replication peer.class
class
class
Deprecated.UseAssignReplicationQueuesProcedure
instead, kept only for keeping compatibility.class
The procedure for disabling a replication peer.class
The procedure for enabling a replication peer.class
A procedure for migrating replication queue data from zookeeper to hbase:replication table.class
The base class for all replication peer related procedure except sync replication state transition.class
The procedure for replaying all the remote wals for transitting a sync replication peer from STANDBY to DOWNGRADE_ACTIVE.class
class
The procedure for removing a replication peer.class
The procedure for replaying a set of remote wals.class
A remote procedure which is used to send replaying remote wal work to region server.class
The procedure for transit current sync replication state for a synchronous replication peer.class
The procedure for updating the config for a replication peer.Modifier and TypeMethodDescriptionprotected Procedure<MasterProcedureEnv>[]
ClaimReplicationQueueRemoteProcedure.execute
(MasterProcedureEnv env) protected Procedure<MasterProcedureEnv>[]
ClaimReplicationQueuesProcedure.execute
(MasterProcedureEnv env) Deprecated.Modifier and TypeMethodDescriptionSyncReplicationReplayWALManager.acquirePeerWorker
(String peerId, Procedure<?> proc) Get a worker for replaying remote wal for a give peer.void
-
Uses of Procedure in org.apache.hadoop.hbase.procedure2
Modifier and TypeClassDescription(package private) class
CompletedProcedureCleaner<TEnvironment>
Internal cleaner that removes the completed procedure results after a TTL.class
FailedProcedure<TEnvironment>
class
OnePhaseProcedure<TEnvironment>
class
ProcedureInMemoryChore<TEnvironment>
Special procedure used as a chore.class
SequentialProcedure<TEnvironment>
A SequentialProcedure describes one step in a procedure chain:class
StateMachineProcedure<TEnvironment,
TState> Procedure described by a series of steps.class
TwoPhaseProcedure<TEnvironment>
Modifier and TypeFieldDescriptionprivate Procedure<TEnvironment>
ProcedureExecutor.WorkerThread.activeProcedure
private Procedure<?>
LockAndQueue.exclusiveLockOwnerProcedure
private final Procedure<?>
LockedResource.exclusiveLockOwnerProcedure
private final Procedure<TEnvironment>
CompletedProcedureRetainer.procedure
Modifier and TypeFieldDescriptionLockAndQueue.procedureRetriever
private final ConcurrentHashMap<Long,
Procedure<TEnvironment>> ProcedureExecutor.procedures
Helper map to lookup the live procedures by ID.private List<Procedure<TEnvironment>>
StateMachineProcedure.subProcList
private Set<Procedure<TEnvironment>>
RootProcedureState.subprocs
private ArrayList<Procedure<TEnvironment>>
RootProcedureState.subprocStack
LockedResource.waitingProcedures
Modifier and TypeMethodDescriptionprotected <T extends Procedure<TEnvironment>>
voidStateMachineProcedure.addChildProcedure
(T... subProcedure) Add a child procedure to execute<T extends Procedure<TEnvironment>>
TProcedureExecutor.getProcedure
(Class<T> clazz, long procId) Modifier and TypeMethodDescriptionstatic Procedure<?>
ProcedureUtil.convertToProcedure
(org.apache.hadoop.hbase.shaded.protobuf.generated.ProcedureProtos.Procedure proto) Helper to convert the protobuf procedure.protected abstract Procedure
AbstractProcedureScheduler.dequeue()
Fetch one Procedure from the queue NOTE: this method is called with the sched lock held.protected Procedure
SimpleProcedureScheduler.dequeue()
protected Procedure<TEnvironment>[]
Procedure.doExecute
(TEnvironment env) Internal method called by the ProcedureExecutor that starts the user-level code execute().protected Procedure[]
SequentialProcedure.doExecute
(TEnvironment env) protected Procedure<TEnvironment>[]
FailedProcedure.execute
(TEnvironment env) protected abstract Procedure<TEnvironment>[]
Procedure.execute
(TEnvironment env) The main code of the procedure.protected Procedure<TEnvironment>[]
ProcedureInMemoryChore.execute
(TEnvironment env) protected Procedure[]
StateMachineProcedure.execute
(TEnvironment env) Procedure<?>
LockAndQueue.getExclusiveLockOwnerProcedure()
Procedure<?>
LockedResource.getExclusiveLockOwnerProcedure()
Procedure<?>
LockStatus.getExclusiveLockOwnerProcedure()
Get the procedure which holds the exclusive lock.CompletedProcedureRetainer.getProcedure()
ProcedureExecutor.getProcedure
(long procId) ProcedureExecutor.getResult
(long procId) ProcedureExecutor.getResultOrProcedure
(long procId) private Procedure<TEnvironment>[]
ProcedureExecutor.initializeChildren
(RootProcedureState<TEnvironment> procStack, Procedure<TEnvironment> procedure, Procedure<TEnvironment>[] subprocs) private static Procedure<?>
ProcedureUtil.newProcedure
(String className) AbstractProcedureScheduler.poll()
AbstractProcedureScheduler.poll
(long nanos) ProcedureScheduler.poll()
Fetch one Procedure from the queueFetch one Procedure from the queueprivate Procedure<TEnvironment>
ProcedureExecutor.prepareProcedure
(Procedure<TEnvironment> proc) Procedure<?>
LockAndQueue.removeFirst()
Modifier and TypeMethodDescriptionLockAndQueue.filterWaitingQueue
(Predicate<Procedure> predicate) ProcedureExecutor.getActiveProceduresNoCopy()
Should only be used when starting up, where the procedure workers have not been started.ProcedureExecutor.getProcedures()
Get procedures.protected List<Procedure<TEnvironment>>
RootProcedureState.getSubproceduresStack()
protected Collection<Procedure<TEnvironment>>
RootProcedureState.getSubprocs()
LockedResource.getWaitingProcedures()
Modifier and TypeMethodDescriptionprotected boolean
RootProcedureState.acquire
(Procedure<TEnvironment> proc) Called by the ProcedureExecutor to mark the procedure step as running.private Procedure.LockState
ProcedureExecutor.acquireLock
(Procedure<TEnvironment> proc) void
TimeoutExecutorThread.add
(Procedure<TEnvironment> procedure) void
void
void
Inserts the specified element at the end of this queue.void
Inserts the specified element at the end of this queue.protected <T extends Procedure<TEnvironment>>
voidStateMachineProcedure.addChildProcedure
(T... subProcedure) Add a child procedure to executevoid
void
void
Inserts the specified element at the front of this queue.void
Inserts the specified element at the front of this queue.void
protected boolean
RootProcedureState.addRollbackStep
(Procedure<TEnvironment> proc) Called by the ProcedureExecutor after the procedure step is completed, to add the step to the rollback list (or procedure stack).protected void
RootProcedureState.addSubProcedure
(Procedure<TEnvironment> proc) static boolean
ProcedureFutureUtil.checkFuture
(Procedure<?> proc, Supplier<CompletableFuture<Void>> getFuture, Consumer<CompletableFuture<Void>> setFuture, Runnable actionAfterDone) private void
ProcedureExecutor.cleanupAfterRollbackOneStep
(Procedure<TEnvironment> proc) int
Procedure.compareTo
(Procedure<TEnvironment> other) void
ProcedureScheduler.completionCleanup
(Procedure proc) The procedure in execution completed.void
SimpleProcedureScheduler.completionCleanup
(Procedure proc) static org.apache.hadoop.hbase.shaded.protobuf.generated.ProcedureProtos.Procedure
ProcedureUtil.convertToProtoProcedure
(Procedure<?> proc) Helper to convert the procedure to protobuf.private void
ProcedureExecutor.countDownChildren
(RootProcedureState<TEnvironment> procStack, Procedure<TEnvironment> procedure) protected abstract void
Add the procedure to the queue.protected void
private void
ProcedureExecutor.execCompletionCleanup
(Procedure<TEnvironment> proc) private void
ProcedureExecutor.execProcedure
(RootProcedureState<TEnvironment> procStack, Procedure<TEnvironment> procedure) Executesprocedure
Calls the doExecute() of the procedure If the procedure execution didn't fail (i.e.private Procedure.LockState
ProcedureExecutor.executeNormalRollback
(Procedure<TEnvironment> rootProc, RootProcedureState<TEnvironment> procStack) private void
ProcedureExecutor.executeProcedure
(Procedure<TEnvironment> proc) private Procedure.LockState
ProcedureExecutor.executeRollback
(Procedure<TEnvironment> proc) Execute the rollback of the procedure step.protected void
TimeoutExecutorThread.executeTimedoutProcedure
(Procedure<TEnvironment> proc) private void
ProcedureExecutor.executeUnexpectedRollback
(Procedure<TEnvironment> rootProc, RootProcedureState<TEnvironment> procStack) protected static <T> Long
Procedure.getRootProcedureId
(Map<Long, Procedure<T>> procedures, Procedure<T> proc) Helper to lookup the root Procedure ID given a specified procedure.(package private) Long
ProcedureExecutor.getRootProcedureId
(Procedure<TEnvironment> proc) private void
ProcedureExecutor.handleInterruptedException
(Procedure<TEnvironment> proc, InterruptedException e) boolean
LockAndQueue.hasLockAccess
(Procedure<?> proc) boolean
LockStatus.hasLockAccess
(Procedure<?> proc) Return true if the procedure itself holds the exclusive lock, or any ancestors of the give procedure hold the exclusive lock.static boolean
Procedure.haveSameParent
(Procedure<?> a, Procedure<?> b) private Procedure<TEnvironment>[]
ProcedureExecutor.initializeChildren
(RootProcedureState<TEnvironment> procStack, Procedure<TEnvironment> procedure, Procedure<TEnvironment>[] subprocs) private boolean
ProcedureExecutor.isRootFinished
(Procedure<?> proc) protected void
RootProcedureState.loadStack
(Procedure<TEnvironment> proc) Called on store load by the ProcedureExecutor to load part of the stack.private Procedure<TEnvironment>
ProcedureExecutor.prepareProcedure
(Procedure<TEnvironment> proc) protected void
private long
ProcedureExecutor.pushProcedure
(Procedure<TEnvironment> proc) protected void
RootProcedureState.release
(Procedure<TEnvironment> proc) Called by the ProcedureExecutor to mark the procedure step as finished.boolean
LockAndQueue.releaseExclusiveLock
(Procedure<?> proc) Returns whether we should wake the procedures waiting on the lock here.private void
ProcedureExecutor.releaseLock
(Procedure<TEnvironment> proc, boolean force) boolean
TimeoutExecutorThread.remove
(Procedure<TEnvironment> procedure) private void
ProcedureExecutor.restoreLock
(Procedure<TEnvironment> proc, Set<Long> restored) private void
ProcedureExecutor.rootProcedureFinished
(Procedure<TEnvironment> proc) private void
ProcedureExecutor.submitChildrenProcedures
(Procedure<TEnvironment>[] subprocs) long
ProcedureExecutor.submitProcedure
(Procedure<TEnvironment> proc) Add a new root-procedure to the executor.long
ProcedureExecutor.submitProcedure
(Procedure<TEnvironment> proc, NonceKey nonceKey) Add a new root-procedure to the executor.void
ProcedureExecutor.submitProcedures
(Procedure<TEnvironment>[] procs) Add a set of new root-procedure to the executor.static void
static void
ProcedureFutureUtil.suspendIfNecessary
(Procedure<?> proc, Consumer<CompletableFuture<Void>> setFuture, CompletableFuture<Void> future, MasterProcedureEnv env, Runnable actionAfterDone) boolean
ProcedureEvent.suspendIfNotReady
(Procedure proc) Returns true if event is not ready and adds procedure to suspended queue, else returns false.boolean
LockAndQueue.tryExclusiveLock
(Procedure<?> proc) boolean
LockAndQueue.trySharedLock
(Procedure<?> proc) Returns whether we have succesfully acquired the shared lock.private void
ProcedureExecutor.updateStoreOnExec
(RootProcedureState<TEnvironment> procStack, Procedure<TEnvironment> procedure, Procedure<TEnvironment>[] subprocs) (package private) static void
ProcedureUtil.validateClass
(Procedure<?> proc) protected void
AbstractProcedureScheduler.waitProcedure
(LockAndQueue lockAndQueue, Procedure proc) boolean
ProcedureEvent.wakeIfSuspended
(AbstractProcedureScheduler procedureScheduler, Procedure<?> proc) Wakes up the suspended procedures only if the givenproc
is waiting on this event.protected void
AbstractProcedureScheduler.wakeProcedure
(Procedure procedure) static void
ProcedureFutureUtil.wakeUp
(Procedure<?> proc, MasterProcedureEnv env) void
The procedure can't run at the moment.void
private void
ProcedureExecutor.yieldProcedure
(Procedure<TEnvironment> proc) Modifier and TypeMethodDescriptionvoid
void
Inserts all elements in the iterator at the front of this queue.LockAndQueue.filterWaitingQueue
(Predicate<Procedure> predicate) protected static <T> Long
Procedure.getRootProcedureId
(Map<Long, Procedure<T>> procedures, Procedure<T> proc) Helper to lookup the root Procedure ID given a specified procedure.private void
ProcedureExecutor.initializeStacks
(ProcedureStore.ProcedureIterator procIter, List<Procedure<TEnvironment>> runnableList, List<Procedure<TEnvironment>> failedList, List<Procedure<TEnvironment>> waitingList, List<Procedure<TEnvironment>> waitingTimeoutList) private void
ProcedureExecutor.processWaitingProcedures
(List<Procedure<TEnvironment>> waitingList, List<Procedure<TEnvironment>> runnableList) private void
ProcedureExecutor.processWaitingTimeoutProcedures
(List<Procedure<TEnvironment>> waitingTimeoutList) private void
ProcedureExecutor.pushProceduresAfterLoad
(List<Procedure<TEnvironment>> runnableList, List<Procedure<TEnvironment>> failedList) private void
ProcedureExecutor.restoreLocks
(Deque<Procedure<TEnvironment>> stack, Set<Long> restored) ModifierConstructorDescriptionCompletedProcedureRetainer
(Procedure<TEnvironment> procedure) DelayedProcedure
(Procedure<TEnvironment> procedure) LockedResource
(LockedResourceType resourceType, String resourceName, LockType lockType, Procedure<?> exclusiveLockOwnerProcedure, int sharedLockCount, List<Procedure<?>> waitingProcedures) ModifierConstructorDescriptionLockAndQueue
(Function<Long, Procedure<?>> procedureRetriever) LockedResource
(LockedResourceType resourceType, String resourceName, LockType lockType, Procedure<?> exclusiveLockOwnerProcedure, int sharedLockCount, List<Procedure<?>> waitingProcedures) -
Uses of Procedure in org.apache.hadoop.hbase.procedure2.store
Modifier and TypeMethodDescriptionProcedure<?>
ProtoAndProcedure.getProcedure()
Procedure<?>
InMemoryProcedureIterator.next()
ProcedureStore.ProcedureIterator.next()
Returns the next procedure in the iteration.Modifier and TypeMethodDescriptionvoid
void
The parent procedure completed.void
void
void
Serialize a set of new procedures.void
When a procedure is submitted to the executor insert(proc, null) will be called.void
void
The specified procedure was executed, and the new state should be written to the store. -
Uses of Procedure in org.apache.hadoop.hbase.procedure2.store.region
Modifier and TypeMethodDescriptionvoid
void
void
private void
RegionProcedureStore.serializePut
(Procedure<?> proc, List<Mutation> mutations, List<byte[]> rowsToLock) void
Modifier and TypeMethodDescriptionprivate void
RegionProcedureStore.checkUnsupportedProcedure
(Map<Class<?>, List<Procedure<?>>> procsByType) In HBASE-20811, we have introduced a new TRSP to assign/unassign/move regions, and it is incompatible with the old AssignProcedure/UnassignProcedure/MoveRegionProcedure. -
Uses of Procedure in org.apache.hadoop.hbase.procedure2.store.wal
Modifier and TypeMethodDescriptionvoid
Deprecated.void
Deprecated.void
Deprecated.private void
ProcedureWALPrettyPrinter.printProcedure
(Procedure<?> proc) Deprecated.void
Deprecated.static void
ProcedureWALFormat.writeDelete
(ByteSlot slot, Procedure<?> proc, long[] subprocs) Deprecated.static void
ProcedureWALFormat.writeEntry
(ByteSlot slot, org.apache.hadoop.hbase.shaded.protobuf.generated.ProcedureProtos.ProcedureWALEntry.Type type, Procedure<?> proc, Procedure<?>[] subprocs) Deprecated.static void
ProcedureWALFormat.writeInsert
(ByteSlot slot, Procedure<?> proc) Deprecated.static void
ProcedureWALFormat.writeInsert
(ByteSlot slot, Procedure<?> proc, Procedure<?>[] subprocs) Deprecated.static void
ProcedureWALFormat.writeUpdate
(ByteSlot slot, Procedure<?> proc) Deprecated. -
Uses of Procedure in org.apache.hadoop.hbase.procedure2.trace
-
Uses of Procedure in org.apache.hadoop.hbase.regionserver.storefiletracker
Modifier and TypeClassDescriptionclass
Procedure for setting StoreFileTracker information to table descriptor.class
class
This procedure is used to change the store file tracker implementation.class
-
Uses of Procedure in org.apache.hadoop.hbase.rsgroup
Modifier and TypeClassDescriptionclass
Procedure for migrating rs group information to table descriptor.