Uses of Interface
org.apache.hadoop.hbase.client.Connection
Packages that use 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 Connection in org.apache.hadoop.hbase
Classes in org.apache.hadoop.hbase that implement ConnectionModifier and TypeClassDescriptionclassWraps a Connection to make it can't be closed or aborted.Fields in org.apache.hadoop.hbase declared as ConnectionMethods in org.apache.hadoop.hbase that return ConnectionModifier and TypeMethodDescriptionServer.createConnection(org.apache.hadoop.conf.Configuration conf) Server.getConnection()Returns a reference to the servers' connection.Methods in org.apache.hadoop.hbase with parameters of type ConnectionModifier and TypeMethodDescriptionstatic voidMetaTableAccessor.addRegionsToMeta(Connection connection, List<RegionInfo> regionInfos, int regionReplication) Adds a hbase:meta row for each of the specified new regions.private static voidMetaTableAccessor.addRegionsToMeta(Connection connection, List<RegionInfo> regionInfos, int regionReplication, long ts) Adds a hbase:meta row for each of the specified new regions.static voidMetaTableAccessor.addRegionToMeta(Connection connection, RegionInfo regionInfo) Adds a (single) hbase:meta row for the specified new region and its daughters.static voidMetaTableAccessor.addSplitsToParent(Connection connection, RegionInfo regionInfo, RegionInfo splitA, RegionInfo splitB) Adds daughter region infos to hbase:meta row for the specified region.private static voidMetaTableAccessor.deleteFromMetaTable(Connection connection, List<Delete> deletes) Delete the passeddeletesfrom thehbase:metatable.private static voidMetaTableAccessor.deleteFromMetaTable(Connection connection, Delete d) Delete the passeddfrom thehbase:metatable.static voidMetaTableAccessor.deleteMergeQualifiers(Connection connection, RegionInfo mergeRegion) Deletes merge qualifiers for the specified merge region.static voidMetaTableAccessor.deleteRegionInfo(Connection connection, RegionInfo regionInfo) Deletes the specified region from META.static voidMetaTableAccessor.deleteRegionInfos(Connection connection, List<RegionInfo> regionsInfo) Deletes the specified regions from META.private static voidMetaTableAccessor.deleteRegionInfos(Connection connection, List<RegionInfo> regionsInfo, long ts) Deletes the specified regions from META.static voidMetaTableAccessor.deleteTableState(Connection connection, TableName table) Remove state for table from metaMetaTableAccessor.fullScan(Connection connection, MetaTableAccessor.QueryType type) Performs a full scan ofhbase:meta.static voidMetaTableAccessor.fullScanMetaAndPrint(Connection connection) MetaTableAccessor.fullScanRegions(Connection connection) Performs a full scan ofhbase:metafor regions.static voidMetaTableAccessor.fullScanRegions(Connection connection, MetaTableAccessor.Visitor visitor) Performs a full scan ofhbase:metafor regions.static voidMetaTableAccessor.fullScanTables(Connection connection, MetaTableAccessor.Visitor visitor) Performs a full scan ofhbase:metafor tables.static List<RegionInfo>MetaTableAccessor.getAllRegions(Connection connection, boolean excludeOfflinedSplitParents) Lists all of the regions currently in META.static List<RSGroupInfo>RSGroupTableAccessor.getAllRSGroupInfo(Connection connection) static ResultMetaTableAccessor.getCatalogFamilyRow(Connection connection, RegionInfo ri) Returns Return theHConstants.CATALOG_FAMILYrow from hbase:meta.private static RegionInfoMetaTableAccessor.getClosestRegionInfo(Connection connection, TableName tableName, byte[] row) Returns Get closest metatable region row to passedrowstatic List<RegionInfo>MetaTableAccessor.getMergeRegions(Connection connection, RegionInfo regionInfo) Returns Return all regioninfos listed in the 'info:merge*' columns of theregionInforow.static TableMetaTableAccessor.getMetaHTable(Connection connection) Callers should call close on the returnedTableinstance.static Pair<RegionInfo,ServerName> MetaTableAccessor.getRegion(Connection connection, byte[] regionName) Deprecated.static HRegionLocationMetaTableAccessor.getRegionLocation(Connection connection, byte[] regionName) Returns the HRegionLocation from meta for the given regionstatic HRegionLocationMetaTableAccessor.getRegionLocation(Connection connection, RegionInfo regionInfo) Returns the HRegionLocation from meta for the given regionstatic ResultMetaTableAccessor.getRegionResult(Connection connection, RegionInfo regionInfo) Gets the result in hbase:meta for the specified region.static long[]MetaTableAccessor.getReplicationBarrier(Connection conn, byte[] regionName) MetaTableAccessor.getReplicationBarrierResult(Connection conn, TableName tableName, byte[] row, byte[] encodedRegionName) static RSGroupInfoRSGroupTableAccessor.getRSGroupInfo(Connection connection, byte[] rsGroupName) static NavigableMap<RegionInfo,Result> MetaTableAccessor.getServerUserRegions(Connection connection, ServerName serverName) Get the user regions a given server is hosting.MetaTableAccessor.getTableEncodedRegionNameAndLastBarrier(Connection conn, TableName tableName) MetaTableAccessor.getTableEncodedRegionNamesForSerialReplication(Connection conn, TableName tableName) static List<RegionInfo>MetaTableAccessor.getTableRegions(Connection connection, TableName tableName) Gets all of the regions of the specified table.static List<RegionInfo>MetaTableAccessor.getTableRegions(Connection connection, TableName tableName, boolean excludeOfflinedSplitParents) Gets all of the regions of the specified table.static List<Pair<RegionInfo,ServerName>> MetaTableAccessor.getTableRegionsAndLocations(Connection connection, TableName tableName) Do not use this method to get meta table regions, use methods in MetaTableLocator instead.static List<Pair<RegionInfo,ServerName>> MetaTableAccessor.getTableRegionsAndLocations(Connection connection, TableName tableName, boolean excludeOfflinedSplitParents) Do not use this method to get meta table regions, use methods in MetaTableLocator instead.static TableStateMetaTableAccessor.getTableState(Connection conn, TableName tableName) Fetch table state for given table from META tablestatic Map<TableName,TableState> MetaTableAccessor.getTableStates(Connection conn) Fetch table states from META tablestatic booleanMetaTableAccessor.hasMergeRegions(Connection conn, RegionInfo regionInfo) Check whether the givenregionInfohas any 'info:merge*' columns.static booleanRSGroupTableAccessor.isRSGroupsEnabled(Connection connection) static voidMetaTableAccessor.mergeRegions(Connection connection, RegionInfo mergedRegion, Map<RegionInfo, Long> parentSeqNum, ServerName sn, int regionReplication) Merge regions into one in an atomic operation.static voidMetaTableAccessor.overwriteRegions(Connection connection, List<RegionInfo> regionInfos, int regionReplication) Overwrites the specified regions from hbase:meta.static voidMetaTableAccessor.putsToMetaTable(Connection connection, List<Put> ps) Put the passedpsto thehbase:metatable.private static voidMetaTableAccessor.putToMetaTable(Connection connection, Put p) Put the passedpto thehbase:metatable.static ResultMetaTableAccessor.scanByRegionEncodedName(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.(package private) static voidMetaTableAccessor.scanMeta(Connection connection, byte[] startRow, byte[] stopRow, MetaTableAccessor.QueryType type, int maxRows, MetaTableAccessor.Visitor visitor) Performs a scan of META table.private static voidMetaTableAccessor.scanMeta(Connection connection, byte[] startRow, byte[] stopRow, MetaTableAccessor.QueryType type, Filter filter, int maxRows, MetaTableAccessor.Visitor visitor, CatalogReplicaMode metaReplicaMode) private static voidMetaTableAccessor.scanMeta(Connection connection, byte[] startRow, byte[] stopRow, MetaTableAccessor.QueryType type, MetaTableAccessor.Visitor visitor) static voidMetaTableAccessor.scanMeta(Connection connection, MetaTableAccessor.Visitor visitor, TableName tableName, byte[] row, int rowLimit) Performs a scan of META table for given table starting from given row.private static voidMetaTableAccessor.scanMeta(Connection connection, TableName table, MetaTableAccessor.QueryType type, int maxRows, MetaTableAccessor.Visitor visitor, CatalogReplicaMode metaReplicaMode) static voidMetaTableAccessor.scanMetaForTableRegions(Connection connection, MetaTableAccessor.Visitor visitor, TableName tableName) static voidMetaTableAccessor.scanMetaForTableRegions(Connection connection, MetaTableAccessor.Visitor visitor, TableName tableName, CatalogReplicaMode metaReplicaMode) static voidMetaTableAccessor.splitRegion(Connection connection, RegionInfo parent, long parentOpenSeqNum, RegionInfo splitA, RegionInfo splitB, ServerName sn, int regionReplication) Splits the region into two in an atomic operation.private static voidMetaTableAccessor.updateLocation(Connection connection, RegionInfo regionInfo, ServerName sn, long openSeqNum, long masterSystemTime) Updates the location of the specified region to be the specified server.static voidMetaTableAccessor.updateRegionLocation(Connection connection, RegionInfo regionInfo, ServerName sn, long openSeqNum, long masterSystemTime) Updates the location of the specified region in hbase:meta to be the specified server hostname and startcode.static voidMetaTableAccessor.updateRegionState(Connection connection, RegionInfo ri, RegionState.State state) Update state column in hbase:meta.private static voidMetaTableAccessor.updateTableState(Connection connection, TableState state) Update state of the table in meta.static voidMetaTableAccessor.updateTableState(Connection conn, TableName tableName, TableState.State actual) Updates state in META Do not use.Constructors in org.apache.hadoop.hbase with parameters of type Connection -
Uses of Connection in org.apache.hadoop.hbase.backup
Fields in org.apache.hadoop.hbase.backup declared as ConnectionMethods in org.apache.hadoop.hbase.backup with parameters of type ConnectionModifier and TypeMethodDescriptionstatic TableBackupClientBackupClientFactory.create(Connection conn, String backupId, BackupRequest request) private StringRestoreDriver.getTablesForSet(Connection conn, String name) -
Uses of Connection in org.apache.hadoop.hbase.backup.example
Constructors in org.apache.hadoop.hbase.backup.example with parameters of type ConnectionModifierConstructorDescriptionHFileArchiveManager(Connection connection, org.apache.hadoop.conf.Configuration conf) -
Uses of Connection in org.apache.hadoop.hbase.backup.impl
Fields in org.apache.hadoop.hbase.backup.impl declared as ConnectionModifier and TypeFieldDescriptionprivate final ConnectionBackupAdminImpl.conn(package private) ConnectionBackupCommands.Command.connprotected final ConnectionBackupManager.connprivate ConnectionRestoreTablesClient.connprotected ConnectionTableBackupClient.connprivate final ConnectionBackupSystemTable.connectionConnection to HBase cluster, shared among all instancesMethods in org.apache.hadoop.hbase.backup.impl that return ConnectionMethods in org.apache.hadoop.hbase.backup.impl with parameters of type ConnectionModifier and TypeMethodDescriptionstatic voidTableBackupClient.cleanupAndRestoreBackupSystem(Connection conn, BackupInfo backupInfo, org.apache.hadoop.conf.Configuration conf) protected voidTableBackupClient.completeBackup(Connection conn, BackupInfo backupInfo, BackupManager backupManager, BackupType type, org.apache.hadoop.conf.Configuration conf) Complete the overall backup.static voidBackupSystemTable.deleteSnapshot(Connection conn) protected static voidTableBackupClient.deleteSnapshots(Connection conn, BackupInfo backupInfo, org.apache.hadoop.conf.Configuration conf) Delete HBase snapshot for backup.protected voidTableBackupClient.failBackup(Connection conn, BackupInfo backupInfo, BackupManager backupManager, Exception e, String msg, BackupType type, org.apache.hadoop.conf.Configuration conf) Fail the overall backup.voidTableBackupClient.init(Connection conn, String backupId, BackupRequest request) private voidBackupCommands.RepairCommand.repairFailedBackupDeletionIfAny(Connection conn, BackupSystemTable sysTable) static voidBackupCommands.RepairCommand.repairFailedBackupMergeIfAny(Connection conn, BackupSystemTable sysTable) static voidBackupSystemTable.restoreFromSnapshot(Connection conn) static voidBackupSystemTable.snapshot(Connection conn) static booleanBackupSystemTable.snapshotExists(Connection conn) protected booleanIncrementalTableBackupClient.tableExists(TableName table, Connection conn) Constructors in org.apache.hadoop.hbase.backup.impl with parameters of type ConnectionModifierConstructorDescriptionBackupAdminImpl(Connection conn) BackupManager(Connection conn, org.apache.hadoop.conf.Configuration conf) Backup manager constructor.BackupSystemTable(Connection conn) FullTableBackupClient(Connection conn, String backupId, BackupRequest request) IncrementalBackupManager(Connection conn, org.apache.hadoop.conf.Configuration conf) IncrementalTableBackupClient(Connection conn, String backupId, BackupRequest request) RestoreTablesClient(Connection conn, RestoreRequest request) TableBackupClient(Connection conn, String backupId, BackupRequest request) -
Uses of Connection in org.apache.hadoop.hbase.backup.mapreduce
Methods in org.apache.hadoop.hbase.backup.mapreduce with parameters of type ConnectionModifier and TypeMethodDescriptionprotected voidMapReduceBackupMergeJob.deleteBackupImages(List<String> backupIds, Connection conn, org.apache.hadoop.fs.FileSystem fs, String backupRoot) -
Uses of Connection in org.apache.hadoop.hbase.backup.master
Fields in org.apache.hadoop.hbase.backup.master declared as Connection -
Uses of Connection in org.apache.hadoop.hbase.backup.util
Methods in org.apache.hadoop.hbase.backup.util with parameters of type ConnectionModifier and TypeMethodDescriptionprivate voidRestoreTool.checkAndCreateTable(Connection conn, TableName targetTableName, ArrayList<org.apache.hadoop.fs.Path> regionDirList, TableDescriptor htd, boolean truncateIfExists) Prepare the table for bulkload, most codes copied fromcreateTablemethod inBulkLoadHFilesTool.static voidBackupUtils.copyTableRegionInfo(Connection conn, BackupInfo backupInfo, org.apache.hadoop.conf.Configuration conf) copy out Table RegionInfo into incremental backup image need to consider move this logic into HBackupFileSystemprivate voidRestoreTool.createAndRestoreTable(Connection conn, TableName tableName, TableName newTableName, org.apache.hadoop.fs.Path tableBackupPath, boolean truncateIfExists, String lastIncrBackupId) voidRestoreTool.fullRestoreTable(Connection conn, org.apache.hadoop.fs.Path tableBackupPath, TableName tableName, TableName newTableName, boolean truncateIfExists, String lastIncrBackupId) voidRestoreTool.incrementalRestoreTable(Connection conn, org.apache.hadoop.fs.Path tableBackupPath, org.apache.hadoop.fs.Path[] logDirs, TableName[] tableNames, TableName[] newTableNames, String incrBackupId) During incremental backup operation.(package private) voidRestoreTool.modifyTableSync(Connection conn, TableDescriptor desc) -
Uses of Connection in org.apache.hadoop.hbase.client
Subinterfaces of Connection in org.apache.hadoop.hbase.clientModifier and TypeInterfaceDescriptioninterfaceInternal methods on Connection that should not be used by user code.Classes in org.apache.hadoop.hbase.client that implement ConnectionModifier and TypeClassDescriptionclassMain implementation ofConnectionandClusterConnectioninterfaces.(package private) static classSome tests shut down the master.static final classA 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.Fields in org.apache.hadoop.hbase.client declared as ConnectionModifier and TypeFieldDescription(package private) ConnectionConnectionImplementation.MasterServiceState.connectionprivate final ConnectionRegionServerCallable.connectionMethods in org.apache.hadoop.hbase.client that return ConnectionModifier and TypeMethodDescriptionstatic ConnectionConnectionFactory.createConnection()Create a new Connection instance using default HBaseConfiguration.static ConnectionConnectionFactory.createConnection(org.apache.hadoop.conf.Configuration conf) Create a new Connection instance using the passedconfinstance.static ConnectionConnectionFactory.createConnection(org.apache.hadoop.conf.Configuration conf, ExecutorService pool) Create a new Connection instance using the passedconfinstance.static ConnectionConnectionFactory.createConnection(org.apache.hadoop.conf.Configuration conf, ExecutorService pool, User user) Create a new Connection instance using the passedconfinstance.static ConnectionConnectionFactory.createConnection(org.apache.hadoop.conf.Configuration conf, ExecutorService pool, User user, Map<String, byte[]> connectionAttributes) Create a new Connection instance using the passedconfinstance.static ConnectionConnectionFactory.createConnection(org.apache.hadoop.conf.Configuration conf, User user) Create a new Connection instance using the passedconfinstance.Admin.getConnection()Returns Connection used by this object.HBaseAdmin.getConnection()Returns Connection used by this object.protected ConnectionHTable.getConnection()INTERNAL Used by unit tests and tools to do low-level manipulations.(package private) ConnectionRegionAdminServiceCallable.getConnection()ReturnsConnectioninstance used by this Callable.Methods in org.apache.hadoop.hbase.client with parameters of type ConnectionModifier and TypeMethodDescriptionvoidSecureBulkLoadClient.cleanupBulkLoad(Connection conn, String bulkToken) (package private) static HTableDescriptorHBaseAdmin.getHTableDescriptor(TableName tableName, Connection connection, RpcRetryingCallerFactory rpcCallerFactory, RpcControllerFactory rpcControllerFactory, int operationTimeout, int rpcTimeout) Deprecated.since 2.0 version and will be removed in 3.0 version.(package private) static TableDescriptorHBaseAdmin.getTableDescriptor(TableName tableName, Connection connection, RpcRetryingCallerFactory rpcCallerFactory, RpcControllerFactory rpcControllerFactory, int operationTimeout, int rpcTimeout) SecureBulkLoadClient.prepareBulkLoad(Connection conn) Constructors in org.apache.hadoop.hbase.client with parameters of type ConnectionModifierConstructorDescription(package private)CancellableRegionServerCallable(Connection connection, TableName tableName, byte[] row, org.apache.hbase.thirdparty.com.google.protobuf.RpcController rpcController, int rpcTimeout, RetryingTimeTracker tracker, int priority, Map<String, byte[]> requestAttributes) ClientServiceCallable(Connection connection, TableName tableName, byte[] row, org.apache.hbase.thirdparty.com.google.protobuf.RpcController rpcController, int priority, Map<String, byte[]> requestAttributes) HTableMultiplexer(Connection conn, org.apache.hadoop.conf.Configuration conf, int perRegionServerBufferQueueSize) Deprecated.(package private)MasterCallable(Connection connection, RpcControllerFactory rpcConnectionFactory) (package private)MasterServiceState(Connection connection) NoncedRegionServerCallable(Connection connection, TableName tableName, byte[] row, HBaseRpcController rpcController, int priority, Map<String, byte[]> requestAttributes) RegionServerCallable(Connection connection, TableName tableName, byte[] row, org.apache.hbase.thirdparty.com.google.protobuf.RpcController rpcController, int priority, Map<String, byte[]> requestAttributes) RegionServerCallable(Connection connection, TableName tableName, byte[] row, org.apache.hbase.thirdparty.com.google.protobuf.RpcController rpcController, Map<String, byte[]> requestAttributes) -
Uses of Connection in org.apache.hadoop.hbase.client.example
Fields in org.apache.hadoop.hbase.client.example declared as ConnectionModifier and TypeFieldDescriptionprivate final ConnectionMultiThreadedClientExample.ReadExampleCallable.connectionprivate final ConnectionMultiThreadedClientExample.SingleWriteExampleCallable.connectionprivate final ConnectionMultiThreadedClientExample.WriteExampleCallable.connectionprivate final ConnectionRefreshHFilesClient.connectionMethods in org.apache.hadoop.hbase.client.example with parameters of type ConnectionModifier and TypeMethodDescriptionprivate voidMultiThreadedClientExample.warmUpConnectionCache(Connection connection, TableName tn) Constructors in org.apache.hadoop.hbase.client.example with parameters of type ConnectionModifierConstructorDescriptionReadExampleCallable(Connection connection, TableName tableName) SingleWriteExampleCallable(Connection connection, TableName tableName) WriteExampleCallable(Connection connection, TableName tableName) -
Uses of Connection in org.apache.hadoop.hbase.client.replication
Fields in org.apache.hadoop.hbase.client.replication declared as ConnectionModifier and TypeFieldDescriptionprivate final ConnectionReplicationAdmin.connectionDeprecated. -
Uses of Connection in org.apache.hadoop.hbase.coprocessor
Methods in org.apache.hadoop.hbase.coprocessor that return ConnectionModifier and TypeMethodDescriptionMasterCoprocessorEnvironment.createConnection(org.apache.hadoop.conf.Configuration conf) Creates a cluster connection using the passed Configuration.RegionCoprocessorEnvironment.createConnection(org.apache.hadoop.conf.Configuration conf) Creates a cluster connection using the passed Configuration.RegionServerCoprocessorEnvironment.createConnection(org.apache.hadoop.conf.Configuration conf) Creates a cluster connection using the passed Configuration.MasterCoprocessorEnvironment.getConnection()Returns the hosts' Connection to the Cluster.RegionCoprocessorEnvironment.getConnection()Returns the hosts' Connection to the Cluster.RegionServerCoprocessorEnvironment.getConnection()Returns the hosts' Connection to the Cluster. -
Uses of Connection in org.apache.hadoop.hbase.favored
Methods in org.apache.hadoop.hbase.favored with parameters of type ConnectionModifier and TypeMethodDescriptionstatic voidFavoredNodeAssignmentHelper.updateMetaWithFavoredNodesInfo(Map<RegionInfo, List<ServerName>> regionToFavoredNodes, Connection connection) Update meta table with favored nodes info -
Uses of Connection in org.apache.hadoop.hbase.hbtop.screen
Fields in org.apache.hadoop.hbase.hbtop.screen declared as Connection -
Uses of Connection in org.apache.hadoop.hbase.mapred
Fields in org.apache.hadoop.hbase.mapred declared as ConnectionModifier and TypeFieldDescriptionprivate ConnectionTableOutputFormat.TableRecordWriter.connprivate ConnectionHRegionPartitioner.connectionprivate ConnectionTableInputFormatBase.connectionMethods in org.apache.hadoop.hbase.mapred with parameters of type ConnectionModifier and TypeMethodDescriptionprotected voidTableInputFormatBase.initializeTable(Connection connection, TableName tableName) Allows subclasses to initialize the table information. -
Uses of Connection in org.apache.hadoop.hbase.mapreduce
Fields in org.apache.hadoop.hbase.mapreduce declared as ConnectionModifier and TypeFieldDescriptionprivate ConnectionHRegionPartitioner.connection(package private) ConnectionMultiTableOutputFormat.MultiTableRecordWriter.connectionprivate ConnectionTableInputFormatBase.connectionThe underlyingConnectionof the table.private ConnectionTableOutputFormat.TableRecordWriter.connection(package private) ConnectionSyncTable.SyncMapper.sourceConnection(package private) ConnectionSyncTable.SyncMapper.targetConnectionMethods in org.apache.hadoop.hbase.mapreduce that return ConnectionModifier and TypeMethodDescriptionprivate static ConnectionSyncTable.SyncMapper.openConnection(org.apache.hadoop.conf.Configuration conf, String zkClusterConfKey, String configPrefix) Methods in org.apache.hadoop.hbase.mapreduce with parameters of type ConnectionModifier and TypeMethodDescriptionprotected voidTableInputFormatBase.initializeTable(Connection connection, TableName tableName) Allows subclasses to initialize the table information.private static TableSyncTable.SyncMapper.openTable(Connection connection, org.apache.hadoop.conf.Configuration conf, String tableNameConfKey) -
Uses of Connection in org.apache.hadoop.hbase.mapreduce.replication
Fields in org.apache.hadoop.hbase.mapreduce.replication declared as ConnectionModifier and TypeFieldDescriptionprivate ConnectionVerifyReplication.Verifier.replicatedConnectionprivate ConnectionVerifyReplication.Verifier.sourceConnection -
Uses of Connection in org.apache.hadoop.hbase.master
Fields in org.apache.hadoop.hbase.master declared as ConnectionModifier and TypeFieldDescriptionprivate final ConnectionRegionPlacementMaintainer.connectionprivate final ConnectionSnapshotOfRegionAssignmentFromMeta.connectionMethods in org.apache.hadoop.hbase.master that return ConnectionModifier and TypeMethodDescriptionMasterCoprocessorHost.MasterEnvironment.createConnection(org.apache.hadoop.conf.Configuration conf) MasterCoprocessorHost.MasterEnvironment.getConnection()Methods in org.apache.hadoop.hbase.master with parameters of type ConnectionModifier and TypeMethodDescriptionprivate voidTableStateManager.fixTableStates(TableDescriptors tableDescriptors, Connection connection) Constructors in org.apache.hadoop.hbase.master with parameters of type ConnectionModifierConstructorDescriptionSnapshotOfRegionAssignmentFromMeta(Connection connection) SnapshotOfRegionAssignmentFromMeta(Connection connection, Set<TableName> disabledTables, boolean excludeOfflinedSplitParents) -
Uses of Connection in org.apache.hadoop.hbase.master.cleaner
Fields in org.apache.hadoop.hbase.master.cleaner declared as ConnectionConstructors in org.apache.hadoop.hbase.master.cleaner with parameters of type ConnectionModifierConstructorDescriptionReplicationBarrierCleaner(org.apache.hadoop.conf.Configuration conf, Stoppable stopper, Connection conn, ReplicationPeerManager peerManager) -
Uses of Connection in org.apache.hadoop.hbase.master.http.api_v1.cluster_metrics.resource
Fields in org.apache.hadoop.hbase.master.http.api_v1.cluster_metrics.resource declared as ConnectionModifier and TypeFieldDescription(package private) final ConnectionClusterMetricsResource.connection -
Uses of Connection in org.apache.hadoop.hbase.master.procedure
Fields in org.apache.hadoop.hbase.master.procedure declared as ConnectionModifier and TypeFieldDescriptionprivate final ConnectionHBCKServerCrashProcedure.UnknownServerVisitor.connectionConstructors in org.apache.hadoop.hbase.master.procedure with parameters of type ConnectionModifierConstructorDescriptionprivateUnknownServerVisitor(Connection connection, ServerName unknownServerName) -
Uses of Connection in org.apache.hadoop.hbase.namequeues
Fields in org.apache.hadoop.hbase.namequeues declared as ConnectionMethods in org.apache.hadoop.hbase.namequeues with parameters of type ConnectionModifier and TypeMethodDescriptionvoidSlowLogPersistentService.addAllLogsToSysTable(Connection connection) Poll from queueForSysTable and insert 100 records in hbase:slowlog table in single batchstatic voidWALEventTrackerTableAccessor.addWalEventTrackerRows(Queue<WALEventTrackerPayload> walEventPayloads, Connection connection) Add wal event tracker rows to hbase:waleventtracker tableprivate static voidWALEventTrackerTableAccessor.doPut(Connection connection, List<Put> puts) (package private) voidLogEventHandler.persistAll(NamedQueuePayload.NamedQueueEvent namedQueueEvent, Connection connection) Add all in memory queue records to system table.voidNamedQueueRecorder.persistAll(NamedQueuePayload.NamedQueueEvent namedQueueEvent, Connection connection) Add all in memory queue records to system table.voidNamedQueueService.persistAll(Connection connection) Add all in memory queue records to system table.voidWALEventTrackerQueueService.persistAll(Connection connection) Constructors in org.apache.hadoop.hbase.namequeues with parameters of type ConnectionModifierConstructorDescriptionNamedQueueServiceChore(Stoppable stopper, int period, NamedQueueRecorder namedQueueRecorder, Connection connection) Chore Constructor -
Uses of Connection in org.apache.hadoop.hbase.namequeues.impl
Methods in org.apache.hadoop.hbase.namequeues.impl with parameters of type ConnectionModifier and TypeMethodDescriptionvoidBalancerDecisionQueueService.persistAll(Connection connection) voidBalancerRejectionQueueService.persistAll(Connection connection) voidSlowLogQueueService.persistAll(Connection connection) Add all slowLog events to system table. -
Uses of Connection in org.apache.hadoop.hbase.quotas
Fields in org.apache.hadoop.hbase.quotas declared as ConnectionModifier and TypeFieldDescription(package private) final ConnectionFileArchiverNotifierFactoryImpl.CacheKey.connprivate final ConnectionFileArchiverNotifierImpl.connprivate final ConnectionNamespaceQuotaSnapshotStore.connprivate final ConnectionQuotaObserverChore.connprivate final ConnectionQuotaObserverChore.TablesWithQuotas.connprivate final ConnectionSnapshotQuotaObserverChore.connprivate final ConnectionSpaceQuotaRefresherChore.connprivate final ConnectionTableQuotaSnapshotStore.connprivate ConnectionTableSpaceQuotaSnapshotNotifier.connprivate ConnectionQuotaRetriever.connectionConnection to use.Methods in org.apache.hadoop.hbase.quotas that return ConnectionModifier and TypeMethodDescription(package private) ConnectionRegionServerSpaceQuotaManager.getConnection()(package private) ConnectionSpaceQuotaRefresherChore.getConnection()Methods in org.apache.hadoop.hbase.quotas with parameters of type ConnectionModifier and TypeMethodDescriptionstatic voidQuotaUtil.addNamespaceQuota(Connection connection, String namespace, org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Quotas data) private static voidQuotaUtil.addQuotas(Connection connection, byte[] rowKey, byte[] qualifier, org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Quotas data) private static voidQuotaUtil.addQuotas(Connection connection, byte[] rowKey, org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Quotas data) static voidQuotaUtil.addRegionServerQuota(Connection connection, String regionServer, org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Quotas data) static voidQuotaUtil.addTableQuota(Connection connection, TableName table, org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Quotas data) static voidQuotaUtil.addUserQuota(Connection connection, String user, String namespace, org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Quotas data) static voidQuotaUtil.addUserQuota(Connection connection, String user, org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Quotas data) static voidQuotaUtil.addUserQuota(Connection connection, String user, TableName table, org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Quotas data) QuotaTableUtil.createDeletesForExistingNamespaceSnapshotSizes(Connection connection) Returns a list ofDeleteto remove all namespace snapshot entries from quota table.QuotaTableUtil.createDeletesForExistingSnapshotsFromScan(Connection connection, Scan scan) Returns a list ofDeleteto remove all entries returned by the passed scanner.QuotaTableUtil.createDeletesForExistingTableSnapshotSizes(Connection connection) Returns a list ofDeleteto remove all table snapshot entries from quota table.static voidQuotaUtil.deleteNamespaceQuota(Connection connection, String namespace) private static voidQuotaUtil.deleteQuotas(Connection connection, byte[] rowKey) private static voidQuotaUtil.deleteQuotas(Connection connection, byte[] rowKey, byte[] qualifier) static voidQuotaUtil.deleteRegionServerQuota(Connection connection, String regionServer) static voidQuotaUtil.deleteTableQuota(Connection connection, TableName table) (package private) static voidQuotaTableUtil.deleteTableUsageSnapshotsForNamespace(Connection connection, String namespace) Remove table usage snapshots (u:p columns) for the namespace passedstatic voidQuotaUtil.deleteUserQuota(Connection connection, String user) static voidQuotaUtil.deleteUserQuota(Connection connection, String user, String namespace) static voidQuotaUtil.deleteUserQuota(Connection connection, String user, TableName table) static voidQuotaUtil.disableTableIfNotDisabled(Connection conn, TableName tableName) Method to disable a table, if not already disabled.private static voidQuotaUtil.doDelete(Connection connection, Delete delete) protected static Result[]QuotaTableUtil.doGet(Connection connection, List<Get> gets) protected static ResultQuotaTableUtil.doGet(Connection connection, Get get) private static voidQuotaUtil.doPut(Connection connection, Put put) static voidQuotaUtil.enableTableIfNotEnabled(Connection conn, TableName tableName) Method to enable a table, if not already enabled.static <K> Map<K,QuotaState> QuotaUtil.fetchGlobalQuotas(String type, Connection connection, List<Get> gets, QuotaUtil.KeyFromRow<K> kfr) static Map<String,QuotaState> QuotaUtil.fetchNamespaceQuotas(Connection connection, List<Get> gets, double factor) static Map<String,QuotaState> QuotaUtil.fetchRegionServerQuotas(Connection connection, List<Get> gets) static Map<TableName,QuotaState> QuotaUtil.fetchTableQuotas(Connection connection, List<Get> gets, Map<TableName, Double> tableMachineFactors) static Map<String,UserQuotaState> QuotaUtil.fetchUserQuotas(Connection connection, List<Get> gets, Map<TableName, Double> tableMachineQuotaFactors, double factor) FileArchiverNotifierFactory.get(Connection conn, org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.fs.FileSystem fs, TableName tn) Creates or obtains aFileArchiverNotifierinstance for the given args.FileArchiverNotifierFactoryImpl.get(Connection conn, org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.fs.FileSystem fs, TableName tn) Returns theFileArchiverNotifierinstance for the givenTableName.static SpaceQuotaSnapshotQuotaTableUtil.getCurrentSnapshotFromQuotaTable(Connection conn, 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(Connection connection, String namespace) QuotaTableUtil.getNamespaceSnapshots(Connection conn) Returns a set of the names of all namespaces containing snapshot entries.(package private) static longQuotaTableUtil.getNamespaceSnapshotSize(Connection conn, String namespace) Fetches the computed size of all snapshots against tables in a namespace for space quotas.QuotaTableUtil.getObservedSnapshotSizes(Connection conn) Fetches any persisted HBase snapshot sizes stored in the quota table.private static org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.QuotasQuotaTableUtil.getQuotas(Connection connection, byte[] rowKey) private static org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.QuotasQuotaTableUtil.getQuotas(Connection connection, byte[] rowKey, byte[] qualifier) static org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.QuotasQuotaTableUtil.getRegionServerQuota(Connection connection, String regionServer) static Map<TableName,SpaceQuotaSnapshot> QuotaTableUtil.getSnapshots(Connection conn) Fetches allSpaceQuotaSnapshotobjects from thehbase:quotatable.static org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.QuotasQuotaTableUtil.getTableQuota(Connection connection, TableName table) QuotaTableUtil.getTableSnapshots(Connection conn) Returns a multimap for all existing table snapshot entries.static org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.QuotasQuotaTableUtil.getUserQuota(Connection connection, String user) static org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.QuotasQuotaTableUtil.getUserQuota(Connection connection, String user, String namespace) static org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.QuotasQuotaTableUtil.getUserQuota(Connection connection, String user, TableName table) (package private) voidQuotaRetriever.init(Connection conn, Scan scan) voidSpaceQuotaSnapshotNotifier.initialize(Connection conn) Initializes the notifier.voidTableSpaceQuotaSnapshotNotifier.initialize(Connection conn) protected static booleanQuotaUtil.isExceedThrottleQuotaEnabled(Connection connection) voidMasterQuotaManager.processFileArchivals(org.apache.hadoop.hbase.shaded.protobuf.generated.RegionServerStatusProtos.FileArchiveNotificationRequest request, Connection conn, org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.fs.FileSystem fs) protected static voidQuotaUtil.switchExceedThrottleQuota(Connection connection, boolean exceedThrottleQuotaEnabled) Constructors in org.apache.hadoop.hbase.quotas with parameters of type ConnectionModifierConstructorDescription(package private)CacheKey(Connection conn, org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.fs.FileSystem fs, TableName tn) FileArchiverNotifierImpl(Connection conn, org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.fs.FileSystem fs, TableName tn) NamespaceQuotaSnapshotStore(Connection conn, QuotaObserverChore chore, Map<RegionInfo, Long> regionUsage) (package private)QuotaObserverChore(Connection conn, org.apache.hadoop.conf.Configuration conf, SpaceQuotaSnapshotNotifier snapshotNotifier, MasterQuotaManager quotaManager, Stoppable stopper, MetricsMaster metrics) (package private)SnapshotQuotaObserverChore(Connection conn, org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.fs.FileSystem fs, Stoppable stopper, MetricsMaster metrics) SpaceQuotaRefresherChore(RegionServerSpaceQuotaManager manager, Connection conn) TableQuotaSnapshotStore(Connection conn, QuotaObserverChore chore, Map<RegionInfo, Long> regionUsage) TablesWithQuotas(Connection conn, org.apache.hadoop.conf.Configuration conf) -
Uses of Connection in org.apache.hadoop.hbase.regionserver
Fields in org.apache.hadoop.hbase.regionserver declared as ConnectionMethods in org.apache.hadoop.hbase.regionserver that return ConnectionModifier and TypeMethodDescriptionHRegionServer.createConnection(org.apache.hadoop.conf.Configuration conf) RegionCoprocessorHost.RegionEnvironment.createConnection(org.apache.hadoop.conf.Configuration conf) RegionServerCoprocessorHost.RegionServerEnvironment.createConnection(org.apache.hadoop.conf.Configuration conf) HRegionServer.getConnection()RegionCoprocessorHost.RegionEnvironment.getConnection()RegionServerCoprocessorHost.RegionServerEnvironment.getConnection()Constructors in org.apache.hadoop.hbase.regionserver with parameters of type ConnectionModifierConstructorDescription(package private)SecureBulkLoadManager(org.apache.hadoop.conf.Configuration conf, Connection conn) -
Uses of Connection in org.apache.hadoop.hbase.replication.regionserver
Fields in org.apache.hadoop.hbase.replication.regionserver declared as ConnectionModifier and TypeFieldDescriptionprivate final ConnectionReplicationSinkManager.connprivate final ConnectionSerialReplicationChecker.connprivate ConnectionHFileReplicator.connectionprivate ConnectionReplicationSink.sharedConnectionThis sharedConnectionis used for handling bulk load hfiles replication.Methods in org.apache.hadoop.hbase.replication.regionserver that return ConnectionModifier and TypeMethodDescriptionprotected ConnectionHBaseInterClusterReplicationEndpoint.createConnection(org.apache.hadoop.conf.Configuration conf) ReplicationSyncUp.DummyServer.createConnection(org.apache.hadoop.conf.Configuration conf) private ConnectionReplicationSink.getConnection()Return the sharedConnectionwhich is used for handling bulk load hfiles replication.Methods in org.apache.hadoop.hbase.replication.regionserver with parameters of type ConnectionModifier and TypeMethodDescriptionprotected ReplicationSinkManagerHBaseInterClusterReplicationEndpoint.createReplicationSinkManager(Connection conn) voidWALEntrySinkFilter.init(Connection connection) Called after Construction.Constructors in org.apache.hadoop.hbase.replication.regionserver with parameters of type ConnectionModifierConstructorDescriptionHFileReplicator(org.apache.hadoop.conf.Configuration sourceClusterConf, String sourceBaseNamespaceDirPath, String sourceHFileArchiveDirPath, Map<String, List<Pair<byte[], List<String>>>> tableQueueMap, org.apache.hadoop.conf.Configuration conf, Connection connection, List<String> sourceClusterIds) -
Uses of Connection in org.apache.hadoop.hbase.rsgroup
Fields in org.apache.hadoop.hbase.rsgroup declared as ConnectionConstructors in org.apache.hadoop.hbase.rsgroup with parameters of type Connection -
Uses of Connection in org.apache.hadoop.hbase.security.access
Methods in org.apache.hadoop.hbase.security.access with parameters of type ConnectionModifier and TypeMethodDescription(package private) static voidSnapshotScannerHDFSAclController.SnapshotScannerHDFSAclStorage.addUserTableHdfsAcl(Connection connection, String user, TableName tableName) (package private) static voidSnapshotScannerHDFSAclController.SnapshotScannerHDFSAclStorage.addUserTableHdfsAcl(Connection connection, Set<String> users, TableName tableName) (package private) static voidSnapshotScannerHDFSAclController.SnapshotScannerHDFSAclStorage.deleteNamespaceHdfsAcl(Connection connection, String namespace) (package private) static voidSnapshotScannerHDFSAclController.SnapshotScannerHDFSAclStorage.deleteUserTableHdfsAcl(Connection connection, Set<String> users, TableName tableName) static List<UserPermission>AccessControlClient.getUserPermissions(Connection connection, String tableRegex) List all the userPermissions matching the given pattern.static List<UserPermission>AccessControlClient.getUserPermissions(Connection connection, String tableRegex, byte[] columnFamily) List all the userPermissions matching the given table pattern and column family.static List<UserPermission>AccessControlClient.getUserPermissions(Connection connection, String tableRegex, byte[] columnFamily, byte[] columnQualifier) List all the userPermissions matching the given table pattern, column family and column qualifier.static List<UserPermission>AccessControlClient.getUserPermissions(Connection connection, String tableRegex, byte[] columnFamily, byte[] columnQualifier, String userName) List all the userPermissions matching the given table pattern, column family and column qualifier.static List<UserPermission>AccessControlClient.getUserPermissions(Connection connection, String tableRegex, byte[] columnFamily, String userName) List all the userPermissions matching the given table pattern, column family and user name.static List<UserPermission>AccessControlClient.getUserPermissions(Connection connection, String tableRegex, String userName) List all the userPermissions matching the given table pattern and user name.private static voidAccessControlClient.grant(Connection connection, String userName, boolean mergeExistingPermissions, Permission.Action... actions) Grant global permissions for the specified user.private static voidAccessControlClient.grant(Connection connection, String namespace, String userName, boolean mergeExistingPermissions, Permission.Action... actions) Grants permission on the specified namespace for the specified user.static voidAccessControlClient.grant(Connection connection, String namespace, String userName, Permission.Action... actions) Grants permission on the specified namespace for the specified user.static voidAccessControlClient.grant(Connection connection, String userName, Permission.Action... actions) Grant global permissions for the specified user.private static voidAccessControlClient.grant(Connection connection, TableName tableName, String userName, byte[] family, byte[] qual, boolean mergeExistingPermissions, Permission.Action... actions) Grants permission on the specified table for the specified userstatic voidAccessControlClient.grant(Connection connection, TableName tableName, String userName, byte[] family, byte[] qual, Permission.Action... actions) Grants permission on the specified table for the specified user.static booleanAccessControlClient.hasPermission(Connection connection, String tableName, byte[] columnFamily, byte[] columnQualifier, String userName, Permission.Action... actions) Validates whether specified user has permission to perform actions on the mentioned table, column family or column qualifier.static booleanAccessControlClient.hasPermission(Connection connection, String tableName, String columnFamily, String columnQualifier, String userName, Permission.Action... actions) Validates whether specified user has permission to perform actions on the mentioned table, column family or column qualifier.static booleanAccessControlClient.isAccessControllerRunning(Connection connection) static booleanAccessControlClient.isAuthorizationEnabled(Connection connection) Return true if authorization is supported and enabledstatic booleanAccessControlClient.isCellAuthorizationEnabled(Connection connection) Return true if cell authorization is supported and enabledstatic voidAccessControlClient.revoke(Connection connection, String namespace, String userName, Permission.Action... actions) Revokes the permission on the namespace for the specified user.static voidAccessControlClient.revoke(Connection connection, String userName, Permission.Action... actions) Revoke global permissions for the specified user.static voidAccessControlClient.revoke(Connection connection, TableName tableName, String username, byte[] family, byte[] qualifier, Permission.Action... actions) Revokes the permission on the tableConstructors in org.apache.hadoop.hbase.security.access with parameters of type ConnectionModifierConstructorDescriptionSnapshotScannerHDFSAclHelper(org.apache.hadoop.conf.Configuration configuration, Connection connection) -
Uses of Connection in org.apache.hadoop.hbase.security.provider.example
Methods in org.apache.hadoop.hbase.security.provider.example with parameters of type ConnectionModifier and TypeMethodDescriptionstatic org.apache.hadoop.security.token.Token<? extends org.apache.hadoop.security.token.TokenIdentifier>ShadeClientTokenUtil.obtainToken(Connection conn, String username, char[] password) -
Uses of Connection in org.apache.hadoop.hbase.security.token
Methods in org.apache.hadoop.hbase.security.token with parameters of type ConnectionModifier and TypeMethodDescriptionstatic voidTokenUtil.addTokenForJob(Connection conn, User user, org.apache.hadoop.mapreduce.Job job) Checks for an authentication token for the given user, obtaining a new token if necessary, and adds it to the credentials for the given map reduce job.static voidTokenUtil.addTokenForJob(Connection conn, org.apache.hadoop.mapred.JobConf job, User user) Checks for an authentication token for the given user, obtaining a new token if necessary, and adds it to the credentials for the given map reduce job.static booleanTokenUtil.addTokenIfMissing(Connection conn, User user) Checks if an authentication tokens exists for the connected cluster, obtaining one if needed and adding it to the user's credentials.private static org.apache.hadoop.security.token.Token<AuthenticationTokenIdentifier>TokenUtil.getAuthToken(Connection conn, User user) Get the authentication token of the user for the cluster specified in the configurationstatic voidClientTokenUtil.obtainAndCacheToken(Connection conn, User user) Obtain an authentication token for the given user and add it to the user's credentials.static voidTokenUtil.obtainAndCacheToken(Connection conn, User user) static org.apache.hadoop.security.token.Token<AuthenticationTokenIdentifier>ClientTokenUtil.obtainToken(Connection conn) Obtain and return an authentication token for the current user.(package private) static org.apache.hadoop.security.token.Token<AuthenticationTokenIdentifier>ClientTokenUtil.obtainToken(Connection conn, User user) Obtain and return an authentication token for the given user.static org.apache.hadoop.security.token.Token<AuthenticationTokenIdentifier>TokenUtil.obtainToken(Connection conn) Deprecated.External users should not use this method.static org.apache.hadoop.security.token.Token<AuthenticationTokenIdentifier>TokenUtil.obtainToken(Connection conn, User user) Deprecated.External users should not use this method.static voidTokenUtil.obtainTokenForJob(Connection conn, User user, org.apache.hadoop.mapreduce.Job job) Obtain an authentication token on behalf of the given user and add it to the credentials for the given map reduce job.static voidTokenUtil.obtainTokenForJob(Connection conn, org.apache.hadoop.mapred.JobConf job, User user) Obtain an authentication token on behalf of the given user and add it to the credentials for the given map reduce job. -
Uses of Connection in org.apache.hadoop.hbase.security.visibility
Methods in org.apache.hadoop.hbase.security.visibility with parameters of type ConnectionModifier and TypeMethodDescriptionstatic org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsResponseVisibilityClient.addLabel(Connection connection, String label) Utility method for adding label to the system.static org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsResponseVisibilityClient.addLabels(Connection connection, String[] labels) Utility method for adding labels to the system.static org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsResponseVisibilityClient.clearAuths(Connection connection, String[] auths, String user) Removes given labels from user's globally authorized list of labels.static org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.GetAuthsResponseVisibilityClient.getAuths(Connection connection, String user) Get the authorization for a given userstatic booleanVisibilityClient.isCellVisibilityEnabled(Connection connection) Return true if cell visibility features are supported and enabledstatic org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.ListLabelsResponseVisibilityClient.listLabels(Connection connection, String regex) Retrieve the list of visibility labels defined in the system.static org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsResponseVisibilityClient.setAuths(Connection connection, String[] auths, String user) Sets given labels globally authorized for the user.private static org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsResponseVisibilityClient.setOrClearAuths(Connection connection, String[] auths, String user, boolean setOrClear) -
Uses of Connection in org.apache.hadoop.hbase.slowlog
Methods in org.apache.hadoop.hbase.slowlog with parameters of type ConnectionModifier and TypeMethodDescriptionstatic voidSlowLogTableAccessor.addSlowLogRecords(List<org.apache.hadoop.hbase.shaded.protobuf.generated.TooSlowLog.SlowLogPayload> slowLogPayloads, Connection connection) Add slow/large log records to hbase:slowlog tableprivate static voidSlowLogTableAccessor.doPut(Connection connection, List<Put> puts) -
Uses of Connection in org.apache.hadoop.hbase.snapshot
Methods in org.apache.hadoop.hbase.snapshot with parameters of type ConnectionModifier and TypeMethodDescriptionvoidRestoreSnapshotHelper.RestoreMetaChanges.updateMetaParentRegions(Connection connection, List<RegionInfo> regionInfos) -
Uses of Connection in org.apache.hadoop.hbase.thrift2.client
Classes in org.apache.hadoop.hbase.thrift2.client that implement ConnectionMethods in org.apache.hadoop.hbase.thrift2.client that return Connection -
Uses of Connection in org.apache.hadoop.hbase.tool
Fields in org.apache.hadoop.hbase.tool declared as ConnectionModifier and TypeFieldDescriptionprotected ConnectionCanaryTool.Monitor.connectionprivate ConnectionCanaryTool.RegionServerTask.connectionprivate ConnectionCanaryTool.RegionTask.connectionprivate final ConnectionCanaryTool.ZookeeperTask.connectionMethods in org.apache.hadoop.hbase.tool with parameters of type ConnectionModifier and TypeMethodDescriptionprotected ClientServiceCallable<byte[]>LoadIncrementalHFiles.buildClientServiceCallable(Connection conn, TableName tableName, byte[] first, Collection<LoadIncrementalHFiles.LoadQueueItem> lqis, boolean copyFile) Deprecated.protected voidLoadIncrementalHFiles.bulkLoadPhase(Table table, Connection conn, ExecutorService pool, Deque<LoadIncrementalHFiles.LoadQueueItem> queue, org.apache.hbase.thirdparty.com.google.common.collect.Multimap<ByteBuffer, LoadIncrementalHFiles.LoadQueueItem> regionGroups, boolean copyFile, Map<LoadIncrementalHFiles.LoadQueueItem, ByteBuffer> item2RegionMap) Deprecated.This takes the LQI's grouped by likely regions and attempts to bulk load them.voidLoadIncrementalHFiles.loadHFileQueue(Table table, Connection conn, Deque<LoadIncrementalHFiles.LoadQueueItem> queue, Pair<byte[][], byte[][]> startEndKeys) Deprecated.Used by the replication sink to load the hfiles from the source cluster.voidLoadIncrementalHFiles.loadHFileQueue(Table table, Connection conn, Deque<LoadIncrementalHFiles.LoadQueueItem> queue, Pair<byte[][], byte[][]> startEndKeys, boolean copyFile) Deprecated.Used by the replication sink to load the hfiles from the source cluster.private CanaryTool.MonitorCanaryTool.newMonitor(Connection connection, String[] monitorTargets) A Factory method forCanaryTool.Monitor.protected List<LoadIncrementalHFiles.LoadQueueItem>LoadIncrementalHFiles.tryAtomicRegionLoad(Connection conn, TableName tableName, byte[] first, Collection<LoadIncrementalHFiles.LoadQueueItem> lqis, boolean copyFile) Deprecated.as of release 2.3.0.Constructors in org.apache.hadoop.hbase.tool with parameters of type ConnectionModifierConstructorDescriptionprotectedMonitor(Connection connection, String[] monitorTargets, boolean useRegExp, CanaryTool.Sink sink, ExecutorService executor, boolean treatFailureAsError, long allowedFailures) RegionMonitor(Connection connection, String[] monitorTargets, boolean useRegExp, CanaryTool.Sink sink, ExecutorService executor, boolean writeSniffing, TableName writeTableName, boolean treatFailureAsError, HashMap<String, Long> configuredReadTableTimeouts, long configuredWriteTableTimeout, long allowedFailures) RegionServerMonitor(Connection connection, String[] monitorTargets, boolean useRegExp, CanaryTool.Sink sink, ExecutorService executor, boolean allRegions, boolean treatFailureAsError, long allowedFailures) (package private)RegionServerTask(Connection connection, String serverName, RegionInfo region, CanaryTool.RegionServerStdOutSink sink, Boolean rawScanEnabled, AtomicLong successes) (package private)RegionTask(Connection connection, RegionInfo region, ServerName serverName, CanaryTool.RegionStdOutSink sink, CanaryTool.RegionTask.TaskType taskType, boolean rawScanEnabled, LongAdder rwLatency, boolean readAllCF) protectedZookeeperMonitor(Connection connection, String[] monitorTargets, boolean useRegExp, CanaryTool.Sink sink, ExecutorService executor, boolean treatFailureAsError, long allowedFailures) ZookeeperTask(Connection connection, String host, String znode, int timeout, CanaryTool.ZookeeperStdOutSink sink) -
Uses of Connection in org.apache.hadoop.hbase.util
Fields in org.apache.hadoop.hbase.util declared as ConnectionModifier and TypeFieldDescriptionprivate final ConnectionMoveWithAck.connprivate ConnectionRegionMover.conn(package private) final ConnectionConnectionCache.ConnectionInfo.connectionprivate Connection[]MultiHConnection.connectionsMethods in org.apache.hadoop.hbase.util with parameters of type ConnectionModifier and TypeMethodDescriptionstatic voidHBaseFsckRepair.closeRegionSilentlyAndWait(Connection connection, ServerName server, RegionInfo region) Contacts a region server and waits up to hbase.hbck.close.timeout ms (default 120s) to close the region.static voidHBaseFsckRepair.fixMultiAssignment(Connection connection, RegionInfo region, List<ServerName> servers) Fix multiple assignment by doing silent closes on each RS hosting the region and then force ZK unassigned node to OFFLINE to trigger assignment by master.private static intRegionSplitter.getRegionServerCount(Connection connection) Alternative getCurrentNrHRS which is no longer available.(package private) static ServerNameMoveWithAck.getServerNameForRegion(RegionInfo region, Admin admin, Connection conn) Get servername that is up in hbase:meta hosting the given region.(package private) static LinkedList<Pair<byte[],byte[]>> RegionSplitter.getSplits(Connection connection, TableName tableName, RegionSplitter.SplitAlgorithm splitAlgo) (package private) static LinkedList<Pair<byte[],byte[]>> RegionSplitter.splitScan(LinkedList<Pair<byte[], byte[]>> regionList, Connection connection, TableName tableName, RegionSplitter.SplitAlgorithm splitAlgo) Constructors in org.apache.hadoop.hbase.util with parameters of type ConnectionModifierConstructorDescription(package private)ConnectionInfo(Connection conn, String user) (package private)MoveWithAck(Connection conn, RegionInfo regionInfo, ServerName sourceServer, ServerName targetServer, List<RegionInfo> movedRegions) -
Uses of Connection in org.apache.hadoop.hbase.util.compaction
Fields in org.apache.hadoop.hbase.util.compaction declared as ConnectionModifier and TypeFieldDescriptionprotected final ConnectionMajorCompactionRequest.connectionprotected ConnectionMajorCompactor.connectionMethods in org.apache.hadoop.hbase.util.compaction with parameters of type ConnectionModifier and TypeMethodDescription(package private) Optional<MajorCompactionRequest>MajorCompactionRequest.createRequest(Connection connection, Set<String> stores, long timestamp) private Optional<MajorCompactionRequest>MajorCompactionTTLRequest.createRequest(Connection connection, TableDescriptor htd) (package private) static Optional<MajorCompactionRequest>MajorCompactionRequest.newRequest(Connection connection, RegionInfo info, Set<String> stores, long timestamp) (package private) static Optional<MajorCompactionRequest>MajorCompactionTTLRequest.newRequest(Connection connection, RegionInfo info, TableDescriptor htd) Constructors in org.apache.hadoop.hbase.util.compaction with parameters of type ConnectionModifierConstructorDescription(package private)MajorCompactionRequest(Connection connection, RegionInfo region) (package private)MajorCompactionRequest(Connection connection, RegionInfo region, Set<String> stores) (package private)MajorCompactionTTLRequest(Connection connection, RegionInfo region)
MetaTableAccessor.getRegionLocation(Connection, byte[])instead