Package | Description |
---|---|
org.apache.hadoop.hbase.ipc |
Tools to help define network clients and servers.
|
Modifier and Type | Field and Description |
---|---|
protected List<BlockingQueue<CallRunner>> |
RpcExecutor.queues |
Modifier and Type | Method and Description |
---|---|
CallRunner |
AdaptiveLifoCoDelCallQueue.element() |
protected CallRunner |
RpcExecutor.Handler.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 |
---|---|
protected List<BlockingQueue<CallRunner>> |
RpcExecutor.getQueues()
Returns the list of request queues
|
Iterator<CallRunner> |
AdaptiveLifoCoDelCallQueue.iterator() |
Modifier and Type | Method and Description |
---|---|
boolean |
AdaptiveLifoCoDelCallQueue.add(CallRunner callRunner) |
boolean |
FifoRpcScheduler.dispatch(CallRunner task) |
boolean |
MasterFifoRpcScheduler.dispatch(CallRunner task) |
boolean |
RWQueueRpcExecutor.dispatch(CallRunner callTask) |
boolean |
FastPathBalancedQueueRpcExecutor.dispatch(CallRunner callTask) |
boolean |
SimpleRpcScheduler.dispatch(CallRunner callTask) |
abstract boolean |
RpcExecutor.dispatch(CallRunner callTask)
Add the request to the executor queue
|
boolean |
BalancedQueueRpcExecutor.dispatch(CallRunner callTask) |
abstract boolean |
RpcScheduler.dispatch(CallRunner task)
Dispatches an RPC request asynchronously.
|
protected boolean |
FifoRpcScheduler.executeRpcCall(ThreadPoolExecutor executor,
AtomicInteger queueSize,
CallRunner task) |
protected String |
FifoRpcScheduler.getCallMethod(CallRunner task) |
boolean |
AdaptiveLifoCoDelCallQueue.offer(CallRunner callRunner) |
boolean |
AdaptiveLifoCoDelCallQueue.offer(CallRunner callRunner,
long timeout,
TimeUnit unit) |
void |
AdaptiveLifoCoDelCallQueue.put(CallRunner callRunner) |
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) |
protected RpcExecutor.Handler |
FastPathBalancedQueueRpcExecutor.getHandler(String name,
double handlerFailureThreshhold,
BlockingQueue<CallRunner> q,
AtomicInteger activeHandlerCount) |
protected RpcExecutor.Handler |
RpcExecutor.getHandler(String name,
double handlerFailureThreshhold,
BlockingQueue<CallRunner> q,
AtomicInteger activeHandlerCount)
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.
|
Copyright © 2007–2019 Cloudera. All rights reserved.