Uses of Interface
org.apache.hadoop.hbase.client.Connection
Package
Description
Provides HBase Client
Table of Contents
Provides HBase MapReduce
Input/OutputFormats, a table indexing MapReduce job, and utility methods.
Provides HBase MapReduce
Input/OutputFormats, a table indexing MapReduce job, and utility methods.
Multi Cluster Replication
-
Uses of Connection in org.apache.hadoop.hbase
Modifier and TypeMethodDescriptionHBaseServerBase.createConnection
(org.apache.hadoop.conf.Configuration conf) MockRegionServerServices.createConnection
(org.apache.hadoop.conf.Configuration conf) Server.createConnection
(org.apache.hadoop.conf.Configuration conf) HBaseTestingUtility.getConnection()
Deprecated.Get a shared Connection to the cluster.HBaseTestingUtility.getConnection
(User user) Deprecated.Get a assigned Connection to the cluster.MockRegionServerServices.getConnection()
default Connection
Server.getConnection()
Returns a reference to the servers' connection.Modifier and TypeMethodDescriptionstatic void
MetaTableAccessor.addRegionsToMeta
(Connection connection, List<RegionInfo> regionInfos, int regionReplication) Adds a hbase:meta row for each of the specified new regions.static void
MetaTableAccessor.addRegionsToMeta
(Connection connection, List<RegionInfo> regionInfos, int regionReplication, long ts) Adds a hbase:meta row for each of the specified new regions.static void
MetaTableAccessor.addSplitsToParent
(Connection connection, RegionInfo regionInfo, RegionInfo splitA, RegionInfo splitB) Adds daughter region infos to hbase:meta row for the specified region.private static void
MetaTableAccessor.deleteFromMetaTable
(Connection connection, List<Delete> deletes) Delete the passeddeletes
from thehbase:meta
table.private static void
MetaTableAccessor.deleteFromMetaTable
(Connection connection, Delete d) Delete the passedd
from thehbase:meta
table.static void
MetaTableAccessor.deleteTableState
(Connection connection, TableName table) Remove state for table from metaMetaTableAccessor.fullScan
(Connection connection, ClientMetaTableAccessor.QueryType type) Performs a full scan ofhbase:meta
.static void
MetaTableAccessor.fullScanMetaAndPrint
(Connection connection) MetaTableAccessor.fullScanRegions
(Connection connection) Performs a full scan ofhbase:meta
for regions.static void
MetaTableAccessor.fullScanRegions
(Connection connection, ClientMetaTableAccessor.Visitor visitor) Performs a full scan ofhbase:meta
for regions.static void
MetaTableAccessor.fullScanTables
(Connection connection, ClientMetaTableAccessor.Visitor visitor) Performs a full scan ofhbase:meta
for tables.static List<RegionInfo>
MetaTableAccessor.getAllRegions
(Connection connection, boolean excludeOfflinedSplitParents) Lists all of the regions currently in META.static Result
MetaTableAccessor.getCatalogFamilyRow
(Connection connection, RegionInfo ri) Returns Return theHConstants.CATALOG_FAMILY
row from hbase:meta.private static RegionInfo
MetaTableAccessor.getClosestRegionInfo
(Connection connection, TableName tableName, byte[] row) Returns Get closest metatable region row to passedrow
static Table
MetaTableAccessor.getMetaHTable
(Connection connection) Callers should call close on the returnedTable
instance.static int
HBaseTestingUtility.getMetaRSPort
(Connection connection) Deprecated.static Pair<RegionInfo,
ServerName> MetaTableAccessor.getRegion
(Connection connection, byte[] regionName) Deprecated.static HRegionLocation
MetaTableAccessor.getRegionLocation
(Connection connection, byte[] regionName) Returns the HRegionLocation from meta for the given regionstatic HRegionLocation
MetaTableAccessor.getRegionLocation
(Connection connection, RegionInfo regionInfo) Returns the HRegionLocation from meta for the given regionstatic Result
MetaTableAccessor.getRegionResult
(Connection connection, RegionInfo regionInfo) Gets the result in hbase:meta for the specified region.static List<RegionInfo>
MetaTableAccessor.getTableRegions
(Connection connection, TableName tableName) Gets all of the regions of the specified table.static List<RegionInfo>
MetaTableAccessor.getTableRegions
(Connection connection, TableName tableName, boolean excludeOfflinedSplitParents) Gets all of the regions of the specified table.static List<Pair<RegionInfo,
ServerName>> MetaTableAccessor.getTableRegionsAndLocations
(Connection connection, TableName tableName) Do not use this method to get meta table regions, use methods in MetaTableLocator instead.static List<Pair<RegionInfo,
ServerName>> MetaTableAccessor.getTableRegionsAndLocations
(Connection connection, TableName tableName, boolean excludeOfflinedSplitParents) Do not use this method to get meta table regions, use methods in MetaTableLocator instead.static TableState
MetaTableAccessor.getTableState
(Connection conn, TableName tableName) Fetch table state for given table from META tablestatic Map<TableName,
TableState> MetaTableAccessor.getTableStates
(Connection conn) Fetch table states from META tablestatic void
MetaTableAccessor.putsToMetaTable
(Connection connection, List<Put> ps) Put the passedps
to thehbase:meta
table.private static void
MetaTableAccessor.putToMetaTable
(Connection connection, Put p) Put the passedp
to thehbase:meta
table.(package private) static PerformanceEvaluation.RunResult
PerformanceEvaluation.runOneClient
(Class<? extends PerformanceEvaluation.TestBase> cmd, org.apache.hadoop.conf.Configuration conf, Connection con, AsyncConnection asyncCon, PerformanceEvaluation.TestOptions opts, PerformanceEvaluation.Status status) static Result
MetaTableAccessor.scanByRegionEncodedName
(Connection connection, String regionEncodedName) Scans META table for a row whose key contains the specified regionEncodedName, returning a single relatedResult
instance if any row is found, null otherwise.static void
MetaTableAccessor.scanMeta
(Connection connection, byte[] startRow, byte[] stopRow, ClientMetaTableAccessor.QueryType type, int maxRows, ClientMetaTableAccessor.Visitor visitor) Performs a scan of META table.static void
MetaTableAccessor.scanMeta
(Connection connection, byte[] startRow, byte[] stopRow, ClientMetaTableAccessor.QueryType type, ClientMetaTableAccessor.Visitor visitor) static void
MetaTableAccessor.scanMeta
(Connection connection, byte[] startRow, byte[] stopRow, ClientMetaTableAccessor.QueryType type, Filter filter, int maxRows, ClientMetaTableAccessor.Visitor visitor) static void
MetaTableAccessor.scanMeta
(Connection connection, ClientMetaTableAccessor.Visitor visitor, TableName tableName, byte[] row, int rowLimit) Performs a scan of META table for given table starting from given row.private static void
MetaTableAccessor.scanMeta
(Connection connection, TableName table, ClientMetaTableAccessor.QueryType type, int maxRows, ClientMetaTableAccessor.Visitor visitor) static void
MetaTableAccessor.scanMetaForTableRegions
(Connection connection, ClientMetaTableAccessor.Visitor visitor, TableName tableName) private static void
MetaTableAccessor.updateLocation
(Connection connection, RegionInfo regionInfo, ServerName sn, long openSeqNum, long masterSystemTime) Updates the location of the specified region to be the specified server.static void
MetaTableAccessor.updateRegionLocation
(Connection connection, RegionInfo regionInfo, ServerName sn, long openSeqNum, long masterSystemTime) Updates the location of the specified region in hbase:meta to be the specified server hostname and startcode.static void
MetaTableAccessor.updateRegionState
(Connection connection, RegionInfo ri, RegionState.State state) Update state column in hbase:meta.private static void
MetaTableAccessor.updateTableState
(Connection connection, TableState state) Update state of the table in meta.static void
MetaTableAccessor.updateTableState
(Connection conn, TableName tableName, TableState.State actual) Updates state in META Do not use.ModifierConstructorDescription(package private)
AppendTest
(Connection con, PerformanceEvaluation.TestOptions options, PerformanceEvaluation.Status status) (package private)
BufferedMutatorTest
(Connection con, PerformanceEvaluation.TestOptions options, PerformanceEvaluation.Status status) (package private)
CASTableTest
(Connection con, PerformanceEvaluation.TestOptions options, PerformanceEvaluation.Status status) (package private)
CheckAndDeleteTest
(Connection con, PerformanceEvaluation.TestOptions options, PerformanceEvaluation.Status status) (package private)
CheckAndMutateTest
(Connection con, PerformanceEvaluation.TestOptions options, PerformanceEvaluation.Status status) (package private)
CheckAndPutTest
(Connection con, PerformanceEvaluation.TestOptions options, PerformanceEvaluation.Status status) (package private)
CleanMetaTest
(Connection con, PerformanceEvaluation.TestOptions options, PerformanceEvaluation.Status status) (package private)
FilteredScanTest
(Connection con, PerformanceEvaluation.TestOptions options, PerformanceEvaluation.Status status) (package private)
IncrementTest
(Connection con, PerformanceEvaluation.TestOptions options, PerformanceEvaluation.Status status) (package private)
MetaRandomReadTest
(Connection con, PerformanceEvaluation.TestOptions options, PerformanceEvaluation.Status status) (package private)
MetaTest
(Connection con, PerformanceEvaluation.TestOptions options, PerformanceEvaluation.Status status) (package private)
MetaWriteTest
(Connection con, PerformanceEvaluation.TestOptions options, PerformanceEvaluation.Status status) (package private)
RandomDeleteTest
(Connection con, PerformanceEvaluation.TestOptions options, PerformanceEvaluation.Status status) (package private)
RandomReadTest
(Connection con, PerformanceEvaluation.TestOptions options, PerformanceEvaluation.Status status) (package private)
RandomScanWithRange10000Test
(Connection con, PerformanceEvaluation.TestOptions options, PerformanceEvaluation.Status status) (package private)
RandomScanWithRange1000Test
(Connection con, PerformanceEvaluation.TestOptions options, PerformanceEvaluation.Status status) (package private)
RandomScanWithRange100Test
(Connection con, PerformanceEvaluation.TestOptions options, PerformanceEvaluation.Status status) (package private)
RandomScanWithRange10Test
(Connection con, PerformanceEvaluation.TestOptions options, PerformanceEvaluation.Status status) (package private)
RandomScanWithRangeTest
(Connection con, PerformanceEvaluation.TestOptions options, PerformanceEvaluation.Status status) (package private)
RandomSeekScanTest
(Connection con, PerformanceEvaluation.TestOptions options, PerformanceEvaluation.Status status) (package private)
RandomWriteTest
(Connection con, PerformanceEvaluation.TestOptions options, PerformanceEvaluation.Status status) (package private)
ReverseScanTest
(Connection con, PerformanceEvaluation.TestOptions options, PerformanceEvaluation.Status status) (package private)
ScanTest
(Connection con, PerformanceEvaluation.TestOptions options, PerformanceEvaluation.Status status) (package private)
SequentialDeleteTest
(Connection con, PerformanceEvaluation.TestOptions options, PerformanceEvaluation.Status status) (package private)
SequentialReadTest
(Connection con, PerformanceEvaluation.TestOptions options, PerformanceEvaluation.Status status) (package private)
SequentialWriteTest
(Connection con, PerformanceEvaluation.TestOptions options, PerformanceEvaluation.Status status) (package private)
TableTest
(Connection con, PerformanceEvaluation.TestOptions options, PerformanceEvaluation.Status status) (package private)
Test
(Connection con, PerformanceEvaluation.TestOptions options, PerformanceEvaluation.Status status) -
Uses of Connection in org.apache.hadoop.hbase.backup
Modifier and TypeMethodDescriptionstatic TableBackupClient
BackupClientFactory.create
(Connection conn, String backupId, BackupRequest request) private String
RestoreDriver.getTablesForSet
(Connection conn, String name) -
Uses of Connection in org.apache.hadoop.hbase.backup.example
ModifierConstructorDescriptionHFileArchiveManager
(Connection connection, org.apache.hadoop.conf.Configuration conf) ZKTableArchiveClient
(org.apache.hadoop.conf.Configuration conf, Connection connection) -
Uses of Connection in org.apache.hadoop.hbase.backup.impl
Modifier and TypeFieldDescriptionprivate final Connection
BackupAdminImpl.conn
(package private) Connection
BackupCommands.Command.conn
protected final Connection
BackupManager.conn
private Connection
RestoreTablesClient.conn
protected Connection
TableBackupClient.conn
private final Connection
BackupSystemTable.connection
Connection to HBase cluster, shared among all instancesModifier and TypeMethodDescriptionstatic void
TableBackupClient.cleanupAndRestoreBackupSystem
(Connection conn, BackupInfo backupInfo, org.apache.hadoop.conf.Configuration conf) protected void
TableBackupClient.completeBackup
(Connection conn, BackupInfo backupInfo, BackupType type, org.apache.hadoop.conf.Configuration conf) Complete the overall backup.static void
BackupSystemTable.deleteSnapshot
(Connection conn) protected static void
TableBackupClient.deleteSnapshots
(Connection conn, BackupInfo backupInfo, org.apache.hadoop.conf.Configuration conf) Delete HBase snapshot for backup.protected void
TableBackupClient.failBackup
(Connection conn, BackupInfo backupInfo, BackupManager backupManager, Exception e, String msg, BackupType type, org.apache.hadoop.conf.Configuration conf) Fail the overall backup.void
TableBackupClient.init
(Connection conn, String backupId, BackupRequest request) private void
BackupCommands.RepairCommand.repairFailedBackupDeletionIfAny
(Connection conn, BackupSystemTable sysTable) static void
BackupCommands.RepairCommand.repairFailedBackupMergeIfAny
(Connection conn, BackupSystemTable sysTable) static void
BackupSystemTable.restoreFromSnapshot
(Connection conn) static void
BackupSystemTable.snapshot
(Connection conn) static boolean
BackupSystemTable.snapshotExists
(Connection conn) protected boolean
IncrementalTableBackupClient.tableExists
(TableName table, Connection conn) ModifierConstructorDescriptionBackupAdminImpl
(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
Modifier and TypeMethodDescriptionprotected void
MapReduceBackupMergeJob.deleteBackupImages
(List<String> backupIds, Connection conn, org.apache.hadoop.fs.FileSystem fs, String backupRoot) -
Uses of Connection in org.apache.hadoop.hbase.backup.master
-
Uses of Connection in org.apache.hadoop.hbase.backup.util
Modifier and TypeMethodDescriptionprivate void
RestoreTool.checkAndCreateTable
(Connection conn, TableName targetTableName, ArrayList<org.apache.hadoop.fs.Path> regionDirList, TableDescriptor htd, boolean truncateIfExists) Prepare the table for bulkload, most codes copied fromcreateTable
method inBulkLoadHFilesTool
.static void
BackupUtils.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 void
RestoreTool.createAndRestoreTable
(Connection conn, TableName tableName, TableName newTableName, org.apache.hadoop.fs.Path tableBackupPath, boolean truncateIfExists, String lastIncrBackupId) void
RestoreTool.fullRestoreTable
(Connection conn, org.apache.hadoop.fs.Path tableBackupPath, TableName tableName, TableName newTableName, boolean truncateIfExists, String lastIncrBackupId) void
RestoreTool.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) void
RestoreTool.modifyTableSync
(Connection conn, TableDescriptor desc) -
Uses of Connection in org.apache.hadoop.hbase.client
Modifier and TypeClassDescription(package private) class
The connection implementation based onAsyncConnection
.class
Wraps aConnection
to make it can't be closed or aborted.Modifier and TypeFieldDescriptionprivate final Connection
AdminOverAsyncAdmin.conn
private final Connection
SharedConnection.conn
Modifier and TypeMethodDescriptionstatic Connection
ConnectionFactory.createConnection()
Create a new Connection instance using default HBaseConfiguration.static Connection
ConnectionFactory.createConnection
(URI connectionUri) Create a new Connection instance using default HBaseConfiguration.static Connection
ConnectionFactory.createConnection
(URI connectionUri, org.apache.hadoop.conf.Configuration conf) Create a new Connection instance using the passedconf
instance.static Connection
ConnectionFactory.createConnection
(URI connectionUri, org.apache.hadoop.conf.Configuration conf, ExecutorService pool) Create a new Connection instance using the passedconf
instance.static Connection
ConnectionFactory.createConnection
(URI connectionUri, org.apache.hadoop.conf.Configuration conf, ExecutorService pool, User user) Create a new Connection instance using the passedconf
instance.static Connection
ConnectionFactory.createConnection
(URI connectionUri, org.apache.hadoop.conf.Configuration conf, ExecutorService pool, User user, Map<String, byte[]> connectionAttributes) Create a new Connection instance using the passedconf
instance.static Connection
ConnectionFactory.createConnection
(URI connectionUri, org.apache.hadoop.conf.Configuration conf, User user) Create a new Connection instance using the passedconf
instance.static Connection
ConnectionFactory.createConnection
(org.apache.hadoop.conf.Configuration conf) Create a new Connection instance using the passedconf
instance.static Connection
ConnectionFactory.createConnection
(org.apache.hadoop.conf.Configuration conf, ExecutorService pool) Create a new Connection instance using the passedconf
instance.static Connection
ConnectionFactory.createConnection
(org.apache.hadoop.conf.Configuration conf, ExecutorService pool, User user) Create a new Connection instance using the passedconf
instance.static Connection
ConnectionFactory.createConnection
(org.apache.hadoop.conf.Configuration conf, ExecutorService pool, User user, Map<String, byte[]> connectionAttributes) Create a new Connection instance using the passedconf
instance.static Connection
ConnectionFactory.createConnection
(org.apache.hadoop.conf.Configuration conf, User user) Create a new Connection instance using the passedconf
instance.Admin.getConnection()
Returns Connection used by this object.AdminOverAsyncAdmin.getConnection()
AsyncConnection.toConnection()
Convert this connection to aConnection
.AsyncConnectionImpl.toConnection()
SharedAsyncConnection.toConnection()
ModifierConstructorDescriptionAdminOverAsyncAdmin
(Connection conn, RawAsyncHBaseAdmin admin) SharedConnection
(Connection conn) -
Uses of Connection in org.apache.hadoop.hbase.client.example
Modifier and TypeFieldDescriptionprivate final Connection
MultiThreadedClientExample.ReadExampleCallable.connection
private final Connection
MultiThreadedClientExample.SingleWriteExampleCallable.connection
private final Connection
MultiThreadedClientExample.WriteExampleCallable.connection
private final Connection
RefreshHFilesClient.connection
Modifier and TypeMethodDescriptionprivate void
MultiThreadedClientExample.warmUpConnectionCache
(Connection connection, TableName tn) ModifierConstructorDescriptionReadExampleCallable
(Connection connection, TableName tableName) SingleWriteExampleCallable
(Connection connection, TableName tableName) WriteExampleCallable
(Connection connection, TableName tableName) -
Uses of Connection in org.apache.hadoop.hbase.coprocessor
Modifier 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
Modifier and TypeMethodDescriptionstatic void
FavoredNodeAssignmentHelper.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
-
Uses of Connection in org.apache.hadoop.hbase.mapred
Modifier and TypeFieldDescriptionprivate Connection
TableOutputFormat.TableRecordWriter.conn
private Connection
HRegionPartitioner.connection
private Connection
TableInputFormatBase.connection
Modifier and TypeMethodDescriptionprotected void
TableInputFormatBase.initializeTable
(Connection connection, TableName tableName) Allows subclasses to initialize the table information. -
Uses of Connection in org.apache.hadoop.hbase.mapreduce
Modifier and TypeFieldDescriptionprivate Connection
HRegionPartitioner.connection
(package private) Connection
MultiTableOutputFormat.MultiTableRecordWriter.connection
private Connection
TableInputFormatBase.connection
The underlyingConnection
of the table.private Connection
TableOutputFormat.TableRecordWriter.connection
(package private) Connection
SyncTable.SyncMapper.sourceConnection
(package private) Connection
SyncTable.SyncMapper.targetConnection
Modifier and TypeMethodDescriptionprivate static Connection
TableOutputFormat.createConnection
(org.apache.hadoop.conf.Configuration conf) private static Connection
SyncTable.SyncMapper.openConnection
(org.apache.hadoop.conf.Configuration conf, String uriConfKey, String zkClusterConfKey, String configPrefix) Modifier and TypeMethodDescriptionprotected void
TableInputFormatBase.initializeTable
(Connection connection, TableName tableName) Allows subclasses to initialize the table information.private static Table
SyncTable.SyncMapper.openTable
(Connection connection, org.apache.hadoop.conf.Configuration conf, String tableNameConfKey) Modifier and TypeMethodDescriptionprivate static void
TableMapReduceUtil.addTokenForJob
(IOExceptionSupplier<Connection> connSupplier, User user, org.apache.hadoop.mapreduce.Job job) -
Uses of Connection in org.apache.hadoop.hbase.mapreduce.replication
Modifier and TypeFieldDescriptionprivate Connection
VerifyReplication.Verifier.replicatedConnection
private Connection
VerifyReplication.Verifier.sourceConnection
-
Uses of Connection in org.apache.hadoop.hbase.master
Modifier and TypeFieldDescriptionprivate final Connection
SnapshotOfRegionAssignmentFromMeta.connection
Modifier and TypeMethodDescriptionMasterCoprocessorHost.MasterEnvironment.createConnection
(org.apache.hadoop.conf.Configuration conf) MasterCoprocessorHost.MasterEnvironment.getConnection()
Modifier and TypeMethodDescriptionstatic void
TableNamespaceManager.insertNamespaceToMeta
(Connection conn, NamespaceDescriptor ns) ModifierConstructorDescriptionSnapshotOfRegionAssignmentFromMeta
(Connection connection) SnapshotOfRegionAssignmentFromMeta
(Connection connection, Set<TableName> disabledTables, boolean excludeOfflinedSplitParents) -
Uses of Connection in org.apache.hadoop.hbase.master.balancer
Modifier and TypeMethodDescriptionClusterInfoProvider.getConnection()
Returns a reference to the cluster's connection.MasterClusterInfoProvider.getConnection()
-
Uses of Connection in org.apache.hadoop.hbase.master.cleaner
ModifierConstructorDescriptionReplicationBarrierCleaner
(org.apache.hadoop.conf.Configuration conf, Stoppable stopper, Connection conn, ReplicationPeerManager peerManager) -
Uses of Connection in org.apache.hadoop.hbase.master.procedure
Modifier and TypeFieldDescriptionprivate final Connection
HBCKServerCrashProcedure.UnknownServerVisitor.connection
ModifierConstructorDescriptionprivate
UnknownServerVisitor
(Connection connection, ServerName unknownServerName) -
Uses of Connection in org.apache.hadoop.hbase.namequeues
Modifier and TypeMethodDescriptionvoid
SlowLogPersistentService.addAllLogsToSysTable
(Connection connection) Poll from queueForSysTable and insert 100 records in hbase:slowlog table in single batchstatic void
WALEventTrackerTableAccessor.addWalEventTrackerRows
(Queue<WALEventTrackerPayload> walEventPayloads, Connection connection) Add wal event tracker rows to hbase:waleventtracker tableprivate static void
WALEventTrackerTableAccessor.doPut
(Connection connection, List<Put> puts) (package private) void
LogEventHandler.persistAll
(NamedQueuePayload.NamedQueueEvent namedQueueEvent, Connection connection) Add all in memory queue records to system table.void
NamedQueueRecorder.persistAll
(NamedQueuePayload.NamedQueueEvent namedQueueEvent, Connection connection) Add all in memory queue records to system table.void
NamedQueueService.persistAll
(Connection connection) Add all in memory queue records to system table.void
WALEventTrackerQueueService.persistAll
(Connection connection) ModifierConstructorDescriptionNamedQueueServiceChore
(Stoppable stopper, int period, NamedQueueRecorder namedQueueRecorder, Connection connection) Chore Constructor -
Uses of Connection in org.apache.hadoop.hbase.namequeues.impl
Modifier and TypeMethodDescriptionvoid
BalancerDecisionQueueService.persistAll
(Connection connection) void
BalancerRejectionQueueService.persistAll
(Connection connection) void
SlowLogQueueService.persistAll
(Connection connection) Add all slowLog events to system table. -
Uses of Connection in org.apache.hadoop.hbase.quotas
Modifier and TypeFieldDescription(package private) final Connection
FileArchiverNotifierFactoryImpl.CacheKey.conn
private final Connection
FileArchiverNotifierImpl.conn
private final Connection
NamespaceQuotaSnapshotStore.conn
private final Connection
QuotaObserverChore.conn
private final Connection
QuotaObserverChore.TablesWithQuotas.conn
private final Connection
SnapshotQuotaObserverChore.conn
private final Connection
SpaceQuotaRefresherChore.conn
private final Connection
TableQuotaSnapshotStore.conn
private Connection
TableSpaceQuotaSnapshotNotifier.conn
private Connection
QuotaRetriever.connection
Connection to use.Modifier and TypeMethodDescription(package private) Connection
RegionServerSpaceQuotaManager.getConnection()
(package private) Connection
SpaceQuotaRefresherChore.getConnection()
Modifier and TypeMethodDescriptionstatic void
QuotaUtil.addNamespaceQuota
(Connection connection, String namespace, org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Quotas data) private static void
QuotaUtil.addQuotas
(Connection connection, byte[] rowKey, byte[] qualifier, org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Quotas data) private static void
QuotaUtil.addQuotas
(Connection connection, byte[] rowKey, org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Quotas data) static void
QuotaUtil.addRegionServerQuota
(Connection connection, String regionServer, org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Quotas data) static void
QuotaUtil.addTableQuota
(Connection connection, TableName table, org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Quotas data) static void
QuotaUtil.addUserQuota
(Connection connection, String user, String namespace, org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Quotas data) static void
QuotaUtil.addUserQuota
(Connection connection, String user, org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Quotas data) static void
QuotaUtil.addUserQuota
(Connection connection, String user, TableName table, org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Quotas data) QuotaTableUtil.createDeletesForExistingNamespaceSnapshotSizes
(Connection connection) Returns a list ofDelete
to remove all namespace snapshot entries from quota table.QuotaTableUtil.createDeletesForExistingSnapshotsFromScan
(Connection connection, Scan scan) Returns a list ofDelete
to remove all entries returned by the passed scanner.QuotaTableUtil.createDeletesForExistingTableSnapshotSizes
(Connection connection) Returns a list ofDelete
to remove all table snapshot entries from quota table.static void
QuotaUtil.deleteNamespaceQuota
(Connection connection, String namespace) private static void
QuotaUtil.deleteQuotas
(Connection connection, byte[] rowKey) private static void
QuotaUtil.deleteQuotas
(Connection connection, byte[] rowKey, byte[] qualifier) static void
QuotaUtil.deleteRegionServerQuota
(Connection connection, String regionServer) static void
QuotaUtil.deleteTableQuota
(Connection connection, TableName table) (package private) static void
QuotaTableUtil.deleteTableUsageSnapshotsForNamespace
(Connection connection, String namespace) Remove table usage snapshots (u:p columns) for the namespace passedstatic void
QuotaUtil.deleteUserQuota
(Connection connection, String user) static void
QuotaUtil.deleteUserQuota
(Connection connection, String user, String namespace) static void
QuotaUtil.deleteUserQuota
(Connection connection, String user, TableName table) static void
QuotaUtil.disableTableIfNotDisabled
(Connection conn, TableName tableName) Method to disable a table, if not already disabled.private static void
QuotaUtil.doDelete
(Connection connection, Delete delete) protected static Result[]
QuotaTableUtil.doGet
(Connection connection, List<Get> gets) protected static Result
QuotaTableUtil.doGet
(Connection connection, Get get) private static void
QuotaUtil.doPut
(Connection connection, Put put) static void
QuotaUtil.enableTableIfNotEnabled
(Connection conn, TableName tableName) Method to enable a table, if not already enabled.static <K> Map<K,
QuotaState> QuotaUtil.fetchGlobalQuotas
(String type, Connection connection, List<Get> gets, QuotaUtil.KeyFromRow<K> kfr) static Map<String,
QuotaState> QuotaUtil.fetchNamespaceQuotas
(Connection connection, List<Get> gets, double factor) static Map<String,
QuotaState> QuotaUtil.fetchRegionServerQuotas
(Connection connection, List<Get> gets) static Map<TableName,
QuotaState> QuotaUtil.fetchTableQuotas
(Connection connection, List<Get> gets, Map<TableName, Double> tableMachineFactors) static Map<String,
UserQuotaState> QuotaUtil.fetchUserQuotas
(Connection connection, List<Get> gets, Map<TableName, Double> tableMachineQuotaFactors, double factor) FileArchiverNotifierFactory.get
(Connection conn, org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.fs.FileSystem fs, TableName tn) Creates or obtains aFileArchiverNotifier
instance for the given args.FileArchiverNotifierFactoryImpl.get
(Connection conn, org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.fs.FileSystem fs, TableName tn) Returns theFileArchiverNotifier
instance for the givenTableName
.static SpaceQuotaSnapshot
QuotaTableUtil.getCurrentSnapshotFromQuotaTable
(Connection conn, TableName tableName) Returns the current space quota snapshot of the giventableName
fromQuotaTableUtil.QUOTA_TABLE_NAME
or null if the no quota information is available for that tableName.static org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Quotas
QuotaTableUtil.getNamespaceQuota
(Connection connection, String namespace) QuotaTableUtil.getNamespaceSnapshots
(Connection conn) Returns a set of the names of all namespaces containing snapshot entries.(package private) static long
QuotaTableUtil.getNamespaceSnapshotSize
(Connection conn, String namespace) Fetches the computed size of all snapshots against tables in a namespace for space quotas.QuotaTableUtil.getObservedSnapshotSizes
(Connection conn) Fetches any persisted HBase snapshot sizes stored in the quota table.private static org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Quotas
QuotaTableUtil.getQuotas
(Connection connection, byte[] rowKey) private static org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Quotas
QuotaTableUtil.getQuotas
(Connection connection, byte[] rowKey, byte[] qualifier) static org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Quotas
QuotaTableUtil.getRegionServerQuota
(Connection connection, String regionServer) static Map<TableName,
SpaceQuotaSnapshot> QuotaTableUtil.getSnapshots
(Connection conn) Fetches allSpaceQuotaSnapshot
objects from thehbase:quota
table.static org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Quotas
QuotaTableUtil.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.Quotas
QuotaTableUtil.getUserQuota
(Connection connection, String user) static org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Quotas
QuotaTableUtil.getUserQuota
(Connection connection, String user, String namespace) static org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Quotas
QuotaTableUtil.getUserQuota
(Connection connection, String user, TableName table) private void
QuotaRetriever.init
(Connection conn, Scan scan) void
SpaceQuotaSnapshotNotifier.initialize
(Connection conn) Initializes the notifier.void
TableSpaceQuotaSnapshotNotifier.initialize
(Connection conn) protected static boolean
QuotaUtil.isExceedThrottleQuotaEnabled
(Connection connection) void
MasterQuotaManager.processFileArchivals
(org.apache.hadoop.hbase.shaded.protobuf.generated.RegionServerStatusProtos.FileArchiveNotificationRequest request, Connection conn, org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.fs.FileSystem fs) protected static void
QuotaUtil.switchExceedThrottleQuota
(Connection connection, boolean exceedThrottleQuotaEnabled) ModifierConstructorDescription(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) QuotaRetriever
(Connection conn) QuotaRetriever
(Connection conn, Scan scan) QuotaRetriever
(Connection conn, QuotaFilter filter) (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
Modifier and TypeMethodDescriptionRegionCoprocessorHost.RegionEnvironment.createConnection
(org.apache.hadoop.conf.Configuration conf) RegionServerCoprocessorHost.RegionServerEnvironment.createConnection
(org.apache.hadoop.conf.Configuration conf) RegionCoprocessorHost.RegionEnvironment.getConnection()
RegionServerCoprocessorHost.RegionServerEnvironment.getConnection()
-
Uses of Connection in org.apache.hadoop.hbase.replication
Modifier and TypeMethodDescriptionReplicationBarrierFamilyFormat.getReplicationBarrierResult
(Connection conn, TableName tableName, byte[] row, byte[] encodedRegionName) static long[]
ReplicationBarrierFamilyFormat.getReplicationBarriers
(Connection conn, byte[] regionName) static ReplicationQueueStorage
ReplicationStorageFactory.getReplicationQueueStorage
(Connection conn, org.apache.hadoop.conf.Configuration conf) Create a newReplicationQueueStorage
.static ReplicationQueueStorage
ReplicationStorageFactory.getReplicationQueueStorage
(Connection conn, org.apache.hadoop.conf.Configuration conf, TableName tableName) Create a newReplicationQueueStorage
.ReplicationBarrierFamilyFormat.getTableEncodedRegionNameAndLastBarrier
(Connection conn, TableName tableName) ReplicationBarrierFamilyFormat.getTableEncodedRegionNamesForSerialReplication
(Connection conn, TableName tableName) -
Uses of Connection in org.apache.hadoop.hbase.replication.master
-
Uses of Connection in org.apache.hadoop.hbase.replication.regionserver
Modifier and TypeMethodDescriptionReplicationSyncUp.DummyServer.createConnection
(org.apache.hadoop.conf.Configuration conf) ReplicationSyncUp.DummyServer.getConnection()
Modifier and TypeMethodDescriptionDumpReplicationQueues.dumpQueues
(Connection connection, Set<String> peerIds, boolean hdfs, org.apache.hadoop.conf.Configuration conf) DumpReplicationQueues.dumpReplicationViaTable
(Connection connection, org.apache.hadoop.conf.Configuration conf) -
Uses of Connection in org.apache.hadoop.hbase.rsgroup
-
Uses of Connection in org.apache.hadoop.hbase.security.access
Modifier and TypeMethodDescription(package private) static void
SnapshotScannerHDFSAclController.SnapshotScannerHDFSAclStorage.addUserTableHdfsAcl
(Connection connection, String user, TableName tableName) (package private) static void
SnapshotScannerHDFSAclController.SnapshotScannerHDFSAclStorage.addUserTableHdfsAcl
(Connection connection, Set<String> users, TableName tableName) (package private) static void
SnapshotScannerHDFSAclController.SnapshotScannerHDFSAclStorage.deleteNamespaceHdfsAcl
(Connection connection, String namespace) (package private) static void
SnapshotScannerHDFSAclController.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 void
AccessControlClient.grant
(Connection connection, String userName, boolean mergeExistingPermissions, Permission.Action... actions) Grant global permissions for the specified user.private static void
AccessControlClient.grant
(Connection connection, String namespace, String userName, boolean mergeExistingPermissions, Permission.Action... actions) Grants permission on the specified namespace for the specified user.static void
AccessControlClient.grant
(Connection connection, String namespace, String userName, Permission.Action... actions) Grants permission on the specified namespace for the specified user.static void
AccessControlClient.grant
(Connection connection, String userName, Permission.Action... actions) Grant global permissions for the specified user.private static void
AccessControlClient.grant
(Connection connection, TableName tableName, String userName, byte[] family, byte[] qual, boolean mergeExistingPermissions, Permission.Action... actions) Grants permission on the specified table for the specified userstatic void
AccessControlClient.grant
(Connection connection, TableName tableName, String userName, byte[] family, byte[] qual, Permission.Action... actions) Grants permission on the specified table for the specified user.static boolean
AccessControlClient.hasPermission
(Connection connection, String tableName, byte[] columnFamily, byte[] columnQualifier, String userName, Permission.Action... actions) Validates whether specified user has permission to perform actions on the mentioned table, column family or column qualifier.static boolean
AccessControlClient.hasPermission
(Connection connection, String tableName, String columnFamily, String columnQualifier, String userName, Permission.Action... actions) Validates whether specified user has permission to perform actions on the mentioned table, column family or column qualifier.static boolean
AccessControlClient.isAccessControllerRunning
(Connection connection) static boolean
AccessControlClient.isAuthorizationEnabled
(Connection connection) Return true if authorization is supported and enabledstatic boolean
AccessControlClient.isCellAuthorizationEnabled
(Connection connection) Return true if cell authorization is supported and enabledstatic void
AccessControlClient.revoke
(Connection connection, String namespace, String userName, Permission.Action... actions) Revokes the permission on the namespace for the specified user.static void
AccessControlClient.revoke
(Connection connection, String userName, Permission.Action... actions) Revoke global permissions for the specified user.static void
AccessControlClient.revoke
(Connection connection, TableName tableName, String username, byte[] family, byte[] qualifier, Permission.Action... actions) Revokes the permission on the tableModifierConstructorDescriptionSnapshotScannerHDFSAclHelper
(org.apache.hadoop.conf.Configuration configuration, Connection connection) -
Uses of Connection in org.apache.hadoop.hbase.security.provider.example
Modifier 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
Modifier and TypeMethodDescriptionstatic void
TokenUtil.addTokenForJob
(Connection conn, User user, org.apache.hadoop.mapreduce.Job job) Checks for an authentication token for the given user, obtaining a new token if necessary, and adds it to the credentials for the given map reduce job.static void
TokenUtil.addTokenForJob
(Connection conn, org.apache.hadoop.mapred.JobConf job, User user) Checks for an authentication token for the given user, obtaining a new token if necessary, and adds it to the credentials for the given map reduce job.static boolean
TokenUtil.addTokenIfMissing
(Connection conn, User user) Checks if an authentication tokens exists for the connected cluster, obtaining one if needed and adding it to the user's credentials.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 void
ClientTokenUtil.obtainAndCacheToken
(Connection conn, User user) Obtain an authentication token for the given user and add it to the user's credentials.static void
TokenUtil.obtainAndCacheToken
(Connection conn, User user) (package private) 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, will be removed in 4.0.0.static org.apache.hadoop.security.token.Token<AuthenticationTokenIdentifier>
TokenUtil.obtainToken
(Connection conn, User user) Deprecated.External users should not use this method, will be removed in 4.0.0.static void
TokenUtil.obtainTokenForJob
(Connection conn, User user, org.apache.hadoop.mapreduce.Job job) Obtain an authentication token on behalf of the given user and add it to the credentials for the given map reduce job.static void
TokenUtil.obtainTokenForJob
(Connection conn, org.apache.hadoop.mapred.JobConf job, User user) Obtain an authentication token on behalf of the given user and add it to the credentials for the given map reduce job. -
Uses of Connection in org.apache.hadoop.hbase.security.visibility
Modifier and TypeMethodDescriptionstatic org.apache.hadoop.hbase.shaded.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsResponse
VisibilityClient.addLabel
(Connection connection, String label) Utility method for adding label to the system.static org.apache.hadoop.hbase.shaded.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsResponse
VisibilityClient.addLabels
(Connection connection, String[] labels) Utility method for adding labels to the system.static org.apache.hadoop.hbase.shaded.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsResponse
VisibilityClient.clearAuths
(Connection connection, String[] auths, String user) Removes given labels from user's globally authorized list of labels.static org.apache.hadoop.hbase.shaded.protobuf.generated.VisibilityLabelsProtos.GetAuthsResponse
VisibilityClient.getAuths
(Connection connection, String user) Get the authorization for a given userstatic boolean
VisibilityClient.isCellVisibilityEnabled
(Connection connection) Return true if cell visibility features are supported and enabledstatic org.apache.hadoop.hbase.shaded.protobuf.generated.VisibilityLabelsProtos.ListLabelsResponse
VisibilityClient.listLabels
(Connection connection, String regex) Retrieve the list of visibility labels defined in the system.static org.apache.hadoop.hbase.shaded.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsResponse
VisibilityClient.setAuths
(Connection connection, String[] auths, String user) Sets given labels globally authorized for the user.private static org.apache.hadoop.hbase.shaded.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsResponse
VisibilityClient.setOrClearAuths
(Connection connection, String[] auths, String user, boolean setOrClear) -
Uses of Connection in org.apache.hadoop.hbase.slowlog
Modifier and TypeMethodDescriptionstatic void
SlowLogTableAccessor.addSlowLogRecords
(List<org.apache.hadoop.hbase.shaded.protobuf.generated.TooSlowLog.SlowLogPayload> slowLogPayloads, Connection connection) Add slow/large log records to hbase:slowlog tableprivate static void
SlowLogTableAccessor.doPut
(Connection connection, List<Put> puts) -
Uses of Connection in org.apache.hadoop.hbase.snapshot
Modifier and TypeMethodDescriptionvoid
RestoreSnapshotHelper.RestoreMetaChanges.updateMetaParentRegions
(Connection connection, List<RegionInfo> regionInfos) -
Uses of Connection in org.apache.hadoop.hbase.thrift2.client
-
Uses of Connection in org.apache.hadoop.hbase.tool
Modifier and TypeFieldDescriptionprotected Connection
CanaryTool.Monitor.connection
private Connection
CanaryTool.RegionServerTask.connection
private Connection
CanaryTool.RegionTask.connection
private final Connection
CanaryTool.ZookeeperTask.connection
Modifier and TypeMethodDescriptionprivate CanaryTool.Monitor
CanaryTool.newMonitor
(Connection connection, String[] monitorTargets) A Factory method forCanaryTool.Monitor
.ModifierConstructorDescriptionprotected
Monitor
(Connection connection, String[] monitorTargets, boolean useRegExp, CanaryTool.Sink sink, ExecutorService executor, boolean treatFailureAsError, long allowedFailures) RegionMonitor
(Connection connection, String[] monitorTargets, boolean useRegExp, CanaryTool.Sink sink, ExecutorService executor, boolean writeSniffing, TableName writeTableName, boolean treatFailureAsError, HashMap<String, Long> configuredReadTableTimeouts, long configuredWriteTableTimeout, long allowedFailures) RegionServerMonitor
(Connection connection, String[] monitorTargets, boolean useRegExp, CanaryTool.Sink sink, ExecutorService executor, boolean allRegions, boolean treatFailureAsError, long allowedFailures) (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) protected
ZookeeperMonitor
(Connection connection, String[] monitorTargets, boolean useRegExp, CanaryTool.Sink sink, ExecutorService executor, boolean treatFailureAsError, long allowedFailures) ZookeeperTask
(Connection connection, String host, String znode, int timeout, CanaryTool.ZookeeperStdOutSink sink) -
Uses of Connection in org.apache.hadoop.hbase.util
Modifier and TypeFieldDescriptionprivate final Connection
MoveWithAck.conn
private Connection
RegionMover.conn
(package private) final Connection
ConnectionCache.ConnectionInfo.connection
private Connection
HBaseFsck.connection
Deprecated.private final Connection
HBaseFsck.WorkItemRegion.connection
protected final Connection
MultiThreadedAction.connection
Modifier and TypeMethodDescriptionstatic void
HBaseFsckRepair.closeRegionSilentlyAndWait
(Connection connection, ServerName server, RegionInfo region) Contacts a region server and waits up to hbase.hbck.close.timeout ms (default 120s) to close the region.static void
HBaseFsckRepair.fixMultiAssignment
(Connection connection, RegionInfo region, List<ServerName> servers) Fix multiple assignment by doing silent closes on each RS hosting the region and then force ZK unassigned node to OFFLINE to trigger assignment by master.private static int
RegionSplitter.getRegionServerCount
(Connection connection) Alternative getCurrentNrHRS which is no longer available.(package private) static ServerName
MoveWithAck.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) ModifierConstructorDescription(package private)
ConnectionInfo
(Connection conn, String user) (package private)
MoveWithAck
(Connection conn, RegionInfo regionInfo, ServerName sourceServer, ServerName targetServer, List<RegionInfo> movedRegions) (package private)
WorkItemRegion
(HBaseFsck hbck, ServerName info, HbckErrorReporter errors, Connection connection) -
Uses of Connection in org.apache.hadoop.hbase.util.compaction
Modifier and TypeFieldDescriptionprotected final Connection
MajorCompactionRequest.connection
protected Connection
MajorCompactor.connection
Modifier 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) ModifierConstructorDescription(package private)
MajorCompactionRequest
(Connection connection, RegionInfo region) (package private)
MajorCompactionRequest
(Connection connection, RegionInfo region, Set<String> stores) (package private)
MajorCompactionTTLRequest
(Connection connection, RegionInfo region) -
Uses of Connection in org.apache.hadoop.hbase.util.hbck
ModifierConstructorDescriptionReplicationChecker
(org.apache.hadoop.conf.Configuration conf, ZKWatcher zkw, Connection conn, HbckErrorReporter errorReporter)
MetaTableAccessor.getRegionLocation(Connection, byte[])
instead