See: Description
Interface | Description |
---|---|
CellBlockBuilder.OutputStreamSupplier | |
CoprocessorRpcChannel |
Base interface which provides clients with an RPC connection to call coprocessor endpoint
Service s. |
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.
|
QueueBalancer |
Interface for balancing requests across IPC queues
|
RpcCall |
Interface of all necessary to carry out a RPC method invocation on the server.
|
RpcCallback |
Denotes a callback action that has to be executed at the end of an Rpc Call.
|
RpcCallContext |
Interface of all necessary to carry out a RPC service invocation on the server.
|
RpcClient |
Interface for RpcClient implementations so ConnectionManager can handle it.
|
RpcResponse |
An interface represent the response of an rpc call.
|
RpcServer.CallCleanup | |
RpcServerInterface |
Class | Description |
---|---|
AbstractRpcClient<T extends RpcConnection> |
Provides the basics for a RpcClient implementation like configuration and Logging.
|
AbstractRpcClient.AbstractRpcChannel | |
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.
|
BlockingRpcConnection |
Thread that reads responses and notifies callers.
|
BufferCallBeforeInitHandler |
We will expose the connection to upper layer before initialized, so we need to buffer the calls
passed in and write them out once the connection is established.
|
BufferCallBeforeInitHandler.BufferCallEvent | |
BufferChain |
Chain of ByteBuffers.
|
Call |
A call waiting for a value.
|
CallEvent |
Used to tell netty handler the call is cancelled, timeout...
|
CallQueueInfo | |
CallRunner |
The request processing logic, which is usually executed in thread pools provided by an
RpcScheduler . |
CellBlockBuilder |
Helper class for building cell block.
|
CellBlockBuilder.ByteBufferOutputStreamSupplier | |
CellBlockBuilder.ByteBufOutputStreamSupplier | |
ConnectionId |
This class holds the address and the user ticket, etc.
|
CoprocessorRpcUtils |
Utilities for handling coprocessor rpc service calls.
|
CoprocessorRpcUtils.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. |
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.
|
FastPathRpcHandler | |
FastPathRWQueueRpcExecutor |
RPC Executor that extends
RWQueueRpcExecutor with fast-path feature, used in
FastPathBalancedQueueRpcExecutor . |
FifoRpcScheduler |
A very simple RpcScheduler} that serves incoming requests in order.
|
FifoRpcScheduler.FifoCallRunner | |
HBaseRpcControllerImpl |
Get instances via
RpcControllerFactory on client-side. |
HeapByteBufAllocator |
A pooled ByteBufAllocator that does not prefer direct buffers regardless of platform settings.
|
IPCUtil |
Utility to help ipc'ing.
|
MasterFifoRpcScheduler |
A special RpcScheduler} only used for master.
|
MetaRWQueueRpcExecutor |
RPC Executor that uses different queues for reads and writes for meta.
|
MetricsHBaseServer | |
MetricsHBaseServerSourceFactory | |
MetricsHBaseServerSourceFactoryImpl | |
MetricsHBaseServerSourceImpl | |
MetricsHBaseServerWrapperImpl | |
NettyRpcClient |
Netty client for the requests and responses.
|
NettyRpcClientConfigHelper |
Helper class for passing config to
NettyRpcClient . |
NettyRpcConnection |
RPC connection implementation based on netty.
|
NettyRpcDuplexHandler |
The netty rpc handler.
|
NettyRpcFrameDecoder |
Decoder for extracting frame
|
NettyRpcServer |
An RPC server with Netty4 implementation.
|
NettyRpcServerPreambleHandler |
Handle connection preamble.
|
NettyRpcServerRequestDecoder |
Decoder for rpc request.
|
NettyRpcServerResponseEncoder |
Encoder for
RpcResponse . |
NettyServerCall |
Datastructure that holds all necessary to a method invocation and then afterward, carries the
result.
|
NettyServerRpcConnection |
RpcConnection implementation for netty rpc server.
|
PluggableBlockingQueue |
Abstract class template for defining a pluggable blocking queue implementation to be used by the
'pluggable' call queue type in the RpcExecutor.
|
RandomQueueBalancer |
Queue balancer that just randomly selects a queue in the range [0, num queues).
|
RemoteWithExtrasException.ClassLoaderHolder |
Dynamic class loader to load filter/comparators
|
RpcClientFactory |
Factory to create a
RpcClient |
RpcConnection |
Base class for ipc connection.
|
RpcControllerFactory |
Factory to create a
HBaseRpcController |
RpcExecutor |
Runs the CallRunners passed here via
RpcExecutor.dispatch(CallRunner) . |
RpcExecutor.CallPriorityComparator |
Comparator used by the "normal callQueue" if DEADLINE_CALL_QUEUE_CONF_KEY is set to true.
|
RpcHandler |
Thread to handle rpc call.
|
RpcScheduler |
An interface for RPC request scheduling algorithm.
|
RpcScheduler.Context |
Exposes runtime information of a
RpcServer that a RpcScheduler may need. |
RpcSchedulerContext | |
RpcServer |
An RPC server that hosts protobuf described Services.
|
RpcServer.BlockingServiceAndInterface |
Datastructure for passing a
BlockingService and its associated class of protobuf
service interface. |
RpcServerFactory | |
RPCTInfoGetter |
Used to extract a tracing
Context from an instance of TracingProtos.RPCTInfo . |
RWQueueRpcExecutor |
RPC Executor that uses different queues for reads and writes.
|
ServerCall<T extends ServerRpcConnection> |
Datastructure that holds all necessary to a method invocation and then afterward, carries the
result.
|
ServerRpcConnection |
Reads calls from a connection and queues them for handling.
|
ServerRpcConnection.ByteBuffByteInput | |
ServerRpcController |
Used for server-side protobuf RPC service invocations.
|
SimpleRpcScheduler |
The default scheduler.
|
SimpleRpcServer | Deprecated |
SimpleRpcServerResponder | Deprecated |
SimpleServerCall | Deprecated |
SimpleServerRpcConnection | Deprecated |
Enum | Description |
---|---|
BufferCallBeforeInitHandler.BufferCallAction | |
CallEvent.Type | |
MetricsHBaseServerSourceFactoryImpl.SourceStorage |
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.
|
PluggableRpcQueueNotFound |
Internal runtime error type to indicate the RpcExecutor failed to execute a `pluggable` call
queue type.
|
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 | |
UnsupportedCryptoException | |
WrongVersionException |
Annotation Type | Description |
---|---|
QosPriority |
Annotation which decorates RPC methods to denote the relative priority among other RPCs in the
same server.
|
Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.