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 48801200BAA for ; Fri, 16 Sep 2016 03:57:07 +0200 (CEST) Received: by cust-asf.ponee.io (Postfix) id 471EB160AE2; Fri, 16 Sep 2016 01:57: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 345D1160AD7 for ; Fri, 16 Sep 2016 03:57:04 +0200 (CEST) Received: (qmail 40674 invoked by uid 500); 16 Sep 2016 01:57: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 40121 invoked by uid 99); 16 Sep 2016 01:57:01 -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, 16 Sep 2016 01:57:01 +0000 Received: by git1-us-west.apache.org (ASF Mail Server at git1-us-west.apache.org, from userid 33) id 50E63EEE3A; Fri, 16 Sep 2016 01:57:01 +0000 (UTC) Content-Type: text/plain; charset="us-ascii" MIME-Version: 1.0 Content-Transfer-Encoding: 7bit From: dimaspivak@apache.org To: commits@hbase.apache.org Date: Fri, 16 Sep 2016 01:57:09 -0000 Message-Id: In-Reply-To: <1adfd2ce4405497b80d48473de1a7041@git.apache.org> References: <1adfd2ce4405497b80d48473de1a7041@git.apache.org> X-Mailer: ASF-Git Admin Mailer Subject: [09/52] [partial] hbase-site git commit: Published site at 56be3ac7c8d203710f844cd799f2fa3496f0515a. archived-at: Fri, 16 Sep 2016 01:57:07 -0000 http://git-wip-us.apache.org/repos/asf/hbase-site/blob/f55baeba/devapidocs/org/apache/hadoop/hbase/client/HTable.html ---------------------------------------------------------------------- diff --git a/devapidocs/org/apache/hadoop/hbase/client/HTable.html b/devapidocs/org/apache/hadoop/hbase/client/HTable.html index b24068e..48b0a8e 100644 --- a/devapidocs/org/apache/hadoop/hbase/client/HTable.html +++ b/devapidocs/org/apache/hadoop/hbase/client/HTable.html @@ -115,7 +115,7 @@ var activeTableTab = "activeTableTab";
@InterfaceAudience.Private
  @InterfaceStability.Stable
-public class HTable
+public class HTable
 extends Object
 implements Table
