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.LockState
Nested classes/interfaces inherited from interface org.apache.hadoop.hbase.master.procedure.TableProcedureInterface
TableProcedureInterface.TableOperationType
-
Field Summary
Modifier and TypeFieldDescriptionprotected ServerName
Deprecated.protected ServerName
Deprecated.private boolean
Deprecated.Fields inherited from class org.apache.hadoop.hbase.master.assignment.RegionTransitionProcedure
aborted
Fields inherited from class org.apache.hadoop.hbase.procedure2.Procedure
NO_PROC_ID, NO_TIMEOUT
Fields inherited from interface org.apache.hadoop.hbase.master.procedure.TableProcedureInterface
DUMMY_NAMESPACE_TABLE_NAME
-
Constructor Summary
-
Method Summary
Modifier and TypeMethodDescriptionprotected void
deserializeStateData
(ProcedureStateSerializer serializer) Deprecated.Called on store load to allow the user to decode the previously serialized state.protected void
finishTransition
(MasterProcedureEnv env, RegionStateNode regionNode) Deprecated.protected ProcedureMetrics
Deprecated.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 boolean
isRollbackSupported
(org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProcedureProtos.RegionTransitionState state) Deprecated.remoteCallBuild
(MasterProcedureEnv env, ServerName serverName) Deprecated.For building the remote operation.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.protected void
reportTransition
(MasterProcedureEnv env, RegionStateNode regionNode, org.apache.hadoop.hbase.shaded.protobuf.generated.RegionServerStatusProtos.RegionStateTransition.TransitionCode code, long seqId) Deprecated.protected void
serializeStateData
(ProcedureStateSerializer serializer) Deprecated.The user-level code of the procedure may have some state to persist (e.g.protected boolean
startTransition
(MasterProcedureEnv env, RegionStateNode regionNode) Deprecated.void
Deprecated.Extend the toString() information with the procedure details e.g.protected boolean
updateTransition
(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, toStringState
Methods inherited from class org.apache.hadoop.hbase.procedure2.Procedure
acquireLock, addStackIndex, afterReplay, 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, wasExecuted
Methods inherited from class java.lang.Object
clone, equals, finalize, getClass, hashCode, notify, notifyAll, wait, wait, wait
Methods 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:TableProcedureInterface
Given 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:
isRollbackSupported
in classRegionTransitionProcedure
-
serializeStateData
Deprecated.Description copied from class:Procedure
The 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:
serializeStateData
in classProcedure<MasterProcedureEnv>
- Parameters:
serializer
- stores the serializable state- Throws:
IOException
-
deserializeStateData
Deprecated.Description copied from class:Procedure
Called on store load to allow the user to decode the previously serialized state.- Specified by:
deserializeStateData
in classProcedure<MasterProcedureEnv>
- Parameters:
serializer
- contains the serialized state- Throws:
IOException
-
startTransition
Deprecated.- Specified by:
startTransition
in classRegionTransitionProcedure
-
updateTransition
protected boolean updateTransition(MasterProcedureEnv env, RegionStateNode regionNode) throws IOException Deprecated.- Specified by:
updateTransition
in classRegionTransitionProcedure
- Throws:
IOException
-
finishTransition
protected void finishTransition(MasterProcedureEnv env, RegionStateNode regionNode) throws IOException Deprecated.- Specified by:
finishTransition
in classRegionTransitionProcedure
- Throws:
IOException
-
remoteCallBuild
public Optional<RemoteProcedureDispatcher.RemoteOperation> remoteCallBuild(MasterProcedureEnv env, ServerName serverName) Deprecated.Description copied from interface:RemoteProcedureDispatcher.RemoteProcedure
For 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:
remoteCallBuild
in interfaceRemoteProcedureDispatcher.RemoteProcedure<MasterProcedureEnv,
ServerName> - Specified by:
remoteCallBuild
in 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:
reportTransition
in 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:
remoteCallFailed
in classRegionTransitionProcedure
-
toStringClassDetails
Deprecated.Description copied from class:Procedure
Extend the toString() information with the procedure details e.g. className and parameters- Overrides:
toStringClassDetails
in classRegionTransitionProcedure
- Parameters:
sb
- the string builder to use to append the proc specific information
-
getProcedureMetrics
Deprecated.Description copied from class:Procedure
Override this method to provide procedure specific counters for submitted count, failed count and time histogram.- Overrides:
getProcedureMetrics
in classProcedure<MasterProcedureEnv>
- Parameters:
env
- The environment passed to the procedure executor- Returns:
- Container object for procedure related metric
-