Uses of Interface
org.apache.hadoop.hbase.client.Connection
Package
Description
Provides HBase Client
Table of Contents
Provides HBase MapReduce
Input/OutputFormats, a table indexing MapReduce job, and utility methods.
Provides HBase MapReduce
Input/OutputFormats, a table indexing MapReduce job, and utility methods.
Multi Cluster Replication
-
Uses of org.apache.hadoop.hbase.client.Connection in org.apache.hadoop.hbase
Modifier and TypeMethodDescriptionorg.apache.hadoop.hbase.client.Connection
HBaseServerBase.createConnection
(org.apache.hadoop.conf.Configuration conf) org.apache.hadoop.hbase.client.Connection
MockRegionServerServices.createConnection
(org.apache.hadoop.conf.Configuration conf) org.apache.hadoop.hbase.client.Connection
Server.createConnection
(org.apache.hadoop.conf.Configuration conf) org.apache.hadoop.hbase.client.Connection
HBaseTestingUtility.getConnection()
Deprecated.Get a shared Connection to the cluster.org.apache.hadoop.hbase.client.Connection
HBaseTestingUtility.getConnection
(org.apache.hadoop.hbase.security.User user) Deprecated.Get a assigned Connection to the cluster.org.apache.hadoop.hbase.client.Connection
MockRegionServerServices.getConnection()
default org.apache.hadoop.hbase.client.Connection
Server.getConnection()
Returns a reference to the servers' connection.Modifier and TypeMethodDescriptionstatic void
MetaTableAccessor.addRegionsToMeta
(org.apache.hadoop.hbase.client.Connection connection, List<org.apache.hadoop.hbase.client.RegionInfo> regionInfos, int regionReplication) Adds a hbase:meta row for each of the specified new regions.static void
MetaTableAccessor.addRegionsToMeta
(org.apache.hadoop.hbase.client.Connection connection, List<org.apache.hadoop.hbase.client.RegionInfo> regionInfos, int regionReplication, long ts) Adds a hbase:meta row for each of the specified new regions.static void
MetaTableAccessor.addSplitsToParent
(org.apache.hadoop.hbase.client.Connection connection, org.apache.hadoop.hbase.client.RegionInfo regionInfo, org.apache.hadoop.hbase.client.RegionInfo splitA, org.apache.hadoop.hbase.client.RegionInfo splitB) Adds daughter region infos to hbase:meta row for the specified region.static void
MetaTableAccessor.deleteTableState
(org.apache.hadoop.hbase.client.Connection connection, org.apache.hadoop.hbase.TableName table) Remove state for table from metastatic void
MetaTableAccessor.fullScanMetaAndPrint
(org.apache.hadoop.hbase.client.Connection connection) static List<org.apache.hadoop.hbase.client.Result>
MetaTableAccessor.fullScanRegions
(org.apache.hadoop.hbase.client.Connection connection) Performs a full scan ofhbase:meta
for regions.static void
MetaTableAccessor.fullScanRegions
(org.apache.hadoop.hbase.client.Connection connection, org.apache.hadoop.hbase.ClientMetaTableAccessor.Visitor visitor) Performs a full scan ofhbase:meta
for regions.static void
MetaTableAccessor.fullScanTables
(org.apache.hadoop.hbase.client.Connection connection, org.apache.hadoop.hbase.ClientMetaTableAccessor.Visitor visitor) Performs a full scan ofhbase:meta
for tables.static List<org.apache.hadoop.hbase.client.RegionInfo>
MetaTableAccessor.getAllRegions
(org.apache.hadoop.hbase.client.Connection connection, boolean excludeOfflinedSplitParents) Lists all of the regions currently in META.static org.apache.hadoop.hbase.client.Result
MetaTableAccessor.getCatalogFamilyRow
(org.apache.hadoop.hbase.client.Connection connection, org.apache.hadoop.hbase.client.RegionInfo ri) Returns Return theHConstants.CATALOG_FAMILY
row from hbase:meta.static org.apache.hadoop.hbase.client.Table
MetaTableAccessor.getMetaHTable
(org.apache.hadoop.hbase.client.Connection connection) Callers should call close on the returnedTable
instance.static int
HBaseTestingUtility.getMetaRSPort
(org.apache.hadoop.hbase.client.Connection connection) Deprecated.static org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.client.RegionInfo,
org.apache.hadoop.hbase.ServerName> MetaTableAccessor.getRegion
(org.apache.hadoop.hbase.client.Connection connection, byte[] regionName) Deprecated.static org.apache.hadoop.hbase.HRegionLocation
MetaTableAccessor.getRegionLocation
(org.apache.hadoop.hbase.client.Connection connection, byte[] regionName) Returns the HRegionLocation from meta for the given regionstatic org.apache.hadoop.hbase.HRegionLocation
MetaTableAccessor.getRegionLocation
(org.apache.hadoop.hbase.client.Connection connection, org.apache.hadoop.hbase.client.RegionInfo regionInfo) Returns the HRegionLocation from meta for the given regionstatic org.apache.hadoop.hbase.client.Result
MetaTableAccessor.getRegionResult
(org.apache.hadoop.hbase.client.Connection connection, org.apache.hadoop.hbase.client.RegionInfo regionInfo) Gets the result in hbase:meta for the specified region.static List<org.apache.hadoop.hbase.client.RegionInfo>
MetaTableAccessor.getTableRegions
(org.apache.hadoop.hbase.client.Connection connection, org.apache.hadoop.hbase.TableName tableName) Gets all of the regions of the specified table.static List<org.apache.hadoop.hbase.client.RegionInfo>
MetaTableAccessor.getTableRegions
(org.apache.hadoop.hbase.client.Connection connection, org.apache.hadoop.hbase.TableName tableName, boolean excludeOfflinedSplitParents) Gets all of the regions of the specified table.static List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.client.RegionInfo,
org.apache.hadoop.hbase.ServerName>> MetaTableAccessor.getTableRegionsAndLocations
(org.apache.hadoop.hbase.client.Connection connection, org.apache.hadoop.hbase.TableName tableName) Do not use this method to get meta table regions, use methods in MetaTableLocator instead.static List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.client.RegionInfo,
org.apache.hadoop.hbase.ServerName>> MetaTableAccessor.getTableRegionsAndLocations
(org.apache.hadoop.hbase.client.Connection connection, org.apache.hadoop.hbase.TableName tableName, boolean excludeOfflinedSplitParents) Do not use this method to get meta table regions, use methods in MetaTableLocator instead.static org.apache.hadoop.hbase.client.TableState
MetaTableAccessor.getTableState
(org.apache.hadoop.hbase.client.Connection conn, org.apache.hadoop.hbase.TableName tableName) Fetch table state for given table from META tablestatic Map<org.apache.hadoop.hbase.TableName,
org.apache.hadoop.hbase.client.TableState> MetaTableAccessor.getTableStates
(org.apache.hadoop.hbase.client.Connection conn) Fetch table states from META tablestatic void
MetaTableAccessor.putsToMetaTable
(org.apache.hadoop.hbase.client.Connection connection, List<org.apache.hadoop.hbase.client.Put> ps) Put the passedps
to thehbase:meta
table.static org.apache.hadoop.hbase.client.Result
MetaTableAccessor.scanByRegionEncodedName
(org.apache.hadoop.hbase.client.Connection connection, String regionEncodedName) Scans META table for a row whose key contains the specified regionEncodedName, returning a single relatedResult
instance if any row is found, null otherwise.static void
MetaTableAccessor.scanMeta
(org.apache.hadoop.hbase.client.Connection connection, byte[] startRow, byte[] stopRow, org.apache.hadoop.hbase.ClientMetaTableAccessor.QueryType type, int maxRows, org.apache.hadoop.hbase.ClientMetaTableAccessor.Visitor visitor) Performs a scan of META table.static void
MetaTableAccessor.scanMeta
(org.apache.hadoop.hbase.client.Connection connection, byte[] startRow, byte[] stopRow, org.apache.hadoop.hbase.ClientMetaTableAccessor.QueryType type, org.apache.hadoop.hbase.ClientMetaTableAccessor.Visitor visitor) static void
MetaTableAccessor.scanMeta
(org.apache.hadoop.hbase.client.Connection connection, byte[] startRow, byte[] stopRow, org.apache.hadoop.hbase.ClientMetaTableAccessor.QueryType type, org.apache.hadoop.hbase.filter.Filter filter, int maxRows, org.apache.hadoop.hbase.ClientMetaTableAccessor.Visitor visitor) static void
MetaTableAccessor.scanMeta
(org.apache.hadoop.hbase.client.Connection connection, org.apache.hadoop.hbase.ClientMetaTableAccessor.Visitor visitor, org.apache.hadoop.hbase.TableName tableName, byte[] row, int rowLimit) Performs a scan of META table for given table starting from given row.static void
MetaTableAccessor.scanMetaForTableRegions
(org.apache.hadoop.hbase.client.Connection connection, org.apache.hadoop.hbase.ClientMetaTableAccessor.Visitor visitor, org.apache.hadoop.hbase.TableName tableName) static void
MetaTableAccessor.updateRegionLocation
(org.apache.hadoop.hbase.client.Connection connection, org.apache.hadoop.hbase.client.RegionInfo regionInfo, org.apache.hadoop.hbase.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
(org.apache.hadoop.hbase.client.Connection connection, org.apache.hadoop.hbase.client.RegionInfo ri, org.apache.hadoop.hbase.master.RegionState.State state) Update state column in hbase:meta.static void
MetaTableAccessor.updateTableState
(org.apache.hadoop.hbase.client.Connection conn, org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.TableState.State actual) Updates state in META Do not use. -
Uses of org.apache.hadoop.hbase.client.Connection in org.apache.hadoop.hbase.backup
Modifier and TypeMethodDescriptionstatic org.apache.hadoop.hbase.backup.impl.TableBackupClient
BackupClientFactory.create
(org.apache.hadoop.hbase.client.Connection conn, String backupId, org.apache.hadoop.hbase.backup.BackupRequest request) -
Uses of org.apache.hadoop.hbase.client.Connection in org.apache.hadoop.hbase.client
Modifier and TypeClassDescriptionclass
org.apache.hadoop.hbase.client.SharedConnection
Wraps aConnection
to make it can't be closed or aborted.Modifier and TypeMethodDescriptionstatic org.apache.hadoop.hbase.client.Connection
ConnectionFactory.createConnection()
Create a new Connection instance using default HBaseConfiguration.static org.apache.hadoop.hbase.client.Connection
ConnectionFactory.createConnection
(URI connectionUri) Create a new Connection instance using default HBaseConfiguration.static org.apache.hadoop.hbase.client.Connection
ConnectionFactory.createConnection
(URI connectionUri, org.apache.hadoop.conf.Configuration conf) Create a new Connection instance using the passedconf
instance.static org.apache.hadoop.hbase.client.Connection
ConnectionFactory.createConnection
(URI connectionUri, org.apache.hadoop.conf.Configuration conf, ExecutorService pool) Create a new Connection instance using the passedconf
instance.static org.apache.hadoop.hbase.client.Connection
ConnectionFactory.createConnection
(URI connectionUri, org.apache.hadoop.conf.Configuration conf, ExecutorService pool, org.apache.hadoop.hbase.security.User user) Create a new Connection instance using the passedconf
instance.static org.apache.hadoop.hbase.client.Connection
ConnectionFactory.createConnection
(URI connectionUri, org.apache.hadoop.conf.Configuration conf, ExecutorService pool, org.apache.hadoop.hbase.security.User user, Map<String, byte[]> connectionAttributes) Create a new Connection instance using the passedconf
instance.static org.apache.hadoop.hbase.client.Connection
ConnectionFactory.createConnection
(URI connectionUri, org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.security.User user) Create a new Connection instance using the passedconf
instance.static org.apache.hadoop.hbase.client.Connection
ConnectionFactory.createConnection
(org.apache.hadoop.conf.Configuration conf) Create a new Connection instance using the passedconf
instance.static org.apache.hadoop.hbase.client.Connection
ConnectionFactory.createConnection
(org.apache.hadoop.conf.Configuration conf, ExecutorService pool) Create a new Connection instance using the passedconf
instance.static org.apache.hadoop.hbase.client.Connection
ConnectionFactory.createConnection
(org.apache.hadoop.conf.Configuration conf, ExecutorService pool, org.apache.hadoop.hbase.security.User user) Create a new Connection instance using the passedconf
instance.static org.apache.hadoop.hbase.client.Connection
ConnectionFactory.createConnection
(org.apache.hadoop.conf.Configuration conf, ExecutorService pool, org.apache.hadoop.hbase.security.User user, Map<String, byte[]> connectionAttributes) Create a new Connection instance using the passedconf
instance.static org.apache.hadoop.hbase.client.Connection
ConnectionFactory.createConnection
(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.security.User user) Create a new Connection instance using the passedconf
instance.org.apache.hadoop.hbase.client.Connection
Admin.getConnection()
Returns Connection used by this object.org.apache.hadoop.hbase.client.Connection
AsyncConnection.toConnection()
Convert this connection to aConnection
.org.apache.hadoop.hbase.client.Connection
AsyncConnectionImpl.toConnection()
org.apache.hadoop.hbase.client.Connection
SharedAsyncConnection.toConnection()
ModifierConstructorDescriptionSharedConnection
(org.apache.hadoop.hbase.client.Connection conn) -
Uses of org.apache.hadoop.hbase.client.Connection in org.apache.hadoop.hbase.client.example
ModifierConstructorDescriptionReadExampleCallable
(org.apache.hadoop.hbase.client.Connection connection, org.apache.hadoop.hbase.TableName tableName) SingleWriteExampleCallable
(org.apache.hadoop.hbase.client.Connection connection, org.apache.hadoop.hbase.TableName tableName) WriteExampleCallable
(org.apache.hadoop.hbase.client.Connection connection, org.apache.hadoop.hbase.TableName tableName) -
Uses of org.apache.hadoop.hbase.client.Connection in org.apache.hadoop.hbase.coprocessor
Modifier and TypeMethodDescriptionorg.apache.hadoop.hbase.client.Connection
MasterCoprocessorEnvironment.createConnection
(org.apache.hadoop.conf.Configuration conf) Creates a cluster connection using the passed Configuration.org.apache.hadoop.hbase.client.Connection
RegionCoprocessorEnvironment.createConnection
(org.apache.hadoop.conf.Configuration conf) Creates a cluster connection using the passed Configuration.org.apache.hadoop.hbase.client.Connection
RegionServerCoprocessorEnvironment.createConnection
(org.apache.hadoop.conf.Configuration conf) Creates a cluster connection using the passed Configuration.org.apache.hadoop.hbase.client.Connection
MasterCoprocessorEnvironment.getConnection()
Returns the hosts' Connection to the Cluster.org.apache.hadoop.hbase.client.Connection
RegionCoprocessorEnvironment.getConnection()
Returns the hosts' Connection to the Cluster.org.apache.hadoop.hbase.client.Connection
RegionServerCoprocessorEnvironment.getConnection()
Returns the hosts' Connection to the Cluster. -
Uses of org.apache.hadoop.hbase.client.Connection in org.apache.hadoop.hbase.favored
Modifier and TypeMethodDescriptionstatic void
FavoredNodeAssignmentHelper.updateMetaWithFavoredNodesInfo
(Map<org.apache.hadoop.hbase.client.RegionInfo, List<org.apache.hadoop.hbase.ServerName>> regionToFavoredNodes, org.apache.hadoop.hbase.client.Connection connection) Update meta table with favored nodes info -
Uses of org.apache.hadoop.hbase.client.Connection in org.apache.hadoop.hbase.mapred
Modifier and TypeMethodDescriptionprotected void
TableInputFormatBase.initializeTable
(org.apache.hadoop.hbase.client.Connection connection, org.apache.hadoop.hbase.TableName tableName) Allows subclasses to initialize the table information. -
Uses of org.apache.hadoop.hbase.client.Connection in org.apache.hadoop.hbase.mapreduce
Modifier and TypeMethodDescriptionprotected void
TableInputFormatBase.initializeTable
(org.apache.hadoop.hbase.client.Connection connection, org.apache.hadoop.hbase.TableName tableName) Allows subclasses to initialize the table information. -
Uses of org.apache.hadoop.hbase.client.Connection in org.apache.hadoop.hbase.master
Modifier and TypeMethodDescriptionstatic void
TableNamespaceManager.insertNamespaceToMeta
(org.apache.hadoop.hbase.client.Connection conn, org.apache.hadoop.hbase.NamespaceDescriptor ns) ModifierConstructorDescriptionSnapshotOfRegionAssignmentFromMeta
(org.apache.hadoop.hbase.client.Connection connection) SnapshotOfRegionAssignmentFromMeta
(org.apache.hadoop.hbase.client.Connection connection, Set<org.apache.hadoop.hbase.TableName> disabledTables, boolean excludeOfflinedSplitParents) -
Uses of org.apache.hadoop.hbase.client.Connection in org.apache.hadoop.hbase.namequeues
Modifier and TypeMethodDescriptionvoid
SlowLogPersistentService.addAllLogsToSysTable
(org.apache.hadoop.hbase.client.Connection connection) Poll from queueForSysTable and insert 100 records in hbase:slowlog table in single batchstatic void
WALEventTrackerTableAccessor.addWalEventTrackerRows
(Queue<org.apache.hadoop.hbase.namequeues.WALEventTrackerPayload> walEventPayloads, org.apache.hadoop.hbase.client.Connection connection) Add wal event tracker rows to hbase:waleventtracker tablevoid
NamedQueueRecorder.persistAll
(org.apache.hadoop.hbase.namequeues.NamedQueuePayload.NamedQueueEvent namedQueueEvent, org.apache.hadoop.hbase.client.Connection connection) Add all in memory queue records to system table.void
NamedQueueService.persistAll
(org.apache.hadoop.hbase.client.Connection connection) Add all in memory queue records to system table.void
WALEventTrackerQueueService.persistAll
(org.apache.hadoop.hbase.client.Connection connection) ModifierConstructorDescriptionNamedQueueServiceChore
(org.apache.hadoop.hbase.Stoppable stopper, int period, org.apache.hadoop.hbase.namequeues.NamedQueueRecorder namedQueueRecorder, org.apache.hadoop.hbase.client.Connection connection) Chore Constructor -
Uses of org.apache.hadoop.hbase.client.Connection in org.apache.hadoop.hbase.namequeues.impl
Modifier and TypeMethodDescriptionvoid
BalancerDecisionQueueService.persistAll
(org.apache.hadoop.hbase.client.Connection connection) void
BalancerRejectionQueueService.persistAll
(org.apache.hadoop.hbase.client.Connection connection) void
SlowLogQueueService.persistAll
(org.apache.hadoop.hbase.client.Connection connection) Add all slowLog events to system table. -
Uses of org.apache.hadoop.hbase.client.Connection in org.apache.hadoop.hbase.quotas
Modifier and TypeMethodDescriptionstatic void
QuotaUtil.addNamespaceQuota
(org.apache.hadoop.hbase.client.Connection connection, String namespace, org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Quotas data) static void
QuotaUtil.addRegionServerQuota
(org.apache.hadoop.hbase.client.Connection connection, String regionServer, org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Quotas data) static void
QuotaUtil.addTableQuota
(org.apache.hadoop.hbase.client.Connection connection, org.apache.hadoop.hbase.TableName table, org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Quotas data) static void
QuotaUtil.addUserQuota
(org.apache.hadoop.hbase.client.Connection connection, String user, String namespace, org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Quotas data) static void
QuotaUtil.addUserQuota
(org.apache.hadoop.hbase.client.Connection connection, String user, org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Quotas data) static void
QuotaUtil.addUserQuota
(org.apache.hadoop.hbase.client.Connection connection, String user, org.apache.hadoop.hbase.TableName table, org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Quotas data) static void
QuotaUtil.deleteNamespaceQuota
(org.apache.hadoop.hbase.client.Connection connection, String namespace) static void
QuotaUtil.deleteRegionServerQuota
(org.apache.hadoop.hbase.client.Connection connection, String regionServer) static void
QuotaUtil.deleteTableQuota
(org.apache.hadoop.hbase.client.Connection connection, org.apache.hadoop.hbase.TableName table) static void
QuotaUtil.deleteUserQuota
(org.apache.hadoop.hbase.client.Connection connection, String user) static void
QuotaUtil.deleteUserQuota
(org.apache.hadoop.hbase.client.Connection connection, String user, String namespace) static void
QuotaUtil.deleteUserQuota
(org.apache.hadoop.hbase.client.Connection connection, String user, org.apache.hadoop.hbase.TableName table) static void
QuotaUtil.disableTableIfNotDisabled
(org.apache.hadoop.hbase.client.Connection conn, org.apache.hadoop.hbase.TableName tableName) Method to disable a table, if not already disabled.protected static org.apache.hadoop.hbase.client.Result[]
QuotaTableUtil.doGet
(org.apache.hadoop.hbase.client.Connection connection, List<org.apache.hadoop.hbase.client.Get> gets) protected static org.apache.hadoop.hbase.client.Result
QuotaTableUtil.doGet
(org.apache.hadoop.hbase.client.Connection connection, org.apache.hadoop.hbase.client.Get get) static void
QuotaUtil.enableTableIfNotEnabled
(org.apache.hadoop.hbase.client.Connection conn, org.apache.hadoop.hbase.TableName tableName) Method to enable a table, if not already enabled.static <K> Map<K,
org.apache.hadoop.hbase.quotas.QuotaState> QuotaUtil.fetchGlobalQuotas
(String type, org.apache.hadoop.hbase.client.Connection connection, List<org.apache.hadoop.hbase.client.Get> gets, org.apache.hadoop.hbase.quotas.QuotaUtil.KeyFromRow<K> kfr) QuotaUtil.fetchNamespaceQuotas
(org.apache.hadoop.hbase.client.Connection connection, List<org.apache.hadoop.hbase.client.Get> gets, double factor) QuotaUtil.fetchRegionServerQuotas
(org.apache.hadoop.hbase.client.Connection connection, List<org.apache.hadoop.hbase.client.Get> gets) static Map<org.apache.hadoop.hbase.TableName,
org.apache.hadoop.hbase.quotas.QuotaState> QuotaUtil.fetchTableQuotas
(org.apache.hadoop.hbase.client.Connection connection, List<org.apache.hadoop.hbase.client.Get> gets, Map<org.apache.hadoop.hbase.TableName, Double> tableMachineFactors) QuotaUtil.fetchUserQuotas
(org.apache.hadoop.hbase.client.Connection connection, List<org.apache.hadoop.hbase.client.Get> gets, Map<org.apache.hadoop.hbase.TableName, Double> tableMachineQuotaFactors, double factor) org.apache.hadoop.hbase.quotas.FileArchiverNotifier
FileArchiverNotifierFactory.get
(org.apache.hadoop.hbase.client.Connection conn, org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.hbase.TableName tn) Creates or obtains aFileArchiverNotifier
instance for the given args.org.apache.hadoop.hbase.quotas.FileArchiverNotifier
FileArchiverNotifierFactoryImpl.get
(org.apache.hadoop.hbase.client.Connection conn, org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.hbase.TableName tn) Returns theFileArchiverNotifier
instance for the givenTableName
.static org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot
QuotaTableUtil.getCurrentSnapshotFromQuotaTable
(org.apache.hadoop.hbase.client.Connection conn, org.apache.hadoop.hbase.TableName tableName) Returns the current space quota snapshot of the giventableName
fromQuotaTableUtil.QUOTA_TABLE_NAME
or null if the no quota information is available for that tableName.static org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Quotas
QuotaTableUtil.getNamespaceQuota
(org.apache.hadoop.hbase.client.Connection connection, String namespace) QuotaTableUtil.getNamespaceSnapshots
(org.apache.hadoop.hbase.client.Connection conn) Returns a set of the names of all namespaces containing snapshot entries.QuotaTableUtil.getObservedSnapshotSizes
(org.apache.hadoop.hbase.client.Connection conn) Fetches any persisted HBase snapshot sizes stored in the quota table.static org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Quotas
QuotaTableUtil.getRegionServerQuota
(org.apache.hadoop.hbase.client.Connection connection, String regionServer) static Map<org.apache.hadoop.hbase.TableName,
org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot> QuotaTableUtil.getSnapshots
(org.apache.hadoop.hbase.client.Connection conn) Fetches allSpaceQuotaSnapshot
objects from thehbase:quota
table.static org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Quotas
QuotaTableUtil.getTableQuota
(org.apache.hadoop.hbase.client.Connection connection, org.apache.hadoop.hbase.TableName table) static org.apache.hbase.thirdparty.com.google.common.collect.Multimap<org.apache.hadoop.hbase.TableName,
String> QuotaTableUtil.getTableSnapshots
(org.apache.hadoop.hbase.client.Connection conn) Returns a multimap for all existing table snapshot entries.static org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Quotas
QuotaTableUtil.getUserQuota
(org.apache.hadoop.hbase.client.Connection connection, String user) static org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Quotas
QuotaTableUtil.getUserQuota
(org.apache.hadoop.hbase.client.Connection connection, String user, String namespace) static org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Quotas
QuotaTableUtil.getUserQuota
(org.apache.hadoop.hbase.client.Connection connection, String user, org.apache.hadoop.hbase.TableName table) void
SpaceQuotaSnapshotNotifier.initialize
(org.apache.hadoop.hbase.client.Connection conn) Initializes the notifier.void
TableSpaceQuotaSnapshotNotifier.initialize
(org.apache.hadoop.hbase.client.Connection conn) protected static boolean
QuotaUtil.isExceedThrottleQuotaEnabled
(org.apache.hadoop.hbase.client.Connection connection) void
MasterQuotaManager.processFileArchivals
(org.apache.hadoop.hbase.shaded.protobuf.generated.RegionServerStatusProtos.FileArchiveNotificationRequest request, org.apache.hadoop.hbase.client.Connection conn, org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.fs.FileSystem fs) protected static void
QuotaUtil.switchExceedThrottleQuota
(org.apache.hadoop.hbase.client.Connection connection, boolean exceedThrottleQuotaEnabled) ModifierConstructorDescriptionFileArchiverNotifierImpl
(org.apache.hadoop.hbase.client.Connection conn, org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.hbase.TableName tn) NamespaceQuotaSnapshotStore
(org.apache.hadoop.hbase.client.Connection conn, org.apache.hadoop.hbase.quotas.QuotaObserverChore chore, Map<org.apache.hadoop.hbase.client.RegionInfo, Long> regionUsage) QuotaRetriever
(org.apache.hadoop.hbase.client.Connection conn) QuotaRetriever
(org.apache.hadoop.hbase.client.Connection conn, org.apache.hadoop.hbase.client.Scan scan) QuotaRetriever
(org.apache.hadoop.hbase.client.Connection conn, org.apache.hadoop.hbase.quotas.QuotaFilter filter) SpaceQuotaRefresherChore
(org.apache.hadoop.hbase.quotas.RegionServerSpaceQuotaManager manager, org.apache.hadoop.hbase.client.Connection conn) TableQuotaSnapshotStore
(org.apache.hadoop.hbase.client.Connection conn, org.apache.hadoop.hbase.quotas.QuotaObserverChore chore, Map<org.apache.hadoop.hbase.client.RegionInfo, Long> regionUsage) -
Uses of org.apache.hadoop.hbase.client.Connection in org.apache.hadoop.hbase.replication
Modifier and TypeMethodDescriptionstatic org.apache.hadoop.hbase.replication.ReplicationBarrierFamilyFormat.ReplicationBarrierResult
ReplicationBarrierFamilyFormat.getReplicationBarrierResult
(org.apache.hadoop.hbase.client.Connection conn, org.apache.hadoop.hbase.TableName tableName, byte[] row, byte[] encodedRegionName) static long[]
ReplicationBarrierFamilyFormat.getReplicationBarriers
(org.apache.hadoop.hbase.client.Connection conn, byte[] regionName) static org.apache.hadoop.hbase.replication.ReplicationQueueStorage
ReplicationStorageFactory.getReplicationQueueStorage
(org.apache.hadoop.hbase.client.Connection conn, org.apache.hadoop.conf.Configuration conf) Create a newReplicationQueueStorage
.static org.apache.hadoop.hbase.replication.ReplicationQueueStorage
ReplicationStorageFactory.getReplicationQueueStorage
(org.apache.hadoop.hbase.client.Connection conn, org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.TableName tableName) Create a newReplicationQueueStorage
.ReplicationBarrierFamilyFormat.getTableEncodedRegionNameAndLastBarrier
(org.apache.hadoop.hbase.client.Connection conn, org.apache.hadoop.hbase.TableName tableName) ReplicationBarrierFamilyFormat.getTableEncodedRegionNamesForSerialReplication
(org.apache.hadoop.hbase.client.Connection conn, org.apache.hadoop.hbase.TableName tableName) ModifierConstructorDescriptionTableReplicationQueueStorage
(org.apache.hadoop.hbase.client.Connection conn, org.apache.hadoop.hbase.TableName tableName) -
Uses of org.apache.hadoop.hbase.client.Connection in org.apache.hadoop.hbase.rsgroup
ModifierConstructorDescriptionRSGroupAdminClient
(org.apache.hadoop.hbase.client.Connection conn) Deprecated. -
Uses of org.apache.hadoop.hbase.client.Connection in org.apache.hadoop.hbase.slowlog
Modifier and TypeMethodDescriptionstatic void
SlowLogTableAccessor.addSlowLogRecords
(List<org.apache.hadoop.hbase.shaded.protobuf.generated.TooSlowLog.SlowLogPayload> slowLogPayloads, org.apache.hadoop.hbase.client.Connection connection) Add slow/large log records to hbase:slowlog table -
Uses of org.apache.hadoop.hbase.client.Connection in org.apache.hadoop.hbase.snapshot
Modifier and TypeMethodDescriptionvoid
RestoreSnapshotHelper.RestoreMetaChanges.updateMetaParentRegions
(org.apache.hadoop.hbase.client.Connection connection, List<org.apache.hadoop.hbase.client.RegionInfo> regionInfos) -
Uses of org.apache.hadoop.hbase.client.Connection in org.apache.hadoop.hbase.util
Modifier and TypeFieldDescriptionprotected final org.apache.hadoop.hbase.client.Connection
MultiThreadedAction.connection
Modifier and TypeMethodDescriptionstatic void
HBaseFsckRepair.closeRegionSilentlyAndWait
(org.apache.hadoop.hbase.client.Connection connection, org.apache.hadoop.hbase.ServerName server, org.apache.hadoop.hbase.client.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
(org.apache.hadoop.hbase.client.Connection connection, org.apache.hadoop.hbase.client.RegionInfo region, List<org.apache.hadoop.hbase.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. -
Uses of org.apache.hadoop.hbase.client.Connection in org.apache.hadoop.hbase.util.compaction
Modifier and TypeFieldDescriptionprotected final org.apache.hadoop.hbase.client.Connection
MajorCompactionRequest.connection
protected org.apache.hadoop.hbase.client.Connection
MajorCompactor.connection
-
Uses of org.apache.hadoop.hbase.client.Connection in org.apache.hadoop.hbase.util.hbck
ModifierConstructorDescriptionReplicationChecker
(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.zookeeper.ZKWatcher zkw, org.apache.hadoop.hbase.client.Connection conn, org.apache.hadoop.hbase.util.HbckErrorReporter errorReporter)
MetaTableAccessor.getRegionLocation(Connection, byte[])
instead