Package org.apache.hadoop.hbase.ipc
package org.apache.hadoop.hbase.ipc
Tools to help define network clients and servers.
This is the hadoop copied local so can fix bugs and make hbase-specific optimizations.
-
ClassDescriptionorg.apache.hadoop.hbase.ipc.AbstractRpcClient<T extends org.apache.hadoop.hbase.ipc.RpcConnection>Provides the basics for a RpcClient implementation like configuration and Logging.org.apache.hadoop.hbase.ipc.AbstractRpcClient.BlockingRpcChannelImplementationBlocking rpc channel that goes via hbase rpc.org.apache.hadoop.hbase.ipc.AbstractRpcClient.RpcChannelImplementationAsync rpc channel that goes via hbase rpc.org.apache.hadoop.hbase.ipc.AdaptiveLifoCoDelCallQueueAdaptive LIFO blocking queue utilizing CoDel algorithm to prevent queue overloading.org.apache.hadoop.hbase.ipc.BadAuthExceptionorg.apache.hadoop.hbase.ipc.BalancedQueueRpcExecutorAn
RpcExecutor
that will balance requests evenly across all its queues, but still remains efficient with a single queue via an inlinable queue balancing mechanism.org.apache.hadoop.hbase.ipc.BlockingRpcCallback<R>SimpleRpcCallback
implementation providing aFuture
-likeBlockingRpcCallback.get()
method, which will block util the instance'sBlockingRpcCallback.run(Object)
method has been called.org.apache.hadoop.hbase.ipc.BlockingRpcClientDoes RPC against a cluster.org.apache.hadoop.hbase.ipc.CallCancelledExceptionClient side call cancelled.org.apache.hadoop.hbase.ipc.CallerDisconnectedExceptionException indicating that the remote host making this IPC lost its IPC connection.org.apache.hadoop.hbase.ipc.CallQueueInfoorg.apache.hadoop.hbase.ipc.CallRunnerThe request processing logic, which is usually executed in thread pools provided by anRpcScheduler
.org.apache.hadoop.hbase.ipc.CallTimeoutExceptionClient-side call timeoutorg.apache.hadoop.hbase.ipc.CellScannerButNoCodecExceptionThrown if a cellscanner but no codec to encode it with.org.apache.hadoop.hbase.ipc.CoprocessorRpcChannelBase interface which provides clients with an RPC connection to call coprocessor endpointService
s.org.apache.hadoop.hbase.ipc.CoprocessorRpcUtilsUtilities for handling coprocessor rpc service calls.org.apache.hadoop.hbase.ipc.CoprocessorRpcUtils.BlockingRpcCallback<R>SimpleRpcCallback
implementation providing aFuture
-likeCoprocessorRpcUtils.BlockingRpcCallback.get()
method, which will block util the instance'sCoprocessorRpcUtils.BlockingRpcCallback.run(Object)
method has been called.org.apache.hadoop.hbase.ipc.DecommissionedHostRejectedExceptionorg.apache.hadoop.hbase.ipc.DelegatingHBaseRpcControllerSimple delegating controller for use with theRpcControllerFactory
to help override standard behavior of aHBaseRpcController
.org.apache.hadoop.hbase.ipc.DelegatingRpcSchedulerUsers of the hbase.region.server.rpc.scheduler.factory.class customization config can return an implementation which extends this class in order to minimize impact of breaking interface changes.org.apache.hadoop.hbase.ipc.EmptyServiceNameExceptionorg.apache.hadoop.hbase.ipc.FailedServerExceptionIndicates that we're trying to connect to a already known as dead server.org.apache.hadoop.hbase.ipc.FailedServersA class to manage a list of servers that failed recently.org.apache.hadoop.hbase.ipc.FallbackDisallowedExceptionIndicate that the rpc server tells client to fallback to simple auth but client is disabled to do so.org.apache.hadoop.hbase.ipc.FastPathBalancedQueueRpcExecutorBalanced queue executor with a fastpath.org.apache.hadoop.hbase.ipc.FastPathRpcHandlerorg.apache.hadoop.hbase.ipc.FastPathRWQueueRpcExecutorRPC Executor that extendsRWQueueRpcExecutor
with fast-path feature, used inFastPathBalancedQueueRpcExecutor
.org.apache.hadoop.hbase.ipc.FatalConnectionExceptionThrown when server finds fatal issue w/ connection setup: e.g.org.apache.hadoop.hbase.ipc.FifoRpcSchedulerA very simple RpcScheduler} that serves incoming requests in order.org.apache.hadoop.hbase.ipc.HBaseRpcControllerOptionally carries Cells across the proxy/service interface down into ipc.org.apache.hadoop.hbase.ipc.HBaseRpcController.CancellationCallbackorg.apache.hadoop.hbase.ipc.HBaseRpcControllerImplGet instances viaRpcControllerFactory
on client-side.org.apache.hadoop.hbase.ipc.HBaseRPCErrorHandlerAn interface for calling out of RPC for error conditions.org.apache.hadoop.hbase.ipc.HeapByteBufAllocatorA pooled ByteBufAllocator that does not prefer direct buffers regardless of platform settings.org.apache.hadoop.hbase.ipc.MasterFifoRpcSchedulerA special RpcScheduler} only used for master.org.apache.hadoop.hbase.ipc.MetaRWQueueRpcExecutorRPC Executor that uses different queues for reads and writes for meta.org.apache.hadoop.hbase.ipc.MetricsHBaseServerorg.apache.hadoop.hbase.ipc.MetricsHBaseServerSourceorg.apache.hadoop.hbase.ipc.MetricsHBaseServerSourceFactoryorg.apache.hadoop.hbase.ipc.MetricsHBaseServerSourceFactoryImplorg.apache.hadoop.hbase.ipc.MetricsHBaseServerSourceImplorg.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapperorg.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapperImplorg.apache.hadoop.hbase.ipc.NettyRpcClientNetty client for the requests and responses.org.apache.hadoop.hbase.ipc.NettyRpcClientConfigHelperHelper class for passing config toNettyRpcClient
.org.apache.hadoop.hbase.ipc.NettyRpcServerAn RPC server with Netty4 implementation.org.apache.hadoop.hbase.ipc.NettyRpcServerChannelWritabilityHandlerHandler to enforce writability protections on our server channels:
- Responds to channel writability events, which are triggered when the total pending bytes for a channel passes configured high and low watermarks.Abstract class template for defining a pluggable blocking queue implementation to be used by the 'pluggable' call queue type in the RpcExecutor.org.apache.hadoop.hbase.ipc.PluggableRpcQueueNotFoundInternal runtime error type to indicate the RpcExecutor failed to execute a `pluggable` call queue type.org.apache.hadoop.hbase.ipc.PriorityFunctionFunction to figure priority of incoming request.org.apache.hadoop.hbase.ipc.QosPriorityAnnotation which decorates RPC methods to denote the relative priority among other RPCs in the same server.org.apache.hadoop.hbase.ipc.QueueBalancerInterface for balancing requests across IPC queuesorg.apache.hadoop.hbase.ipc.RandomQueueBalancerQueue balancer that just randomly selects a queue in the range [0, num queues).org.apache.hadoop.hbase.ipc.RemoteWithExtrasExceptionARemoteException
with some extra information.org.apache.hadoop.hbase.ipc.RpcCallInterface of all necessary to carry out a RPC method invocation on the server.org.apache.hadoop.hbase.ipc.RpcCallbackDenotes a callback action that has to be executed at the end of an Rpc Call.org.apache.hadoop.hbase.ipc.RpcCallContextInterface of all necessary to carry out a RPC service invocation on the server.org.apache.hadoop.hbase.ipc.RpcClientInterface for RpcClient implementations so ConnectionManager can handle it.org.apache.hadoop.hbase.ipc.RpcClientFactoryFactory to create aRpcClient
org.apache.hadoop.hbase.ipc.RpcConnectionConstantsConstants to be used by RPC connection based utilities.org.apache.hadoop.hbase.ipc.RpcControllerFactoryFactory to create aHBaseRpcController
org.apache.hadoop.hbase.ipc.RpcExecutorRuns the CallRunners passed here viaRpcExecutor.dispatch(CallRunner)
.org.apache.hadoop.hbase.ipc.RpcHandlerThread to handle rpc call.org.apache.hadoop.hbase.ipc.RpcSchedulerAn interface for RPC request scheduling algorithm.org.apache.hadoop.hbase.ipc.RpcScheduler.ContextExposes runtime information of aRpcServer
that aRpcScheduler
may need.org.apache.hadoop.hbase.ipc.RpcServerAn RPC server that hosts protobuf described Services.org.apache.hadoop.hbase.ipc.RpcServer.BlockingServiceAndInterfaceDatastructure for passing aBlockingService
and its associated class of protobuf service interface.org.apache.hadoop.hbase.ipc.RpcServer.CallCleanuporg.apache.hadoop.hbase.ipc.RpcServerFactoryorg.apache.hadoop.hbase.ipc.RpcServerInterfaceorg.apache.hadoop.hbase.ipc.RWQueueRpcExecutorRPC Executor that uses different queues for reads and writes.org.apache.hadoop.hbase.ipc.SecurityNotEnabledExceptionWill be thrown when server received a security preamble call for asking the server principal but security is not enabled for this server.org.apache.hadoop.hbase.ipc.ServerCall<T extends org.apache.hadoop.hbase.ipc.ServerRpcConnection>Datastructure that holds all necessary to a method invocation and then afterward, carries the result.org.apache.hadoop.hbase.ipc.ServerNotRunningYetExceptionorg.apache.hadoop.hbase.ipc.ServerRpcControllerUsed for server-side protobuf RPC service invocations.org.apache.hadoop.hbase.ipc.ServerTooBusyExceptionThrow this in RPC call if there are too many pending requests for one region serverorg.apache.hadoop.hbase.ipc.SimpleRpcSchedulerThe default scheduler.org.apache.hadoop.hbase.ipc.SimpleRpcServerDeprecated.org.apache.hadoop.hbase.ipc.StoppedRpcClientExceptionorg.apache.hadoop.hbase.ipc.UnknownServiceExceptionorg.apache.hadoop.hbase.ipc.UnsupportedCellCodecExceptionorg.apache.hadoop.hbase.ipc.UnsupportedCompressionCodecExceptionorg.apache.hadoop.hbase.ipc.UnsupportedCryptoExceptionorg.apache.hadoop.hbase.ipc.WrongVersionException