public static interface RpcHeaderProtos.RpcRequestHeaderProtoOrBuilder
extends org.apache.hadoop.thirdparty.protobuf.MessageOrBuilder
Modifier and Type | Method and Description |
---|---|
RpcHeaderProtos.RPCCallerContextProto |
getCallerContext()
call context
|
RpcHeaderProtos.RPCCallerContextProtoOrBuilder |
getCallerContextOrBuilder()
call context
|
int |
getCallId()
a sequence number that is sent back in response
|
org.apache.hadoop.thirdparty.protobuf.ByteString |
getClientId()
Globally unique client ID
|
int |
getRetryCount()
clientId + callId uniquely identifies a request
retry count, 1 means this is the first retry
|
RpcHeaderProtos.RpcKindProto |
getRpcKind()
optional .hadoop.common.RpcKindProto rpcKind = 1; |
RpcHeaderProtos.RpcRequestHeaderProto.OperationProto |
getRpcOp()
optional .hadoop.common.RpcRequestHeaderProto.OperationProto rpcOp = 2; |
long |
getStateId()
The last seen Global State ID
|
RpcHeaderProtos.RPCTraceInfoProto |
getTraceInfo()
tracing info
|
RpcHeaderProtos.RPCTraceInfoProtoOrBuilder |
getTraceInfoOrBuilder()
tracing info
|
boolean |
hasCallerContext()
call context
|
boolean |
hasCallId()
a sequence number that is sent back in response
|
boolean |
hasClientId()
Globally unique client ID
|
boolean |
hasRetryCount()
clientId + callId uniquely identifies a request
retry count, 1 means this is the first retry
|
boolean |
hasRpcKind()
optional .hadoop.common.RpcKindProto rpcKind = 1; |
boolean |
hasRpcOp()
optional .hadoop.common.RpcRequestHeaderProto.OperationProto rpcOp = 2; |
boolean |
hasStateId()
The last seen Global State ID
|
boolean |
hasTraceInfo()
tracing info
|
findInitializationErrors, getAllFields, getDefaultInstanceForType, getDescriptorForType, getField, getInitializationErrorString, getOneofFieldDescriptor, getRepeatedField, getRepeatedFieldCount, getUnknownFields, hasField, hasOneof
boolean hasRpcKind()
optional .hadoop.common.RpcKindProto rpcKind = 1;
RpcHeaderProtos.RpcKindProto getRpcKind()
optional .hadoop.common.RpcKindProto rpcKind = 1;
boolean hasRpcOp()
optional .hadoop.common.RpcRequestHeaderProto.OperationProto rpcOp = 2;
RpcHeaderProtos.RpcRequestHeaderProto.OperationProto getRpcOp()
optional .hadoop.common.RpcRequestHeaderProto.OperationProto rpcOp = 2;
boolean hasCallId()
a sequence number that is sent back in response
required sint32 callId = 3;
int getCallId()
a sequence number that is sent back in response
required sint32 callId = 3;
boolean hasClientId()
Globally unique client ID
required bytes clientId = 4;
org.apache.hadoop.thirdparty.protobuf.ByteString getClientId()
Globally unique client ID
required bytes clientId = 4;
boolean hasRetryCount()
clientId + callId uniquely identifies a request retry count, 1 means this is the first retry
optional sint32 retryCount = 5 [default = -1];
int getRetryCount()
clientId + callId uniquely identifies a request retry count, 1 means this is the first retry
optional sint32 retryCount = 5 [default = -1];
boolean hasTraceInfo()
tracing info
optional .hadoop.common.RPCTraceInfoProto traceInfo = 6;
RpcHeaderProtos.RPCTraceInfoProto getTraceInfo()
tracing info
optional .hadoop.common.RPCTraceInfoProto traceInfo = 6;
RpcHeaderProtos.RPCTraceInfoProtoOrBuilder getTraceInfoOrBuilder()
tracing info
optional .hadoop.common.RPCTraceInfoProto traceInfo = 6;
boolean hasCallerContext()
call context
optional .hadoop.common.RPCCallerContextProto callerContext = 7;
RpcHeaderProtos.RPCCallerContextProto getCallerContext()
call context
optional .hadoop.common.RPCCallerContextProto callerContext = 7;
RpcHeaderProtos.RPCCallerContextProtoOrBuilder getCallerContextOrBuilder()
call context
optional .hadoop.common.RPCCallerContextProto callerContext = 7;
boolean hasStateId()
The last seen Global State ID
optional int64 stateId = 8;
long getStateId()
The last seen Global State ID
optional int64 stateId = 8;
Copyright © 2008–2020 Apache Software Foundation. All rights reserved.