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 B29F02004F2 for ; Sat, 26 Aug 2017 17:10:43 +0200 (CEST) Received: by cust-asf.ponee.io (Postfix) id B0E2516502D; Sat, 26 Aug 2017 15:10:43 +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 89D7216501E for ; Sat, 26 Aug 2017 17:10:41 +0200 (CEST) Received: (qmail 41545 invoked by uid 500); 26 Aug 2017 15:10:37 -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 38310 invoked by uid 99); 26 Aug 2017 15:10:34 -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; Sat, 26 Aug 2017 15:10:34 +0000 Received: by git1-us-west.apache.org (ASF Mail Server at git1-us-west.apache.org, from userid 33) id 17021F5F3F; Sat, 26 Aug 2017 15:10:31 +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: Sat, 26 Aug 2017 15:10:40 -0000 Message-Id: <9b1abadf14d04d0f93e4f25ecaf167dd@git.apache.org> In-Reply-To: <314affcace494020babafe808278a87a@git.apache.org> References: <314affcace494020babafe808278a87a@git.apache.org> X-Mailer: ASF-Git Admin Mailer Subject: [11/51] [partial] hbase-site git commit: Published site at . archived-at: Sat, 26 Aug 2017 15:10:43 -0000 http://git-wip-us.apache.org/repos/asf/hbase-site/blob/ebf9a8b8/devapidocs/org/apache/hadoop/hbase/client/AsyncTable.html ---------------------------------------------------------------------- diff --git a/devapidocs/org/apache/hadoop/hbase/client/AsyncTable.html b/devapidocs/org/apache/hadoop/hbase/client/AsyncTable.html index 1b54d76..d9bd132 100644 --- a/devapidocs/org/apache/hadoop/hbase/client/AsyncTable.html +++ b/devapidocs/org/apache/hadoop/hbase/client/AsyncTable.html @@ -110,7 +110,7 @@ var activeTableTab = "activeTableTab";

@InterfaceAudience.Public
-public interface AsyncTable
+public interface AsyncTable
 extends AsyncTableBase
The asynchronous table for normal users.

@@ -119,6 +119,10 @@ extends Since: +

