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 C7D37200B6B for ; Thu, 14 Jul 2016 21:46:34 +0200 (CEST) Received: by cust-asf.ponee.io (Postfix) id C677B160A8C; Thu, 14 Jul 2016 19:46:34 +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 D20BF160A86 for ; Thu, 14 Jul 2016 21:46:32 +0200 (CEST) Received: (qmail 59942 invoked by uid 500); 14 Jul 2016 19:46:26 -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 58136 invoked by uid 99); 14 Jul 2016 19:46:25 -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; Thu, 14 Jul 2016 19:46:25 +0000 Received: by git1-us-west.apache.org (ASF Mail Server at git1-us-west.apache.org, from userid 33) id 9F94BE968A; Thu, 14 Jul 2016 19:46:25 +0000 (UTC) Content-Type: text/plain; charset="us-ascii" MIME-Version: 1.0 Content-Transfer-Encoding: 7bit From: busbey@apache.org To: commits@hbase.apache.org Date: Thu, 14 Jul 2016 19:46:54 -0000 Message-Id: In-Reply-To: <588ce14c0d8544b2906deffa43a1c0cc@git.apache.org> References: <588ce14c0d8544b2906deffa43a1c0cc@git.apache.org> X-Mailer: ASF-Git Admin Mailer Subject: [31/52] [partial] hbase-site git commit: Published site at a55af38689fbe273e716ebbf6191e9515986dbf3. archived-at: Thu, 14 Jul 2016 19:46:35 -0000 http://git-wip-us.apache.org/repos/asf/hbase-site/blob/975096b1/devapidocs/org/apache/hadoop/hbase/procedure2/Procedure.html ---------------------------------------------------------------------- diff --git a/devapidocs/org/apache/hadoop/hbase/procedure2/Procedure.html b/devapidocs/org/apache/hadoop/hbase/procedure2/Procedure.html index f8671bf..0d04412 100644 --- a/devapidocs/org/apache/hadoop/hbase/procedure2/Procedure.html +++ b/devapidocs/org/apache/hadoop/hbase/procedure2/Procedure.html @@ -379,220 +379,224 @@ implements getTimeRemaining()  +protected boolean +hasChildren()  + + boolean hasException()  - + boolean hasOwner()  - + boolean hasParent()  - + boolean hasTimeout()  - + protected void incChildrenLatch()
Called by the ProcedureExecutor on procedure-load to restore the latch state
- + boolean isFailed()  - + boolean isFinished()  - + boolean isSuccess()  - + boolean isSuspended()  - + boolean isWaiting()  - + protected boolean isYieldAfterExecutionStep(TEnvironment env)
By default, the executor will try ro run procedures start to finish.
- + protected static Procedure newInstance(String className)  - + protected void releaseLock(TEnvironment env)
The user should override this method, and release lock if necessary.
- + protected boolean removeStackIndex()  - + void resume()  - + protected abstract void rollback(TEnvironment env)
The code to undo what done by the execute() code.
- + protected abstract void serializeStateData(OutputStream stream)
The user-level code of the procedure may have some state to persist (e.g.
- + protected void setAbortFailure(String source, String msg)  - + protected void setChildrenLatch(int numChildren)
Called by the ProcedureExecutor on procedure-load to restore the latch state
- + protected void setFailure(RemoteProcedureException exception)  - + protected void setFailure(String source, Throwable cause)  - + private void setLastUpdate(long lastUpdate)
Called on store load to initialize the Procedure internals after the creation/deserialization.
- + protected void setNonceKey(NonceKey nonceKey)
Called by the ProcedureExecutor to set the value to the newly created procedure.
- + void setOwner(String owner)  - + protected void setParentProcId(long parentProcId)
Called by the ProcedureExecutor to assign the parent to the newly created procedure.
- + protected void setProcId(long procId)
Called by the ProcedureExecutor to assign the ID to the newly created procedure.
- + protected void setResult(byte[] result)
The procedure may leave a "result" on completion.
- + protected void setStackIndexes(List<Integer> stackIndexes)
Called on store load to initialize the Procedure internals after the creation/deserialization.
- + protected void setStartTime(long startTime)
Called on store load to initialize the Procedure internals after the creation/deserialization.
- + protected void setState(org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureState state)  - + protected void setTimeout(int timeout)  - + protected boolean setTimeoutFailure()  - + protected boolean shouldWaitClientAck(TEnvironment env)
By default, the executor will keep the procedure result around util the eviction TTL is expired.
- + void suspend()  - + String toString()  - + protected String toStringClass()  - + protected void toStringClassDetails(StringBuilder builder)
Extend the toString() information with the procedure details e.g.
- + String toStringDetails()
Extend the toString() information with more procedure details
- + protected StringBuilder toStringSimpleSB()
Build the StringBuilder for the simple form of procedure string.
- + protected void toStringState(StringBuilder builder)
Called from toString() when interpolating Procedure state
- + protected void updateTimestamp()  - + protected static void validateClass(Procedure proc)  - + protected boolean wasExecuted()  @@ -1456,6 +1460,16 @@ protected boolean  + + + @@ -1463,7 +1477,7 @@ protected boolean 

addStackIndex

@InterfaceAudience.Private
-protected void addStackIndex(int index)
+protected void addStackIndex(int index)
Called by the RootProcedureState on procedure execution. Each procedure store its stack-index positions.
@@ -1475,7 +1489,7 @@ protected void 

removeStackIndex

@InterfaceAudience.Private
-protected boolean removeStackIndex()
+protected boolean removeStackIndex() @@ -1485,7 +1499,7 @@ protected boolean 

setStackIndexes

@InterfaceAudience.Private
-protected void setStackIndexes(List<Integer> stackIndexes)
+protected void setStackIndexes(List<Integer> stackIndexes)
Called on store load to initialize the Procedure internals after the creation/deserialization.
@@ -1497,7 +1511,7 @@ protected void 

wasExecuted

@InterfaceAudience.Private
-protected boolean wasExecuted()
+protected boolean wasExecuted() @@ -1507,7 +1521,7 @@ protected boolean 

getStackIndexes

@InterfaceAudience.Private
-protected int[] getStackIndexes()
+protected int[] getStackIndexes() @@ -1516,7 +1530,7 @@ protected int[] 
  • compareTo

    -
    public int compareTo(Procedure other)
    +
    public int compareTo(Procedure other)
    Specified by:
    compareTo in interface Comparable<Procedure>
    @@ -1529,7 +1543,7 @@ protected int[] 
  • getProcIdHashCode

    -
    public static long getProcIdHashCode(long procId)
    +
    public static long getProcIdHashCode(long procId)
    Get an hashcode for the specified Procedure ID
    Returns:
    the hashcode for the specified procId
  • @@ -1541,7 +1555,7 @@ protected int[] 

    getRootProcedureId

    @InterfaceAudience.Private
    -protected static Long getRootProcedureId(Map<Long,Procedure> procedures,
    +protected static Long getRootProcedureId(Map<Long,Procedure> procedures,
                                                     Procedure proc)
  • @@ -1551,7 +1565,7 @@ protected static 
  • newInstance

    -
    protected static Procedure newInstance(String className)
    +
    protected static Procedure newInstance(String className)
                                     throws IOException
    Throws:
    IOException
    @@ -1563,7 +1577,7 @@ protected static 
  • validateClass

    -
    protected static void validateClass(Procedure proc)
    +
    protected static void validateClass(Procedure proc)
                                  throws IOException
    Throws:
    IOException
    @@ -1576,7 +1590,7 @@ protected static 

    createProcedureInfo

    @InterfaceAudience.Private
    -public static ProcedureInfo createProcedureInfo(Procedure proc,
    +public static ProcedureInfo createProcedureInfo(Procedure proc,
                                                               NonceKey nonceKey)
    Helper to create the ProcedureInfo from Procedure.
  • @@ -1588,7 +1602,7 @@ public static 

    convert

    @InterfaceAudience.Private
    -public static org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure convert(Procedure proc)
    +public static org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure convert(Procedure proc)
                                                                                         throws IOException
    Helper to convert the procedure to protobuf. Used by ProcedureStore implementations.
    @@ -1603,7 +1617,7 @@ public static org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Pr
  • convert

    @InterfaceAudience.Private
    -public static Procedure convert(org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure proto)
    +public static Procedure convert(org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure proto)
                              throws IOException
    Helper to convert the protobuf procedure. Used by ProcedureStore implementations. http://git-wip-us.apache.org/repos/asf/hbase-site/blob/975096b1/devapidocs/org/apache/hadoop/hbase/procedure2/ProcedureExecutor.CompletedProcedureCleaner.html ---------------------------------------------------------------------- diff --git a/devapidocs/org/apache/hadoop/hbase/procedure2/ProcedureExecutor.CompletedProcedureCleaner.html b/devapidocs/org/apache/hadoop/hbase/procedure2/ProcedureExecutor.CompletedProcedureCleaner.html index 6fbb034..58cd75c 100644 --- a/devapidocs/org/apache/hadoop/hbase/procedure2/ProcedureExecutor.CompletedProcedureCleaner.html +++ b/devapidocs/org/apache/hadoop/hbase/procedure2/ProcedureExecutor.CompletedProcedureCleaner.html @@ -263,7 +263,7 @@ extends Procedure -acquireLock, addStackIndex, beforeReplay, childrenCountDown, compareTo, completionCleanup, convert, convert, createProcedureInfo, doExecute, doRollback, elapsedTime, getException, getLastUpdate, getNonceKey, getOwner, getParentProcId, getProcId, getProcIdHashCode, getResult, getRootProcedureId, getStackIndexes, getStartTime, getState, getTimeout, getTimeRemaining, hasException, hasOwner, hasParent, hasTimeout, incChildrenLatch, isFailed, isFinished, isSuccess, isSuspended, isWaiting, isYieldAfterExecutionStep, newInstance, releaseLock, removeStackIndex, resume, setAbortFailure, setChildrenLatch, setFailure, setFailure, setNonceKey, setOwner, setParentProcId, setProcId, setResult, setStackIndexes, setStartTime, setState, setTimeout, setTimeoutFailure, shouldWaitClientAck, suspend, toString, toStringClass, toStringClassDetails, toStringDetails, toStringSimpleSB, toStringState, updateTimestamp, validateClass, wasExecuted
  • +acquireLock, addStackIndex, beforeReplay, childrenCountDown, compareTo, completionCleanup, convert, convert, createProcedureInfo, doExecute, doRollback, elapsedTime, getException, getLastUpdate, getNonceKey, getOwner, getParentProcId, getProcId, getProcIdHashCode, getResult, getRootProcedureId, getStackIndexes, getStartTime, getState, getTimeout, getTimeRemaining, hasChildren, hasException, hasOwner, hasParent, hasTimeout, incChildrenLatch, isFailed, isFinished, isSuccess, isSuspended, isWaiting, isYieldAfterExecutionStep, newInstance, releaseLock, removeStackIndex, resume, setAbortFailure, setChildrenLatch, setFailure, setFailure, setNonceKey, setOwner, setParentProcId, se tProcId, setResult, setStackIndexes, setStartTime, setState, setTimeout, setTimeoutFailure, shouldWaitClientAck, suspend, toString, toStringClass, toStringClassDetails, toStringDetails, toStringSimpleSB, toStringState, updateTimestamp, validateClass, wasExecuted
  • @@ -780,7 +786,7 @@ extends
  • isRunning

    -
    public boolean isRunning()
    +
    public boolean isRunning()
  • @@ -789,7 +795,7 @@ extends
  • getNumThreads

    -
    public int getNumThreads()
    +
    public int getNumThreads()
    Returns:
    the number of execution threads.
  • @@ -799,7 +805,7 @@ extends
  • getActiveExecutorCount

    -
    public int getActiveExecutorCount()
    +
    public int getActiveExecutorCount()
  • @@ -808,7 +814,7 @@ extends
  • getEnvironment

    -
    public TEnvironment getEnvironment()
    +
    public TEnvironment getEnvironment()
  • @@ -817,7 +823,7 @@ extends
  • getStore

    -
    public ProcedureStore getStore()
    +
    public ProcedureStore getStore()
  • @@ -826,7 +832,7 @@ extends
  • registerListener

    -
    public void registerListener(ProcedureExecutor.ProcedureExecutorListener listener)
    +
    public void registerListener(ProcedureExecutor.ProcedureExecutorListener listener)
  • @@ -835,7 +841,7 @@ extends
  • unregisterListener

    -
    public boolean unregisterListener(ProcedureExecutor.ProcedureExecutorListener listener)
    +
    public boolean unregisterListener(ProcedureExecutor.ProcedureExecutorListener listener)
  • @@ -844,7 +850,7 @@ extends
  • listProcedures

    -
    public List<ProcedureInfolistProcedures()
    +
    public List<ProcedureInfolistProcedures()
    List procedures.
    Returns:
    the procedures in a list
  • @@ -855,7 +861,7 @@ extends
  • submitProcedure

    -
    public long submitProcedure(Procedure proc)
    +
    public long submitProcedure(Procedure proc)
    Add a new root-procedure to the executor.
    Parameters:
    proc - the new procedure to execute.
    Returns:
    the procedure id, that can be used to monitor the operation
    @@ -867,7 +873,7 @@ extends
  • submitProcedure

    -
    public long submitProcedure(Procedure proc,
    +
    public long submitProcedure(Procedure proc,
                        long nonceGroup,
                        long nonce)
    Add a new root-procedure to the executor.
    @@ -881,7 +887,7 @@ extends
  • getResult

    -
    public ProcedureInfo getResult(long procId)
    +
    public ProcedureInfo getResult(long procId)
  • @@ -890,7 +896,7 @@ extends
  • isFinished

    -
    public boolean isFinished(long procId)
    +
    public boolean isFinished(long procId)
    Return true if the procedure is finished. The state may be "completed successfully" or "failed and rolledback". Use getResult() to check the state or get the result data.
    @@ -904,7 +910,7 @@ extends
  • isStarted

    -
    public boolean isStarted(long procId)
    +
    public boolean isStarted(long procId)
    Return true if the procedure is started.
    Parameters:
    procId - the ID of the procedure to check
    Returns:
    true if the procedure execution is started, otherwise false.
    @@ -916,7 +922,7 @@ extends
  • removeResult

    -
    public void removeResult(long procId)
    +
    public void removeResult(long procId)
    Mark the specified completed procedure, as ready to remove.
    Parameters:
    procId - the ID of the procedure to remove
  • @@ -927,7 +933,7 @@ extends
  • abort

    -
    public boolean abort(long procId)
    +
    public boolean abort(long procId)
    Send an abort notification the specified procedure. Depending on the procedure implementation the abort can be considered or ignored.
    Parameters:
    procId - the procedure to abort
    @@ -940,7 +946,7 @@ extends
  • abort

    -
    public boolean abort(long procId,
    +
    public boolean abort(long procId,
                 boolean mayInterruptIfRunning)
    Send an abort notification the specified procedure. Depending on the procedure implementation the abort can be considered or ignored.
    @@ -954,7 +960,7 @@ extends
  • isProcedureOwner

    -
    public boolean isProcedureOwner(long procId,
    +
    public boolean isProcedureOwner(long procId,
                            User user)
    Check if the user is this procedure's owner
    Parameters:
    procId - the target procedure
    user - the user
    @@ -968,7 +974,7 @@ extends
  • getResults

    -
    public Map<Long,ProcedureInfogetResults()
    +
    public Map<Long,ProcedureInfogetResults()
  • @@ -977,7 +983,7 @@ extends
  • getProcedure

    -
    public Procedure getProcedure(long procId)
    +
    public Procedure getProcedure(long procId)
  • @@ -986,7 +992,7 @@ extends
  • getRunnableSet

    -
    protected ProcedureRunnableSet getRunnableSet()
    +
    protected ProcedureRunnableSet getRunnableSet()
  • @@ -995,7 +1001,7 @@ extends
  • execLoop

    -
    private void execLoop()
    +
    private void execLoop()
    Execution loop (N threads) while the executor is in a running state, fetch a procedure from the runnables queue and start the execution.
    @@ -1007,7 +1013,7 @@ extends
  • execLoop

    -
    private void execLoop(Procedure proc)
    +
    private void execLoop(Procedure proc)
  • @@ -1016,7 +1022,7 @@ extends
  • timeoutLoop

    -
    private void timeoutLoop()
    +
    private void timeoutLoop()
  • @@ -1025,7 +1031,7 @@ extends
  • executeRollback

    -
    private boolean executeRollback(long rootProcId,
    +
    private boolean executeRollback(long rootProcId,
                           RootProcedureState procStack)
    Execute the rollback of the full procedure stack. Once the procedure is rolledback, the root-procedure will be visible as @@ -1038,7 +1044,7 @@ extends
  • executeRollback

    -
    private boolean executeRollback(Procedure proc)
    +
    private boolean executeRollback(Procedure proc)
    Execute the rollback of the procedure step. It updates the store with the new state (stack index) or will remove completly the procedure in case it is a child.
    @@ -1050,7 +1056,7 @@ extends
  • execProcedure

    -
    private void execProcedure(RootProcedureState procStack,
    +
    private void execProcedure(RootProcedureState procStack,
                      Procedure procedure)
    Executes the specified procedure - calls the doExecute() of the procedure @@ -1069,13 +1075,24 @@ extends + + + @@ -1085,7 +1102,7 @@ extends
  • sendProcedureLoadedNotification

    -
    private void sendProcedureLoadedNotification(long procId)
    +
    private void sendProcedureLoadedNotification(long procId)
  • @@ -1094,7 +1111,7 @@ extends
  • sendProcedureAddedNotification

    -
    private void sendProcedureAddedNotification(long procId)
    +
    private void sendProcedureAddedNotification(long procId)
  • @@ -1103,7 +1120,7 @@ extends
  • sendProcedureFinishedNotification

    -
    private void sendProcedureFinishedNotification(long procId)
    +
    private void sendProcedureFinishedNotification(long procId)
  • @@ -1112,7 +1129,7 @@ extends
  • nextProcId

    -
    private long nextProcId()
    +
    private long nextProcId()
  • @@ -1121,7 +1138,7 @@ extends
  • getRootProcedureId

    -
    private Long getRootProcedureId(Procedure proc)
    +
    private Long getRootProcedureId(Procedure proc)
  • @@ -1130,7 +1147,7 @@ extends
  • procedureFinished

    -
    private void procedureFinished(Procedure proc)
    +
    private void procedureFinished(Procedure proc)
  • @@ -1139,7 +1156,7 @@ extends
  • getResultOrProcedure

    -
    public Pair<ProcedureInfo,ProceduregetResultOrProcedure(long procId)
    +
    public Pair<ProcedureInfo,ProceduregetResultOrProcedure(long procId)