See: Description
| Interface | Description |
|---|---|
| HBaseRpcController |
Optionally carries Cells across the proxy/service interface down into ipc.
|
| HBaseRpcController.CancellationCallback | |
| 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<T extends org.apache.hadoop.hbase.ipc.RpcConnection> |
Provides the basics for a RpcClient implementation like configuration and Logging.
|
| AbstractRpcClient.BlockingRpcChannelImplementation |
Blocking rpc channel that goes via hbase rpc.
|
| AbstractRpcClient.RpcChannelImplementation |
Async rpc channel that goes via hbase rpc.
|
| AdaptiveLifoCoDelCallQueue |
Adaptive LIFO blocking queue utilizing CoDel algorithm to prevent queue overloading.
|
| 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. |
| BlockingRpcClient |
Does RPC against a cluster.
|
| 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. |
| CoprocessorRpcUtils |
Utilities for handling coprocessor service calls.
|
| DelegatingHBaseRpcController |
Simple delegating controller for use with the
RpcControllerFactory to help override
standard behavior of a HBaseRpcController. |
| FailedServers |
A class to manage a list of servers that failed recently.
|
| FastPathBalancedQueueRpcExecutor |
Balanced queue executor with a fastpath.
|
| FifoRpcScheduler |
A very simple
RpcScheduler} that serves incoming requests in order. |
| HBaseRpcControllerImpl |
Optionally carries Cells across the proxy/service interface down into ipc.
|
| MasterCoprocessorRpcChannel |
Provides clients with an RPC connection to call coprocessor endpoint
Services
against the active master. |
| MetricsHBaseServer | |
| MetricsHBaseServerSourceFactory | |
| MetricsHBaseServerSourceFactoryImpl | |
| MetricsHBaseServerSourceImpl | |
| MetricsHBaseServerWrapperImpl | |
| NettyRpcClient |
Netty client for the requests and responses.
|
| NettyRpcClientConfigHelper |
Helper class for passing config to
NettyRpcClient. |
| 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 |
| RpcControllerFactory |
Factory to create a
HBaseRpcController. |
| RpcExecutor |
Runs the CallRunners passed here via
RpcExecutor.dispatch(CallRunner). |
| 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 |
The default scheduler.
|
| Exception | Description |
|---|---|
| BadAuthException | |
| CallCancelledException |
Client side call cancelled.
|
| CallerDisconnectedException |
Exception indicating that the remote host making this IPC lost its
IPC connection.
|
| CallTimeoutException |
Client-side call timeout
|
| CellScannerButNoCodecException |
Thrown if a cellscanner but no codec to encode it with.
|
| EmptyServiceNameException | |
| FailedServerException |
Indicates that we're trying to connect to a already known as dead server.
|
| FallbackDisallowedException |
Indicate that the rpc server tells client to fallback to simple auth but client is disabled to do
so.
|
| FatalConnectionException |
Thrown when server finds fatal issue w/ connection setup: e.g.
|
| RemoteWithExtrasException |
A
RemoteException with some extra information. |
| ServerNotRunningYetException | |
| ServerTooBusyException |
Throw this in rpc call if there are too many pending requests for one region server
|
| 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–2019 The Apache Software Foundation. All rights reserved.