Uses of Class
org.apache.hadoop.hbase.ipc.CallRunner
Packages that use org.apache.hadoop.hbase.ipc.CallRunner
- 
Uses of org.apache.hadoop.hbase.ipc.CallRunner in org.apache.hadoop.hbase.ipcFields in org.apache.hadoop.hbase.ipc with type parameters of type org.apache.hadoop.hbase.ipc.CallRunner in inModifier and TypeFieldDescriptionprotected final List<BlockingQueue<org.apache.hadoop.hbase.ipc.CallRunner>>RpcExecutor.queuesMethods in org.apache.hadoop.hbase.ipc that return org.apache.hadoop.hbase.ipc.CallRunner in inModifier and TypeMethodDescriptionorg.apache.hadoop.hbase.ipc.CallRunnerAdaptiveLifoCoDelCallQueue.element()protected org.apache.hadoop.hbase.ipc.CallRunnerFastPathRpcHandler.getCallRunner()protected org.apache.hadoop.hbase.ipc.CallRunnerRpcHandler.getCallRunner()org.apache.hadoop.hbase.ipc.CallRunnerAdaptiveLifoCoDelCallQueue.peek()org.apache.hadoop.hbase.ipc.CallRunnerAdaptiveLifoCoDelCallQueue.poll()org.apache.hadoop.hbase.ipc.CallRunnerAdaptiveLifoCoDelCallQueue.poll(long timeout, TimeUnit unit) org.apache.hadoop.hbase.ipc.CallRunnerAdaptiveLifoCoDelCallQueue.remove()org.apache.hadoop.hbase.ipc.CallRunnerAdaptiveLifoCoDelCallQueue.take()Behaves asLinkedBlockingQueue.take(), except it will silently skip all calls which it thinks should be dropped.Methods in org.apache.hadoop.hbase.ipc that return types with arguments of type org.apache.hadoop.hbase.ipc.CallRunner in inModifier and TypeMethodDescriptionprotected List<BlockingQueue<org.apache.hadoop.hbase.ipc.CallRunner>>RpcExecutor.getQueues()Returns the list of request queuesIterator<org.apache.hadoop.hbase.ipc.CallRunner>AdaptiveLifoCoDelCallQueue.iterator()Methods in org.apache.hadoop.hbase.ipc with parameters of type org.apache.hadoop.hbase.ipc.CallRunner in inModifier and TypeMethodDescriptionbooleanAdaptiveLifoCoDelCallQueue.add(org.apache.hadoop.hbase.ipc.CallRunner callRunner) booleanBalancedQueueRpcExecutor.dispatch(org.apache.hadoop.hbase.ipc.CallRunner callTask) booleanDelegatingRpcScheduler.dispatch(org.apache.hadoop.hbase.ipc.CallRunner task) booleanFastPathBalancedQueueRpcExecutor.dispatch(org.apache.hadoop.hbase.ipc.CallRunner callTask) booleanFastPathRWQueueRpcExecutor.dispatch(org.apache.hadoop.hbase.ipc.CallRunner callTask) booleanFifoRpcScheduler.dispatch(org.apache.hadoop.hbase.ipc.CallRunner task) booleanMasterFifoRpcScheduler.dispatch(org.apache.hadoop.hbase.ipc.CallRunner task) abstract booleanRpcExecutor.dispatch(org.apache.hadoop.hbase.ipc.CallRunner callTask) Add the request to the executor queueabstract booleanRpcScheduler.dispatch(org.apache.hadoop.hbase.ipc.CallRunner task) Dispatches an RPC request asynchronously.booleanRWQueueRpcExecutor.dispatch(org.apache.hadoop.hbase.ipc.CallRunner callTask) booleanSimpleRpcScheduler.dispatch(org.apache.hadoop.hbase.ipc.CallRunner callTask) protected booleanRWQueueRpcExecutor.dispatchTo(boolean toWriteQueue, boolean toScanQueue, org.apache.hadoop.hbase.ipc.CallRunner callTask) protected booleanFifoRpcScheduler.executeRpcCall(ThreadPoolExecutor executor, AtomicInteger queueSize, org.apache.hadoop.hbase.ipc.CallRunner task) protected StringFifoRpcScheduler.getCallMethod(org.apache.hadoop.hbase.ipc.CallRunner task) intQueueBalancer.getNextQueue(org.apache.hadoop.hbase.ipc.CallRunner callRunner) Returns the index of the next queue to which a request should be insertedintRandomQueueBalancer.getNextQueue(org.apache.hadoop.hbase.ipc.CallRunner callRunner) booleanAdaptiveLifoCoDelCallQueue.offer(org.apache.hadoop.hbase.ipc.CallRunner callRunner) booleanAdaptiveLifoCoDelCallQueue.offer(org.apache.hadoop.hbase.ipc.CallRunner callRunner, long timeout, TimeUnit unit) voidAdaptiveLifoCoDelCallQueue.put(org.apache.hadoop.hbase.ipc.CallRunner callRunner) protected booleanRWQueueRpcExecutor.shouldDispatchToScanQueue(org.apache.hadoop.hbase.ipc.CallRunner task) Method parameters in org.apache.hadoop.hbase.ipc with type arguments of type org.apache.hadoop.hbase.ipc.CallRunner in inModifier and TypeMethodDescriptionbooleanAdaptiveLifoCoDelCallQueue.addAll(Collection<? extends org.apache.hadoop.hbase.ipc.CallRunner> c) intAdaptiveLifoCoDelCallQueue.drainTo(Collection<? super org.apache.hadoop.hbase.ipc.CallRunner> c) intAdaptiveLifoCoDelCallQueue.drainTo(Collection<? super org.apache.hadoop.hbase.ipc.CallRunner> c, int maxElements) static org.apache.hadoop.hbase.ipc.QueueBalancerRpcExecutor.getBalancer(String executorName, org.apache.hadoop.conf.Configuration conf, List<BlockingQueue<org.apache.hadoop.hbase.ipc.CallRunner>> queues) protected org.apache.hadoop.hbase.ipc.RpcHandlerFastPathBalancedQueueRpcExecutor.getHandler(String name, double handlerFailureThreshhold, int handlerCount, BlockingQueue<org.apache.hadoop.hbase.ipc.CallRunner> q, AtomicInteger activeHandlerCount, AtomicInteger failedHandlerCount, org.apache.hadoop.hbase.Abortable abortable) protected org.apache.hadoop.hbase.ipc.RpcHandlerFastPathRWQueueRpcExecutor.getHandler(String name, double handlerFailureThreshhold, int handlerCount, BlockingQueue<org.apache.hadoop.hbase.ipc.CallRunner> q, AtomicInteger activeHandlerCount, AtomicInteger failedHandlerCount, org.apache.hadoop.hbase.Abortable abortable) protected org.apache.hadoop.hbase.ipc.RpcHandlerRpcExecutor.getHandler(String name, double handlerFailureThreshhold, int handlerCount, BlockingQueue<org.apache.hadoop.hbase.ipc.CallRunner> q, AtomicInteger activeHandlerCount, AtomicInteger failedHandlerCount, org.apache.hadoop.hbase.Abortable abortable) Override if providing alternate Handler implementation.protected voidRpcExecutor.startHandlers(String nameSuffix, int numHandlers, List<BlockingQueue<org.apache.hadoop.hbase.ipc.CallRunner>> callQueues, int qindex, int qsize, int port, AtomicInteger activeHandlerCount) Start up our handlers.Constructor parameters in org.apache.hadoop.hbase.ipc with type arguments of type org.apache.hadoop.hbase.ipc.CallRunner in inModifierConstructorDescriptionRandomQueueBalancer(org.apache.hadoop.conf.Configuration conf, String executorName, List<BlockingQueue<org.apache.hadoop.hbase.ipc.CallRunner>> queues)