Uses of Class
org.apache.hadoop.hbase.ipc.CallRunner
Packages that use CallRunner
-
Uses of CallRunner in org.apache.hadoop.hbase.ipc
Fields in org.apache.hadoop.hbase.ipc declared as CallRunnerModifier and TypeFieldDescriptionprivate final CallRunnerFifoRpcScheduler.FifoCallRunner.callRunnerprivate CallRunnerFastPathRpcHandler.loadedCallRunnerFields in org.apache.hadoop.hbase.ipc with type parameters of type CallRunnerModifier and TypeFieldDescription(package private) final BlockingQueue<CallRunner>RpcHandler.qQ to find CallRunners to run in.private LinkedBlockingDeque<CallRunner>AdaptiveLifoCoDelCallQueue.queueprivate final List<BlockingQueue<CallRunner>>RandomQueueBalancer.queuesprotected final List<BlockingQueue<CallRunner>>RpcExecutor.queuesMethods in org.apache.hadoop.hbase.ipc that return CallRunnerModifier and TypeMethodDescriptionAdaptiveLifoCoDelCallQueue.element()protected CallRunnerFastPathRpcHandler.getCallRunner()(package private) CallRunnerFifoRpcScheduler.FifoCallRunner.getCallRunner()protected CallRunnerRpcHandler.getCallRunner()Returns ACallRunnernAdaptiveLifoCoDelCallQueue.peek()AdaptiveLifoCoDelCallQueue.poll()AdaptiveLifoCoDelCallQueue.remove()AdaptiveLifoCoDelCallQueue.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 CallRunnerModifier and TypeMethodDescriptionprivate Optional<Class<? extends BlockingQueue<CallRunner>>>RpcExecutor.getPluggableQueueClass()(package private) List<BlockingQueue<CallRunner>>RandomQueueBalancer.getQueues()Exposed for use in testsprotected List<BlockingQueue<CallRunner>>RpcExecutor.getQueues()Returns the list of request queuesAdaptiveLifoCoDelCallQueue.iterator()Methods in org.apache.hadoop.hbase.ipc with parameters of type CallRunnerModifier and TypeMethodDescriptionbooleanAdaptiveLifoCoDelCallQueue.add(CallRunner callRunner) intRpcExecutor.CallPriorityComparator.compare(CallRunner a, CallRunner b) booleanBalancedQueueRpcExecutor.dispatch(CallRunner callTask) booleanDelegatingRpcScheduler.dispatch(CallRunner task) booleanFastPathBalancedQueueRpcExecutor.dispatch(CallRunner callTask) booleanFastPathRWQueueRpcExecutor.dispatch(CallRunner callTask) booleanFifoRpcScheduler.dispatch(CallRunner task) booleanMasterFifoRpcScheduler.dispatch(CallRunner task) booleanMetaRWQueueRpcExecutor.dispatch(CallRunner callTask) abstract booleanRpcExecutor.dispatch(CallRunner callTask) Add the request to the executor queueabstract booleanRpcScheduler.dispatch(CallRunner task) Dispatches an RPC request asynchronously.booleanRWQueueRpcExecutor.dispatch(CallRunner callTask) booleanSimpleRpcScheduler.dispatch(CallRunner callTask) protected booleanRWQueueRpcExecutor.dispatchTo(boolean toWriteQueue, boolean toScanQueue, CallRunner callTask) protected booleanFifoRpcScheduler.executeRpcCall(ThreadPoolExecutor executor, AtomicInteger queueSize, CallRunner task) protected StringFifoRpcScheduler.getCallMethod(CallRunner task) private static StringRpcExecutor.getMethodName(CallRunner callRunner) Return theDescriptors.MethodDescriptor.getName()fromcallRunneror "Unknown".intQueueBalancer.getNextQueue(CallRunner callRunner) Returns the index of the next queue to which a request should be insertedintRandomQueueBalancer.getNextQueue(CallRunner callRunner) private static longRpcExecutor.getRpcCallSize(CallRunner callRunner) Return theRpcCall.getSize()fromcallRunneror 0L.(package private) booleanFastPathRpcHandler.loadCallRunner(CallRunner cr) private booleanAdaptiveLifoCoDelCallQueue.needToDrop(CallRunner callRunner) booleanAdaptiveLifoCoDelCallQueue.offer(CallRunner callRunner) booleanAdaptiveLifoCoDelCallQueue.offer(CallRunner callRunner, long timeout, TimeUnit unit) voidAdaptiveLifoCoDelCallQueue.put(CallRunner callRunner) private voidRpcHandler.run(CallRunner cr) protected booleanRWQueueRpcExecutor.shouldDispatchToScanQueue(CallRunner task) Method parameters in org.apache.hadoop.hbase.ipc with type arguments of type CallRunnerModifier and TypeMethodDescriptionbooleanAdaptiveLifoCoDelCallQueue.addAll(Collection<? extends CallRunner> c) intAdaptiveLifoCoDelCallQueue.drainTo(Collection<? super CallRunner> c) intAdaptiveLifoCoDelCallQueue.drainTo(Collection<? super CallRunner> c, int maxElements) static QueueBalancerRpcExecutor.getBalancer(String executorName, org.apache.hadoop.conf.Configuration conf, List<BlockingQueue<CallRunner>> queues) protected RpcHandlerFastPathBalancedQueueRpcExecutor.getHandler(String name, double handlerFailureThreshhold, int handlerCount, BlockingQueue<CallRunner> q, AtomicInteger activeHandlerCount, AtomicInteger failedHandlerCount, Abortable abortable) protected RpcHandlerFastPathRWQueueRpcExecutor.getHandler(String name, double handlerFailureThreshhold, int handlerCount, BlockingQueue<CallRunner> q, AtomicInteger activeHandlerCount, AtomicInteger failedHandlerCount, Abortable abortable) protected RpcHandlerRpcExecutor.getHandler(String name, double handlerFailureThreshhold, int handlerCount, BlockingQueue<CallRunner> q, AtomicInteger activeHandlerCount, AtomicInteger failedHandlerCount, Abortable abortable) Override if providing alternate Handler implementation.protected voidRpcExecutor.startHandlers(String nameSuffix, int numHandlers, List<BlockingQueue<CallRunner>> callQueues, int qindex, int qsize, int port, AtomicInteger activeHandlerCount) Start up our handlers.Constructors in org.apache.hadoop.hbase.ipc with parameters of type CallRunnerConstructor parameters in org.apache.hadoop.hbase.ipc with type arguments of type CallRunnerModifierConstructorDescription(package private)FastPathRpcHandler(String name, double handlerFailureThreshhold, int handlerCount, BlockingQueue<CallRunner> q, AtomicInteger activeHandlerCount, AtomicInteger failedHandlerCount, Abortable abortable, Deque<FastPathRpcHandler> fastPathHandlerStack) RandomQueueBalancer(org.apache.hadoop.conf.Configuration conf, String executorName, List<BlockingQueue<CallRunner>> queues) (package private)RpcHandler(String name, double handlerFailureThreshhold, int handlerCount, BlockingQueue<CallRunner> q, AtomicInteger activeHandlerCount, AtomicInteger failedHandlerCount, Abortable abortable)