Return-Path: X-Original-To: archive-asf-public-internal@cust-asf2.ponee.io Delivered-To: archive-asf-public-internal@cust-asf2.ponee.io Received: from cust-asf.ponee.io (cust-asf.ponee.io [163.172.22.183]) by cust-asf2.ponee.io (Postfix) with ESMTP id BE5362004F5 for ; Fri, 11 Aug 2017 17:06:11 +0200 (CEST) Received: by cust-asf.ponee.io (Postfix) id BCA0D16D5B9; Fri, 11 Aug 2017 15:06:11 +0000 (UTC) Delivered-To: archive-asf-public@cust-asf.ponee.io Received: from mail.apache.org (hermes.apache.org [140.211.11.3]) by cust-asf.ponee.io (Postfix) with SMTP id BF81F16D5AD for ; Fri, 11 Aug 2017 17:06:09 +0200 (CEST) Received: (qmail 18513 invoked by uid 500); 11 Aug 2017 15:06:05 -0000 Mailing-List: contact commits-help@hbase.apache.org; run by ezmlm Precedence: bulk List-Help: List-Unsubscribe: List-Post: List-Id: Reply-To: dev@hbase.apache.org Delivered-To: mailing list commits@hbase.apache.org Received: (qmail 17373 invoked by uid 99); 11 Aug 2017 15:06:04 -0000 Received: from git1-us-west.apache.org (HELO git1-us-west.apache.org) (140.211.11.23) by apache.org (qpsmtpd/0.29) with ESMTP; Fri, 11 Aug 2017 15:06:04 +0000 Received: by git1-us-west.apache.org (ASF Mail Server at git1-us-west.apache.org, from userid 33) id 4BDDDF69D2; Fri, 11 Aug 2017 15:06:02 +0000 (UTC) Content-Type: text/plain; charset="us-ascii" MIME-Version: 1.0 Content-Transfer-Encoding: 7bit From: git-site-role@apache.org To: commits@hbase.apache.org Date: Fri, 11 Aug 2017 15:06:30 -0000 Message-Id: In-Reply-To: <0b697391afec4a64a8a7e889132b223c@git.apache.org> References: <0b697391afec4a64a8a7e889132b223c@git.apache.org> X-Mailer: ASF-Git Admin Mailer Subject: [29/51] [partial] hbase-site git commit: Published site at 82d554e3783372cc6b05489452c815b57c06f6cd. archived-at: Fri, 11 Aug 2017 15:06:11 -0000 http://git-wip-us.apache.org/repos/asf/hbase-site/blob/346adc37/devapidocs/org/apache/hadoop/hbase/master/assignment/RegionTransitionProcedure.html ---------------------------------------------------------------------- diff --git a/devapidocs/org/apache/hadoop/hbase/master/assignment/RegionTransitionProcedure.html b/devapidocs/org/apache/hadoop/hbase/master/assignment/RegionTransitionProcedure.html index cda5289..9f98479 100644 --- a/devapidocs/org/apache/hadoop/hbase/master/assignment/RegionTransitionProcedure.html +++ b/devapidocs/org/apache/hadoop/hbase/master/assignment/RegionTransitionProcedure.html @@ -123,7 +123,7 @@ var activeTableTab = "activeTableTab";

@InterfaceAudience.Private
-public abstract class RegionTransitionProcedure
+public abstract class RegionTransitionProcedure
 extends Procedure<MasterProcedureEnv>
 implements TableProcedureInterface, RemoteProcedureDispatcher.RemoteProcedure<MasterProcedureEnv,ServerName>
Base class for the Assign and Unassign Procedure. @@ -134,6 +134,7 @@ implements AssignProcedure.forceNewPlan. When the number of attempts reach hreshold configuration 'hbase.assignment.maximum.attempts', the procedure is aborted. For UnassignProcedure, similar re-attempts are - intentionally not implemented. It is a 'one shot' procedure. + intentionally not implemented. It is a 'one shot' procedure. See its class doc for how it + handles failure.

TODO: Considering it is a priority doing all we can to get make a region available as soon as possible, re-attempting with any target makes sense if specified target fails in case of - AssignProcedure. For UnassignProcedure, if communication with RS fails, - similar re-attempt makes little sense (what should be different from previous attempt?). Also it - could be complex with current implementation of - execute(MasterProcedureEnv) and UnassignProcedure. - We have made a choice of keeping UnassignProcedure simple, where the procedure either - succeeds or fails depending on communication with RS. As parent will have broader context, parent - can better handle the failed instance of UnassignProcedure. Similar simplicity for - AssignProcedure is desired and should be explored/ discussed further.

