Package | Description |
---|---|
org.apache.hadoop.hbase | |
org.apache.hadoop.hbase.client |
Provides HBase Client
|
org.apache.hadoop.hbase.client.example | |
org.apache.hadoop.hbase.mapred |
Provides HBase MapReduce
Input/OutputFormats, a table indexing MapReduce job, and utility methods.
|
org.apache.hadoop.hbase.mapreduce |
Provides HBase MapReduce
Input/OutputFormats, a table indexing MapReduce job, and utility methods.
|
org.apache.hadoop.hbase.master | |
org.apache.hadoop.hbase.master.balancer | |
org.apache.hadoop.hbase.quotas | |
org.apache.hadoop.hbase.replication.regionserver | |
org.apache.hadoop.hbase.security.access | |
org.apache.hadoop.hbase.security.token | |
org.apache.hadoop.hbase.security.visibility | |
org.apache.hadoop.hbase.snapshot | |
org.apache.hadoop.hbase.tool |
Modifier and Type | Method and Description |
---|---|
static void |
MetaTableAccessor.addDaughter(Connection connection,
HRegionInfo regionInfo,
ServerName sn,
long openSeqNum)
Adds a daughter region entry to meta.
|
static void |
MetaTableAccessor.addRegionsToMeta(Connection connection,
List<HRegionInfo> regionInfos,
int regionReplication)
Adds a hbase:meta row for each of the specified new regions.
|
static void |
MetaTableAccessor.addRegionsToMeta(Connection connection,
List<HRegionInfo> regionInfos,
int regionReplication,
long ts)
Adds a hbase:meta row for each of the specified new regions.
|
static void |
MetaTableAccessor.addRegionToMeta(Connection connection,
HRegionInfo regionInfo)
Adds a hbase:meta row for the specified new region.
|
static void |
MetaTableAccessor.addRegionToMeta(Connection connection,
HRegionInfo regionInfo,
HRegionInfo splitA,
HRegionInfo splitB)
Adds a (single) hbase:meta row for the specified new region and its daughters.
|
static void |
MetaTableAccessor.deleteFromMetaTable(Connection connection,
List<Delete> deletes)
Delete the passed
deletes from the hbase:meta table. |
static void |
MetaTableAccessor.deleteMergeQualifiers(Connection connection,
HRegionInfo mergedRegion)
Deletes merge qualifiers for the specified merged region.
|
static void |
MetaTableAccessor.deleteRegion(Connection connection,
HRegionInfo regionInfo)
Deletes the specified region from META.
|
static void |
MetaTableAccessor.deleteRegions(Connection connection,
List<HRegionInfo> regionsInfo)
Deletes the specified regions from META.
|
static void |
MetaTableAccessor.deleteRegions(Connection connection,
List<HRegionInfo> regionsInfo,
long ts)
Deletes the specified regions from META.
|
static List<Result> |
MetaTableAccessor.fullScan(Connection connection)
Performs a full scan of
hbase:meta . |
static void |
MetaTableAccessor.fullScan(Connection connection,
MetaTableAccessor.Visitor visitor)
Performs a full scan of
hbase:meta . |
static void |
MetaTableAccessor.fullScan(Connection connection,
MetaTableAccessor.Visitor visitor,
byte[] startrow)
Performs a full scan of a catalog table.
|
static void |
MetaTableAccessor.fullScanMetaAndPrint(Connection connection) |
static List<Result> |
MetaTableAccessor.fullScanOfMeta(Connection connection)
Performs a full scan of a
hbase:meta table. |
static Pair<HRegionInfo,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,
HRegionInfo 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<HRegionInfo,HRegionInfo> |
MetaTableAccessor.getRegionsFromMergeQualifier(Connection connection,
byte[] regionName)
Get regions from the merge qualifier of the specified merged region
|
static NavigableMap<HRegionInfo,Result> |
MetaTableAccessor.getServerUserRegions(Connection connection,
ServerName serverName) |
static List<HRegionInfo> |
MetaTableAccessor.getTableRegions(ZooKeeperWatcher zkw,
Connection connection,
TableName tableName)
Gets all of the regions of the specified table.
|
static List<HRegionInfo> |
MetaTableAccessor.getTableRegions(ZooKeeperWatcher zkw,
Connection connection,
TableName tableName,
boolean excludeOfflinedSplitParents)
Gets all of the regions of the specified table.
|
static List<HRegionInfo> |
MetaTableAccessor.getTableRegions(ZooKeeperWatcher zkw,
Connection connection,
TableName tableName,
boolean excludeOfflinedSplitParents,
boolean excludeReplicaRegions)
Gets all of the regions of the specified table.
|
static List<Pair<HRegionInfo,ServerName>> |
MetaTableAccessor.getTableRegionsAndLocations(ZooKeeperWatcher zkw,
Connection connection,
TableName tableName) |
static List<Pair<HRegionInfo,ServerName>> |
MetaTableAccessor.getTableRegionsAndLocations(ZooKeeperWatcher zkw,
Connection connection,
TableName tableName,
boolean excludeOfflinedSplitParents) |
static List<Pair<HRegionInfo,ServerName>> |
MetaTableAccessor.getTableRegionsAndLocations(ZooKeeperWatcher zkw,
Connection connection,
TableName tableName,
boolean excludeOfflinedSplitParents,
boolean excludeReplicaRegions) |
static boolean |
MetaTableAccessor.infoServerExists(Connection connection)
Checks whether hbase:meta contains any info:server entry.
|
static void |
MetaTableAccessor.mergeRegions(Connection connection,
HRegionInfo mergedRegion,
HRegionInfo regionA,
HRegionInfo regionB,
ServerName sn,
int regionReplication,
long masterSystemTime)
Merge the two regions into one in an atomic operation.
|
static void |
MetaTableAccessor.mutateMetaTable(Connection connection,
List<Mutation> mutations)
Execute the passed
mutations against hbase:meta table. |
static void |
MetaTableAccessor.mutateRegions(Connection connection,
List<HRegionInfo> regionsToRemove,
List<HRegionInfo> regionsToAdd)
Adds and Removes the specified regions from hbase:meta
|
static void |
MetaTableAccessor.overwriteRegions(Connection connection,
List<HRegionInfo> 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.splitRegion(Connection connection,
HRegionInfo parent,
HRegionInfo splitA,
HRegionInfo 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,
HRegionInfo 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.
|
Modifier and Type | Interface and Description |
---|---|
interface |
ClusterConnection
Internal methods on Connection that should not be used by user code.
|
interface |
HConnection
Deprecated.
in favor of
Connection and ConnectionFactory |
Modifier and Type | Class and Description |
---|---|
class |
CoprocessorHConnection
Connection to an HTable from within a Coprocessor.
|
Modifier and Type | Field and Description |
---|---|
protected Connection |
RegionServerCallable.connection |
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 |
Admin.getConnection() |
Modifier and Type | Method and Description |
---|---|
static NavigableMap<HRegionInfo,ServerName> |
MetaScanner.allTableRegions(org.apache.hadoop.conf.Configuration conf,
Connection connection,
TableName tableName,
boolean offlined)
Deprecated.
|
static NavigableMap<HRegionInfo,ServerName> |
MetaScanner.allTableRegions(Connection connection,
TableName tableName)
Lists all of the table regions currently in META.
|
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.
|
static List<HRegionInfo> |
MetaScanner.listAllRegions(org.apache.hadoop.conf.Configuration conf,
Connection connection,
boolean offlined)
Lists all of the regions currently in META.
|
static List<RegionLocations> |
MetaScanner.listTableRegionLocations(org.apache.hadoop.conf.Configuration conf,
Connection connection,
TableName tableName)
Lists table regions and locations grouped by region range from META.
|
static void |
MetaScanner.metaScan(Connection connection,
MetaScanner.MetaScannerVisitor visitor)
Scans the meta table and calls a visitor on each RowResult and uses a empty
start row value as table name.
|
static void |
MetaScanner.metaScan(Connection connection,
MetaScanner.MetaScannerVisitor visitor,
TableName userTableName)
Scans the meta table and calls a visitor on each RowResult.
|
static void |
MetaScanner.metaScan(Connection connection,
MetaScanner.MetaScannerVisitor visitor,
TableName userTableName,
byte[] row,
int rowLimit)
Scans the meta table and calls a visitor on each RowResult.
|
Constructor and Description |
---|
HBaseAdmin(Connection connection)
Deprecated.
Constructing HBaseAdmin objects manually has been deprecated.
Use
getAdmin() to obtain an instance of Admin instead. |
HTable(byte[] tableName,
Connection connection,
ExecutorService pool)
Deprecated.
Do not use, internal ctor.
|
HTable(TableName tableName,
Connection connection)
Deprecated.
Do not use.
|
HTable(TableName tableName,
Connection connection,
ExecutorService pool)
Deprecated.
Do not use, internal ctor.
|
HTableMultiplexer(Connection conn,
org.apache.hadoop.conf.Configuration conf,
int perRegionServerBufferQueueSize) |
PayloadCarryingServerCallable(Connection connection,
TableName tableName,
byte[] row,
RpcControllerFactory rpcControllerFactory) |
PayloadCarryingServerCallable(Connection connection,
TableName tableName,
byte[] row,
RpcControllerFactory rpcControllerFactory,
int priority) |
RegionServerCallable(Connection connection,
TableName tableName,
byte[] row) |
RegionServerCallable(Connection connection,
TableName tableName,
byte[] row,
int priority) |
Constructor and Description |
---|
MultiThreadedClientExample.ReadExampleCallable(Connection connection,
TableName tableName) |
MultiThreadedClientExample.SingleWriteExampleCallable(Connection connection,
TableName tableName) |
MultiThreadedClientExample.WriteExampleCallable(Connection connection,
TableName tableName) |
Modifier and Type | Method and Description |
---|---|
protected void |
TableInputFormatBase.initializeTable(Connection connection,
TableName tableName)
Allows subclasses to initialize the table information.
|
Modifier and Type | Method and Description |
---|---|
protected void |
LoadIncrementalHFiles.bulkLoadPhase(Table table,
Connection conn,
ExecutorService pool,
Deque<LoadIncrementalHFiles.LoadQueueItem> queue,
com.google.common.collect.Multimap<ByteBuffer,LoadIncrementalHFiles.LoadQueueItem> regionGroups)
This takes the LQI's grouped by likely regions and attempts to bulk load
them.
|
protected void |
TableInputFormatBase.initializeTable(Connection connection,
TableName tableName)
Allows subclasses to initialize the table information.
|
void |
LoadIncrementalHFiles.loadHFileQueue(Table table,
Connection conn,
Deque<LoadIncrementalHFiles.LoadQueueItem> queue,
Pair<byte[][],byte[][]> startEndKeys)
Used by the replication sink to load the hfiles from the source cluster.
|
protected List<LoadIncrementalHFiles.LoadQueueItem> |
LoadIncrementalHFiles.tryAtomicRegionLoad(Connection conn,
TableName tableName,
byte[] first,
Collection<LoadIncrementalHFiles.LoadQueueItem> lqis)
Attempts to do an atomic load of many hfiles into a region.
|
Constructor and Description |
---|
SnapshotOfRegionAssignmentFromMeta(Connection connection) |
SnapshotOfRegionAssignmentFromMeta(Connection connection,
Set<TableName> disabledTables,
boolean excludeOfflinedSplitParents) |
Modifier and Type | Method and Description |
---|---|
static void |
FavoredNodeAssignmentHelper.updateMetaWithFavoredNodesInfo(Map<HRegionInfo,List<ServerName>> regionToFavoredNodes,
Connection connection)
Update meta table with favored nodes info
|
Modifier and Type | Method and Description |
---|---|
static void |
QuotaUtil.addNamespaceQuota(Connection connection,
String namespace,
org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Quotas data) |
static void |
QuotaUtil.addTableQuota(Connection connection,
TableName table,
org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Quotas data) |
static void |
QuotaUtil.addUserQuota(Connection connection,
String user,
org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Quotas data) |
static void |
QuotaUtil.addUserQuota(Connection connection,
String user,
String namespace,
org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Quotas data) |
static void |
QuotaUtil.addUserQuota(Connection connection,
String user,
TableName table,
org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Quotas data) |
static void |
QuotaUtil.deleteNamespaceQuota(Connection connection,
String namespace) |
static void |
QuotaUtil.deleteTableQuota(Connection connection,
TableName table) |
static void |
QuotaUtil.deleteUserQuota(Connection connection,
String user) |
static void |
QuotaUtil.deleteUserQuota(Connection connection,
String user,
String namespace) |
static void |
QuotaUtil.deleteUserQuota(Connection connection,
String user,
TableName table) |
protected static Result |
QuotaTableUtil.doGet(Connection connection,
Get get) |
protected static Result[] |
QuotaTableUtil.doGet(Connection connection,
List<Get> gets) |
static <K> Map<K,QuotaState> |
QuotaUtil.fetchGlobalQuotas(String type,
Connection connection,
List<Get> gets,
org.apache.hadoop.hbase.quotas.QuotaUtil.KeyFromRow<K> kfr) |
static Map<String,QuotaState> |
QuotaUtil.fetchNamespaceQuotas(Connection connection,
List<Get> gets) |
static Map<TableName,QuotaState> |
QuotaUtil.fetchTableQuotas(Connection connection,
List<Get> gets) |
static Map<String,UserQuotaState> |
QuotaUtil.fetchUserQuotas(Connection connection,
List<Get> gets) |
static org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Quotas |
QuotaTableUtil.getNamespaceQuota(Connection connection,
String namespace) |
static org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Quotas |
QuotaTableUtil.getTableQuota(Connection connection,
TableName table) |
static org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Quotas |
QuotaTableUtil.getUserQuota(Connection connection,
String user) |
static org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Quotas |
QuotaTableUtil.getUserQuota(Connection connection,
String user,
String namespace) |
static org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Quotas |
QuotaTableUtil.getUserQuota(Connection connection,
String user,
TableName table) |
Constructor and Description |
---|
HFileReplicator(org.apache.hadoop.conf.Configuration sourceClusterConf,
String sourceBaseNamespaceDirPath,
String sourceHFileArchiveDirPath,
Map<String,List<Pair<byte[],List<String>>>> tableQueueMap,
org.apache.hadoop.conf.Configuration conf,
Connection connection,
List<String> sourceClusterIds) |
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,
boolean mergeExistingPermissions,
Permission.Action... actions)
Grant global permissions for the specified user.
|
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,
boolean mergeExistingPermissions,
Permission.Action... actions)
Grants permission on the specified namespace 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,
boolean mergeExistingPermissions,
Permission.Action... actions)
Grants permission on the specified table 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
|
Modifier and Type | Method and Description |
---|---|
static void |
TokenUtil.addTokenForJob(Connection conn,
org.apache.hadoop.mapred.JobConf job,
User user)
Checks for an authentication token for the given user, obtaining a new token if necessary,
and adds it to the credentials for the given map reduce job.
|
static void |
TokenUtil.addTokenForJob(Connection conn,
User user,
org.apache.hadoop.mapreduce.Job job)
Checks for an authentication token for the given user, obtaining a new token if necessary,
and adds it to the credentials for the given map reduce job.
|
static boolean |
TokenUtil.addTokenIfMissing(Connection conn,
User user)
Checks if an authentication tokens exists for the connected cluster,
obtaining one if needed and adding it to the user's credentials.
|
static void |
TokenUtil.obtainAndCacheToken(Connection conn,
User user)
Obtain an authentication token for the given user and add it to the
user's credentials.
|
static org.apache.hadoop.security.token.Token<AuthenticationTokenIdentifier> |
TokenUtil.obtainToken(Connection conn)
Obtain and return an authentication token for the current user.
|
static org.apache.hadoop.security.token.Token<AuthenticationTokenIdentifier> |
TokenUtil.obtainToken(Connection conn,
User user)
Obtain and return an authentication token for the current user.
|
static void |
TokenUtil.obtainTokenForJob(Connection conn,
org.apache.hadoop.mapred.JobConf job,
User user)
Obtain an authentication token on behalf of the given user and add it to
the credentials for the given map reduce job.
|
static void |
TokenUtil.obtainTokenForJob(Connection conn,
User user,
org.apache.hadoop.mapreduce.Job job)
Obtain an authentication token on behalf of the given user and add it to
the credentials for the given map reduce job.
|
Modifier and Type | Method and Description |
---|---|
static org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsResponse |
VisibilityClient.addLabel(Connection connection,
String label)
Utility method for adding label to the system.
|
static org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsResponse |
VisibilityClient.addLabels(Connection connection,
String[] labels)
Utility method for adding labels to the system.
|
static org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsResponse |
VisibilityClient.clearAuths(Connection connection,
String[] auths,
String user)
Removes given labels from user's globally authorized list of labels.
|
static org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.GetAuthsResponse |
VisibilityClient.getAuths(Connection connection,
String user) |
static boolean |
VisibilityClient.isCellVisibilityEnabled(Connection connection)
Return true if cell visibility features are supported and enabled
|
static org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.ListLabelsResponse |
VisibilityClient.listLabels(Connection connection,
String regex)
Retrieve the list of visibility labels defined in the system.
|
static org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsResponse |
VisibilityClient.setAuths(Connection connection,
String[] auths,
String user)
Sets given labels globally authorized for the user.
|
Modifier and Type | Method and Description |
---|---|
void |
RestoreSnapshotHelper.RestoreMetaChanges.updateMetaParentRegions(Connection connection,
List<HRegionInfo> regionInfos) |
Modifier and Type | Field and Description |
---|---|
protected Connection |
CanaryTool.Monitor.connection |
Constructor and Description |
---|
CanaryTool.Monitor(Connection connection,
String[] monitorTargets,
boolean useRegExp,
CanaryTool.Sink sink,
ExecutorService executor,
boolean treatFailureAsError,
long allowedFailures) |
Copyright © 2007–2019 The Apache Software Foundation. All rights reserved.