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.hbaseClasses in org.apache.hadoop.hbase that implement org.apache.hadoop.hbase.client.Connection in inModifier and TypeClassDescriptionclassorg.apache.hadoop.hbase.SharedConnectionWraps 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.ConnectionServer.createConnection(org.apache.hadoop.conf.Configuration conf) org.apache.hadoop.hbase.client.ConnectionServer.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 voidMetaTableAccessor.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 voidMetaTableAccessor.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 voidMetaTableAccessor.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 voidMetaTableAccessor.deleteMergeQualifiers(org.apache.hadoop.hbase.client.Connection connection, org.apache.hadoop.hbase.client.RegionInfo mergeRegion) Deletes merge qualifiers for the specified merge region.static voidMetaTableAccessor.deleteRegionInfo(org.apache.hadoop.hbase.client.Connection connection, org.apache.hadoop.hbase.client.RegionInfo regionInfo) Deletes the specified region from META.static voidMetaTableAccessor.deleteRegionInfos(org.apache.hadoop.hbase.client.Connection connection, List<org.apache.hadoop.hbase.client.RegionInfo> regionsInfo) Deletes the specified regions from META.static voidMetaTableAccessor.deleteTableState(org.apache.hadoop.hbase.client.Connection connection, org.apache.hadoop.hbase.TableName table) Remove state for table from metastatic voidMetaTableAccessor.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:metafor regions.static voidMetaTableAccessor.fullScanRegions(org.apache.hadoop.hbase.client.Connection connection, org.apache.hadoop.hbase.MetaTableAccessor.Visitor visitor) Performs a full scan ofhbase:metafor regions.static voidMetaTableAccessor.fullScanTables(org.apache.hadoop.hbase.client.Connection connection, org.apache.hadoop.hbase.MetaTableAccessor.Visitor visitor) Performs a full scan ofhbase:metafor 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.ResultMetaTableAccessor.getCatalogFamilyRow(org.apache.hadoop.hbase.client.Connection connection, org.apache.hadoop.hbase.client.RegionInfo ri) Returns Return theHConstants.CATALOG_FAMILYrow 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 theregionInforow.static org.apache.hadoop.hbase.client.TableMetaTableAccessor.getMetaHTable(org.apache.hadoop.hbase.client.Connection connection) Callers should call close on the returnedTableinstance.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.HRegionLocationMetaTableAccessor.getRegionLocation(org.apache.hadoop.hbase.client.Connection connection, byte[] regionName) Returns the HRegionLocation from meta for the given regionstatic org.apache.hadoop.hbase.HRegionLocationMetaTableAccessor.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.ResultMetaTableAccessor.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.ReplicationBarrierResultMetaTableAccessor.getReplicationBarrierResult(org.apache.hadoop.hbase.client.Connection conn, org.apache.hadoop.hbase.TableName tableName, byte[] row, byte[] encodedRegionName) static org.apache.hadoop.hbase.rsgroup.RSGroupInfoRSGroupTableAccessor.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.TableStateMetaTableAccessor.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 booleanMetaTableAccessor.hasMergeRegions(org.apache.hadoop.hbase.client.Connection conn, org.apache.hadoop.hbase.client.RegionInfo regionInfo) Check whether the givenregionInfohas any 'info:merge*' columns.static booleanRSGroupTableAccessor.isRSGroupsEnabled(org.apache.hadoop.hbase.client.Connection connection) static voidMetaTableAccessor.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 voidMetaTableAccessor.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 voidMetaTableAccessor.putsToMetaTable(org.apache.hadoop.hbase.client.Connection connection, List<org.apache.hadoop.hbase.client.Put> ps) Put the passedpsto thehbase:metatable.static org.apache.hadoop.hbase.client.ResultMetaTableAccessor.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 relatedResultinstance if any row is found, null otherwise.static voidMetaTableAccessor.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 voidMetaTableAccessor.scanMetaForTableRegions(org.apache.hadoop.hbase.client.Connection connection, org.apache.hadoop.hbase.MetaTableAccessor.Visitor visitor, org.apache.hadoop.hbase.TableName tableName) static voidMetaTableAccessor.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 voidMetaTableAccessor.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 voidMetaTableAccessor.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 voidMetaTableAccessor.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 voidMetaTableAccessor.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.backupMethods 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.TableBackupClientBackupClientFactory.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.clientSubinterfaces of org.apache.hadoop.hbase.client.Connection in in org.apache.hadoop.hbase.clientModifier and TypeInterfaceDescriptioninterfaceorg.apache.hadoop.hbase.client.ClusterConnectionInternal 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 TypeClassDescriptionclassorg.apache.hadoop.hbase.client.ConnectionImplementationMain implementation ofConnectionandClusterConnectioninterfaces.static final classorg.apache.hadoop.hbase.client.ServerConnectionUtils.ShortCircuitingClusterConnectionA 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.ConnectionConnectionFactory.createConnection()Create a new Connection instance using default HBaseConfiguration.static org.apache.hadoop.hbase.client.ConnectionConnectionFactory.createConnection(org.apache.hadoop.conf.Configuration conf) Create a new Connection instance using the passedconfinstance.static org.apache.hadoop.hbase.client.ConnectionConnectionFactory.createConnection(org.apache.hadoop.conf.Configuration conf, ExecutorService pool) Create a new Connection instance using the passedconfinstance.static org.apache.hadoop.hbase.client.ConnectionConnectionFactory.createConnection(org.apache.hadoop.conf.Configuration conf, ExecutorService pool, org.apache.hadoop.hbase.security.User user) Create a new Connection instance using the passedconfinstance.static org.apache.hadoop.hbase.client.ConnectionConnectionFactory.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 passedconfinstance.static org.apache.hadoop.hbase.client.ConnectionConnectionFactory.createConnection(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.security.User user) Create a new Connection instance using the passedconfinstance.org.apache.hadoop.hbase.client.ConnectionAdmin.getConnection()Returns Connection used by this object.org.apache.hadoop.hbase.client.ConnectionHBaseAdmin.getConnection()Returns Connection used by this object.protected org.apache.hadoop.hbase.client.ConnectionHTable.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 TypeMethodDescriptionvoidSecureBulkLoadClient.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.exampleConstructors 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.coprocessorMethods in org.apache.hadoop.hbase.coprocessor that return org.apache.hadoop.hbase.client.Connection in inModifier and TypeMethodDescriptionorg.apache.hadoop.hbase.client.ConnectionMasterCoprocessorEnvironment.createConnection(org.apache.hadoop.conf.Configuration conf) Creates a cluster connection using the passed Configuration.org.apache.hadoop.hbase.client.ConnectionRegionCoprocessorEnvironment.createConnection(org.apache.hadoop.conf.Configuration conf) Creates a cluster connection using the passed Configuration.org.apache.hadoop.hbase.client.ConnectionRegionServerCoprocessorEnvironment.createConnection(org.apache.hadoop.conf.Configuration conf) Creates a cluster connection using the passed Configuration.org.apache.hadoop.hbase.client.ConnectionMasterCoprocessorEnvironment.getConnection()Returns the hosts' Connection to the Cluster.org.apache.hadoop.hbase.client.ConnectionRegionCoprocessorEnvironment.getConnection()Returns the hosts' Connection to the Cluster.org.apache.hadoop.hbase.client.ConnectionRegionServerCoprocessorEnvironment.getConnection()Returns the hosts' Connection to the Cluster.
- 
Uses of org.apache.hadoop.hbase.client.Connection in org.apache.hadoop.hbase.favoredMethods in org.apache.hadoop.hbase.favored with parameters of type org.apache.hadoop.hbase.client.Connection in inModifier and TypeMethodDescriptionstatic voidFavoredNodeAssignmentHelper.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.mapredMethods in org.apache.hadoop.hbase.mapred with parameters of type org.apache.hadoop.hbase.client.Connection in inModifier and TypeMethodDescriptionprotected voidTableInputFormatBase.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.mapreduceMethods in org.apache.hadoop.hbase.mapreduce with parameters of type org.apache.hadoop.hbase.client.Connection in inModifier and TypeMethodDescriptionprotected voidTableInputFormatBase.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.masterConstructors 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.namequeuesMethods in org.apache.hadoop.hbase.namequeues with parameters of type org.apache.hadoop.hbase.client.Connection in inModifier and TypeMethodDescriptionvoidSlowLogPersistentService.addAllLogsToSysTable(org.apache.hadoop.hbase.client.Connection connection) Poll from queueForSysTable and insert 100 records in hbase:slowlog table in single batchstatic voidWALEventTrackerTableAccessor.addWalEventTrackerRows(Queue<org.apache.hadoop.hbase.namequeues.WALEventTrackerPayload> walEventPayloads, org.apache.hadoop.hbase.client.Connection connection) Add wal event tracker rows to hbase:waleventtracker tablevoidNamedQueueRecorder.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.voidNamedQueueService.persistAll(org.apache.hadoop.hbase.client.Connection connection) Add all in memory queue records to system table.voidWALEventTrackerQueueService.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.implMethods in org.apache.hadoop.hbase.namequeues.impl with parameters of type org.apache.hadoop.hbase.client.Connection in inModifier and TypeMethodDescriptionvoidBalancerDecisionQueueService.persistAll(org.apache.hadoop.hbase.client.Connection connection) voidBalancerRejectionQueueService.persistAll(org.apache.hadoop.hbase.client.Connection connection) voidSlowLogQueueService.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.quotasMethods in org.apache.hadoop.hbase.quotas with parameters of type org.apache.hadoop.hbase.client.Connection in inModifier and TypeMethodDescriptionstatic voidQuotaUtil.addNamespaceQuota(org.apache.hadoop.hbase.client.Connection connection, String namespace, org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Quotas data) static voidQuotaUtil.addRegionServerQuota(org.apache.hadoop.hbase.client.Connection connection, String regionServer, org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Quotas data) static voidQuotaUtil.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 voidQuotaUtil.addUserQuota(org.apache.hadoop.hbase.client.Connection connection, String user, String namespace, org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Quotas data) static voidQuotaUtil.addUserQuota(org.apache.hadoop.hbase.client.Connection connection, String user, org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Quotas data) static voidQuotaUtil.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 voidQuotaUtil.deleteNamespaceQuota(org.apache.hadoop.hbase.client.Connection connection, String namespace) static voidQuotaUtil.deleteRegionServerQuota(org.apache.hadoop.hbase.client.Connection connection, String regionServer) static voidQuotaUtil.deleteTableQuota(org.apache.hadoop.hbase.client.Connection connection, org.apache.hadoop.hbase.TableName table) static voidQuotaUtil.deleteUserQuota(org.apache.hadoop.hbase.client.Connection connection, String user) static voidQuotaUtil.deleteUserQuota(org.apache.hadoop.hbase.client.Connection connection, String user, String namespace) static voidQuotaUtil.deleteUserQuota(org.apache.hadoop.hbase.client.Connection connection, String user, org.apache.hadoop.hbase.TableName table) static voidQuotaUtil.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.ResultQuotaTableUtil.doGet(org.apache.hadoop.hbase.client.Connection connection, org.apache.hadoop.hbase.client.Get get) static voidQuotaUtil.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.FileArchiverNotifierFileArchiverNotifierFactory.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 aFileArchiverNotifierinstance for the given args.org.apache.hadoop.hbase.quotas.FileArchiverNotifierFileArchiverNotifierFactoryImpl.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 theFileArchiverNotifierinstance for the givenTableName.static org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshotQuotaTableUtil.getCurrentSnapshotFromQuotaTable(org.apache.hadoop.hbase.client.Connection conn, org.apache.hadoop.hbase.TableName tableName) Returns the current space quota snapshot of the giventableNamefromQuotaTableUtil.QUOTA_TABLE_NAMEor null if the no quota information is available for that tableName.static org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.QuotasQuotaTableUtil.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.QuotasQuotaTableUtil.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 allSpaceQuotaSnapshotobjects from thehbase:quotatable.static org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.QuotasQuotaTableUtil.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.QuotasQuotaTableUtil.getUserQuota(org.apache.hadoop.hbase.client.Connection connection, String user) static org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.QuotasQuotaTableUtil.getUserQuota(org.apache.hadoop.hbase.client.Connection connection, String user, String namespace) static org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.QuotasQuotaTableUtil.getUserQuota(org.apache.hadoop.hbase.client.Connection connection, String user, org.apache.hadoop.hbase.TableName table) voidSpaceQuotaSnapshotNotifier.initialize(org.apache.hadoop.hbase.client.Connection conn) Initializes the notifier.voidTableSpaceQuotaSnapshotNotifier.initialize(org.apache.hadoop.hbase.client.Connection conn) protected static booleanQuotaUtil.isExceedThrottleQuotaEnabled(org.apache.hadoop.hbase.client.Connection connection) voidMasterQuotaManager.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 voidQuotaUtil.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.regionserverMethods in org.apache.hadoop.hbase.regionserver that return org.apache.hadoop.hbase.client.Connection in inModifier and TypeMethodDescriptionorg.apache.hadoop.hbase.client.ConnectionHRegionServer.createConnection(org.apache.hadoop.conf.Configuration conf) org.apache.hadoop.hbase.client.ConnectionHRegionServer.getConnection()
- 
Uses of org.apache.hadoop.hbase.client.Connection in org.apache.hadoop.hbase.rsgroupConstructors 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.slowlogMethods in org.apache.hadoop.hbase.slowlog with parameters of type org.apache.hadoop.hbase.client.Connection in inModifier and TypeMethodDescriptionstatic voidSlowLogTableAccessor.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.snapshotMethods in org.apache.hadoop.hbase.snapshot with parameters of type org.apache.hadoop.hbase.client.Connection in inModifier and TypeMethodDescriptionvoidRestoreSnapshotHelper.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.utilMethods in org.apache.hadoop.hbase.util with parameters of type org.apache.hadoop.hbase.client.Connection in inModifier and TypeMethodDescriptionstatic voidHBaseFsckRepair.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 voidHBaseFsckRepair.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.compactionFields 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.ConnectionMajorCompactionRequest.connectionprotected org.apache.hadoop.hbase.client.ConnectionMajorCompactor.connection
MetaTableAccessor.getRegionLocation(Connection, byte[])instead