protected class RpcClientImpl.Connection
extends java.lang.Thread
| Modifier and Type | Field and Description |
|---|---|
protected java.util.concurrent.ConcurrentSkipListMap<java.lang.Integer,Call> |
calls |
protected org.apache.hadoop.hbase.ipc.RpcClientImpl.Connection.CallSender |
callSender |
protected java.io.DataInputStream |
in |
protected java.io.DataOutputStream |
out |
protected ConnectionId |
remoteId |
protected java.util.concurrent.atomic.AtomicBoolean |
shouldCloseConnection |
protected java.net.Socket |
socket |
| 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() |
java.net.InetSocketAddress |
getRemoteAddress() |
protected boolean |
markClosed(java.io.IOException e) |
protected void |
readResponse() |
void |
run() |
protected void |
setupConnection() |
protected void |
setupIOstreams() |
protected void |
tracedWriteRequest(Call call,
int priority,
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, yieldprotected ConnectionId remoteId
protected java.net.Socket socket
protected java.io.DataInputStream in
protected java.io.DataOutputStream out
protected final java.util.concurrent.ConcurrentSkipListMap<java.lang.Integer,Call> calls
protected final java.util.concurrent.atomic.AtomicBoolean shouldCloseConnection
protected final org.apache.hadoop.hbase.ipc.RpcClientImpl.Connection.CallSender callSender
protected void setupConnection()
throws java.io.IOException
java.io.IOExceptionprotected void closeConnection()
protected boolean waitForWork()
throws java.lang.InterruptedException
java.lang.InterruptedExceptionpublic java.net.InetSocketAddress getRemoteAddress()
public void run()
run in interface java.lang.Runnablerun in class java.lang.Threadprotected void setupIOstreams()
throws java.io.IOException
java.io.IOExceptionprotected void close()
protected void tracedWriteRequest(Call call, int priority, Span span) throws java.io.IOException
java.io.IOExceptionprotected void readResponse()
protected boolean markClosed(java.io.IOException e)
protected void cleanupCalls(boolean allCalls)
allCalls - true for all calls, false for only the calls in timeout