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.tmpl.regionserver | |
org.apache.hadoop.hbase.tool |
Class and Description |
---|
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.
|
RpcClient
Interface for RpcClient implementations so ConnectionManager can handle it.
|
RpcControllerFactory
Factory to create a
HBaseRpcController |
Class and Description |
---|
AbstractRpcClient
Provides the basics for a RpcClient implementation like configuration and Logging.
|
AbstractRpcClient.AbstractRpcChannel |
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. |
BlockingRpcClient
Does RPC against a cluster.
|
BlockingRpcConnection
Thread that reads responses and notifies callers.
|
BlockingRpcConnection.CallSender
If the client wants to interrupt its calls easily (i.e.
|
BufferCallBeforeInitHandler.BufferCallAction |
BufferCallBeforeInitHandler.BufferCallEvent |
BufferChain
Chain of ByteBuffers.
|
Call
A call waiting for a value.
|
CallEvent.Type |
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.OutputStreamSupplier |
ConnectionId
This class holds the address and the user ticket, etc.
|
FailedServers
A class to manage a list of servers that failed recently.
|
FastPathBalancedQueueRpcExecutor.FastPathHandler |
FatalConnectionException
Thrown when server finds fatal issue w/ connection setup: e.g.
|
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.
|
MetricsHBaseServer |
MetricsHBaseServerSource |
MetricsHBaseServerSourceFactory |
MetricsHBaseServerSourceFactoryImpl.SourceStorage |
MetricsHBaseServerWrapper |
NettyRpcClient
Netty client for the requests and responses.
|
NettyRpcConnection
RPC connection implementation based on netty.
|
NettyRpcServer
An RPC server with Netty4 implementation.
|
NettyRpcServerPreambleHandler
Handle connection preamble.
|
NettyServerCall
Datastructure that holds all necessary to a method invocation and then afterward, carries the
result.
|
NettyServerRpcConnection
RpcConnection implementation for netty rpc server.
|
PriorityFunction
Function to figure priority of incoming request.
|
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.
|
RpcConnection
Base class for ipc connection.
|
RpcControllerFactory
Factory to create a
HBaseRpcController |
RpcExecutor
Runs the CallRunners passed here via
RpcExecutor.dispatch(CallRunner) . |
RpcExecutor.Handler
Handler thread run the
CallRunner.run() in. |
RpcExecutor.QueueBalancer |
RpcResponse
An interface represent the response of an rpc call.
|
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.CallCleanup |
RpcServerInterface |
ServerCall
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.
|
SimpleRpcServer
The RPC server with native java NIO implementation deriving from Hadoop to
host protobuf described Services.
|
SimpleRpcServer.ConnectionManager |
SimpleRpcServer.Listener
Listens on the socket.
|
SimpleRpcServer.Listener.Reader |
SimpleRpcServerResponder
Sends responses of RPC back to clients.
|
SimpleServerCall
Datastructure that holds all necessary to a method invocation and then afterward, carries the
result.
|
SimpleServerRpcConnection
Reads calls from a connection and queues them for handling.
|
Class and Description |
---|
HBaseRpcController
Optionally carries Cells across the proxy/service interface down into ipc.
|
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.
|
RpcControllerFactory
Factory to create a
HBaseRpcController |
RpcServer.BlockingServiceAndInterface
Datastructure for passing a
BlockingService and its associated class of
protobuf service interface. |
RpcServerInterface |
ServerNotRunningYetException |
Class and Description |
---|
RpcScheduler
An interface for RPC request scheduling algorithm.
|
Class and Description |
---|
HBaseRpcController
Optionally carries Cells across the proxy/service interface down into ipc.
|
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.
|
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.
|
RpcControllerFactory
Factory to create a
HBaseRpcController |
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
HBaseRpcController |
Class and Description |
---|
ServerCall
Datastructure that holds all necessary to a method invocation and then afterward, carries
the result.
|
Class and Description |
---|
HBaseRpcController
Optionally carries Cells across the proxy/service interface down into ipc.
|
RpcControllerFactory
Factory to create a
HBaseRpcController |
Class and Description |
---|
CoprocessorRpcChannel
Base interface which provides clients with an RPC connection to
call coprocessor endpoint
Service s. |
Class and Description |
---|
MetricsHBaseServerWrapper |
Class and Description |
---|
RpcControllerFactory
Factory to create a
HBaseRpcController |
Copyright © 2007–2019 The Apache Software Foundation. All rights reserved.