@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 org.apache.hadoop.hbase.shaded.protobuf.generated.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() |
org.apache.hadoop.hbase.shaded.protobuf.generated.HBaseProtos.VersionInfo |
getClientVersionInfo() |
long |
getDeadline()
Return the deadline of this call.
|
org.apache.hadoop.hbase.shaded.protobuf.generated.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, waitsendResponseIfReadygetRequestUserNameprotected 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 org.apache.hadoop.hbase.shaded.protobuf.generated.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()
RpcCallpublic void retainByWAL()
public void releaseByWAL()
public org.apache.hadoop.hbase.shaded.protobuf.generated.RPCProtos.RequestHeader getHeader()
public int getPriority()
getPriority in interface RpcCallpublic String toShortString()
toShortString in interface RpcCallpublic void setResponse(org.apache.hbase.thirdparty.com.google.protobuf.Message m,
CellScanner cells,
Throwable t,
String errorMsg)
RpcCallsetResponse in interface RpcCallm - 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
IOExceptionpublic long disconnectSince()
RpcCallContextdisconnectSince in interface RpcCallContextpublic boolean isClientCellBlockSupported()
RpcCallContextisClientCellBlockSupported in interface RpcCallContextpublic long getResponseCellSize()
RpcCallContextgetResponseCellSize in interface RpcCallContextpublic void incrementResponseCellSize(long cellSize)
RpcCallContextincrementResponseCellSize in interface RpcCallContextpublic long getResponseBlockSize()
getResponseBlockSize in interface RpcCallContextpublic void incrementResponseBlockSize(long blockSize)
incrementResponseBlockSize in interface RpcCallContextpublic long getResponseExceptionSize()
getResponseExceptionSize in interface RpcCallContextpublic void incrementResponseExceptionSize(long exSize)
incrementResponseExceptionSize in interface RpcCallContextpublic long getSize()
RpcCallpublic long getDeadline()
RpcCallgetDeadline in interface RpcCallpublic Optional<User> getRequestUser()
RpcCallContextgetRequestUser in interface RpcCallContextpublic InetAddress getRemoteAddress()
getRemoteAddress in interface RpcCallContextpublic org.apache.hadoop.hbase.shaded.protobuf.generated.HBaseProtos.VersionInfo getClientVersionInfo()
getClientVersionInfo in interface RpcCallContextpublic void setCallBack(RpcCallback callback)
RpcCallContextsetCallBack in interface RpcCallContextpublic boolean isRetryImmediatelySupported()
isRetryImmediatelySupported in interface RpcCallContextpublic org.apache.hbase.thirdparty.com.google.protobuf.BlockingService getService()
getService in interface RpcCallpublic 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 RpcCallpublic long getReceiveTime()
getReceiveTime in interface RpcCallpublic long getStartTime()
getStartTime in interface RpcCallpublic void setStartTime(long t)
RpcCallsetStartTime in interface RpcCallpublic int getTimeout()
getTimeout in interface RpcCallpublic int getRemotePort()
getRemotePort in interface RpcCallpublic org.apache.hadoop.hbase.ipc.BufferChain getResponse()
Copyright © 2007–2019 The Apache Software Foundation. All rights reserved.