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 5D97E200B11 for ; Mon, 13 Jun 2016 18:54:55 +0200 (CEST) Received: by cust-asf.ponee.io (Postfix) id 5B1C4160A6A; Mon, 13 Jun 2016 16:54:55 +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 D149B160A5B for ; Mon, 13 Jun 2016 18:54:52 +0200 (CEST) Received: (qmail 72837 invoked by uid 500); 13 Jun 2016 16:54:51 -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 72729 invoked by uid 99); 13 Jun 2016 16:54:51 -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, 13 Jun 2016 16:54:51 +0000 Received: by git1-us-west.apache.org (ASF Mail Server at git1-us-west.apache.org, from userid 33) id 94D47E05E1; Mon, 13 Jun 2016 16:54:51 +0000 (UTC) Content-Type: text/plain; charset="us-ascii" MIME-Version: 1.0 Content-Transfer-Encoding: 7bit From: misty@apache.org To: commits@hbase.apache.org Date: Mon, 13 Jun 2016 16:54:53 -0000 Message-Id: <9724f19485a148b2bf9510703ba12cde@git.apache.org> In-Reply-To: <599017fe047c4e938f5b99e79ca65f4d@git.apache.org> References: <599017fe047c4e938f5b99e79ca65f4d@git.apache.org> X-Mailer: ASF-Git Admin Mailer Subject: [03/52] [partial] hbase-site git commit: Published site at 56c209c8aaf15997888307f8a76767858cb9f470. archived-at: Mon, 13 Jun 2016 16:54:55 -0000 http://git-wip-us.apache.org/repos/asf/hbase-site/blob/7f869c01/devapidocs/org/apache/hadoop/hbase/ipc/SimpleRpcScheduler.html ---------------------------------------------------------------------- diff --git a/devapidocs/org/apache/hadoop/hbase/ipc/SimpleRpcScheduler.html b/devapidocs/org/apache/hadoop/hbase/ipc/SimpleRpcScheduler.html index 2db94f9..ac287dd 100644 --- a/devapidocs/org/apache/hadoop/hbase/ipc/SimpleRpcScheduler.html +++ b/devapidocs/org/apache/hadoop/hbase/ipc/SimpleRpcScheduler.html @@ -106,11 +106,14 @@
@InterfaceAudience.LimitedPrivate(value={"Coprocesssor","Phoenix"})
 @InterfaceStability.Evolving
-public class SimpleRpcScheduler
+public class SimpleRpcScheduler
 extends RpcScheduler
 implements ConfigurationObserver
