@InterfaceAudience.LimitedPrivate(value={"Coprocesssor","Phoenix"})
@InterfaceStability.Evolving
public class FastPathRWQueueRpcExecutor
extends RWQueueRpcExecutor
RWQueueRpcExecutor with fast-path feature, used in
FastPathBalancedQueueRpcExecutor.| Modifier and Type | Field and Description |
|---|---|
private Deque<FastPathRpcHandler> |
readHandlerStack |
private Deque<FastPathRpcHandler> |
scanHandlerStack |
private Deque<FastPathRpcHandler> |
writeHandlerStack |
CALL_QUEUE_READ_SHARE_CONF_KEY, CALL_QUEUE_SCAN_SHARE_CONF_KEYCALL_QUEUE_CODEL_DEFAULT_INTERVAL, CALL_QUEUE_CODEL_DEFAULT_LIFO_THRESHOLD, CALL_QUEUE_CODEL_DEFAULT_TARGET_DELAY, CALL_QUEUE_CODEL_INTERVAL, CALL_QUEUE_CODEL_LIFO_THRESHOLD, CALL_QUEUE_CODEL_TARGET_DELAY, CALL_QUEUE_HANDLER_FACTOR_CONF_KEY, CALL_QUEUE_QUEUE_BALANCER_CLASS, CALL_QUEUE_QUEUE_BALANCER_CLASS_DEFAULT, CALL_QUEUE_TYPE_CODEL_CONF_VALUE, CALL_QUEUE_TYPE_CONF_DEFAULT, CALL_QUEUE_TYPE_CONF_KEY, CALL_QUEUE_TYPE_DEADLINE_CONF_VALUE, CALL_QUEUE_TYPE_FIFO_CONF_VALUE, CALL_QUEUE_TYPE_PLUGGABLE_CONF_VALUE, currentQueueLimit, DEFAULT_CALL_QUEUE_SIZE_HARD_LIMIT, numCallQueues, PLUGGABLE_CALL_QUEUE_CLASS_NAME, PLUGGABLE_CALL_QUEUE_WITH_FAST_PATH_ENABLED, QUEUE_MAX_CALL_DELAY_CONF_KEY, queues| Constructor and Description |
|---|
FastPathRWQueueRpcExecutor(String name,
int handlerCount,
int maxQueueLength,
PriorityFunction priority,
org.apache.hadoop.conf.Configuration conf,
Abortable abortable) |
| Modifier and Type | Method and Description |
|---|---|
boolean |
dispatch(CallRunner callTask)
Add the request to the executor queue
|
protected RpcHandler |
getHandler(String name,
double handlerFailureThreshhold,
int handlerCount,
BlockingQueue<CallRunner> q,
AtomicInteger activeHandlerCount,
AtomicInteger failedHandlerCount,
Abortable abortable)
Override if providing alternate Handler implementation.
|
computeNumCallQueues, dispatchTo, getActiveHandlerCount, getActiveReadHandlerCount, getActiveScanHandlerCount, getActiveWriteHandlerCount, getReadBalancer, getReadQueueLength, getReadShare, getScanBalancer, getScanQueueLength, getScanShare, getWriteBalancer, getWriteQueueLength, isWriteRequest, onConfigurationChange, shouldDispatchToScanQueue, startHandlersgetBalancer, getCallQueueCountsSummary, getCallQueueSizeSummary, getName, getNumGeneralCallsDropped, getNumLifoModeSwitches, getQueueLength, getQueues, initializeQueues, isCodelQueueType, isDeadlineQueueType, isFifoQueueType, isPluggableQueueType, isPluggableQueueWithFastPath, resizeQueues, start, startHandlers, stopprivate final Deque<FastPathRpcHandler> readHandlerStack
private final Deque<FastPathRpcHandler> writeHandlerStack
private final Deque<FastPathRpcHandler> scanHandlerStack
public FastPathRWQueueRpcExecutor(String name, int handlerCount, int maxQueueLength, PriorityFunction priority, org.apache.hadoop.conf.Configuration conf, Abortable abortable)
protected RpcHandler getHandler(String name, double handlerFailureThreshhold, int handlerCount, BlockingQueue<CallRunner> q, AtomicInteger activeHandlerCount, AtomicInteger failedHandlerCount, Abortable abortable)
RpcExecutorgetHandler in class RpcExecutorpublic boolean dispatch(CallRunner callTask)
RpcExecutordispatch in class RWQueueRpcExecutorCopyright © 2007–2020 The Apache Software Foundation. All rights reserved.