Package | Description |
---|---|
org.apache.hadoop.hbase | |
org.apache.hadoop.hbase.backup.example | |
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.regionserver | |
org.apache.hadoop.hbase.regionserver.handler | |
org.apache.hadoop.hbase.replication.regionserver | |
org.apache.hadoop.hbase.util |
Modifier and Type | Method and Description |
---|---|
ClusterConnection |
Server.getConnection()
Returns a reference to the servers' cluster connection.
|
Modifier and Type | Field and Description |
---|---|
private ClusterConnection |
ZKTableArchiveClient.connection |
Constructor and Description |
---|
ZKTableArchiveClient(org.apache.hadoop.conf.Configuration conf,
ClusterConnection connection) |
Modifier and Type | Class and Description |
---|---|
(package private) class |
ConnectionAdapter
Deprecated.
|
(package private) static class |
ConnectionManager.HConnectionImplementation
Encapsulates connection to zookeeper and regionservers.
|
(package private) static class |
ConnectionUtils.MasterlessConnection
Some tests shut down the master.
|
class |
CoprocessorHConnection
Connection to an HTable from within a Coprocessor.
|
Modifier and Type | Field and Description |
---|---|
protected ClusterConnection |
ScannerCallable.cConnection |
protected ClusterConnection |
RpcRetryingCallerWithReadReplicas.cConnection |
(package private) ClusterConnection |
ScannerCallableWithReplicas.cConnection |
private ClusterConnection |
HTableMultiplexer.conn |
protected ClusterConnection |
HTable.connection |
private ClusterConnection |
HRegionLocator.connection |
protected ClusterConnection |
AsyncProcess.connection |
private ClusterConnection |
HBaseAdmin.connection |
private ClusterConnection |
ClientScanner.connection |
protected ClusterConnection |
RegionAdminServiceCallable.connection |
protected ClusterConnection |
BufferedMutatorImpl.connection |
private ClusterConnection |
HTableWrapper.connection |
private ClusterConnection |
ConnectionAdapter.wrappedConnection
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
(package private) static ClusterConnection |
ConnectionManager.createConnection(org.apache.hadoop.conf.Configuration conf,
boolean managed,
ExecutorService pool,
User user)
Deprecated.
|
(package private) static ClusterConnection |
HConnectionManager.createConnection(org.apache.hadoop.conf.Configuration conf,
boolean managed,
ExecutorService pool,
User user)
Deprecated.
|
(package private) static ClusterConnection |
ConnectionManager.createConnectionInternal(org.apache.hadoop.conf.Configuration conf) |
static ClusterConnection |
ConnectionUtils.createShortCircuitConnection(org.apache.hadoop.conf.Configuration conf,
ExecutorService pool,
User user,
ServerName serverName,
org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService.BlockingInterface admin,
org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ClientService.BlockingInterface client)
Creates a short-circuit connection that can bypass the RPC layer (serialization,
deserialization, networking, etc..) when talking to a local server.
|
static ClusterConnection |
ConnectionUtils.createShortCircuitHConnection(Connection conn,
ServerName serverName,
org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService.BlockingInterface admin,
org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ClientService.BlockingInterface client)
Deprecated.
|
ClusterConnection |
ScannerCallable.getConnection() |
protected ClusterConnection |
ClientScanner.getConnection() |
(package private) ClusterConnection |
HTableMultiplexer.getConnection() |
static ClusterConnection |
CoprocessorHConnection.getConnectionForEnvironment(CoprocessorEnvironment env)
Create an unmanaged
HConnection based on the environment in which we are running the
coprocessor. |
(package private) static ClusterConnection |
ConnectionManager.getConnectionInternal(org.apache.hadoop.conf.Configuration conf) |
Modifier and Type | Method and Description |
---|---|
ScannerCallableWithReplicas |
ClientSmallScanner.SmallScannerCallableFactory.getCallable(ClusterConnection connection,
TableName table,
Scan scan,
ScanMetrics scanMetrics,
byte[] localStartKey,
int cacheNum,
RpcControllerFactory controllerFactory,
ExecutorService pool,
int primaryOperationTimeout,
int retries,
int scannerTimeout,
org.apache.hadoop.conf.Configuration conf,
RpcRetryingCaller<Result[]> caller) |
ScannerCallableWithReplicas |
ClientSmallReversedScanner.SmallReversedScannerCallableFactory.getCallable(ClusterConnection connection,
TableName table,
Scan scan,
ScanMetrics scanMetrics,
byte[] localStartKey,
int cacheNum,
RpcControllerFactory controllerFactory,
ExecutorService pool,
int primaryOperationTimeout,
int retries,
int scannerTimeout,
org.apache.hadoop.conf.Configuration conf,
RpcRetryingCaller<Result[]> caller,
boolean isFirstRegionToLocate) |
(package private) static RegionLocations |
RpcRetryingCallerWithReadReplicas.getRegionLocations(boolean useCache,
int replicaId,
ClusterConnection cConnection,
TableName tableName,
byte[] row) |
static RegionLocations |
RegionAdminServiceCallable.getRegionLocations(ClusterConnection connection,
TableName tableName,
byte[] row,
boolean useCache,
int replicaId) |
(package private) static NonceGenerator |
ConnectionManager.injectNonceGeneratorForTesting(ClusterConnection conn,
NonceGenerator cnm) |
static NonceGenerator |
ConnectionUtils.injectNonceGeneratorForTesting(ClusterConnection conn,
NonceGenerator cnm) |
Constructor and Description |
---|
AsyncProcess(ClusterConnection hc,
org.apache.hadoop.conf.Configuration conf,
ExecutorService pool,
RpcRetryingCallerFactory rpcCaller,
boolean useGlobalErrors,
RpcControllerFactory rpcFactory) |
BufferedMutatorImpl(ClusterConnection conn,
RpcRetryingCallerFactory rpcCallerFactory,
RpcControllerFactory rpcFactory,
BufferedMutatorParams params) |
ClientScanner(org.apache.hadoop.conf.Configuration conf,
Scan scan,
TableName tableName,
ClusterConnection connection,
RpcRetryingCallerFactory rpcFactory,
RpcControllerFactory controllerFactory,
ExecutorService pool,
int primaryOperationTimeout)
Create a new ClientScanner for the specified table Note that the passed
Scan 's start
row maybe changed changed. |
ClientSmallReversedScanner.SmallReversedScannerCallable(ClusterConnection connection,
TableName table,
Scan scan,
ScanMetrics scanMetrics,
byte[] locateStartRow,
RpcControllerFactory controllerFactory,
int caching,
int replicaId) |
ClientSmallReversedScanner(org.apache.hadoop.conf.Configuration conf,
Scan scan,
TableName tableName,
ClusterConnection connection,
RpcRetryingCallerFactory rpcFactory,
RpcControllerFactory controllerFactory,
ExecutorService pool,
int primaryOperationTimeout)
Create a new ReversibleClientScanner for the specified table.
|
ClientSmallReversedScanner(org.apache.hadoop.conf.Configuration conf,
Scan scan,
TableName tableName,
ClusterConnection connection,
RpcRetryingCallerFactory rpcFactory,
RpcControllerFactory controllerFactory,
ExecutorService pool,
int primaryOperationTimeout,
ClientSmallReversedScanner.SmallReversedScannerCallableFactory callableFactory)
Create a new ReversibleClientScanner for the specified table.
|
ClientSmallScanner.SmallScannerCallable(ClusterConnection connection,
TableName table,
Scan scan,
ScanMetrics scanMetrics,
RpcControllerFactory controllerFactory,
int caching,
int id) |
ClientSmallScanner(org.apache.hadoop.conf.Configuration conf,
Scan scan,
TableName tableName,
ClusterConnection connection,
RpcRetryingCallerFactory rpcFactory,
RpcControllerFactory controllerFactory,
ExecutorService pool,
int primaryOperationTimeout)
Create a new ShortClientScanner for the specified table.
|
ClientSmallScanner(org.apache.hadoop.conf.Configuration conf,
Scan scan,
TableName tableName,
ClusterConnection connection,
RpcRetryingCallerFactory rpcFactory,
RpcControllerFactory controllerFactory,
ExecutorService pool,
int primaryOperationTimeout,
ClientSmallScanner.SmallScannerCallableFactory callableFactory)
Create a new ShortClientScanner for the specified table.
|
CoprocessorHConnection(ClusterConnection delegate,
HRegionServer server)
Deprecated.
delegate is not used
|
FlushRegionCallable(ClusterConnection connection,
RpcControllerFactory rpcControllerFactory,
HRegionInfo regionInfo,
boolean writeFlushWalMarker) |
FlushRegionCallable(ClusterConnection connection,
RpcControllerFactory rpcControllerFactory,
TableName tableName,
byte[] regionName,
byte[] regionStartKey,
boolean writeFlushWalMarker) |
HBaseAdmin(ClusterConnection connection) |
HRegionLocator(TableName tableName,
ClusterConnection connection) |
HTable(ClusterConnection conn,
BufferedMutatorParams params)
For internal testing.
|
HTable(TableName tableName,
ClusterConnection connection,
ConnectionConfiguration tableConfig,
RpcRetryingCallerFactory rpcCallerFactory,
RpcControllerFactory rpcControllerFactory,
ExecutorService pool)
Creates an object to access a HBase table.
|
HTableMultiplexer.FlushWorker(org.apache.hadoop.conf.Configuration conf,
ClusterConnection conn,
HRegionLocation addr,
HTableMultiplexer htableMultiplexer,
int perRegionServerBufferQueueSize,
ExecutorService pool,
ScheduledExecutorService executor) |
HTableWrapper(List<HTableInterface> openTables,
TableName tableName,
ClusterConnection connection,
ExecutorService pool) |
MultiServerCallable(ClusterConnection connection,
TableName tableName,
ServerName location,
RpcControllerFactory rpcFactory,
MultiAction<R> multi) |
RegionAdminServiceCallable(ClusterConnection connection,
RpcControllerFactory rpcControllerFactory,
HRegionLocation location,
TableName tableName,
byte[] row) |
RegionAdminServiceCallable(ClusterConnection connection,
RpcControllerFactory rpcControllerFactory,
HRegionLocation location,
TableName tableName,
byte[] row,
int replicaId) |
RegionAdminServiceCallable(ClusterConnection connection,
RpcControllerFactory rpcControllerFactory,
TableName tableName,
byte[] row) |
ReversedClientScanner(org.apache.hadoop.conf.Configuration conf,
Scan scan,
TableName tableName,
ClusterConnection connection,
RpcRetryingCallerFactory rpcFactory,
RpcControllerFactory controllerFactory,
ExecutorService pool,
int primaryOperationTimeout)
Create a new ReversibleClientScanner for the specified table Note that the
passed
Scan 's start row maybe changed. |
ReversedScannerCallable(ClusterConnection connection,
TableName tableName,
Scan scan,
ScanMetrics scanMetrics,
byte[] locateStartRow)
|
ReversedScannerCallable(ClusterConnection connection,
TableName tableName,
Scan scan,
ScanMetrics scanMetrics,
byte[] locateStartRow,
RpcControllerFactory rpcFactory) |
ReversedScannerCallable(ClusterConnection connection,
TableName tableName,
Scan scan,
ScanMetrics scanMetrics,
byte[] locateStartRow,
RpcControllerFactory rpcFactory,
int replicaId) |
RpcRetryingCallerWithReadReplicas(RpcControllerFactory rpcControllerFactory,
TableName tableName,
ClusterConnection cConnection,
Get get,
ExecutorService pool,
int retries,
int callTimeout,
int timeBeforeReplicas) |
ScannerCallable(ClusterConnection connection,
TableName tableName,
Scan scan,
ScanMetrics scanMetrics,
RpcControllerFactory rpcControllerFactory) |
ScannerCallable(ClusterConnection connection,
TableName tableName,
Scan scan,
ScanMetrics scanMetrics,
RpcControllerFactory rpcControllerFactory,
int id) |
ScannerCallableWithReplicas(TableName tableName,
ClusterConnection cConnection,
ScannerCallable baseCallable,
ExecutorService pool,
int timeBeforeReplicas,
Scan scan,
int retries,
int scannerTimeout,
int caching,
org.apache.hadoop.conf.Configuration conf,
RpcRetryingCaller<Result[]> caller) |
Modifier and Type | Field and Description |
---|---|
private ClusterConnection |
RegionServerCoprocessorRpcChannel.connection |
private ClusterConnection |
RegionCoprocessorRpcChannel.connection |
private ClusterConnection |
MasterCoprocessorRpcChannel.connection |
Constructor and Description |
---|
MasterCoprocessorRpcChannel(ClusterConnection conn) |
RegionCoprocessorRpcChannel(ClusterConnection conn,
TableName table,
byte[] row) |
RegionServerCoprocessorRpcChannel(ClusterConnection conn,
ServerName serverName) |
Modifier and Type | Field and Description |
---|---|
private ClusterConnection |
ServerManager.connection |
Modifier and Type | Method and Description |
---|---|
static void |
ServerManager.closeRegionSilentlyAndWait(ClusterConnection connection,
ServerName server,
HRegionInfo region,
long timeout)
Contacts a region server and waits up to timeout ms
to close the region.
|
Modifier and Type | Field and Description |
---|---|
protected ClusterConnection |
HRegionServer.clusterConnection
Cluster connection to be shared by services.
|
Modifier and Type | Method and Description |
---|---|
protected ClusterConnection |
HRegionServer.createClusterConnection()
Create a 'smarter' HConnection, one that is capable of by-passing RPC if the request is to
the local server.
|
ClusterConnection |
HRegionServer.getConnection() |
Modifier and Type | Field and Description |
---|---|
private ClusterConnection |
RegionReplicaFlushHandler.connection |
Constructor and Description |
---|
RegionReplicaFlushHandler(Server server,
ClusterConnection connection,
RpcRetryingCallerFactory rpcRetryingCallerFactory,
RpcControllerFactory rpcControllerFactory,
int operationTimeout,
HRegion region) |
Modifier and Type | Field and Description |
---|---|
private ClusterConnection |
RegionReplicaReplicationEndpoint.connection |
(package private) ClusterConnection |
RegionReplicaReplicationEndpoint.RegionReplicaSinkWriter.connection |
Modifier and Type | Method and Description |
---|---|
ClusterConnection |
ReplicationSyncUp.DummyServer.getConnection() |
Constructor and Description |
---|
RegionReplicaReplicationEndpoint.RegionReplicaOutputSink(WALSplitter.PipelineController controller,
TableDescriptors tableDescriptors,
WALSplitter.EntryBuffers entryBuffers,
ClusterConnection connection,
ExecutorService pool,
int numWriters,
int operationTimeout) |
RegionReplicaReplicationEndpoint.RegionReplicaReplayCallable(ClusterConnection connection,
RpcControllerFactory rpcControllerFactory,
TableName tableName,
HRegionLocation location,
HRegionInfo regionInfo,
byte[] row,
List<WAL.Entry> entries,
AtomicLong skippedEntries) |
RegionReplicaReplicationEndpoint.RegionReplicaSinkWriter(RegionReplicaReplicationEndpoint.RegionReplicaOutputSink sink,
ClusterConnection connection,
ExecutorService pool,
int operationTimeout,
TableDescriptors tableDescriptors) |
Modifier and Type | Field and Description |
---|---|
private ClusterConnection |
HBaseFsck.connection |
Copyright © 2007–2019 The Apache Software Foundation. All rights reserved.