Package | Description |
---|---|
org.apache.hadoop.hbase | |
org.apache.hadoop.hbase.client |
Provides HBase Client
|
org.apache.hadoop.hbase.ipc | |
org.apache.hadoop.hbase.zookeeper |
Modifier and Type | Method and Description |
---|---|
static void |
MetaTableAccessor.addDaughter(HConnection hConnection,
HRegionInfo regionInfo,
ServerName sn,
long openSeqNum)
Adds a daughter region entry to meta.
|
static void |
MetaTableAccessor.addRegionsToMeta(HConnection hConnection,
List<HRegionInfo> regionInfos)
Adds a hbase:meta row for each of the specified new regions.
|
static void |
MetaTableAccessor.addRegionToMeta(HConnection hConnection,
HRegionInfo regionInfo)
Adds a hbase:meta row for the specified new region.
|
static void |
MetaTableAccessor.addRegionToMeta(HConnection hConnection,
HRegionInfo regionInfo,
HRegionInfo splitA,
HRegionInfo splitB)
Adds a (single) hbase:meta row for the specified new region and its daughters.
|
static void |
MetaTableAccessor.deleteFromMetaTable(HConnection hConnection,
List<Delete> deletes)
Delete the passed
deletes from the hbase:meta table. |
static void |
MetaTableAccessor.deleteMergeQualifiers(HConnection hConnection,
HRegionInfo mergedRegion)
Deletes merge qualifiers for the specified merged region.
|
static void |
MetaTableAccessor.deleteRegion(HConnection hConnection,
HRegionInfo regionInfo)
Deletes the specified region from META.
|
static void |
MetaTableAccessor.deleteRegions(HConnection hConnection,
List<HRegionInfo> regionsInfo)
Deletes the specified regions from META.
|
static List<Result> |
MetaTableAccessor.fullScan(HConnection hConnection)
Performs a full scan of
hbase:meta . |
static void |
MetaTableAccessor.fullScan(HConnection hConnection,
MetaTableAccessor.Visitor visitor)
Performs a full scan of
hbase:meta . |
static void |
MetaTableAccessor.fullScan(HConnection hConnection,
MetaTableAccessor.Visitor visitor,
byte[] startrow)
Performs a full scan of a catalog table.
|
static void |
MetaTableAccessor.fullScanMetaAndPrint(HConnection hConnection) |
static List<Result> |
MetaTableAccessor.fullScanOfMeta(HConnection hConnection)
Performs a full scan of a
hbase:meta table. |
static Pair<HRegionInfo,ServerName> |
MetaTableAccessor.getRegion(HConnection hConnection,
byte[] regionName)
Deprecated.
|
static HRegionLocation |
MetaTableAccessor.getRegionLocation(HConnection hConnection,
byte[] regionName)
Returns the HRegionLocation from meta for the given region
|
static HRegionLocation |
MetaTableAccessor.getRegionLocation(HConnection hConnection,
HRegionInfo regionInfo)
Returns the HRegionLocation from meta for the given region
|
static Result |
MetaTableAccessor.getRegionResult(HConnection hConnection,
byte[] regionName)
Gets the result in hbase:meta for the specified region.
|
static Pair<HRegionInfo,HRegionInfo> |
MetaTableAccessor.getRegionsFromMergeQualifier(HConnection hConnection,
byte[] regionName)
Get regions from the merge qualifier of the specified merged region
|
static NavigableMap<HRegionInfo,Result> |
MetaTableAccessor.getServerUserRegions(HConnection hConnection,
ServerName serverName) |
static List<HRegionInfo> |
MetaTableAccessor.getTableRegions(ZooKeeperWatcher zkw,
HConnection hConnection,
TableName tableName)
Gets all of the regions of the specified table.
|
static List<HRegionInfo> |
MetaTableAccessor.getTableRegions(ZooKeeperWatcher zkw,
HConnection hConnection,
TableName tableName,
boolean excludeOfflinedSplitParents)
Gets all of the regions of the specified table.
|
static List<Pair<HRegionInfo,ServerName>> |
MetaTableAccessor.getTableRegionsAndLocations(ZooKeeperWatcher zkw,
HConnection hConnection,
TableName tableName) |
static List<Pair<HRegionInfo,ServerName>> |
MetaTableAccessor.getTableRegionsAndLocations(ZooKeeperWatcher zkw,
HConnection hConnection,
TableName tableName,
boolean excludeOfflinedSplitParents) |
static void |
MetaTableAccessor.mergeRegions(HConnection hConnection,
HRegionInfo mergedRegion,
HRegionInfo regionA,
HRegionInfo regionB,
ServerName sn)
Merge the two regions into one in an atomic operation.
|
static void |
MetaTableAccessor.mutateMetaTable(HConnection hConnection,
List<Mutation> mutations)
Execute the passed
mutations against hbase:meta table. |
static void |
MetaTableAccessor.mutateRegions(HConnection hConnection,
List<HRegionInfo> regionsToRemove,
List<HRegionInfo> regionsToAdd)
Adds and Removes the specified regions from hbase:meta
|
static void |
MetaTableAccessor.overwriteRegions(HConnection hConnection,
List<HRegionInfo> regionInfos)
Overwrites the specified regions from hbase:meta
|
static void |
MetaTableAccessor.putsToMetaTable(HConnection hConnection,
List<Put> ps)
Put the passed
ps to the hbase:meta table. |
static void |
MetaTableAccessor.removeRegionReplicasFromMeta(Set<byte[]> metaRows,
int replicaIndexToDeleteFrom,
int numReplicasToRemove,
HConnection hConnection)
Deletes some replica columns corresponding to replicas for the passed rows
|
static void |
MetaTableAccessor.splitRegion(HConnection hConnection,
HRegionInfo parent,
HRegionInfo splitA,
HRegionInfo splitB,
ServerName sn)
Splits the region into two in an atomic operation.
|
static boolean |
MetaTableAccessor.tableExists(HConnection hConnection,
TableName tableName)
Checks if the specified table exists.
|
static void |
MetaTableAccessor.updateRegionLocation(HConnection hConnection,
HRegionInfo regionInfo,
ServerName sn,
long updateSeqNum)
Updates the location of the specified region in hbase:meta to be the specified
server hostname and startcode.
|
Modifier and Type | Interface and Description |
---|---|
interface |
ClusterConnection
Internal methods on HConnection that should not be used by user code.
|
Modifier and Type | Field and Description |
---|---|
protected HConnection |
RegionServerCallable.connection |
Modifier and Type | Method and Description |
---|---|
static HConnection |
HConnectionManager.createConnection(org.apache.hadoop.conf.Configuration conf)
Deprecated.
|
static HConnection |
HConnectionManager.createConnection(org.apache.hadoop.conf.Configuration conf,
ExecutorService pool)
Deprecated.
|
static HConnection |
HConnectionManager.createConnection(org.apache.hadoop.conf.Configuration conf,
ExecutorService pool,
User user)
Deprecated.
|
static HConnection |
HConnectionManager.createConnection(org.apache.hadoop.conf.Configuration conf,
User user)
Deprecated.
|
static HConnection |
ConnectionUtils.createShortCircuitHConnection(HConnection conn,
ServerName serverName,
AdminProtos.AdminService.BlockingInterface admin,
ClientProtos.ClientService.BlockingInterface client)
Adapt a HConnection so that it can bypass the RPC layer (serialization,
deserialization, networking, etc..) when it talks to a local server.
|
HConnection |
HTable.getConnection()
Deprecated.
This method will be changed from public to package protected.
|
HConnection |
HBaseAdmin.getConnection() |
static HConnection |
HConnectionManager.getConnection(org.apache.hadoop.conf.Configuration conf)
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
abstract T |
HConnectable.connect(HConnection connection) |
static HConnection |
ConnectionUtils.createShortCircuitHConnection(HConnection conn,
ServerName serverName,
AdminProtos.AdminService.BlockingInterface admin,
ClientProtos.ClientService.BlockingInterface client)
Adapt a HConnection so that it can bypass the RPC layer (serialization,
deserialization, networking, etc..) when it talks to a local server.
|
static void |
HConnectionManager.deleteStaleConnection(HConnection connection)
Deprecated.
|
static NonceGenerator |
ConnectionUtils.injectNonceGeneratorForTesting(HConnection conn,
NonceGenerator cnm) |
Constructor and Description |
---|
HBaseAdmin(HConnection connection)
Deprecated.
Do not use this internal ctor.
|
HTable(byte[] tableName,
HConnection connection,
ExecutorService pool)
Deprecated.
Do not use, internal ctor.
|
HTable(TableName tableName,
HConnection connection,
ExecutorService pool)
Deprecated.
Do not use, internal ctor.
|
RegionServerCallable(HConnection connection,
TableName tableName,
byte[] row) |
Constructor and Description |
---|
MasterCoprocessorRpcChannel(HConnection conn) |
RegionCoprocessorRpcChannel(HConnection conn,
TableName table,
byte[] row) |
Modifier and Type | Method and Description |
---|---|
boolean |
MetaTableLocator.verifyMetaRegionLocation(HConnection hConnection,
ZooKeeperWatcher zkw,
long timeout)
Verify
hbase:meta is deployed and accessible. |
Copyright © 2014 The Apache Software Foundation. All Rights Reserved.