@InterfaceAudience.Private public class FastPathBalancedQueueRpcExecutor extends BalancedQueueRpcExecutor
RpcExecutor.Handler, RpcExecutor.QueueBalancer
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_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, currentQueueLimit, DEFAULT_CALL_QUEUE_SIZE_HARD_LIMIT, numCallQueues, QUEUE_MAX_CALL_DELAY_CONF_KEY, queues
Constructor and Description |
---|
FastPathBalancedQueueRpcExecutor(String name,
int handlerCount,
int maxQueueLength,
PriorityFunction priority,
org.apache.hadoop.conf.Configuration conf,
Abortable abortable) |
FastPathBalancedQueueRpcExecutor(String name,
int handlerCount,
String callQueueType,
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 RpcExecutor.Handler |
getHandler(String name,
double handlerFailureThreshhold,
BlockingQueue<CallRunner> q,
AtomicInteger activeHandlerCount)
Override if providing alternate Handler implementation.
|
computeNumCallQueues, getActiveHandlerCount, getActiveReadHandlerCount, getActiveScanHandlerCount, getActiveWriteHandlerCount, getBalancer, getCallQueueCountsSummary, getCallQueueSizeSummary, getName, getNumGeneralCallsDropped, getNumLifoModeSwitches, getQueueLength, getQueues, getReadQueueLength, getScanQueueLength, getWriteQueueLength, initializeQueues, isCodelQueueType, isDeadlineQueueType, isFifoQueueType, onConfigurationChange, resizeQueues, start, startHandlers, startHandlers, stop
public FastPathBalancedQueueRpcExecutor(String name, int handlerCount, int maxQueueLength, PriorityFunction priority, org.apache.hadoop.conf.Configuration conf, Abortable abortable)
public FastPathBalancedQueueRpcExecutor(String name, int handlerCount, String callQueueType, int maxQueueLength, PriorityFunction priority, org.apache.hadoop.conf.Configuration conf, Abortable abortable)
protected RpcExecutor.Handler getHandler(String name, double handlerFailureThreshhold, BlockingQueue<CallRunner> q, AtomicInteger activeHandlerCount)
RpcExecutor
getHandler
in class RpcExecutor
public boolean dispatch(CallRunner callTask) throws InterruptedException
RpcExecutor
dispatch
in class BalancedQueueRpcExecutor
InterruptedException
Copyright © 2007–2019 Cloudera. All rights reserved.