-
A scheduler that maintains isolated handler pools for general, - high-priority, and replication requests.
+
The default scheduler. Configurable. Maintains isolated handler pools for general ('default'), + high-priority ('priority'), and replication ('replication') requests. Default behavior is to + balance the requests across handlers. Add configs to enable balancing by read vs writes, etc. + See below article for explanation of options.
+
See Also:
Overview on Request Queuing
@@ -204,7 +207,7 @@ implements static String CALL_QUEUE_TYPE_CONF_KEY -
If set to 'deadline', uses a priority queue and deprioritize long-running scans
+
If set to 'deadline', the default, uses a priority queue and deprioritizes long-running scans
@@ -364,18 +367,22 @@ implements +private static boolean +isDeadlineQueueType(String callQueueType)  + + void onConfigurationChange(org.apache.hadoop.conf.Configuration conf)
Resize call queues;
- + void start()
Prepares for request serving.
- + void stop()
Stops serving new requests.
@@ -409,7 +416,7 @@ implements
  • LOG

    -
    private static final org.apache.commons.logging.Log LOG
    +
    private static final org.apache.commons.logging.Log LOG
  • @@ -418,7 +425,7 @@ implements
  • CALL_QUEUE_READ_SHARE_CONF_KEY

    -
    public static final String CALL_QUEUE_READ_SHARE_CONF_KEY
    +
    public static final String CALL_QUEUE_READ_SHARE_CONF_KEY
    See Also:
    Constant Field Values
  • @@ -428,7 +435,7 @@ implements
  • CALL_QUEUE_SCAN_SHARE_CONF_KEY

    -
    public static final String CALL_QUEUE_SCAN_SHARE_CONF_KEY
    +
    public static final String CALL_QUEUE_SCAN_SHARE_CONF_KEY
    See Also:
    Constant Field Values
  • @@ -438,7 +445,7 @@ implements
  • CALL_QUEUE_HANDLER_FACTOR_CONF_KEY

    -
    public static final String CALL_QUEUE_HANDLER_FACTOR_CONF_KEY
    +
    public static final String CALL_QUEUE_HANDLER_FACTOR_CONF_KEY
    See Also:
    Constant Field Values
  • @@ -448,8 +455,8 @@ implements
  • CALL_QUEUE_TYPE_CONF_KEY

    -
    public static final String CALL_QUEUE_TYPE_CONF_KEY
    -
    If set to 'deadline', uses a priority queue and deprioritize long-running scans
    +
    public static final String CALL_QUEUE_TYPE_CONF_KEY
    +
    If set to 'deadline', the default, uses a priority queue and deprioritizes long-running scans
    See Also:
    Constant Field Values
  • @@ -459,7 +466,7 @@ implements
  • CALL_QUEUE_TYPE_CODEL_CONF_VALUE

    -
    public static final String CALL_QUEUE_TYPE_CODEL_CONF_VALUE
    +
    public static final String CALL_QUEUE_TYPE_CODEL_CONF_VALUE
    See Also:
    Constant Field Values
  • @@ -469,7 +476,7 @@ implements
  • CALL_QUEUE_TYPE_DEADLINE_CONF_VALUE

    -
    public static final String CALL_QUEUE_TYPE_DEADLINE_CONF_VALUE
    +
    public static final String CALL_QUEUE_TYPE_DEADLINE_CONF_VALUE
    See Also:
    Constant Field Values
  • @@ -479,7 +486,7 @@ implements
  • CALL_QUEUE_TYPE_FIFO_CONF_VALUE

    -
    public static final String CALL_QUEUE_TYPE_FIFO_CONF_VALUE
    +
    public static final String CALL_QUEUE_TYPE_FIFO_CONF_VALUE
    See Also:
    Constant Field Values
  • @@ -489,7 +496,7 @@ implements
  • QUEUE_MAX_CALL_DELAY_CONF_KEY

    -
    public static final String QUEUE_MAX_CALL_DELAY_CONF_KEY
    +
    public static final String QUEUE_MAX_CALL_DELAY_CONF_KEY
    max delay in msec used to bound the deprioritized requests
    See Also:
    Constant Field Values
  • @@ -500,7 +507,7 @@ implements
  • CALL_QUEUE_CODEL_TARGET_DELAY

    -
    public static final String CALL_QUEUE_CODEL_TARGET_DELAY
    +
    public static final String CALL_QUEUE_CODEL_TARGET_DELAY
    See Also:
    Constant Field Values
  • @@ -510,7 +517,7 @@ implements
  • CALL_QUEUE_CODEL_INTERVAL

    -
    public static final String CALL_QUEUE_CODEL_INTERVAL
    +
    public static final String CALL_QUEUE_CODEL_INTERVAL
    See Also:
    Constant Field Values
  • @@ -520,7 +527,7 @@ implements
  • CALL_QUEUE_CODEL_LIFO_THRESHOLD

    -
    public static final String CALL_QUEUE_CODEL_LIFO_THRESHOLD
    +
    public static final String CALL_QUEUE_CODEL_LIFO_THRESHOLD
    See Also:
    Constant Field Values
  • @@ -530,7 +537,7 @@ implements
  • CALL_QUEUE_CODEL_DEFAULT_TARGET_DELAY

    -
    public static final int CALL_QUEUE_CODEL_DEFAULT_TARGET_DELAY
    +
    public static final int CALL_QUEUE_CODEL_DEFAULT_TARGET_DELAY
    See Also:
    Constant Field Values
  • @@ -540,7 +547,7 @@ implements
  • CALL_QUEUE_CODEL_DEFAULT_INTERVAL

    -
    public static final int CALL_QUEUE_CODEL_DEFAULT_INTERVAL
    +
    public static final int CALL_QUEUE_CODEL_DEFAULT_INTERVAL
    See Also:
    Constant Field Values
  • @@ -550,7 +557,7 @@ implements
  • CALL_QUEUE_CODEL_DEFAULT_LIFO_THRESHOLD

    -
    public static final double CALL_QUEUE_CODEL_DEFAULT_LIFO_THRESHOLD
    +
    public static final double CALL_QUEUE_CODEL_DEFAULT_LIFO_THRESHOLD
    See Also:
    Constant Field Values
  • @@ -560,7 +567,7 @@ implements
  • numGeneralCallsDropped

    -
    private AtomicLong numGeneralCallsDropped
    +
    private AtomicLong numGeneralCallsDropped
  • @@ -569,7 +576,7 @@ implements
  • numLifoModeSwitches

    -
    private AtomicLong numLifoModeSwitches
    +
    private AtomicLong numLifoModeSwitches
  • @@ -578,7 +585,7 @@ implements
  • port

    -
    private int port
    +
    private int port
  • @@ -587,7 +594,7 @@ implements
  • priority

    -
    private final PriorityFunction priority
    +
    private final PriorityFunction priority
  • @@ -596,7 +603,7 @@ implements
  • callExecutor

    -
    private final RpcExecutor callExecutor
    +
    private final RpcExecutor callExecutor
  • @@ -605,7 +612,7 @@ implements
  • priorityExecutor

    -
    private final RpcExecutor priorityExecutor
    +
    private final RpcExecutor priorityExecutor
  • @@ -614,7 +621,7 @@ implements
  • replicationExecutor

    -
    private final RpcExecutor replicationExecutor
    +
    private final RpcExecutor replicationExecutor
  • @@ -623,7 +630,7 @@ implements
  • highPriorityLevel

    -
    private final int highPriorityLevel
    +
    private final int highPriorityLevel
    What level a high priority call is at.
  • @@ -633,7 +640,7 @@ implements
  • abortable

    -
    private Abortable abortable
    +
    private Abortable abortable
  • @@ -650,7 +657,7 @@ implements
  • SimpleRpcScheduler

    -
    public SimpleRpcScheduler(org.apache.hadoop.conf.Configuration conf,
    +
    public SimpleRpcScheduler(org.apache.hadoop.conf.Configuration conf,
                       int handlerCount,
                       int priorityHandlerCount,
                       int replicationHandlerCount,
    @@ -666,7 +673,7 @@ implements 
     
  • SimpleRpcScheduler

    -
    public SimpleRpcScheduler(org.apache.hadoop.conf.Configuration conf,
    +
    public SimpleRpcScheduler(org.apache.hadoop.conf.Configuration conf,
                       int handlerCount,
                       int priorityHandlerCount,
                       int replicationHandlerCount,
    @@ -688,7 +695,7 @@ implements 
     
  • onConfigurationChange

    -
    public void onConfigurationChange(org.apache.hadoop.conf.Configuration conf)
    +
    public void onConfigurationChange(org.apache.hadoop.conf.Configuration conf)
    Resize call queues;
    Specified by:
    @@ -696,13 +703,22 @@ implements Parameters:
    conf - new configuration
  • + + + +
    • init

      -
      public void init(RpcScheduler.Context context)
      +
      public void init(RpcScheduler.Context context)
      Description copied from class: RpcScheduler
      Does some quick initialization. Heavy tasks (e.g. starting threads) should be done in RpcScheduler.start(). This method is called before start.
      @@ -718,7 +734,7 @@ implements
    • start

      -
      public void start()
      +
      public void start()
      Description copied from class: RpcScheduler
      Prepares for request serving. An implementation may start some handler threads here.
      @@ -733,7 +749,7 @@ implements
    • stop

      -
      public void stop()
      +
      public void stop()
      Description copied from class: RpcScheduler
      Stops serving new requests.
      @@ -748,7 +764,7 @@ implements
    • dispatch

      -
      public boolean dispatch(CallRunner callTask)
      +
      public boolean dispatch(CallRunner callTask)
                        throws InterruptedException
      Description copied from class: RpcScheduler
      Dispatches an RPC request asynchronously. An implementation is free to choose to process the @@ -767,7 +783,7 @@ implements
    • getGeneralQueueLength

      -
      public int getGeneralQueueLength()
      +
      public int getGeneralQueueLength()
      Description copied from class: RpcScheduler
      Retrieves length of the general queue for metrics.
      @@ -782,7 +798,7 @@ implements
    • getPriorityQueueLength

      -
      public int getPriorityQueueLength()
      +
      public int getPriorityQueueLength()
      Description copied from class: RpcScheduler
      Retrieves length of the priority queue for metrics.
      @@ -797,7 +813,7 @@ implements
    • getReplicationQueueLength

      -
      public int getReplicationQueueLength()
      +
      public int getReplicationQueueLength()
      Description copied from class: RpcScheduler
      Retrieves length of the replication queue for metrics.
      @@ -812,7 +828,7 @@ implements
    • getActiveRpcHandlerCount

      -
      public int getActiveRpcHandlerCount()
      +
      public int getActiveRpcHandlerCount()
      Description copied from class: RpcScheduler
      Retrieves the number of active handler.
      @@ -827,7 +843,7 @@ implements
    • getNumGeneralCallsDropped

      -
      public long getNumGeneralCallsDropped()
      +
      public long getNumGeneralCallsDropped()
      Description copied from class: RpcScheduler
      If CoDel-based RPC executors are used, retrieves the number of Calls that were dropped from general queue because RPC executor is under high load; returns 0 otherwise.
      @@ -843,7 +859,7 @@ implements
    • getNumLifoModeSwitches

      -
      public long getNumLifoModeSwitches()
      +
      public long getNumLifoModeSwitches()
      Description copied from class: RpcScheduler
      If CoDel-based RPC executors are used, retrieves the number of Calls that were picked from the tail of the queue (indicating adaptive LIFO mode, when http://git-wip-us.apache.org/repos/asf/hbase-site/blob/7f869c01/devapidocs/org/apache/hadoop/hbase/ipc/class-use/AsyncRpcChannel.html ---------------------------------------------------------------------- diff --git a/devapidocs/org/apache/hadoop/hbase/ipc/class-use/AsyncRpcChannel.html b/devapidocs/org/apache/hadoop/hbase/ipc/class-use/AsyncRpcChannel.html index c17dc3b..23a6b9d 100644 --- a/devapidocs/org/apache/hadoop/hbase/ipc/class-use/AsyncRpcChannel.html +++ b/devapidocs/org/apache/hadoop/hbase/ipc/class-use/AsyncRpcChannel.html @@ -140,13 +140,13 @@ AsyncRpcChannel -AsyncRpcClient.createRpcChannel(String serviceName, +RpcClientImpl.createRpcChannel(String serviceName, ServerName sn, User user)  AsyncRpcChannel -RpcClientImpl.createRpcChannel(String serviceName, +AsyncRpcClient.createRpcChannel(String serviceName, ServerName sn, User user)  http://git-wip-us.apache.org/repos/asf/hbase-site/blob/7f869c01/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 53c18ef..747ebe0 100644 --- a/devapidocs/org/apache/hadoop/hbase/ipc/class-use/CallRunner.html +++ b/devapidocs/org/apache/hadoop/hbase/ipc/class-use/CallRunner.html @@ -101,13 +101,13 @@ AdaptiveLifoCoDelCallQueue.queue  -private List<BlockingQueue<CallRunner>> -RWQueueRpcExecutor.queues  - - protected List<BlockingQueue<CallRunner>> BalancedQueueRpcExecutor.queues  + +private List<BlockingQueue<CallRunner>> +RWQueueRpcExecutor.queues  + @@ -155,19 +155,19 @@ - - - - - + + + + + @@ -192,11 +192,13 @@ - + - - + + @@ -206,17 +208,15 @@ - + - - + + - + http://git-wip-us.apache.org/repos/asf/hbase-site/blob/7f869c01/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 719e25c..9d79d3e 100644 --- a/devapidocs/org/apache/hadoop/hbase/ipc/class-use/CoprocessorRpcChannel.html +++ b/devapidocs/org/apache/hadoop/hbase/ipc/class-use/CoprocessorRpcChannel.html @@ -119,14 +119,14 @@ - - http://git-wip-us.apache.org/repos/asf/hbase-site/blob/7f869c01/devapidocs/org/apache/hadoop/hbase/ipc/class-use/FailedServerException.html ---------------------------------------------------------------------- diff --git a/devapidocs/org/apache/hadoop/hbase/ipc/class-use/FailedServerException.html b/devapidocs/org/apache/hadoop/hbase/ipc/class-use/FailedServerException.html index 07b5bab..a881328 100644 --- a/devapidocs/org/apache/hadoop/hbase/ipc/class-use/FailedServerException.html +++ b/devapidocs/org/apache/hadoop/hbase/ipc/class-use/FailedServerException.html @@ -106,13 +106,13 @@ - - http://git-wip-us.apache.org/repos/asf/hbase-site/blob/7f869c01/devapidocs/org/apache/hadoop/hbase/ipc/class-use/FailedServers.html ---------------------------------------------------------------------- diff --git a/devapidocs/org/apache/hadoop/hbase/ipc/class-use/FailedServers.html b/devapidocs/org/apache/hadoop/hbase/ipc/class-use/FailedServers.html index d1ba1ac..1540f20 100644 --- a/devapidocs/org/apache/hadoop/hbase/ipc/class-use/FailedServers.html +++ b/devapidocs/org/apache/hadoop/hbase/ipc/class-use/FailedServers.html @@ -97,13 +97,13 @@ - - - - + + + +
      protected List<BlockingQueue<CallRunner>>RWQueueRpcExecutor.getQueues() 
      protected abstract List<BlockingQueue<CallRunner>> RpcExecutor.getQueues()
      Returns the list of request queues
      List<BlockingQueue<CallRunner>> BalancedQueueRpcExecutor.getQueues() 
      protected List<BlockingQueue<CallRunner>>RWQueueRpcExecutor.getQueues() 
      Iterator<CallRunner> AdaptiveLifoCoDelCallQueue.iterator() 
      booleanRWQueueRpcExecutor.dispatch(CallRunner callTask) FifoRpcScheduler.dispatch(CallRunner task) 
      booleanSimpleRpcScheduler.dispatch(CallRunner callTask) abstract booleanRpcScheduler.dispatch(CallRunner task) +
      Dispatches an RPC request asynchronously.
      +
      abstract boolean
      booleanFifoRpcScheduler.dispatch(CallRunner task) BalancedQueueRpcExecutor.dispatch(CallRunner callTask) 
      abstract booleanRpcScheduler.dispatch(CallRunner task) -
      Dispatches an RPC request asynchronously.
      -
      booleanRWQueueRpcExecutor.dispatch(CallRunner callTask) 
      booleanBalancedQueueRpcExecutor.dispatch(CallRunner callTask) SimpleRpcScheduler.dispatch(CallRunner callTask) 
      private boolean
      CoprocessorRpcChannelTable.coprocessorService(byte[] row) +HTable.coprocessorService(byte[] row)
      Creates and returns a RpcChannel instance connected to the table region containing the specified row.
      CoprocessorRpcChannelHTable.coprocessorService(byte[] row) +Table.coprocessorService(byte[] row)
      Creates and returns a RpcChannel instance connected to the table region containing the specified row.
      AsyncRpcChannelAsyncRpcClient.createRpcChannel(String serviceName, +RpcClientImpl.createRpcChannel(String serviceName, ServerName sn, User user) 
      AsyncRpcChannelRpcClientImpl.createRpcChannel(String serviceName, +AsyncRpcClient.createRpcChannel(String serviceName, ServerName sn, User user) 
      (package private) FailedServersAsyncRpcClient.failedServers 
      protected FailedServers RpcClientImpl.failedServers 
      (package private) FailedServersAsyncRpcClient.failedServers 
    • http://git-wip-us.apache.org/repos/asf/hbase-site/blob/7f869c01/devapidocs/org/apache/hadoop/hbase/ipc/class-use/IOExceptionConverter.html ---------------------------------------------------------------------- diff --git a/devapidocs/org/apache/hadoop/hbase/ipc/class-use/IOExceptionConverter.html b/devapidocs/org/apache/hadoop/hbase/ipc/class-use/IOExceptionConverter.html index 21cd685..6535b6a 100644 --- a/devapidocs/org/apache/hadoop/hbase/ipc/class-use/IOExceptionConverter.html +++ b/devapidocs/org/apache/hadoop/hbase/ipc/class-use/IOExceptionConverter.html @@ -111,27 +111,27 @@ <R extends com.google.protobuf.Message,O> 
      Future<O>
      -RpcClientImpl.AsyncRpcChannel.callMethod(com.google.protobuf.Descriptors.MethodDescriptor method, +AsyncRpcChannelImpl.callMethod(com.google.protobuf.Descriptors.MethodDescriptor method, com.google.protobuf.Message request, CellScanner cellScanner, R responsePrototype, MessageConverter<R,O> messageConverter, IOExceptionConverter exceptionConverter, long rpcTimeout, - int priority)  + int priority) +
      Calls method on channel
      + <R extends com.google.protobuf.Message,O> 
      Future<O>
      -AsyncRpcChannelImpl.callMethod(com.google.protobuf.Descriptors.MethodDescriptor method, +RpcClientImpl.AsyncRpcChannel.callMethod(com.google.protobuf.Descriptors.MethodDescriptor method, com.google.protobuf.Message request, CellScanner cellScanner, R responsePrototype, MessageConverter<R,O> messageConverter, IOExceptionConverter exceptionConverter, long rpcTimeout, - int priority) -
      Calls method on channel
      - + int priority)
        <R extends com.google.protobuf.Message,O> 
      Future<O>
      http://git-wip-us.apache.org/repos/asf/hbase-site/blob/7f869c01/devapidocs/org/apache/hadoop/hbase/ipc/class-use/MessageConverter.html ---------------------------------------------------------------------- diff --git a/devapidocs/org/apache/hadoop/hbase/ipc/class-use/MessageConverter.html b/devapidocs/org/apache/hadoop/hbase/ipc/class-use/MessageConverter.html index 329c852..a9dd7c9 100644 --- a/devapidocs/org/apache/hadoop/hbase/ipc/class-use/MessageConverter.html +++ b/devapidocs/org/apache/hadoop/hbase/ipc/class-use/MessageConverter.html @@ -128,27 +128,27 @@ <R extends com.google.protobuf.Message,O> 
      Future<O>
      -RpcClientImpl.AsyncRpcChannel.callMethod(com.google.protobuf.Descriptors.MethodDescriptor method, +AsyncRpcChannelImpl.callMethod(com.google.protobuf.Descriptors.MethodDescriptor method, com.google.protobuf.Message request, CellScanner cellScanner, R responsePrototype, MessageConverter<R,O> messageConverter, IOExceptionConverter exceptionConverter, long rpcTimeout, - int priority)  + int priority) +
      Calls method on channel
      + <R extends com.google.protobuf.Message,O> 
      Future<O>
      -AsyncRpcChannelImpl.callMethod(com.google.protobuf.Descriptors.MethodDescriptor method, +RpcClientImpl.AsyncRpcChannel.callMethod(com.google.protobuf.Descriptors.MethodDescriptor method, com.google.protobuf.Message request, CellScanner cellScanner, R responsePrototype, MessageConverter<R,O> messageConverter, IOExceptionConverter exceptionConverter, long rpcTimeout, - int priority) -
      Calls method on channel
      - + int priority)
        <R extends com.google.protobuf.Message,O> 
      Future<O>
      http://git-wip-us.apache.org/repos/asf/hbase-site/blob/7f869c01/devapidocs/org/apache/hadoop/hbase/ipc/class-use/PayloadCarryingRpcController.html ---------------------------------------------------------------------- diff --git a/devapidocs/org/apache/hadoop/hbase/ipc/class-use/PayloadCarryingRpcController.html b/devapidocs/org/apache/hadoop/hbase/ipc/class-use/PayloadCarryingRpcController.html index fd6bd7f..de9f638 100644 --- a/devapidocs/org/apache/hadoop/hbase/ipc/class-use/PayloadCarryingRpcController.html +++ b/devapidocs/org/apache/hadoop/hbase/ipc/class-use/PayloadCarryingRpcController.html @@ -111,16 +111,16 @@ -private PayloadCarryingRpcController -RpcRetryingCallerWithReadReplicas.ReplicaRegionServerCallable.controller  +protected PayloadCarryingRpcController +PayloadCarryingServerCallable.controller  -protected PayloadCarryingRpcController -ScannerCallable.controller  +private PayloadCarryingRpcController +RpcRetryingCallerWithReadReplicas.ReplicaRegionServerCallable.controller  protected PayloadCarryingRpcController -PayloadCarryingServerCallable.controller  +ScannerCallable.controller  @@ -222,7 +222,7 @@ protected Pair<com.google.protobuf.Message,CellScanner> -AsyncRpcClient.call(PayloadCarryingRpcController pcrc, +RpcClientImpl.call(PayloadCarryingRpcController pcrc, com.google.protobuf.Descriptors.MethodDescriptor md, com.google.protobuf.Message param, com.google.protobuf.Message returnType, @@ -250,7 +250,7 @@ protected Pair<com.google.protobuf.Message,CellScanner> -RpcClientImpl.call(PayloadCarryingRpcController pcrc, +AsyncRpcClient.call(PayloadCarryingRpcController pcrc, com.google.protobuf.Descriptors.MethodDescriptor md, com.google.protobuf.Message param, com.google.protobuf.Message returnType, http://git-wip-us.apache.org/repos/asf/hbase-site/blob/7f869c01/devapidocs/org/apache/hadoop/hbase/ipc/class-use/PriorityFunction.html ---------------------------------------------------------------------- diff --git a/devapidocs/org/apache/hadoop/hbase/ipc/class-use/PriorityFunction.html b/devapidocs/org/apache/hadoop/hbase/ipc/class-use/PriorityFunction.html index 7dbdd8a..c096c0e 100644 --- a/devapidocs/org/apache/hadoop/hbase/ipc/class-use/PriorityFunction.html +++ b/devapidocs/org/apache/hadoop/hbase/ipc/class-use/PriorityFunction.html @@ -248,20 +248,33 @@ RpcScheduler -RpcSchedulerFactory.create(org.apache.hadoop.conf.Configuration conf, +SimpleRpcSchedulerFactory.create(org.apache.hadoop.conf.Configuration conf, PriorityFunction priority)
      Deprecated. 
      RpcScheduler -SimpleRpcSchedulerFactory.create(org.apache.hadoop.conf.Configuration conf, +RpcSchedulerFactory.create(org.apache.hadoop.conf.Configuration conf, PriorityFunction priority)
      Deprecated. 
      RpcScheduler +FifoRpcSchedulerFactory.create(org.apache.hadoop.conf.Configuration conf, + PriorityFunction priority) +
      Deprecated. 
      + + + +RpcScheduler +SimpleRpcSchedulerFactory.create(org.apache.hadoop.conf.Configuration conf, + PriorityFunction priority, + Abortable server)  + + +RpcScheduler RpcSchedulerFactory.create(org.apache.hadoop.conf.Configuration conf, PriorityFunction priority, Abortable server) @@ -270,7 +283,7 @@ RpcScheduler -SimpleRpcSchedulerFactory.create(org.apache.hadoop.conf.Configuration conf, +FifoRpcSchedulerFactory.create(org.apache.hadoop.conf.Configuration conf, PriorityFunction priority, Abortable server)  http://git-wip-us.apache.org/repos/asf/hbase-site/blob/7f869c01/devapidocs/org/apache/hadoop/hbase/ipc/class-use/RpcCallback.html ---------------------------------------------------------------------- diff --git a/devapidocs/org/apache/hadoop/hbase/ipc/class-use/RpcCallback.html b/devapidocs/org/apache/hadoop/hbase/ipc/class-use/RpcCallback.html index be65a28..a96a86e 100644 --- a/devapidocs/org/apache/hadoop/hbase/ipc/class-use/RpcCallback.html +++ b/devapidocs/org/apache/hadoop/hbase/ipc/class-use/RpcCallback.html @@ -115,14 +115,14 @@ void -RpcServer.Call.setCallBack(RpcCallback callback)  - - -void RpcCallContext.setCallBack(RpcCallback callback)
      Sets a callback which has to be executed at the end of this RPC call.
      + +void +RpcServer.Call.setCallBack(RpcCallback callback)  +