Class UnassignProcedure
java.lang.Object
org.apache.hadoop.hbase.procedure2.Procedure<MasterProcedureEnv>
org.apache.hadoop.hbase.master.assignment.RegionTransitionProcedure
org.apache.hadoop.hbase.master.assignment.UnassignProcedure
- All Implemented Interfaces:
Comparable<Procedure<MasterProcedureEnv>>,TableProcedureInterface,RemoteProcedureDispatcher.RemoteProcedure<MasterProcedureEnv,ServerName>
Deprecated.
Do not use any more.
Leave here only for checking if we can successfully start the master.
- See Also:
-
Nested Class Summary
Nested classes/interfaces inherited from class org.apache.hadoop.hbase.procedure2.Procedure
Procedure.LockStateNested classes/interfaces inherited from interface org.apache.hadoop.hbase.master.procedure.TableProcedureInterface
TableProcedureInterface.TableOperationType -
Field Summary
FieldsModifier and TypeFieldDescriptionprotected ServerNameDeprecated.protected ServerNameDeprecated.private booleanDeprecated.Fields inherited from class org.apache.hadoop.hbase.master.assignment.RegionTransitionProcedure
abortedFields inherited from class org.apache.hadoop.hbase.procedure2.Procedure
NO_PROC_ID, NO_TIMEOUTFields inherited from interface org.apache.hadoop.hbase.master.procedure.TableProcedureInterface
DUMMY_NAMESPACE_TABLE_NAME -
Constructor Summary
Constructors -
Method Summary
Modifier and TypeMethodDescriptionprotected voiddeserializeStateData(ProcedureStateSerializer serializer) Deprecated.Called on store load to allow the user to decode the previously serialized state.protected voidfinishTransition(MasterProcedureEnv env, RegionStateNode regionNode) Deprecated.protected ProcedureMetricsDeprecated.Override this method to provide procedure specific counters for submitted count, failed count and time histogram.Deprecated.Given an operation type we can take decisions about what to do with pending operations.protected booleanisRollbackSupported(org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProcedureProtos.RegionTransitionState state) Deprecated.remoteCallBuild(MasterProcedureEnv env, ServerName serverName) Deprecated.For building the remote operation.protected booleanremoteCallFailed(MasterProcedureEnv env, RegionStateNode regionNode, IOException exception) Deprecated.Returns If true, we will re-wake up this procedure; if false, the procedure stays suspended.protected voidreportTransition(MasterProcedureEnv env, RegionStateNode regionNode, org.apache.hadoop.hbase.shaded.protobuf.generated.RegionServerStatusProtos.RegionStateTransition.TransitionCode code, long seqId) Deprecated.protected voidserializeStateData(ProcedureStateSerializer serializer) Deprecated.The user-level code of the procedure may have some state to persist (e.g.protected booleanstartTransition(MasterProcedureEnv env, RegionStateNode regionNode) Deprecated.voidDeprecated.Extend the toString() information with the procedure details e.g.protected booleanupdateTransition(MasterProcedureEnv env, RegionStateNode regionNode) Deprecated.Methods inherited from class org.apache.hadoop.hbase.master.assignment.RegionTransitionProcedure
abort, execute, getAttempt, getProcName, getRegionInfo, getRegionState, getTableName, getTransitionState, isMeta, remoteCallFailed, remoteOperationCompleted, remoteOperationFailed, rollback, setAttempt, setRegionInfo, setTransitionState, toStringStateMethods inherited from class org.apache.hadoop.hbase.procedure2.Procedure
acquireLock, addStackIndex, afterExec, afterReplay, beforeExec, beforeReplay, bypass, compareTo, completionCleanup, doExecute, doRollback, elapsedTime, getChildrenLatch, getException, getLastUpdate, getNonceKey, getOwner, getParentProcId, getProcId, getProcIdHashCode, getResult, getRootProcedureId, getRootProcId, getStackIndexes, getState, getSubmittedTime, getTimeout, getTimeoutTimestamp, hasChildren, hasException, hasLock, hasOwner, hasParent, hasTimeout, haveSameParent, holdLock, incChildrenLatch, isBypass, isFailed, isFinished, isInitializing, isLockedWhenLoading, isRollbackSupported, isRunnable, isSuccess, isWaiting, isYieldAfterExecutionStep, releaseLock, removeStackIndex, setAbortFailure, setChildrenLatch, setExecuted, setFailure, setFailure, setLastUpdate, setNonceKey, setOwner, setOwner, setParentProcId, setProcId, setResult, setRootProcId, setStackIndexes, setState, setSubmittedTime, setTimeout, setTimeoutFailure, shouldWaitClientAck, skipPersistence, suspend, toString, toStringClass, toStringDetails, toStringSimpleSB, updateMetricsOnFinish, updateMetricsOnSubmit, updateTimestamp, waitInitialized, wasExecutedMethods inherited from class java.lang.Object
clone, equals, finalize, getClass, hashCode, notify, notifyAll, wait, wait, waitMethods inherited from interface org.apache.hadoop.hbase.procedure2.RemoteProcedureDispatcher.RemoteProcedure
storeInDispatchedQueue
-
Field Details
-
hostingServer
Deprecated. -
destinationServer
Deprecated. -
removeAfterUnassigning
Deprecated.
-
-
Constructor Details
-
UnassignProcedure
public UnassignProcedure()Deprecated.
-
-
Method Details
-
getTableOperationType
Deprecated.Description copied from interface:TableProcedureInterfaceGiven an operation type we can take decisions about what to do with pending operations. e.g. if we get a delete and we have some table operation pending (e.g. add column) we can abort those operations.- Returns:
- the operation type that the procedure is executing.
-
isRollbackSupported
protected boolean isRollbackSupported(org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProcedureProtos.RegionTransitionState state) Deprecated.- Specified by:
isRollbackSupportedin classRegionTransitionProcedure
-
serializeStateData
Deprecated.Description copied from class:ProcedureThe user-level code of the procedure may have some state to persist (e.g. input arguments or current position in the processing state) to be able to resume on failure.- Specified by:
serializeStateDatain classProcedure<MasterProcedureEnv>- Parameters:
serializer- stores the serializable state- Throws:
IOException
-
deserializeStateData
Deprecated.Description copied from class:ProcedureCalled on store load to allow the user to decode the previously serialized state.- Specified by:
deserializeStateDatain classProcedure<MasterProcedureEnv>- Parameters:
serializer- contains the serialized state- Throws:
IOException
-
startTransition
Deprecated.- Specified by:
startTransitionin classRegionTransitionProcedure
-
updateTransition
protected boolean updateTransition(MasterProcedureEnv env, RegionStateNode regionNode) throws IOException Deprecated.- Specified by:
updateTransitionin classRegionTransitionProcedure- Throws:
IOException
-
finishTransition
protected void finishTransition(MasterProcedureEnv env, RegionStateNode regionNode) throws IOException Deprecated.- Specified by:
finishTransitionin classRegionTransitionProcedure- Throws:
IOException
-
remoteCallBuild
public Optional<RemoteProcedureDispatcher.RemoteOperation> remoteCallBuild(MasterProcedureEnv env, ServerName serverName) Deprecated.Description copied from interface:RemoteProcedureDispatcher.RemoteProcedureFor building the remote operation. May be empty if no need to send remote call. Usually, this means the RemoteProcedure has been finished already. This is possible, as we may have already sent the procedure to RS but then the rpc connection is broken so the executeProcedures call fails, but the RS does receive the procedure and execute it and then report back, before we retry again.- Specified by:
remoteCallBuildin interfaceRemoteProcedureDispatcher.RemoteProcedure<MasterProcedureEnv,ServerName> - Specified by:
remoteCallBuildin classRegionTransitionProcedure
-
reportTransition
protected void reportTransition(MasterProcedureEnv env, RegionStateNode regionNode, org.apache.hadoop.hbase.shaded.protobuf.generated.RegionServerStatusProtos.RegionStateTransition.TransitionCode code, long seqId) throws UnexpectedStateException Deprecated.- Specified by:
reportTransitionin classRegionTransitionProcedure- Throws:
UnexpectedStateException
-
remoteCallFailed
protected boolean remoteCallFailed(MasterProcedureEnv env, RegionStateNode regionNode, IOException exception) Deprecated.Returns If true, we will re-wake up this procedure; if false, the procedure stays suspended.- Specified by:
remoteCallFailedin classRegionTransitionProcedure
-
toStringClassDetails
Deprecated.Description copied from class:ProcedureExtend the toString() information with the procedure details e.g. className and parameters- Overrides:
toStringClassDetailsin classRegionTransitionProcedure- Parameters:
sb- the string builder to use to append the proc specific information
-
getProcedureMetrics
Deprecated.Description copied from class:ProcedureOverride this method to provide procedure specific counters for submitted count, failed count and time histogram.- Overrides:
getProcedureMetricsin classProcedure<MasterProcedureEnv>- Parameters:
env- The environment passed to the procedure executor- Returns:
- Container object for procedure related metric
-