Package | Description |
---|---|
org.apache.hadoop.hbase | |
org.apache.hadoop.hbase.client |
Provides HBase Client
|
org.apache.hadoop.hbase.quotas | |
org.apache.hadoop.hbase.security.access | |
org.apache.hadoop.hbase.security.visibility |
Modifier and Type | Method and Description |
---|---|
static void |
MetaTableAccessor.addRegionsToMeta(Connection connection,
List<RegionInfo> regionInfos,
int regionReplication)
Adds a hbase:meta row for each of the specified new regions.
|
static void |
MetaTableAccessor.addRegionToMeta(Connection connection,
RegionInfo regionInfo)
Adds a (single) hbase:meta row for the specified new region and its daughters.
|
static void |
MetaTableAccessor.addSplitsToParent(Connection connection,
RegionInfo regionInfo,
RegionInfo splitA,
RegionInfo splitB)
Adds daughter region infos to hbase:meta row for the specified region.
|
static NavigableMap<RegionInfo,ServerName> |
MetaTableAccessor.allTableRegions(Connection connection,
TableName tableName)
Deprecated.
use
MetaTableAccessor.getTableRegionsAndLocations(org.apache.hadoop.hbase.client.Connection, org.apache.hadoop.hbase.TableName) , region can have multiple locations |
static void |
MetaTableAccessor.deleteMergeQualifiers(Connection connection,
RegionInfo mergedRegion)
Deletes merge qualifiers for the specified merged region.
|
static void |
MetaTableAccessor.deleteRegion(Connection connection,
RegionInfo regionInfo)
Deletes the specified region from META.
|
static void |
MetaTableAccessor.deleteRegions(Connection connection,
List<RegionInfo> regionsInfo)
Deletes the specified regions from META.
|
static void |
MetaTableAccessor.deleteRegions(Connection connection,
List<RegionInfo> regionsInfo,
long ts)
Deletes the specified regions from META.
|
static void |
MetaTableAccessor.deleteTableState(Connection connection,
TableName table)
Remove state for table from meta
|
static List<Result> |
MetaTableAccessor.fullScan(Connection connection,
MetaTableAccessor.QueryType type)
Performs a full scan of
hbase:meta . |
static void |
MetaTableAccessor.fullScanMetaAndPrint(Connection connection) |
static List<Result> |
MetaTableAccessor.fullScanRegions(Connection connection)
Performs a full scan of
hbase:meta for regions. |
static void |
MetaTableAccessor.fullScanRegions(Connection connection,
MetaTableAccessor.Visitor visitor)
Performs a full scan of
hbase:meta for regions. |
static void |
MetaTableAccessor.fullScanTables(Connection connection,
MetaTableAccessor.Visitor visitor)
Performs a full scan of
hbase:meta for tables. |
static List<RegionInfo> |
MetaTableAccessor.getAllRegions(Connection connection,
boolean excludeOfflinedSplitParents)
Lists all of the regions currently in META.
|
static List<RSGroupInfo> |
RSGroupTableAccessor.getAllRSGroupInfo(Connection connection) |
static Table |
MetaTableAccessor.getMetaHTable(Connection connection)
Callers should call close on the returned
Table instance. |
static Pair<RegionInfo,ServerName> |
MetaTableAccessor.getRegion(Connection connection,
byte[] regionName)
Deprecated.
|
static int |
MetaTableAccessor.getRegionCount(Connection connection,
TableName tableName)
Count regions in
hbase:meta for passed table. |
static HRegionLocation |
MetaTableAccessor.getRegionLocation(Connection connection,
byte[] regionName)
Returns the HRegionLocation from meta for the given region
|
static HRegionLocation |
MetaTableAccessor.getRegionLocation(Connection connection,
RegionInfo regionInfo)
Returns the HRegionLocation from meta for the given region
|
static Result |
MetaTableAccessor.getRegionResult(Connection connection,
byte[] regionName)
Gets the result in hbase:meta for the specified region.
|
static Pair<RegionInfo,RegionInfo> |
MetaTableAccessor.getRegionsFromMergeQualifier(Connection connection,
byte[] regionName)
Get regions from the merge qualifier of the specified merged region
|
static RSGroupInfo |
RSGroupTableAccessor.getRSGroupInfo(Connection connection,
byte[] rsGroupName) |
static Scan |
MetaTableAccessor.getScanForTableName(Connection connection,
TableName tableName)
Deprecated.
|
static NavigableMap<RegionInfo,Result> |
MetaTableAccessor.getServerUserRegions(Connection connection,
ServerName serverName) |
static List<RegionInfo> |
MetaTableAccessor.getTableRegions(Connection connection,
TableName tableName)
Gets all of the regions of the specified table.
|
static List<RegionInfo> |
MetaTableAccessor.getTableRegions(Connection connection,
TableName tableName,
boolean excludeOfflinedSplitParents)
Gets all of the regions of the specified table.
|
static List<Pair<RegionInfo,ServerName>> |
MetaTableAccessor.getTableRegionsAndLocations(Connection connection,
TableName tableName)
Do not use this method to get meta table regions, use methods in MetaTableLocator instead.
|
static List<Pair<RegionInfo,ServerName>> |
MetaTableAccessor.getTableRegionsAndLocations(Connection connection,
TableName tableName,
boolean excludeOfflinedSplitParents)
Do not use this method to get meta table regions, use methods in MetaTableLocator instead.
|
static TableState |
MetaTableAccessor.getTableState(Connection conn,
TableName tableName)
Fetch table state for given table from META table
|
static Map<TableName,TableState> |
MetaTableAccessor.getTableStates(Connection conn)
Fetch table states from META table
|
static boolean |
RSGroupTableAccessor.isRSGroupsEnabled(Connection connection) |
static void |
MetaTableAccessor.mergeRegions(Connection connection,
RegionInfo mergedRegion,
RegionInfo regionA,
RegionInfo regionB,
ServerName sn,
int regionReplication)
Merge the two regions into one in an atomic operation.
|
static void |
MetaTableAccessor.multiMutate(Connection connection,
Table table,
byte[] row,
List<Mutation> mutations)
Performs an atomic multi-mutate operation against the given table.
|
static void |
MetaTableAccessor.mutateMetaTable(Connection connection,
List<Mutation> mutations)
Execute the passed
mutations against hbase:meta table. |
static void |
MetaTableAccessor.overwriteRegions(Connection connection,
List<RegionInfo> regionInfos,
int regionReplication)
Overwrites the specified regions from hbase:meta.
|
static void |
MetaTableAccessor.putsToMetaTable(Connection connection,
List<Put> ps)
Put the passed
ps to the hbase:meta table. |
static void |
MetaTableAccessor.removeRegionReplicasFromMeta(Set<byte[]> metaRows,
int replicaIndexToDeleteFrom,
int numReplicasToRemove,
Connection connection)
Deletes some replica columns corresponding to replicas for the passed rows
|
static void |
MetaTableAccessor.scanMeta(Connection connection,
byte[] startRow,
byte[] stopRow,
MetaTableAccessor.QueryType type,
int maxRows,
MetaTableAccessor.Visitor visitor)
Performs a scan of META table.
|
static void |
MetaTableAccessor.scanMeta(Connection connection,
byte[] startRow,
byte[] stopRow,
MetaTableAccessor.QueryType type,
MetaTableAccessor.Visitor visitor) |
static void |
MetaTableAccessor.scanMeta(Connection connection,
MetaTableAccessor.Visitor visitor,
TableName tableName,
byte[] row,
int rowLimit)
Performs a scan of META table for given table starting from
given row.
|
static void |
MetaTableAccessor.scanMeta(Connection connection,
TableName table,
MetaTableAccessor.QueryType type,
int maxRows,
MetaTableAccessor.Visitor visitor) |
static void |
MetaTableAccessor.scanMetaForTableRegions(Connection connection,
MetaTableAccessor.Visitor visitor,
TableName tableName) |
static void |
MetaTableAccessor.splitRegion(Connection connection,
RegionInfo parent,
RegionInfo splitA,
RegionInfo splitB,
ServerName sn,
int regionReplication)
Splits the region into two in an atomic operation.
|
static boolean |
MetaTableAccessor.tableExists(Connection connection,
TableName tableName)
Checks if the specified table exists.
|
static void |
MetaTableAccessor.updateRegionLocation(Connection connection,
RegionInfo regionInfo,
ServerName sn,
long openSeqNum,
long masterSystemTime)
Updates the location of the specified region in hbase:meta to be the specified server hostname
and startcode.
|
static void |
MetaTableAccessor.updateTableState(Connection conn,
TableName tableName,
TableState.State actual)
Updates state in META
|
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 |
---|---|
static class |
ConnectionUtils.ShortCircuitingClusterConnection
A ClusterConnection that will short-circuit RPC making direct invocations against the
localhost if the invocation target is 'this' server; save on network and protobuf
invocations.
|
Modifier and Type | Method and Description |
---|---|
static Connection |
ConnectionFactory.createConnection()
Create a new Connection instance using default HBaseConfiguration.
|
static Connection |
ConnectionFactory.createConnection(org.apache.hadoop.conf.Configuration conf)
Create a new Connection instance using the passed
conf instance. |
static Connection |
ConnectionFactory.createConnection(org.apache.hadoop.conf.Configuration conf,
ExecutorService pool)
Create a new Connection instance using the passed
conf instance. |
static Connection |
ConnectionFactory.createConnection(org.apache.hadoop.conf.Configuration conf,
ExecutorService pool,
User user)
Create a new Connection instance using the passed
conf instance. |
static Connection |
ConnectionFactory.createConnection(org.apache.hadoop.conf.Configuration conf,
User user)
Create a new Connection instance using the passed
conf instance. |
Connection |
HBaseAdmin.getConnection() |
Connection |
Admin.getConnection() |
protected Connection |
HTable.getConnection()
INTERNAL Used by unit tests and tools to do low-level
manipulations.
|
Modifier and Type | Method and Description |
---|---|
void |
SecureBulkLoadClient.cleanupBulkLoad(Connection conn,
String bulkToken) |
static org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.GetQuotaStatesResponse |
QuotaStatusCalls.getMasterQuotaStates(Connection conn,
RpcControllerFactory factory,
RpcRetryingCallerFactory rpcCaller,
int timeout)
Executes an RPC tot he HBase master to fetch its view on space quotas.
|
static org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.GetSpaceQuotaRegionSizesResponse |
QuotaStatusCalls.getMasterRegionSizes(Connection conn,
RpcControllerFactory factory,
RpcRetryingCallerFactory rpcCaller,
int timeout)
Executes an RPC to the HBase master to fetch its view on the Region sizes.
|
String |
SecureBulkLoadClient.prepareBulkLoad(Connection conn) |
Constructor and Description |
---|
ClientServiceCallable(Connection connection,
TableName tableName,
byte[] row,
org.apache.hbase.thirdparty.com.google.protobuf.RpcController rpcController,
int priority) |
HTableMultiplexer(Connection conn,
org.apache.hadoop.conf.Configuration conf,
int perRegionServerBufferQueueSize) |
NoncedRegionServerCallable(Connection connection,
TableName tableName,
byte[] row,
HBaseRpcController rpcController,
int priority) |
RegionServerCallable(Connection connection,
TableName tableName,
byte[] row,
org.apache.hbase.thirdparty.com.google.protobuf.RpcController rpcController) |
RegionServerCallable(Connection connection,
TableName tableName,
byte[] row,
org.apache.hbase.thirdparty.com.google.protobuf.RpcController rpcController,
int priority) |
Modifier and Type | Method and Description |
---|---|
protected static Result |
QuotaTableUtil.doGet(Connection connection,
Get get) |
protected static Result[] |
QuotaTableUtil.doGet(Connection connection,
List<Get> gets) |
static SpaceQuotaSnapshot |
QuotaTableUtil.getCurrentSnapshot(Connection conn,
String namespace)
Returns the Master's view of a quota on the given
namespace or null if the
Master has no quota information on that namespace. |
static SpaceQuotaSnapshot |
QuotaTableUtil.getCurrentSnapshot(Connection conn,
TableName tn)
Returns the Master's view of a quota on the given
tableName or null if the
Master has no quota information on that table. |
static Map<TableName,Long> |
QuotaTableUtil.getMasterReportedTableSizes(Connection conn)
Fetches the table sizes on the filesystem as tracked by the HBase Master.
|
static org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Quotas |
QuotaTableUtil.getNamespaceQuota(Connection connection,
String namespace) |
static Map<String,Long> |
QuotaTableUtil.getObservedSnapshotSizes(Connection conn)
Fetches any persisted HBase snapshot sizes stored in the quota table.
|
static Map<TableName,SpaceQuotaSnapshot> |
QuotaTableUtil.getRegionServerQuotaSnapshots(Connection conn,
ServerName regionServer)
Fetches the observed
SpaceQuotaSnapshot s observed by a RegionServer. |
static Map<TableName,SpaceQuotaSnapshot> |
QuotaTableUtil.getSnapshots(Connection conn)
Fetches all
SpaceQuotaSnapshot objects from the hbase:quota table. |
static org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Quotas |
QuotaTableUtil.getTableQuota(Connection connection,
TableName table) |
static org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Quotas |
QuotaTableUtil.getUserQuota(Connection connection,
String user) |
static org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Quotas |
QuotaTableUtil.getUserQuota(Connection connection,
String user,
String namespace) |
static org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Quotas |
QuotaTableUtil.getUserQuota(Connection connection,
String user,
TableName table) |
Modifier and Type | Method and Description |
---|---|
static List<UserPermission> |
AccessControlClient.getUserPermissions(Connection connection,
String tableRegex)
List all the userPermissions matching the given pattern.
|
static void |
AccessControlClient.grant(Connection connection,
String userName,
Permission.Action... actions)
Grant global permissions for the specified user.
|
static void |
AccessControlClient.grant(Connection connection,
String namespace,
String userName,
Permission.Action... actions)
Grants permission on the specified namespace for the specified user.
|
static void |
AccessControlClient.grant(Connection connection,
TableName tableName,
String userName,
byte[] family,
byte[] qual,
Permission.Action... actions)
Grants permission on the specified table for the specified user.
|
static boolean |
AccessControlClient.isAccessControllerRunning(Connection connection) |
static boolean |
AccessControlClient.isAuthorizationEnabled(Connection connection)
Return true if authorization is supported and enabled
|
static boolean |
AccessControlClient.isCellAuthorizationEnabled(Connection connection)
Return true if cell authorization is supported and enabled
|
static void |
AccessControlClient.revoke(Connection connection,
String userName,
Permission.Action... actions)
Revoke global permissions for the specified user.
|
static void |
AccessControlClient.revoke(Connection connection,
String namespace,
String userName,
Permission.Action... actions)
Revokes the permission on the table for the specified user.
|
static void |
AccessControlClient.revoke(Connection connection,
TableName tableName,
String username,
byte[] family,
byte[] qualifier,
Permission.Action... actions)
Revokes the permission on the table
|
Copyright © 2007–2018 The Apache Software Foundation. All rights reserved.