protected class RpcClientImpl.Connection extends Thread
Thread.State, Thread.UncaughtExceptionHandler
Modifier and Type | Field and Description |
---|---|
protected ConcurrentSkipListMap<Integer,Call> |
calls |
protected org.apache.hadoop.hbase.ipc.RpcClientImpl.Connection.CallSender |
callSender |
protected DataInputStream |
in |
protected DataOutputStream |
out |
protected ConnectionId |
remoteId |
protected AtomicBoolean |
shouldCloseConnection |
protected Socket |
socket |
MAX_PRIORITY, MIN_PRIORITY, NORM_PRIORITY
Modifier and Type | Method and Description |
---|---|
protected void |
cleanupCalls(boolean allCalls)
Cleanup the calls older than a given timeout, in milli seconds.
|
protected void |
close()
Close the connection.
|
protected void |
closeConnection() |
InetSocketAddress |
getRemoteAddress() |
protected boolean |
markClosed(IOException e) |
protected void |
readResponse() |
void |
run() |
protected void |
setupConnection() |
protected void |
setupIOstreams() |
protected void |
tracedWriteRequest(Call call,
int priority,
org.apache.htrace.Span span) |
protected boolean |
waitForWork() |
activeCount, checkAccess, clone, countStackFrames, currentThread, destroy, dumpStack, enumerate, getAllStackTraces, getContextClassLoader, getDefaultUncaughtExceptionHandler, getId, getName, getPriority, getStackTrace, getState, getThreadGroup, getUncaughtExceptionHandler, holdsLock, interrupt, interrupted, isAlive, isDaemon, isInterrupted, join, join, join, resume, setContextClassLoader, setDaemon, setDefaultUncaughtExceptionHandler, setName, setPriority, setUncaughtExceptionHandler, sleep, sleep, start, stop, stop, suspend, toString, yield
protected ConnectionId remoteId
protected Socket socket
protected DataInputStream in
protected DataOutputStream out
protected final ConcurrentSkipListMap<Integer,Call> calls
protected final AtomicBoolean shouldCloseConnection
protected final org.apache.hadoop.hbase.ipc.RpcClientImpl.Connection.CallSender callSender
protected void setupConnection() throws IOException
IOException
protected void closeConnection()
protected boolean waitForWork() throws InterruptedException
InterruptedException
public InetSocketAddress getRemoteAddress()
protected void setupIOstreams() throws IOException
IOException
protected void close()
protected void tracedWriteRequest(Call call, int priority, org.apache.htrace.Span span) throws IOException
IOException
protected void readResponse()
protected boolean markClosed(IOException e)
protected void cleanupCalls(boolean allCalls)
allCalls
- true for all calls, false for only the calls in timeoutCopyright © 2007-2016 The Apache Software Foundation. All Rights Reserved.