Uses of Class
org.apache.hadoop.hbase.ipc.CallRunner
-
Uses of CallRunner in org.apache.hadoop.hbase.ipc
Modifier and TypeFieldDescriptionprivate final CallRunner
FifoRpcScheduler.FifoCallRunner.callRunner
private CallRunner
FastPathRpcHandler.loadedCallRunner
Modifier and TypeFieldDescription(package private) final BlockingQueue<CallRunner>
RpcHandler.q
Q to find CallRunners to run in.private LinkedBlockingDeque<CallRunner>
AdaptiveLifoCoDelCallQueue.queue
private final List<BlockingQueue<CallRunner>>
RandomQueueBalancer.queues
protected final List<BlockingQueue<CallRunner>>
RpcExecutor.queues
Modifier and TypeMethodDescriptionAdaptiveLifoCoDelCallQueue.element()
protected CallRunner
FastPathRpcHandler.getCallRunner()
(package private) CallRunner
FifoRpcScheduler.FifoCallRunner.getCallRunner()
protected CallRunner
RpcHandler.getCallRunner()
Returns ACallRunner
nAdaptiveLifoCoDelCallQueue.peek()
AdaptiveLifoCoDelCallQueue.poll()
AdaptiveLifoCoDelCallQueue.remove()
AdaptiveLifoCoDelCallQueue.take()
Behaves asLinkedBlockingQueue.take()
, except it will silently skip all calls which it thinks should be dropped.Modifier 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()
Modifier and TypeMethodDescriptionboolean
AdaptiveLifoCoDelCallQueue.add
(CallRunner callRunner) int
RpcExecutor.CallPriorityComparator.compare
(CallRunner a, CallRunner b) boolean
BalancedQueueRpcExecutor.dispatch
(CallRunner callTask) boolean
DelegatingRpcScheduler.dispatch
(CallRunner task) boolean
FastPathBalancedQueueRpcExecutor.dispatch
(CallRunner callTask) boolean
FastPathRWQueueRpcExecutor.dispatch
(CallRunner callTask) boolean
FifoRpcScheduler.dispatch
(CallRunner task) boolean
MasterFifoRpcScheduler.dispatch
(CallRunner task) abstract boolean
RpcExecutor.dispatch
(CallRunner callTask) Add the request to the executor queueabstract boolean
RpcScheduler.dispatch
(CallRunner task) Dispatches an RPC request asynchronously.boolean
RWQueueRpcExecutor.dispatch
(CallRunner callTask) boolean
SimpleRpcScheduler.dispatch
(CallRunner callTask) protected boolean
RWQueueRpcExecutor.dispatchTo
(boolean toWriteQueue, boolean toScanQueue, CallRunner callTask) protected boolean
FifoRpcScheduler.executeRpcCall
(ThreadPoolExecutor executor, AtomicInteger queueSize, CallRunner task) protected String
FifoRpcScheduler.getCallMethod
(CallRunner task) private static String
RpcExecutor.getMethodName
(CallRunner callRunner) Return theDescriptors.MethodDescriptor.getName()
fromcallRunner
or "Unknown".int
QueueBalancer.getNextQueue
(CallRunner callRunner) Returns the index of the next queue to which a request should be insertedint
RandomQueueBalancer.getNextQueue
(CallRunner callRunner) private static long
RpcExecutor.getRpcCallSize
(CallRunner callRunner) Return theRpcCall.getSize()
fromcallRunner
or 0L.(package private) boolean
FastPathRpcHandler.loadCallRunner
(CallRunner cr) private boolean
AdaptiveLifoCoDelCallQueue.needToDrop
(CallRunner callRunner) boolean
AdaptiveLifoCoDelCallQueue.offer
(CallRunner callRunner) boolean
AdaptiveLifoCoDelCallQueue.offer
(CallRunner callRunner, long timeout, TimeUnit unit) void
AdaptiveLifoCoDelCallQueue.put
(CallRunner callRunner) private void
RpcHandler.run
(CallRunner cr) protected boolean
RWQueueRpcExecutor.shouldDispatchToScanQueue
(CallRunner task) Modifier and TypeMethodDescriptionboolean
AdaptiveLifoCoDelCallQueue.addAll
(Collection<? extends CallRunner> c) int
AdaptiveLifoCoDelCallQueue.drainTo
(Collection<? super CallRunner> c) int
AdaptiveLifoCoDelCallQueue.drainTo
(Collection<? super CallRunner> c, int maxElements) static QueueBalancer
RpcExecutor.getBalancer
(String executorName, org.apache.hadoop.conf.Configuration conf, List<BlockingQueue<CallRunner>> queues) protected RpcHandler
FastPathBalancedQueueRpcExecutor.getHandler
(String name, double handlerFailureThreshhold, int handlerCount, BlockingQueue<CallRunner> q, AtomicInteger activeHandlerCount, AtomicInteger failedHandlerCount, Abortable abortable) protected RpcHandler
FastPathRWQueueRpcExecutor.getHandler
(String name, double handlerFailureThreshhold, int handlerCount, BlockingQueue<CallRunner> q, AtomicInteger activeHandlerCount, AtomicInteger failedHandlerCount, Abortable abortable) protected RpcHandler
RpcExecutor.getHandler
(String name, double handlerFailureThreshhold, int handlerCount, BlockingQueue<CallRunner> q, AtomicInteger activeHandlerCount, AtomicInteger failedHandlerCount, Abortable abortable) Override if providing alternate Handler implementation.protected void
RpcExecutor.startHandlers
(String nameSuffix, int numHandlers, List<BlockingQueue<CallRunner>> callQueues, int qindex, int qsize, int port, AtomicInteger activeHandlerCount) Start up our handlers.ModifierConstructorDescription(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)