Uses of Interface
org.apache.hadoop.hbase.client.Connection
Packages that use 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.
-
Uses of org.apache.hadoop.hbase.client.Connection in org.apache.hadoop.hbase
Classes in org.apache.hadoop.hbase that implement org.apache.hadoop.hbase.client.Connection in inModifier and TypeClassDescriptionclass
org.apache.hadoop.hbase.SharedConnection
Wraps a Connection to make it can't be closed or aborted.Methods in org.apache.hadoop.hbase that return org.apache.hadoop.hbase.client.Connection in inModifier and TypeMethodDescriptionorg.apache.hadoop.hbase.client.Connection
Server.createConnection
(org.apache.hadoop.conf.Configuration conf) org.apache.hadoop.hbase.client.Connection
Server.getConnection()
Returns a reference to the servers' connection.Methods in org.apache.hadoop.hbase with parameters of type org.apache.hadoop.hbase.client.Connection in inModifier 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.addRegionToMeta
(org.apache.hadoop.hbase.client.Connection connection, org.apache.hadoop.hbase.client.RegionInfo regionInfo) Adds a (single) hbase:meta row for the specified new region and its daughters.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.deleteMergeQualifiers
(org.apache.hadoop.hbase.client.Connection connection, org.apache.hadoop.hbase.client.RegionInfo mergeRegion) Deletes merge qualifiers for the specified merge region.static void
MetaTableAccessor.deleteRegionInfo
(org.apache.hadoop.hbase.client.Connection connection, org.apache.hadoop.hbase.client.RegionInfo regionInfo) Deletes the specified region from META.static void
MetaTableAccessor.deleteRegionInfos
(org.apache.hadoop.hbase.client.Connection connection, List<org.apache.hadoop.hbase.client.RegionInfo> regionsInfo) Deletes the specified regions from META.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.MetaTableAccessor.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.MetaTableAccessor.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 List<org.apache.hadoop.hbase.rsgroup.RSGroupInfo>
RSGroupTableAccessor.getAllRSGroupInfo
(org.apache.hadoop.hbase.client.Connection connection) 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 List<org.apache.hadoop.hbase.client.RegionInfo>
MetaTableAccessor.getMergeRegions
(org.apache.hadoop.hbase.client.Connection connection, org.apache.hadoop.hbase.client.RegionInfo regionInfo) Returns Return all regioninfos listed in the 'info:merge*' columns of theregionInfo
row.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 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 long[]
MetaTableAccessor.getReplicationBarrier
(org.apache.hadoop.hbase.client.Connection conn, byte[] regionName) static org.apache.hadoop.hbase.MetaTableAccessor.ReplicationBarrierResult
MetaTableAccessor.getReplicationBarrierResult
(org.apache.hadoop.hbase.client.Connection conn, org.apache.hadoop.hbase.TableName tableName, byte[] row, byte[] encodedRegionName) static org.apache.hadoop.hbase.rsgroup.RSGroupInfo
RSGroupTableAccessor.getRSGroupInfo
(org.apache.hadoop.hbase.client.Connection connection, byte[] rsGroupName) static NavigableMap<org.apache.hadoop.hbase.client.RegionInfo,
org.apache.hadoop.hbase.client.Result> MetaTableAccessor.getServerUserRegions
(org.apache.hadoop.hbase.client.Connection connection, org.apache.hadoop.hbase.ServerName serverName) Get the user regions a given server is hosting.MetaTableAccessor.getTableEncodedRegionNameAndLastBarrier
(org.apache.hadoop.hbase.client.Connection conn, org.apache.hadoop.hbase.TableName tableName) MetaTableAccessor.getTableEncodedRegionNamesForSerialReplication
(org.apache.hadoop.hbase.client.Connection conn, org.apache.hadoop.hbase.TableName tableName) 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 boolean
MetaTableAccessor.hasMergeRegions
(org.apache.hadoop.hbase.client.Connection conn, org.apache.hadoop.hbase.client.RegionInfo regionInfo) Check whether the givenregionInfo
has any 'info:merge*' columns.static boolean
RSGroupTableAccessor.isRSGroupsEnabled
(org.apache.hadoop.hbase.client.Connection connection) static void
MetaTableAccessor.mergeRegions
(org.apache.hadoop.hbase.client.Connection connection, org.apache.hadoop.hbase.client.RegionInfo mergedRegion, Map<org.apache.hadoop.hbase.client.RegionInfo, Long> parentSeqNum, org.apache.hadoop.hbase.ServerName sn, int regionReplication) Merge regions into one in an atomic operation.static void
MetaTableAccessor.overwriteRegions
(org.apache.hadoop.hbase.client.Connection connection, List<org.apache.hadoop.hbase.client.RegionInfo> regionInfos, int regionReplication) Overwrites the specified regions from hbase:meta.static 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, org.apache.hadoop.hbase.MetaTableAccessor.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.MetaTableAccessor.Visitor visitor, org.apache.hadoop.hbase.TableName tableName) static void
MetaTableAccessor.scanMetaForTableRegions
(org.apache.hadoop.hbase.client.Connection connection, org.apache.hadoop.hbase.MetaTableAccessor.Visitor visitor, org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.CatalogReplicaMode metaReplicaMode) static void
MetaTableAccessor.splitRegion
(org.apache.hadoop.hbase.client.Connection connection, org.apache.hadoop.hbase.client.RegionInfo parent, long parentOpenSeqNum, org.apache.hadoop.hbase.client.RegionInfo splitA, org.apache.hadoop.hbase.client.RegionInfo splitB, org.apache.hadoop.hbase.ServerName sn, int regionReplication) Splits the region into two in an atomic operation.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.Constructors in org.apache.hadoop.hbase with parameters of type org.apache.hadoop.hbase.client.Connection in inModifierConstructorDescriptionSharedConnection
(org.apache.hadoop.hbase.client.Connection conn) -
Uses of org.apache.hadoop.hbase.client.Connection in org.apache.hadoop.hbase.backup
Methods in org.apache.hadoop.hbase.backup with parameters of type org.apache.hadoop.hbase.client.Connection in inModifier 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
Subinterfaces of org.apache.hadoop.hbase.client.Connection in in org.apache.hadoop.hbase.clientModifier and TypeInterfaceDescriptioninterface
org.apache.hadoop.hbase.client.ClusterConnection
Internal methods on Connection that should not be used by user code.Classes in org.apache.hadoop.hbase.client that implement org.apache.hadoop.hbase.client.Connection in inModifier and TypeClassDescriptionclass
org.apache.hadoop.hbase.client.ConnectionImplementation
Main implementation ofConnection
andClusterConnection
interfaces.static final class
org.apache.hadoop.hbase.client.ServerConnectionUtils.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.Methods in org.apache.hadoop.hbase.client that return org.apache.hadoop.hbase.client.Connection in inModifier 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
(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
HBaseAdmin.getConnection()
Returns Connection used by this object.protected org.apache.hadoop.hbase.client.Connection
HTable.getConnection()
INTERNAL Used by unit tests and tools to do low-level manipulations.Methods in org.apache.hadoop.hbase.client with parameters of type org.apache.hadoop.hbase.client.Connection in inModifier and TypeMethodDescriptionvoid
SecureBulkLoadClient.cleanupBulkLoad
(org.apache.hadoop.hbase.client.Connection conn, String bulkToken) SecureBulkLoadClient.prepareBulkLoad
(org.apache.hadoop.hbase.client.Connection conn) Constructors in org.apache.hadoop.hbase.client with parameters of type org.apache.hadoop.hbase.client.Connection in inModifierConstructorDescriptionClientServiceCallable
(org.apache.hadoop.hbase.client.Connection connection, org.apache.hadoop.hbase.TableName tableName, byte[] row, org.apache.hbase.thirdparty.com.google.protobuf.RpcController rpcController, int priority, Map<String, byte[]> requestAttributes) HTableMultiplexer
(org.apache.hadoop.hbase.client.Connection conn, org.apache.hadoop.conf.Configuration conf, int perRegionServerBufferQueueSize) Deprecated.NoncedRegionServerCallable
(org.apache.hadoop.hbase.client.Connection connection, org.apache.hadoop.hbase.TableName tableName, byte[] row, org.apache.hadoop.hbase.ipc.HBaseRpcController rpcController, int priority, Map<String, byte[]> requestAttributes) RegionServerCallable
(org.apache.hadoop.hbase.client.Connection connection, org.apache.hadoop.hbase.TableName tableName, byte[] row, org.apache.hbase.thirdparty.com.google.protobuf.RpcController rpcController, int priority, Map<String, byte[]> requestAttributes) RegionServerCallable
(org.apache.hadoop.hbase.client.Connection connection, org.apache.hadoop.hbase.TableName tableName, byte[] row, org.apache.hbase.thirdparty.com.google.protobuf.RpcController rpcController, Map<String, byte[]> requestAttributes) -
Uses of org.apache.hadoop.hbase.client.Connection in org.apache.hadoop.hbase.client.example
Constructors in org.apache.hadoop.hbase.client.example with parameters of type org.apache.hadoop.hbase.client.Connection in inModifierConstructorDescriptionReadExampleCallable
(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
Methods in org.apache.hadoop.hbase.coprocessor that return org.apache.hadoop.hbase.client.Connection in inModifier 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
Methods in org.apache.hadoop.hbase.favored with parameters of type org.apache.hadoop.hbase.client.Connection in inModifier 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
Methods in org.apache.hadoop.hbase.mapred with parameters of type org.apache.hadoop.hbase.client.Connection in inModifier 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
Methods in org.apache.hadoop.hbase.mapreduce with parameters of type org.apache.hadoop.hbase.client.Connection in inModifier 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
Constructors in org.apache.hadoop.hbase.master with parameters of type org.apache.hadoop.hbase.client.Connection in inModifierConstructorDescriptionSnapshotOfRegionAssignmentFromMeta
(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
Methods in org.apache.hadoop.hbase.namequeues with parameters of type org.apache.hadoop.hbase.client.Connection in inModifier 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) Constructors in org.apache.hadoop.hbase.namequeues with parameters of type org.apache.hadoop.hbase.client.Connection in inModifierConstructorDescriptionNamedQueueServiceChore
(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
Methods in org.apache.hadoop.hbase.namequeues.impl with parameters of type org.apache.hadoop.hbase.client.Connection in inModifier 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
Methods in org.apache.hadoop.hbase.quotas with parameters of type org.apache.hadoop.hbase.client.Connection in inModifier 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) Constructors in org.apache.hadoop.hbase.quotas with parameters of type org.apache.hadoop.hbase.client.Connection in inModifierConstructorDescriptionFileArchiverNotifierImpl
(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) 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.regionserver
Methods in org.apache.hadoop.hbase.regionserver that return org.apache.hadoop.hbase.client.Connection in inModifier and TypeMethodDescriptionorg.apache.hadoop.hbase.client.Connection
HRegionServer.createConnection
(org.apache.hadoop.conf.Configuration conf) org.apache.hadoop.hbase.client.Connection
HRegionServer.getConnection()
-
Uses of org.apache.hadoop.hbase.client.Connection in org.apache.hadoop.hbase.rsgroup
Constructors in org.apache.hadoop.hbase.rsgroup with parameters of type org.apache.hadoop.hbase.client.Connection in inModifierConstructorDescriptionRSGroupAdminClient
(org.apache.hadoop.hbase.client.Connection conn) -
Uses of org.apache.hadoop.hbase.client.Connection in org.apache.hadoop.hbase.slowlog
Methods in org.apache.hadoop.hbase.slowlog with parameters of type org.apache.hadoop.hbase.client.Connection in inModifier 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
Methods in org.apache.hadoop.hbase.snapshot with parameters of type org.apache.hadoop.hbase.client.Connection in inModifier 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
Methods in org.apache.hadoop.hbase.util with parameters of type org.apache.hadoop.hbase.client.Connection in inModifier 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
Fields in org.apache.hadoop.hbase.util.compaction declared as org.apache.hadoop.hbase.client.Connection in inModifier and TypeFieldDescriptionprotected final org.apache.hadoop.hbase.client.Connection
MajorCompactionRequest.connection
protected org.apache.hadoop.hbase.client.Connection
MajorCompactor.connection
MetaTableAccessor.getRegionLocation(Connection, byte[])
instead