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.
  • Class
    Description
    org.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.BlockingRpcChannelImplementation
    Blocking rpc channel that goes via hbase rpc.
    org.apache.hadoop.hbase.ipc.AbstractRpcClient.RpcChannelImplementation
    Async rpc channel that goes via hbase rpc.
    org.apache.hadoop.hbase.ipc.AdaptiveLifoCoDelCallQueue
    Adaptive LIFO blocking queue utilizing CoDel algorithm to prevent queue overloading.
    org.apache.hadoop.hbase.ipc.AnnotationReadingPriorityFunction<T extends org.apache.hadoop.hbase.HBaseRpcServicesBase<?>>
    Reads special method annotations and table names to figure a priority for use by QoS facility in ipc; e.g: rpcs to hbase:meta get priority.
    org.apache.hadoop.hbase.ipc.BadAuthException
     
    org.apache.hadoop.hbase.ipc.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.
    org.apache.hadoop.hbase.ipc.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.
    org.apache.hadoop.hbase.ipc.BlockingRpcClient
    Does RPC against a cluster.
    org.apache.hadoop.hbase.ipc.CallCancelledException
    Client side call cancelled.
    org.apache.hadoop.hbase.ipc.CallerDisconnectedException
    Exception indicating that the remote host making this IPC lost its IPC connection.
    org.apache.hadoop.hbase.ipc.CallQueueInfo
     
    org.apache.hadoop.hbase.ipc.CallRunner
    The request processing logic, which is usually executed in thread pools provided by an RpcScheduler.
    org.apache.hadoop.hbase.ipc.CallTimeoutException
    Client-side call timeout
    org.apache.hadoop.hbase.ipc.CellScannerButNoCodecException
    Thrown if a cellscanner but no codec to encode it with.
    org.apache.hadoop.hbase.ipc.CoprocessorRpcChannel
    Deprecated.
    Please stop using this class again, as it is too low level, which is part of the rpc framework for HBase.
    org.apache.hadoop.hbase.ipc.CoprocessorRpcUtils
    Utilities for handling coprocessor rpc service calls.
    org.apache.hadoop.hbase.ipc.CoprocessorRpcUtils.BlockingRpcCallback<R>
    Simple RpcCallback implementation providing a Future-like CoprocessorRpcUtils.BlockingRpcCallback.get() method, which will block util the instance's CoprocessorRpcUtils.BlockingRpcCallback.run(Object) method has been called.
    org.apache.hadoop.hbase.ipc.DecommissionedHostRejectedException
     
    org.apache.hadoop.hbase.ipc.DelegatingHBaseRpcController
    Simple delegating controller for use with the RpcControllerFactory to help override standard behavior of a HBaseRpcController.
    org.apache.hadoop.hbase.ipc.DelegatingRpcScheduler
    Users 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.EmptyServiceNameException
     
    org.apache.hadoop.hbase.ipc.FailedServerException
    Indicates that we're trying to connect to a already known as dead server.
    org.apache.hadoop.hbase.ipc.FailedServers
    A class to manage a list of servers that failed recently.
    org.apache.hadoop.hbase.ipc.FallbackDisallowedException
    Indicate that the rpc server tells client to fallback to simple auth but client is disabled to do so.
    org.apache.hadoop.hbase.ipc.FastPathBalancedQueueRpcExecutor
    Balanced queue executor with a fastpath.
    org.apache.hadoop.hbase.ipc.FastPathRpcHandler
     
    org.apache.hadoop.hbase.ipc.FastPathRWQueueRpcExecutor
    RPC Executor that extends RWQueueRpcExecutor with fast-path feature, used in FastPathBalancedQueueRpcExecutor.
    org.apache.hadoop.hbase.ipc.FatalConnectionException
    Thrown when server finds fatal issue w/ connection setup: e.g.
    org.apache.hadoop.hbase.ipc.FifoRpcScheduler
    A very simple RpcScheduler} that serves incoming requests in order.
    org.apache.hadoop.hbase.ipc.HBaseRpcController
    Optionally carries Cells across the proxy/service interface down into ipc.
    org.apache.hadoop.hbase.ipc.HBaseRpcController.CancellationCallback
     
    org.apache.hadoop.hbase.ipc.HBaseRpcControllerImpl
    Get instances via RpcControllerFactory on client-side.
    org.apache.hadoop.hbase.ipc.HBaseRPCErrorHandler
    An interface for calling out of RPC for error conditions.
    org.apache.hadoop.hbase.ipc.HeapByteBufAllocator
    A pooled ByteBufAllocator that does not prefer direct buffers regardless of platform settings.
    org.apache.hadoop.hbase.ipc.MasterFifoRpcScheduler
    A special RpcScheduler} only used for master.
    org.apache.hadoop.hbase.ipc.MetaRWQueueRpcExecutor
    RPC Executor that uses different queues for reads and writes for meta.
    org.apache.hadoop.hbase.ipc.MetricsHBaseServer
     
    org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
     
    org.apache.hadoop.hbase.ipc.MetricsHBaseServerSourceFactory
     
    org.apache.hadoop.hbase.ipc.MetricsHBaseServerSourceFactoryImpl
     
    org.apache.hadoop.hbase.ipc.MetricsHBaseServerSourceImpl
     
    org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapper
     
    org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapperImpl
     
    org.apache.hadoop.hbase.ipc.NettyRpcClient
    Netty client for the requests and responses.
    org.apache.hadoop.hbase.ipc.NettyRpcClientConfigHelper
    Helper class for passing config to NettyRpcClient.
    org.apache.hadoop.hbase.ipc.NettyRpcServer
    An RPC server with Netty4 implementation.
    org.apache.hadoop.hbase.ipc.NettyRpcServerChannelWritabilityHandler
    Handler 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.PluggableRpcQueueNotFound
    Internal runtime error type to indicate the RpcExecutor failed to execute a `pluggable` call queue type.
    org.apache.hadoop.hbase.ipc.PriorityFunction
    Function to figure priority of incoming request.
    org.apache.hadoop.hbase.ipc.QosPriority
    Annotation which decorates RPC methods to denote the relative priority among other RPCs in the same server.
    org.apache.hadoop.hbase.ipc.QueueBalancer
    Interface for balancing requests across IPC queues
    org.apache.hadoop.hbase.ipc.RandomQueueBalancer
    Queue balancer that just randomly selects a queue in the range [0, num queues).
    org.apache.hadoop.hbase.ipc.RemoteWithExtrasException
    A RemoteException with some extra information.
    org.apache.hadoop.hbase.ipc.RpcCall
    Interface of all necessary to carry out a RPC method invocation on the server.
    org.apache.hadoop.hbase.ipc.RpcCallback
    Denotes a callback action that has to be executed at the end of an Rpc Call.
    org.apache.hadoop.hbase.ipc.RpcCallContext
    Interface of all necessary to carry out a RPC service invocation on the server.
    org.apache.hadoop.hbase.ipc.RpcClient
    Interface for RpcClient implementations so ConnectionManager can handle it.
    org.apache.hadoop.hbase.ipc.RpcClientFactory
    Factory to create a RpcClient
    org.apache.hadoop.hbase.ipc.RpcConnectionConstants
    Constants to be used by RPC connection based utilities.
    org.apache.hadoop.hbase.ipc.RpcControllerFactory
    Factory to create a HBaseRpcController
    org.apache.hadoop.hbase.ipc.RpcExecutor
    Runs the CallRunners passed here via RpcExecutor.dispatch(CallRunner).
    org.apache.hadoop.hbase.ipc.RpcHandler
    Thread to handle rpc call.
    org.apache.hadoop.hbase.ipc.RpcScheduler
    An interface for RPC request scheduling algorithm.
    org.apache.hadoop.hbase.ipc.RpcScheduler.Context
    Exposes runtime information of a RpcServer that a RpcScheduler may need.
    org.apache.hadoop.hbase.ipc.RpcServer
    An RPC server that hosts protobuf described Services.
    org.apache.hadoop.hbase.ipc.RpcServer.BlockingServiceAndInterface
    Datastructure for passing a BlockingService and its associated class of protobuf service interface.
    org.apache.hadoop.hbase.ipc.RpcServer.CallCleanup
     
    org.apache.hadoop.hbase.ipc.RpcServerFactory
     
    org.apache.hadoop.hbase.ipc.RpcServerInterface
     
    org.apache.hadoop.hbase.ipc.RWQueueRpcExecutor
    RPC Executor that uses different queues for reads and writes.
    org.apache.hadoop.hbase.ipc.SecurityNotEnabledException
    Will 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.ServerNotRunningYetException
     
    org.apache.hadoop.hbase.ipc.ServerRpcController
    Used for server-side protobuf RPC service invocations.
    org.apache.hadoop.hbase.ipc.ServerTooBusyException
    Throw this in RPC call if there are too many pending requests for one region server
    org.apache.hadoop.hbase.ipc.SimpleRpcScheduler
    The default scheduler.
    org.apache.hadoop.hbase.ipc.SimpleRpcServer
    Deprecated.
    org.apache.hadoop.hbase.ipc.StoppedRpcClientException
     
    org.apache.hadoop.hbase.ipc.UnknownServiceException
     
    org.apache.hadoop.hbase.ipc.UnsupportedCellCodecException
     
    org.apache.hadoop.hbase.ipc.UnsupportedCompressionCodecException
     
    org.apache.hadoop.hbase.ipc.UnsupportedCryptoException
     
    org.apache.hadoop.hbase.ipc.WrongVersionException