@InterfaceAudience.Private @InterfaceStability.Evolving public class MasterFifoRpcScheduler extends FifoRpcScheduler
RpcScheduler.Context
Modifier and Type | Field and Description |
---|---|
private static org.slf4j.Logger |
LOG |
static String |
MASTER_SERVER_REPORT_HANDLER_COUNT
Set RSReport requests handlers count when masters use MasterFifoRpcScheduler.
|
private static String |
REGION_SERVER_REPORT |
private ThreadPoolExecutor |
rsReportExecutor |
private int |
rsReportHandlerCount |
private AtomicInteger |
rsReportQueueSize |
private int |
rsRsreportMaxQueueLength |
executor, handlerCount, maxQueueLength, queueSize
IPC_SERVER_MAX_CALLQUEUE_LENGTH, IPC_SERVER_PRIORITY_MAX_CALLQUEUE_LENGTH, IPC_SERVER_REPLICATION_MAX_CALLQUEUE_LENGTH
Constructor and Description |
---|
MasterFifoRpcScheduler(org.apache.hadoop.conf.Configuration conf,
int callHandlerCount,
int rsReportHandlerCount) |
Modifier and Type | Method and Description |
---|---|
boolean |
dispatch(CallRunner task)
Dispatches an RPC request asynchronously.
|
int |
getActiveRpcHandlerCount()
Retrieves the total number of active handler.
|
CallQueueInfo |
getCallQueueInfo()
Get call queue information
|
int |
getGeneralQueueLength()
Retrieves length of the general queue for metrics.
|
void |
start()
Prepares for request serving.
|
void |
stop()
Stops serving new requests.
|
executeRpcCall, getActiveGeneralRpcHandlerCount, getActiveMetaPriorityRpcHandlerCount, getActivePriorityRpcHandlerCount, getActiveReadRpcHandlerCount, getActiveReplicationRpcHandlerCount, getActiveScanRpcHandlerCount, getActiveWriteRpcHandlerCount, getCallMethod, getMetaPriorityQueueLength, getNumGeneralCallsDropped, getNumLifoModeSwitches, getPriorityQueueLength, getReadQueueLength, getReplicationQueueLength, getScanQueueLength, getWriteQueueLength, init, updateMethodCountAndSizeByQueue
private static final org.slf4j.Logger LOG
public static final String MASTER_SERVER_REPORT_HANDLER_COUNT
private static final String REGION_SERVER_REPORT
private final int rsReportHandlerCount
private final int rsRsreportMaxQueueLength
private final AtomicInteger rsReportQueueSize
private ThreadPoolExecutor rsReportExecutor
public MasterFifoRpcScheduler(org.apache.hadoop.conf.Configuration conf, int callHandlerCount, int rsReportHandlerCount)
public void start()
RpcScheduler
start
in class FifoRpcScheduler
public void stop()
RpcScheduler
stop
in class FifoRpcScheduler
public boolean dispatch(CallRunner task)
RpcScheduler
dispatch
in class FifoRpcScheduler
task
- the request to be dispatchedpublic int getGeneralQueueLength()
RpcScheduler
getGeneralQueueLength
in class FifoRpcScheduler
public int getActiveRpcHandlerCount()
RpcScheduler
getActiveRpcHandlerCount
in class FifoRpcScheduler
public CallQueueInfo getCallQueueInfo()
RpcScheduler
getCallQueueInfo
in class FifoRpcScheduler
Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.