@InterfaceAudience.Private public abstract class ServerCall<T extends org.apache.hadoop.hbase.ipc.ServerRpcConnection> extends Object implements RpcCall
Modifier and Type | Field and Description |
---|---|
protected org.apache.hadoop.hbase.ipc.CellBlockBuilder |
cellBlockBuilder |
protected ByteBufferListOutputStream |
cellBlockStream |
protected CellScanner |
cellScanner |
protected T |
connection |
protected long |
deadline |
protected RPCProtos.RequestHeader |
header |
protected int |
id |
protected boolean |
isError |
protected org.apache.hbase.thirdparty.com.google.protobuf.Descriptors.MethodDescriptor |
md |
protected org.apache.hbase.thirdparty.com.google.protobuf.Message |
param |
protected long |
receiveTime |
protected InetAddress |
remoteAddress |
protected RpcServer.CallCleanup |
reqCleanup |
protected ByteBufferPool |
reservoir |
protected org.apache.hadoop.hbase.ipc.BufferChain |
response
Chain of buffers to send as response.
|
protected RpcCallback |
rpcCallback |
protected org.apache.hbase.thirdparty.com.google.protobuf.BlockingService |
service |
protected long |
size |
protected long |
startTime |
protected int |
timeout |
protected User |
user |
Modifier and Type | Method and Description |
---|---|
void |
cleanup()
Do the necessary cleanup after the call if needed.
|
long |
disconnectSince()
Check if the caller who made this IPC call has disconnected.
|
void |
done()
Call is done.
|
CellScanner |
getCellScanner() |
HBaseProtos.VersionInfo |
getClientVersionInfo() |
long |
getDeadline()
Return the deadline of this call.
|
RPCProtos.RequestHeader |
getHeader() |
org.apache.hbase.thirdparty.com.google.protobuf.Descriptors.MethodDescriptor |
getMethod() |
org.apache.hbase.thirdparty.com.google.protobuf.Message |
getParam() |
int |
getPriority() |
long |
getReceiveTime() |
InetAddress |
getRemoteAddress() |
int |
getRemotePort() |
Optional<User> |
getRequestUser()
Returns the user credentials associated with the current RPC request or not present if no
credentials were provided.
|
org.apache.hadoop.hbase.ipc.BufferChain |
getResponse() |
long |
getResponseBlockSize() |
long |
getResponseCellSize()
The size of response cells that have been accumulated so far.
|
long |
getResponseExceptionSize() |
org.apache.hbase.thirdparty.com.google.protobuf.BlockingService |
getService() |
long |
getSize()
Used to calculate the request call queue size.
|
long |
getStartTime() |
int |
getTimeout() |
void |
incrementResponseBlockSize(long blockSize) |
void |
incrementResponseCellSize(long cellSize)
Add on the given amount to the retained cell size.
|
void |
incrementResponseExceptionSize(long exSize) |
boolean |
isClientCellBlockSupported()
If the client connected and specified a codec to use, then we will use this codec making
cellblocks to return.
|
boolean |
isRetryImmediatelySupported() |
void |
releaseByWAL() |
void |
retainByWAL() |
void |
setCallBack(RpcCallback callback)
Sets a callback which has to be executed at the end of this RPC call.
|
void |
setResponse(org.apache.hbase.thirdparty.com.google.protobuf.Message m,
CellScanner cells,
Throwable t,
String errorMsg)
Set the response resulting from this RPC call.
|
void |
setStartTime(long t)
Set the time when the call starts to be executed.
|
String |
toShortString() |
String |
toString() |
protected org.apache.hadoop.hbase.ipc.BufferChain |
wrapWithSasl(org.apache.hadoop.hbase.ipc.BufferChain bc) |
clone, equals, finalize, getClass, hashCode, notify, notifyAll, wait, wait, wait
sendResponseIfReady
getRequestUserName
protected final int id
protected final org.apache.hbase.thirdparty.com.google.protobuf.BlockingService service
protected final org.apache.hbase.thirdparty.com.google.protobuf.Descriptors.MethodDescriptor md
protected final RPCProtos.RequestHeader header
protected org.apache.hbase.thirdparty.com.google.protobuf.Message param
protected final CellScanner cellScanner
protected final T extends org.apache.hadoop.hbase.ipc.ServerRpcConnection connection
protected final long receiveTime
protected final int timeout
protected long startTime
protected final long deadline
protected final ByteBufferPool reservoir
protected final org.apache.hadoop.hbase.ipc.CellBlockBuilder cellBlockBuilder
protected org.apache.hadoop.hbase.ipc.BufferChain response
protected final long size
protected boolean isError
protected ByteBufferListOutputStream cellBlockStream
protected RpcServer.CallCleanup reqCleanup
protected final User user
protected final InetAddress remoteAddress
protected RpcCallback rpcCallback
public void done()
public void cleanup()
RpcCall
public void retainByWAL()
public void releaseByWAL()
public RPCProtos.RequestHeader getHeader()
public int getPriority()
getPriority
in interface RpcCall
public String toShortString()
toShortString
in interface RpcCall
public void setResponse(org.apache.hbase.thirdparty.com.google.protobuf.Message m, CellScanner cells, Throwable t, String errorMsg)
RpcCall
setResponse
in interface RpcCall
m
- The result message as response.cells
- The CellScanner that possibly carries the payload.t
- The error Throwable resulting from the call.errorMsg
- Extra error message.protected org.apache.hadoop.hbase.ipc.BufferChain wrapWithSasl(org.apache.hadoop.hbase.ipc.BufferChain bc) throws IOException
IOException
public long disconnectSince()
RpcCallContext
disconnectSince
in interface RpcCallContext
public boolean isClientCellBlockSupported()
RpcCallContext
isClientCellBlockSupported
in interface RpcCallContext
public long getResponseCellSize()
RpcCallContext
getResponseCellSize
in interface RpcCallContext
public void incrementResponseCellSize(long cellSize)
RpcCallContext
incrementResponseCellSize
in interface RpcCallContext
public long getResponseBlockSize()
getResponseBlockSize
in interface RpcCallContext
public void incrementResponseBlockSize(long blockSize)
incrementResponseBlockSize
in interface RpcCallContext
public long getResponseExceptionSize()
getResponseExceptionSize
in interface RpcCallContext
public void incrementResponseExceptionSize(long exSize)
incrementResponseExceptionSize
in interface RpcCallContext
public long getSize()
RpcCall
public long getDeadline()
RpcCall
getDeadline
in interface RpcCall
public Optional<User> getRequestUser()
RpcCallContext
getRequestUser
in interface RpcCallContext
public InetAddress getRemoteAddress()
getRemoteAddress
in interface RpcCallContext
public HBaseProtos.VersionInfo getClientVersionInfo()
getClientVersionInfo
in interface RpcCallContext
public void setCallBack(RpcCallback callback)
RpcCallContext
setCallBack
in interface RpcCallContext
public boolean isRetryImmediatelySupported()
isRetryImmediatelySupported
in interface RpcCallContext
public org.apache.hbase.thirdparty.com.google.protobuf.BlockingService getService()
getService
in interface RpcCall
public org.apache.hbase.thirdparty.com.google.protobuf.Descriptors.MethodDescriptor getMethod()
public org.apache.hbase.thirdparty.com.google.protobuf.Message getParam()
public CellScanner getCellScanner()
getCellScanner
in interface RpcCall
public long getReceiveTime()
getReceiveTime
in interface RpcCall
public long getStartTime()
getStartTime
in interface RpcCall
public void setStartTime(long t)
RpcCall
setStartTime
in interface RpcCall
public int getTimeout()
getTimeout
in interface RpcCall
public int getRemotePort()
getRemotePort
in interface RpcCall
public org.apache.hadoop.hbase.ipc.BufferChain getResponse()
Copyright © 2007–2019 Cloudera. All rights reserved.