2.0.0
+
@@ -191,7 +195,7 @@ extends
  • getScanner

    -
    default ResultScanner getScanner(byte[] family)
    +
    default ResultScanner getScanner(byte[] family)
    Gets a scanner on the current table for the given family.
    Parameters:
    @@ -207,7 +211,7 @@ extends
  • getScanner

    -
    default ResultScanner getScanner(byte[] family,
    +
    default ResultScanner getScanner(byte[] family,
                                      byte[] qualifier)
    Gets a scanner on the current table for the given family and qualifier.
    @@ -225,7 +229,7 @@ extends
  • getScanner

    -
    ResultScanner getScanner(Scan scan)
    +
    ResultScanner getScanner(Scan scan)
    Returns a scanner on the current table as specified by the Scan object.
    Parameters:
    @@ -241,7 +245,7 @@ extends
  • scan

    -
    void scan(Scan scan,
    +
    void scan(Scan scan,
               ScanResultConsumer consumer)
    The scan API uses the observer pattern. All results that match the given scan object will be passed to the given consumer by calling ScanResultConsumer.onNext(Result). http://git-wip-us.apache.org/repos/asf/hbase-site/blob/ebf9a8b8/devapidocs/org/apache/hadoop/hbase/client/AsyncTableBase.html ---------------------------------------------------------------------- diff --git a/devapidocs/org/apache/hadoop/hbase/client/AsyncTableBase.html b/devapidocs/org/apache/hadoop/hbase/client/AsyncTableBase.html index b9c3905..7ebb699 100644 --- a/devapidocs/org/apache/hadoop/hbase/client/AsyncTableBase.html +++ b/devapidocs/org/apache/hadoop/hbase/client/AsyncTableBase.html @@ -110,7 +110,7 @@ var activeTableTab = "activeTableTab";

    @InterfaceAudience.Public
    -public interface AsyncTableBase
    +public interface AsyncTableBase
    The base interface for asynchronous version of Table. Obtain an instance from a AsyncConnection.

    @@ -118,6 +118,10 @@ public interface CompletableFuture.

    +
    +
    Since:
    +
    2.0.0
    +
  • @@ -389,7 +393,7 @@ public interface
  • getName

    -
    TableName getName()
    +
    TableName getName()
    Gets the fully qualified table name instance of this table.
  • @@ -399,7 +403,7 @@ public interface
  • getConfiguration

    -
    org.apache.hadoop.conf.Configuration getConfiguration()
    +
    org.apache.hadoop.conf.Configuration getConfiguration()
    Returns the Configuration object used by this instance.

    The reference returned is not a copy, so any change made to it will affect this instance.

    @@ -411,7 +415,7 @@ public interface
  • getRpcTimeout

    -
    long getRpcTimeout(TimeUnit unit)
    +
    long getRpcTimeout(TimeUnit unit)
    Get timeout of each rpc request in this Table instance. It will be overridden by a more specific rpc timeout config such as readRpcTimeout or writeRpcTimeout.
    @@ -427,7 +431,7 @@ public interface
  • getReadRpcTimeout

    -
    long getReadRpcTimeout(TimeUnit unit)
    +
    long getReadRpcTimeout(TimeUnit unit)
    Get timeout of each rpc read request in this Table instance.
  • @@ -437,7 +441,7 @@ public interface
  • getWriteRpcTimeout

    -
    long getWriteRpcTimeout(TimeUnit unit)
    +
    long getWriteRpcTimeout(TimeUnit unit)
    Get timeout of each rpc write request in this Table instance.
  • @@ -447,7 +451,7 @@ public interface
  • getOperationTimeout

    -
    long getOperationTimeout(TimeUnit unit)
    +
    long getOperationTimeout(TimeUnit unit)
    Get timeout of each operation in Table instance.
  • @@ -457,7 +461,7 @@ public interface
  • getScanTimeout

    -
    long getScanTimeout(TimeUnit unit)
    +
    long getScanTimeout(TimeUnit unit)
    Get the timeout of a single operation in a scan. It works like operation timeout for other operations.
  • @@ -468,7 +472,7 @@ public interface
  • exists

    -
    default CompletableFuture<Booleanexists(Get get)
    +
    default CompletableFuture<Booleanexists(Get get)
    Test for the existence of columns in the table, as specified by the Get.

    This will return true if the Get matches one or more keys, false if not. @@ -487,7 +491,7 @@ public interface

  • get

    -
    CompletableFuture<Resultget(Get get)
    +
    CompletableFuture<Resultget(Get get)
    Extracts certain cells from a given row.
    Parameters:
    @@ -506,7 +510,7 @@ public interface
  • put

    -
    CompletableFuture<Voidput(Put put)
    +
    CompletableFuture<Voidput(Put put)
    Puts some data to the table.
    Parameters:
    @@ -522,7 +526,7 @@ public interface
  • delete

    -
    CompletableFuture<Voiddelete(Delete delete)
    +
    CompletableFuture<Voiddelete(Delete delete)
    Deletes the specified cells/row.
    Parameters:
    @@ -538,7 +542,7 @@ public interface
  • append

    -
    CompletableFuture<Resultappend(Append append)
    +
    CompletableFuture<Resultappend(Append append)
    Appends values to one or more columns within a single row.

    This operation does not appear atomic to readers. Appends are done under a single row lock, so @@ -560,7 +564,7 @@ public interface

  • increment

    -
    CompletableFuture<Resultincrement(Increment increment)
    +
    CompletableFuture<Resultincrement(Increment increment)
    Increments one or more columns within a single row.

    This operation does not appear atomic to readers. Increments are done under a single row lock, @@ -582,7 +586,7 @@ public interface

  • incrementColumnValue

    -
    default CompletableFuture<LongincrementColumnValue(byte[] row,
    +
    default CompletableFuture<LongincrementColumnValue(byte[] row,
                                                          byte[] family,
                                                          byte[] qualifier,
                                                          long amount)
    @@ -607,7 +611,7 @@ public interface
  • incrementColumnValue

    -
    default CompletableFuture<LongincrementColumnValue(byte[] row,
    +
    default CompletableFuture<LongincrementColumnValue(byte[] row,
                                                          byte[] family,
                                                          byte[] qualifier,
                                                          long amount,
    @@ -637,7 +641,7 @@ public interface 
     
  • checkAndPut

    -
    default CompletableFuture<BooleancheckAndPut(byte[] row,
    +
    default CompletableFuture<BooleancheckAndPut(byte[] row,
                                                    byte[] family,
                                                    byte[] qualifier,
                                                    byte[] value,
    @@ -664,7 +668,7 @@ public interface 
     
  • checkAndPut

    -
    CompletableFuture<BooleancheckAndPut(byte[] row,
    +
    CompletableFuture<BooleancheckAndPut(byte[] row,
                                            byte[] family,
                                            byte[] qualifier,
                                            CompareFilter.CompareOp compareOp,
    @@ -693,7 +697,7 @@ public interface 
     
  • checkAndDelete

    -
    default CompletableFuture<BooleancheckAndDelete(byte[] row,
    +
    default CompletableFuture<BooleancheckAndDelete(byte[] row,
                                                       byte[] family,
                                                       byte[] qualifier,
                                                       byte[] value,
    @@ -720,7 +724,7 @@ public interface 
     
  • checkAndDelete

    -
    CompletableFuture<BooleancheckAndDelete(byte[] row,
    +
    CompletableFuture<BooleancheckAndDelete(byte[] row,
                                               byte[] family,
                                               byte[] qualifier,
                                               CompareFilter.CompareOp compareOp,
    @@ -749,7 +753,7 @@ public interface 
     
  • mutateRow

    -
    CompletableFuture<VoidmutateRow(RowMutations mutation)
    +
    CompletableFuture<VoidmutateRow(RowMutations mutation)
    Performs multiple mutations atomically on a single row. Currently Put and Delete are supported.
    @@ -766,7 +770,7 @@ public interface
  • checkAndMutate

    -
    default CompletableFuture<BooleancheckAndMutate(byte[] row,
    +
    default CompletableFuture<BooleancheckAndMutate(byte[] row,
                                                       byte[] family,
                                                       byte[] qualifier,
                                                       byte[] value,
    @@ -793,7 +797,7 @@ public interface 
     
  • checkAndMutate

    -
    CompletableFuture<BooleancheckAndMutate(byte[] row,
    +
    CompletableFuture<BooleancheckAndMutate(byte[] row,
                                               byte[] family,
                                               byte[] qualifier,
                                               CompareFilter.CompareOp compareOp,
    @@ -822,7 +826,7 @@ public interface 
     
  • scanAll

    -
    CompletableFuture<List<Result>> scanAll(Scan scan)
    +
    CompletableFuture<List<Result>> scanAll(Scan scan)
    Return all the results that match the given scan object.

    Notice that usually you should use this method with a Scan object that has limit set. @@ -868,7 +872,7 @@ public interface

  • exists

    -
    default List<CompletableFuture<Boolean>> exists(List<Get> gets)
    +
    default List<CompletableFuture<Boolean>> exists(List<Get> gets)
    Test for the existence of columns in the table, as specified by the Gets.

    This will return a list of booleans. Each value will be true if the related Get matches one or @@ -889,7 +893,7 @@ public interface

  • existsAll

    -
    default CompletableFuture<List<Boolean>> existsAll(List<Get> gets)
    +
    default CompletableFuture<List<Boolean>> existsAll(List<Get> gets)
    A simple version for batch exists. It will fail if there are any failures and you will get the whole result boolean list at once if the operation is succeeded.
    @@ -906,7 +910,7 @@ public interface
  • get

    -
    List<CompletableFuture<Result>> get(List<Get> gets)
    +
    List<CompletableFuture<Result>> get(List<Get> gets)
    Extracts certain cells from the given rows, in batch.

    Notice that you may not get all the results with this function, which means some of the @@ -926,7 +930,7 @@ public interface

  • getAll

    -
    default CompletableFuture<List<Result>> getAll(List<Get> gets)
    +
    default CompletableFuture<List<Result>> getAll(List<Get> gets)
    A simple version for batch get. It will fail if there are any failures and you will get the whole result list at once if the operation is succeeded.
    @@ -943,7 +947,7 @@ public interface
  • put

    -
    List<CompletableFuture<Void>> put(List<Put> puts)
    +
    List<CompletableFuture<Void>> put(List<Put> puts)
    Puts some data in the table, in batch.
    Parameters:
    @@ -959,7 +963,7 @@ public interface
  • putAll

    -
    default CompletableFuture<VoidputAll(List<Put> puts)
    +
    default CompletableFuture<VoidputAll(List<Put> puts)
    A simple version of batch put. It will fail if there are any failures.
    Parameters:
    @@ -975,7 +979,7 @@ public interface
  • delete

    -
    List<CompletableFuture<Void>> delete(List<Delete> deletes)
    +
    List<CompletableFuture<Void>> delete(List<Delete> deletes)
    Deletes the specified cells/rows in bulk.
    Parameters:
    @@ -991,7 +995,7 @@ public interface
  • deleteAll

    -
    default CompletableFuture<VoiddeleteAll(List<Delete> deletes)
    +
    default CompletableFuture<VoiddeleteAll(List<Delete> deletes)
    A simple version of batch delete. It will fail if there are any failures.
    Parameters:
    @@ -1007,7 +1011,7 @@ public interface
  • batch

    -
    <T> List<CompletableFuture<T>> batch(List<? extends Row> actions)
    +
    <T> List<CompletableFuture<T>> batch(List<? extends Row> actions)
    Method that does a batch call on Deletes, Gets, Puts, Increments and Appends. The ordering of execution of the actions is not defined. Meaning if you do a Put and a Get in the same batch(java.util.List<? extends org.apache.hadoop.hbase.client.Row>) call, you will not necessarily be guaranteed that the Get returns what the Put @@ -1026,7 +1030,7 @@ public interface
  • batchAll

    -
    default <T> CompletableFuture<List<T>> batchAll(List<? extends Row> actions)
    +
    default <T> CompletableFuture<List<T>> batchAll(List<? extends Row> actions)
    A simple version of batch. It will fail if there are any failures and you will get the whole result list at once if the operation is succeeded.
    http://git-wip-us.apache.org/repos/asf/hbase-site/blob/ebf9a8b8/devapidocs/org/apache/hadoop/hbase/client/AsyncTableBuilder.html ---------------------------------------------------------------------- diff --git a/devapidocs/org/apache/hadoop/hbase/client/AsyncTableBuilder.html b/devapidocs/org/apache/hadoop/hbase/client/AsyncTableBuilder.html index 91e6abb..bba1ac3 100644 --- a/devapidocs/org/apache/hadoop/hbase/client/AsyncTableBuilder.html +++ b/devapidocs/org/apache/hadoop/hbase/client/AsyncTableBuilder.html @@ -106,12 +106,16 @@ var activeTableTab = "activeTableTab";

    @InterfaceAudience.Public
    -public interface AsyncTableBuilder<T extends AsyncTableBase>
    +public interface AsyncTableBuilder<T extends AsyncTableBase>
  • For creating AsyncTable or RawAsyncTable.

    The implementation should have default configurations set before returning the builder to user. So users are free to only set the configs they care about to create a new AsyncTable/RawAsyncTable instance.

    +
    +
    Since:
    +
    2.0.0
    +
  • @@ -218,7 +222,7 @@ public interface
  • setOperationTimeout

    -
    AsyncTableBuilder<TsetOperationTimeout(long timeout,
    +
    AsyncTableBuilder<TsetOperationTimeout(long timeout,
                                              TimeUnit unit)
    Set timeout for a whole operation such as get, put or delete. Notice that scan will not be effected by this value, see scanTimeoutNs. @@ -239,7 +243,7 @@ public interface
  • setScanTimeout

    -
    AsyncTableBuilder<TsetScanTimeout(long timeout,
    +
    AsyncTableBuilder<TsetScanTimeout(long timeout,
                                         TimeUnit unit)
    As now we have heartbeat support for scan, ideally a scan will never timeout unless the RS is crash. The RS will always return something before the rpc timed out or scan timed out to tell @@ -257,7 +261,7 @@ public interface
  • setRpcTimeout

    -
    AsyncTableBuilder<TsetRpcTimeout(long timeout,
    +
    AsyncTableBuilder<TsetRpcTimeout(long timeout,
                                        TimeUnit unit)
    Set timeout for each rpc request.

    @@ -271,7 +275,7 @@ public interface

  • setReadRpcTimeout

    -
    AsyncTableBuilder<TsetReadRpcTimeout(long timeout,
    +
    AsyncTableBuilder<TsetReadRpcTimeout(long timeout,
                                            TimeUnit unit)
    Set timeout for each read(get, scan) rpc request.
  • @@ -282,7 +286,7 @@ public interface
  • setWriteRpcTimeout

    -
    AsyncTableBuilder<TsetWriteRpcTimeout(long timeout,
    +
    AsyncTableBuilder<TsetWriteRpcTimeout(long timeout,
                                             TimeUnit unit)
    Set timeout for each write(put, delete) rpc request.
  • @@ -293,7 +297,7 @@ public interface
  • setRetryPause

    -
    AsyncTableBuilder<TsetRetryPause(long pause,
    +
    AsyncTableBuilder<TsetRetryPause(long pause,
                                        TimeUnit unit)
    Set the base pause time for retrying. We use an exponential policy to generate sleep time when retrying.
    @@ -305,7 +309,7 @@ public interface
  • setMaxRetries

    -
    default AsyncTableBuilder<TsetMaxRetries(int maxRetries)
    +
    default AsyncTableBuilder<TsetMaxRetries(int maxRetries)
    Set the max retry times for an operation. Usually it is the max attempt times minus 1.

    Operation timeout and max attempt times(or max retry times) are both limitations for retrying, @@ -323,7 +327,7 @@ public interface

  • setMaxAttempts

    -
    AsyncTableBuilder<TsetMaxAttempts(int maxAttempts)
    +
    AsyncTableBuilder<TsetMaxAttempts(int maxAttempts)
    Set the max attempt times for an operation. Usually it is the max retry times plus 1. Operation timeout and max attempt times(or max retry times) are both limitations for retrying, we will stop retrying when we reach any of the limitations.
    @@ -340,7 +344,7 @@ public interface
  • setStartLogErrorsCnt

    -
    AsyncTableBuilder<TsetStartLogErrorsCnt(int startLogErrorsCnt)
    +
    AsyncTableBuilder<TsetStartLogErrorsCnt(int startLogErrorsCnt)
    Set the number of retries that are allowed before we start to log.
  • @@ -350,7 +354,7 @@ public interface
  • build

    -
    T build()
    +
    T build()
    Create the AsyncTable or RawAsyncTable instance.
  • http://git-wip-us.apache.org/repos/asf/hbase-site/blob/ebf9a8b8/devapidocs/org/apache/hadoop/hbase/client/AsyncTableRegionLocator.html ---------------------------------------------------------------------- diff --git a/devapidocs/org/apache/hadoop/hbase/client/AsyncTableRegionLocator.html b/devapidocs/org/apache/hadoop/hbase/client/AsyncTableRegionLocator.html index c114c7f..4a0ab73 100644 --- a/devapidocs/org/apache/hadoop/hbase/client/AsyncTableRegionLocator.html +++ b/devapidocs/org/apache/hadoop/hbase/client/AsyncTableRegionLocator.html @@ -106,11 +106,15 @@ var activeTableTab = "activeTableTab";

    @InterfaceAudience.Public
    -public interface AsyncTableRegionLocator
    +public interface AsyncTableRegionLocator
    The asynchronous version of RegionLocator.

    Usually the implementations will not throw any exception directly, you need to get the exception from the returned CompletableFuture.

    +
    +
    Since:
    +
    2.0.0
    +
  • @@ -169,7 +173,7 @@ public interface
  • getName

    -
    TableName getName()
    +
    TableName getName()
    Gets the fully qualified table name instance of the table whose region we want to locate.
  • @@ -179,7 +183,7 @@ public interface
  • getRegionLocation

    -
    default CompletableFuture<HRegionLocationgetRegionLocation(byte[] row)
    +
    default CompletableFuture<HRegionLocationgetRegionLocation(byte[] row)
    Finds the region on which the given row is being served. Does not reload the cache.

    Returns the location of the region to which the row belongs.

    @@ -195,7 +199,7 @@ public interface
  • getRegionLocation

    -
    CompletableFuture<HRegionLocationgetRegionLocation(byte[] row,
    +
    CompletableFuture<HRegionLocationgetRegionLocation(byte[] row,
                                                          boolean reload)
    Finds the region on which the given row is being served.