Package org.apache.hadoop.hbase.ipc
Class FastPathRpcHandler
java.lang.Object
java.lang.Thread
org.apache.hadoop.hbase.ipc.RpcHandler
org.apache.hadoop.hbase.ipc.FastPathRpcHandler
- All Implemented Interfaces:
- Runnable
- 
Nested Class SummaryNested classes/interfaces inherited from class java.lang.ThreadThread.State, Thread.UncaughtExceptionHandler
- 
Field SummaryFieldsModifier and TypeFieldDescription(package private) final Deque<FastPathRpcHandler>private CallRunnerprivate SemaphoreFields inherited from class org.apache.hadoop.hbase.ipc.RpcHandlerabortable, activeHandlerCount, failedHandlerCount, handlerCount, handlerFailureThreshhold, qFields inherited from class java.lang.ThreadMAX_PRIORITY, MIN_PRIORITY, NORM_PRIORITY
- 
Constructor SummaryConstructorsConstructorDescriptionFastPathRpcHandler(String name, double handlerFailureThreshhold, int handlerCount, BlockingQueue<CallRunner> q, AtomicInteger activeHandlerCount, AtomicInteger failedHandlerCount, Abortable abortable, Deque<FastPathRpcHandler> fastPathHandlerStack) 
- 
Method SummaryModifier and TypeMethodDescriptionprotected CallRunnerReturns ACallRunnern(package private) booleanMethods inherited from class org.apache.hadoop.hbase.ipc.RpcHandlerrun, stopRunningMethods inherited from class java.lang.ThreadactiveCount, checkAccess, clone, countStackFrames, currentThread, dumpStack, enumerate, getAllStackTraces, getContextClassLoader, getDefaultUncaughtExceptionHandler, getId, getName, getPriority, getStackTrace, getState, getThreadGroup, getUncaughtExceptionHandler, holdsLock, interrupt, interrupted, isAlive, isDaemon, isInterrupted, join, join, join, onSpinWait, resume, setContextClassLoader, setDaemon, setDefaultUncaughtExceptionHandler, setName, setPriority, setUncaughtExceptionHandler, sleep, sleep, start, stop, suspend, toString, yield
- 
Field Details- 
fastPathHandlerStack
- 
semaphore
- 
loadedCallRunner
 
- 
- 
Constructor Details- 
FastPathRpcHandlerFastPathRpcHandler(String name, double handlerFailureThreshhold, int handlerCount, BlockingQueue<CallRunner> q, AtomicInteger activeHandlerCount, AtomicInteger failedHandlerCount, Abortable abortable, Deque<FastPathRpcHandler> fastPathHandlerStack) 
 
- 
- 
Method Details- 
getCallRunnerDescription copied from class:RpcHandlerReturns ACallRunnern- Overrides:
- getCallRunnerin class- RpcHandler
- Throws:
- InterruptedException
 
- 
loadCallRunner- Parameters:
- cr- Task gotten via fastpath.
- Returns:
- True if we successfully loaded our task
 
 
-