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 AC3AF200D1D for ; Fri, 8 Sep 2017 17:14:07 +0200 (CEST) Received: by cust-asf.ponee.io (Postfix) id AB4E1160CC7; Fri, 8 Sep 2017 15:14:07 +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 EDA1C161487 for ; Fri, 8 Sep 2017 17:14:05 +0200 (CEST) Received: (qmail 29959 invoked by uid 500); 8 Sep 2017 15:14:01 -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 25738 invoked by uid 99); 8 Sep 2017 15:13:57 -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, 08 Sep 2017 15:13:57 +0000 Received: by git1-us-west.apache.org (ASF Mail Server at git1-us-west.apache.org, from userid 33) id CB3FDF571F; Fri, 8 Sep 2017 15:13:56 +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, 08 Sep 2017 15:14:26 -0000 Message-Id: In-Reply-To: References: X-Mailer: ASF-Git Admin Mailer Subject: [31/51] [partial] hbase-site git commit: Published site at . archived-at: Fri, 08 Sep 2017 15:14:07 -0000 http://git-wip-us.apache.org/repos/asf/hbase-site/blob/985cca06/devapidocs/org/apache/hadoop/hbase/client/Query.html ---------------------------------------------------------------------- diff --git a/devapidocs/org/apache/hadoop/hbase/client/Query.html b/devapidocs/org/apache/hadoop/hbase/client/Query.html index a53fe3a..9578b2b 100644 --- a/devapidocs/org/apache/hadoop/hbase/client/Query.html +++ b/devapidocs/org/apache/hadoop/hbase/client/Query.html @@ -128,8 +128,9 @@ var activeTableTab = "activeTableTab";

@InterfaceAudience.Public
-public abstract class Query
+public abstract class Query
 extends OperationWithAttributes
