Package org.apache.hadoop.hbase.ipc
Class FastPathRWQueueRpcExecutor
java.lang.Object
org.apache.hadoop.hbase.ipc.RpcExecutor
org.apache.hadoop.hbase.ipc.RWQueueRpcExecutor
org.apache.hadoop.hbase.ipc.FastPathRWQueueRpcExecutor
@LimitedPrivate({"Coprocesssor","Phoenix"})
@Evolving
public class FastPathRWQueueRpcExecutor
extends RWQueueRpcExecutor
RPC Executor that extends
RWQueueRpcExecutor with fast-path feature, used in
FastPathBalancedQueueRpcExecutor.-
Field Summary
FieldsModifier and TypeFieldDescriptionprivate final Deque<FastPathRpcHandler>private final Deque<FastPathRpcHandler>private final Deque<FastPathRpcHandler>Fields inherited from class org.apache.hadoop.hbase.ipc.RWQueueRpcExecutor
CALL_QUEUE_READ_SHARE_CONF_KEY, CALL_QUEUE_SCAN_SHARE_CONF_KEYFields inherited from class org.apache.hadoop.hbase.ipc.RpcExecutor
CALL_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 Summary
ConstructorsConstructorDescriptionFastPathRWQueueRpcExecutor(String name, int handlerCount, int maxQueueLength, PriorityFunction priority, org.apache.hadoop.conf.Configuration conf, Abortable abortable) -
Method Summary
Modifier and TypeMethodDescriptionbooleandispatch(CallRunner callTask) Add the request to the executor queueprotected RpcHandlergetHandler(String name, double handlerFailureThreshhold, int handlerCount, BlockingQueue<CallRunner> q, AtomicInteger activeHandlerCount, AtomicInteger failedHandlerCount, Abortable abortable) Override if providing alternate Handler implementation.Methods inherited from class org.apache.hadoop.hbase.ipc.RWQueueRpcExecutor
computeNumCallQueues, dispatchTo, getActiveHandlerCount, getActiveReadHandlerCount, getActiveScanHandlerCount, getActiveWriteHandlerCount, getNumScanQueues, getReadBalancer, getReadQueueLength, getReadShare, getScanBalancer, getScanQueueLength, getScanShare, getWriteBalancer, getWriteQueueLength, isWriteRequest, onConfigurationChange, shouldDispatchToScanQueue, startHandlersMethods inherited from class org.apache.hadoop.hbase.ipc.RpcExecutor
getBalancer, getCallQueueCountsSummary, getCallQueueHandlerFactor, getCallQueueSizeSummary, getName, getNumGeneralCallsDropped, getNumLifoModeSwitches, getQueueLength, getQueues, initializeQueues, isCodelQueueType, isDeadlineQueueType, isFifoQueueType, isPluggableQueueType, isPluggableQueueWithFastPath, resizeQueues, start, startHandlers, stop
-
Field Details
-
readHandlerStack
-
writeHandlerStack
-
scanHandlerStack
-
-
Constructor Details
-
FastPathRWQueueRpcExecutor
public FastPathRWQueueRpcExecutor(String name, int handlerCount, int maxQueueLength, PriorityFunction priority, org.apache.hadoop.conf.Configuration conf, Abortable abortable)
-
-
Method Details
-
getHandler
protected RpcHandler getHandler(String name, double handlerFailureThreshhold, int handlerCount, BlockingQueue<CallRunner> q, AtomicInteger activeHandlerCount, AtomicInteger failedHandlerCount, Abortable abortable) Description copied from class:RpcExecutorOverride if providing alternate Handler implementation.- Overrides:
getHandlerin classRpcExecutor
-
dispatch
Description copied from class:RpcExecutorAdd the request to the executor queue- Overrides:
dispatchin classRWQueueRpcExecutor
-