Uses of Class
org.apache.hadoop.hbase.procedure2.Procedure
Packages that use Procedure
Package
Description
-
Uses of Procedure in org.apache.hadoop.hbase.master
Methods in org.apache.hadoop.hbase.master that return types with arguments of type ProcedureModifier and TypeMethodDescriptionSplitWALManager.createSplitWALProcedures(List<org.apache.hadoop.fs.FileStatus> splittingWALs, ServerName crashedServer) HMaster.getProcedures()MasterServices.getProcedures()Get proceduresSplitWALManager.splitWALs(ServerName crashedServer, boolean splitMeta) Methods in org.apache.hadoop.hbase.master with parameters of type ProcedureModifier and TypeMethodDescriptionSplitWALManager.acquireSplitWALWorker(Procedure<?> procedure) Acquire a split WAL workerprivate longClusterSchemaServiceImpl.submitProcedure(Procedure<MasterProcedureEnv> procedure, NonceKey nonceKey) voidMethod parameters in org.apache.hadoop.hbase.master with type arguments of type ProcedureModifier and TypeMethodDescriptionvoidMasterCoprocessorHost.postGetProcedures(List<Procedure<?>> procInfoList) -
Uses of Procedure in org.apache.hadoop.hbase.master.assignment
Subclasses of Procedure in org.apache.hadoop.hbase.master.assignmentModifier and TypeClassDescriptionprivate static classprivate static classclassDeprecated.Do not use any more.classThe remote procedure used to close a region.classDeprecated.2.3.0 UseGCMultipleMergedRegionsProcedure.classGC regions that have been Merged.classGC a Region that is no longer in use.classThe procedure to Merge regions in a table.classDeprecated.Do not use any more.classThe remote procedure used to open a region.classThe base class for the remote procedures used to open/close a region.classDeprecated.Do not use any more.classThe procedure to split a region in a table.classThe procedure to deal with the state transition of a region.classDeprecated.Do not use any more.Methods in org.apache.hadoop.hbase.master.assignment that return ProcedureModifier and TypeMethodDescriptionprotected Procedure<MasterProcedureEnv>[]RegionRemoteProcedureBase.execute(MasterProcedureEnv env) protected Procedure[]RegionTransitionProcedure.execute(MasterProcedureEnv env) Deprecated.protected Procedure[]TransitRegionStateProcedure.execute(MasterProcedureEnv env) Methods in org.apache.hadoop.hbase.master.assignment with parameters of type ProcedureModifier and TypeMethodDescriptionbooleanAssignmentManager.waitMetaAssigned(Procedure<?> proc, RegionInfo regionInfo) Notice that this event does not mean the AM has already finished region state rebuilding.booleanAssignmentManager.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
Subclasses of Procedure in org.apache.hadoop.hbase.master.lockingModifier and TypeClassDescriptionfinal classProcedure 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.Methods in org.apache.hadoop.hbase.master.locking that return ProcedureModifier and TypeMethodDescriptionprotected Procedure<MasterProcedureEnv>[]LockProcedure.execute(MasterProcedureEnv env) -
Uses of Procedure in org.apache.hadoop.hbase.master.procedure
Subclasses of Procedure in org.apache.hadoop.hbase.master.procedureModifier and TypeClassDescriptionclassBase class for all the Namespace procedures that want to use a StateMachineProcedure.classBase class for all the Region procedures that want to use a StateMachine.classBase class for all the Table procedures that want to use a StateMachineProcedure.classclassThe procedure to create a new namespace.classclassThe procedure to remove a namespace.classclassclassclassclassclassActs like the super class in all cases except when no Regions found in the current Master in-memory context.classThis procedure is used to initialize meta table for a new hbase deploy.classThe procedure to add a namespace to an existing table.classThe procedure will only update the table descriptor without reopening all the regions.classclassDeprecated.Do not use any more, leave it here only for compatible.classUsed for reopening the regions for a table.classclassHandle crashed server.classclassA procedure used to take snapshot on tables.classA remote procedure which is used to send region snapshot request to region server.classA remote procedure which is used to send verify snapshot request to region server.classThe procedure is to split a WAL.classA remote procedure which is used to send split WAL request to region server.classThe procedure to switch rpc throttleclassThe procedure to switch rpc throttle on region serverclassclassFields in org.apache.hadoop.hbase.master.procedure declared as ProcedureModifier and TypeFieldDescriptionprivate final Procedure<?>ProcedureSyncWait.ProcedureFuture.procFields in org.apache.hadoop.hbase.master.procedure with type parameters of type ProcedureMethods in org.apache.hadoop.hbase.master.procedure that return ProcedureModifier and TypeMethodDescriptionprivate Procedure<MasterProcedureEnv>[]SnapshotProcedure.createRemoteSnapshotProcedures(MasterProcedureEnv env) private Procedure[]ServerCrashProcedure.createSplittingWalProcedures(MasterProcedureEnv env, boolean splitMeta) protected ProcedureMasterProcedureScheduler.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()Methods in org.apache.hadoop.hbase.master.procedure with parameters of type ProcedureModifier and TypeMethodDescriptionvoidvoidMasterProcedureScheduler.completionCleanup(Procedure proc) protected voidprotected abstract voidprotected voidstatic Stringstatic StringProcedureDescriber.describeParameters(Procedure<?> proc) private <T extends Comparable<T>>
voidMasterProcedureScheduler.doAdd(FairQueue<T> fairq, Queue<T> queue, Procedure<?> proc, boolean addFront) protected voidprivate static Stringprivate static ServerNameMasterProcedureScheduler.getServerName(Procedure<?> proc) private static TableNameMasterProcedureScheduler.getTableName(Procedure<?> proc) private <T extends Comparable<T>>
booleanMasterProcedureScheduler.isLockReady(Procedure<?> proc, Queue<T> rq) private static booleanMasterProcedureScheduler.isMetaProcedure(Procedure<?> proc) private static booleanMasterProcedureScheduler.isPeerProcedure(Procedure<?> proc) private static booleanMasterProcedureScheduler.isServerProcedure(Procedure<?> proc) private static booleanMasterProcedureScheduler.isTableProcedure(Procedure<?> proc) (package private) booleanMasterProcedureScheduler.markTableAsDeleted(TableName table, Procedure<?> procedure) Tries to remove the queue and the table-lock of the specified table.private static ObjectProcedureDescriber.parametersToObject(Procedure<?> proc) static voidProcedurePrepareLatch.releaseLatch(ProcedurePrepareLatch latch, Procedure proc) (package private) booleanMetaQueue.requireExclusiveLock(Procedure<?> proc) Deprecated.booleanPeerQueue.requireExclusiveLock(Procedure<?> proc) (package private) abstract booleanQueue.requireExclusiveLock(Procedure<?> proc) booleanServerQueue.requireExclusiveLock(Procedure<?> proc) booleanTableQueue.requireExclusiveLock(Procedure<?> proc) static byte[]ProcedureSyncWait.submitAndWaitProcedure(ProcedureExecutor<MasterProcedureEnv> procExec, Procedure<MasterProcedureEnv> proc) protected longMasterProcedureUtil.NonceProcedureRunnable.submitProcedure(Procedure<MasterProcedureEnv> proc) static Future<byte[]>ProcedureSyncWait.submitProcedure(ProcedureExecutor<MasterProcedureEnv> procExec, Procedure<MasterProcedureEnv> proc) private voidMasterProcedureScheduler.tryCleanupPeerQueue(String peerId, Procedure procedure) private voidMasterProcedureScheduler.tryCleanupServerQueue(ServerName serverName, Procedure<?> proc) static IOExceptionMasterProcedureUtil.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) booleanMasterProcedureEnv.waitInitialized(Procedure<?> proc) booleanMasterProcedureScheduler.waitMetaExclusiveLock(Procedure<?> procedure) Deprecated.only used forRecoverMetaProcedure.booleanMasterProcedureScheduler.waitNamespaceExclusiveLock(Procedure<?> procedure, String namespace) Suspend the procedure if the specified namespace is already locked.booleanMasterProcedureScheduler.waitPeerExclusiveLock(Procedure<?> procedure, String peerId) Try to acquire the exclusive lock on the specified peer.booleanMasterProcedureScheduler.waitRegion(Procedure<?> procedure, RegionInfo regionInfo) Suspend the procedure if the specified region is already locked.booleanMasterProcedureScheduler.waitRegions(Procedure<?> procedure, TableName table, RegionInfo... regionInfos) Suspend the procedure if the specified set of regions are already locked.booleanMasterProcedureScheduler.waitServerExclusiveLock(Procedure<?> procedure, ServerName serverName) Try to acquire the exclusive lock on the specified server.booleanMasterProcedureScheduler.waitTableExclusiveLock(Procedure<?> procedure, TableName table) Suspend the procedure if the specified table is already locked.private TableQueueMasterProcedureScheduler.waitTableQueueSharedLock(Procedure<?> procedure, TableName table) booleanMasterProcedureScheduler.waitTableSharedLock(Procedure<?> procedure, TableName table) Suspend the procedure if the specified table is already locked.voidMasterProcedureScheduler.wakeMetaExclusiveLock(Procedure<?> procedure) Deprecated.only used forRecoverMetaProcedure.voidMasterProcedureScheduler.wakeNamespaceExclusiveLock(Procedure<?> procedure, String namespace) Wake the procedures waiting for the specified namespacevoidMasterProcedureScheduler.wakePeerExclusiveLock(Procedure<?> procedure, String peerId) Wake the procedures waiting for the specified peervoidMasterProcedureScheduler.wakeRegion(Procedure<?> procedure, RegionInfo regionInfo) Wake the procedures waiting for the specified regionvoidMasterProcedureScheduler.wakeRegions(Procedure<?> procedure, TableName table, RegionInfo... regionInfos) Wake the procedures waiting for the specified regionsvoidMasterProcedureScheduler.wakeServerExclusiveLock(Procedure<?> procedure, ServerName serverName) Wake the procedures waiting for the specified servervoidMasterProcedureScheduler.wakeTableExclusiveLock(Procedure<?> procedure, TableName table) Wake the procedures waiting for the specified tablevoidMasterProcedureScheduler.wakeTableSharedLock(Procedure<?> procedure, TableName table) Wake the procedures waiting for the specified tablevoidConstructors in org.apache.hadoop.hbase.master.procedure with parameters of type ProcedureModifierConstructorDescriptionProcedureFuture(ProcedureExecutor<MasterProcedureEnv> procExec, Procedure<?> proc) Constructor parameters in org.apache.hadoop.hbase.master.procedure with type arguments of type ProcedureModifierConstructorDescriptionMasterProcedureScheduler(Function<Long, Procedure<?>> procedureRetriever) SchemaLocking(Function<Long, Procedure<?>> procedureRetriever) -
Uses of Procedure in org.apache.hadoop.hbase.master.replication
Subclasses of Procedure in org.apache.hadoop.hbase.master.replicationModifier and TypeClassDescriptionclassAbstractPeerProcedure<TState>The base class for all replication peer related procedure.classThe procedure for adding a new replication peer.classclassUsed to assign the replication queues of a dead server to other region servers.classThe procedure for disabling a replication peer.classThe procedure for enabling a replication peer.classThe base class for all replication peer related procedure except sync replication state transition.classclassThe procedure for removing a replication peer.classThe procedure for updating the config for a replication peer.Methods in org.apache.hadoop.hbase.master.replication that return ProcedureModifier and TypeMethodDescriptionprotected Procedure<MasterProcedureEnv>[]ClaimReplicationQueuesProcedure.execute(MasterProcedureEnv env) -
Uses of Procedure in org.apache.hadoop.hbase.procedure2
Subclasses of Procedure in org.apache.hadoop.hbase.procedure2Modifier and TypeClassDescription(package private) classCompletedProcedureCleaner<TEnvironment>Internal cleaner that removes the completed procedure results after a TTL.classFailedProcedure<TEnvironment>classOnePhaseProcedure<TEnvironment>classProcedureInMemoryChore<TEnvironment>Special procedure used as a chore.classSequentialProcedure<TEnvironment>A SequentialProcedure describes one step in a procedure chain:classStateMachineProcedure<TEnvironment,TState> Procedure described by a series of steps.classTwoPhaseProcedure<TEnvironment>Fields in org.apache.hadoop.hbase.procedure2 declared as ProcedureModifier and TypeFieldDescriptionprivate Procedure<TEnvironment>ProcedureExecutor.WorkerThread.activeProcedureprivate Procedure<?>LockAndQueue.exclusiveLockOwnerProcedureprivate final Procedure<?>LockedResource.exclusiveLockOwnerProcedureprivate final Procedure<TEnvironment>CompletedProcedureRetainer.procedureFields in org.apache.hadoop.hbase.procedure2 with type parameters of type ProcedureModifier and TypeFieldDescriptionLockAndQueue.procedureRetrieverprivate final ConcurrentHashMap<Long,Procedure<TEnvironment>> ProcedureExecutor.proceduresHelper map to lookup the live procedures by ID.private List<Procedure<TEnvironment>>StateMachineProcedure.subProcListprivate Set<Procedure<TEnvironment>>RootProcedureState.subprocsprivate ArrayList<Procedure<TEnvironment>>RootProcedureState.subprocStackLockedResource.waitingProceduresMethods in org.apache.hadoop.hbase.procedure2 with type parameters of type ProcedureModifier 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) Methods in org.apache.hadoop.hbase.procedure2 that return ProcedureModifier and TypeMethodDescriptionstatic Procedure<?>ProcedureUtil.convertToProcedure(org.apache.hadoop.hbase.shaded.protobuf.generated.ProcedureProtos.Procedure proto) Helper to convert the protobuf procedure.protected abstract ProcedureAbstractProcedureScheduler.dequeue()Fetch one Procedure from the queue NOTE: this method is called with the sched lock held.protected ProcedureSimpleProcedureScheduler.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()Methods in org.apache.hadoop.hbase.procedure2 that return types with arguments of type ProcedureModifier 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()Methods in org.apache.hadoop.hbase.procedure2 with parameters of type ProcedureModifier and TypeMethodDescriptionprotected booleanRootProcedureState.acquire(Procedure<TEnvironment> proc) Called by the ProcedureExecutor to mark the procedure step as running.private Procedure.LockStateProcedureExecutor.acquireLock(Procedure<TEnvironment> proc) voidTimeoutExecutorThread.add(Procedure<TEnvironment> procedure) voidvoidvoidInserts the specified element at the end of this queue.voidInserts the specified element at the end of this queue.protected <T extends Procedure<TEnvironment>>
voidStateMachineProcedure.addChildProcedure(T... subProcedure) Add a child procedure to executevoidvoidvoidInserts the specified element at the front of this queue.voidInserts the specified element at the front of this queue.voidprotected booleanRootProcedureState.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 voidRootProcedureState.addSubProcedure(Procedure<TEnvironment> proc) private voidProcedureExecutor.cleanupAfterRollbackOneStep(Procedure<TEnvironment> proc) intProcedure.compareTo(Procedure<TEnvironment> other) voidProcedureScheduler.completionCleanup(Procedure proc) The procedure in execution completed.voidSimpleProcedureScheduler.completionCleanup(Procedure proc) static org.apache.hadoop.hbase.shaded.protobuf.generated.ProcedureProtos.ProcedureProcedureUtil.convertToProtoProcedure(Procedure<?> proc) Helper to convert the procedure to protobuf.private voidProcedureExecutor.countDownChildren(RootProcedureState<TEnvironment> procStack, Procedure<TEnvironment> procedure) protected abstract voidAdd the procedure to the queue.protected voidprivate voidProcedureExecutor.execCompletionCleanup(Procedure<TEnvironment> proc) private voidProcedureExecutor.execProcedure(RootProcedureState<TEnvironment> procStack, Procedure<TEnvironment> procedure) ExecutesprocedureCalls the doExecute() of the procedure If the procedure execution didn't fail (i.e.private Procedure.LockStateProcedureExecutor.executeNormalRollback(Procedure<TEnvironment> rootProc, RootProcedureState<TEnvironment> procStack) private voidProcedureExecutor.executeProcedure(Procedure<TEnvironment> proc) private Procedure.LockStateProcedureExecutor.executeRollback(Procedure<TEnvironment> proc) Execute the rollback of the procedure step.protected voidTimeoutExecutorThread.executeTimedoutProcedure(Procedure<TEnvironment> proc) private voidProcedureExecutor.executeUnexpectedRollback(Procedure<TEnvironment> rootProc, RootProcedureState<TEnvironment> procStack) protected static <T> LongProcedure.getRootProcedureId(Map<Long, Procedure<T>> procedures, Procedure<T> proc) Helper to lookup the root Procedure ID given a specified procedure.(package private) LongProcedureExecutor.getRootProcedureId(Procedure<TEnvironment> proc) private voidProcedureExecutor.handleInterruptedException(Procedure<TEnvironment> proc, InterruptedException e) booleanLockAndQueue.hasLockAccess(Procedure<?> proc) booleanLockStatus.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 booleanProcedure.haveSameParent(Procedure<?> a, Procedure<?> b) private Procedure<TEnvironment>[]ProcedureExecutor.initializeChildren(RootProcedureState<TEnvironment> procStack, Procedure<TEnvironment> procedure, Procedure<TEnvironment>[] subprocs) private booleanProcedureExecutor.isRootFinished(Procedure<?> proc) protected voidRootProcedureState.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) private voidProcedureExecutor.procedureFinished(Procedure<TEnvironment> proc) protected voidprivate longProcedureExecutor.pushProcedure(Procedure<TEnvironment> proc) protected voidRootProcedureState.release(Procedure<TEnvironment> proc) Called by the ProcedureExecutor to mark the procedure step as finished.booleanLockAndQueue.releaseExclusiveLock(Procedure<?> proc) Returns whether we should wake the procedures waiting on the lock here.private voidProcedureExecutor.releaseLock(Procedure<TEnvironment> proc, boolean force) booleanTimeoutExecutorThread.remove(Procedure<TEnvironment> procedure) private voidProcedureExecutor.restoreLock(Procedure<TEnvironment> proc, Set<Long> restored) private voidProcedureExecutor.submitChildrenProcedures(Procedure<TEnvironment>[] subprocs) longProcedureExecutor.submitProcedure(Procedure<TEnvironment> proc) Add a new root-procedure to the executor.longProcedureExecutor.submitProcedure(Procedure<TEnvironment> proc, NonceKey nonceKey) Add a new root-procedure to the executor.voidProcedureExecutor.submitProcedures(Procedure<TEnvironment>[] procs) Add a set of new root-procedure to the executor.booleanProcedureEvent.suspendIfNotReady(Procedure proc) Returns true if event is not ready and adds procedure to suspended queue, else returns false.booleanLockAndQueue.tryExclusiveLock(Procedure<?> proc) booleanLockAndQueue.trySharedLock(Procedure<?> proc) Returns whether we have succesfully acquired the shared lock.private voidProcedureExecutor.updateStoreOnExec(RootProcedureState<TEnvironment> procStack, Procedure<TEnvironment> procedure, Procedure<TEnvironment>[] subprocs) (package private) static voidProcedureUtil.validateClass(Procedure<?> proc) protected voidAbstractProcedureScheduler.waitProcedure(LockAndQueue lockAndQueue, Procedure proc) booleanProcedureEvent.wakeIfSuspended(AbstractProcedureScheduler procedureScheduler, Procedure<?> proc) Wakes up the suspended procedures only if the givenprocis waiting on this event.protected voidAbstractProcedureScheduler.wakeProcedure(Procedure procedure) voidThe procedure can't run at the moment.voidprivate voidProcedureExecutor.yieldProcedure(Procedure<TEnvironment> proc) Method parameters in org.apache.hadoop.hbase.procedure2 with type arguments of type ProcedureModifier and TypeMethodDescriptionvoidvoidInserts all elements in the iterator at the front of this queue.LockAndQueue.filterWaitingQueue(Predicate<Procedure> predicate) protected static <T> LongProcedure.getRootProcedureId(Map<Long, Procedure<T>> procedures, Procedure<T> proc) Helper to lookup the root Procedure ID given a specified procedure.private voidProcedureExecutor.initializeStacks(ProcedureStore.ProcedureIterator procIter, List<Procedure<TEnvironment>> runnableList, List<Procedure<TEnvironment>> failedList, List<Procedure<TEnvironment>> waitingList, List<Procedure<TEnvironment>> waitingTimeoutList) private voidProcedureExecutor.processWaitingProcedures(List<Procedure<TEnvironment>> waitingList, List<Procedure<TEnvironment>> runnableList) private voidProcedureExecutor.processWaitingTimeoutProcedures(List<Procedure<TEnvironment>> waitingTimeoutList) private voidProcedureExecutor.pushProceduresAfterLoad(List<Procedure<TEnvironment>> runnableList, List<Procedure<TEnvironment>> failedList) private voidProcedureExecutor.restoreLocks(Deque<Procedure<TEnvironment>> stack, Set<Long> restored) Constructors in org.apache.hadoop.hbase.procedure2 with parameters of type ProcedureModifierConstructorDescriptionCompletedProcedureRetainer(Procedure<TEnvironment> procedure) DelayedProcedure(Procedure<TEnvironment> procedure) LockedResource(LockedResourceType resourceType, String resourceName, LockType lockType, Procedure<?> exclusiveLockOwnerProcedure, int sharedLockCount, List<Procedure<?>> waitingProcedures) Constructor parameters in org.apache.hadoop.hbase.procedure2 with type arguments of type ProcedureModifierConstructorDescriptionLockAndQueue(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
Fields in org.apache.hadoop.hbase.procedure2.store declared as ProcedureMethods in org.apache.hadoop.hbase.procedure2.store that return ProcedureModifier and TypeMethodDescriptionProcedure<?>ProtoAndProcedure.getProcedure()Procedure<?>InMemoryProcedureIterator.next()ProcedureStore.ProcedureIterator.next()Returns the next procedure in the iteration.Methods in org.apache.hadoop.hbase.procedure2.store with parameters of type ProcedureModifier and TypeMethodDescriptionvoidvoidThe parent procedure completed.voidvoidvoidSerialize a set of new procedures.voidWhen a procedure is submitted to the executor insert(proc, null) will be called.voidvoidThe 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
Methods in org.apache.hadoop.hbase.procedure2.store.region with parameters of type ProcedureModifier and TypeMethodDescriptionvoidvoidvoidprivate voidRegionProcedureStore.serializePut(Procedure<?> proc, List<Mutation> mutations, List<byte[]> rowsToLock) voidMethod parameters in org.apache.hadoop.hbase.procedure2.store.region with type arguments of type ProcedureModifier and TypeMethodDescriptionprivate voidRegionProcedureStore.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
Methods in org.apache.hadoop.hbase.procedure2.store.wal with parameters of type ProcedureModifier and TypeMethodDescriptionvoidDeprecated.voidDeprecated.voidDeprecated.private voidProcedureWALPrettyPrinter.printProcedure(Procedure<?> proc) Deprecated.voidDeprecated.static voidProcedureWALFormat.writeDelete(ByteSlot slot, Procedure<?> proc, long[] subprocs) Deprecated.static voidProcedureWALFormat.writeEntry(ByteSlot slot, org.apache.hadoop.hbase.shaded.protobuf.generated.ProcedureProtos.ProcedureWALEntry.Type type, Procedure<?> proc, Procedure<?>[] subprocs) Deprecated.static voidProcedureWALFormat.writeInsert(ByteSlot slot, Procedure<?> proc) Deprecated.static voidProcedureWALFormat.writeInsert(ByteSlot slot, Procedure<?> proc, Procedure<?>[] subprocs) Deprecated.static voidProcedureWALFormat.writeUpdate(ByteSlot slot, Procedure<?> proc) Deprecated. -
Uses of Procedure in org.apache.hadoop.hbase.procedure2.trace
Constructors in org.apache.hadoop.hbase.procedure2.trace with parameters of type Procedure -
Uses of Procedure in org.apache.hadoop.hbase.regionserver.storefiletracker
Subclasses of Procedure in org.apache.hadoop.hbase.regionserver.storefiletrackerModifier and TypeClassDescriptionclassProcedure for setting StoreFileTracker information to table descriptor.classclassThis procedure is used to change the store file tracker implementation.class