+
Base class for HBase read operations; e.g. Scan and Get.
@@ -352,7 +353,7 @@ extends
  • ISOLATION_LEVEL

    -
    private static final String ISOLATION_LEVEL
    +
    private static final String ISOLATION_LEVEL
    See Also:
    Constant Field Values
    @@ -365,7 +366,7 @@ extends
  • filter

    -
    protected Filter filter
    +
    protected Filter filter
  • @@ -374,7 +375,7 @@ extends
  • targetReplicaId

    -
    protected int targetReplicaId
    +
    protected int targetReplicaId
  • @@ -383,7 +384,7 @@ extends
  • consistency

    -
    protected Consistency consistency
    +
    protected Consistency consistency
  • @@ -392,7 +393,7 @@ extends
  • colFamTimeRangeMap

    -
    protected Map<byte[],TimeRange> colFamTimeRangeMap
    +
    protected Map<byte[],TimeRange> colFamTimeRangeMap
  • @@ -401,7 +402,7 @@ extends
  • loadColumnFamiliesOnDemand

    -
    protected Boolean loadColumnFamiliesOnDemand
    +
    protected Boolean loadColumnFamiliesOnDemand
  • @@ -418,7 +419,7 @@ extends
  • Query

    -
    public Query()
    +
    public Query()
  • @@ -435,7 +436,7 @@ extends
  • getFilter

    -
    public Filter getFilter()
    +
    public Filter getFilter()
    Returns:
    Filter
    @@ -448,7 +449,7 @@ extends
  • setFilter

    -
    public Query setFilter(Filter filter)
    +
    public Query setFilter(Filter filter)
    Apply the specified server-side filter when performing the Query. Only Filter.filterKeyValue(org.apache.hadoop.hbase.Cell) is called AFTER all tests for ttl, column match, deletes and column family's max versions have been run.
    @@ -466,7 +467,7 @@ extends
  • setAuthorizations

    -
    public Query setAuthorizations(Authorizations authorizations)
    +
    public Query setAuthorizations(Authorizations authorizations)
    Sets the authorizations to be used by this Query
    Parameters:
    @@ -480,7 +481,7 @@ extends
  • getAuthorizations

    -
    public Authorizations getAuthorizations()
    +
    public Authorizations getAuthorizations()
                                      throws DeserializationException
    Returns:
    @@ -496,7 +497,7 @@ extends
  • getACL

    -
    public byte[] getACL()
    +
    public byte[] getACL()
    Returns:
    The serialized ACL for this operation, or null if none
    @@ -509,7 +510,7 @@ extends
  • setACL

    -
    public Query setACL(String user,
    +
    public Query setACL(String user,
                         Permission perms)
    Parameters:
    @@ -524,7 +525,7 @@ extends
  • setACL

    -
    public Query setACL(Map<String,Permission> perms)
    +
    public Query setACL(Map<String,Permission> perms)
    Parameters:
    perms - A map of permissions for a user or users
    @@ -537,7 +538,7 @@ extends
  • getConsistency

    -
    public Consistency getConsistency()
    +
    public Consistency getConsistency()
    Returns the consistency level for this operation
    Returns:
    @@ -551,7 +552,7 @@ extends
  • setConsistency

    -
    public Query setConsistency(Consistency consistency)
    +
    public Query setConsistency(Consistency consistency)
    Sets the consistency level for this operation
    Parameters:
    @@ -565,7 +566,7 @@ extends
  • setReplicaId

    -
    public Query setReplicaId(int Id)
    +
    public Query setReplicaId(int Id)
    Specify region replica id where Query will fetch data from. Use this together with setConsistency(Consistency) passing Consistency.TIMELINE to read data from a specific replicaId. @@ -582,7 +583,7 @@ extends
  • getReplicaId

    -
    public int getReplicaId()
    +
    public int getReplicaId()
    Returns region replica id where Query will fetch data from.
    Returns:
    @@ -596,7 +597,7 @@ extends
  • setIsolationLevel

    -
    public Query setIsolationLevel(IsolationLevel level)
    +
    public Query setIsolationLevel(IsolationLevel level)
    Set the isolation level for this query. If the isolation level is set to READ_UNCOMMITTED, then this query will return data from committed and @@ -617,7 +618,7 @@ extends
  • getIsolationLevel

    -
    public IsolationLevel getIsolationLevel()
    +
    public IsolationLevel getIsolationLevel()
    Returns:
    The isolation level of this query. @@ -632,7 +633,7 @@ extends
  • setLoadColumnFamiliesOnDemand

    -
    public Query setLoadColumnFamiliesOnDemand(boolean value)
    +
    public Query setLoadColumnFamiliesOnDemand(boolean value)
    Set the value indicating whether loading CFs on demand should be allowed (cluster default is false). On-demand CF loading doesn't load column families until necessary, e.g. if you filter on one column, the other column family data will be loaded only for the rows @@ -655,7 +656,7 @@ extends
  • getLoadColumnFamiliesOnDemandValue

    -
    public Boolean getLoadColumnFamiliesOnDemandValue()
    +
    public Boolean getLoadColumnFamiliesOnDemandValue()
    Get the raw loadColumnFamiliesOnDemand setting; if it's not set, can be null.
  • @@ -665,7 +666,7 @@ extends
  • doLoadColumnFamiliesOnDemand

    -
    public boolean doLoadColumnFamiliesOnDemand()
    +
    public boolean doLoadColumnFamiliesOnDemand()
    Get the logical value indicating whether on-demand CF loading should be allowed.
  • @@ -675,7 +676,7 @@ extends
  • setColumnFamilyTimeRange

    -
    public Query setColumnFamilyTimeRange(byte[] cf,
    +
    public Query setColumnFamilyTimeRange(byte[] cf,
                                           long minStamp,
                                           long maxStamp)
    Get versions of columns only within the specified timestamp range, @@ -699,7 +700,7 @@ extends
  • getColumnFamilyTimeRange

    -
    public Map<byte[],TimeRangegetColumnFamilyTimeRange()
    +
    public Map<byte[],TimeRangegetColumnFamilyTimeRange()
    Returns:
    A map of column families to time ranges
    http://git-wip-us.apache.org/repos/asf/hbase-site/blob/985cca06/devapidocs/org/apache/hadoop/hbase/client/RawAsyncTable.html ---------------------------------------------------------------------- diff --git a/devapidocs/org/apache/hadoop/hbase/client/RawAsyncTable.html b/devapidocs/org/apache/hadoop/hbase/client/RawAsyncTable.html index 82aa76a..e234d10 100644 --- a/devapidocs/org/apache/hadoop/hbase/client/RawAsyncTable.html +++ b/devapidocs/org/apache/hadoop/hbase/client/RawAsyncTable.html @@ -222,7 +222,7 @@ extends AsyncTableBase -append, batch, batchAll, checkAndDelete, checkAndDelete, checkAndMutate, checkAndMutate, checkAndPut, checkAndPut, delete, delete, deleteAll, exists, exists, existsAll, get, get, getAll, getConfiguration, getName, getOperationTimeout, getReadRpcTimeout, getRpcTimeout, getScanTimeout, getWriteRpcTimeout, increment, incrementColumnValue, incrementColumnValue, mutateRow, put, put, putAll, scanAll
  • +append, batch, batchAll, checkAndDelete, checkAndDelete, checkAndMutate, checkAndMutate, checkAndPut, checkAndPut, delete, delete, deleteAll, exists, exists, existsAll, get, get, getAll, getConfiguration, getName, getOperationTimeout, getReadRpcTimeout, getRpcTimeout, getScanTimeout, getWriteRpcTimeout, increment, incrementColumnValue, incrementColumnValue, mutateRow, put, put, putAll, scanAll
  • http://git-wip-us.apache.org/repos/asf/hbase-site/blob/985cca06/devapidocs/org/apache/hadoop/hbase/client/RawAsyncTableImpl.html ---------------------------------------------------------------------- diff --git a/devapidocs/org/apache/hadoop/hbase/client/RawAsyncTableImpl.html b/devapidocs/org/apache/hadoop/hbase/client/RawAsyncTableImpl.html index 1ac15ea..b62e07e 100644 --- a/devapidocs/org/apache/hadoop/hbase/client/RawAsyncTableImpl.html +++ b/devapidocs/org/apache/hadoop/hbase/client/RawAsyncTableImpl.html @@ -280,10 +280,10 @@ implements CompletableFuture<Boolean> -checkAndDelete(byte[] row, +checkAndDelete(byte[] row, byte[] family, byte[] qualifier, - CompareFilter.CompareOp compareOp, + CompareOperator op, byte[] value, Delete delete)
    Atomically checks if a row/family/qualifier value matches the expected value.
    @@ -291,10 +291,10 @@ implements CompletableFuture<Boolean> -checkAndMutate(byte[] row, +checkAndMutate(byte[] row, byte[] family, byte[] qualifier, - CompareFilter.CompareOp compareOp, + CompareOperator op, byte[] value, RowMutations mutation)
    Atomically checks if a row/family/qualifier value matches the expected value.
    @@ -302,10 +302,10 @@ implements CompletableFuture<Boolean> -checkAndPut(byte[] row, +checkAndPut(byte[] row, byte[] family, byte[] qualifier, - CompareFilter.CompareOp compareOp, + CompareOperator op, byte[] value, Put put)
    Atomically checks if a row/family/qualifier value matches the expected value.
    @@ -930,7 +930,7 @@ implements +
  • -
    Description copied from interface: AsyncTableBase
    +
    Description copied from interface: AsyncTableBase
    Atomically checks if a row/family/qualifier value matches the expected value. If it does, it adds the put. If the passed value is null, the check is for the lack of column (ie: non-existence)
    Specified by:
    -
    checkAndPut in interface AsyncTableBase
    +
    checkAndPut in interface AsyncTableBase
    Parameters:
    row - to check
    family - column family to check
    qualifier - column qualifier to check
    -
    compareOp - comparison operator to use
    +
    op - comparison operator to use
    value - the expected value
    put - data to put if check succeeds
    Returns:
    @@ -962,7 +962,7 @@ implements +
  • -
    Description copied from interface: AsyncTableBase
    +
    Description copied from interface: AsyncTableBase
    Atomically checks if a row/family/qualifier value matches the expected value. If it does, it adds the delete. If the passed value is null, the check is for the lack of column (ie: non-existence)
    Specified by:
    -
    checkAndDelete in interface AsyncTableBase
    +
    checkAndDelete in interface AsyncTableBase
    Parameters:
    row - to check
    family - column family to check
    qualifier - column qualifier to check
    -
    compareOp - comparison operator to use
    +
    op - comparison operator to use
    value - the expected value
    delete - data to delete if check succeeds
    Returns:
    @@ -1028,7 +1028,7 @@ implements +
      @@ -1037,21 +1037,21 @@ implements CompletableFuture<BooleancheckAndMutate(byte[] row, byte[] family, byte[] qualifier, - CompareFilter.CompareOp compareOp, + CompareOperator op, byte[] value, RowMutations mutation) -
      Description copied from interface: AsyncTableBase
      +
      Description copied from interface: AsyncTableBase
      Atomically checks if a row/family/qualifier value matches the expected value. If it does, it performs the row mutations. If the passed value is null, the check is for the lack of column (ie: non-existence)
      Specified by:
      -
      checkAndMutate in interface AsyncTableBase
      +
      checkAndMutate in interface AsyncTableBase
      Parameters:
      row - to check
      family - column family to check
      qualifier - column qualifier to check
      -
      compareOp - the comparison operator
      +
      op - the comparison operator
      value - the expected value
      mutation - mutations to perform if check succeeds
      Returns: