Package | Description |
---|---|
org.apache.hadoop.hbase.ipc |
Tools to help define network clients and servers.
|
Modifier and Type | Field and Description |
---|---|
private CallRunner |
FifoRpcScheduler.FifoCallRunner.callRunner |
private CallRunner |
FastPathRpcHandler.loadedCallRunner |
Modifier and Type | Field and Description |
---|---|
(package private) BlockingQueue<CallRunner> |
RpcHandler.q
Q to find CallRunners to run in.
|
private LinkedBlockingDeque<CallRunner> |
AdaptiveLifoCoDelCallQueue.queue |
protected List<BlockingQueue<CallRunner>> |
RpcExecutor.queues |
private List<BlockingQueue<CallRunner>> |
RandomQueueBalancer.queues |
Modifier and Type | Method and Description |
---|---|
CallRunner |
AdaptiveLifoCoDelCallQueue.element() |
protected CallRunner |
RpcHandler.getCallRunner()
Returns A
CallRunner n |
protected CallRunner |
FastPathRpcHandler.getCallRunner() |
(package private) CallRunner |
FifoRpcScheduler.FifoCallRunner.getCallRunner() |
CallRunner |
AdaptiveLifoCoDelCallQueue.peek() |
CallRunner |
AdaptiveLifoCoDelCallQueue.poll() |
CallRunner |
AdaptiveLifoCoDelCallQueue.poll(long timeout,
TimeUnit unit) |
CallRunner |
AdaptiveLifoCoDelCallQueue.remove() |
CallRunner |
AdaptiveLifoCoDelCallQueue.take()
Behaves as
LinkedBlockingQueue.take() , except it will silently skip all calls which it
thinks should be dropped. |
Modifier and Type | Method and Description |
---|---|
private Optional<Class<? extends BlockingQueue<CallRunner>>> |
RpcExecutor.getPluggableQueueClass() |
protected List<BlockingQueue<CallRunner>> |
RpcExecutor.getQueues()
Returns the list of request queues
|
(package private) List<BlockingQueue<CallRunner>> |
RandomQueueBalancer.getQueues()
Exposed for use in tests
|
Iterator<CallRunner> |
AdaptiveLifoCoDelCallQueue.iterator() |
Modifier and Type | Method and Description |
---|---|
boolean |
AdaptiveLifoCoDelCallQueue.add(CallRunner callRunner) |
int |
RpcExecutor.CallPriorityComparator.compare(CallRunner a,
CallRunner b) |
abstract boolean |
RpcExecutor.dispatch(CallRunner callTask)
Add the request to the executor queue
|
boolean |
RWQueueRpcExecutor.dispatch(CallRunner callTask) |
boolean |
BalancedQueueRpcExecutor.dispatch(CallRunner callTask) |
abstract boolean |
RpcScheduler.dispatch(CallRunner task)
Dispatches an RPC request asynchronously.
|
boolean |
FastPathBalancedQueueRpcExecutor.dispatch(CallRunner callTask) |
boolean |
SimpleRpcScheduler.dispatch(CallRunner callTask) |
boolean |
FifoRpcScheduler.dispatch(CallRunner task) |
boolean |
FastPathRWQueueRpcExecutor.dispatch(CallRunner callTask) |
boolean |
MasterFifoRpcScheduler.dispatch(CallRunner task) |
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 the
Descriptors.MethodDescriptor#getName() from callRunner or "Unknown". |
int |
QueueBalancer.getNextQueue(CallRunner callRunner)
Returns the index of the next queue to which a request should be inserted
|
int |
RandomQueueBalancer.getNextQueue(CallRunner callRunner) |
private static long |
RpcExecutor.getRpcCallSize(CallRunner callRunner)
Return the
RpcCall.getSize() from callRunner 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 Type | Method and Description |
---|---|
boolean |
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 |
RpcExecutor.getHandler(String name,
double handlerFailureThreshhold,
int handlerCount,
BlockingQueue<CallRunner> q,
AtomicInteger activeHandlerCount,
AtomicInteger failedHandlerCount,
Abortable abortable)
Override if providing alternate Handler implementation.
|
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 void |
RpcExecutor.startHandlers(String nameSuffix,
int numHandlers,
List<BlockingQueue<CallRunner>> callQueues,
int qindex,
int qsize,
int port,
AtomicInteger activeHandlerCount)
Start up our handlers.
|
Constructor and Description |
---|
FifoCallRunner(CallRunner cr) |
Constructor and Description |
---|
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) |
RpcHandler(String name,
double handlerFailureThreshhold,
int handlerCount,
BlockingQueue<CallRunner> q,
AtomicInteger activeHandlerCount,
AtomicInteger failedHandlerCount,
Abortable abortable) |
Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.