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 8A3BF200D3A for ; Wed, 15 Nov 2017 16:30:38 +0100 (CET) Received: by cust-asf.ponee.io (Postfix) id 8779C160C0F; Wed, 15 Nov 2017 15:30:38 +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 568E7160BF6 for ; Wed, 15 Nov 2017 16:30:34 +0100 (CET) Received: (qmail 65488 invoked by uid 500); 15 Nov 2017 15:30:31 -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 64875 invoked by uid 99); 15 Nov 2017 15:30:31 -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; Wed, 15 Nov 2017 15:30:31 +0000 Received: by git1-us-west.apache.org (ASF Mail Server at git1-us-west.apache.org, from userid 33) id 6BB63F5E66; Wed, 15 Nov 2017 15:30:28 +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: Wed, 15 Nov 2017 15:30:34 -0000 Message-Id: <6b9f589b70fa4669a28ebcd574f27d90@git.apache.org> In-Reply-To: <67e4cc16295a40faaf2f98b501a06374@git.apache.org> References: <67e4cc16295a40faaf2f98b501a06374@git.apache.org> X-Mailer: ASF-Git Admin Mailer Subject: [07/51] [partial] hbase-site git commit: Published site at . archived-at: Wed, 15 Nov 2017 15:30:38 -0000 http://git-wip-us.apache.org/repos/asf/hbase-site/blob/cba900e4/devapidocs/org/apache/hadoop/hbase/io/hfile/class-use/CachedBlock.html ---------------------------------------------------------------------- diff --git a/devapidocs/org/apache/hadoop/hbase/io/hfile/class-use/CachedBlock.html b/devapidocs/org/apache/hadoop/hbase/io/hfile/class-use/CachedBlock.html index 8108f0a..59ee24f 100644 --- a/devapidocs/org/apache/hadoop/hbase/io/hfile/class-use/CachedBlock.html +++ b/devapidocs/org/apache/hadoop/hbase/io/hfile/class-use/CachedBlock.html @@ -150,15 +150,15 @@ Iterator<CachedBlock> -CombinedBlockCache.iterator()  +BlockCache.iterator()  Iterator<CachedBlock> -BlockCache.iterator()  +LruBlockCache.iterator()  Iterator<CachedBlock> -LruBlockCache.iterator()  +CombinedBlockCache.iterator()  Iterator<CachedBlock> http://git-wip-us.apache.org/repos/asf/hbase-site/blob/cba900e4/devapidocs/org/apache/hadoop/hbase/io/hfile/class-use/HFile.Writer.html ---------------------------------------------------------------------- diff --git a/devapidocs/org/apache/hadoop/hbase/io/hfile/class-use/HFile.Writer.html b/devapidocs/org/apache/hadoop/hbase/io/hfile/class-use/HFile.Writer.html index a8e355e..7d29f77 100644 --- a/devapidocs/org/apache/hadoop/hbase/io/hfile/class-use/HFile.Writer.html +++ b/devapidocs/org/apache/hadoop/hbase/io/hfile/class-use/HFile.Writer.html @@ -143,18 +143,18 @@ void -HFileDataBlockEncoderImpl.saveMetadata(HFile.Writer writer)  - - -void NoOpDataBlockEncoder.saveMetadata(HFile.Writer writer)  - + void HFileDataBlockEncoder.saveMetadata(HFile.Writer writer)
Save metadata in HFile which will be written to disk
+ +void +HFileDataBlockEncoderImpl.saveMetadata(HFile.Writer writer)  + @@ -203,18 +203,18 @@ -void -RowColBloomContext.addLastBloomKey(HFile.Writer writer)  +abstract void +BloomContext.addLastBloomKey(HFile.Writer writer) +
Adds the last bloom key to the HFile Writer as part of StorefileWriter close.
+ void RowBloomContext.addLastBloomKey(HFile.Writer writer)  -abstract void -BloomContext.addLastBloomKey(HFile.Writer writer) -
Adds the last bloom key to the HFile Writer as part of StorefileWriter close.
- +void +RowColBloomContext.addLastBloomKey(HFile.Writer writer)  static BloomFilterWriter http://git-wip-us.apache.org/repos/asf/hbase-site/blob/cba900e4/devapidocs/org/apache/hadoop/hbase/io/hfile/class-use/HFileBlock.Writer.html ---------------------------------------------------------------------- diff --git a/devapidocs/org/apache/hadoop/hbase/io/hfile/class-use/HFileBlock.Writer.html b/devapidocs/org/apache/hadoop/hbase/io/hfile/class-use/HFileBlock.Writer.html index 6b0eb0b..ded8848 100644 --- a/devapidocs/org/apache/hadoop/hbase/io/hfile/class-use/HFileBlock.Writer.html +++ b/devapidocs/org/apache/hadoop/hbase/io/hfile/class-use/HFileBlock.Writer.html @@ -106,15 +106,15 @@ +private HFileBlock.Writer +HFileBlockIndex.BlockIndexWriter.blockWriter  + + protected HFileBlock.Writer HFileWriterImpl.blockWriter
block writer
- -private HFileBlock.Writer -HFileBlockIndex.BlockIndexWriter.blockWriter  - http://git-wip-us.apache.org/repos/asf/hbase-site/blob/cba900e4/devapidocs/org/apache/hadoop/hbase/io/hfile/class-use/HFileContext.html ---------------------------------------------------------------------- diff --git a/devapidocs/org/apache/hadoop/hbase/io/hfile/class-use/HFileContext.html b/devapidocs/org/apache/hadoop/hbase/io/hfile/class-use/HFileContext.html index 2af7d60..eff6d3c 100644 --- a/devapidocs/org/apache/hadoop/hbase/io/hfile/class-use/HFileContext.html +++ b/devapidocs/org/apache/hadoop/hbase/io/hfile/class-use/HFileContext.html @@ -136,15 +136,15 @@ - + - + - + @@ -224,23 +224,23 @@ + + + + - + - - - - - + @@ -277,20 +277,20 @@ - - - - - + + + + + @@ -323,35 +323,35 @@ - - - - - + - - - - + + + + - + + + + + - - - - + + + +
HFileContextHFileBlockDecodingContext.getHFileContext() HFileBlockEncodingContext.getHFileContext() 
HFileContextHFileBlockDefaultDecodingContext.getHFileContext() HFileBlockDecodingContext.getHFileContext() 
HFileContextHFileBlockEncodingContext.getHFileContext() HFileBlockDefaultDecodingContext.getHFileContext() 
HFileContext
private HFileContextHFile.WriterFactory.fileContext 
private HFileContext HFileBlock.fileContext
Meta data that holds meta information on the hfileblock.
private HFileContext HFileBlock.Writer.fileContext
Meta data that holds information about the hfileblock
private HFileContextHFileBlock.FSReaderImpl.fileContext 
private HFileContextHFile.WriterFactory.fileContext HFileBlock.FSReaderImpl.fileContext 
private HFileContext
HFileContextHFileWriterImpl.getFileContext() 
HFileContext HFile.Writer.getFileContext()
Return the file context for the HFile this writer belongs to
HFileContext HFile.Reader.getFileContext()
Return the file context of the HFile this reader belongs to
HFileContextHFileWriterImpl.getFileContext() 
HFileContext HFileReaderImpl.getFileContext() 
HFileBlockDecodingContextHFileDataBlockEncoderImpl.newDataBlockDecodingContext(HFileContext fileContext) 
HFileBlockDecodingContext NoOpDataBlockEncoder.newDataBlockDecodingContext(HFileContext meta) 
HFileBlockDecodingContext HFileDataBlockEncoder.newDataBlockDecodingContext(HFileContext fileContext)
create a encoder specific decoding context for reading.
HFileBlockEncodingContextHFileDataBlockEncoderImpl.newDataBlockEncodingContext(byte[] dummyHeader, - HFileContext fileContext) 
HFileBlockDecodingContextHFileDataBlockEncoderImpl.newDataBlockDecodingContext(HFileContext fileContext) 
HFileBlockEncodingContext NoOpDataBlockEncoder.newDataBlockEncodingContext(byte[] dummyHeader, HFileContext meta) 
HFileBlockEncodingContext HFileDataBlockEncoder.newDataBlockEncodingContext(byte[] headerBytes, HFileContext fileContext)
Create an encoder specific encoding context object for writing.
HFileBlockEncodingContextHFileDataBlockEncoderImpl.newDataBlockEncodingContext(byte[] dummyHeader, + HFileContext fileContext) 
(package private) HFileBlock HFileBlock.unpack(HFileContext fileContext, http://git-wip-us.apache.org/repos/asf/hbase-site/blob/cba900e4/devapidocs/org/apache/hadoop/hbase/io/hfile/class-use/InlineBlockWriter.html ---------------------------------------------------------------------- diff --git a/devapidocs/org/apache/hadoop/hbase/io/hfile/class-use/InlineBlockWriter.html b/devapidocs/org/apache/hadoop/hbase/io/hfile/class-use/InlineBlockWriter.html index 8ce8e92..9d43437 100644 --- a/devapidocs/org/apache/hadoop/hbase/io/hfile/class-use/InlineBlockWriter.html +++ b/devapidocs/org/apache/hadoop/hbase/io/hfile/class-use/InlineBlockWriter.html @@ -145,15 +145,15 @@
voidHFileWriterImpl.addInlineBlockWriter(InlineBlockWriter ibw) 
void HFile.Writer.addInlineBlockWriter(InlineBlockWriter bloomWriter)
Adds an inline block writer such as a multi-level block index writer or a compound Bloom filter writer.
voidHFileWriterImpl.addInlineBlockWriter(InlineBlockWriter ibw) 
http://git-wip-us.apache.org/repos/asf/hbase-site/blob/cba900e4/devapidocs/org/apache/hadoop/hbase/io/hfile/class-use/LruCachedBlock.html ---------------------------------------------------------------------- diff --git a/devapidocs/org/apache/hadoop/hbase/io/hfile/class-use/LruCachedBlock.html b/devapidocs/org/apache/hadoop/hbase/io/hfile/class-use/LruCachedBlock.html index c03def2..e18df2e 100644 --- a/devapidocs/org/apache/hadoop/hbase/io/hfile/class-use/LruCachedBlock.html +++ b/devapidocs/org/apache/hadoop/hbase/io/hfile/class-use/LruCachedBlock.html @@ -156,13 +156,13 @@ void -LruCachedBlockQueue.add(LruCachedBlock cb) -
Attempt to add the specified cached block to this queue.
- +LruBlockCache.BlockBucket.add(LruCachedBlock block)  void -LruBlockCache.BlockBucket.add(LruCachedBlock block)  +LruCachedBlockQueue.add(LruCachedBlock cb) +
Attempt to add the specified cached block to this queue.
+ int http://git-wip-us.apache.org/repos/asf/hbase-site/blob/cba900e4/devapidocs/org/apache/hadoop/hbase/io/hfile/package-tree.html ---------------------------------------------------------------------- diff --git a/devapidocs/org/apache/hadoop/hbase/io/hfile/package-tree.html b/devapidocs/org/apache/hadoop/hbase/io/hfile/package-tree.html index 7bb283b..f9771af 100644 --- a/devapidocs/org/apache/hadoop/hbase/io/hfile/package-tree.html +++ b/devapidocs/org/apache/hadoop/hbase/io/hfile/package-tree.html @@ -273,12 +273,12 @@ http://git-wip-us.apache.org/repos/asf/hbase-site/blob/cba900e4/devapidocs/org/apache/hadoop/hbase/ipc/CallEvent.Type.html ---------------------------------------------------------------------- diff --git a/devapidocs/org/apache/hadoop/hbase/ipc/CallEvent.Type.html b/devapidocs/org/apache/hadoop/hbase/ipc/CallEvent.Type.html index 11e817e..3e5d13a 100644 --- a/devapidocs/org/apache/hadoop/hbase/ipc/CallEvent.Type.html +++ b/devapidocs/org/apache/hadoop/hbase/ipc/CallEvent.Type.html @@ -236,7 +236,7 @@ the order they are declared.
  • values

    -
    public static CallEvent.Type[] values()
    +
    public static CallEvent.Type[] values()
    Returns an array containing the constants of this enum type, in the order they are declared. This method may be used to iterate over the constants as follows: @@ -256,7 +256,7 @@ for (CallEvent.Type c : CallEvent.Type.values())
    • valueOf

      -
      public static CallEvent.Type valueOf(String name)
      +
      public static CallEvent.Type valueOf(String name)
      Returns the enum constant of this type with the specified name. The string must match exactly an identifier used to declare an enum constant in this type. (Extraneous whitespace characters are http://git-wip-us.apache.org/repos/asf/hbase-site/blob/cba900e4/devapidocs/org/apache/hadoop/hbase/ipc/class-use/Call.html ---------------------------------------------------------------------- diff --git a/devapidocs/org/apache/hadoop/hbase/ipc/class-use/Call.html b/devapidocs/org/apache/hadoop/hbase/ipc/class-use/Call.html index 3931e76..96df063 100644 --- a/devapidocs/org/apache/hadoop/hbase/ipc/class-use/Call.html +++ b/devapidocs/org/apache/hadoop/hbase/ipc/class-use/Call.html @@ -152,16 +152,16 @@ org.apache.hadoop.hbase.shaded.protobuf.generated.RPCProtos.CellBlockMeta cellBlockMeta)  -protected abstract void -RpcConnection.callTimeout(Call call)  +protected void +BlockingRpcConnection.callTimeout(Call call)  protected void NettyRpcConnection.callTimeout(Call call)  -protected void -BlockingRpcConnection.callTimeout(Call call)  +protected abstract void +RpcConnection.callTimeout(Call call)  private void @@ -183,9 +183,9 @@ BlockingRpcConnection.CallSender.sendCall(Call call)  -abstract void -RpcConnection.sendRequest(Call call, - HBaseRpcController hrc)  +void +BlockingRpcConnection.sendRequest(Call call, + HBaseRpcController pcrc)  void @@ -193,9 +193,9 @@ HBaseRpcController hrc)  -void -BlockingRpcConnection.sendRequest(Call call, - HBaseRpcController pcrc)  +abstract void +RpcConnection.sendRequest(Call call, + HBaseRpcController hrc)  (package private) static void http://git-wip-us.apache.org/repos/asf/hbase-site/blob/cba900e4/devapidocs/org/apache/hadoop/hbase/ipc/class-use/CallQueueInfo.html ---------------------------------------------------------------------- diff --git a/devapidocs/org/apache/hadoop/hbase/ipc/class-use/CallQueueInfo.html b/devapidocs/org/apache/hadoop/hbase/ipc/class-use/CallQueueInfo.html index f746d97..4982943 100644 --- a/devapidocs/org/apache/hadoop/hbase/ipc/class-use/CallQueueInfo.html +++ b/devapidocs/org/apache/hadoop/hbase/ipc/class-use/CallQueueInfo.html @@ -105,19 +105,19 @@ -abstract CallQueueInfo -RpcScheduler.getCallQueueInfo() -
      Get call queue information
      - - - CallQueueInfo FifoRpcScheduler.getCallQueueInfo()  - + CallQueueInfo SimpleRpcScheduler.getCallQueueInfo()  + +abstract CallQueueInfo +RpcScheduler.getCallQueueInfo() +
      Get call queue information
      + +
    • http://git-wip-us.apache.org/repos/asf/hbase-site/blob/cba900e4/devapidocs/org/apache/hadoop/hbase/ipc/class-use/CallRunner.html ---------------------------------------------------------------------- diff --git a/devapidocs/org/apache/hadoop/hbase/ipc/class-use/CallRunner.html b/devapidocs/org/apache/hadoop/hbase/ipc/class-use/CallRunner.html index c745594..88e0729 100644 --- a/devapidocs/org/apache/hadoop/hbase/ipc/class-use/CallRunner.html +++ b/devapidocs/org/apache/hadoop/hbase/ipc/class-use/CallRunner.html @@ -149,16 +149,16 @@ AdaptiveLifoCoDelCallQueue.element()  -protected CallRunner -FastPathBalancedQueueRpcExecutor.FastPathHandler.getCallRunner()  +(package private) CallRunner +FifoRpcScheduler.FifoCallRunner.getCallRunner()  protected CallRunner RpcExecutor.Handler.getCallRunner()  -(package private) CallRunner -FifoRpcScheduler.FifoCallRunner.getCallRunner()  +protected CallRunner +FastPathBalancedQueueRpcExecutor.FastPathHandler.getCallRunner()  CallRunner @@ -223,17 +223,15 @@ boolean -FastPathBalancedQueueRpcExecutor.dispatch(CallRunner callTask)  +RWQueueRpcExecutor.dispatch(CallRunner callTask)  -abstract boolean -RpcScheduler.dispatch(CallRunner task) -
      Dispatches an RPC request asynchronously.
      - +boolean +FifoRpcScheduler.dispatch(CallRunner task)  boolean -RWQueueRpcExecutor.dispatch(CallRunner callTask)  +SimpleRpcScheduler.dispatch(CallRunner callTask)  boolean @@ -247,11 +245,13 @@ boolean -FifoRpcScheduler.dispatch(CallRunner task)  +FastPathBalancedQueueRpcExecutor.dispatch(CallRunner callTask)  -boolean -SimpleRpcScheduler.dispatch(CallRunner callTask)  +abstract boolean +RpcScheduler.dispatch(CallRunner task) +
      Dispatches an RPC request asynchronously.
      + (package private) boolean @@ -303,19 +303,19 @@ protected RpcExecutor.Handler -FastPathBalancedQueueRpcExecutor.getHandler(String name, +RpcExecutor.getHandler(String name, double handlerFailureThreshhold, BlockingQueue<CallRunner> q, - AtomicInteger activeHandlerCount)  + AtomicInteger activeHandlerCount) +
      Override if providing alternate Handler implementation.
      + protected RpcExecutor.Handler -RpcExecutor.getHandler(String name, +FastPathBalancedQueueRpcExecutor.getHandler(String name, double handlerFailureThreshhold, BlockingQueue<CallRunner> q, - AtomicInteger activeHandlerCount) -
      Override if providing alternate Handler implementation.
      - + AtomicInteger activeHandlerCount)
        protected void http://git-wip-us.apache.org/repos/asf/hbase-site/blob/cba900e4/devapidocs/org/apache/hadoop/hbase/ipc/class-use/CellBlockBuilder.html ---------------------------------------------------------------------- diff --git a/devapidocs/org/apache/hadoop/hbase/ipc/class-use/CellBlockBuilder.html b/devapidocs/org/apache/hadoop/hbase/ipc/class-use/CellBlockBuilder.html index fcda916..3fe92d9 100644 --- a/devapidocs/org/apache/hadoop/hbase/ipc/class-use/CellBlockBuilder.html +++ b/devapidocs/org/apache/hadoop/hbase/ipc/class-use/CellBlockBuilder.html @@ -114,11 +114,11 @@ protected CellBlockBuilder -RpcServer.cellBlockBuilder  +ServerCall.cellBlockBuilder  protected CellBlockBuilder -ServerCall.cellBlockBuilder  +RpcServer.cellBlockBuilder  http://git-wip-us.apache.org/repos/asf/hbase-site/blob/cba900e4/devapidocs/org/apache/hadoop/hbase/ipc/class-use/ConnectionId.html ---------------------------------------------------------------------- diff --git a/devapidocs/org/apache/hadoop/hbase/ipc/class-use/ConnectionId.html b/devapidocs/org/apache/hadoop/hbase/ipc/class-use/ConnectionId.html index 2e54781..2a507fe 100644 --- a/devapidocs/org/apache/hadoop/hbase/ipc/class-use/ConnectionId.html +++ b/devapidocs/org/apache/hadoop/hbase/ipc/class-use/ConnectionId.html @@ -144,21 +144,21 @@ -protected NettyRpcConnection -NettyRpcClient.createConnection(ConnectionId remoteId)  - - protected abstract T AbstractRpcClient.createConnection(ConnectionId remoteId)
      Not connected.
      - + protected BlockingRpcConnection BlockingRpcClient.createConnection(ConnectionId remoteId)
      Creates a connection.
      + +protected NettyRpcConnection +NettyRpcClient.createConnection(ConnectionId remoteId)  + private T AbstractRpcClient.getConnection(ConnectionId remoteId) http://git-wip-us.apache.org/repos/asf/hbase-site/blob/cba900e4/devapidocs/org/apache/hadoop/hbase/ipc/class-use/CoprocessorRpcChannel.html ---------------------------------------------------------------------- diff --git a/devapidocs/org/apache/hadoop/hbase/ipc/class-use/CoprocessorRpcChannel.html b/devapidocs/org/apache/hadoop/hbase/ipc/class-use/CoprocessorRpcChannel.html index 591cabf..04e9a7d 100644 --- a/devapidocs/org/apache/hadoop/hbase/ipc/class-use/CoprocessorRpcChannel.html +++ b/devapidocs/org/apache/hadoop/hbase/ipc/class-use/CoprocessorRpcChannel.html @@ -145,14 +145,14 @@ CoprocessorRpcChannel -HTable.coprocessorService(byte[] row) +Table.coprocessorService(byte[] row)
      Creates and returns a RpcChannel instance connected to the table region containing the specified row.
      CoprocessorRpcChannel -Table.coprocessorService(byte[] row) +HTable.coprocessorService(byte[] row)
      Creates and returns a RpcChannel instance connected to the table region containing the specified row.
      http://git-wip-us.apache.org/repos/asf/hbase-site/blob/cba900e4/devapidocs/org/apache/hadoop/hbase/ipc/class-use/HBaseRpcController.CancellationCallback.html ---------------------------------------------------------------------- diff --git a/devapidocs/org/apache/hadoop/hbase/ipc/class-use/HBaseRpcController.CancellationCallback.html b/devapidocs/org/apache/hadoop/hbase/ipc/class-use/HBaseRpcController.CancellationCallback.html index 91d2eee..6d64706 100644 --- a/devapidocs/org/apache/hadoop/hbase/ipc/class-use/HBaseRpcController.CancellationCallback.html +++ b/devapidocs/org/apache/hadoop/hbase/ipc/class-use/HBaseRpcController.CancellationCallback.html @@ -111,16 +111,16 @@ void +HBaseRpcControllerImpl.notifyOnCancel(org.apache.hadoop.hbase.shaded.com.google.protobuf.RpcCallback<Object> callback, + HBaseRpcController.CancellationCallback action)  + + +void HBaseRpcController.notifyOnCancel(org.apache.hadoop.hbase.shaded.com.google.protobuf.RpcCallback<Object> callback, HBaseRpcController.CancellationCallback action)
      If not cancelled, add the callback to cancellation callback list.
      - -void -HBaseRpcControllerImpl.notifyOnCancel(org.apache.hadoop.hbase.shaded.com.google.protobuf.RpcCallback<Object> callback, - HBaseRpcController.CancellationCallback action)  - http://git-wip-us.apache.org/repos/asf/hbase-site/blob/cba900e4/devapidocs/org/apache/hadoop/hbase/ipc/class-use/HBaseRpcController.html ---------------------------------------------------------------------- diff --git a/devapidocs/org/apache/hadoop/hbase/ipc/class-use/HBaseRpcController.html b/devapidocs/org/apache/hadoop/hbase/ipc/class-use/HBaseRpcController.html index c245bf9..8fd32d4 100644 --- a/devapidocs/org/apache/hadoop/hbase/ipc/class-use/HBaseRpcController.html +++ b/devapidocs/org/apache/hadoop/hbase/ipc/class-use/HBaseRpcController.html @@ -123,21 +123,21 @@ +HBaseRpcController +AsyncClientScanner.OpenScannerResponse.controller  + + private HBaseRpcController RegionAdminServiceCallable.controller  - + private HBaseRpcController AsyncScanSingleRegionRpcRetryingCaller.controller  - + protected HBaseRpcController AsyncRpcRetryingCaller.controller  - -HBaseRpcController -AsyncClientScanner.OpenScannerResponse.controller  - private HBaseRpcController MasterCallable.rpcController  @@ -156,13 +156,13 @@ RegionAdminServiceCallable.getCurrentPayloadCarryingRpcController()  -private HBaseRpcController -AsyncConnectionImpl.getRpcController()  - - (package private) HBaseRpcController MasterCallable.getRpcController()  + +private HBaseRpcController +AsyncConnectionImpl.getRpcController()  + @@ -320,17 +320,17 @@ - - @@ -517,9 +517,9 @@ org.apache.hadoop.hbase.shaded.com.google.protobuf.RpcCallback<org.apache.hadoop.hbase.shaded.com.google.protobuf.Message> callback)  - - + + @@ -527,9 +527,9 @@ HBaseRpcController hrc)  - - + +
      CompletableFuture<Boolean>AsyncScanSingleRegionRpcRetryingCaller.start(HBaseRpcController controller, +AsyncRpcRetryingCallerFactory.ScanSingleRegionCallerBuilder.start(HBaseRpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ScanResponse respWhenOpen) -
      Now we will also fetch some cells along with the scanner id when opening a scanner, so we also - need to process the ScanResponse for the open scanner request.
      +
      Short cut for build().start(HBaseRpcController, ScanResponse).
      CompletableFuture<Boolean>AsyncRpcRetryingCallerFactory.ScanSingleRegionCallerBuilder.start(HBaseRpcController controller, +AsyncScanSingleRegionRpcRetryingCaller.start(HBaseRpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ScanResponse respWhenOpen) -
      Short cut for build().start(HBaseRpcController, ScanResponse).
      +
      Now we will also fetch some cells along with the scanner id when opening a scanner, so we also + need to process the ScanResponse for the open scanner request.
      abstract voidRpcConnection.sendRequest(Call call, - HBaseRpcController hrc) voidBlockingRpcConnection.sendRequest(Call call, + HBaseRpcController pcrc) 
      void
      voidBlockingRpcConnection.sendRequest(Call call, - HBaseRpcController pcrc) abstract voidRpcConnection.sendRequest(Call call, + HBaseRpcController hrc) 
      http://git-wip-us.apache.org/repos/asf/hbase-site/blob/cba900e4/devapidocs/org/apache/hadoop/hbase/ipc/class-use/MetricsHBaseServer.html ---------------------------------------------------------------------- diff --git a/devapidocs/org/apache/hadoop/hbase/ipc/class-use/MetricsHBaseServer.html b/devapidocs/org/apache/hadoop/hbase/ipc/class-use/MetricsHBaseServer.html index 5808ce3..7c967d0 100644 --- a/devapidocs/org/apache/hadoop/hbase/ipc/class-use/MetricsHBaseServer.html +++ b/devapidocs/org/apache/hadoop/hbase/ipc/class-use/MetricsHBaseServer.html @@ -105,16 +105,16 @@ -private MetricsHBaseServer -NettyRpcServerRequestDecoder.metrics  +protected MetricsHBaseServer +RpcServer.metrics  private MetricsHBaseServer NettyRpcServerResponseEncoder.metrics  -protected MetricsHBaseServer -RpcServer.metrics  +private MetricsHBaseServer +NettyRpcServerRequestDecoder.metrics