org.apache.hadoop.hbase.ipc.CallRunner
AdaptiveLifoCoDelCallQueue.element()
protected org.apache.hadoop.hbase.ipc.CallRunner
FastPathRpcHandler.getCallRunner()
protected org.apache.hadoop.hbase.ipc.CallRunner
RpcHandler.getCallRunner()
org.apache.hadoop.hbase.ipc.CallRunner
AdaptiveLifoCoDelCallQueue.peek()
org.apache.hadoop.hbase.ipc.CallRunner
AdaptiveLifoCoDelCallQueue.poll()
org.apache.hadoop.hbase.ipc.CallRunner
AdaptiveLifoCoDelCallQueue.poll(long timeout,
TimeUnit unit)
org.apache.hadoop.hbase.ipc.CallRunner
AdaptiveLifoCoDelCallQueue.remove()
org.apache.hadoop.hbase.ipc.CallRunner
AdaptiveLifoCoDelCallQueue.take()
boolean
AdaptiveLifoCoDelCallQueue.add(org.apache.hadoop.hbase.ipc.CallRunner callRunner)
boolean
BalancedQueueRpcExecutor.dispatch(org.apache.hadoop.hbase.ipc.CallRunner callTask)
boolean
DelegatingRpcScheduler.dispatch(org.apache.hadoop.hbase.ipc.CallRunner task)
boolean
FastPathBalancedQueueRpcExecutor.dispatch(org.apache.hadoop.hbase.ipc.CallRunner callTask)
boolean
FastPathRWQueueRpcExecutor.dispatch(org.apache.hadoop.hbase.ipc.CallRunner callTask)
boolean
FifoRpcScheduler.dispatch(org.apache.hadoop.hbase.ipc.CallRunner task)
boolean
MasterFifoRpcScheduler.dispatch(org.apache.hadoop.hbase.ipc.CallRunner task)
abstract boolean
RpcExecutor.dispatch(org.apache.hadoop.hbase.ipc.CallRunner callTask)
Add the request to the executor queue
abstract boolean
RpcScheduler.dispatch(org.apache.hadoop.hbase.ipc.CallRunner task)
Dispatches an RPC request asynchronously.
boolean
RWQueueRpcExecutor.dispatch(org.apache.hadoop.hbase.ipc.CallRunner callTask)
boolean
SimpleRpcScheduler.dispatch(org.apache.hadoop.hbase.ipc.CallRunner callTask)
protected boolean
RWQueueRpcExecutor.dispatchTo(boolean toWriteQueue,
boolean toScanQueue,
org.apache.hadoop.hbase.ipc.CallRunner callTask)
protected boolean
FifoRpcScheduler.getCallMethod(org.apache.hadoop.hbase.ipc.CallRunner task)
int
QueueBalancer.getNextQueue(org.apache.hadoop.hbase.ipc.CallRunner callRunner)
Returns the index of the next queue to which a request should be inserted
int
RandomQueueBalancer.getNextQueue(org.apache.hadoop.hbase.ipc.CallRunner callRunner)
boolean
AdaptiveLifoCoDelCallQueue.offer(org.apache.hadoop.hbase.ipc.CallRunner callRunner)
boolean
AdaptiveLifoCoDelCallQueue.offer(org.apache.hadoop.hbase.ipc.CallRunner callRunner,
long timeout,
TimeUnit unit)
void
AdaptiveLifoCoDelCallQueue.put(org.apache.hadoop.hbase.ipc.CallRunner callRunner)
protected boolean
RWQueueRpcExecutor.shouldDispatchToScanQueue(org.apache.hadoop.hbase.ipc.CallRunner task)
boolean
AdaptiveLifoCoDelCallQueue.addAll(Collection<? extends org.apache.hadoop.hbase.ipc.CallRunner> c)
int
AdaptiveLifoCoDelCallQueue.drainTo(Collection<? super org.apache.hadoop.hbase.ipc.CallRunner> c)
int
AdaptiveLifoCoDelCallQueue.drainTo(Collection<? super org.apache.hadoop.hbase.ipc.CallRunner> c,
int maxElements)
static org.apache.hadoop.hbase.ipc.QueueBalancer
RpcExecutor.getBalancer(String executorName,
org.apache.hadoop.conf.Configuration conf,
List<BlockingQueue<org.apache.hadoop.hbase.ipc.CallRunner>> queues)
protected org.apache.hadoop.hbase.ipc.RpcHandler
FastPathBalancedQueueRpcExecutor.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.RpcHandler
FastPathRWQueueRpcExecutor.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.RpcHandler
RpcExecutor.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 void
RpcExecutor.startHandlers(String nameSuffix,
int numHandlers,
List<BlockingQueue<org.apache.hadoop.hbase.ipc.CallRunner>> callQueues,
int qindex,
int qsize,
int port,
AtomicInteger activeHandlerCount)