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 DF533200BA1 for ; Mon, 17 Oct 2016 23:27:25 +0200 (CEST) Received: by cust-asf.ponee.io (Postfix) id DDEC0160AEC; Mon, 17 Oct 2016 21:27:25 +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 DCE0B160AFE for ; Mon, 17 Oct 2016 23:27:23 +0200 (CEST) Received: (qmail 83400 invoked by uid 500); 17 Oct 2016 21:27:20 -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 82798 invoked by uid 99); 17 Oct 2016 21:27:19 -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; Mon, 17 Oct 2016 21:27:19 +0000 Received: by git1-us-west.apache.org (ASF Mail Server at git1-us-west.apache.org, from userid 33) id D2B0BE0579; Mon, 17 Oct 2016 21:27:19 +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: Mon, 17 Oct 2016 21:27:39 -0000 Message-Id: In-Reply-To: <5b0beac2212646a7b8b9107a0a792004@git.apache.org> References: <5b0beac2212646a7b8b9107a0a792004@git.apache.org> X-Mailer: ASF-Git Admin Mailer Subject: [21/52] [partial] hbase-site git commit: Published site at 278625312047a2100f4dbb2d2eaa4e2219d00e14. archived-at: Mon, 17 Oct 2016 21:27:26 -0000 http://git-wip-us.apache.org/repos/asf/hbase-site/blob/f07ee53f/devapidocs/org/apache/hadoop/hbase/class-use/HBaseIOException.html ---------------------------------------------------------------------- diff --git a/devapidocs/org/apache/hadoop/hbase/class-use/HBaseIOException.html b/devapidocs/org/apache/hadoop/hbase/class-use/HBaseIOException.html index 37c4991..35afe20 100644 --- a/devapidocs/org/apache/hadoop/hbase/class-use/HBaseIOException.html +++ b/devapidocs/org/apache/hadoop/hbase/class-use/HBaseIOException.html @@ -138,38 +138,42 @@   -org.apache.hadoop.hbase.procedure2.store.wal +org.apache.hadoop.hbase.procedure2   -org.apache.hadoop.hbase.quotas +org.apache.hadoop.hbase.procedure2.store.wal   -org.apache.hadoop.hbase.regionserver +org.apache.hadoop.hbase.quotas   -org.apache.hadoop.hbase.regionserver.wal +org.apache.hadoop.hbase.regionserver   -org.apache.hadoop.hbase.rsgroup +org.apache.hadoop.hbase.regionserver.wal   -org.apache.hadoop.hbase.security +org.apache.hadoop.hbase.rsgroup   -org.apache.hadoop.hbase.security.visibility +org.apache.hadoop.hbase.security   -org.apache.hadoop.hbase.snapshot +org.apache.hadoop.hbase.security.visibility   +org.apache.hadoop.hbase.snapshot +  + + org.apache.hadoop.hbase.util   @@ -699,6 +703,24 @@ +
  • + + +

    Uses of HBaseIOException in org.apache.hadoop.hbase.procedure2

    + + + + + + + + + + + + +
    Subclasses of HBaseIOException in org.apache.hadoop.hbase.procedure2 
    Modifier and TypeClass and Description
    class BadProcedureException 
    +
  • http://git-wip-us.apache.org/repos/asf/hbase-site/blob/f07ee53f/devapidocs/org/apache/hadoop/hbase/class-use/HColumnDescriptor.html ---------------------------------------------------------------------- diff --git a/devapidocs/org/apache/hadoop/hbase/class-use/HColumnDescriptor.html b/devapidocs/org/apache/hadoop/hbase/class-use/HColumnDescriptor.html index dc52d45..44e2d29 100644 --- a/devapidocs/org/apache/hadoop/hbase/class-use/HColumnDescriptor.html +++ b/devapidocs/org/apache/hadoop/hbase/class-use/HColumnDescriptor.html @@ -129,47 +129,43 @@ Input/OutputFormats, a table indexing MapReduce job, and utility methods.   -org.apache.hadoop.hbase.mob.mapreduce -  - - org.apache.hadoop.hbase.regionserver   - + org.apache.hadoop.hbase.replication
    Multi Cluster Replication
    - + org.apache.hadoop.hbase.rsgroup   - + org.apache.hadoop.hbase.security   - + org.apache.hadoop.hbase.security.access   - + org.apache.hadoop.hbase.security.visibility   - + org.apache.hadoop.hbase.snapshot   - + org.apache.hadoop.hbase.thrift
    Provides an HBase Thrift service.
    - + org.apache.hadoop.hbase.tool   @@ -1445,68 +1441,6 @@ service.
  • -
  • - - -

    Uses of HColumnDescriptor in org.apache.hadoop.hbase.mob.mapreduce

    - - - - - - - - - - - - - - - - -
    Fields in org.apache.hadoop.hbase.mob.mapreduce declared as HColumnDescriptor 
    Modifier and TypeField and Description
    private HColumnDescriptorSweepReducer.family 
    private HColumnDescriptorMemStoreWrapper.hcd 
    - - - - - - - - - - - - - - - - -
    Methods in org.apache.hadoop.hbase.mob.mapreduce with parameters of type HColumnDescriptor 
    Modifier and TypeMethod and Description
    private voidSweepJob.removeUnusedFiles(org.apache.hadoop.mapreduce.Job job, - TableName tn, - HColumnDescriptor hcd) -
    Archives unused mob files.
    -
    intSweepJob.sweep(TableName tn, - HColumnDescriptor family) -
    Runs MapReduce to do the sweeping on the mob files.
    -
    - - - - - - - - - - -
    Constructors in org.apache.hadoop.hbase.mob.mapreduce with parameters of type HColumnDescriptor 
    Constructor and Description
    MemStoreWrapper(org.apache.hadoop.mapreduce.Reducer.Context context, - org.apache.hadoop.fs.FileSystem fs, - BufferedMutator table, - HColumnDescriptor hcd, - MemStore memstore, - CacheConfig cacheConfig) 
    -
  • http://git-wip-us.apache.org/repos/asf/hbase-site/blob/f07ee53f/devapidocs/org/apache/hadoop/hbase/class-use/HRegionLocation.html ---------------------------------------------------------------------- diff --git a/devapidocs/org/apache/hadoop/hbase/class-use/HRegionLocation.html b/devapidocs/org/apache/hadoop/hbase/class-use/HRegionLocation.html index 9c5db45..7504456 100644 --- a/devapidocs/org/apache/hadoop/hbase/class-use/HRegionLocation.html +++ b/devapidocs/org/apache/hadoop/hbase/class-use/HRegionLocation.html @@ -437,6 +437,30 @@ service. +default CompletableFuture<HRegionLocation> +AsyncTableRegionLocator.getRegionLocation(byte[] row) +
    Finds the region on which the given row is being served.
    + + + +CompletableFuture<HRegionLocation> +AsyncTableRegionLocator.getRegionLocation(byte[] row, + boolean reload) +
    Finds the region on which the given row is being served.
    + + + +CompletableFuture<HRegionLocation> +AsyncTableRegionLocatorImpl.getRegionLocation(byte[] row, + boolean reload)  + + +(package private) CompletableFuture<HRegionLocation> +AsyncRegionLocator.getRegionLocation(TableName tableName, + byte[] row, + boolean reload)  + + List<HRegionLocation> ClusterConnection.locateRegions(TableName tableName)
    Gets the locations of all regions in the specified table, tableName.
    @@ -494,51 +518,71 @@ service. +CompletableFuture<T> +AsyncSingleRequestRpcRetryingCaller.Callable.call(HBaseRpcController controller, + HRegionLocation loc, + org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ClientService.Interface stub)  + + +private static <REQ,PREQ,PRESP,RESP>
    CompletableFuture<RESP>
    +AsyncTableImpl.call(HBaseRpcController controller, + HRegionLocation loc, + org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ClientService.Interface stub, + REQ req, + AsyncTableImpl.Converter<PREQ,byte[],REQ> reqConvert, + AsyncTableImpl.RpcCall<PRESP,PREQ> rpcCall, + AsyncTableImpl.Converter<RESP,HBaseRpcController,PRESP> respConverter)  + + +private void +AsyncSingleRequestRpcRetryingCaller.call(HRegionLocation loc)  + + (package private) AsyncProcess.RowChecker.ReturnCode AsyncProcess.RowCheckerHost.canTakeOperation(HRegionLocation loc, long rowSize)  - + AsyncProcess.RowChecker.ReturnCode AsyncProcess.RowChecker.canTakeOperation(HRegionLocation loc, long rowSize)  - + AsyncProcess.RowChecker.ReturnCode AsyncProcess.SubmittedSizeChecker.canTakeOperation(HRegionLocation loc, long rowSize)  - + AsyncProcess.RowChecker.ReturnCode AsyncProcess.TaskCountChecker.canTakeOperation(HRegionLocation loc, long rowSize)
    1) check the regions is allowed.
    - + AsyncProcess.RowChecker.ReturnCode AsyncProcess.RequestSizeChecker.canTakeOperation(HRegionLocation loc, long rowSize)  - + void MetaCache.clearCache(HRegionLocation location)  - + void ClusterConnection.deleteCachedRegionLocation(HRegionLocation location)
    Deletes cached locations for the specific region.
    - + void ConnectionImplementation.deleteCachedRegionLocation(HRegionLocation location)  - + (package private) LinkedBlockingQueue<HTableMultiplexer.PutStatus> HTableMultiplexer.getQueue(HRegionLocation addr)  - + void AsyncProcess.RowChecker.notifyFinal(AsyncProcess.RowChecker.ReturnCode code, HRegionLocation loc, @@ -546,34 +590,34 @@ service.
    Add the final ReturnCode to the checker.
    - + void AsyncProcess.SubmittedSizeChecker.notifyFinal(AsyncProcess.RowChecker.ReturnCode code, HRegionLocation loc, long rowSize)  - + void AsyncProcess.TaskCountChecker.notifyFinal(AsyncProcess.RowChecker.ReturnCode code, HRegionLocation loc, long rowSize)  - + void AsyncProcess.RequestSizeChecker.notifyFinal(AsyncProcess.RowChecker.ReturnCode code, HRegionLocation loc, long rowSize)  - + (package private) boolean HTableMultiplexer.FlushWorker.resubmitFailedPut(HTableMultiplexer.PutStatus ps, HRegionLocation oldLoc)  - + protected void RegionServerCallable.setLocation(HRegionLocation location)  - + static <T> T ResultStatsUtil.updateStats(T r, ServerStatisticTracker stats, http://git-wip-us.apache.org/repos/asf/hbase-site/blob/f07ee53f/devapidocs/org/apache/hadoop/hbase/class-use/KeyValue.KeyOnlyKeyValue.html ---------------------------------------------------------------------- diff --git a/devapidocs/org/apache/hadoop/hbase/class-use/KeyValue.KeyOnlyKeyValue.html b/devapidocs/org/apache/hadoop/hbase/class-use/KeyValue.KeyOnlyKeyValue.html index 717161b..b92a00a 100644 --- a/devapidocs/org/apache/hadoop/hbase/class-use/KeyValue.KeyOnlyKeyValue.html +++ b/devapidocs/org/apache/hadoop/hbase/class-use/KeyValue.KeyOnlyKeyValue.html @@ -83,10 +83,14 @@ -org.apache.hadoop.hbase.io.encoding +org.apache.hadoop.hbase   +org.apache.hadoop.hbase.io.encoding +  + + org.apache.hadoop.hbase.regionserver   @@ -95,6 +99,24 @@