An implementation of Table. Used to communicate with a single HBase table. @@ -752,7 +752,7 @@ implements
  • LOG

    -
    private static final org.apache.commons.logging.Log LOG
    +
    private static final org.apache.commons.logging.Log LOG
  • @@ -761,7 +761,7 @@ implements
  • connection

    -
    protected ClusterConnection connection
    +
    protected ClusterConnection connection
  • @@ -770,7 +770,7 @@ implements
  • tableName

    -
    private final TableName tableName
    +
    private final TableName tableName
  • @@ -779,7 +779,7 @@ implements
  • configuration

    -
    private volatile org.apache.hadoop.conf.Configuration configuration
    +
    private volatile org.apache.hadoop.conf.Configuration configuration
  • @@ -788,7 +788,7 @@ implements
  • connConfiguration

    -
    private ConnectionConfiguration connConfiguration
    +
    private ConnectionConfiguration connConfiguration
  • @@ -797,7 +797,7 @@ implements
  • mutator

    -
    protected BufferedMutatorImpl mutator
    +
    protected BufferedMutatorImpl mutator
  • @@ -806,7 +806,7 @@ implements
  • closed

    -
    private boolean closed
    +
    private boolean closed
  • @@ -815,7 +815,7 @@ implements
  • scannerCaching

    -
    protected int scannerCaching
    +
    protected int scannerCaching
  • @@ -824,7 +824,7 @@ implements
  • scannerMaxResultSize

    -
    protected long scannerMaxResultSize
    +
    protected long scannerMaxResultSize
  • @@ -833,7 +833,7 @@ implements
  • pool

    -
    private ExecutorService pool
    +
    private ExecutorService pool
  • @@ -842,7 +842,7 @@ implements
  • operationTimeout

    -
    private int operationTimeout
    +
    private int operationTimeout
  • @@ -851,7 +851,7 @@ implements
  • readRpcTimeout

    -
    private int readRpcTimeout
    +
    private int readRpcTimeout
  • @@ -860,7 +860,7 @@ implements
  • writeRpcTimeout

    -
    private int writeRpcTimeout
    +
    private int writeRpcTimeout
  • @@ -869,7 +869,7 @@ implements
  • cleanupPoolOnClose

    -
    private final boolean cleanupPoolOnClose
    +
    private final boolean cleanupPoolOnClose
  • @@ -878,7 +878,7 @@ implements
  • cleanupConnectionOnClose

    -
    private final boolean cleanupConnectionOnClose
    +
    private final boolean cleanupConnectionOnClose
  • @@ -887,7 +887,7 @@ implements
  • defaultConsistency

    -
    private Consistency defaultConsistency
    +
    private Consistency defaultConsistency
  • @@ -896,7 +896,7 @@ implements
  • locator

    -
    private HRegionLocator locator
    +
    private HRegionLocator locator
  • @@ -905,7 +905,7 @@ implements
  • multiAp

    -
    protected AsyncProcess multiAp
    +
    protected AsyncProcess multiAp
    The Async process for batch
  • @@ -915,7 +915,7 @@ implements
  • rpcCallerFactory

    -
    private RpcRetryingCallerFactory rpcCallerFactory
    +
    private RpcRetryingCallerFactory rpcCallerFactory
  • @@ -924,7 +924,7 @@ implements
  • rpcControllerFactory

    -
    private RpcControllerFactory rpcControllerFactory
    +
    private RpcControllerFactory rpcControllerFactory
  • @@ -942,7 +942,7 @@ implements

    HTable

    @InterfaceAudience.Private
    -protected HTable(TableName tableName,
    +protected HTable(TableName tableName,
                                                 ClusterConnection connection,
                                                 ConnectionConfiguration tableConfig,
                                                 RpcRetryingCallerFactory rpcCallerFactory,
    @@ -968,7 +968,7 @@ protected 
     
  • HTable

    -
    protected HTable(ClusterConnection conn,
    +
    protected HTable(ClusterConnection conn,
                      BufferedMutatorParams params)
               throws IOException
    For internal testing. Uses Connection provided in params.
    @@ -993,7 +993,7 @@ protected 

    getDefaultExecutor

    @InterfaceAudience.Private
    -public static ThreadPoolExecutor getDefaultExecutor(org.apache.hadoop.conf.Configuration conf)
    +public static ThreadPoolExecutor getDefaultExecutor(org.apache.hadoop.conf.Configuration conf)
  • @@ -1002,7 +1002,7 @@ public static 
  • getMaxKeyValueSize

    -
    public static int getMaxKeyValueSize(org.apache.hadoop.conf.Configuration conf)
    +
    public static int getMaxKeyValueSize(org.apache.hadoop.conf.Configuration conf)
    Returns:
    maxKeyValueSize from configuration.
    @@ -1015,7 +1015,7 @@ public static 
  • finishSetup

    -
    private void finishSetup()
    +
    private void finishSetup()
                       throws IOException
    setup this HTable's parameter based on the passed configuration
    @@ -1030,7 +1030,7 @@ public static 
  • getConfiguration

    -
    public org.apache.hadoop.conf.Configuration getConfiguration()
    +
    public 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 @@ -1047,7 +1047,7 @@ public static 

  • getName

    -
    public TableName getName()
    +
    public TableName getName()
    Description copied from interface: Table
    Gets the fully qualified table name instance of this table.
    @@ -1062,7 +1062,7 @@ public static 
  • getConnection

    -
    protected Connection getConnection()
    +
    protected Connection getConnection()
    INTERNAL Used by unit tests and tools to do low-level manipulations.
    @@ -1077,7 +1077,7 @@ public static 
  • getTableDescriptor

    -
    public HTableDescriptor getTableDescriptor()
    +
    public HTableDescriptor getTableDescriptor()
                                         throws IOException
    Gets the table descriptor for this table.
    @@ -1094,7 +1094,7 @@ public static 
  • getKeysAndRegionsInRange

    -
    private Pair<List<byte[]>,List<HRegionLocation>> getKeysAndRegionsInRange(byte[] startKey,
    +
    private Pair<List<byte[]>,List<HRegionLocation>> getKeysAndRegionsInRange(byte[] startKey,
                                                                               byte[] endKey,
                                                                               boolean includeEndKey)
                                                                        throws IOException
    @@ -1120,7 +1120,7 @@ public static 
  • getKeysAndRegionsInRange

    -
    private Pair<List<byte[]>,List<HRegionLocation>> getKeysAndRegionsInRange(byte[] startKey,
    +
    private Pair<List<byte[]>,List<HRegionLocation>> getKeysAndRegionsInRange(byte[] startKey,
                                                                               byte[] endKey,
                                                                               boolean includeEndKey,
                                                                               boolean reload)
    @@ -1148,7 +1148,7 @@ public static 
     
  • getScanner

    -
    public ResultScanner getScanner(Scan scan)
    +
    public ResultScanner getScanner(Scan scan)
                              throws IOException
    The underlying HTable must not be closed. Table.getScanner(Scan) has other usage details.
    @@ -1170,7 +1170,7 @@ public static 
  • getScanner

    -
    public ResultScanner getScanner(byte[] family)
    +
    public ResultScanner getScanner(byte[] family)
                              throws IOException
    The underlying HTable must not be closed. Table.getScanner(byte[]) has other usage details.
    @@ -1192,7 +1192,7 @@ public static 
  • getScanner

    -
    public ResultScanner getScanner(byte[] family,
    +
    public ResultScanner getScanner(byte[] family,
                                     byte[] qualifier)
                              throws IOException
    The underlying HTable must not be closed. @@ -1216,7 +1216,7 @@ public static 
  • get

    -
    public Result get(Get get)
    +
    public Result get(Get get)
                throws IOException
    Extracts certain cells from a given row.
    @@ -1239,7 +1239,7 @@ public static 
  • get

    -
    private Result get(Get get,
    +
    private Result get(Get get,
                        boolean checkExistenceOnly)
                 throws IOException
    @@ -1254,7 +1254,7 @@ public static 
  • get

    -
    public Result[] get(List<Get> gets)
    +
    public Result[] get(List<Get> gets)
                  throws IOException
    Extracts certain cells from the given rows, in batch.
    @@ -1278,7 +1278,7 @@ public static 
  • batch

    -
    public void batch(List<? extends Row> actions,
    +
    public void batch(List<? extends Row> actions,
                       Object[] results)
                throws InterruptedException,
                       IOException
    @@ -1306,7 +1306,7 @@ public static 
  • batch

    -
    public void batch(List<? extends Row> actions,
    +
    public void batch(List<? extends Row> actions,
                       Object[] results,
                       int timeout)
                throws InterruptedException,
    @@ -1324,7 +1324,7 @@ public static 
     
  • batchCallback

    -
    public <R> void batchCallback(List<? extends Row> actions,
    +
    public <R> void batchCallback(List<? extends Row> actions,
                                   Object[] results,
                                   Batch.Callback<R> callback)
                            throws IOException,
    @@ -1345,7 +1345,7 @@ public static 
     
  • doBatchWithCallback

    -
    public static <R> void doBatchWithCallback(List<? extends Row> actions,
    +
    public static <R> void doBatchWithCallback(List<? extends Row> actions,
                                                Object[] results,
                                                Batch.Callback<R> callback,
                                                ClusterConnection connection,
    @@ -1366,7 +1366,7 @@ public static 
     
  • delete

    -
    public void delete(Delete delete)
    +
    public void delete(Delete delete)
                 throws IOException
    Deletes the specified cells/row.
    @@ -1385,7 +1385,7 @@ public static 
  • delete

    -
    public void delete(List<Delete> deletes)
    +
    public void delete(List<Delete> deletes)
                 throws IOException
    Deletes the specified cells/rows in bulk.
    @@ -1409,7 +1409,7 @@ public static 
  • put

    -
    public void put(Put put)
    +
    public void put(Put put)
              throws IOException
    Puts some data in the table.
    @@ -1428,7 +1428,7 @@ public static 
  • put

    -
    public void put(List<Put> puts)
    +
    public void put(List<Put> puts)
              throws IOException
    Puts some data in the table, in batch.

    @@ -1454,7 +1454,7 @@ public static 

  • mutateRow

    -
    public void mutateRow(RowMutations rm)
    +
    public void mutateRow(RowMutations rm)
                    throws IOException
    Performs multiple mutations atomically on a single row. Currently Put and Delete are supported.
    @@ -1474,7 +1474,7 @@ public static 
  • checkHasFamilies

    -
    private static void checkHasFamilies(Mutation mutation)
    +
    private static void checkHasFamilies(Mutation mutation)
                                   throws IOException
    Throws:
    @@ -1488,7 +1488,7 @@ public static 
  • append

    -
    public Result append(Append append)
    +
    public Result append(Append append)
                   throws IOException
    Appends values to one or more columns within a single row.

    @@ -1515,7 +1515,7 @@ public static 

  • increment

    -
    public Result increment(Increment increment)
    +
    public Result increment(Increment increment)
                      throws IOException
    Increments one or more columns within a single row.

    @@ -1542,7 +1542,7 @@ public static 

  • incrementColumnValue

    -
    public long incrementColumnValue(byte[] row,
    +
    public long incrementColumnValue(byte[] row,
                                      byte[] family,
                                      byte[] qualifier,
                                      long amount)
    @@ -1572,7 +1572,7 @@ public static 
     
  • incrementColumnValue

    -
    public long incrementColumnValue(byte[] row,
    +
    public long incrementColumnValue(byte[] row,
                                      byte[] family,
                                      byte[] qualifier,
                                      long amount,
    @@ -1608,7 +1608,7 @@ public static 
     
  • checkAndPut

    -
    public boolean checkAndPut(byte[] row,
    +
    public boolean checkAndPut(byte[] row,
                                byte[] family,
                                byte[] qualifier,
                                byte[] value,
    @@ -1639,7 +1639,7 @@ public static 
     
  • checkAndPut

    -
    public boolean checkAndPut(byte[] row,
    +
    public boolean checkAndPut(byte[] row,
                                byte[] family,
                                byte[] qualifier,
                                CompareFilter.CompareOp compareOp,
    @@ -1672,7 +1672,7 @@ public static 
     
  • checkAndDelete

    -
    public boolean checkAndDelete(byte[] row,
    +
    public boolean checkAndDelete(byte[] row,
                                   byte[] family,
                                   byte[] qualifier,
                                   byte[] value,
    @@ -1703,7 +1703,7 @@ public static 
     
  • checkAndDelete

    -
    public boolean checkAndDelete(byte[] row,
    +
    public boolean checkAndDelete(byte[] row,
                                   byte[] family,
                                   byte[] qualifier,
                                   CompareFilter.CompareOp compareOp,
    @@ -1736,7 +1736,7 @@ public static 
     
  • checkAndMutate

    -
    public boolean checkAndMutate(byte[] row,
    +
    public boolean checkAndMutate(byte[] row,
                                   byte[] family,
                                   byte[] qualifier,
                                   CompareFilter.CompareOp compareOp,
    @@ -1769,7 +1769,7 @@ public static 
     
  • exists

    -
    public boolean exists(Get get)
    +
    public boolean exists(Get get)
                    throws IOException
    Test for the existence of columns in the table, as specified by the Get.

    @@ -1797,7 +1797,7 @@ public static 

  • existsAll

    -
    public boolean[] existsAll(List<Get> gets)
    +
    public boolean[] existsAll(List<Get> gets)
                         throws IOException
    Test for the existence of columns in the table, as specified by the Gets.

    @@ -1826,7 +1826,7 @@ public static 

  • flushCommits

    -
    void flushCommits()
    +
    void flushCommits()
                throws IOException
    Throws:
    @@ -1840,7 +1840,7 @@ public static 
  • processBatchCallback

    -
    public <R> void processBatchCallback(List<? extends Row> list,
    +
    public <R> void processBatchCallback(List<? extends Row> list,
                                          Object[] results,
                                          Batch.Callback<R> callback)
                                   throws IOException,
    @@ -1866,7 +1866,7 @@ public static 
     
  • close

    -
    public void close()
    +
    public void close()
                throws IOException
    Description copied from interface: Table
    Releases any resources held or pending changes in internal buffers.
    @@ -1888,7 +1888,7 @@ public static 
  • validatePut

    -
    public void validatePut(Put put)
    +
    public void validatePut(Put put)
                      throws IllegalArgumentException
    Throws:
    @@ -1902,7 +1902,7 @@ public static 
  • validatePut

    -
    public static void validatePut(Put put,
    +
    public static void validatePut(Put put,
                                    int maxKeyValueSize)
                             throws IllegalArgumentException
    @@ -1917,7 +1917,7 @@ public static 
  • getWriteBufferSize

    -
    public long getWriteBufferSize()
    +
    public long getWriteBufferSize()
    Returns the maximum size in bytes of the write buffer for this HTable.

    The default value comes from the configuration parameter @@ -1936,7 +1936,7 @@ public static 

  • setWriteBufferSize

    -
    public void setWriteBufferSize(long writeBufferSize)
    +
    public void setWriteBufferSize(long writeBufferSize)
                             throws IOException
    Sets the size of the buffer in bytes.

    @@ -1958,7 +1958,7 @@ public static 

  • getPool

    -
    ExecutorService getPool()
    +
    ExecutorService getPool()
    The pool is used for mutli requests for this HTable
    Returns:
    @@ -1972,7 +1972,7 @@ public static 
  • clearRegionCache

    -
    public void clearRegionCache()
    +
    public void clearRegionCache()
    Explicitly clears the region cache to fetch the latest value from META. This is a power user function: avoid unless you know the ramifications.
  • @@ -1983,7 +1983,7 @@ public static 
  • coprocessorService

    -
    public CoprocessorRpcChannel coprocessorService(byte[] row)
    +
    public CoprocessorRpcChannel coprocessorService(byte[] row)
    Creates and returns a RpcChannel instance connected to the table region containing the specified row. The row given does not actually have to exist. Whichever region would contain the row based on start and end keys will @@ -2022,7 +2022,7 @@ public static 
  • coprocessorService

    -
    public <T extends com.google.protobuf.Service,R> Map<byte[],R> coprocessorService(Class<T> service,
    +
    public <T extends com.google.protobuf.Service,R> Map<byte[],R> coprocessorService(Class<T> service,
                                                                                       byte[] startKey,
                                                                                       byte[] endKey,
                                                                                       Batch.Call<T,R> callable)
    @@ -2060,7 +2060,7 @@ public static 
     
  • coprocessorService

    -
    public <T extends com.google.protobuf.Service,R> void coprocessorService(Class<T> service,
    +
    public <T extends com.google.protobuf.Service,R> void coprocessorService(Class<T> service,
                                                                              byte[] startKey,
                                                                              byte[] endKey,
                                                                              Batch.Call<T,R> callable,
    @@ -2100,7 +2100,7 @@ public static 
     
  • getStartKeysInRange

    -
    private List<byte[]> getStartKeysInRange(byte[] start,
    +
    private List<byte[]> getStartKeysInRange(byte[] start,
                                              byte[] end)
                                       throws IOException
    @@ -2115,7 +2115,7 @@ public static 
  • setOperationTimeout

    -
    public void setOperationTimeout(int operationTimeout)
    +
    public void setOperationTimeout(int operationTimeout)
    Description copied from interface: Table
    Set timeout (millisecond) of each operation in this Table instance, will override the value of hbase.client.operation.timeout in configuration. @@ -2138,7 +2138,7 @@ public static 
  • getOperationTimeout

    -
    public int getOperationTimeout()
    +
    public int getOperationTimeout()
    Description copied from interface: Table
    Get timeout (millisecond) of each operation for in Table instance.
    @@ -2154,7 +2154,7 @@ public static 

    getRpcTimeout

    @Deprecated
    -public int getRpcTimeout()
    +public int getRpcTimeout()
  • Deprecated. 
    Description copied from interface: Table
    Get timeout (millisecond) of each rpc request in this Table instance.
    @@ -2171,7 +2171,7 @@ public int 

    setRpcTimeout

    @Deprecated
    -public void setRpcTimeout(int rpcTimeout)
    +public void setRpcTimeout(int rpcTimeout)
  • Deprecated. 
    Description copied from interface: Table
    Set timeout (millisecond) of each rpc request in operations of this Table instance, will @@ -2194,7 +2194,7 @@ public void 
  • getWriteRpcTimeout

    -
    public int getWriteRpcTimeout()
    +
    public int getWriteRpcTimeout()
    Description copied from interface: Table
    Get timeout (millisecond) of each rpc write request in this Table instance.
    @@ -2209,7 +2209,7 @@ public void 
  • setWriteRpcTimeout

    -
    public void setWriteRpcTimeout(int writeRpcTimeout)
    +
    public void setWriteRpcTimeout(int writeRpcTimeout)
    Description copied from interface: Table
    Set timeout (millisecond) of each rpc write request in operations of this Table instance, will override the value of hbase.rpc.write.timeout in configuration. @@ -2227,7 +2227,7 @@ public void 
  • getReadRpcTimeout

    -
    public int getReadRpcTimeout()
    +
    public int getReadRpcTimeout()
    Description copied from interface: Table
    Get timeout (millisecond) of each rpc read request in this Table instance.
    @@ -2242,7 +2242,7 @@ public void 
  • setReadRpcTimeout

    -
    public void setReadRpcTimeout(int readRpcTimeout)
    +
    public void setReadRpcTimeout(int readRpcTimeout)
    Description copied from interface: Table
    Set timeout (millisecond) of each rpc read request in operations of this Table instance, will override the value of hbase.rpc.read.timeout in configuration. @@ -2260,7 +2260,7 @@ public void 
  • toString

    -
    public String toString()
    +
    public String toString()
    Overrides:
    toString in class Object
    @@ -2275,7 +2275,7 @@ public void 
  • batchCoprocessorService

    -
    public <R extends com.google.protobuf.Message> Map<byte[],R> batchCoprocessorService(com.google.protobuf.Descriptors.MethodDescriptor methodDescriptor,
    +
    public <R extends com.google.protobuf.Message> Map<byte[],R> batchCoprocessorService(com.google.protobuf.Descriptors.MethodDescriptor methodDescriptor,
                                                                                          com.google.protobuf.Message request,
                                                                                          byte[] startKey,
                                                                                          byte[] endKey,
    @@ -2316,7 +2316,7 @@ public void 
     
  • batchCoprocessorService

    -
    public <R extends com.google.protobuf.Message> void batchCoprocessorService(com.google.protobuf.Descriptors.MethodDescriptor methodDescriptor,
    +
    public <R extends com.google.protobuf.Message> void batchCoprocessorService(com.google.protobuf.Descriptors.MethodDescriptor methodDescriptor,
                                                                                 com.google.protobuf.Message request,
                                                                                 byte[] startKey,
                                                                                 byte[] endKey,
    @@ -2360,7 +2360,7 @@ public void 
     
  • getRegionLocator

    -
    public RegionLocator getRegionLocator()
    +
    public RegionLocator getRegionLocator()
  • @@ -2369,7 +2369,7 @@ public void 
  • getBufferedMutator

    -
    BufferedMutator getBufferedMutator()
    +
    BufferedMutator getBufferedMutator()
                                 throws IOException
    Throws:
    http://git-wip-us.apache.org/repos/asf/hbase-site/blob/f55baeba/devapidocs/org/apache/hadoop/hbase/client/MultiResponse.RegionResult.html ---------------------------------------------------------------------- diff --git a/devapidocs/org/apache/hadoop/hbase/client/MultiResponse.RegionResult.html b/devapidocs/org/apache/hadoop/hbase/client/MultiResponse.RegionResult.html index 9cd6776..1e08d95 100644 --- a/devapidocs/org/apache/hadoop/hbase/client/MultiResponse.RegionResult.html +++ b/devapidocs/org/apache/hadoop/hbase/client/MultiResponse.RegionResult.html @@ -113,7 +113,7 @@ var activeTableTab = "activeTableTab";


    -
    static class MultiResponse.RegionResult
    +
    static class MultiResponse.RegionResult
     extends Object
  • @@ -218,7 +218,7 @@ extends
  • result

    -
    Map<Integer,Object> result
    +
    Map<Integer,Object> result
  • @@ -227,7 +227,7 @@ extends
  • stat

    -
    org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionLoadStats stat
    +
    org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionLoadStats stat
  • @@ -244,7 +244,7 @@ extends
  • RegionResult

    -
    RegionResult()
    +
    RegionResult()
  • @@ -261,7 +261,7 @@ extends
  • addResult

    -
    public void addResult(int index,
    +
    public void addResult(int index,
                           Object result)
  • @@ -271,7 +271,7 @@ extends
  • setStat

    -
    public void setStat(org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionLoadStats stat)
    +
    public void setStat(org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionLoadStats stat)
  • @@ -280,7 +280,7 @@ extends
  • size

    -
    public int size()
    +
    public int size()
  • @@ -289,7 +289,7 @@ extends
  • getStat

    -
    public org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionLoadStats getStat()
    +
    public org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionLoadStats getStat()