Package | Description |
---|---|
org.apache.hadoop.hbase | |
org.apache.hadoop.hbase.backup.example | |
org.apache.hadoop.hbase.client |
Provides HBase Client
|
org.apache.hadoop.hbase.mapreduce |
Provides HBase MapReduce
Input/OutputFormats, a table indexing MapReduce job, and utility methods.
|
org.apache.hadoop.hbase.regionserver | |
org.apache.hadoop.hbase.regionserver.wal | |
org.apache.hadoop.hbase.replication.regionserver | |
org.apache.hadoop.hbase.util | |
org.apache.hadoop.hbase.wal | |
org.apache.hadoop.hbase.zookeeper |
Modifier and Type | Method and Description |
---|---|
(package private) static boolean |
MetaMigrationConvertingToPB.isMetaTableUpdated(HConnection hConnection)
Deprecated.
|
Constructor and Description |
---|
HFileArchiveManager(HConnection connection,
org.apache.hadoop.conf.Configuration conf) |
Modifier and Type | Interface and Description |
---|---|
interface |
ClusterConnection
Internal methods on Connection that should not be used by user code.
|
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 |
---|---|
(package private) HConnection |
ConnectionManager.HConnectionImplementation.MasterServiceState.connection |
protected HConnection |
MasterCallable.connection |
Modifier and Type | Method and Description |
---|---|
static HConnection |
ConnectionManager.createConnection(org.apache.hadoop.conf.Configuration conf)
Create a new HConnection instance using the passed
conf instance. |
static HConnection |
HConnectionManager.createConnection(org.apache.hadoop.conf.Configuration conf)
Deprecated.
|
(package private) static HConnection |
ConnectionManager.createConnection(org.apache.hadoop.conf.Configuration conf,
boolean managed)
Deprecated.
|
(package private) static HConnection |
HConnectionManager.createConnection(org.apache.hadoop.conf.Configuration conf,
boolean managed)
Deprecated.
|
static HConnection |
ConnectionManager.createConnection(org.apache.hadoop.conf.Configuration conf,
ExecutorService pool)
Create a new HConnection instance using the passed
conf instance. |
static HConnection |
HConnectionManager.createConnection(org.apache.hadoop.conf.Configuration conf,
ExecutorService pool)
Deprecated.
|
static HConnection |
ConnectionManager.createConnection(org.apache.hadoop.conf.Configuration conf,
ExecutorService pool,
User user)
Create a new HConnection instance using the passed
conf instance. |
static HConnection |
HConnectionManager.createConnection(org.apache.hadoop.conf.Configuration conf,
ExecutorService pool,
User user)
Deprecated.
|
static HConnection |
ConnectionManager.createConnection(org.apache.hadoop.conf.Configuration conf,
User user)
Create a new HConnection instance using the passed
conf instance. |
static HConnection |
HConnectionManager.createConnection(org.apache.hadoop.conf.Configuration conf,
User user)
Deprecated.
|
HConnection |
HTable.getConnection()
Deprecated.
This method will be changed from public to package protected.
|
(package private) HConnection |
RegionServerCallable.getConnection() |
HConnection |
HBaseAdmin.getConnection() |
(package private) HConnection |
RegionAdminServiceCallable.getConnection() |
static HConnection |
ConnectionManager.getConnection(org.apache.hadoop.conf.Configuration conf)
Deprecated.
|
static HConnection |
HConnectionManager.getConnection(org.apache.hadoop.conf.Configuration conf)
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
abstract T |
HConnectable.connect(HConnection connection) |
private static void |
ConnectionManager.deleteConnection(HConnection connection,
boolean staleConnection)
Deprecated.
|
static void |
ConnectionManager.deleteStaleConnection(HConnection connection)
Deprecated.
|
static void |
HConnectionManager.deleteStaleConnection(HConnection connection)
Deprecated.
|
(package private) static HTableDescriptor |
HBaseAdmin.getTableDescriptor(TableName tableName,
HConnection connection,
RpcRetryingCallerFactory rpcCallerFactory,
RpcControllerFactory rpcControllerFactory,
int operationTimeout,
int rpcTimeout) |
Constructor and Description |
---|
ConnectionManager.HConnectionImplementation.MasterServiceState(HConnection connection) |
MasterCallable(HConnection connection) |
Modifier and Type | Method and Description |
---|---|
protected List<LoadIncrementalHFiles.LoadQueueItem> |
LoadIncrementalHFiles.tryAtomicRegionLoad(HConnection conn,
byte[] tableName,
byte[] first,
Collection<LoadIncrementalHFiles.LoadQueueItem> lqis)
Deprecated.
As of release 0.96
(HBASE-9508).
This will be removed in HBase 2.0.0.
Use
LoadIncrementalHFiles.tryAtomicRegionLoad(Connection, TableName, byte[], Collection) . |
Modifier and Type | Method and Description |
---|---|
private void |
RegionMergeTransactionImpl.mergeRegionsAndPutMetaEntries(HConnection hConnection,
HRegionInfo mergedRegion,
HRegionInfo regionA,
HRegionInfo regionB,
ServerName serverName,
List<Mutation> metaEntries,
int regionReplication) |
private void |
SplitTransactionImpl.offlineParentInMetaAndputMetaEntries(HConnection hConnection,
HRegionInfo parent,
HRegionInfo splitA,
HRegionInfo splitB,
ServerName serverName,
List<Mutation> metaEntries,
int regionReplication) |
Modifier and Type | Field and Description |
---|---|
private HConnection |
WALEditsReplaySink.conn |
Constructor and Description |
---|
WALEditsReplaySink.ReplayServerCallable(HConnection connection,
TableName tableName,
HRegionLocation regionLoc,
HRegionInfo regionInfo,
List<WAL.Entry> entries) |
WALEditsReplaySink(org.apache.hadoop.conf.Configuration conf,
TableName tableName,
HConnection conn)
Create a sink for WAL log entries replay
|
Modifier and Type | Field and Description |
---|---|
private HConnection |
HBaseInterClusterReplicationEndpoint.conn |
private HConnection |
ReplicationSinkManager.conn |
Constructor and Description |
---|
ReplicationSinkManager(HConnection conn,
String peerClusterId,
HBaseReplicationEndpoint endpoint,
org.apache.hadoop.conf.Configuration conf)
Instantiate for a single replication peer cluster.
|
Modifier and Type | Field and Description |
---|---|
private HConnection |
HBaseFsck.WorkItemRegion.connection |
private HConnection[] |
MultiHConnection.hConnections |
Modifier and Type | Method and Description |
---|---|
static void |
HBaseFsckRepair.closeRegionSilentlyAndWait(HConnection connection,
ServerName server,
HRegionInfo region)
Contacts a region server and waits up to hbase.hbck.close.timeout ms
(default 120s) to close the region.
|
static void |
HBaseFsckRepair.fixMultiAssignment(HConnection connection,
HRegionInfo region,
List<ServerName> servers)
Fix multiple assignment by doing silent closes on each RS hosting the region
and then force ZK unassigned node to OFFLINE to trigger assignment by
master.
|
Constructor and Description |
---|
HBaseFsck.WorkItemRegion(HBaseFsck hbck,
ServerName info,
HBaseFsck.ErrorReporter errors,
HConnection connection) |
Modifier and Type | Field and Description |
---|---|
private Map<TableName,HConnection> |
WALSplitter.LogReplayOutputSink.tableNameToHConnectionMap |
Modifier and Type | Method and Description |
---|---|
private HConnection |
WALSplitter.LogReplayOutputSink.getConnectionByTableName(TableName tableName) |
Modifier and Type | Method and Description |
---|---|
private HRegionLocation |
WALSplitter.LogReplayOutputSink.locateRegionAndRefreshLastFlushedSequenceId(HConnection hconn,
TableName table,
byte[] row,
String originalEncodedRegionName)
Locate destination region based on table name & row.
|
Constructor and Description |
---|
WALSplitter.RegionServerWriter(org.apache.hadoop.conf.Configuration conf,
TableName tableName,
HConnection conn) |
Modifier and Type | Method and Description |
---|---|
private static org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService.BlockingInterface |
MetaTableLocator.getCachedConnection(HConnection hConnection,
ServerName sn) |
private org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService.BlockingInterface |
MetaTableLocator.getMetaServerConnection(HConnection hConnection,
ZooKeeperWatcher zkw,
long timeout,
int replicaId)
Gets a connection to the server hosting meta, as reported by ZooKeeper,
waiting up to the specified timeout for availability.
|
boolean |
MetaTableLocator.verifyMetaRegionLocation(HConnection hConnection,
ZooKeeperWatcher zkw,
long timeout)
Verify
hbase:meta is deployed and accessible. |
boolean |
MetaTableLocator.verifyMetaRegionLocation(HConnection hConnection,
ZooKeeperWatcher zkw,
long timeout,
int replicaId)
Verify
hbase:meta is deployed and accessible. |
Copyright © 2007–2019 The Apache Software Foundation. All rights reserved.