Package | Description |
---|---|
org.apache.hadoop.hbase.client |
Provides HBase Client
|
org.apache.hadoop.hbase.ipc |
Tools to help define network clients and servers.
|
org.apache.hadoop.hbase.master | |
org.apache.hadoop.hbase.quotas | |
org.apache.hadoop.hbase.regionserver | |
org.apache.hadoop.hbase.regionserver.handler | |
org.apache.hadoop.hbase.regionserver.wal | |
org.apache.hadoop.hbase.replication.regionserver | |
org.apache.hadoop.hbase.rest.client | |
org.apache.hadoop.hbase.security | |
org.apache.hadoop.hbase.tmpl.regionserver |
Class and Description |
---|
CoprocessorRpcChannel
Base class which provides clients with an RPC connection to
call coprocessor endpoint
Service s. |
PayloadCarryingRpcController
Optionally carries Cells across the proxy/service interface down into ipc.
|
RpcClient
Interface for RpcClient implementations so ConnectionManager can handle it.
|
RpcControllerFactory
Factory to create a
PayloadCarryingRpcController |
Class and Description |
---|
AbstractRpcClient
Provides the basics for a RpcClient implementation like configuration and Logging.
|
AsyncCall
Represents an Async Hbase call and its response.
|
AsyncRpcChannel
Netty RPC channel
|
AsyncRpcClient
Netty client for the requests and responses
|
BufferChain
Chain of ByteBuffers.
|
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
Service s. |
FailedServerException
Indicates that we're trying to connect to a already known as dead 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 |
MetricsHBaseServerSourceFactoryImpl.SourceStorage |
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.CallFuture |
RpcClientImpl.Connection
Thread that reads responses and notifies callers.
|
RpcClientImpl.Connection.CallSender
If the client wants to interrupt its calls easily (i.e.
|
RpcControllerFactory
Factory to create a
PayloadCarryingRpcController |
RpcExecutor |
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. |
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.Listener
Listens on the socket.
|
RpcServer.Listener.Reader |
RpcServer.Responder |
RpcServerInterface |
StoppedRpcClientException |
TimeLimitedRpcController |
Class and Description |
---|
HBaseRPCErrorHandler
An interface for calling out of RPC for error conditions.
|
PayloadCarryingRpcController
Optionally carries Cells across the proxy/service interface down into ipc.
|
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.
|
RpcControllerFactory
Factory to create a
PayloadCarryingRpcController |
RpcServer.BlockingServiceAndInterface
Datastructure for passing a
BlockingService and its associated class of
protobuf service interface. |
ServerNotRunningYetException |
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.
|
PayloadCarryingRpcController
Optionally carries Cells across the proxy/service interface down into ipc.
|
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.
|
RpcCallContext |
RpcClient
Interface for RpcClient implementations so ConnectionManager can handle it.
|
RpcControllerFactory
Factory to create a
PayloadCarryingRpcController |
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 |
---|
RpcControllerFactory
Factory to create a
PayloadCarryingRpcController |
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
Service s. |
Class and Description |
---|
RpcServer.Connection
Reads calls from a connection and queues them for handling.
|
Class and Description |
---|
MetricsHBaseServerWrapper |
Copyright © 2007–2019 The Apache Software Foundation. All rights reserved.