Modifier and Type | Class and Description |
---|---|
class |
SharedConnection
Wraps a Connection to make it can't be closed or aborted.
|
Modifier and Type | Field and Description |
---|---|
private Connection |
SharedConnection.conn |
Modifier and Type | Method and Description |
---|---|
Connection |
Server.createConnection(org.apache.hadoop.conf.Configuration conf) |
Connection |
Server.getConnection()
Returns a reference to the servers' connection.
|
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.
|
private static void |
MetaTableAccessor.addRegionsToMeta(Connection connection,
List<RegionInfo> regionInfos,
int regionReplication,
long ts)
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.
|
private static void |
MetaTableAccessor.deleteFromMetaTable(Connection connection,
Delete d)
Delete the passed
d from the hbase:meta table. |
private static void |
MetaTableAccessor.deleteFromMetaTable(Connection connection,
List<Delete> deletes)
Delete the passed
deletes from the hbase:meta table. |
static void |
MetaTableAccessor.deleteMergeQualifiers(Connection connection,
RegionInfo mergeRegion)
Deletes merge qualifiers for the specified merge region.
|
static void |
MetaTableAccessor.deleteRegionInfo(Connection connection,
RegionInfo regionInfo)
Deletes the specified region from META.
|
static void |
MetaTableAccessor.deleteRegionInfos(Connection connection,
List<RegionInfo> regionsInfo)
Deletes the specified regions from META.
|
private static void |
MetaTableAccessor.deleteRegionInfos(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
|
private 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) |
private static RegionInfo |
MetaTableAccessor.getClosestRegionInfo(Connection connection,
TableName tableName,
byte[] row) |
static List<RegionInfo> |
MetaTableAccessor.getMergeRegions(Connection connection,
byte[] regionName) |
static Table |
MetaTableAccessor.getMetaHTable(Connection connection)
Callers should call close on the returned
Table instance. |
private static Scan |
MetaTableAccessor.getMetaScan(Connection connection,
int rowUpperLimit) |
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 long[] |
MetaTableAccessor.getReplicationBarrier(Connection conn,
byte[] regionName) |
static MetaTableAccessor.ReplicationBarrierResult |
MetaTableAccessor.getReplicationBarrierResult(Connection conn,
TableName tableName,
byte[] row,
byte[] encodedRegionName) |
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<Pair<String,Long>> |
MetaTableAccessor.getTableEncodedRegionNameAndLastBarrier(Connection conn,
TableName tableName) |
static List<String> |
MetaTableAccessor.getTableEncodedRegionNamesForSerialReplication(Connection conn,
TableName tableName) |
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,
Map<RegionInfo,Long> parentSeqNum,
ServerName sn,
int regionReplication)
Merge regions into one in an atomic operation.
|
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. |
private static void |
MetaTableAccessor.putToMetaTable(Connection connection,
Put p)
Put the passed
p 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 Result |
MetaTableAccessor.scanByRegionEncodedName(Connection connection,
String regionEncodedName)
Scans META table for a row whose key contains the specified regionEncodedName,
returning a single related
Result instance if any row is found, null otherwise. |
private static void |
MetaTableAccessor.scanMeta(Connection connection,
byte[] startRow,
byte[] stopRow,
MetaTableAccessor.QueryType type,
Filter filter,
int maxRows,
MetaTableAccessor.Visitor visitor) |
(package private) static void |
MetaTableAccessor.scanMeta(Connection connection,
byte[] startRow,
byte[] stopRow,
MetaTableAccessor.QueryType type,
int maxRows,
MetaTableAccessor.Visitor visitor)
Performs a scan of META table.
|
private 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.
|
private 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,
long parentOpenSeqNum,
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.
|
private static void |
MetaTableAccessor.updateLocation(Connection connection,
RegionInfo regionInfo,
ServerName sn,
long openSeqNum,
long masterSystemTime)
Updates the location of the specified region to be the specified server.
|
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.updateRegionState(Connection connection,
RegionInfo ri,
RegionState.State state)
Update state column in hbase:meta.
|
static void |
MetaTableAccessor.updateTableState(Connection conn,
TableName tableName,
TableState.State actual)
Updates state in META
|
private static void |
MetaTableAccessor.updateTableState(Connection connection,
TableState state)
Update state of the table in meta.
|
Constructor and Description |
---|
SharedConnection(Connection conn) |
Constructor and Description |
---|
HFileArchiveManager(Connection 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 |
ConnectionImplementation
Main implementation of
Connection and ClusterConnection interfaces. |
(package private) static class |
ConnectionUtils.MasterlessConnection
Some tests shut down the master.
|
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 | Field and Description |
---|---|
(package private) Connection |
ConnectionImplementation.MasterServiceState.connection |
private 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. |
protected Connection |
HTable.getConnection()
INTERNAL Used by unit tests and tools to do low-level
manipulations.
|
Connection |
Admin.getConnection() |
(package private) Connection |
RegionAdminServiceCallable.getConnection() |
Connection |
HBaseAdmin.getConnection() |
Modifier and Type | Method and Description |
---|---|
void |
SecureBulkLoadClient.cleanupBulkLoad(Connection conn,
String bulkToken) |
(package private) static HTableDescriptor |
HBaseAdmin.getHTableDescriptor(TableName tableName,
Connection connection,
RpcRetryingCallerFactory rpcCallerFactory,
RpcControllerFactory rpcControllerFactory,
int operationTimeout,
int rpcTimeout)
Deprecated.
since 2.0 version and will be removed in 3.0 version.
use
HBaseAdmin.getTableDescriptor(TableName,
Connection, RpcRetryingCallerFactory,RpcControllerFactory,int,int) |
(package private) static TableDescriptor |
HBaseAdmin.getTableDescriptor(TableName tableName,
Connection connection,
RpcRetryingCallerFactory rpcCallerFactory,
RpcControllerFactory rpcControllerFactory,
int operationTimeout,
int rpcTimeout) |
String |
SecureBulkLoadClient.prepareBulkLoad(Connection conn) |
Constructor and Description |
---|
CancellableRegionServerCallable(Connection connection,
TableName tableName,
byte[] row,
org.apache.hbase.thirdparty.com.google.protobuf.RpcController rpcController,
int rpcTimeout,
RetryingTimeTracker tracker,
int priority) |
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)
Deprecated.
|
MasterCallable(Connection connection,
RpcControllerFactory rpcConnectionFactory) |
MasterServiceState(Connection connection) |
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 | Field and Description |
---|---|
private Connection |
AggregationClient.connection |
Modifier and Type | Field and Description |
---|---|
private Connection |
RefreshHFilesClient.connection |
private Connection |
MultiThreadedClientExample.WriteExampleCallable.connection |
private Connection |
MultiThreadedClientExample.SingleWriteExampleCallable.connection |
private Connection |
MultiThreadedClientExample.ReadExampleCallable.connection |
Modifier and Type | Method and Description |
---|---|
private void |
MultiThreadedClientExample.warmUpConnectionCache(Connection connection,
TableName tn) |
Constructor and Description |
---|
ReadExampleCallable(Connection connection,
TableName tableName) |
SingleWriteExampleCallable(Connection connection,
TableName tableName) |
WriteExampleCallable(Connection connection,
TableName tableName) |
Modifier and Type | Field and Description |
---|---|
private Connection |
ReplicationAdmin.connection
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
Connection |
MasterCoprocessorEnvironment.createConnection(org.apache.hadoop.conf.Configuration conf)
Creates a cluster connection using the passed Configuration.
|
Connection |
RegionCoprocessorEnvironment.createConnection(org.apache.hadoop.conf.Configuration conf)
Creates a cluster connection using the passed Configuration.
|
Connection |
RegionServerCoprocessorEnvironment.createConnection(org.apache.hadoop.conf.Configuration conf)
Creates a cluster connection using the passed Configuration.
|
Connection |
MasterCoprocessorEnvironment.getConnection()
Returns the hosts' Connection to the Cluster.
|
Connection |
RegionCoprocessorEnvironment.getConnection()
Returns the hosts' Connection to the Cluster.
|
Connection |
RegionServerCoprocessorEnvironment.getConnection()
Returns the hosts' Connection to the Cluster.
|
Modifier and Type | Method and Description |
---|---|
static void |
FavoredNodeAssignmentHelper.updateMetaWithFavoredNodesInfo(Map<RegionInfo,List<ServerName>> regionToFavoredNodes,
Connection connection)
Update meta table with favored nodes info
|
Modifier and Type | Field and Description |
---|---|
private Connection |
Screen.connection |
Modifier and Type | Field and Description |
---|---|
private Connection |
TableOutputFormat.TableRecordWriter.conn |
private Connection |
TableInputFormatBase.connection |
private Connection |
HRegionPartitioner.connection |
Modifier and Type | Method and Description |
---|---|
protected void |
TableInputFormatBase.initializeTable(Connection connection,
TableName tableName)
Allows subclasses to initialize the table information.
|
Modifier and Type | Field and Description |
---|---|
private Connection |
TableInputFormatBase.connection
The underlying
Connection of the table. |
private Connection |
HRegionPartitioner.connection |
private Connection |
TableOutputFormat.TableRecordWriter.connection |
(package private) Connection |
MultiTableOutputFormat.MultiTableRecordWriter.connection |
(package private) Connection |
SyncTable.SyncMapper.sourceConnection |
(package private) Connection |
SyncTable.SyncMapper.targetConnection |
Modifier and Type | Method and Description |
---|---|
private static Connection |
SyncTable.SyncMapper.openConnection(org.apache.hadoop.conf.Configuration conf,
String zkClusterConfKey,
String configPrefix) |
Modifier and Type | Method and Description |
---|---|
protected void |
TableInputFormatBase.initializeTable(Connection connection,
TableName tableName)
Allows subclasses to initialize the table information.
|
private static Table |
SyncTable.SyncMapper.openTable(Connection connection,
org.apache.hadoop.conf.Configuration conf,
String tableNameConfKey) |
Modifier and Type | Field and Description |
---|---|
private Connection |
VerifyReplication.Verifier.replicatedConnection |
private Connection |
VerifyReplication.Verifier.sourceConnection |
Modifier and Type | Field and Description |
---|---|
private Connection |
RegionPlacementMaintainer.connection |
private Connection |
SnapshotOfRegionAssignmentFromMeta.connection |
Modifier and Type | Method and Description |
---|---|
Connection |
MasterCoprocessorHost.MasterEnvironment.createConnection(org.apache.hadoop.conf.Configuration conf) |
Connection |
MasterCoprocessorHost.MasterEnvironment.getConnection() |
Modifier and Type | Method and Description |
---|---|
private void |
TableStateManager.fixTableStates(TableDescriptors tableDescriptors,
Connection connection) |
Constructor and Description |
---|
SnapshotOfRegionAssignmentFromMeta(Connection connection) |
SnapshotOfRegionAssignmentFromMeta(Connection connection,
Set<TableName> disabledTables,
boolean excludeOfflinedSplitParents) |
Modifier and Type | Field and Description |
---|---|
private Connection |
ReplicationBarrierCleaner.conn |
Constructor and Description |
---|
ReplicationBarrierCleaner(org.apache.hadoop.conf.Configuration conf,
Stoppable stopper,
Connection conn,
ReplicationPeerManager peerManager) |
Modifier and Type | Field and Description |
---|---|
private Connection |
HBCKServerCrashProcedure.UnknownServerVisitor.connection |
Modifier and Type | Method and Description |
---|---|
private int |
EnableTableProcedure.getNumberOfReplicasFromMeta(Connection connection,
int regionReplicaCount,
List<RegionInfo> regionsOfTable) |
private Result |
EnableTableProcedure.getRegionFromMeta(Connection connection,
List<RegionInfo> regionsOfTable) |
Constructor and Description |
---|
UnknownServerVisitor(Connection connection,
ServerName unknownServerName) |
Modifier and Type | Method and Description |
---|---|
private void |
PartitionedMobCompactor.bulkloadRefFile(Connection connection,
Table table,
org.apache.hadoop.fs.Path bulkloadDirectory,
String fileName)
Bulkloads the current file.
|
private List<org.apache.hadoop.fs.Path> |
PartitionedMobCompactor.compactMobFilePartition(PartitionedMobCompactionRequest request,
PartitionedMobCompactionRequest.CompactionPartition partition,
List<HStoreFile> delFiles,
Connection connection,
Table table)
Compacts a partition of selected small mob files and all the del files.
|
private void |
PartitionedMobCompactor.compactMobFilesInBatch(PartitionedMobCompactionRequest request,
PartitionedMobCompactionRequest.CompactionPartition partition,
Connection connection,
Table table,
List<HStoreFile> filesToCompact,
int batch,
org.apache.hadoop.fs.Path bulkloadPathOfPartition,
org.apache.hadoop.fs.Path bulkloadColumnPath,
List<org.apache.hadoop.fs.Path> newFiles)
Compacts a partition of selected small mob files and all the del files in a batch.
|
Modifier and Type | Field and Description |
---|---|
private Connection |
SpaceQuotaRefresherChore.conn |
(package private) Connection |
FileArchiverNotifierFactoryImpl.CacheKey.conn |
private Connection |
SnapshotQuotaObserverChore.conn |
private Connection |
TableSpaceQuotaSnapshotNotifier.conn |
private Connection |
FileArchiverNotifierImpl.conn |
private Connection |
QuotaObserverChore.conn |
private Connection |
QuotaObserverChore.TablesWithQuotas.conn |
private Connection |
NamespaceQuotaSnapshotStore.conn |
private Connection |
TableQuotaSnapshotStore.conn |
private Connection |
QuotaRetriever.connection
Connection to use.
|
Modifier and Type | Method and Description |
---|---|
(package private) Connection |
SpaceQuotaRefresherChore.getConnection() |
(package private) Connection |
RegionServerSpaceQuotaManager.getConnection() |
Modifier and Type | Method and Description |
---|---|
static void |
QuotaUtil.addNamespaceQuota(Connection connection,
String namespace,
org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Quotas data) |
private static void |
QuotaUtil.addQuotas(Connection connection,
byte[] rowKey,
byte[] qualifier,
org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Quotas data) |
private static void |
QuotaUtil.addQuotas(Connection connection,
byte[] rowKey,
org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Quotas data) |
static void |
QuotaUtil.addRegionServerQuota(Connection connection,
String regionServer,
org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Quotas data) |
static void |
QuotaUtil.addTableQuota(Connection connection,
TableName table,
org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Quotas data) |
static void |
QuotaUtil.addUserQuota(Connection connection,
String user,
org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Quotas data) |
static void |
QuotaUtil.addUserQuota(Connection connection,
String user,
String namespace,
org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Quotas data) |
static void |
QuotaUtil.addUserQuota(Connection connection,
String user,
TableName table,
org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Quotas data) |
(package private) static List<Delete> |
QuotaTableUtil.createDeletesForExistingNamespaceSnapshotSizes(Connection connection)
Returns a list of
Delete to remove all namespace snapshot entries from quota table. |
(package private) static List<Delete> |
QuotaTableUtil.createDeletesForExistingSnapshotsFromScan(Connection connection,
Scan scan)
Returns a list of
Delete to remove all entries returned by the passed scanner. |
(package private) static List<Delete> |
QuotaTableUtil.createDeletesForExistingTableSnapshotSizes(Connection connection)
Returns a list of
Delete to remove all table snapshot entries from quota table. |
static void |
QuotaUtil.deleteNamespaceQuota(Connection connection,
String namespace) |
private static void |
QuotaUtil.deleteQuotas(Connection connection,
byte[] rowKey) |
private static void |
QuotaUtil.deleteQuotas(Connection connection,
byte[] rowKey,
byte[] qualifier) |
static void |
QuotaUtil.deleteRegionServerQuota(Connection connection,
String regionServer) |
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) |
static void |
QuotaUtil.disableTableIfNotDisabled(Connection conn,
TableName tableName)
Method to disable a table, if not already disabled.
|
private static void |
QuotaUtil.doDelete(Connection connection,
Delete delete) |
protected static Result |
QuotaTableUtil.doGet(Connection connection,
Get get) |
protected static Result[] |
QuotaTableUtil.doGet(Connection connection,
List<Get> gets) |
private static void |
QuotaUtil.doPut(Connection connection,
Put put) |
static void |
QuotaUtil.enableTableIfNotEnabled(Connection conn,
TableName tableName)
Method to enable a table, if not already enabled.
|
static <K> Map<K,QuotaState> |
QuotaUtil.fetchGlobalQuotas(String type,
Connection connection,
List<Get> gets,
QuotaUtil.KeyFromRow<K> kfr) |
static Map<String,QuotaState> |
QuotaUtil.fetchNamespaceQuotas(Connection connection,
List<Get> gets,
double factor) |
static Map<String,QuotaState> |
QuotaUtil.fetchRegionServerQuotas(Connection connection,
List<Get> gets) |
static Map<TableName,QuotaState> |
QuotaUtil.fetchTableQuotas(Connection connection,
List<Get> gets,
Map<TableName,Double> tableMachineFactors) |
static Map<String,UserQuotaState> |
QuotaUtil.fetchUserQuotas(Connection connection,
List<Get> gets,
Map<TableName,Double> tableMachineQuotaFactors,
double factor) |
FileArchiverNotifier |
FileArchiverNotifierFactoryImpl.get(Connection conn,
org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
TableName tn)
Returns the
FileArchiverNotifier instance for the given TableName . |
FileArchiverNotifier |
FileArchiverNotifierFactory.get(Connection conn,
org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
TableName tn)
Creates or obtains a
FileArchiverNotifier instance for the given args. |
static SpaceQuotaSnapshot |
QuotaTableUtil.getCurrentSnapshotFromQuotaTable(Connection conn,
TableName tableName) |
static org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Quotas |
QuotaTableUtil.getNamespaceQuota(Connection connection,
String namespace) |
static Set<String> |
QuotaTableUtil.getNamespaceSnapshots(Connection conn)
Returns a set of the names of all namespaces containing snapshot entries.
|
(package private) static long |
QuotaTableUtil.getNamespaceSnapshotSize(Connection conn,
String namespace)
Fetches the computed size of all snapshots against tables in a namespace for space quotas.
|
static Map<String,Long> |
QuotaTableUtil.getObservedSnapshotSizes(Connection conn)
Fetches any persisted HBase snapshot sizes stored in the quota table.
|
private static org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Quotas |
QuotaTableUtil.getQuotas(Connection connection,
byte[] rowKey) |
private static org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Quotas |
QuotaTableUtil.getQuotas(Connection connection,
byte[] rowKey,
byte[] qualifier) |
static org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Quotas |
QuotaTableUtil.getRegionServerQuota(Connection connection,
String 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.hbase.thirdparty.com.google.common.collect.Multimap<TableName,String> |
QuotaTableUtil.getTableSnapshots(Connection conn)
Returns a multimap for all existing table snapshot entries.
|
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) |
(package private) void |
QuotaRetriever.init(Connection conn,
Scan scan) |
void |
TableSpaceQuotaSnapshotNotifier.initialize(Connection conn) |
void |
SpaceQuotaSnapshotNotifier.initialize(Connection conn)
Initializes the notifier.
|
protected static boolean |
QuotaUtil.isExceedThrottleQuotaEnabled(Connection connection) |
void |
MasterQuotaManager.processFileArchivals(org.apache.hadoop.hbase.shaded.protobuf.generated.RegionServerStatusProtos.FileArchiveNotificationRequest request,
Connection conn,
org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs) |
protected static void |
QuotaUtil.switchExceedThrottleQuota(Connection connection,
boolean exceedThrottleQuotaEnabled) |
Constructor and Description |
---|
CacheKey(Connection conn,
org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
TableName tn) |
FileArchiverNotifierImpl(Connection conn,
org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
TableName tn) |
NamespaceQuotaSnapshotStore(Connection conn,
QuotaObserverChore chore,
Map<RegionInfo,Long> regionUsage) |
QuotaObserverChore(Connection conn,
org.apache.hadoop.conf.Configuration conf,
SpaceQuotaSnapshotNotifier snapshotNotifier,
MasterQuotaManager quotaManager,
Stoppable stopper,
MetricsMaster metrics) |
SnapshotQuotaObserverChore(Connection conn,
org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
Stoppable stopper,
MetricsMaster metrics) |
SpaceQuotaRefresherChore(RegionServerSpaceQuotaManager manager,
Connection conn) |
TableQuotaSnapshotStore(Connection conn,
QuotaObserverChore chore,
Map<RegionInfo,Long> regionUsage) |
TablesWithQuotas(Connection conn,
org.apache.hadoop.conf.Configuration conf) |
Modifier and Type | Field and Description |
---|---|
private Connection |
SecureBulkLoadManager.conn |
Modifier and Type | Method and Description |
---|---|
Connection |
RegionCoprocessorHost.RegionEnvironment.createConnection(org.apache.hadoop.conf.Configuration conf) |
Connection |
RegionServerCoprocessorHost.RegionServerEnvironment.createConnection(org.apache.hadoop.conf.Configuration conf) |
Connection |
HRegionServer.createConnection(org.apache.hadoop.conf.Configuration conf) |
Connection |
RegionCoprocessorHost.RegionEnvironment.getConnection() |
Connection |
RegionServerCoprocessorHost.RegionServerEnvironment.getConnection() |
Connection |
HRegionServer.getConnection() |
Constructor and Description |
---|
SecureBulkLoadManager(org.apache.hadoop.conf.Configuration conf,
Connection conn) |
Modifier and Type | Field and Description |
---|---|
private Connection |
ReplicationSinkManager.conn |
private Connection |
SerialReplicationChecker.conn |
private Connection |
HFileReplicator.connection |
private Connection |
ReplicationSink.sharedHtableCon |
Modifier and Type | Method and Description |
---|---|
Connection |
ReplicationSyncUp.DummyServer.createConnection(org.apache.hadoop.conf.Configuration conf) |
private Connection |
ReplicationSink.getConnection() |
Modifier and Type | Method and Description |
---|---|
void |
WALEntrySinkFilter.init(Connection connection)
Called after Construction.
|
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 | Field and Description |
---|---|
private Connection |
RSGroupInfoManagerImpl.conn |
Constructor and Description |
---|
RSGroupAdminClient(Connection conn) |
Modifier and Type | Method and Description |
---|---|
static List<UserPermission> |
AccessControlClient.getUserPermissions(Connection connection,
String tableRegex)
List all the userPermissions matching the given pattern.
|
static List<UserPermission> |
AccessControlClient.getUserPermissions(Connection connection,
String tableRegex,
byte[] columnFamily)
List all the userPermissions matching the given table pattern and column family.
|
static List<UserPermission> |
AccessControlClient.getUserPermissions(Connection connection,
String tableRegex,
byte[] columnFamily,
byte[] columnQualifier)
List all the userPermissions matching the given table pattern, column family and column
qualifier.
|
static List<UserPermission> |
AccessControlClient.getUserPermissions(Connection connection,
String tableRegex,
byte[] columnFamily,
byte[] columnQualifier,
String userName)
List all the userPermissions matching the given table pattern, column family and column
qualifier.
|
static List<UserPermission> |
AccessControlClient.getUserPermissions(Connection connection,
String tableRegex,
byte[] columnFamily,
String userName)
List all the userPermissions matching the given table pattern, column family and user name.
|
static List<UserPermission> |
AccessControlClient.getUserPermissions(Connection connection,
String tableRegex,
String userName)
List all the userPermissions matching the given table pattern and user name.
|
private 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.
|
private 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.
|
private 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.hasPermission(Connection connection,
String tableName,
byte[] columnFamily,
byte[] columnQualifier,
String userName,
Permission.Action... actions)
Validates whether specified user has permission to perform actions on the mentioned table,
column family or column qualifier.
|
static boolean |
AccessControlClient.hasPermission(Connection connection,
String tableName,
String columnFamily,
String columnQualifier,
String userName,
Permission.Action... actions)
Validates whether specified user has permission to perform actions on the mentioned table,
column family or column qualifier.
|
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 namespace 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.
|
private static org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsResponse |
VisibilityClient.setOrClearAuths(Connection connection,
String[] auths,
String user,
boolean setOrClear) |
Modifier and Type | Method and Description |
---|---|
void |
RestoreSnapshotHelper.RestoreMetaChanges.updateMetaParentRegions(Connection connection,
List<RegionInfo> regionInfos) |
Modifier and Type | Class and Description |
---|---|
class |
ThriftConnection |
Modifier and Type | Method and Description |
---|---|
Connection |
ThriftAdmin.getConnection() |
Modifier and Type | Field and Description |
---|---|
private Connection |
CanaryTool.ZookeeperTask.connection |
private Connection |
CanaryTool.RegionTask.connection |
private Connection |
CanaryTool.RegionServerTask.connection |
protected Connection |
CanaryTool.Monitor.connection |
Modifier and Type | Method and Description |
---|---|
protected ClientServiceCallable<byte[]> |
LoadIncrementalHFiles.buildClientServiceCallable(Connection conn,
TableName tableName,
byte[] first,
Collection<LoadIncrementalHFiles.LoadQueueItem> lqis,
boolean copyFile)
Deprecated.
|
protected void |
LoadIncrementalHFiles.bulkLoadPhase(Table table,
Connection conn,
ExecutorService pool,
Deque<LoadIncrementalHFiles.LoadQueueItem> queue,
org.apache.hbase.thirdparty.com.google.common.collect.Multimap<ByteBuffer,LoadIncrementalHFiles.LoadQueueItem> regionGroups,
boolean copyFile,
Map<LoadIncrementalHFiles.LoadQueueItem,ByteBuffer> item2RegionMap)
Deprecated.
This takes the LQI's grouped by likely regions and attempts to bulk load them.
|
void |
LoadIncrementalHFiles.loadHFileQueue(Table table,
Connection conn,
Deque<LoadIncrementalHFiles.LoadQueueItem> queue,
Pair<byte[][],byte[][]> startEndKeys)
Deprecated.
Used by the replication sink to load the hfiles from the source cluster.
|
void |
LoadIncrementalHFiles.loadHFileQueue(Table table,
Connection conn,
Deque<LoadIncrementalHFiles.LoadQueueItem> queue,
Pair<byte[][],byte[][]> startEndKeys,
boolean copyFile)
Deprecated.
Used by the replication sink to load the hfiles from the source cluster.
|
private CanaryTool.Monitor |
CanaryTool.newMonitor(Connection connection,
String[] monitorTargets)
A Factory method for
CanaryTool.Monitor . |
Constructor and Description |
---|
Monitor(Connection connection,
String[] monitorTargets,
boolean useRegExp,
CanaryTool.Sink sink,
ExecutorService executor,
boolean treatFailureAsError,
long allowedFailures) |
RegionMonitor(Connection connection,
String[] monitorTargets,
boolean useRegExp,
CanaryTool.Sink sink,
ExecutorService executor,
boolean writeSniffing,
TableName writeTableName,
boolean treatFailureAsError,
HashMap<String,Long> configuredReadTableTimeouts,
long configuredWriteTableTimeout,
long allowedFailures) |
RegionServerMonitor(Connection connection,
String[] monitorTargets,
boolean useRegExp,
CanaryTool.Sink sink,
ExecutorService executor,
boolean allRegions,
boolean treatFailureAsError,
long allowedFailures) |
RegionServerTask(Connection connection,
String serverName,
RegionInfo region,
CanaryTool.RegionServerStdOutSink sink,
AtomicLong successes) |
RegionTask(Connection connection,
RegionInfo region,
ServerName serverName,
CanaryTool.RegionStdOutSink sink,
CanaryTool.RegionTask.TaskType taskType,
boolean rawScanEnabled,
LongAdder rwLatency) |
ZookeeperMonitor(Connection connection,
String[] monitorTargets,
boolean useRegExp,
CanaryTool.Sink sink,
ExecutorService executor,
boolean treatFailureAsError,
long allowedFailures) |
ZookeeperTask(Connection connection,
String host,
String znode,
int timeout,
CanaryTool.ZookeeperStdOutSink sink) |
Modifier and Type | Field and Description |
---|---|
private Connection |
RegionMover.conn |
(package private) Connection |
ConnectionCache.ConnectionInfo.connection |
private Connection[] |
MultiHConnection.connections |
Modifier and Type | Method and Description |
---|---|
static void |
HBaseFsckRepair.closeRegionSilentlyAndWait(Connection connection,
ServerName server,
RegionInfo region)
Contacts a region server and waits up to hbase.hbck.close.timeout ms
(default 120s) to close the region.
|
static void |
HBaseFsckRepair.fixMultiAssignment(Connection connection,
RegionInfo 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.
|
private static int |
RegionSplitter.getRegionServerCount(Connection connection)
Alternative getCurrentNrHRS which is no longer available.
|
(package private) static LinkedList<Pair<byte[],byte[]>> |
RegionSplitter.getSplits(Connection connection,
TableName tableName,
RegionSplitter.SplitAlgorithm splitAlgo) |
(package private) static LinkedList<Pair<byte[],byte[]>> |
RegionSplitter.splitScan(LinkedList<Pair<byte[],byte[]>> regionList,
Connection connection,
TableName tableName,
RegionSplitter.SplitAlgorithm splitAlgo) |
Constructor and Description |
---|
ConnectionInfo(Connection conn,
String user) |
Modifier and Type | Field and Description |
---|---|
private Connection |
MajorCompactor.connection |
Modifier and Type | Method and Description |
---|---|
(package private) Connection |
MajorCompactionRequest.getConnection(org.apache.hadoop.conf.Configuration configuration) |
Modifier and Type | Method and Description |
---|---|
(package private) HRegionFileSystem |
MajorCompactionRequest.getFileSystem(Connection connection) |
Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.