See: Description
| Interface | Description |
|---|---|
| Delayable |
A call whose response can be delayed by the server.
|
| HBaseRPCErrorHandler |
An interface for calling out of RPC for error conditions.
|
| MetricsHBaseServerSource | |
| MetricsHBaseServerWrapper | |
| PriorityFunction |
Function to figure priority of incoming request.
|
| RpcCallContext | |
| RpcClient |
Interface for RpcClient implementations so ConnectionManager can handle it.
|
| RpcServerInterface |
| Class | Description |
|---|---|
| AbstractRpcClient |
Provides the basics for a RpcClient implementation like configuration and Logging.
|
| AbstractRpcClient.BlockingRpcChannelImplementation |
Blocking rpc channel that goes via hbase rpc.
|
| AsyncCall |
Represents an Async Hbase call and its response.
|
| AsyncRpcChannel |
Netty RPC channel
|
| AsyncRpcClient |
Netty client for the requests and responses
|
| AsyncRpcClient.RpcChannelImplementation |
Blocking rpc channel that goes via hbase rpc.
|
| AsyncServerResponseHandler |
Handles Hbase responses
|
| BalancedQueueRpcExecutor |
An
RpcExecutor that will balance requests evenly across all its queues, but still remains
efficient with a single queue via an inlinable queue balancing mechanism. |
| BlockingRpcCallback<R> |
Simple
RpcCallback implementation providing a
Future-like BlockingRpcCallback.get() method, which
will block util the instance's BlockingRpcCallback.run(Object) method has been called. |
| Call |
A call waiting for a value.
|
| CallRunner |
The request processing logic, which is usually executed in thread pools provided by an
RpcScheduler. |
| ConnectionId |
This class holds the address and the user ticket, etc.
|
| CoprocessorRpcChannel |
Base class which provides clients with an RPC connection to
call coprocessor endpoint
Services. |
| DelegatingPayloadCarryingRpcController |
Simple delegating controller for use with the
RpcControllerFactory to help override
standard behavior of a PayloadCarryingRpcController. |
| FailedServers |
A class to manage a list of servers that failed recently.
|
| FifoRpcScheduler |
A very simple
RpcScheduler} that serves incoming requests in order. |
| IPCUtil |
Utility to help ipc'ing.
|
| MasterCoprocessorRpcChannel |
Provides clients with an RPC connection to call coprocessor endpoint
Services
against the active master. |
| MetricsHBaseServer | |
| MetricsHBaseServerSourceFactory | |
| MetricsHBaseServerSourceFactoryImpl | |
| MetricsHBaseServerSourceImpl | |
| MetricsHBaseServerWrapperImpl | |
| PayloadCarryingRpcController |
Optionally carries Cells across the proxy/service interface down into ipc.
|
| RegionCoprocessorRpcChannel |
Provides clients with an RPC connection to call coprocessor endpoint
Services
against a given table region. |
| RegionServerCoprocessorRpcChannel |
Provides clients with an RPC connection to call coprocessor endpoint
Services against a given region server. |
| RpcClientFactory |
Factory to create a
RpcClient |
| RpcClientImpl |
Does RPC against a cluster.
|
| RpcControllerFactory |
Factory to create a
PayloadCarryingRpcController |
| RpcExecutor | |
| RpcExecutor.QueueBalancer | |
| RpcScheduler |
An interface for RPC request scheduling algorithm.
|
| RpcScheduler.Context |
Exposes runtime information of a
RpcServer that a RpcScheduler may need. |
| RpcServer |
An RPC server that hosts protobuf described Services.
|
| RpcServer.BlockingServiceAndInterface |
Datastructure for passing a
BlockingService and its associated class of
protobuf service interface. |
| RWQueueRpcExecutor |
RPC Executor that uses different queues for reads and writes.
|
| ServerRpcController |
Used for server-side protobuf RPC service invocations.
|
| SimpleRpcScheduler |
A scheduler that maintains isolated handler pools for general,
high-priority, and replication requests.
|
| TimeLimitedRpcController |
| Exception | Description |
|---|---|
| BadAuthException | |
| CallerDisconnectedException |
Exception indicating that the remote host making this IPC lost its
IPC connection.
|
| CallTimeoutException |
Client-side call timeout
|
| EmptyServiceNameException | |
| FailedServerException |
Indicates that we're trying to connect to a already known as dead server.
|
| FatalConnectionException |
Thrown when server finds fatal issue w/ connection setup: e.g.
|
| IPCUtil.CellScannerButNoCodecException |
Thrown if a cellscanner but no codec to encode it with.
|
| RemoteWithExtrasException |
A
RemoteException with some extra information. |
| RpcServer.CallQueueTooBigException | |
| ServerNotRunningYetException | |
| StoppedRpcClientException | |
| UnknownServiceException | |
| UnsupportedCellCodecException | |
| UnsupportedCompressionCodecException | |
| WrongVersionException |
| Annotation Type | Description |
|---|---|
| QosPriority |
Annotation which decorates RPC methods to denote the relative priority among other RPCs in the
same server.
|
Copyright © 2007–2016 The Apache Software Foundation. All rights reserved.