| Class and Description |
|---|
| RpcServerInterface |
| Class and Description |
|---|
| AbstractRpcClient
Provides the basics for a RpcClient implementation like configuration and Logging.
|
| CoprocessorRpcChannel
Base class which provides clients with an RPC connection to
call coprocessor endpoint
com.google.protobuf.Services. |
| DelegatingPayloadCarryingRpcController
Simple delegating controller for use with the
RpcControllerFactory to help override
standard behavior of a PayloadCarryingRpcController. |
| PayloadCarryingRpcController
Optionally carries Cells across the proxy/service interface down into ipc.
|
| RpcClient
Interface for RpcClient implementations so ConnectionManager can handle it.
|
| RpcClientImpl
Does RPC against a cluster.
|
| RpcControllerFactory
Factory to create a
PayloadCarryingRpcController |
| TimeLimitedRpcController |
| Class and Description |
|---|
| AbstractRpcClient
Provides the basics for a RpcClient implementation like configuration and Logging.
|
| AbstractTestIPC
Some basic ipc tests.
|
| AsyncRpcChannel
Netty RPC channel
|
| AsyncRpcClient
Netty client for the requests and 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. |
| 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
com.google.protobuf.Services. |
| Delayable
A call whose response can be delayed by the server.
|
| FailedServers
A class to manage a list of servers that failed recently.
|
| FatalConnectionException
Thrown when server finds fatal issue w/ connection setup: e.g.
|
| HBaseRPCErrorHandler
An interface for calling out of RPC for error conditions.
|
| IPCUtil
Utility to help ipc'ing.
|
| MetricsHBaseServer |
| MetricsHBaseServerSource |
| MetricsHBaseServerSourceFactory |
| MetricsHBaseServerWrapper |
| PayloadCarryingRpcController
Optionally carries Cells across the proxy/service interface down into ipc.
|
| PriorityFunction
Function to figure priority of incoming request.
|
| RpcCallContext |
| RpcClient
Interface for RpcClient implementations so ConnectionManager can handle it.
|
| RpcClientImpl
Does RPC against a cluster.
|
| RpcClientImpl.Connection
Thread that reads responses and notifies callers.
|
| RpcControllerFactory
Factory to create a
PayloadCarryingRpcController |
| RpcExecutor
Runs the CallRunners passed here via
RpcExecutor.dispatch(CallRunner). |
| RpcExecutor.Handler
Handler thread run the
CallRunner.run() in. |
| RpcExecutor.QueueBalancer |
| RpcScheduler
An interface for RPC request scheduling algorithm.
|
| RpcScheduler.Context
Exposes runtime information of a
RpcServer that a RpcScheduler may need. |
| RpcServer.BlockingServiceAndInterface
Datastructure for passing a
BlockingService and its associated class of
protobuf service interface. |
| RpcServer.Call
Datastructure that holds all necessary to a method invocation and then afterward, carries
the result.
|
| RpcServer.Connection
Reads calls from a connection and queues them for handling.
|
| RpcServer.Responder |
| RpcServerInterface |
| TimeLimitedRpcController |
| Class and Description |
|---|
| HBaseRPCErrorHandler
An interface for calling out of RPC for error conditions.
|
| PriorityFunction
Function to figure priority of incoming request.
|
| QosPriority
Annotation which decorates RPC methods to denote the relative priority among other RPCs in the
same server.
|
| RpcServer.BlockingServiceAndInterface
Datastructure for passing a
BlockingService and its associated class of
protobuf service interface. |
| Class and Description |
|---|
| RpcScheduler
An interface for RPC request scheduling algorithm.
|
| Class and Description |
|---|
| HBaseRPCErrorHandler
An interface for calling out of RPC for error conditions.
|
| PriorityFunction
Function to figure priority of incoming request.
|
| QosPriority
Annotation which decorates RPC methods to denote the relative priority among other RPCs in the
same server.
|
| RpcScheduler
An interface for RPC request scheduling algorithm.
|
| RpcServer.BlockingServiceAndInterface
Datastructure for passing a
BlockingService and its associated class of
protobuf service interface. |
| RpcServerInterface |
| Class and Description |
|---|
| RpcControllerFactory
Factory to create a
PayloadCarryingRpcController |
| Class and Description |
|---|
| CoprocessorRpcChannel
Base class which provides clients with an RPC connection to
call coprocessor endpoint
com.google.protobuf.Services. |
| Class and Description |
|---|
| RpcServer.Connection
Reads calls from a connection and queues them for handling.
|