@InterfaceAudience.Private public class SplitWALProcedure extends StateMachineProcedure<MasterProcedureEnv,org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProcedureProtos.SplitWALState> implements ServerProcedureInterface
SplitWALRemoteProcedure
to actually send the request to region
server to split this WAL.
It also check if the split wal task really succeed. If the WAL still exists, it will
schedule another region server to split this WAL.StateMachineProcedure.Flow
Procedure.LockState
ServerProcedureInterface.ServerOperationType
stateCount
NO_PROC_ID, NO_TIMEOUT
构造器和说明 |
---|
SplitWALProcedure() |
SplitWALProcedure(String walPath,
ServerName crashedServer) |
abort, addChildProcedure, execute, failIfAborted, getCurrentState, getCurrentStateId, getCycles, isEofState, isRollbackSupported, isYieldAfterExecutionStep, isYieldBeforeExecuteFromState, rollback, setNextState, toStringState
acquireLock, addStackIndex, beforeReplay, bypass, compareTo, completionCleanup, doExecute, doRollback, elapsedTime, getChildrenLatch, getException, getLastUpdate, getNonceKey, getOwner, getParentProcId, getProcedureMetrics, getProcId, getProcIdHashCode, getProcName, getResult, getRootProcedureId, getRootProcId, getStackIndexes, getState, getSubmittedTime, getTimeout, getTimeoutTimestamp, hasChildren, hasException, hasLock, hasOwner, hasParent, hasTimeout, haveSameParent, holdLock, incChildrenLatch, isBypass, isFailed, isFinished, isInitializing, isLockedWhenLoading, isRunnable, isSuccess, isWaiting, releaseLock, removeStackIndex, setAbortFailure, setChildrenLatch, setFailure, setFailure, setLastUpdate, setNonceKey, setOwner, setOwner, setParentProcId, setProcId, setResult, setRootProcId, setStackIndexes, setState, setSubmittedTime, setTimeout, shouldWaitClientAck, skipPersistence, toString, toStringClass, toStringClassDetails, toStringDetails, toStringSimpleSB, updateMetricsOnFinish, updateMetricsOnSubmit, updateTimestamp, waitInitialized, wasExecuted
public SplitWALProcedure()
public SplitWALProcedure(String walPath, ServerName crashedServer)
protected StateMachineProcedure.Flow executeFromState(MasterProcedureEnv env, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProcedureProtos.SplitWALState state) throws ProcedureSuspendedException, ProcedureYieldException, InterruptedException
protected void rollbackState(MasterProcedureEnv env, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProcedureProtos.SplitWALState splitOneWalState) throws IOException, InterruptedException
protected org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProcedureProtos.SplitWALState getState(int stateId)
protected int getStateId(org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProcedureProtos.SplitWALState state)
protected org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProcedureProtos.SplitWALState getInitialState()
protected void serializeStateData(ProcedureStateSerializer serializer) throws IOException
protected void deserializeStateData(ProcedureStateSerializer serializer) throws IOException
protected boolean setTimeoutFailure(MasterProcedureEnv env)
setTimeoutFailure
在类中 Procedure<MasterProcedureEnv>
public String getWAL()
public ServerName getWorker()
public ServerName getServerName()
getServerName
在接口中 ServerProcedureInterface
public boolean hasMetaTableRegion()
hasMetaTableRegion
在接口中 ServerProcedureInterface
public ServerProcedureInterface.ServerOperationType getServerOperationType()
ServerProcedureInterface
getServerOperationType
在接口中 ServerProcedureInterface
protected void afterReplay(MasterProcedureEnv env)
afterReplay
在类中 Procedure<MasterProcedureEnv>
Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.