| Package | Description | 
|---|---|
| org.apache.hadoop.ipc | Tools to help define network clients and servers. | 
| org.apache.hadoop.util | Common utilities. | 
| Modifier and Type | Method and Description | 
|---|---|
| static RPC.RpcKind | RPC.RpcKind. valueOf(String name) | 
| static RPC.RpcKind[] | RPC.RpcKind. values() | 
| Modifier and Type | Method and Description | 
|---|---|
| RPC.Server | RPC.Server. addProtocol(RPC.RpcKind rpcKind,
           Class<?> protocolClass,
           Object protocolImpl)Add a protocol to the existing server. | 
| abstract Writable | Server. call(RPC.RpcKind rpcKind,
    String protocol,
    Writable param,
    long receiveTime)Called for each call. | 
| Writable | RPC.Server. call(RPC.RpcKind rpcKind,
    String protocol,
    Writable rpcRequest,
    long receiveTime) | 
| Writable | Client. call(RPC.RpcKind rpcKind,
    Writable rpcRequest,
    org.apache.hadoop.ipc.Client.ConnectionId remoteId,
    AtomicBoolean fallbackToSimpleAuth)Make a call, passing  rpcRequest, to the IPC server defined byremoteId, returning the rpc respond. | 
| static org.apache.hadoop.ipc.RPC.RpcInvoker | Server. getRpcInvoker(RPC.RpcKind rpcKind) | 
| static boolean | RpcClientUtil. isMethodSupported(Object rpcProxy,
                 Class<?> protocol,
                 RPC.RpcKind rpcKind,
                 long version,
                 String methodName)Returns whether the given method is supported or not. | 
| static void | Server. registerProtocolEngine(RPC.RpcKind rpcKind,
                      Class<? extends Writable> rpcRequestWrapperClass,
                      org.apache.hadoop.ipc.RPC.RpcInvoker rpcInvoker)Register a RPC kind and the class to deserialize the rpc request. | 
| Constructor and Description | 
|---|
| Server.Call(int id,
           int retryCount,
           Void ignore1,
           Void ignore2,
           RPC.RpcKind kind,
           byte[] clientId) | 
| Modifier and Type | Method and Description | 
|---|---|
| static RPC.RpcKind | ProtoUtil. convert(RpcHeaderProtos.RpcKindProto kind) | 
| Modifier and Type | Method and Description | 
|---|---|
| static RpcHeaderProtos.RpcRequestHeaderProto | ProtoUtil. makeRpcRequestHeader(RPC.RpcKind rpcKind,
                    RpcHeaderProtos.RpcRequestHeaderProto.OperationProto operation,
                    int callId,
                    int retryCount,
                    byte[] uuid) | 
Copyright © 2017 Apache Software Foundation. All Rights Reserved.