Package | Description |
---|---|
org.apache.hadoop.hbase.ipc |
Tools to help define network clients and servers.
|
org.apache.hadoop.hbase.namequeues | |
org.apache.hadoop.hbase.regionserver | |
org.apache.hadoop.hbase.server.trace |
Modifier and Type | Class and Description |
---|---|
(package private) class |
NettyServerCall
Datastructure that holds all necessary to a method invocation and then afterward, carries the
result.
|
class |
ServerCall<T extends ServerRpcConnection>
Datastructure that holds all necessary to a method invocation and then afterward, carries the
result.
|
(package private) class |
SimpleServerCall
Deprecated.
|
Modifier and Type | Field and Description |
---|---|
private RpcCall |
CallRunner.call |
Modifier and Type | Field and Description |
---|---|
protected static ThreadLocal<RpcCall> |
RpcServer.CurCall
This is set to Call object before Handler invokes an RPC and ybdie after the call returns.
|
Modifier and Type | Method and Description |
---|---|
RpcCall |
CallRunner.getRpcCall() |
Modifier and Type | Method and Description |
---|---|
static Optional<RpcCall> |
RpcServer.getCurrentCall()
Needed for features such as delayed calls.
|
static Optional<RpcCall> |
RpcServer.unsetCurrentCall()
Used by
RegionProcedureStore . |
Modifier and Type | Method and Description |
---|---|
Pair<org.apache.hbase.thirdparty.com.google.protobuf.Message,CellScanner> |
RpcServerInterface.call(RpcCall call,
MonitoredRPCHandler status) |
Pair<org.apache.hbase.thirdparty.com.google.protobuf.Message,CellScanner> |
RpcServer.call(RpcCall call,
MonitoredRPCHandler status)
This is a server side method, which is invoked over RPC.
|
static void |
RpcServer.setCurrentCall(RpcCall rpcCall)
Used by
RegionProcedureStore . |
Constructor and Description |
---|
CallRunner(RpcServerInterface rpcServer,
RpcCall call)
On construction, adds the size of this call to the running count of outstanding call sizes.
|
Modifier and Type | Field and Description |
---|---|
private RpcCall |
RpcLogDetails.rpcCall |
Modifier and Type | Method and Description |
---|---|
RpcCall |
RpcLogDetails.getRpcCall() |
Constructor and Description |
---|
RpcLogDetails(RpcCall rpcCall,
org.apache.hbase.thirdparty.com.google.protobuf.Message param,
String clientAddress,
long responseSize,
String className,
boolean isSlowLog,
boolean isLargeLog) |
Modifier and Type | Method and Description |
---|---|
private long |
RSRpcServices.getRemainingRpcTimeout(RpcCall call,
HBaseRpcController controller,
long now) |
(package private) long |
RSRpcServices.getTimeLimit(RpcCall rpcCall,
HBaseRpcController controller,
boolean allowHeartbeatMessages) |
private void |
RSRpcServices.scan(HBaseRpcController controller,
org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ScanRequest request,
RSRpcServices.RegionScannerHolder rsh,
long maxQuotaResultSize,
int maxResults,
int limitOfRows,
List<Result> results,
org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ScanResponse.Builder builder,
org.apache.commons.lang3.mutable.MutableObject<Object> lastBlock,
RpcCall rpcCall) |
Modifier and Type | Method and Description |
---|---|
private void |
RegionScannerImpl.checkClientDisconnect(Optional<RpcCall> rpcCall) |
Constructor and Description |
---|
IpcServerSpanBuilder(RpcCall rpcCall) |
Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.