+ AssignProcedure. For UnassignProcedure, our concern is preventing data loss + on failed unassign. See class doc for explanation. @@ -373,7 +369,7 @@ implements RemoteProcedureDispatcher.RemoteOperation response)  -protected abstract void +protected abstract boolean remoteCallFailed(MasterProcedureEnv env, RegionStates.RegionStateNode regionNode, IOException exception)  @@ -486,7 +482,7 @@ implements
  • LOG

    -
    private static final org.apache.commons.logging.Log LOG
    +
    private static final org.apache.commons.logging.Log LOG
  • @@ -495,7 +491,7 @@ implements
  • aborted

    -
    protected final AtomicBoolean aborted
    +
    protected final AtomicBoolean aborted
  • @@ -504,7 +500,7 @@ implements
  • transitionState

    -
    private org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProcedureProtos.RegionTransitionState transitionState
    +
    private org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProcedureProtos.RegionTransitionState transitionState
  • @@ -513,7 +509,7 @@ implements
  • regionInfo

    -
    private HRegionInfo regionInfo
    +
    private HRegionInfo regionInfo
  • @@ -522,7 +518,7 @@ implements
  • lock

    -
    private volatile boolean lock
    +
    private volatile boolean lock
  • @@ -539,7 +535,7 @@ implements
  • RegionTransitionProcedure

    -
    public RegionTransitionProcedure()
    +
    public RegionTransitionProcedure()
  • @@ -548,7 +544,7 @@ implements
  • RegionTransitionProcedure

    -
    public RegionTransitionProcedure(HRegionInfo regionInfo)
    +
    public RegionTransitionProcedure(HRegionInfo regionInfo)
  • @@ -565,7 +561,7 @@ implements
  • getRegionInfo

    -
    public HRegionInfo getRegionInfo()
    +
    public HRegionInfo getRegionInfo()
  • @@ -574,7 +570,7 @@ implements
  • setRegionInfo

    -
    protected void setRegionInfo(HRegionInfo regionInfo)
    +
    protected void setRegionInfo(HRegionInfo regionInfo)
  • @@ -583,7 +579,7 @@ implements
  • getTableName

    -
    public TableName getTableName()
    +
    public TableName getTableName()
    Specified by:
    getTableName in interface TableProcedureInterface
    @@ -598,7 +594,7 @@ implements
  • isMeta

    -
    public boolean isMeta()
    +
    public boolean isMeta()
  • @@ -607,7 +603,7 @@ implements
  • toStringClassDetails

    -
    public void toStringClassDetails(StringBuilder sb)
    +
    public void toStringClassDetails(StringBuilder sb)
    Description copied from class: Procedure
    Extend the toString() information with the procedure details e.g. className and parameters
    @@ -625,7 +621,7 @@ implements
  • getRegionState

    -
    public RegionStates.RegionStateNode getRegionState(MasterProcedureEnv env)
    +
    public RegionStates.RegionStateNode getRegionState(MasterProcedureEnv env)
  • @@ -634,7 +630,7 @@ implements
  • setTransitionState

    -
    protected void setTransitionState(org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProcedureProtos.RegionTransitionState state)
    +
    protected void setTransitionState(org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProcedureProtos.RegionTransitionState state)
  • @@ -643,7 +639,7 @@ implements
  • getTransitionState

    -
    protected org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProcedureProtos.RegionTransitionState getTransitionState()
    +
    protected org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProcedureProtos.RegionTransitionState getTransitionState()
  • @@ -652,7 +648,7 @@ implements
  • startTransition

    -
    protected abstract boolean startTransition(MasterProcedureEnv env,
    +
    protected abstract boolean startTransition(MasterProcedureEnv env,
                                                RegionStates.RegionStateNode regionNode)
                                         throws IOException,
                                                ProcedureSuspendedException
    @@ -669,7 +665,7 @@ implements
  • updateTransition

    -
    protected abstract boolean updateTransition(MasterProcedureEnv env,
    +
    protected abstract boolean updateTransition(MasterProcedureEnv env,
                                                 RegionStates.RegionStateNode regionNode)
                                          throws IOException,
                                                 ProcedureSuspendedException
    @@ -690,7 +686,7 @@ implements
  • finishTransition

    -
    protected abstract void finishTransition(MasterProcedureEnv env,
    +
    protected abstract void finishTransition(MasterProcedureEnv env,
                                              RegionStates.RegionStateNode regionNode)
                                       throws IOException,
                                              ProcedureSuspendedException
    @@ -707,7 +703,7 @@ implements
  • reportTransition

    -
    protected abstract void reportTransition(MasterProcedureEnv env,
    +
    protected abstract void reportTransition(MasterProcedureEnv env,
                                              RegionStates.RegionStateNode regionNode,
                                              org.apache.hadoop.hbase.shaded.protobuf.generated.RegionServerStatusProtos.RegionStateTransition.TransitionCode code,
                                              long seqId)
    @@ -724,7 +720,7 @@ implements 
     
  • remoteCallBuild

    -
    public abstract RemoteProcedureDispatcher.RemoteOperation remoteCallBuild(MasterProcedureEnv env,
    +
    public abstract RemoteProcedureDispatcher.RemoteOperation remoteCallBuild(MasterProcedureEnv env,
                                                                               ServerName serverName)
    Specified by:
    @@ -738,9 +734,15 @@ implements
  • remoteCallFailed

    -
    protected abstract void remoteCallFailed(MasterProcedureEnv env,
    -                                         RegionStates.RegionStateNode regionNode,
    -                                         IOException exception)
    +
    protected abstract boolean remoteCallFailed(MasterProcedureEnv env,
    +                                            RegionStates.RegionStateNode regionNode,
    +                                            IOException exception)
    +
    +
    Returns:
    +
    True if processing of fail is complete; the procedure will be woken from its suspend + and we'll go back to running through procedure steps: + otherwise if false we leave the procedure in suspended state.
    +
  • @@ -749,7 +751,7 @@ implements
  • remoteCallCompleted

    -
    public void remoteCallCompleted(MasterProcedureEnv env,
    +
    public void remoteCallCompleted(MasterProcedureEnv env,
                                     ServerName serverName,
                                     RemoteProcedureDispatcher.RemoteOperation response)
    @@ -764,7 +766,7 @@ implements
  • remoteCallFailed

    -
    public void remoteCallFailed(MasterProcedureEnv env,
    +
    public void remoteCallFailed(MasterProcedureEnv env,
                                  ServerName serverName,
                                  IOException exception)
    @@ -779,7 +781,7 @@ implements
  • addToRemoteDispatcher

    -
    protected boolean addToRemoteDispatcher(MasterProcedureEnv env,
    +
    protected boolean addToRemoteDispatcher(MasterProcedureEnv env,
                                             ServerName targetServer)
    Be careful! At the end of this method, the procedure has either succeeded and this procedure has been set into a suspended state OR, we failed and @@ -799,7 +801,7 @@ implements
  • reportTransition

    -
    protected void reportTransition(MasterProcedureEnv env,
    +
    protected void reportTransition(MasterProcedureEnv env,
                                     ServerName serverName,
                                     org.apache.hadoop.hbase.shaded.protobuf.generated.RegionServerStatusProtos.RegionStateTransition.TransitionCode code,
                                     long seqId)
    @@ -816,7 +818,7 @@ implements 
     
  • isServerOnline

    -
    protected boolean isServerOnline(MasterProcedureEnv env,
    +
    protected boolean isServerOnline(MasterProcedureEnv env,
                                      RegionStates.RegionStateNode regionNode)
  • @@ -826,7 +828,7 @@ implements
  • isServerOnline

    -
    protected boolean isServerOnline(MasterProcedureEnv env,
    +
    protected boolean isServerOnline(MasterProcedureEnv env,
                                      ServerName serverName)
  • @@ -836,7 +838,7 @@ implements
  • toStringState

    -
    protected void toStringState(StringBuilder builder)
    +
    protected void toStringState(StringBuilder builder)
    Description copied from class: Procedure
    Called from Procedure.toString() when interpolating Procedure State. Allows decorating generic Procedure State with Procedure particulars.
    @@ -854,7 +856,7 @@ implements
  • execute

    -
    protected Procedure[] execute(MasterProcedureEnv env)
    +
    protected Procedure[] execute(MasterProcedureEnv env)
                            throws ProcedureSuspendedException
    Description copied from class: Procedure
    The main code of the procedure. It must be idempotent since execute() @@ -880,7 +882,7 @@ implements
  • rollback

    -
    protected void rollback(MasterProcedureEnv env)
    +
    protected void rollback(MasterProcedureEnv env)
    Description copied from class: Procedure
    The code to undo what was done by the execute() code. It is called when the procedure or one of the sub-procedures failed or an @@ -902,7 +904,7 @@ implements
  • isRollbackSupported

    -
    protected abstract boolean isRollbackSupported(org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProcedureProtos.RegionTransitionState state)
    +
    protected abstract boolean isRollbackSupported(org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProcedureProtos.RegionTransitionState state)
  • @@ -911,7 +913,7 @@ implements
  • abort

    -
    protected boolean abort(MasterProcedureEnv env)
    +
    protected boolean abort(MasterProcedureEnv env)
    Description copied from class: Procedure
    The abort() call is asynchronous and each procedure must decide how to deal with it, if they want to be abortable. The simplest implementation @@ -934,7 +936,7 @@ implements
  • acquireLock

    -
    protected Procedure.LockState acquireLock(MasterProcedureEnv env)
    +
    protected Procedure.LockState acquireLock(MasterProcedureEnv env)
    Description copied from class: Procedure
    The user should override this method if they need a lock on an Entity. A lock can be anything, and it is up to the implementor. The Procedure @@ -971,7 +973,7 @@ implements
  • releaseLock

    -
    protected void releaseLock(MasterProcedureEnv env)
    +
    protected void releaseLock(MasterProcedureEnv env)
    Description copied from class: Procedure
    The user should override this method, and release lock if necessary.
    @@ -986,7 +988,7 @@ implements
  • holdLock

    -
    protected boolean holdLock(MasterProcedureEnv env)
    +
    protected boolean holdLock(MasterProcedureEnv env)
    Description copied from class: Procedure
    Used to keep the procedure lock even when the procedure is yielding or suspended. Must implement Procedure.hasLock(Object) if you want to hold the lock for life @@ -1007,7 +1009,7 @@ implements
  • hasLock

    -
    protected boolean hasLock(MasterProcedureEnv env)
    +
    protected boolean hasLock(MasterProcedureEnv env)
    Description copied from class: Procedure
    This is used in conjunction with Procedure.holdLock(Object). If Procedure.holdLock(Object) returns true, the procedure executor will call acquireLock() once and thereafter @@ -1029,7 +1031,7 @@ implements
  • shouldWaitClientAck

    -
    protected boolean shouldWaitClientAck(MasterProcedureEnv env)
    +
    protected boolean shouldWaitClientAck(MasterProcedureEnv env)
    Description copied from class: Procedure
    By default, the executor will keep the procedure result around util the eviction TTL is expired. The client can cut down the waiting time @@ -1052,7 +1054,7 @@ implements
  • getServer

    -
    public abstract ServerName getServer(MasterProcedureEnv env)
    +
    public abstract ServerName getServer(MasterProcedureEnv env)
    Used by ServerCrashProcedure to see if this Assign/Unassign needs processing.
    Returns:
    http://git-wip-us.apache.org/repos/asf/hbase-site/blob/346adc37/devapidocs/org/apache/hadoop/hbase/master/assignment/UnassignProcedure.html ---------------------------------------------------------------------- diff --git a/devapidocs/org/apache/hadoop/hbase/master/assignment/UnassignProcedure.html b/devapidocs/org/apache/hadoop/hbase/master/assignment/UnassignProcedure.html index 737db72..dcc639e 100644 --- a/devapidocs/org/apache/hadoop/hbase/master/assignment/UnassignProcedure.html +++ b/devapidocs/org/apache/hadoop/hbase/master/assignment/UnassignProcedure.html @@ -124,20 +124,30 @@ var activeTableTab = "activeTableTab";

    @InterfaceAudience.Private
    -public class UnassignProcedure
    +public class UnassignProcedure
     extends RegionTransitionProcedure
    -
    Procedure that describe the unassignment of a single region. - There can only be one RegionTransitionProcedure per region running at the time, - since each procedure takes a lock on the region. +
    Procedure that describes the unassignment of a single region. + There can only be one RegionTransitionProcedure -- i.e. an assign or an unassign -- per region + running at a time, since each procedure takes a lock on the region.

    The Unassign starts by placing a "close region" request in the Remote Dispatcher - queue, and the procedure will then go into a "waiting state". + queue, and the procedure will then go into a "waiting state" (suspend). The Remote Dispatcher will batch the various requests for that server and they will be sent to the RS for execution. The RS will complete the open operation by calling master.reportRegionStateTransition(). - The AM will intercept the transition report, and notify the procedure. - The procedure will finish the unassign by publishing its new state on meta - or it will retry the unassign.

    + The AM will intercept the transition report, and notify this procedure. + The procedure will wakeup and finish the unassign by publishing its new state on meta. +

    If we are unable to contact the remote regionserver whether because of ConnectException + or socket timeout, we will call expire on the server we were trying to contact. We will remain + in suspended state waiting for a wake up from the ServerCrashProcedure that is processing the + failed server. The basic idea is that if we notice a crashed server, then we have a + responsibility; i.e. we should not let go of the region until we are sure the server that was + hosting has had its crash processed. If we let go of the region before then, an assign might + run before the logs have been split which would make for data loss. + +

    TODO: Rather than this tricky coordination between SCP and this Procedure, instead, work on + returning a SCP as our subprocedure; probably needs work on the framework to do this, + especially if the SCP already created.

  • @@ -198,10 +208,6 @@ extends private static org.apache.commons.logging.Log LOG  - -protected AtomicBoolean -serverCrashed  - @@ -389,7 +395,7 @@ extends
  • hostingServer

    -
    protected volatile ServerName hostingServer
    +
    protected volatile ServerName hostingServer
    Where to send the unassign RPC.
  • @@ -399,26 +405,17 @@ extends
  • destinationServer

    -
    protected volatile ServerName destinationServer
    +
    protected volatile ServerName destinationServer
    The Server we will subsequently assign the region too (can be null).
  • - - - -
    • force

      -
      private boolean force
      +
      private boolean force
  • @@ -435,7 +432,7 @@ extends
  • UnassignProcedure

    -
    public UnassignProcedure()
    +
    public UnassignProcedure()
  • @@ -444,7 +441,7 @@ extends
  • UnassignProcedure

    -
    public UnassignProcedure(HRegionInfo regionInfo,
    +
    public UnassignProcedure(HRegionInfo regionInfo,
                              ServerName hostingServer,
                              boolean force)
  • @@ -455,7 +452,7 @@ extends
  • UnassignProcedure

    -
    public UnassignProcedure(HRegionInfo regionInfo,
    +
    public UnassignProcedure(HRegionInfo regionInfo,
                              ServerName hostingServer,
                              ServerName destinationServer,
                              boolean force)
    @@ -475,7 +472,7 @@ extends
  • getTableOperationType

    -
    public TableProcedureInterface.TableOperationType getTableOperationType()
    +
    public TableProcedureInterface.TableOperationType getTableOperationType()
    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) @@ -492,7 +489,7 @@ extends
  • isRollbackSupported

    -
    protected boolean isRollbackSupported(org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProcedureProtos.RegionTransitionState state)
    +
    protected boolean isRollbackSupported(org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProcedureProtos.RegionTransitionState state)
    Specified by:
    isRollbackSupported in class RegionTransitionProcedure
    @@ -505,7 +502,7 @@ extends
  • serializeStateData

    -
    public void serializeStateData(OutputStream stream)
    +
    public void serializeStateData(OutputStream stream)
                             throws IOException
    Description copied from class: Procedure
    The user-level code of the procedure may have some state to @@ -527,7 +524,7 @@ extends
  • deserializeStateData

    -
    public void deserializeStateData(InputStream stream)
    +
    public void deserializeStateData(InputStream stream)
                               throws IOException
    Description copied from class: Procedure
    Called on store load to allow the user to decode the previously serialized @@ -548,7 +545,7 @@ extends
  • startTransition

    -
    protected boolean startTransition(MasterProcedureEnv env,
    +
    protected boolean startTransition(MasterProcedureEnv env,
                                       RegionStates.RegionStateNode regionNode)
    Specified by:
    @@ -562,7 +559,7 @@ extends
  • updateTransition

    -
    protected boolean updateTransition(MasterProcedureEnv env,
    +
    protected boolean updateTransition(MasterProcedureEnv env,
                                        RegionStates.RegionStateNode regionNode)
                                 throws IOException
    Description copied from class: RegionTransitionProcedure
    @@ -584,7 +581,7 @@ extends
  • finishTransition

    -
    protected void finishTransition(MasterProcedureEnv env,
    +
    protected void finishTransition(MasterProcedureEnv env,
                                     RegionStates.RegionStateNode regionNode)
                              throws IOException
    @@ -601,7 +598,7 @@ extends
  • remoteCallBuild

    -
    public RemoteProcedureDispatcher.RemoteOperation remoteCallBuild(MasterProcedureEnv env,
    +
    public RemoteProcedureDispatcher.RemoteOperation remoteCallBuild(MasterProcedureEnv env,
                                                                      ServerName serverName)
    Specified by:
    @@ -617,7 +614,7 @@ extends
  • reportTransition

    -
    protected void reportTransition(MasterProcedureEnv env,
    +
    protected void reportTransition(MasterProcedureEnv env,
                                     RegionStates.RegionStateNode regionNode,
                                     org.apache.hadoop.hbase.shaded.protobuf.generated.RegionServerStatusProtos.RegionStateTransition.TransitionCode code,
                                     long seqId)
    @@ -636,12 +633,16 @@ extends 
     
  • remoteCallFailed

    -
    protected void remoteCallFailed(MasterProcedureEnv env,
    -                                RegionStates.RegionStateNode regionNode,
    -                                IOException exception)
    +
    protected boolean remoteCallFailed(MasterProcedureEnv env,
    +                                   RegionStates.RegionStateNode regionNode,
    +                                   IOException exception)
    Specified by:
    remoteCallFailed in class RegionTransitionProcedure
    +
    Returns:
    +
    True if processing of fail is complete; the procedure will be woken from its suspend + and we'll go back to running through procedure steps: + otherwise if false we leave the procedure in suspended state.
  • @@ -651,7 +652,7 @@ extends
  • toStringClassDetails

    -
    public void toStringClassDetails(StringBuilder sb)
    +
    public void toStringClassDetails(StringBuilder sb)
    Description copied from class: Procedure
    Extend the toString() information with the procedure details e.g. className and parameters
    @@ -669,7 +670,7 @@ extends
  • getServer

    -
    public ServerName getServer(MasterProcedureEnv env)
    +
    public ServerName getServer(MasterProcedureEnv env)
    Description copied from class: RegionTransitionProcedure
    Used by ServerCrashProcedure to see if this Assign/Unassign needs processing.
    @@ -686,7 +687,7 @@ extends
  • getProcedureMetrics

    -
    protected ProcedureMetrics getProcedureMetrics(MasterProcedureEnv env)
    +
    protected ProcedureMetrics getProcedureMetrics(MasterProcedureEnv env)
    Description copied from class: Procedure
    Override this method to provide procedure specific counters for submitted count, failed count and time histogram.
    http://git-wip-us.apache.org/repos/asf/hbase-site/blob/346adc37/devapidocs/org/apache/hadoop/hbase/master/assignment/class-use/RegionStates.RegionStateNode.html ---------------------------------------------------------------------- diff --git a/devapidocs/org/apache/hadoop/hbase/master/assignment/class-use/RegionStates.RegionStateNode.html b/devapidocs/org/apache/hadoop/hbase/master/assignment/class-use/RegionStates.RegionStateNode.html index e8dcd1b..b6634ac 100644 --- a/devapidocs/org/apache/hadoop/hbase/master/assignment/class-use/RegionStates.RegionStateNode.html +++ b/devapidocs/org/apache/hadoop/hbase/master/assignment/class-use/RegionStates.RegionStateNode.html @@ -315,19 +315,19 @@ -protected void +protected boolean UnassignProcedure.remoteCallFailed(MasterProcedureEnv env, RegionStates.RegionStateNode regionNode, IOException exception)  -protected abstract void +protected abstract boolean RegionTransitionProcedure.remoteCallFailed(MasterProcedureEnv env, RegionStates.RegionStateNode regionNode, IOException exception)  -protected void +protected boolean AssignProcedure.remoteCallFailed(MasterProcedureEnv env, RegionStates.RegionStateNode regionNode, IOException exception)  http://git-wip-us.apache.org/repos/asf/hbase-site/blob/346adc37/devapidocs/org/apache/hadoop/hbase/master/assignment/class-use/RegionTransitionProcedure.html ---------------------------------------------------------------------- diff --git a/devapidocs/org/apache/hadoop/hbase/master/assignment/class-use/RegionTransitionProcedure.html b/devapidocs/org/apache/hadoop/hbase/master/assignment/class-use/RegionTransitionProcedure.html index 8bdc2f0..e1db7db 100644 --- a/devapidocs/org/apache/hadoop/hbase/master/assignment/class-use/RegionTransitionProcedure.html +++ b/devapidocs/org/apache/hadoop/hbase/master/assignment/class-use/RegionTransitionProcedure.html @@ -111,7 +111,7 @@ class  UnassignProcedure -
    Procedure that describe the unassignment of a single region.
    +
    Procedure that describes the unassignment of a single region.