Uses of Class
org.apache.hadoop.hbase.TableName
Package
Description
Provides HBase Client
Table of Contents
Provides implementations of
HFile
and HFile
BlockCache
.Tools to help define network clients and servers.
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.
The Region Normalizer subsystem is responsible for coaxing all the regions in a table toward
a "normal" size, according to their storefile size.
Multi Cluster Replication
HBase REST
Provides an HBase Thrift
service.
Provides an HBase Thrift
service.
This package provides fully-functional exemplar Java code demonstrating
simple usage of the hbase-client API, for incorporation into a Maven
archetype with hbase-client dependency.
This package provides fully-functional exemplar Java code demonstrating
simple usage of the hbase-client API, for incorporation into a Maven
archetype with hbase-shaded-client dependency.
-
Uses of TableName in org.apache.hadoop.hbase
Modifier and TypeFieldDescriptionstatic final TableName
HConstants.ENSEMBLE_TABLE_NAME
The name of the ensemble tablestatic final TableName
TableName.META_TABLE_NAME
The hbase:meta table's name.static final TableName
TableName.NAMESPACE_TABLE_NAME
The Namespace table's name.static final TableName
TableName.OLD_META_TABLE_NAME
TableName for old .META.static final TableName
TableName.OLD_ROOT_TABLE_NAME
TableName for old -ROOT- table.private static final TableName
RSGroupTableAccessor.RSGROUP_TABLE_NAME
private TableName
HRegionInfo.tableName
Deprecated.private TableName
MetaTableAccessor.TableVisitorBase.tableName
Modifier and TypeFieldDescriptionTableName.tableCache
private final Map<TableName,
RegionStatesCount> ClusterMetricsBuilder.ClusterMetricsImpl.tableRegionStatesCount
private Map<TableName,
RegionStatesCount> ClusterMetricsBuilder.tableRegionStatesCount
Modifier and TypeMethodDescriptionprivate static TableName
TableName.createTableNameIfNecessary
(ByteBuffer bns, ByteBuffer qns) Check that the object does not exist already.private static TableName
TableName.getADummyTableName
(String qualifier) It is used to create table names for old META, and ROOT table.HRegionInfo.getTable()
Deprecated.Get current table name of the regionstatic TableName
HRegionInfo.getTable
(byte[] regionName) Deprecated.HTableDescriptor.getTableName()
Deprecated.Get the name of the tablestatic TableName
TableName.valueOf
(byte[] fullName) Construct a TableNamestatic TableName
TableName.valueOf
(byte[] namespace, byte[] qualifier) static TableName
TableName.valueOf
(byte[] fullName, int offset, int length) Construct a TableNamestatic TableName
Construct a TableNamestatic TableName
static TableName
TableName.valueOf
(ByteBuffer fullname) Construct a TableNamestatic TableName
TableName.valueOf
(ByteBuffer namespace, ByteBuffer qualifier) Modifier and TypeMethodDescriptionClusterMetrics.getTableRegionStatesCount()
Provide region states count for given table.ClusterMetricsBuilder.ClusterMetricsImpl.getTableRegionStatesCount()
ClusterStatus.getTableRegionStatesCount()
Deprecated.static Map<TableName,
TableState> MetaTableAccessor.getTableStates
(Connection conn) Fetch table states from META tableModifier and TypeMethodDescriptionint
static byte[]
HRegionInfo.createRegionName
(TableName tableName, byte[] startKey, byte[] id, boolean newFormat) Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0 UseRegionInfo.createRegionName(TableName, byte[], byte[], boolean)
.static byte[]
HRegionInfo.createRegionName
(TableName tableName, byte[] startKey, byte[] id, int replicaId, boolean newFormat) Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0 UseRegionInfo.createRegionName(TableName, byte[], byte[], int, boolean)
.static byte[]
HRegionInfo.createRegionName
(TableName tableName, byte[] startKey, long regionId, boolean newFormat) Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0 UseRegionInfo.createRegionName(TableName, byte[], long, boolean)
.static byte[]
HRegionInfo.createRegionName
(TableName tableName, byte[] startKey, long regionId, int replicaId, boolean newFormat) Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0 UseRegionInfo.createRegionName(TableName, byte[], long, int, boolean)
.static byte[]
HRegionInfo.createRegionName
(TableName tableName, byte[] startKey, String id, boolean newFormat) Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0 UseRegionInfo.createRegionName(TableName, byte[], String, boolean)
.static void
MetaTableAccessor.deleteTableState
(Connection connection, TableName table) Remove state for table from metadefault boolean
Test whether a given table exists, i.e, has a table descriptor.Returns TableDescriptor for tablenameSharedConnection.getBufferedMutator
(TableName tableName) static CellComparator
CellComparatorImpl.getCellComparator
(TableName tableName) Utility method that makes a guess at comparator to use based off passed tableName.private static RegionInfo
MetaTableAccessor.getClosestRegionInfo
(Connection connection, TableName tableName, byte[] row) Returns Get closest metatable region row to passedrow
static CellComparator
InnerStoreCellComparator.getInnerStoreCellComparator
(TableName tableName) Utility method that makes a guess at comparator to use based off passed tableName.default long
ClusterMetrics.getLastMajorCompactionTimestamp
(TableName table) long
ClusterStatus.getLastMajorCompactionTsForTable
(TableName table) Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0 UseClusterMetrics.getLastMajorCompactionTimestamp(TableName)
instead.SharedConnection.getRegionLocator
(TableName tableName) MetaTableAccessor.getReplicationBarrierResult
(Connection conn, TableName tableName, byte[] row, byte[] encodedRegionName) static Scan
MetaTableAccessor.getScanForTableName
(org.apache.hadoop.conf.Configuration conf, TableName tableName) This method creates a Scan object that will only scan catalog rows that belong to the specified table.SharedConnection.getTableBuilder
(TableName tableName, ExecutorService pool) MetaTableAccessor.getTableEncodedRegionNameAndLastBarrier
(Connection conn, TableName tableName) MetaTableAccessor.getTableEncodedRegionNamesForSerialReplication
(Connection conn, TableName tableName) static CompletableFuture<List<HRegionLocation>>
AsyncMetaTableAccessor.getTableHRegionLocations
(AsyncTable<AdvancedScanResultConsumer> metaTable, TableName tableName) Used to get all region locations for the specific tablestatic 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.private static CompletableFuture<List<Pair<RegionInfo,
ServerName>>> AsyncMetaTableAccessor.getTableRegionsAndLocations
(AsyncTable<AdvancedScanResultConsumer> metaTable, TableName tableName, boolean excludeOfflinedSplitParents) Used to get table regions' info and server.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.private static byte[]
AsyncMetaTableAccessor.getTableStartRowForMeta
(TableName tableName, MetaTableAccessor.QueryType type) static byte[]
MetaTableAccessor.getTableStartRowForMeta
(TableName tableName, MetaTableAccessor.QueryType type) Returns start row for scanning META according to query typestatic CompletableFuture<Optional<TableState>>
AsyncMetaTableAccessor.getTableState
(AsyncTable<?> metaTable, TableName tableName) static TableState
MetaTableAccessor.getTableState
(Connection conn, TableName tableName) Fetch table state for given table from META tableprivate static byte[]
AsyncMetaTableAccessor.getTableStopRowForMeta
(TableName tableName, MetaTableAccessor.QueryType type) static byte[]
MetaTableAccessor.getTableStopRowForMeta
(TableName tableName, MetaTableAccessor.QueryType type) Returns stop row for scanning META according to query typestatic boolean
TableName.isMetaTableName
(TableName tn) Returns True iftn
is the hbase:meta table name.Returns Instance of table descriptor or null if none found.private static CompletableFuture<Void>
AsyncMetaTableAccessor.scanMeta
(AsyncTable<AdvancedScanResultConsumer> metaTable, TableName tableName, MetaTableAccessor.QueryType type, MetaTableAccessor.Visitor visitor) Performs a scan of META table for given table.static void
MetaTableAccessor.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 void
MetaTableAccessor.scanMeta
(Connection connection, TableName table, MetaTableAccessor.QueryType type, int maxRows, MetaTableAccessor.Visitor visitor, CatalogReplicaMode metaReplicaMode) static void
MetaTableAccessor.scanMetaForTableRegions
(Connection connection, MetaTableAccessor.Visitor visitor, TableName tableName) static void
MetaTableAccessor.scanMetaForTableRegions
(Connection connection, MetaTableAccessor.Visitor visitor, TableName tableName, CatalogReplicaMode metaReplicaMode) static CompletableFuture<Boolean>
AsyncMetaTableAccessor.tableExists
(AsyncTable<?> metaTable, TableName tableName) static void
MetaTableAccessor.updateTableState
(Connection conn, TableName tableName, TableState.State actual) Updates state in META Do not use.Modifier and TypeMethodDescriptionClusterMetricsBuilder.setTableRegionStatesCount
(Map<TableName, RegionStatesCount> tableRegionStatesCount) ModifierConstructorDescriptionConcurrentTableModificationException
(TableName tableName) private
HRegionInfo
(long regionId, TableName tableName) Deprecated.Private constructor used constructing HRegionInfo for the first meta regionsHRegionInfo
(long regionId, TableName tableName, int replicaId) Deprecated.HRegionInfo
(TableName tableName) Deprecated.HRegionInfo
(TableName tableName, byte[] startKey, byte[] endKey) Deprecated.Construct HRegionInfo with explicit parametersHRegionInfo
(TableName tableName, byte[] startKey, byte[] endKey, boolean split) Deprecated.Construct HRegionInfo with explicit parametersHRegionInfo
(TableName tableName, byte[] startKey, byte[] endKey, boolean split, long regionId) Deprecated.Construct HRegionInfo with explicit parametersHRegionInfo
(TableName tableName, byte[] startKey, byte[] endKey, boolean split, long regionId, int replicaId) Deprecated.Construct HRegionInfo with explicit parametersHTableDescriptor
(TableName name) Deprecated.Construct a table descriptor specifying a TableName objectHTableDescriptor
(TableName name, HTableDescriptor desc) Deprecated.Construct a table descriptor by cloning the descriptor passed as a parameter but using a different table name.TableExistsException
(TableName tableName) TableNotDisabledException
(TableName tableName) TableNotEnabledException
(TableName tableName) TableNotFoundException
(TableName tableName) TableVisitorBase
(TableName tableName) -
Uses of TableName in org.apache.hadoop.hbase.backup
Modifier and TypeFieldDescriptionprivate TableName[]
RestoreRequest.fromTables
private TableName
BackupTableInfo.table
private TableName[]
RestoreRequest.toTables
Modifier and TypeFieldDescriptionprivate Map<TableName,
BackupTableInfo> BackupInfo.backupTableInfoMap
Backup status map for all tablesBackupHFileCleaner.fullyBackedUpTables
BackupInfo.incrTimestampMap
Previous Region server log timestamps for table set after distributed log roll key - table name, value - map of RegionServer hostname -> last log rolled timestampBackupRequest.tableList
BackupInfo.tableSetTimestampMap
New region server log timestamps for table set after distributed log roll key - table name, value - map of RegionServer hostname -> last log rolled timestampModifier and TypeMethodDescriptionRestoreRequest.getFromTables()
BackupTableInfo.getTable()
BackupInfo.getTableBySnapshot
(String snapshotName) RestoreRequest.getToTables()
Modifier and TypeMethodDescriptionBackupInfo.getIncrTimestampMap()
Get new region server log timestamps after distributed log rollBackupRequest.getTableList()
BackupInfo.getTableNames()
BackupInfo.getTables()
BackupInfo.getTableSetTimestampMap()
BackupInfo.getTableSetTimestampMap
(Map<String, org.apache.hadoop.hbase.shaded.protobuf.generated.BackupProtos.BackupInfo.RSTimestampMap> map) private static Map<TableName,
BackupTableInfo> BackupInfo.toMap
(List<org.apache.hadoop.hbase.shaded.protobuf.generated.BackupProtos.BackupTableInfo> list) Modifier and TypeMethodDescriptionvoid
void
BackupAdmin.addToBackupSet
(String name, TableName[] tables) Add tables to backup set commandstatic void
HBackupFileSystem.checkImageManifestExist
(HashMap<TableName, BackupManifest> backupManifestMap, TableName[] tableArray, org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.fs.Path backupRootPath, String backupId) Check whether the backup image path and there is manifest file in the path.BackupInfo.getBackupTableInfo
(TableName table) BackupInfo.getSnapshotName
(TableName table) static String
HBackupFileSystem.getTableBackupDataDir
(String backupRootDir, String backupId, TableName tableName) BackupInfo.getTableBackupDir
(TableName tableName) static String
HBackupFileSystem.getTableBackupDir
(String backupRootDir, String backupId, TableName tableName) Given the backup root dir, backup id and the table name, return the backup image location, which is also where the backup manifest file is.static org.apache.hadoop.fs.Path
HBackupFileSystem.getTableBackupPath
(TableName tableName, org.apache.hadoop.fs.Path backupRootPath, String backupId) Given the backup root dir, backup id and the table name, return the backup image location, which is also where the backup manifest file is.void
BackupAdmin.removeFromBackupSet
(String name, TableName[] tables) Remove tables from backup setvoid
RestoreJob.run
(org.apache.hadoop.fs.Path[] dirPaths, TableName[] fromTables, org.apache.hadoop.fs.Path restoreRootDir, TableName[] toTables, boolean fullBackupRestore) Run restore operationprivate RestoreRequest
RestoreRequest.setFromTables
(TableName[] fromTables) void
BackupInfo.setSnapshotName
(TableName table, String snapshotName) private RestoreRequest
RestoreRequest.setToTables
(TableName[] toTables) RestoreRequest.Builder.withFromTables
(TableName[] fromTables) RestoreRequest.Builder.withToTables
(TableName[] toTables) Modifier and TypeMethodDescriptionstatic void
HBackupFileSystem.checkImageManifestExist
(HashMap<TableName, BackupManifest> backupManifestMap, TableName[] tableArray, org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.fs.Path backupRootPath, String backupId) Check whether the backup image path and there is manifest file in the path.BackupHFileCleaner.loadHFileRefs
(List<TableName> tableList) void
BackupInfo.setBackupTableInfoMap
(Map<TableName, BackupTableInfo> backupTableInfoMap) void
Set the new region server log timestamps after distributed log rollprivate BackupRequest
BackupRequest.setTableList
(List<TableName> tableList) void
void
BackupRequest.Builder.withTableList
(List<TableName> tables) ModifierConstructorDescriptionBackupInfo
(String backupId, BackupType type, TableName[] tables, String targetRootDir) BackupTableInfo
(TableName table, String targetRootDir, String backupId) -
Uses of TableName in org.apache.hadoop.hbase.backup.impl
Modifier and TypeFieldDescriptionprivate TableName
BackupSystemTable.bulkLoadTableName
Backup System table name for bulk loaded files.private TableName[]
RestoreTablesClient.sTableArray
private TableName
BackupSystemTable.tableName
Backup system table (main) nameprivate TableName[]
RestoreTablesClient.tTableArray
Modifier and TypeFieldDescriptionBackupManifest.BackupImage.incrTimeRanges
BackupManifest.BackupImage.tableList
TableBackupClient.tableList
Modifier and TypeMethodDescriptionprivate TableName
BackupCommands.HistoryCommand.getTableName()
static TableName
BackupSystemTable.getTableName
(org.apache.hadoop.conf.Configuration conf) static TableName
BackupSystemTable.getTableNameForBulkLoadedData
(org.apache.hadoop.conf.Configuration conf) private TableName[]
BackupCommands.BackupSetCommand.toTableNames
(String[] tables) Modifier and TypeMethodDescriptionBackupSystemTable.describeBackupSet
(String name) Get backup set description (list of tables)BackupAdminImpl.excludeNonExistingTables
(List<TableName> tableList, List<TableName> nonExistingTableList) BackupSystemTable.getBackupHistoryForTableSet
(Set<TableName> set, String backupRoot) BackupManager.getIncrementalBackupTableSet()
Return the current tables covered by incremental backup.BackupSystemTable.getIncrementalBackupTableSet
(String backupRoot) Return the current tables covered by incremental backup.BackupManifest.BackupImage.getIncrTimeRanges()
BackupManifest.getIncrTimestampMap()
BackupManifest.getTableList()
Get the table set of this image.BackupManifest.BackupImage.getTableNames()
BackupSystemTable.getTablesForBackupType
(BackupType type) BackupManifest.BackupImage.loadIncrementalTimestampMap
(org.apache.hadoop.hbase.shaded.protobuf.generated.BackupProtos.BackupImage proto) BackupManager.readBulkloadRows
(List<TableName> tableList) BackupSystemTable.readBulkloadRows
(List<TableName> tableList) BackupManager.readLogTimestampMap()
Read the timestamp for each region server log after the last successful backup.BackupSystemTable.readLogTimestampMap
(String backupRoot) Read the timestamp for each region server log after the last successful backup.Modifier and TypeMethodDescriptionvoid
BackupAdminImpl.addToBackupSet
(String name, TableName[] tables) private void
RestoreTablesClient.checkTargetTables
(TableName[] tTableArray, boolean isOverwrite) Validate target tables.private void
BackupAdminImpl.cleanupBackupDir
(BackupInfo backupInfo, TableName table, org.apache.hadoop.conf.Configuration conf) Clean up the data at target directory(package private) static Put
BackupSystemTable.createPutForBulkLoadedFile
(TableName tn, byte[] fam, String p, String backupId, long ts, int idx) BackupSystemTable.createPutForCommittedBulkload
(TableName table, byte[] region, Map<byte[], List<org.apache.hadoop.fs.Path>> finalPaths) BackupSystemTable.createPutForPreparedBulkload
(TableName table, byte[] region, byte[] family, List<Pair<org.apache.hadoop.fs.Path, org.apache.hadoop.fs.Path>> pairs) private Put
BackupSystemTable.createPutForWriteRegionServerLogTimestamp
(TableName table, byte[] smap, String backupRoot) Creates Put to write RS last roll log timestamp map(package private) static Scan
BackupSystemTable.createScanForOrigBulkLoadedFiles
(TableName table) private List<BackupInfo>
BackupAdminImpl.getAffectedBackupSessions
(BackupInfo backupInfo, TableName tn, BackupSystemTable table) BackupManifest.getAllDependentListByTable
(TableName table) Get the full dependent image list in the whole dependency scope for a specific table of this backup in time order from old to new.BackupManager.getAncestors
(BackupInfo backupInfo, TableName table) Get the direct ancestors of this backup for one table involved.BackupSystemTable.getBackupHistoryForTable
(TableName name) Get history for a tableprotected org.apache.hadoop.fs.Path
IncrementalTableBackupClient.getBulkOutputDirForTable
(TableName table) BackupManifest.getDependentListByTable
(TableName table) Get the dependent image list for a specific table of this backup in time order from old to new if want to restore to this backup image level.protected static int
boolean
private boolean
BackupAdminImpl.isLastBackupSession
(BackupSystemTable table, TableName tn, long startTime) void
BackupAdminImpl.removeFromBackupSet
(String name, TableName[] tables) private void
BackupAdminImpl.removeTableFromBackupImage
(BackupInfo info, TableName tn, BackupSystemTable sysTable) private void
RestoreTablesClient.restore
(HashMap<TableName, BackupManifest> backupManifestMap, TableName[] sTableArray, TableName[] tTableArray, boolean isOverwrite) Restore operation.private void
RestoreTablesClient.restoreImages
(BackupManifest.BackupImage[] images, TableName sTable, TableName tTable, boolean truncateIfExists) Restore operation handle each backupImage in array.protected void
FullTableBackupClient.snapshotTable
(Admin admin, TableName tableName, String snapshotName) protected boolean
IncrementalTableBackupClient.tableExists
(TableName table, Connection conn) private String[]
BackupAdminImpl.toStringArray
(TableName[] list) private org.apache.hadoop.hbase.shaded.protobuf.generated.BackupProtos.TableServerTimestamp
BackupSystemTable.toTableServerTimestampProto
(TableName table, Map<String, Long> map) private void
BackupSystemTable.waitForSystemTable
(Admin admin, TableName tableName) void
BackupSystemTable.writeFilesForBulkLoadPreCommit
(TableName tabName, byte[] region, byte[] family, List<Pair<org.apache.hadoop.fs.Path, org.apache.hadoop.fs.Path>> pairs) void
BackupSystemTable.writePathsPostBulkLoad
(TableName tabName, byte[] region, Map<byte[], List<org.apache.hadoop.fs.Path>> finalPaths) Modifier and TypeMethodDescriptionvoid
BackupManager.addIncrementalBackupTableSet
(Set<TableName> tables) Adds set of tables to overall incremental backup table setvoid
BackupSystemTable.addIncrementalBackupTableSet
(Set<TableName> tables, String backupRoot) Add tables to global incremental backup setBackupManager.createBackupInfo
(String backupId, BackupType type, List<TableName> tableList, String targetRootDir, int workers, long bandwidth) Creates a backup info based on input backup request.BackupSystemTable.createDeleteForOrigBulkLoad
(List<TableName> lst) private Put
BackupSystemTable.createPutForIncrBackupTableSet
(Set<TableName> tables, String backupRoot) Creates Put to store incremental backup table setprivate Put
BackupSystemTable.createPutForUpdateTablesForMerge
(List<TableName> tables) BackupAdminImpl.excludeNonExistingTables
(List<TableName> tableList, List<TableName> nonExistingTableList) private void
BackupAdminImpl.finalizeDelete
(Map<String, HashSet<TableName>> tablesMap, BackupSystemTable table) Updates incremental backup set for every backupRootBackupSystemTable.getBackupHistoryForTableSet
(Set<TableName> set, String backupRoot) protected static int
IncrementalTableBackupClient.handleBulkLoad
(List<TableName> sTableList) BackupSystemTable.readBulkLoadedFiles
(String backupId, List<TableName> sTableList) BackupManager.readBulkloadRows
(List<TableName> tableList) BackupSystemTable.readBulkloadRows
(List<TableName> tableList) private void
RestoreTablesClient.restore
(HashMap<TableName, BackupManifest> backupManifestMap, TableName[] sTableArray, TableName[] tTableArray, boolean isOverwrite) Restore operation.private void
void
Set the incremental timestamp map directly.private void
BackupManifest.BackupImage.setTableList
(List<TableName> tableList) void
BackupSystemTable.updateProcessedTablesForMerge
(List<TableName> tables) (package private) BackupManifest.BackupImage.Builder
BackupManifest.BackupImage.Builder.withTableList
(List<TableName> tableList) void
BackupSystemTable.writeBulkLoadedFiles
(List<TableName> sTableList, Map<byte[], List<org.apache.hadoop.fs.Path>>[] maps, String backupId) void
Write the current timestamps for each regionserver to backup system table after a successful full or incremental backup.void
BackupSystemTable.writeRegionServerLogTimestamp
(Set<TableName> tables, Map<String, Long> newTimestamps, String backupRoot) Write the current timestamps for each regionserver to backup system table after a successful full or incremental backup.ModifierConstructorDescriptionBackupManifest
(BackupInfo backup, TableName table) Construct a table level manifest for a backup of the named table.ModifierConstructorDescriptionprivate
BackupImage
(String backupId, BackupType type, String rootDir, List<TableName> tableList, long startTs, long completeTs) -
Uses of TableName in org.apache.hadoop.hbase.backup.mapreduce
Modifier and TypeMethodDescriptionMapReduceBackupCopyJob.SnapshotCopy.getTable()
protected TableName[]
MapReduceBackupMergeJob.getTableNamesInBackupImages
(String[] backupIds) Modifier and TypeMethodDescriptionMapReduceBackupMergeJob.toTableNameList
(List<Pair<TableName, org.apache.hadoop.fs.Path>> processedTableList) Modifier and TypeMethodDescriptionprotected org.apache.hadoop.fs.Path[]
MapReduceBackupMergeJob.findInputDirectories
(org.apache.hadoop.fs.FileSystem fs, String backupRoot, TableName tableName, String[] backupIds) protected void
MapReduceBackupMergeJob.moveData
(org.apache.hadoop.fs.FileSystem fs, String backupRoot, org.apache.hadoop.fs.Path bulkOutputPath, TableName tableName, String mergedBackupId) void
MapReduceRestoreJob.run
(org.apache.hadoop.fs.Path[] dirPaths, TableName[] tableNames, org.apache.hadoop.fs.Path restoreRootDir, TableName[] newTableNames, boolean fullBackupRestore) Modifier and TypeMethodDescriptionprotected List<org.apache.hadoop.fs.Path>
MapReduceBackupMergeJob.toPathList
(List<Pair<TableName, org.apache.hadoop.fs.Path>> processedTableList) MapReduceBackupMergeJob.toTableNameList
(List<Pair<TableName, org.apache.hadoop.fs.Path>> processedTableList) -
Uses of TableName 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
.private void
RestoreTool.createAndRestoreTable
(Connection conn, TableName tableName, TableName newTableName, org.apache.hadoop.fs.Path tableBackupPath, boolean truncateIfExists, String lastIncrBackupId) static RestoreRequest
BackupUtils.createRestoreRequest
(String backupRootDir, String backupId, boolean check, TableName[] fromTables, TableName[] toTables, boolean isOverwrite) Create restore request.void
RestoreTool.fullRestoreTable
(Connection conn, org.apache.hadoop.fs.Path tableBackupPath, TableName tableName, TableName newTableName, boolean truncateIfExists, String lastIncrBackupId) static String
BackupUtils.getFileNameCompatibleString
(TableName table) (package private) ArrayList<org.apache.hadoop.fs.Path>
RestoreTool.getRegionList
(TableName tableName) Gets region list(package private) org.apache.hadoop.fs.Path
RestoreTool.getTableArchivePath
(TableName tableName) return value represent path for: ".../user/biadmin/backup1/default/t1_dn/backup_1396650096738/archive/data/default/t1_dn"static String
BackupUtils.getTableBackupDir
(String backupRootDir, String backupId, TableName tableName) Given the backup root dir, backup id and the table name, return the backup image location, which is also where the backup manifest file is.(package private) TableDescriptor
RestoreTool.getTableDesc
(TableName tableName) Get table descriptorprivate TableDescriptor
RestoreTool.getTableDescriptor
(org.apache.hadoop.fs.FileSystem fileSys, TableName tableName, String lastIncrBackupId) (package private) org.apache.hadoop.fs.Path
RestoreTool.getTableInfoPath
(TableName tableName) Returns value represent path for: ""/$USER/SBACKUP_ROOT/backup_id/namespace/table/.hbase-snapshot/ snapshot_1396650097621_namespace_table" this path contains .snapshotinfo, .tabledesc (0.96 and 0.98) this path contains .snapshotinfo, .data.manifest (trunk)(package private) org.apache.hadoop.fs.Path
RestoreTool.getTableSnapshotPath
(org.apache.hadoop.fs.Path backupRootPath, TableName tableName, String backupId) Returns value represent path for path to backup table snapshot directory: "/$USER/SBACKUP_ROOT/backup_id/namespace/table/.hbase-snapshot"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.Modifier and TypeMethodDescriptionLoop through the RS log timestamp map for the tables, for each RS, find the min timestamp value for the RS among the tables.static boolean
BackupUtils.validate
(HashMap<TableName, BackupManifest> backupManifestMap, org.apache.hadoop.conf.Configuration conf) -
Uses of TableName in org.apache.hadoop.hbase.client
Modifier and TypeFieldDescriptionprivate final TableName
TableDescriptorBuilder.ModifyableTableDescriptor.name
private final TableName
RegionCoprocessorRpcChannel.table
private final TableName
SnapshotDescription.table
private final TableName
AsyncBatchRpcRetryingCaller.tableName
private final TableName
AsyncClientScanner.tableName
private TableName
AsyncProcessTask.Builder.tableName
private final TableName
AsyncProcessTask.tableName
private final TableName
AsyncRegionLocationCache.tableName
private final TableName
AsyncRequestFutureImpl.tableName
private TableName
AsyncRpcRetryingCallerFactory.BatchCallerBuilder.tableName
private TableName
AsyncRpcRetryingCallerFactory.SingleRequestCallerBuilder.tableName
private final TableName
AsyncSingleRequestRpcRetryingCaller.tableName
protected TableName
AsyncTableBuilderBase.tableName
private final TableName
AsyncTableRegionLocatorImpl.tableName
private final TableName
AsyncTableResultScanner.tableName
private final TableName
BufferedMutatorImpl.tableName
private final TableName
BufferedMutatorParams.tableName
private final TableName
CatalogReplicaLoadBalanceSimpleSelector.tableName
protected final TableName
ClientScanner.tableName
private final TableName
HBaseAdmin.TableFuture.tableName
private final TableName
HRegionLocator.tableName
private final TableName
HTable.tableName
private final TableName
MutableRegionInfo.tableName
protected final TableName
RawAsyncHBaseAdmin.TableProcedureBiConsumer.tableName
private final TableName
RawAsyncTableImpl.tableName
protected final TableName
RegionAdminServiceCallable.tableName
private final TableName
RegionCoprocessorRpcChannelImpl.tableName
private final TableName
RegionInfoBuilder.tableName
private final TableName
RegionServerCallable.tableName
protected final TableName
RpcRetryingCallerWithReadReplicas.tableName
private final TableName
ScannerCallableWithReplicas.tableName
protected TableName
TableBuilderBase.tableName
private final TableName
TableState.tableName
Modifier and TypeFieldDescriptionprivate final ConcurrentMap<TableName,
AsyncNonMetaRegionLocator.TableCache> AsyncNonMetaRegionLocator.cache
private final ConcurrentMap<TableName,
ConcurrentNavigableMap<byte[], RegionLocations>> MetaCache.cachedRegionLocations
Map of table to tableHRegionLocation
s.private final ConcurrentMap<TableName,
ConcurrentNavigableMap<byte[], CatalogReplicaLoadBalanceSimpleSelector.StaleLocationCacheEntry>> CatalogReplicaLoadBalanceSimpleSelector.staleCache
NormalizeTableFilterParams.Builder.tableNames
NormalizeTableFilterParams.tableNames
Modifier and TypeMethodDescriptionprivate TableName
HBaseAdmin.checkTableExists
(TableName tableName) Check if table exists or notprivate static TableName
MutableRegionInfo.checkTableName
(TableName tableName) AsyncBufferedMutator.getName()
Gets the fully qualified table name instance of the table that thisAsyncBufferedMutator
writes to.AsyncBufferedMutatorImpl.getName()
AsyncTable.getName()
Gets the fully qualified table name instance of this table.AsyncTableImpl.getName()
AsyncTableRegionLocator.getName()
Gets the fully qualified table name instance of the table whose region we want to locate.AsyncTableRegionLocatorImpl.getName()
BufferedMutator.getName()
Gets the fully qualified table name instance of the table that this BufferedMutator writes to.BufferedMutatorImpl.getName()
HRegionLocator.getName()
HTable.getName()
RawAsyncTableImpl.getName()
RegionLocator.getName()
Gets the fully qualified table name instance of this table.Table.getName()
Gets the fully qualified table name instance of this table.protected TableName
ClientScanner.getTable()
MutableRegionInfo.getTable()
Get current table name of the regionRegionInfo.getTable()
Returns current table name of the regionstatic TableName
RegionInfo.getTable
(byte[] regionName) Gets the table name from the specified region name.AsyncProcessTask.getTableName()
BufferedMutatorParams.getTableName()
protected TableName
HBaseAdmin.TableFuture.getTableName()
Returns the table nameRegionServerCallable.getTableName()
SnapshotDescription.getTableName()
TableDescriptor.getTableName()
Get the name of the tableTableDescriptorBuilder.ModifyableTableDescriptor.getTableName()
Get the name of the tableTableState.getTableName()
Table name for stateprivate TableName
HBaseAdmin.getTableNameBeforeRestoreSnapshot
(String snapshotName) Check whether the snapshot exists and contains disabled tableAdmin.listTableNames()
List all of the names of userspace tables.Admin.listTableNames
(String regex) Deprecated.since 2.0 version and will be removed in 3.0 version.Admin.listTableNames
(String regex, boolean includeSysTables) Deprecated.since 2.0 version and will be removed in 3.0 version.default TableName[]
Admin.listTableNames
(Pattern pattern) List all of the names of userspace tables.Admin.listTableNames
(Pattern pattern, boolean includeSysTables) List all of the names of userspace tables.HBaseAdmin.listTableNames()
HBaseAdmin.listTableNames
(String regex) HBaseAdmin.listTableNames
(String regex, boolean includeSysTables) HBaseAdmin.listTableNames
(Pattern pattern, boolean includeSysTables) Admin.listTableNamesByNamespace
(String name) Get list of table names by namespace.HBaseAdmin.listTableNamesByNamespace
(String name) Modifier and TypeMethodDescriptionprivate CompletableFuture<TableName>
RawAsyncHBaseAdmin.checkRegionsAndGetTableName
(byte[][] encodedRegionNames) Map<TableName,
? extends SpaceQuotaSnapshotView> Admin.getRegionServerSpaceQuotaSnapshots
(ServerName serverName) Fetches the observedSpaceQuotaSnapshotView
s observed by a RegionServer.CompletableFuture<? extends Map<TableName,
? extends SpaceQuotaSnapshotView>> AsyncAdmin.getRegionServerSpaceQuotaSnapshots
(ServerName serverName) Fetches the observedSpaceQuotaSnapshotView
s observed by a RegionServer.AsyncHBaseAdmin.getRegionServerSpaceQuotaSnapshots
(ServerName serverName) HBaseAdmin.getRegionServerSpaceQuotaSnapshots
(ServerName serverName) RawAsyncHBaseAdmin.getRegionServerSpaceQuotaSnapshots
(ServerName serverName) Admin.getSpaceQuotaTableSizes()
Fetches the table sizes on the filesystem as tracked by the HBase Master.AsyncAdmin.getSpaceQuotaTableSizes()
Fetches the table sizes on the filesystem as tracked by the HBase Master.AsyncHBaseAdmin.getSpaceQuotaTableSizes()
HBaseAdmin.getSpaceQuotaTableSizes()
RawAsyncHBaseAdmin.getSpaceQuotaTableSizes()
AsyncRpcRetryingCaller.getTableName()
AsyncSingleRequestRpcRetryingCaller.getTableName()
NormalizeTableFilterParams.getTableNames()
private CompletableFuture<List<TableName>>
RawAsyncHBaseAdmin.getTableNames
(org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.GetTableNamesRequest request) default CompletableFuture<List<TableName>>
AsyncAdmin.listTableNames()
List all of the names of userspace tables.AsyncAdmin.listTableNames
(boolean includeSysTables) List all of the names of tables.AsyncAdmin.listTableNames
(Pattern pattern, boolean includeSysTables) List all of the names of userspace tables.AsyncHBaseAdmin.listTableNames
(boolean includeSysTables) AsyncHBaseAdmin.listTableNames
(Pattern pattern, boolean includeSysTables) RawAsyncHBaseAdmin.listTableNames
(boolean includeSysTables) RawAsyncHBaseAdmin.listTableNames
(Pattern pattern, boolean includeSysTables) AsyncAdmin.listTableNamesByNamespace
(String name) Get list of table names by namespace.AsyncHBaseAdmin.listTableNamesByNamespace
(String name) RawAsyncHBaseAdmin.listTableNamesByNamespace
(String name) Admin.listTableNamesByState
(boolean isEnabled) List all enabled or disabled table namesAsyncAdmin.listTableNamesByState
(boolean isEnabled) List all enabled or disabled table namesAsyncHBaseAdmin.listTableNamesByState
(boolean isEnabled) HBaseAdmin.listTableNamesByState
(boolean isEnabled) RawAsyncHBaseAdmin.listTableNamesByState
(boolean isEnabled) Modifier and TypeMethodDescriptiondefault void
Admin.addColumn
(TableName tableName, ColumnFamilyDescriptor columnFamily) Deprecated.As of release 2.0.0.default void
Admin.addColumnFamily
(TableName tableName, ColumnFamilyDescriptor columnFamily) Add a column family to an existing table.AsyncAdmin.addColumnFamily
(TableName tableName, ColumnFamilyDescriptor columnFamily) Add a column family to an existing table.AsyncHBaseAdmin.addColumnFamily
(TableName tableName, ColumnFamilyDescriptor columnFamily) RawAsyncHBaseAdmin.addColumnFamily
(TableName tableName, ColumnFamilyDescriptor columnFamily) Admin.addColumnFamilyAsync
(TableName tableName, ColumnFamilyDescriptor columnFamily) Add a column family to an existing table.HBaseAdmin.addColumnFamilyAsync
(TableName tableName, ColumnFamilyDescriptor columnFamily) void
ClusterConnection.cacheLocation
(TableName tableName, RegionLocations location) void
ConnectionImplementation.cacheLocation
(TableName tableName, RegionLocations location) Put a newly discovered HRegionLocation into the cache.private void
ConnectionImplementation.cacheLocation
(TableName tableName, ServerName source, HRegionLocation location) Put a newly discovered HRegionLocation into the cache.void
MetaCache.cacheLocation
(TableName tableName, RegionLocations locations) Put a newly discovered HRegionLocation into the cache.void
MetaCache.cacheLocation
(TableName tableName, ServerName source, HRegionLocation location) Put a newly discovered HRegionLocation into the cache.(package private) static int
ConnectionUtils.calcPriority
(int priority, TableName tableName) Select the priority for the rpc call.private void
HBaseAdmin.checkAndSyncTableDescToPeers
(TableName tableName, byte[][] splits) Connect to peer and check the table descriptor on peer: Create the same table on peer when not exist. Throw an exception if the table already has replication enabled on any of the column families. Throw an exception if the table exists on peer cluster but descriptors are not same.private CompletableFuture<Void>
RawAsyncHBaseAdmin.checkAndSyncTableToPeerClusters
(TableName tableName, byte[][] splits) Connect to peer and check the table descriptor on peer: Create the same table on peer when not exist. Throw an exception if the table already has replication enabled on any of the column families. Throw an exception if the table exists on peer cluster but descriptors are not same.private TableName
HBaseAdmin.checkTableExists
(TableName tableName) Check if table exists or notprivate static TableName
MutableRegionInfo.checkTableName
(TableName tableName) Admin.clearBlockCache
(TableName tableName) Clear all the blocks corresponding to this table from BlockCache.AsyncAdmin.clearBlockCache
(TableName tableName) Clear all the blocks corresponding to this table from BlockCache.AsyncHBaseAdmin.clearBlockCache
(TableName tableName) HBaseAdmin.clearBlockCache
(TableName tableName) Clear all the blocks corresponding to this table from BlockCache.RawAsyncHBaseAdmin.clearBlockCache
(TableName tableName) (package private) void
AsyncNonMetaRegionLocator.clearCache
(TableName tableName) (package private) void
AsyncRegionLocator.clearCache
(TableName tableName) void
MetaCache.clearCache
(TableName tableName) Delete all cached entries of a table.
Synchronized because of calls in cacheLocation which need to be executed atomicallyvoid
MetaCache.clearCache
(TableName tableName, byte[] row) Delete a cached location, no matter what it is.void
MetaCache.clearCache
(TableName tableName, byte[] row, int replicaId) Delete a cached location with specific replicaId.
Synchronized because of calls in cacheLocation which need to be executed atomicallyvoid
MetaCache.clearCache
(TableName tableName, byte[] row, ServerName serverName) Delete a cached location for a table, row and server.void
ClusterConnection.clearRegionCache
(TableName tableName) Allows flushing the region cache of all locations that pertain totableName
void
ConnectionImplementation.clearRegionCache
(TableName tableName) void
ConnectionImplementation.clearRegionCache
(TableName tableName, byte[] row) default void
Admin.cloneSnapshot
(byte[] snapshotName, TableName tableName) Deprecated.since 2.3.0, will be removed in 3.0.0.default void
Admin.cloneSnapshot
(String snapshotName, TableName tableName) Create a new table by cloning the snapshot content.default void
Admin.cloneSnapshot
(String snapshotName, TableName tableName, boolean restoreAcl) Create a new table by cloning the snapshot content.default void
Admin.cloneSnapshot
(String snapshotName, TableName tableName, boolean restoreAcl, String customSFT) Create a new table by cloning the snapshot content.default CompletableFuture<Void>
AsyncAdmin.cloneSnapshot
(String snapshotName, TableName tableName) Create a new table by cloning the snapshot content.default CompletableFuture<Void>
AsyncAdmin.cloneSnapshot
(String snapshotName, TableName tableName, boolean restoreAcl) Create a new table by cloning the snapshot content.AsyncAdmin.cloneSnapshot
(String snapshotName, TableName tableName, boolean restoreAcl, String customSFT) Create a new table by cloning the snapshot content.AsyncHBaseAdmin.cloneSnapshot
(String snapshotName, TableName tableName, boolean restoreAcl, String customSFT) RawAsyncHBaseAdmin.cloneSnapshot
(String snapshotName, TableName tableName, boolean restoreAcl, String customSFT) Admin.cloneSnapshotAsync
(String snapshotName, TableName tableName) Create a new table by cloning the snapshot content, but does not block and wait for it to be completely cloned.Admin.cloneSnapshotAsync
(String snapshotName, TableName tableName, boolean restoreAcl) Create a new table by cloning the snapshot content.Admin.cloneSnapshotAsync
(String snapshotName, TableName tableName, boolean restoreAcl, String customSFT) Create a new table by cloning the snapshot content.HBaseAdmin.cloneSnapshotAsync
(String snapshotName, TableName tableName, boolean restoreAcl, String customSFT) void
Admin.cloneTableSchema
(TableName tableName, TableName newTableName, boolean preserveSplits) Create a new table by cloning the existent table schema.AsyncAdmin.cloneTableSchema
(TableName tableName, TableName newTableName, boolean preserveSplits) Create a new table by cloning the existent table schema.AsyncHBaseAdmin.cloneTableSchema
(TableName tableName, TableName newTableName, boolean preserveSplits) void
HBaseAdmin.cloneTableSchema
(TableName tableName, TableName newTableName, boolean preserveSplits) RawAsyncHBaseAdmin.cloneTableSchema
(TableName tableName, TableName newTableName, boolean preserveSplits) void
Compact a table.void
Compact a column family within a table.void
Admin.compact
(TableName tableName, byte[] columnFamily, CompactType compactType) Compact a column family within a table.void
Admin.compact
(TableName tableName, CompactType compactType) Compact a table.default CompletableFuture<Void>
Compact a table.default CompletableFuture<Void>
Compact a column family within a table.AsyncAdmin.compact
(TableName tableName, byte[] columnFamily, CompactType compactType) Compact a column family within a table.AsyncAdmin.compact
(TableName tableName, CompactType compactType) Compact a table.AsyncHBaseAdmin.compact
(TableName tableName, byte[] columnFamily, CompactType compactType) AsyncHBaseAdmin.compact
(TableName tableName, CompactType compactType) void
Compact a table.void
Compact a column family within a table.private void
HBaseAdmin.compact
(TableName tableName, byte[] columnFamily, boolean major, CompactType compactType) Compact a table.void
HBaseAdmin.compact
(TableName tableName, byte[] columnFamily, CompactType compactType) Compact a column family within a table.void
HBaseAdmin.compact
(TableName tableName, CompactType compactType) Compact a table.private CompletableFuture<Void>
RawAsyncHBaseAdmin.compact
(TableName tableName, byte[] columnFamily, boolean major, CompactType compactType) Compact column family of a table, Asynchronous operation even if CompletableFuture.get()RawAsyncHBaseAdmin.compact
(TableName tableName, byte[] columnFamily, CompactType compactType) RawAsyncHBaseAdmin.compact
(TableName tableName, CompactType compactType) private CompletableFuture<Void>
RawAsyncHBaseAdmin.compareTableWithPeerCluster
(TableName tableName, TableDescriptor tableDesc, ReplicationPeerDescription peer, AsyncAdmin peerAdmin) private void
AsyncNonMetaRegionLocator.complete
(TableName tableName, AsyncNonMetaRegionLocator.LocateRequest req, RegionLocations locs, Throwable error) private static CompletableFuture<Boolean>
RawAsyncHBaseAdmin.completeCheckTableState
(CompletableFuture<Boolean> future, TableState tableState, Throwable error, TableState.State targetState, TableName tableName) Utility for completing passed TableStateCompletableFuture
future
using passed parameters.static TableState
TableState.convert
(TableName tableName, org.apache.hadoop.hbase.shaded.protobuf.generated.HBaseProtos.TableState tableState) Covert from PB version of TableStatestatic TableDescriptor
TableDescriptorBuilder.copy
(TableName name, TableDescriptor desc) private MultiServerCallable
AsyncRequestFutureImpl.createCallable
(ServerName server, TableName tableName, MultiAction multi) Create a callable.static RegionInfo
RegionInfo.createMobRegionInfo
(TableName tableName) Creates a RegionInfo object for MOB data.static byte[]
RegionInfo.createRegionName
(TableName tableName, byte[] startKey, byte[] id, boolean newFormat) Make a region name of passed parameters.static byte[]
RegionInfo.createRegionName
(TableName tableName, byte[] startKey, byte[] id, int replicaId, boolean newFormat) Make a region name of passed parameters.static byte[]
RegionInfo.createRegionName
(TableName tableName, byte[] startKey, long regionid, boolean newFormat) Make a region name of passed parameters.static byte[]
RegionInfo.createRegionName
(TableName tableName, byte[] startKey, long regionid, int replicaId, boolean newFormat) Make a region name of passed parameters.static byte[]
RegionInfo.createRegionName
(TableName tableName, byte[] startKey, String id, boolean newFormat) Make a region name of passed parameters.CatalogReplicaLoadBalanceSelectorFactory.createSelector
(String replicaSelectorClass, TableName tableName, ChoreService choreService, IntSupplier getReplicaCount) Create a CatalogReplicaLoadBalanceReplicaSelector based on input config.private CompletableFuture<Void>
RawAsyncHBaseAdmin.createTable
(TableName tableName, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.CreateTableRequest request) void
Admin.deleteColumn
(TableName tableName, byte[] columnFamily) Deprecated.As of release 2.0.0.void
HBaseAdmin.deleteColumn
(TableName tableName, byte[] columnFamily) Deprecated.Since 2.0.default void
Admin.deleteColumnFamily
(TableName tableName, byte[] columnFamily) Delete a column family from a table.AsyncAdmin.deleteColumnFamily
(TableName tableName, byte[] columnFamily) Delete a column family from a table.AsyncHBaseAdmin.deleteColumnFamily
(TableName tableName, byte[] columnFamily) RawAsyncHBaseAdmin.deleteColumnFamily
(TableName tableName, byte[] columnFamily) Admin.deleteColumnFamilyAsync
(TableName tableName, byte[] columnFamily) Delete a column family from a table.HBaseAdmin.deleteColumnFamilyAsync
(TableName tableName, byte[] columnFamily) default void
Admin.deleteTable
(TableName tableName) Deletes a table.AsyncAdmin.deleteTable
(TableName tableName) Deletes a table.AsyncHBaseAdmin.deleteTable
(TableName tableName) RawAsyncHBaseAdmin.deleteTable
(TableName tableName) Admin.deleteTableAsync
(TableName tableName) Deletes the table but does not block and wait for it to be completely removed.HBaseAdmin.deleteTableAsync
(TableName tableName) default void
Admin.disableTable
(TableName tableName) Disable table and wait on completion.AsyncAdmin.disableTable
(TableName tableName) Disable a table.AsyncHBaseAdmin.disableTable
(TableName tableName) RawAsyncHBaseAdmin.disableTable
(TableName tableName) Admin.disableTableAsync
(TableName tableName) Disable the table but does not block and wait for it to be completely disabled.HBaseAdmin.disableTableAsync
(TableName tableName) void
Admin.disableTableReplication
(TableName tableName) Disable a table's replication switch.AsyncAdmin.disableTableReplication
(TableName tableName) Disable a table's replication switch.AsyncHBaseAdmin.disableTableReplication
(TableName tableName) void
HBaseAdmin.disableTableReplication
(TableName tableName) RawAsyncHBaseAdmin.disableTableReplication
(TableName tableName) static <R> void
HTable.doBatchWithCallback
(List<? extends Row> actions, Object[] results, Batch.Callback<R> callback, ClusterConnection connection, ExecutorService pool, TableName tableName, Map<String, byte[]> requestAttributes) default void
Admin.enableTable
(TableName tableName) Enable a table.AsyncAdmin.enableTable
(TableName tableName) Enable a table.AsyncHBaseAdmin.enableTable
(TableName tableName) RawAsyncHBaseAdmin.enableTable
(TableName tableName) Admin.enableTableAsync
(TableName tableName) Enable the table but does not block and wait for it to be completely enabled.HBaseAdmin.enableTableAsync
(TableName tableName) void
Admin.enableTableReplication
(TableName tableName) Enable a table's replication switch.AsyncAdmin.enableTableReplication
(TableName tableName) Enable a table's replication switch.AsyncHBaseAdmin.enableTableReplication
(TableName tableName) void
HBaseAdmin.enableTableReplication
(TableName tableName) RawAsyncHBaseAdmin.enableTableReplication
(TableName tableName) void
Flush a table.void
Flush the specified column family stores on all regions of the passed table.default void
Flush the specified column family stores on all regions of the passed table.Flush a table.Flush the specified column family stores on all regions of the passed table.Flush the specified column family stores on all regions of the passed table.void
void
Admin.flushAsync
(TableName tableName, List<byte[]> columnFamilies) Flush a table but does not block and wait for it to finish.HBaseAdmin.flushAsync
(TableName tableName, List<byte[]> columnFamilies) private static int
MutableRegionInfo.generateHashCode
(TableName tableName, byte[] startKey, byte[] endKey, long regionId, int replicaId, boolean offLine, byte[] regionName) Admin.getAlterStatus
(TableName tableName) Deprecated.Since 2.0.0.HBaseAdmin.getAlterStatus
(TableName tableName) default AsyncBufferedMutator
AsyncConnection.getBufferedMutator
(TableName tableName) Retrieve anAsyncBufferedMutator
for performing client-side buffering of writes.default AsyncBufferedMutator
AsyncConnection.getBufferedMutator
(TableName tableName, ExecutorService pool) Retrieve anAsyncBufferedMutator
for performing client-side buffering of writes.Connection.getBufferedMutator
(TableName tableName) Retrieve aBufferedMutator
for performing client-side buffering of writes.ConnectionImplementation.getBufferedMutator
(TableName tableName) AsyncConnection.getBufferedMutatorBuilder
(TableName tableName) Returns anAsyncBufferedMutatorBuilder
for creatingAsyncBufferedMutator
.AsyncConnection.getBufferedMutatorBuilder
(TableName tableName, ExecutorService pool) Returns anAsyncBufferedMutatorBuilder
for creatingAsyncBufferedMutator
.AsyncConnectionImpl.getBufferedMutatorBuilder
(TableName tableName) AsyncConnectionImpl.getBufferedMutatorBuilder
(TableName tableName, ExecutorService pool) (package private) RegionLocations
ConnectionImplementation.getCachedLocation
(TableName tableName, byte[] row) Search the cache for a location that fits our table and row key.MetaCache.getCachedLocation
(TableName tableName, byte[] row) Search the cache for a location that fits our table and row key.Admin.getCompactionState
(TableName tableName) Get the current compaction state of a table.Admin.getCompactionState
(TableName tableName, CompactType compactType) Get the current compaction state of a table.default CompletableFuture<CompactionState>
AsyncAdmin.getCompactionState
(TableName tableName) Get the current compaction state of a table.AsyncAdmin.getCompactionState
(TableName tableName, CompactType compactType) Get the current compaction state of a table.AsyncHBaseAdmin.getCompactionState
(TableName tableName, CompactType compactType) HBaseAdmin.getCompactionState
(TableName tableName) HBaseAdmin.getCompactionState
(TableName tableName, CompactType compactType) Get the current compaction state of a table.RawAsyncHBaseAdmin.getCompactionState
(TableName tableName, CompactType compactType) Admin.getCurrentSpaceQuotaSnapshot
(TableName tableName) Returns the Master's view of a quota on the giventableName
or null if the Master has no quota information on that table.CompletableFuture<? extends SpaceQuotaSnapshotView>
AsyncAdmin.getCurrentSpaceQuotaSnapshot
(TableName tableName) Returns the Master's view of a quota on the giventableName
or null if the Master has no quota information on that table.AsyncHBaseAdmin.getCurrentSpaceQuotaSnapshot
(TableName tableName) HBaseAdmin.getCurrentSpaceQuotaSnapshot
(TableName tableName) RawAsyncHBaseAdmin.getCurrentSpaceQuotaSnapshot
(TableName tableName) Admin.getDescriptor
(TableName tableName) Get a table descriptor.AsyncAdmin.getDescriptor
(TableName tableName) Method for getting the tableDescriptorAsyncHBaseAdmin.getDescriptor
(TableName tableName) HBaseAdmin.getDescriptor
(TableName tableName) RawAsyncHBaseAdmin.getDescriptor
(TableName tableName) (package private) static HTableDescriptor
HBaseAdmin.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.long
Admin.getLastMajorCompactionTimestamp
(TableName tableName) Get the timestamp of the last major compaction for the passed table The timestamp of the oldest HFile resulting from a major compaction of that table, or 0 if no such HFile could be found.AsyncAdmin.getLastMajorCompactionTimestamp
(TableName tableName) Get the timestamp of the last major compaction for the passed table.AsyncHBaseAdmin.getLastMajorCompactionTimestamp
(TableName tableName) long
HBaseAdmin.getLastMajorCompactionTimestamp
(TableName tableName) RawAsyncHBaseAdmin.getLastMajorCompactionTimestamp
(TableName tableName) (package private) int
ConnectionImplementation.getNumberOfCachedRegionLocations
(TableName tableName) int
MetaCache.getNumberOfCachedRegionLocations
(TableName tableName) Return the number of cached region for a table.(package private) static int
ConnectionUtils.getPriority
(TableName tableName) (package private) CompletableFuture<HRegionLocation>
AsyncRegionLocator.getRegionLocation
(TableName tableName, byte[] row, int replicaId, RegionLocateType type, boolean reload, long timeoutNs) (package private) CompletableFuture<HRegionLocation>
AsyncRegionLocator.getRegionLocation
(TableName tableName, byte[] row, int replicaId, RegionLocateType type, long timeoutNs) (package private) CompletableFuture<HRegionLocation>
AsyncRegionLocator.getRegionLocation
(TableName tableName, byte[] row, RegionLocateType type, boolean reload, long timeoutNs) (package private) CompletableFuture<HRegionLocation>
AsyncRegionLocator.getRegionLocation
(TableName tableName, byte[] row, RegionLocateType type, long timeoutNs) ClusterConnection.getRegionLocation
(TableName tableName, byte[] row, boolean reload) Find region location hosting passed rowConnectionImplementation.getRegionLocation
(TableName tableName, byte[] row, boolean reload) (package private) RegionLocations
AsyncNonMetaRegionLocator.getRegionLocationInCache
(TableName tableName, byte[] row) (package private) CompletableFuture<RegionLocations>
AsyncNonMetaRegionLocator.getRegionLocations
(TableName tableName, byte[] row, int replicaId, RegionLocateType locateType, boolean reload) (package private) CompletableFuture<RegionLocations>
AsyncRegionLocator.getRegionLocations
(TableName tableName, byte[] row, RegionLocateType type, boolean reload, long timeoutNs) static RegionLocations
RegionAdminServiceCallable.getRegionLocations
(ClusterConnection connection, TableName tableName, byte[] row, boolean useCache, int replicaId) (package private) static RegionLocations
RpcRetryingCallerWithReadReplicas.getRegionLocations
(boolean useCache, int replicaId, ClusterConnection cConnection, TableName tableName, byte[] row) private CompletableFuture<RegionLocations>
AsyncNonMetaRegionLocator.getRegionLocationsInternal
(TableName tableName, byte[] row, int replicaId, RegionLocateType locateType, boolean reload) AsyncConnection.getRegionLocator
(TableName tableName) Retrieve a AsyncRegionLocator implementation to inspect region information on a table.AsyncConnectionImpl.getRegionLocator
(TableName tableName) Connection.getRegionLocator
(TableName tableName) Retrieve a RegionLocator implementation to inspect region information on a table.ConnectionImplementation.getRegionLocator
(TableName tableName) Admin.getRegionMetrics
(ServerName serverName, TableName tableName) GetRegionMetrics
of all regions hosted on a regionserver for a table.AsyncAdmin.getRegionMetrics
(ServerName serverName, TableName tableName) Get a list ofRegionMetrics
of all regions hosted on a region server for a table.AsyncHBaseAdmin.getRegionMetrics
(ServerName serverName, TableName tableName) HBaseAdmin.getRegionMetrics
(ServerName serverName, TableName tableName) RawAsyncHBaseAdmin.getRegionMetrics
(ServerName serverName, TableName tableName) Admin.getRegions
(TableName tableName) Get the regions of a given table.AsyncAdmin.getRegions
(TableName tableName) Get the regions of a given table.AsyncHBaseAdmin.getRegions
(TableName tableName) HBaseAdmin.getRegions
(TableName tableName) RawAsyncHBaseAdmin.getRegions
(TableName tableName) default AsyncTable<AdvancedScanResultConsumer>
Retrieve anAsyncTable
implementation for accessing a table.default AsyncTable<ScanResultConsumer>
AsyncConnection.getTable
(TableName tableName, ExecutorService pool) Retrieve anAsyncTable
implementation for accessing a table.default Table
Retrieve a Table implementation for accessing a table.default Table
Connection.getTable
(TableName tableName, ExecutorService pool) Retrieve a Table implementation for accessing a table.AsyncConnection.getTableBuilder
(TableName tableName) Returns anAsyncTableBuilder
for creatingAsyncTable
.AsyncConnection.getTableBuilder
(TableName tableName, ExecutorService pool) Returns anAsyncTableBuilder
for creatingAsyncTable
.AsyncConnectionImpl.getTableBuilder
(TableName tableName) AsyncConnectionImpl.getTableBuilder
(TableName tableName, ExecutorService pool) Connection.getTableBuilder
(TableName tableName, ExecutorService pool) Returns anTableBuilder
for creatingTable
.ConnectionImplementation.getTableBuilder
(TableName tableName, ExecutorService pool) AsyncNonMetaRegionLocator.getTableCache
(TableName tableName) Admin.getTableDescriptor
(TableName tableName) Deprecated.since 2.0 version and will be removed in 3.0 version.HBaseAdmin.getTableDescriptor
(TableName tableName) (package private) static TableDescriptor
HBaseAdmin.getTableDescriptor
(TableName tableName, Connection connection, RpcRetryingCallerFactory rpcCallerFactory, RpcControllerFactory rpcControllerFactory, int operationTimeout, int rpcTimeout) private CompletableFuture<List<HRegionLocation>>
RawAsyncHBaseAdmin.getTableHRegionLocations
(TableName tableName) List all region locations for the specific table.private ConcurrentNavigableMap<byte[],
RegionLocations> MetaCache.getTableLocations
(TableName tableName) Returns Map of cached locations for passedtableName
.
Despite being Concurrent, writes to the map should be synchronized because we have cases where we need to make multiple updates atomically.Admin.getTableRegions
(TableName tableName) Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0 (HBASE-17980).HBaseAdmin.getTableRegions
(TableName tableName) Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0 UseHBaseAdmin.getRegions(TableName)
.private byte[][]
HBaseAdmin.getTableSplits
(TableName tableName) private CompletableFuture<byte[][]>
RawAsyncHBaseAdmin.getTableSplits
(TableName tableName) ClusterConnection.getTableState
(TableName tableName) Retrieve TableState, represent current table state.ConnectionImplementation.getTableState
(TableName tableName) private MasterCallable<org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.TruncateRegionResponse>
HBaseAdmin.getTruncateRegionCallable
(TableName tableName, RegionInfo hri) private CompletableFuture<Void>
RawAsyncHBaseAdmin.internalRestoreSnapshot
(String snapshotName, TableName tableName, boolean restoreAcl, String customSFT) HBaseAdmin.internalRestoreSnapshotAsync
(String snapshotName, TableName tableName, boolean restoreAcl, String customSFT) Execute Restore/Clone snapshot and wait for the server to complete (blocking).private boolean
boolean
MetaCache.isRegionCached
(TableName tableName, byte[] row) Check the region cache to see whether a region is cached yet or not.boolean
Admin.isTableAvailable
(TableName tableName) Check if a table is available.boolean
Admin.isTableAvailable
(TableName tableName, byte[][] splitKeys) Deprecated.Since 2.0.0.AsyncAdmin.isTableAvailable
(TableName tableName) Check if a table is available.AsyncAdmin.isTableAvailable
(TableName tableName, byte[][] splitKeys) Deprecated.Since 2.2.0.AsyncHBaseAdmin.isTableAvailable
(TableName tableName) AsyncHBaseAdmin.isTableAvailable
(TableName tableName, byte[][] splitKeys) boolean
ClusterConnection.isTableAvailable
(TableName tableName, byte[][] splitKeys) Use this api to check if the table has been created with the specified number of splitkeys which was used while creating the given table.boolean
ConnectionImplementation.isTableAvailable
(TableName tableName, byte[][] splitKeys) boolean
HBaseAdmin.isTableAvailable
(TableName tableName) boolean
HBaseAdmin.isTableAvailable
(TableName tableName, byte[][] splitKeys) RawAsyncHBaseAdmin.isTableAvailable
(TableName tableName) RawAsyncHBaseAdmin.isTableAvailable
(TableName tableName, byte[][] splitKeys) private CompletableFuture<Boolean>
RawAsyncHBaseAdmin.isTableAvailable
(TableName tableName, Optional<byte[][]> splitKeys) boolean
Admin.isTableDisabled
(TableName tableName) Check if a table is disabled.AsyncAdmin.isTableDisabled
(TableName tableName) Check if a table is disabled.AsyncHBaseAdmin.isTableDisabled
(TableName tableName) boolean
ClusterConnection.isTableDisabled
(TableName tableName) Check if a table is disabled.boolean
ConnectionImplementation.isTableDisabled
(TableName tableName) boolean
ConnectionUtils.MasterlessConnection.isTableDisabled
(TableName tableName) boolean
HBaseAdmin.isTableDisabled
(TableName tableName) RawAsyncHBaseAdmin.isTableDisabled
(TableName tableName) boolean
Admin.isTableEnabled
(TableName tableName) Check if a table is enabled.AsyncAdmin.isTableEnabled
(TableName tableName) Check if a table is enabled.AsyncHBaseAdmin.isTableEnabled
(TableName tableName) boolean
ClusterConnection.isTableEnabled
(TableName tableName) A table that isTableEnabled == false and isTableDisabled == false is possible.boolean
ConnectionImplementation.isTableEnabled
(TableName tableName) boolean
HBaseAdmin.isTableEnabled
(TableName tableName) RawAsyncHBaseAdmin.isTableEnabled
(TableName tableName) private void
RawAsyncHBaseAdmin.legacyFlush
(CompletableFuture<Void> future, TableName tableName, List<byte[]> columnFamilies) private void
AsyncNonMetaRegionLocator.locateInMeta
(TableName tableName, AsyncNonMetaRegionLocator.LocateRequest req) private RegionLocations
ConnectionImplementation.locateMeta
(TableName tableName, boolean useCache, int replicaId) ClusterConnection.locateRegion
(TableName tableName, byte[] row) Find the location of the region of tableName that row lives in.ClusterConnection.locateRegion
(TableName tableName, byte[] row, boolean useCache, boolean retry) Gets the locations of the region in the specified table, tableName, for a given row.ClusterConnection.locateRegion
(TableName tableName, byte[] row, boolean useCache, boolean retry, int replicaId) Gets the locations of the region in the specified table, tableName, for a given row.ConnectionImplementation.locateRegion
(TableName tableName, byte[] row) ConnectionImplementation.locateRegion
(TableName tableName, byte[] row, boolean useCache, boolean retry) ConnectionImplementation.locateRegion
(TableName tableName, byte[] row, boolean useCache, boolean retry, int replicaId) private RegionLocations
ConnectionImplementation.locateRegionInMeta
(TableName tableName, byte[] row, boolean useCache, boolean retry, int replicaId) Search the hbase:meta table for the HRegionLocation info that contains the table and row we're seeking.ClusterConnection.locateRegions
(TableName tableName) Gets the locations of all regions in the specified table, tableName.ClusterConnection.locateRegions
(TableName tableName, boolean useCache, boolean offlined) Gets the locations of all regions in the specified table, tableName.ConnectionImplementation.locateRegions
(TableName tableName) ConnectionImplementation.locateRegions
(TableName tableName, boolean useCache, boolean offlined) void
Admin.majorCompact
(TableName tableName) Major compact a table.void
Admin.majorCompact
(TableName tableName, byte[] columnFamily) Major compact a column family within a table.void
Admin.majorCompact
(TableName tableName, byte[] columnFamily, CompactType compactType) Major compact a column family within a table.void
Admin.majorCompact
(TableName tableName, CompactType compactType) Major compact a table.default CompletableFuture<Void>
AsyncAdmin.majorCompact
(TableName tableName) Major compact a table.default CompletableFuture<Void>
AsyncAdmin.majorCompact
(TableName tableName, byte[] columnFamily) Major compact a column family within a table.AsyncAdmin.majorCompact
(TableName tableName, byte[] columnFamily, CompactType compactType) Major compact a column family within a table.AsyncAdmin.majorCompact
(TableName tableName, CompactType compactType) Major compact a table.AsyncHBaseAdmin.majorCompact
(TableName tableName, byte[] columnFamily, CompactType compactType) AsyncHBaseAdmin.majorCompact
(TableName tableName, CompactType compactType) void
HBaseAdmin.majorCompact
(TableName tableName) void
HBaseAdmin.majorCompact
(TableName tableName, byte[] columnFamily) Major compact a column family within a table.void
HBaseAdmin.majorCompact
(TableName tableName, byte[] columnFamily, CompactType compactType) Major compact a column family within a table.void
HBaseAdmin.majorCompact
(TableName tableName, CompactType compactType) Major compact a table.RawAsyncHBaseAdmin.majorCompact
(TableName tableName, byte[] columnFamily, CompactType compactType) RawAsyncHBaseAdmin.majorCompact
(TableName tableName, CompactType compactType) default void
Admin.modifyColumn
(TableName tableName, ColumnFamilyDescriptor columnFamily) Deprecated.As of release 2.0.0.default void
Admin.modifyColumnFamily
(TableName tableName, ColumnFamilyDescriptor columnFamily) Modify an existing column family on a table.AsyncAdmin.modifyColumnFamily
(TableName tableName, ColumnFamilyDescriptor columnFamily) Modify an existing column family on a table.AsyncHBaseAdmin.modifyColumnFamily
(TableName tableName, ColumnFamilyDescriptor columnFamily) RawAsyncHBaseAdmin.modifyColumnFamily
(TableName tableName, ColumnFamilyDescriptor columnFamily) Admin.modifyColumnFamilyAsync
(TableName tableName, ColumnFamilyDescriptor columnFamily) Modify an existing column family on a table.HBaseAdmin.modifyColumnFamilyAsync
(TableName tableName, ColumnFamilyDescriptor columnFamily) default void
Admin.modifyColumnFamilyStoreFileTracker
(TableName tableName, byte[] family, String dstSFT) Change the store file tracker of the given table's given family.AsyncAdmin.modifyColumnFamilyStoreFileTracker
(TableName tableName, byte[] family, String dstSFT) Change the store file tracker of the given table's given family.AsyncHBaseAdmin.modifyColumnFamilyStoreFileTracker
(TableName tableName, byte[] family, String dstSFT) RawAsyncHBaseAdmin.modifyColumnFamilyStoreFileTracker
(TableName tableName, byte[] family, String dstSFT) Admin.modifyColumnFamilyStoreFileTrackerAsync
(TableName tableName, byte[] family, String dstSFT) Change the store file tracker of the given table's given family.HBaseAdmin.modifyColumnFamilyStoreFileTrackerAsync
(TableName tableName, byte[] family, String dstSFT) default void
Admin.modifyTable
(TableName tableName, TableDescriptor td) Deprecated.since 2.0 version and will be removed in 3.0 version.Admin.modifyTableAsync
(TableName tableName, TableDescriptor td) Deprecated.since 2.0 version and will be removed in 3.0 version.default void
Admin.modifyTableStoreFileTracker
(TableName tableName, String dstSFT) Change the store file tracker of the given table.AsyncAdmin.modifyTableStoreFileTracker
(TableName tableName, String dstSFT) Change the store file tracker of the given table.AsyncHBaseAdmin.modifyTableStoreFileTracker
(TableName tableName, String dstSFT) RawAsyncHBaseAdmin.modifyTableStoreFileTracker
(TableName tableName, String dstSFT) Admin.modifyTableStoreFileTrackerAsync
(TableName tableName, String dstSFT) Change the store file tracker of the given table.HBaseAdmin.modifyTableStoreFileTrackerAsync
(TableName tableName, String dstSFT) static RegionInfoBuilder
RegionInfoBuilder.newBuilder
(TableName tableName) static TableDescriptorBuilder
TableDescriptorBuilder.newBuilder
(TableName name) private boolean
AsyncNonMetaRegionLocator.onScanNext
(TableName tableName, AsyncNonMetaRegionLocator.LocateRequest req, Result result) static TableState
private <PREQ,
PRESP>
CompletableFuture<Void>RawAsyncHBaseAdmin.procedureCall
(TableName tableName, PREQ preq, RawAsyncHBaseAdmin.MasterRpcCall<PRESP, PREQ> rpcCall, RawAsyncHBaseAdmin.Converter<Long, PRESP> respConverter, RawAsyncHBaseAdmin.ProcedureBiConsumer consumer) Deprecated.The puts request will be buffered by their corresponding buffer queue.boolean
Deprecated.The put request will be buffered by its corresponding buffer queue.boolean
Deprecated.The put request will be buffered by its corresponding buffer queue.ClusterConnection.relocateRegion
(TableName tableName, byte[] row) Find the location of the region of tableName that row lives in, ignoring any value that might be in the cache.ClusterConnection.relocateRegion
(TableName tableName, byte[] row, int replicaId) Find the location of the region of tableName that row lives in, ignoring any value that might be in the cache.ConnectionImplementation.relocateRegion
(TableName tableName, byte[] row) ConnectionImplementation.relocateRegion
(TableName tableName, byte[] row, int replicaId) (package private) static void
ConnectionUtils.resetController
(HBaseRpcController controller, long timeoutNs, int priority, TableName tableName) private CompletableFuture<Void>
RawAsyncHBaseAdmin.restoreSnapshot
(String snapshotName, TableName tableName, boolean takeFailSafeSnapshot, boolean restoreAcl) int
CatalogReplicaLoadBalanceSelector.select
(TableName tablename, byte[] row, RegionLocateType locateType) Select a catalog replica region where client go to loop up the input row key.int
CatalogReplicaLoadBalanceSimpleSelector.select
(TableName tableName, byte[] row, RegionLocateType locateType) When it looks up a location, it will call this method to find a replica region to go.(package private) void
MasterCallable.setPriority
(TableName tableName) AsyncProcessTask.Builder.setTableName
(TableName tableName) private void
HBaseAdmin.setTableRep
(TableName tableName, boolean enableRep) Set the table's replication switch if the table's replication switch is already not set.private CompletableFuture<Void>
RawAsyncHBaseAdmin.setTableReplication
(TableName tableName, boolean enableRep) Set the table's replication switch if the table's replication switch is already not set.default void
Deprecated.since 2.3.0, will be removed in 3.0.0.default void
Take a snapshot for the given table.default void
Create typed snapshot of the table.default void
Admin.snapshot
(String snapshotName, TableName tableName, SnapshotType type) Create typed snapshot of the table.default void
Admin.snapshot
(String snapshotName, TableName tableName, SnapshotType type, Map<String, Object> snapshotProps) Create typed snapshot of the table.default CompletableFuture<Void>
Take a snapshot for the given table.default CompletableFuture<Void>
AsyncAdmin.snapshot
(String snapshotName, TableName tableName, SnapshotType type) Create typed snapshot of the table.void
Split a table.void
Split a table.Split a table.Split a table.void
void
boolean
Admin.tableExists
(TableName tableName) Check if a table exists.AsyncAdmin.tableExists
(TableName tableName) Check if a table exists.AsyncHBaseAdmin.tableExists
(TableName tableName) boolean
HBaseAdmin.tableExists
(TableName tableName) RawAsyncHBaseAdmin.tableExists
(TableName tableName) (package private) static <T> CompletableFuture<T>
ConnectionUtils.timelineConsistentRead
(AsyncRegionLocator locator, TableName tableName, Query query, byte[] row, RegionLocateType locateType, Function<Integer, CompletableFuture<T>> requestReplica, long rpcTimeoutNs, long primaryCallTimeoutNs, org.apache.hbase.thirdparty.io.netty.util.Timer retryTimer, Optional<MetricsConnection> metrics) default void
Admin.truncateTable
(TableName tableName, boolean preserveSplits) Truncate a table.AsyncAdmin.truncateTable
(TableName tableName, boolean preserveSplits) Truncate a table.AsyncHBaseAdmin.truncateTable
(TableName tableName, boolean preserveSplits) RawAsyncHBaseAdmin.truncateTable
(TableName tableName, boolean preserveSplits) Admin.truncateTableAsync
(TableName tableName, boolean preserveSplits) Truncate the table but does not block and wait for it to be completely enabled.HBaseAdmin.truncateTableAsync
(TableName tableName, boolean preserveSplits) private CompletableFuture<Void>
RawAsyncHBaseAdmin.trySyncTableToPeerCluster
(TableName tableName, byte[][] splits, ReplicationPeerDescription peer) void
ClusterConnection.updateCachedLocations
(TableName tableName, byte[] regionName, byte[] rowkey, Object exception, ServerName source) Update the location cache.void
ConnectionImplementation.updateCachedLocations
(TableName tableName, byte[] regionName, byte[] rowkey, Object exception, ServerName source) Update the location with the new value (if the exception is a RegionMovedException) or delete it from the cache.void
MetricsConnection.updateRpc
(org.apache.hbase.thirdparty.com.google.protobuf.Descriptors.MethodDescriptor method, TableName tableName, org.apache.hbase.thirdparty.com.google.protobuf.Message param, MetricsConnection.CallStats stats, Throwable e) Report RPC context to metrics system.private void
MetricsConnection.updateTableMetric
(String methodName, TableName tableName, MetricsConnection.CallStats stats, Throwable e) Report table rpc context to metrics system.protected void
AsyncProcess.waitForMaximumCurrentTasks
(int max, TableName tableName) Wait until the async does not have more than max tasks in progress.Modifier and TypeMethodDescriptiondefault void
Append the replicable table column family config from the specified peer.Append the replicable table-cf config of the specified peerprivate void
RawAsyncHBaseAdmin.checkAndGetTableName
(byte[] encodeRegionName, AtomicReference<TableName> tableName, CompletableFuture<TableName> result) private void
RawAsyncHBaseAdmin.checkAndGetTableName
(byte[] encodeRegionName, AtomicReference<TableName> tableName, CompletableFuture<TableName> result) Admin.getTableDescriptorsByTableName
(List<TableName> tableNames) Deprecated.since 2.0 version and will be removed in 3.0 version.HBaseAdmin.getTableDescriptorsByTableName
(List<TableName> tableNames) Admin.listTableDescriptors
(List<TableName> tableNames) Get tableDescriptors.AsyncAdmin.listTableDescriptors
(List<TableName> tableNames) List specific tables including system tables.AsyncHBaseAdmin.listTableDescriptors
(List<TableName> tableNames) HBaseAdmin.listTableDescriptors
(List<TableName> tableNames) RawAsyncHBaseAdmin.listTableDescriptors
(List<TableName> tableNames) default void
Remove some table-cfs from config of the specified peer.Remove some table-cfs from config of the specified peerNormalizeTableFilterParams.Builder.tableNames
(List<TableName> tableNames) ModifierConstructorDescriptionAddColumnFamilyFuture
(HBaseAdmin admin, TableName tableName, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.AddColumnResponse response) (package private)
AddColumnFamilyProcedureBiConsumer
(TableName tableName) AsyncBatchRpcRetryingCaller
(org.apache.hbase.thirdparty.io.netty.util.Timer retryTimer, AsyncConnectionImpl conn, TableName tableName, List<? extends Row> actions, long pauseNs, long pauseNsForServerOverloaded, int maxAttempts, long operationTimeoutNs, long rpcTimeoutNs, int startLogErrorsCnt, Map<String, byte[]> requestAttributes) AsyncClientScanner
(Scan scan, AdvancedScanResultConsumer consumer, TableName tableName, AsyncConnectionImpl conn, org.apache.hbase.thirdparty.io.netty.util.Timer retryTimer, long pauseNs, long pauseNsForServerOverloaded, int maxAttempts, long scanTimeoutNs, long rpcTimeoutNs, int startLogErrorsCnt, Map<String, byte[]> requestAttributes) (package private)
AsyncProcessTask
(ExecutorService pool, TableName tableName, RowAccess<? extends Row> rows, AsyncProcessTask.SubmittedRows size, Batch.Callback<T> callback, CancellableRegionServerCallable callable, boolean needResults, int rpcTimeout, int operationTimeout, Object[] results, Map<String, byte[]> requestAttributes) AsyncRegionLocationCache
(TableName tableName) AsyncSingleRequestRpcRetryingCaller
(org.apache.hbase.thirdparty.io.netty.util.Timer retryTimer, AsyncConnectionImpl conn, TableName tableName, byte[] row, int replicaId, RegionLocateType locateType, AsyncSingleRequestRpcRetryingCaller.Callable<T> callable, int priority, long pauseNs, long pauseNsForServerOverloaded, int maxAttempts, long operationTimeoutNs, long rpcTimeoutNs, int startLogErrorsCnt, Map<String, byte[]> requestAttributes) (package private)
AsyncTableBuilderBase
(TableName tableName, AsyncConnectionConfiguration connConf) AsyncTableRegionLocatorImpl
(TableName tableName, AsyncConnectionImpl conn) AsyncTableResultScanner
(TableName tableName, Scan scan, long maxCacheSize) BufferedMutatorParams
(TableName tableName) (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) (package private)
CatalogReplicaLoadBalanceSimpleSelector
(TableName tableName, ChoreService choreService, IntSupplier getNumOfReplicas) ClientAsyncPrefetchScanner
(org.apache.hadoop.conf.Configuration configuration, Scan scan, Scan scanForMetrics, TableName name, ClusterConnection connection, RpcRetryingCallerFactory rpcCallerFactory, RpcControllerFactory rpcControllerFactory, ExecutorService pool, int scanReadRpcTimeout, int scannerTimeout, int replicaCallTimeoutMicroSecondScan, ConnectionConfiguration connectionConfiguration, Map<String, byte[]> requestAttributes) ClientScanner
(org.apache.hadoop.conf.Configuration conf, Scan scan, Scan scanForMetrics, TableName tableName, ClusterConnection connection, RpcRetryingCallerFactory rpcFactory, RpcControllerFactory controllerFactory, ExecutorService pool, int scanReadRpcTimeout, int scannerTimeout, int primaryOperationTimeout, ConnectionConfiguration connectionConfiguration, Map<String, byte[]> requestAttributes) Create a new ClientScanner for the specified table Note that the passedScan
's start row maybe changed changed.ClientServiceCallable
(Connection connection, TableName tableName, byte[] row, org.apache.hbase.thirdparty.com.google.protobuf.RpcController rpcController, int priority, Map<String, byte[]> requestAttributes) ClientSimpleScanner
(org.apache.hadoop.conf.Configuration configuration, Scan scan, Scan scanForMetrics, TableName name, ClusterConnection connection, RpcRetryingCallerFactory rpcCallerFactory, RpcControllerFactory rpcControllerFactory, ExecutorService pool, int scanReadRpcTimeout, int scannerTimeout, int replicaCallTimeoutMicroSecondScan, ConnectionConfiguration connectionConfiguration, Map<String, byte[]> requestAttributes) (package private)
CreateTableProcedureBiConsumer
(TableName tableName) DeleteColumnFamilyFuture
(HBaseAdmin admin, TableName tableName, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.DeleteColumnResponse response) (package private)
DeleteColumnFamilyProcedureBiConsumer
(TableName tableName) DeleteTableFuture
(HBaseAdmin admin, TableName tableName, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.DeleteTableResponse response) (package private)
DeleteTableProcedureBiConsumer
(TableName tableName) DisableTableFuture
(HBaseAdmin admin, TableName tableName, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.DisableTableResponse response) (package private)
DisableTableProcedureBiConsumer
(TableName tableName) EnableTableFuture
(HBaseAdmin admin, TableName tableName, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.EnableTableResponse response) (package private)
EnableTableProcedureBiConsumer
(TableName tableName) FlushRegionCallable
(ClusterConnection connection, RpcControllerFactory rpcControllerFactory, TableName tableName, byte[] regionName, byte[] regionStartKey, boolean writeFlushWalMarker) FlushTableFuture
(HBaseAdmin admin, TableName tableName, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.FlushTableResponse resp) (package private)
FlushTableProcedureBiConsumer
(TableName tableName) HRegionLocator
(TableName tableName, ConnectionImplementation connection) LegacyFlushFuture
(HBaseAdmin admin, TableName tableName, Map<String, String> props) (package private)
MergeTableRegionProcedureBiConsumer
(TableName tableName) MergeTableRegionsFuture
(HBaseAdmin admin, TableName tableName, Long procId) MergeTableRegionsFuture
(HBaseAdmin admin, TableName tableName, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MergeTableRegionsResponse response) Construct a table descriptor specifying a TableName objectprivate
ModifyableTableDescriptor
(TableName name, Collection<ColumnFamilyDescriptor> families, Map<Bytes, Bytes> values) ModifyableTableDescriptor
(TableName name, TableDescriptor desc) Deprecated.ModifyColumnFamilyFuture
(HBaseAdmin admin, TableName tableName, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.ModifyColumnResponse response) (package private)
ModifyColumnFamilyProcedureBiConsumer
(TableName tableName) ModifyColumnFamilyStoreFileTrackerFuture
(HBaseAdmin admin, TableName tableName, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.ModifyColumnStoreFileTrackerResponse response) (package private)
ModifyTableFuture
(HBaseAdmin admin, TableName tableName, Long procId) ModifyTableFuture
(HBaseAdmin admin, TableName tableName, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.ModifyTableResponse response) (package private)
ModifyTableProcedureBiConsumer
(AsyncAdmin admin, TableName tableName) ModifyTablerStoreFileTrackerFuture
(HBaseAdmin admin, TableName tableName, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.ModifyTableStoreFileTrackerResponse response) (package private)
ModifyTableStoreFileTrackerProcedureBiConsumer
(AsyncAdmin admin, TableName tableName) (package private)
MultiServerCallable
(ClusterConnection connection, TableName tableName, ServerName location, MultiAction multi, org.apache.hbase.thirdparty.com.google.protobuf.RpcController rpcController, int rpcTimeout, RetryingTimeTracker tracker, int priority, Map<String, byte[]> requestAttributes) (package private)
MutableRegionInfo
(long regionId, TableName tableName, int replicaId) Package private constructor used constructing MutableRegionInfo for the first meta regions(package private)
MutableRegionInfo
(TableName tableName, byte[] startKey, byte[] endKey, boolean split, long regionId, int replicaId, boolean offLine) NoncedRegionServerCallable
(Connection connection, TableName tableName, byte[] row, HBaseRpcController rpcController, int priority, Map<String, byte[]> requestAttributes) RegionAdminServiceCallable
(ClusterConnection connection, RpcControllerFactory rpcControllerFactory, HRegionLocation location, TableName tableName, byte[] row) RegionAdminServiceCallable
(ClusterConnection connection, RpcControllerFactory rpcControllerFactory, HRegionLocation location, TableName tableName, byte[] row, int replicaId) RegionAdminServiceCallable
(ClusterConnection connection, RpcControllerFactory rpcControllerFactory, TableName tableName, byte[] row) (package private)
RegionCoprocessorRpcChannel
(ClusterConnection conn, TableName table, byte[] row, Map<String, byte[]> requestAttributes) Constructor(package private)
RegionCoprocessorRpcChannelImpl
(AsyncConnectionImpl conn, TableName tableName, RegionInfo region, byte[] row, long rpcTimeoutNs, long operationTimeoutNs) private
RegionInfoBuilder
(TableName tableName) 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) RestoreSnapshotFuture
(HBaseAdmin admin, org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotDescription snapshot, TableName tableName, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.RestoreSnapshotResponse response) RestoreSnapshotFuture
(HBaseAdmin admin, TableName tableName, Long procId) ReversedClientScanner
(org.apache.hadoop.conf.Configuration conf, Scan scan, Scan scanForMetrics, TableName tableName, ClusterConnection connection, RpcRetryingCallerFactory rpcFactory, RpcControllerFactory controllerFactory, ExecutorService pool, int scanReadRpcTimeout, int scannerTimeout, int primaryOperationTimeout, ConnectionConfiguration connectionConfiguration, Map<String, byte[]> requestAttributes) Create a new ReversibleClientScanner for the specified table Note that the passedScan
's start row maybe changed.ReversedScannerCallable
(ClusterConnection connection, TableName tableName, Scan scan, ScanMetrics scanMetrics, RpcControllerFactory rpcFactory, int replicaId, Map<String, byte[]> requestAttributes) RpcRetryingCallerWithReadReplicas
(RpcControllerFactory rpcControllerFactory, TableName tableName, ClusterConnection cConnection, Get get, ExecutorService pool, int retries, int operationTimeout, int rpcTimeout, int timeBeforeReplicas, Map<String, byte[]> requestAttributes) ScannerCallable
(ClusterConnection connection, TableName tableName, Scan scan, ScanMetrics scanMetrics, RpcControllerFactory rpcControllerFactory, int id, Map<String, byte[]> requestAttributes) ScannerCallableWithReplicas
(TableName tableName, ClusterConnection cConnection, ScannerCallable baseCallable, ExecutorService pool, int timeBeforeReplicas, Scan scan, int retries, int readRpcTimeout, int scannerTimeout, boolean useScannerTimeoutForNextCalls, int caching, org.apache.hadoop.conf.Configuration conf, RpcRetryingCaller<Result[]> caller) SnapshotDescription
(String name, TableName table) SnapshotDescription
(String name, TableName table, SnapshotType type) SnapshotDescription
(String name, TableName table, SnapshotType type, String owner) SnapshotDescription
(String name, TableName table, SnapshotType type, String owner, long creationTime, int version) Deprecated.since 2.3.0 and will be removed in 4.0.0.SnapshotDescription
(String name, TableName table, SnapshotType type, String owner, long creationTime, int version, Map<String, Object> snapshotProps) SnapshotDescription Parameterized ConstructorSnapshotDescription
(String snapshotName, TableName tableName, SnapshotType type, Map<String, Object> snapshotProps) SnapshotDescription Parameterized Constructor(package private)
SnapshotProcedureBiConsumer
(TableName tableName) SplitTableRegionFuture
(HBaseAdmin admin, TableName tableName, Long procId) SplitTableRegionFuture
(HBaseAdmin admin, TableName tableName, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.SplitTableRegionResponse response) (package private)
SplitTableRegionProcedureBiConsumer
(TableName tableName) (package private)
TableBuilderBase
(TableName tableName, ConnectionConfiguration connConf) TableCache
(TableName tableName) private
TableFuture
(HBaseAdmin admin, TableName tableName, Long procId) (package private)
TableProcedureBiConsumer
(TableName tableName) TableState
(TableName tableName, TableState.State state) Create instance of TableState.TruncateRegionFuture
(HBaseAdmin admin, TableName tableName, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.TruncateRegionResponse response) (package private)
TruncateRegionProcedureBiConsumer
(TableName tableName) TruncateTableFuture
(HBaseAdmin admin, TableName tableName, boolean preserveSplits, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.TruncateTableResponse response) (package private)
TruncateTableProcedureBiConsumer
(TableName tableName) ModifierConstructorDescriptionprivate
NormalizeTableFilterParams
(List<TableName> tableNames, String regex, String namespace) -
Uses of TableName in org.apache.hadoop.hbase.client.example
Modifier and TypeFieldDescriptionprivate static final TableName
BufferedMutatorExample.TABLE
private final TableName
MultiThreadedClientExample.ReadExampleCallable.tableName
private final TableName
MultiThreadedClientExample.SingleWriteExampleCallable.tableName
private final TableName
MultiThreadedClientExample.WriteExampleCallable.tableName
Modifier and TypeMethodDescriptionvoid
RefreshHFilesClient.refreshHFiles
(TableName tableName) private void
MultiThreadedClientExample.warmUpConnectionCache
(Connection connection, TableName tn) ModifierConstructorDescriptionReadExampleCallable
(Connection connection, TableName tableName) SingleWriteExampleCallable
(Connection connection, TableName tableName) WriteExampleCallable
(Connection connection, TableName tableName) -
Uses of TableName in org.apache.hadoop.hbase.client.locking
Modifier and TypeMethodDescriptionstatic org.apache.hadoop.hbase.shaded.protobuf.generated.LockServiceProtos.LockRequest
LockServiceClient.buildLockRequest
(org.apache.hadoop.hbase.shaded.protobuf.generated.LockServiceProtos.LockType type, String namespace, TableName tableName, List<RegionInfo> regionInfos, String description, long nonceGroup, long nonce) LockServiceClient.tableLock
(TableName tableName, boolean exclusive, String description, Abortable abort) Create a new EntityLock object to acquire an exclusive or shared lock on a table. -
Uses of TableName in org.apache.hadoop.hbase.client.replication
Modifier and TypeMethodDescriptionReplicationPeerConfigUtil.convert2Map
(org.apache.hadoop.hbase.shaded.protobuf.generated.ReplicationProtos.TableCF[] tableCFs) Convert tableCFs Object to Map.ReplicationAdmin.copyTableCFs
(Map<TableName, ? extends Collection<String>> tableCfs) Deprecated.ReplicationPeerConfigUtil.copyTableCFsMap
(Map<TableName, List<String>> preTableCfs) ReplicationPeerConfigUtil.mergeTableCFs
(Map<TableName, List<String>> preTableCfs, Map<TableName, List<String>> tableCfs) ReplicationAdmin.parseTableCFsFromConfig
(String tableCFsConfig) Deprecated.as release of 2.0.0, and it will be removed in 3.0.0ReplicationPeerConfigUtil.parseTableCFsFromConfig
(String tableCFsConfig) Convert tableCFs string into Map.Modifier and TypeMethodDescriptionvoid
ReplicationAdmin.disableTableRep
(TableName tableName) Deprecated.useAdmin.disableTableReplication(TableName)
insteadvoid
ReplicationAdmin.enableTableRep
(TableName tableName) Deprecated.useAdmin.enableTableReplication(TableName)
insteadModifier and TypeMethodDescriptionvoid
ReplicationAdmin.addPeer
(String id, ReplicationPeerConfig peerConfig, Map<TableName, ? extends Collection<String>> tableCfs) Deprecated.as release of 2.0.0, and it will be removed in 3.0.0, useReplicationAdmin.addPeer(String, ReplicationPeerConfig)
instead.static ReplicationPeerConfig
ReplicationPeerConfigUtil.appendExcludeTableCFsToReplicationPeerConfig
(Map<TableName, List<String>> excludeTableCfs, ReplicationPeerConfig peerConfig) void
ReplicationAdmin.appendPeerTableCFs
(String id, Map<TableName, ? extends Collection<String>> tableCfs) Deprecated.static ReplicationPeerConfig
ReplicationPeerConfigUtil.appendTableCFsToReplicationPeerConfig
(Map<TableName, List<String>> tableCfs, ReplicationPeerConfig peerConfig) static org.apache.hadoop.hbase.shaded.protobuf.generated.ReplicationProtos.TableCF[]
ReplicationPeerConfigUtil.convert
(Map<TableName, ? extends Collection<String>> tableCfs) convert map to TableCFs Objectstatic String
ReplicationPeerConfigUtil.convertToString
(Map<TableName, ? extends Collection<String>> tableCfs) ReplicationAdmin.copyTableCFs
(Map<TableName, ? extends Collection<String>> tableCfs) Deprecated.ReplicationPeerConfigUtil.copyTableCFsMap
(Map<TableName, List<String>> preTableCfs) ReplicationPeerConfigUtil.mergeTableCFs
(Map<TableName, List<String>> preTableCfs, Map<TableName, List<String>> tableCfs) static ReplicationPeerConfig
ReplicationPeerConfigUtil.removeExcludeTableCFsFromReplicationPeerConfig
(Map<TableName, List<String>> excludeTableCfs, ReplicationPeerConfig peerConfig, String id) void
ReplicationAdmin.removePeerTableCFs
(String id, Map<TableName, ? extends Collection<String>> tableCfs) Deprecated.static ReplicationPeerConfig
ReplicationPeerConfigUtil.removeTableCFsFromReplicationPeerConfig
(Map<TableName, List<String>> tableCfs, ReplicationPeerConfig peerConfig, String id) void
ReplicationAdmin.setPeerTableCFs
(String id, Map<TableName, ? extends Collection<String>> tableCfs) Deprecated. -
Uses of TableName in org.apache.hadoop.hbase.client.trace
Modifier and TypeMethodDescription(package private) static void
TableSpanBuilder.populateTableNameAttributes
(Map<io.opentelemetry.api.common.AttributeKey<?>, Object> attributes, TableName tableName) Static utility method that performs the primary logic of this builder.TableOperationSpanBuilder.setTableName
(TableName tableName) TableSpanBuilder.setTableName
(TableName tableName) -
Uses of TableName in org.apache.hadoop.hbase.coprocessor
Modifier and TypeMethodDescriptiondefault void
MasterObserver.postCompletedDeleteTableAction
(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName) Called afterHMaster
deletes a table.default void
MasterObserver.postCompletedDisableTableAction
(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName) Called after the disableTable operation has been requested.default void
MasterObserver.postCompletedEnableTableAction
(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName) Called after the enableTable operation has been requested.default void
MasterObserver.postCompletedModifyTableAction
(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName, TableDescriptor currentDescriptor) Deprecated.Since 2.1.default void
MasterObserver.postCompletedModifyTableAction
(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName, TableDescriptor oldDescriptor, TableDescriptor currentDescriptor) Called after to modifying a table's properties.default void
MasterObserver.postCompletedTruncateTableAction
(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName) Called afterHMaster
truncates a table.default void
MasterObserver.postDeleteTable
(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName) Called after the deleteTable operation has been requested.default void
MasterObserver.postDisableTable
(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName) Called after the disableTable operation has been requested.default void
MasterObserver.postEnableTable
(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName) Called after the enableTable operation has been requested.default void
MasterObserver.postGetUserPermissions
(ObserverContext<MasterCoprocessorEnvironment> ctx, String userName, String namespace, TableName tableName, byte[] family, byte[] qualifier) Called after getting user permissions.default void
MasterObserver.postModifyColumnFamilyStoreFileTracker
(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName, byte[] family, String dstSFT) Called after modifying a family store file tracker.default void
MasterObserver.postModifyTable
(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName, TableDescriptor currentDescriptor) Deprecated.Since 2.1.default void
MasterObserver.postModifyTable
(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName, TableDescriptor oldDescriptor, TableDescriptor currentDescriptor) Called after the modifyTable operation has been requested.default void
MasterObserver.postModifyTableStoreFileTracker
(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName, String dstSFT) Called after modifying a table's store file tracker.default void
MasterObserver.postRequestLock
(ObserverContext<MasterCoprocessorEnvironment> ctx, String namespace, TableName tableName, RegionInfo[] regionInfos, String description) Called after new LockProcedure is queued.default void
MasterObserver.postSetTableQuota
(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName, GlobalQuotaSettings quotas) Called after the quota for the table is stored.default void
MasterObserver.postSetUserQuota
(ObserverContext<MasterCoprocessorEnvironment> ctx, String userName, TableName tableName, GlobalQuotaSettings quotas) Called after the quota for the user on the specified table is stored.default void
MasterObserver.postTableFlush
(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName) Called after the table memstore is flushed to disk.default void
MasterObserver.postTruncateTable
(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName) Called after the truncateTable operation has been requested.default void
MasterObserver.preDeleteTable
(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName) Called beforeHMaster
deletes a table.default void
MasterObserver.preDeleteTableAction
(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName) Called beforeHMaster
deletes a table.default void
MasterObserver.preDisableTable
(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName) Called prior to disabling a table.default void
MasterObserver.preDisableTableAction
(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName) Called prior to disabling a table.default void
MasterObserver.preEnableTable
(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName) Called prior to enabling a table.default void
MasterObserver.preEnableTableAction
(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName) Called prior to enabling a table.default void
MasterObserver.preGetUserPermissions
(ObserverContext<MasterCoprocessorEnvironment> ctx, String userName, String namespace, TableName tableName, byte[] family, byte[] qualifier) Called before getting user permissions.default void
MasterObserver.preLockHeartbeat
(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tn, String description) Called before heartbeat to a lock.default String
MasterObserver.preModifyColumnFamilyStoreFileTracker
(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName, byte[] family, String dstSFT) Called prior to modifying a family's store file tracker.default void
MasterObserver.preModifyTable
(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName, TableDescriptor newDescriptor) Deprecated.Since 2.1.default TableDescriptor
MasterObserver.preModifyTable
(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName, TableDescriptor currentDescriptor, TableDescriptor newDescriptor) Called prior to modifying a table's properties.default void
MasterObserver.preModifyTableAction
(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName, TableDescriptor newDescriptor) Deprecated.Since 2.1.default void
MasterObserver.preModifyTableAction
(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName, TableDescriptor currentDescriptor, TableDescriptor newDescriptor) Called prior to modifying a table's properties.default String
MasterObserver.preModifyTableStoreFileTracker
(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName, String dstSFT) Called prior to modifying a table's store file tracker.default void
MasterObserver.preRequestLock
(ObserverContext<MasterCoprocessorEnvironment> ctx, String namespace, TableName tableName, RegionInfo[] regionInfos, String description) Called before new LockProcedure is queued.default void
MasterObserver.preSetTableQuota
(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName, GlobalQuotaSettings quotas) Called before the quota for the table is stored.default void
MasterObserver.preSetUserQuota
(ObserverContext<MasterCoprocessorEnvironment> ctx, String userName, TableName tableName, GlobalQuotaSettings quotas) Called before the quota for the user on the specified table is stored.default void
MasterObserver.preSplitRegion
(ObserverContext<MasterCoprocessorEnvironment> c, TableName tableName, byte[] splitRow) Called before the split region procedure is called.default void
MasterObserver.preSplitRegionAction
(ObserverContext<MasterCoprocessorEnvironment> c, TableName tableName, byte[] splitRow) Called before the region is split.default void
MasterObserver.preTableFlush
(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName) Called before the table memstore is flushed to disk.default void
MasterObserver.preTruncateTable
(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName) Called beforeHMaster
truncates a table.default void
MasterObserver.preTruncateTableAction
(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName) Called beforeHMaster
truncates a table.Modifier and TypeMethodDescriptiondefault void
MasterObserver.postGetTableDescriptors
(ObserverContext<MasterCoprocessorEnvironment> ctx, List<TableName> tableNamesList, List<TableDescriptor> descriptors, String regex) Called after a getTableDescriptors request has been processed.default void
MasterObserver.postMoveTables
(ObserverContext<MasterCoprocessorEnvironment> ctx, Set<TableName> tables, String targetGroup) Called after servers are moved to target region server groupdefault void
MasterObserver.preGetTableDescriptors
(ObserverContext<MasterCoprocessorEnvironment> ctx, List<TableName> tableNamesList, List<TableDescriptor> descriptors, String regex) Called before a getTableDescriptors request has been processed.default void
MasterObserver.preMoveTables
(ObserverContext<MasterCoprocessorEnvironment> ctx, Set<TableName> tables, String targetGroup) Called before tables are moved to target region server group -
Uses of TableName in org.apache.hadoop.hbase.coprocessor.example
Modifier and TypeMethodDescriptionvoid
ExampleMasterObserverWithMetrics.preDisableTable
(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName) -
Uses of TableName in org.apache.hadoop.hbase.favored
Modifier and TypeMethodDescriptionprotected List<RegionPlan>
FavoredNodeLoadBalancer.balanceTable
(TableName tableName, Map<ServerName, List<RegionInfo>> loadOfOneTable) -
Uses of TableName in org.apache.hadoop.hbase.fs
Modifier and TypeMethodDescriptionstatic void
ErasureCodingUtils.setPolicy
(org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.fs.Path rootDir, TableName tableName, String policy) Sets the EC policy on the table directory for the specified tablestatic void
ErasureCodingUtils.unsetPolicy
(org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.fs.Path rootDir, TableName tableName) Unsets any EC policy specified on the path. -
Uses of TableName in org.apache.hadoop.hbase.io
Modifier and TypeMethodDescriptionstatic TableName
HFileLink.getReferencedTableName
(String fileName) Get the Table name of the referenced linkModifier and TypeMethodDescriptionstatic HFileLink
HFileLink.build
(org.apache.hadoop.conf.Configuration conf, TableName table, String region, String family, String hfile) Create an HFileLink instance from table/region/family/hfile locationstatic String
HFileLink.create
(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.fs.Path dstFamilyPath, String familyName, String dstTableName, String dstRegionName, TableName linkedTable, String linkedRegion, String hfileName, boolean createBackRef) Create a new HFileLinkstatic String
HFileLink.create
(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.fs.Path dstFamilyPath, TableName linkedTable, String linkedRegion, String hfileName) Create a new HFileLinkstatic String
HFileLink.create
(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.fs.Path dstFamilyPath, TableName linkedTable, String linkedRegion, String hfileName, boolean createBackRef) Create a new HFileLink.static String
HFileLink.createHFileLinkName
(TableName tableName, String regionName, String hfileName) Create a new HFileLink namestatic org.apache.hadoop.fs.Path
HFileLink.createPath
(TableName table, String region, String family, String hfile) Create an HFileLink relative path for the table/region/family/hfile location -
Uses of TableName in org.apache.hadoop.hbase.io.hfile
-
Uses of TableName in org.apache.hadoop.hbase.ipc
Modifier and TypeMethodDescriptionDelegatingHBaseRpcController.getTableName()
default TableName
HBaseRpcController.getTableName()
Returns Region's table name or null if not available or pertinent.HBaseRpcControllerImpl.getTableName()
Modifier and TypeMethodDescriptionvoid
DelegatingHBaseRpcController.setPriority
(TableName tn) void
HBaseRpcController.setPriority
(TableName tn) Set the priority for this operation.void
HBaseRpcControllerImpl.setPriority
(TableName tn) void
DelegatingHBaseRpcController.setTableName
(TableName tableName) default void
HBaseRpcController.setTableName
(TableName tableName) Sets Region's table name.void
HBaseRpcControllerImpl.setTableName
(TableName tableName) -
Uses of TableName in org.apache.hadoop.hbase.mapred
Modifier and TypeMethodDescriptionprivate static int
TableMapReduceUtil.getRegionCount
(org.apache.hadoop.conf.Configuration conf, TableName tableName) protected void
TableInputFormatBase.initializeTable
(Connection connection, TableName tableName) Allows subclasses to initialize the table information.ModifierConstructorDescriptionTableSplit
(TableName tableName, byte[] startRow, byte[] endRow, String location) Constructor -
Uses of TableName in org.apache.hadoop.hbase.mapreduce
Modifier and TypeMethodDescriptionExportUtils.getArgumentsFromCommandLine
(org.apache.hadoop.conf.Configuration conf, String[] args) WALPlayer.getTableNameList
(String[] tables) Modifier and TypeMethodDescriptionstatic void
TableInputFormat.configureSplitTable
(org.apache.hadoop.mapreduce.Job job, TableName tableName) Sets split table in map-reduce job.private static void
ImportTsv.createTable
(Admin admin, TableName tableName, String[] columns) private static int
TableMapReduceUtil.getRegionCount
(org.apache.hadoop.conf.Configuration conf, TableName tableName) protected void
TableInputFormatBase.initializeTable
(Connection connection, TableName tableName) Allows subclasses to initialize the table information.static void
TableMapReduceUtil.initTableMapperJob
(TableName table, Scan scan, Class<? extends TableMapper> mapper, Class<?> outputKeyClass, Class<?> outputValueClass, org.apache.hadoop.mapreduce.Job job) Use this before submitting a TableMap job.LoadIncrementalHFiles.run
(String dirPath, Map<byte[], List<org.apache.hadoop.fs.Path>> map, TableName tableName) Deprecated.ModifierConstructorDescriptionTableSplit
(TableName tableName, byte[] startRow, byte[] endRow, String location) Creates a new instance without a scanner.TableSplit
(TableName tableName, byte[] startRow, byte[] endRow, String location, long length) Creates a new instance without a scanner.TableSplit
(TableName tableName, Scan scan, byte[] startRow, byte[] endRow, String location) Creates a new instance while assigning all variables.TableSplit
(TableName tableName, Scan scan, byte[] startRow, byte[] endRow, String location, long length) Creates a new instance while assigning all variables.TableSplit
(TableName tableName, Scan scan, byte[] startRow, byte[] endRow, String location, String encodedRegionName, long length) Creates a new instance while assigning all variables. -
Uses of TableName in org.apache.hadoop.hbase.master
Modifier and TypeFieldDescriptionSnapshotOfRegionAssignmentFromMeta.disabledTables
private Map<TableName,
AtomicInteger> HMaster.mobCompactionStates
private final ConcurrentMap<TableName,
TableState.State> TableStateManager.tableName2State
private final Map<TableName,
List<RegionInfo>> SnapshotOfRegionAssignmentFromMeta.tableToRegionMap
the table name to region mapRegionPlacementMaintainer.targetTableSet
private final IdReadWriteLock<TableName>
TableStateManager.tnLock
Modifier and TypeMethodDescriptionRegionPlacementMaintainer.getRegionsMovement
(FavoredNodesPlan newPlan) Return how many regions will move per table since their primary RS will changeSnapshotOfRegionAssignmentFromMeta.getTableSet()
Get the table setTableStateManager.getTablesInStates
(TableState.State... states) Return all tables in given states.SnapshotOfRegionAssignmentFromMeta.getTableToRegionMap()
Get regions for tablesRegionsRecoveryChore.getTableToRegionsByRefCount
(Map<ServerName, ServerMetrics> serverMetricsMap) HMaster.listTableNames
(String namespace, String regex, boolean includeSysTables) Returns the list of table names that match the specified requestHMaster.listTableNamesByNamespace
(String name) MasterServices.listTableNamesByNamespace
(String name) Get list of table names by namespaceModifier and TypeMethodDescriptionlong
HMaster.addColumn
(TableName tableName, ColumnFamilyDescriptor column, long nonceGroup, long nonce) long
MasterServices.addColumn
(TableName tableName, ColumnFamilyDescriptor column, long nonceGroup, long nonce) Add a new column to an existing tableprivate void
HMaster.checkTableExists
(TableName tableName) void
HMaster.checkTableModifiable
(TableName tableName) void
MasterServices.checkTableModifiable
(TableName tableName) Check table is modifiable; i.e.long
HMaster.deleteColumn
(TableName tableName, byte[] columnName, long nonceGroup, long nonce) long
MasterServices.deleteColumn
(TableName tableName, byte[] columnName, long nonceGroup, long nonce) Delete a column from an existing tablelong
HMaster.deleteTable
(TableName tableName, long nonceGroup, long nonce) long
MasterServices.deleteTable
(TableName tableName, long nonceGroup, long nonce) Delete a tableprotected void
TableStateManager.deleteZooKeeper
(TableName tableName) Deprecated.Since 2.0.0.long
HMaster.disableTable
(TableName tableName, long nonceGroup, long nonce) long
MasterServices.disableTable
(TableName tableName, long nonceGroup, long nonce) Disable an existing tablelong
HMaster.enableTable
(TableName tableName, long nonceGroup, long nonce) long
MasterServices.enableTable
(TableName tableName, long nonceGroup, long nonce) Enable an existing tablevoid
AssignmentVerificationReport.fillUp
(TableName tableName, SnapshotOfRegionAssignmentFromMeta snapshot, Map<String, Map<String, Float>> regionLocalityMap) void
AssignmentVerificationReport.fillUpDispersion
(TableName tableName, SnapshotOfRegionAssignmentFromMeta snapshot, FavoredNodesPlan newPlan) Use this to project the dispersion scoreslong
HMaster.flushTable
(TableName tableName, List<byte[]> columnFamilies, long nonceGroup, long nonce) long
MasterServices.flushTable
(TableName tableName, List<byte[]> columnFamilies, long nonceGroup, long nonce) Flush an existing tableprivate void
RegionPlacementMaintainer.genAssignmentPlan
(TableName tableName, SnapshotOfRegionAssignmentFromMeta assignmentSnapshot, Map<String, Map<String, Float>> regionLocalityMap, FavoredNodesPlan plan, boolean munkresForSecondaryAndTertiary) Generate the assignment plan for the existing tableHMaster.getCompactionState
(TableName tableName) Get the compaction state of the tablelong
HMaster.getLastMajorCompactionTimestamp
(TableName table) long
MasterServices.getLastMajorCompactionTimestamp
(TableName table) org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.GetRegionInfoResponse.CompactionState
HMaster.getMobCompactionState
(TableName tableName) Gets the mob file compaction state for a specific table.TableStateManager.getTableState
(TableName tableName) private static boolean
HMaster.isCatalogTable
(TableName tableName) boolean
TableStateManager.isTablePresent
(TableName tableName) boolean
TableStateManager.isTableState
(TableName tableName, TableState.State... states) protected void
MirroringTableStateManager.metaStateDeleted
(TableName tableName) Deprecated.protected void
TableStateManager.metaStateDeleted
(TableName tableName) protected void
MirroringTableStateManager.metaStateUpdated
(TableName tableName, TableState.State newState) Deprecated.protected void
TableStateManager.metaStateUpdated
(TableName tableName, TableState.State newState) long
HMaster.modifyColumn
(TableName tableName, ColumnFamilyDescriptor descriptor, long nonceGroup, long nonce) long
MasterServices.modifyColumn
(TableName tableName, ColumnFamilyDescriptor descriptor, long nonceGroup, long nonce) Modify the column descriptor of an existing column in an existing tablelong
HMaster.modifyColumnStoreFileTracker
(TableName tableName, byte[] family, String dstSFT, long nonceGroup, long nonce) long
MasterServices.modifyColumnStoreFileTracker
(TableName tableName, byte[] family, String dstSFT, long nonceGroup, long nonce) Modify the store file tracker of an existing column in an existing tablelong
HMaster.modifyTable
(TableName tableName, TableDescriptor newDescriptor, long nonceGroup, long nonce, boolean reopenRegions) private long
HMaster.modifyTable
(TableName tableName, HMaster.TableDescriptorGetter newDescriptorGetter, long nonceGroup, long nonce, boolean shouldCheckDescriptor) private long
HMaster.modifyTable
(TableName tableName, HMaster.TableDescriptorGetter newDescriptorGetter, long nonceGroup, long nonce, boolean shouldCheckDescriptor, boolean reopenRegions) default long
MasterServices.modifyTable
(TableName tableName, TableDescriptor descriptor, long nonceGroup, long nonce) Modify the descriptor of an existing tablelong
MasterServices.modifyTable
(TableName tableName, TableDescriptor descriptor, long nonceGroup, long nonce, boolean reopenRegions) Modify the descriptor of an existing tablelong
HMaster.modifyTableStoreFileTracker
(TableName tableName, String dstSFT, long nonceGroup, long nonce) long
MasterServices.modifyTableStoreFileTracker
(TableName tableName, String dstSFT, long nonceGroup, long nonce) Modify the store file tracker of an existing tablevoid
MasterCoprocessorHost.postCompletedDeleteTableAction
(TableName tableName, User user) void
MasterCoprocessorHost.postCompletedDisableTableAction
(TableName tableName, User user) void
MasterCoprocessorHost.postCompletedEnableTableAction
(TableName tableName, User user) void
MasterCoprocessorHost.postCompletedModifyTableAction
(TableName tableName, TableDescriptor oldDescriptor, TableDescriptor currentDescriptor, User user) void
MasterCoprocessorHost.postCompletedTruncateTableAction
(TableName tableName, User user) void
MasterCoprocessorHost.postDeleteTable
(TableName tableName) void
MasterCoprocessorHost.postDisableTable
(TableName tableName) void
MasterCoprocessorHost.postEnableTable
(TableName tableName) void
MasterCoprocessorHost.postGetUserPermissions
(String userName, String namespace, TableName tableName, byte[] family, byte[] qualifier) void
MasterCoprocessorHost.postModifyColumnFamilyStoreFileTracker
(TableName tableName, byte[] family, String dstSFT) void
MasterCoprocessorHost.postModifyTable
(TableName tableName, TableDescriptor oldDescriptor, TableDescriptor currentDescriptor) void
MasterCoprocessorHost.postModifyTableStoreFileTracker
(TableName tableName, String dstSFT) void
MasterCoprocessorHost.postRequestLock
(String namespace, TableName tableName, RegionInfo[] regionInfos, LockType type, String description) void
MasterCoprocessorHost.postSetTableQuota
(TableName table, GlobalQuotaSettings quotas) void
MasterCoprocessorHost.postSetUserQuota
(String user, TableName table, GlobalQuotaSettings quotas) void
MasterCoprocessorHost.postTableFlush
(TableName tableName) void
MasterCoprocessorHost.postTruncateTable
(TableName tableName) void
MasterCoprocessorHost.preDeleteTable
(TableName tableName) void
MasterCoprocessorHost.preDeleteTableAction
(TableName tableName, User user) void
MasterCoprocessorHost.preDisableTable
(TableName tableName) void
MasterCoprocessorHost.preDisableTableAction
(TableName tableName, User user) void
MasterCoprocessorHost.preEnableTable
(TableName tableName) void
MasterCoprocessorHost.preEnableTableAction
(TableName tableName, User user) void
MasterCoprocessorHost.preGetUserPermissions
(String userName, String namespace, TableName tableName, byte[] family, byte[] qualifier) MasterCoprocessorHost.preModifyColumnFamilyStoreFileTracker
(TableName tableName, byte[] family, String dstSFT) MasterCoprocessorHost.preModifyTable
(TableName tableName, TableDescriptor currentDescriptor, TableDescriptor newDescriptor) void
MasterCoprocessorHost.preModifyTableAction
(TableName tableName, TableDescriptor currentDescriptor, TableDescriptor newDescriptor, User user) MasterCoprocessorHost.preModifyTableStoreFileTracker
(TableName tableName, String dstSFT) void
MasterCoprocessorHost.preRequestLock
(String namespace, TableName tableName, RegionInfo[] regionInfos, LockType type, String description) void
MasterCoprocessorHost.preSetTableQuota
(TableName table, GlobalQuotaSettings quotas) void
MasterCoprocessorHost.preSetUserQuota
(String user, TableName table, GlobalQuotaSettings quotas) void
MasterCoprocessorHost.preSplitRegion
(TableName tableName, byte[] splitRow) Invoked just before calling the split region procedurevoid
MasterCoprocessorHost.preSplitRegionAction
(TableName tableName, byte[] splitRow, User user) Invoked just before a splitvoid
MasterCoprocessorHost.preTableFlush
(TableName tableName) void
MasterCoprocessorHost.preTruncateTable
(TableName tableName) void
MasterCoprocessorHost.preTruncateTableAction
(TableName tableName, User user) void
RegionPlacementMaintainer.printDispersionScores
(TableName table, SnapshotOfRegionAssignmentFromMeta snapshot, int numRegions, FavoredNodesPlan newPlan, boolean simplePrint) private TableState
TableStateManager.readMetaState
(TableName tableName) (package private) long
HMaster.reopenRegions
(TableName tableName, List<byte[]> regionNames, long nonceGroup, long nonce) Reopen regions provided in the argumentvoid
HMaster.reportMobCompactionEnd
(TableName tableName) void
HMaster.reportMobCompactionStart
(TableName tableName) void
TableStateManager.setDeletedTable
(TableName tableName) void
TableStateManager.setTableState
(TableName tableName, TableState.State newState) Set table state to provided.long
HMaster.truncateTable
(TableName tableName, boolean preserveSplits, long nonceGroup, long nonce) long
MasterServices.truncateTable
(TableName tableName, boolean preserveSplits, long nonceGroup, long nonce) Truncate a tableprivate void
TableStateManager.updateMetaState
(TableName tableName, TableState.State newState) Modifier and TypeMethodDescriptionLoadBalancer.balanceCluster
(Map<TableName, Map<ServerName, List<RegionInfo>>> loadOfAllTable) Perform the major balance operation for cluster.void
RegionPlacementMaintainer.checkDifferencesWithOldPlan
(Map<TableName, Integer> movesPerTable, Map<String, Map<String, Float>> regionLocalityMap, FavoredNodesPlan newPlan) Compares two plans and check whether the locality dropped or increased (prints the information as a string) also prints the baseline localityHMaster.listTableDescriptors
(String namespace, String regex, List<TableName> tableNameList, boolean includeSysTables) Returns the list of table descriptors that match the specified requestvoid
MasterCoprocessorHost.postGetTableDescriptors
(List<TableName> tableNamesList, List<TableDescriptor> descriptors, String regex) void
MasterCoprocessorHost.postMoveTables
(Set<TableName> tables, String targetGroup) void
MasterCoprocessorHost.preGetTableDescriptors
(List<TableName> tableNamesList, List<TableDescriptor> descriptors, String regex) void
MasterCoprocessorHost.preMoveTables
(Set<TableName> tables, String targetGroup) private void
RegionsRecoveryChore.prepareTableToReopenRegionsMap
(Map<TableName, List<byte[]>> tableToReopenRegionsMap, byte[] regionName, int regionStoreRefCount) default void
LoadBalancer.updateBalancerLoadInfo
(Map<TableName, Map<ServerName, List<RegionInfo>>> loadOfAllTable) In some scenarios, Balancer needs to update internal status or information according to the current tables loadModifierConstructorDescriptionSnapshotOfRegionAssignmentFromMeta
(Connection connection, Set<TableName> disabledTables, boolean excludeOfflinedSplitParents) -
Uses of TableName in org.apache.hadoop.hbase.master.assignment
Modifier and TypeMethodDescriptionRegionStateNode.getTable()
GCMergedRegionsProcedure.getTableName()
Deprecated.GCMultipleMergedRegionsProcedure.getTableName()
MergeTableRegionsProcedure.getTableName()
MoveRegionProcedure.getTableName()
Deprecated.RegionRemoteProcedureBase.getTableName()
RegionTransitionProcedure.getTableName()
Deprecated.Modifier and TypeMethodDescriptionRegionStates.getAssignmentsForBalancer
(TableStateManager tableStateManager, List<ServerName> onlineServers) This is an EXPENSIVE clone.Modifier and TypeMethodDescriptionAssignmentManager.createUnassignProceduresForClosingExcessRegionReplicas
(TableName tableName, int newReplicaCount) Called by ModifyTableProcedures to unassign all the excess region replicas for a table.AssignmentManager.createUnassignProceduresForDisabling
(TableName tableName) Called by DisableTableProcedure to unassign all the regions for a table.void
AssignmentManager.deleteTable
(TableName tableName) Delete the region states.RegionStates.getRegionByStateOfTable
(TableName tableName) RegionStates.getRegionsOfTable
(TableName table) Returns Return online regions of table; does not include OFFLINE or SPLITTING regions.private List<RegionInfo>
RegionStates.getRegionsOfTable
(TableName table, Predicate<RegionStateNode> filter) Returns Return the regions of the table and filter them.RegionStates.getRegionsOfTableForDeleting
(TableName table) Get the regions for deleting a table.RegionStates.getRegionsOfTableForEnabling
(TableName table) Get the regions for enabling a table.RegionStates.getRegionsOfTableForReopen
(TableName tableName) Get the regions to be reopened when modifying a table.private Stream<RegionStateNode>
AssignmentManager.getRegionStateNodes
(TableName tableName, boolean excludeOfflinedSplitParents) AssignmentManager.getRegionStatesCount
(TableName tableName) Provide regions state count for given table.AssignmentManager.getReopenStatus
(TableName tableName) Used by the client (via master) to identify if all regions have the schema updatesprivate Scan
RegionStateStore.getScanForUpdateRegionReplicas
(TableName tableName) private TableDescriptor
RegionStateStore.getTableDescriptor
(TableName tableName) AssignmentManager.getTableRegions
(TableName tableName, boolean excludeOfflinedSplitParents) AssignmentManager.getTableRegionsAndLocations
(TableName tableName, boolean excludeOfflinedSplitParents) (package private) ArrayList<RegionInfo>
RegionStates.getTableRegionsInfo
(TableName tableName) (package private) List<RegionStateNode>
RegionStates.getTableRegionStateNodes
(TableName tableName) (package private) ArrayList<RegionState>
RegionStates.getTableRegionStates
(TableName tableName) private boolean
RegionStateStore.hasGlobalReplicationScope
(TableName tableName) boolean
RegionStates.hasTableRegionStates
(TableName tableName) private boolean
AssignmentManager.isTableDisabled
(TableName tableName) private boolean
RegionStates.isTableDisabled
(TableStateManager tableStateManager, TableName tableName) private boolean
AssignmentManager.isTableEnabled
(TableName tableName) void
RegionStateStore.removeRegionReplicas
(TableName tableName, int oldReplicaCount, int newReplicaCount) -
Uses of TableName in org.apache.hadoop.hbase.master.balancer
Modifier and TypeMethodDescriptionprotected abstract List<RegionPlan>
BaseLoadBalancer.balanceTable
(TableName tableName, Map<ServerName, List<RegionInfo>> loadOfOneTable) Perform the major balance operation for table, all sub classes should override this method.protected List<RegionPlan>
FavoredStochasticBalancer.balanceTable
(TableName tableName, Map<ServerName, List<RegionInfo>> loadOfOneTable) protected List<RegionPlan>
SimpleLoadBalancer.balanceTable
(TableName tableName, Map<ServerName, List<RegionInfo>> loadOfOneTable) Generate a global load balancing plan according to the specified map of server information to the most loaded regions of each server.protected List<RegionPlan>
StochasticLoadBalancer.balanceTable
(TableName tableName, Map<ServerName, List<RegionInfo>> loadOfOneTable) Given the cluster state this will try and approach an optimal balance.protected TableDescriptor
RegionLocationFinder.getTableDescriptor
(TableName tableName) return TableDescriptor for a given tableName(package private) boolean
StochasticLoadBalancer.needsBalance
(TableName tableName, BalancerClusterState cluster) private void
StochasticLoadBalancer.updateBalancerTableLoadInfo
(TableName tableName, Map<ServerName, List<RegionInfo>> loadOfOneTable) private void
StochasticLoadBalancer.updateStochasticCosts
(TableName tableName, double overall, double[] subCosts) update costs to JMXModifier and TypeMethodDescriptionfinal List<RegionPlan>
BaseLoadBalancer.balanceCluster
(Map<TableName, Map<ServerName, List<RegionInfo>>> loadOfAllTable) Perform the major balance operation for cluster, will invokeBaseLoadBalancer.balanceTable(TableName, Map)
to do actual balance.MaintenanceLoadBalancer.balanceCluster
(Map<TableName, Map<ServerName, List<RegionInfo>>> loadOfAllTable) protected void
BaseLoadBalancer.preBalanceCluster
(Map<TableName, Map<ServerName, List<RegionInfo>>> loadOfAllTable) Called before actually executing balanceCluster.protected void
SimpleLoadBalancer.preBalanceCluster
(Map<TableName, Map<ServerName, List<RegionInfo>>> loadOfAllTable) (package private) void
SimpleLoadBalancer.setClusterLoad
(Map<TableName, Map<ServerName, List<RegionInfo>>> clusterLoad) Pass RegionStates and allow balancer to set the current cluster load.protected final Map<ServerName,
List<RegionInfo>> BaseLoadBalancer.toEnsumbleTableLoad
(Map<TableName, Map<ServerName, List<RegionInfo>>> LoadOfAllTable) void
StochasticLoadBalancer.updateBalancerLoadInfo
(Map<TableName, Map<ServerName, List<RegionInfo>>> loadOfAllTable) -
Uses of TableName in org.apache.hadoop.hbase.master.http
Modifier and TypeFieldDescriptionprivate final TableName
MetaBrowser.scanTable
private final TableName
RegionVisualizer.RegionDetails.tableName
Modifier and TypeMethodDescriptionMetaBrowser.getScanTable()
RegionVisualizer.RegionDetails.getTableName()
private static TableName
MetaBrowser.resolveScanTable
(javax.servlet.http.HttpServletRequest request) Modifier and TypeMethodDescriptionprivate static Filter
MetaBrowser.buildTableFilter
(TableName tableName) ModifierConstructorDescription(package private)
RegionDetails
(ServerName serverName, TableName tableName, RegionMetrics regionMetrics) -
Uses of TableName in org.apache.hadoop.hbase.master.janitor
Modifier and TypeMethodDescriptionprivate static RegionInfo
MetaFixer.buildRegionInfo
(TableName tn, byte[] start, byte[] end) CatalogJanitor.checkRegionReferences
(MasterServices services, TableName tableName, RegionInfo region) Checks if a region still holds references to parent. -
Uses of TableName in org.apache.hadoop.hbase.master.locking
Modifier and TypeFieldDescriptionprivate final TableName
LockManager.MasterLock.tableName
private TableName
LockProcedure.tableName
Modifier and TypeMethodDescriptionLockManager.createMasterLock
(TableName tableName, LockType type, String description) long
LockManager.RemoteLocks.requestTableLock
(TableName tableName, LockType type, String description, NonceKey nonceKey) ModifierConstructorDescriptionLockProcedure
(org.apache.hadoop.conf.Configuration conf, TableName tableName, LockType type, String description, CountDownLatch lockAcquireLatch) Constructor for table lock.MasterLock
(TableName tableName, LockType type, String description) -
Uses of TableName in org.apache.hadoop.hbase.master.normalizer
Modifier and TypeFieldDescriptionprivate final TableName
SimpleRegionNormalizer.NormalizeContext.tableName
Modifier and TypeFieldDescriptionprivate final RegionNormalizerWorkQueue<TableName>
RegionNormalizerManager.workQueue
private final RegionNormalizerWorkQueue<TableName>
RegionNormalizerWorker.workQueue
Modifier and TypeMethodDescriptionprivate List<NormalizationPlan>
RegionNormalizerWorker.calculatePlans
(TableName tableName) Modifier and TypeMethodDescriptionboolean
RegionNormalizerManager.normalizeRegions
(List<TableName> tables, boolean isHighPriority) Submit tables for normalization.ModifierConstructorDescription(package private)
RegionNormalizerManager
(RegionNormalizerStateStore regionNormalizerStateStore, RegionNormalizerChore regionNormalizerChore, RegionNormalizerWorkQueue<TableName> workQueue, RegionNormalizerWorker worker) (package private)
RegionNormalizerWorker
(org.apache.hadoop.conf.Configuration configuration, MasterServices masterServices, RegionNormalizer regionNormalizer, RegionNormalizerWorkQueue<TableName> workQueue) -
Uses of TableName in org.apache.hadoop.hbase.master.procedure
Modifier and TypeFieldDescriptionprivate TableName
SnapshotProcedure.snapshotTable
private TableName
DeleteTableProcedure.tableName
private TableName
DisableTableProcedure.tableName
private TableName
EnableTableProcedure.tableName
private TableName
FlushTableProcedure.tableName
private TableName
ModifyTableDescriptorProcedure.tableName
private TableName
ReopenTableRegionsProcedure.tableName
private TableName
TruncateTableProcedure.tableName
Modifier and TypeFieldDescriptionMasterProcedureScheduler.metaRunQueue
private final Map<TableName,
LockAndQueue> SchemaLocking.tableLocks
MasterProcedureScheduler.tableRunQueue
Modifier and TypeMethodDescriptionAbstractStateMachineNamespaceProcedure.getTableName()
AbstractStateMachineRegionProcedure.getTableName()
abstract TableName
AbstractStateMachineTableProcedure.getTableName()
CloneSnapshotProcedure.getTableName()
CreateTableProcedure.getTableName()
DeleteTableProcedure.getTableName()
DisableTableProcedure.getTableName()
EnableTableProcedure.getTableName()
FlushRegionProcedure.getTableName()
FlushTableProcedure.getTableName()
InitMetaProcedure.getTableName()
private static TableName
MasterProcedureScheduler.getTableName
(Procedure<?> proc) ModifyTableDescriptorProcedure.getTableName()
ModifyTableProcedure.getTableName()
ReopenTableRegionsProcedure.getTableName()
RestoreSnapshotProcedure.getTableName()
SnapshotProcedure.getTableName()
SnapshotRegionProcedure.getTableName()
SnapshotVerifyProcedure.getTableName()
TableProcedureInterface.getTableName()
Returns the name of the table the procedure is operating onTruncateTableProcedure.getTableName()
Modifier and TypeMethodDescriptionprivate static void
DeleteTableProcedure.cleanRegionsInMeta
(MasterProcedureEnv env, TableName tableName) There may be items for this table still up in hbase:meta in the case where the info:regioninfo column was empty because of some write error.CreateTableProcedure.CreateHdfsRegions.createHdfsRegions
(MasterProcedureEnv env, org.apache.hadoop.fs.Path tableRootDir, TableName tableName, List<RegionInfo> newRegions) protected static void
DeleteTableProcedure.deleteAssignmentState
(MasterProcedureEnv env, TableName tableName) static void
MasterDDLOperationHelper.deleteColumnFamilyFromFileSystem
(MasterProcedureEnv env, TableName tableName, List<RegionInfo> regionInfoList, byte[] familyName, boolean hasMob) Remove the column family from the file systemprotected static void
DeleteTableProcedure.deleteFromFs
(MasterProcedureEnv env, TableName tableName, List<RegionInfo> regions, boolean archive) protected static void
DeleteTableProcedure.deleteFromMeta
(MasterProcedureEnv env, TableName tableName, List<RegionInfo> regions) protected static void
DeleteTableProcedure.deleteTableDescriptorCache
(MasterProcedureEnv env, TableName tableName) protected static void
DeleteTableProcedure.deleteTableStates
(MasterProcedureEnv env, TableName tableName) (package private) LockAndQueue
SchemaLocking.getTableLock
(TableName tableName) static int
MasterProcedureUtil.getTablePriority
(TableName tableName) Return the priority for the given table.private TableQueue
MasterProcedureScheduler.getTableQueue
(TableName tableName) (package private) boolean
MasterProcedureScheduler.markTableAsDeleted
(TableName table, Procedure<?> procedure) Tries to remove the queue and the table-lock of the specified table.(package private) LockAndQueue
SchemaLocking.removeTableLock
(TableName tableName) private void
MasterProcedureScheduler.removeTableQueue
(TableName tableName) protected static void
CreateTableProcedure.setEnabledState
(MasterProcedureEnv env, TableName tableName) protected static void
CreateTableProcedure.setEnablingState
(MasterProcedureEnv env, TableName tableName) protected static void
DisableTableProcedure.setTableStateToDisabled
(MasterProcedureEnv env, TableName tableName) Mark table state to Disabledprivate static void
DisableTableProcedure.setTableStateToDisabling
(MasterProcedureEnv env, TableName tableName) Mark table state to Disablingprotected static void
EnableTableProcedure.setTableStateToEnabled
(MasterProcedureEnv env, TableName tableName) Mark table state to Enabledprotected static void
EnableTableProcedure.setTableStateToEnabling
(MasterProcedureEnv env, TableName tableName) Mark table state to Enablingboolean
MasterProcedureScheduler.waitRegions
(Procedure<?> procedure, TableName table, RegionInfo... regionInfos) Suspend the procedure if the specified set of regions are already locked.boolean
MasterProcedureScheduler.waitTableExclusiveLock
(Procedure<?> procedure, TableName table) Suspend the procedure if the specified table is already locked.private TableQueue
MasterProcedureScheduler.waitTableQueueSharedLock
(Procedure<?> procedure, TableName table) boolean
MasterProcedureScheduler.waitTableSharedLock
(Procedure<?> procedure, TableName table) Suspend the procedure if the specified table is already locked.void
MasterProcedureScheduler.wakeRegions
(Procedure<?> procedure, TableName table, RegionInfo... regionInfos) Wake the procedures waiting for the specified regionsvoid
MasterProcedureScheduler.wakeTableExclusiveLock
(Procedure<?> procedure, TableName table) Wake the procedures waiting for the specified tablevoid
MasterProcedureScheduler.wakeTableSharedLock
(Procedure<?> procedure, TableName table) Wake the procedures waiting for the specified tableModifierConstructorDescriptionDeleteTableProcedure
(MasterProcedureEnv env, TableName tableName) DeleteTableProcedure
(MasterProcedureEnv env, TableName tableName, ProcedurePrepareLatch syncLatch) DisableTableProcedure
(MasterProcedureEnv env, TableName tableName, boolean skipTableStateCheck) ConstructorDisableTableProcedure
(MasterProcedureEnv env, TableName tableName, boolean skipTableStateCheck, ProcedurePrepareLatch syncLatch) ConstructorEnableTableProcedure
(MasterProcedureEnv env, TableName tableName) ConstructorEnableTableProcedure
(MasterProcedureEnv env, TableName tableName, ProcedurePrepareLatch syncLatch) ConstructorFlushTableProcedure
(MasterProcedureEnv env, TableName tableName) FlushTableProcedure
(MasterProcedureEnv env, TableName tableName, List<byte[]> columnFamilies) protected
ModifyTableDescriptorProcedure
(MasterProcedureEnv env, TableName tableName) ReopenTableRegionsProcedure
(TableName tableName) ReopenTableRegionsProcedure
(TableName tableName, long reopenBatchBackoffMillis, int reopenBatchSizeMax) ReopenTableRegionsProcedure
(TableName tableName, List<byte[]> regionNames) ReopenTableRegionsProcedure
(TableName tableName, List<byte[]> regionNames, long reopenBatchBackoffMillis, int reopenBatchSizeMax) TableQueue
(TableName tableName, int priority, LockStatus tableLock, LockStatus namespaceLockStatus) TruncateTableProcedure
(MasterProcedureEnv env, TableName tableName, boolean preserveSplits) TruncateTableProcedure
(MasterProcedureEnv env, TableName tableName, boolean preserveSplits, ProcedurePrepareLatch latch) -
Uses of TableName in org.apache.hadoop.hbase.master.region
-
Uses of TableName in org.apache.hadoop.hbase.master.replication
Modifier and TypeMethodDescriptionReplicationPeerManager.getSerialPeerIdsBelongsTo
(TableName tableName) private boolean
ModifyPeerProcedure.needReopen
(TableStateManager tsm, TableName tn) private boolean
ModifyPeerProcedure.needSetLastPushedSequenceId
(TableStateManager tsm, TableName tn) protected final void
ModifyPeerProcedure.setLastPushedSequenceIdForTable
(MasterProcedureEnv env, TableName tableName, Map<String, Long> lastSeqIds) Modifier and TypeMethodDescriptionprivate void
ReplicationPeerManager.checkNamespacesAndTableCfsConfigConflict
(Set<String> namespaces, Map<TableName, ? extends Collection<String>> tableCfs) Set a namespace in the peer config means that all tables in this namespace will be replicated to the peer cluster. -
Uses of TableName in org.apache.hadoop.hbase.master.snapshot
Modifier and TypeFieldDescriptionprotected final TableName
TakeSnapshotHandler.snapshotTable
private TableName
MasterSnapshotVerifier.tableName
Modifier and TypeFieldDescriptionSnapshotManager.restoreTableToProcIdMap
private final Map<TableName,
SnapshotSentinel> SnapshotManager.snapshotHandlers
Modifier and TypeMethodDescriptionprivate long
SnapshotManager.cloneSnapshot
(org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotDescription reqSnapshot, TableName tableName, org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotDescription snapshot, TableDescriptor snapshotTableDesc, NonceKey nonceKey, boolean restoreAcl, String customSFT) Clone the specified snapshot.private boolean
SnapshotManager.isRestoringTable
(TableName tableName) Verify if the restore of the specified table is in progress.boolean
SnapshotManager.isTableTakingAnySnapshot
(TableName tableName) boolean
SnapshotManager.isTakingSnapshot
(TableName tableName) Check to see if the specified table has a snapshot in progress.private boolean
SnapshotManager.isTakingSnapshot
(TableName tableName, boolean checkProcedure) Check to see if the specified table has a snapshot in progress.private long
SnapshotManager.restoreSnapshot
(org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotDescription reqSnapshot, TableName tableName, org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotDescription snapshot, TableDescriptor snapshotTableDesc, NonceKey nonceKey, boolean restoreAcl) Restore the specified snapshot.void
SnapshotManager.setSnapshotHandlerForTesting
(TableName tableName, SnapshotSentinel handler) Set the handler for the current snapshotModifier and TypeMethodDescriptionprivate void
SnapshotManager.cleanupSentinels
(Map<TableName, SnapshotSentinel> sentinels) Remove the sentinels that are marked as finished and the completion time has exceeded the removal timeout.private SnapshotSentinel
SnapshotManager.removeSentinelIfFinished
(Map<TableName, SnapshotSentinel> sentinels, org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotDescription snapshot) Return the handler if it is currently live and has the same snapshot target name. -
Uses of TableName in org.apache.hadoop.hbase.mob
Modifier and TypeFieldDescriptionprivate static final ConcurrentMap<TableName,
String> ManualMobMaintHFileCleaner.MOB_REGIONS
(package private) static ThreadLocal<org.apache.hbase.thirdparty.com.google.common.collect.SetMultimap<TableName,
String>> DefaultMobStoreCompactor.mobRefSet
Modifier and TypeMethodDescriptionstatic org.apache.hbase.thirdparty.com.google.common.collect.ImmutableSetMultimap.Builder<TableName,
String> MobUtils.deserializeMobFileRefs
(byte[] bytes) Deserialize the set of referenced mob hfiles from store file metadata.MobUtils.getTableName
(Cell cell) Get the table name from when this cell was written into a mob hfile as a TableName.Modifier and TypeMethodDescriptionprivate static void
MobFileCleanupUtil.archiveMobFiles
(org.apache.hadoop.conf.Configuration conf, TableName tableName, Admin admin, byte[] family, List<org.apache.hadoop.fs.Path> storeFiles) Archives the mob files.void
RSMobFileCleanerChore.archiveMobFiles
(org.apache.hadoop.conf.Configuration conf, TableName tableName, byte[] family, List<org.apache.hadoop.fs.Path> storeFiles) Archives the mob files.private static void
MobFileCleanupUtil.checkColumnFamilyDescriptor
(org.apache.hadoop.conf.Configuration conf, TableName table, org.apache.hadoop.fs.FileSystem fs, Admin admin, ColumnFamilyDescriptor hcd, Set<String> regionNames, long maxCreationTimeToArchive) static void
MobUtils.cleanExpiredMobFiles
(org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.conf.Configuration conf, TableName tableName, ColumnFamilyDescriptor columnDescriptor, CacheConfig cacheConfig, long current) Cleans the expired mob files.static void
MobFileCleanupUtil.cleanupObsoleteMobFiles
(org.apache.hadoop.conf.Configuration conf, TableName table, Admin admin) Performs housekeeping file cleaning (called by MOB Cleaner chore)static org.apache.hadoop.fs.Path
MobUtils.getMobFamilyPath
(org.apache.hadoop.conf.Configuration conf, TableName tableName, String familyName) Gets the family dir of the mob files.static RegionInfo
MobUtils.getMobRegionInfo
(TableName tableName) Gets the RegionInfo of the mob files.static org.apache.hadoop.fs.Path
MobUtils.getMobRegionPath
(org.apache.hadoop.conf.Configuration conf, TableName tableName) Gets the region dir of the mob files.static org.apache.hadoop.fs.Path
MobUtils.getMobRegionPath
(org.apache.hadoop.fs.Path rootDir, TableName tableName) Gets the region dir of the mob files under the specified root dir.static org.apache.hadoop.fs.Path
MobUtils.getMobTableDir
(org.apache.hadoop.fs.Path rootDir, TableName tableName) Gets the table dir of the mob files under the qualified HBase root dir.static boolean
MobUtils.isMobRegionName
(TableName tableName, byte[] regionName) Gets whether the current region name follows the pattern of a mob region name.static boolean
MobUtils.removeMobFiles
(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.fs.FileSystem fs, TableName tableName, org.apache.hadoop.fs.Path tableDir, byte[] family, Collection<HStoreFile> storeFiles) Archives the mob files.private void
MobFileCompactionChore.startCompaction
(Admin admin, TableName table, RegionInfo region, byte[] cf) Modifier and TypeMethodDescriptionprivate void
DefaultMobStoreCompactor.calculateMobLengthMap
(org.apache.hbase.thirdparty.com.google.common.collect.SetMultimap<TableName, String> mobRefs) static byte[]
MobUtils.serializeMobFileRefs
(org.apache.hbase.thirdparty.com.google.common.collect.SetMultimap<TableName, String> mobRefSet) Serialize a set of referenced mob hfiles -
Uses of TableName in org.apache.hadoop.hbase.mob.mapreduce
-
Uses of TableName in org.apache.hadoop.hbase.namequeues
Modifier and TypeFieldDescriptionstatic final TableName
WALEventTrackerTableAccessor.WAL_EVENT_TRACKER_TABLE_NAME
WALEventTrackerTableAccessor.WAL_EVENT_TRACKER_TABLE_NAME_STR
table name - can be enabled with config - hbase.regionserver.wal.event.tracker.enabled -
Uses of TableName in org.apache.hadoop.hbase.namespace
Modifier and TypeFieldDescriptionprivate Map<TableName,
AtomicInteger> NamespaceTableAndRegionInfo.tableAndRegionInfo
Modifier and TypeMethodDescriptionNamespaceTableAndRegionInfo.getTables()
Gets the set of table names belonging to namespace.Modifier and TypeMethodDescriptionprivate void
(package private) void
(package private) boolean
NamespaceStateManager.checkAndUpdateNamespaceRegionCount
(TableName name, byte[] regionName, int incr) Check if adding a region violates namespace quota, if not update namespace cache.(package private) void
NamespaceStateManager.checkAndUpdateNamespaceRegionCount
(TableName name, int incr) Check and update region count for an existing table.(package private) void
NamespaceStateManager.checkAndUpdateNamespaceTableCount
(TableName table, int numRegions) void
NamespaceAuditor.checkQuotaToCreateTable
(TableName tName, int regions) Check quota to create table.void
NamespaceAuditor.checkQuotaToUpdateRegion
(TableName tName, int regions) Check and update region count quota for an existing table.private void
NamespaceAuditor.checkTableTypeAndThrowException
(TableName name) (package private) boolean
NamespaceTableAndRegionInfo.containsTable
(TableName tableName) (package private) int
NamespaceTableAndRegionInfo.decrementRegionCountForTable
(TableName tableName, int count) int
NamespaceAuditor.getRegionCountOfTable
(TableName tName) Get region count for table(package private) int
NamespaceTableAndRegionInfo.getRegionCountOfTable
(TableName tableName) (package private) int
NamespaceTableAndRegionInfo.incRegionCountForTable
(TableName tableName, int count) void
NamespaceAuditor.removeFromNamespaceUsage
(TableName tableName) (package private) void
NamespaceStateManager.removeTable
(TableName tableName) (package private) void
NamespaceTableAndRegionInfo.removeTable
(TableName tableName) -
Uses of TableName in org.apache.hadoop.hbase.procedure.flush
-
Uses of TableName in org.apache.hadoop.hbase.quotas
Modifier and TypeFieldDescriptionstatic final TableName
QuotaTableUtil.QUOTA_TABLE_NAME
System table for quotasprivate final TableName
QuotaSettings.tableName
(package private) final TableName
FileArchiverNotifierFactoryImpl.CacheKey.tn
private final TableName
FileArchiverNotifierImpl.tn
Modifier and TypeFieldDescriptionprivate final Map<TableName,
SpaceViolationPolicyEnforcement> ActivePolicyEnforcement.activePolicies
private final ConcurrentMap<TableName,
FileArchiverNotifier> FileArchiverNotifierFactoryImpl.CACHE
private AtomicReference<Map<TableName,
SpaceQuotaSnapshot>> RegionServerSpaceQuotaManager.currentQuotaSnapshots
private final ConcurrentHashMap<TableName,
SpaceViolationPolicyEnforcement> RegionServerSpaceQuotaManager.enforcedPolicies
private final Map<TableName,
SpaceViolationPolicyEnforcement> ActivePolicyEnforcement.locallyCachedPolicies
private final Map<TableName,
SpaceQuotaSnapshot> QuotaObserverChore.readOnlyTableQuotaSnapshots
private final Map<TableName,
SpaceQuotaSnapshot> ActivePolicyEnforcement.snapshots
private Map<TableName,
QuotaLimiter> UserQuotaState.tableLimiters
private MasterQuotaManager.NamedLock<TableName>
MasterQuotaManager.tableLocks
private final ConcurrentHashMap<TableName,
Double> QuotaCache.tableMachineQuotaFactors
private final ConcurrentMap<TableName,
QuotaState> QuotaCache.tableQuotaCache
private final Map<TableName,
SpaceQuotaSnapshot> QuotaObserverChore.tableQuotaSnapshots
private QuotaSnapshotStore<TableName>
QuotaObserverChore.tableSnapshotStore
QuotaObserverChore.TablesWithQuotas.tablesWithNamespaceQuotas
QuotaObserverChore.TablesWithQuotas.tablesWithTableQuotas
Modifier and TypeMethodDescriptionprotected static TableName
QuotaTableUtil.getTableFromRowKey
(byte[] key) QuotaSettings.getTableName()
Modifier and TypeMethodDescription(package private) Map<TableName,
SpaceViolationPolicyEnforcement> RegionServerSpaceQuotaManager.copyActiveEnforcements()
Returns the collection of tables which have quota violation policies enforced on this RegionServer.RegionServerSpaceQuotaManager.copyQuotaSnapshots()
Copies the lastSpaceQuotaSnapshot
s that were recorded.SpaceQuotaRefresherChore.fetchSnapshotsFromQuotaTable()
Reads all quota snapshots from the quota table.static Map<TableName,
QuotaState> QuotaUtil.fetchTableQuotas
(Connection connection, List<Get> gets, Map<TableName, Double> tableMachineFactors) QuotaObserverChore.TablesWithQuotas.filterInsufficientlyReportedTables
(QuotaSnapshotStore<TableName> tableStore) Filters out all tables for which the Master currently doesn't have enough region space reports received from RegionServers yet.RegionServerSpaceQuotaManager.getActivePoliciesAsMap()
Converts a map of table toSpaceViolationPolicyEnforcement
s intoSpaceViolationPolicy
s.(package private) Map<TableName,
SpaceViolationPolicyEnforcement> ActivePolicyEnforcement.getLocallyCachedPolicies()
Returns an unmodifiable version of the policy enforcements that were cached because they are not in violation of their quota.QuotaObserverChore.TablesWithQuotas.getNamespaceQuotaTables()
Returns an unmodifiable view of all tables in namespaces that have namespace quotas.ActivePolicyEnforcement.getPolicies()
Returns an unmodifiable version of the activeSpaceViolationPolicyEnforcement
s.static Map<TableName,
SpaceQuotaSnapshot> QuotaTableUtil.getSnapshots
(Connection conn) Fetches allSpaceQuotaSnapshot
objects from thehbase:quota
table.SnapshotQuotaObserverChore.getSnapshotsFromTables
(Admin admin, Set<TableName> tablesToFetchSnapshotsFrom) Computes a mapping of originatingTableName
to snapshots, when theTableName
exists in the providedSet
.SnapshotQuotaObserverChore.getSnapshotsToComputeSize()
Fetches each table with a quota (table or namespace quota), and then fetch the name of each snapshot which was created from that table.(package private) Map<TableName,
QuotaState> QuotaCache.getTableQuotaCache()
QuotaObserverChore.getTableQuotaSnapshots()
Returns an unmodifiable view over the currentSpaceQuotaSnapshot
objects for each HBase table with a quota defined.QuotaObserverChore.TablesWithQuotas.getTableQuotaTables()
Returns an unmodifiable view of all tables with table quotas.QuotaObserverChore.TablesWithQuotas.getTablesByNamespace()
Returns a view of all tables that reside in a namespace with a namespace quota, grouped by the namespace itself.QuotaTableUtil.getTableSnapshots
(Connection conn) Returns a multimap for all existing table snapshot entries.(package private) QuotaSnapshotStore<TableName>
QuotaObserverChore.getTableSnapshotStore()
Modifier and TypeMethodDescriptionvoid
QuotaObserverChore.TablesWithQuotas.addNamespaceQuotaTable
(TableName tn) Adds a table with a namespace quota.static void
QuotaUtil.addTableQuota
(Connection connection, TableName table, org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Quotas data) void
QuotaObserverChore.TablesWithQuotas.addTableQuotaTable
(TableName tn) Adds a table with a table quota.static void
QuotaUtil.addUserQuota
(Connection connection, String user, TableName table, org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Quotas data) boolean
RegionServerSpaceQuotaManager.areCompactionsDisabled
(TableName tableName) Returns whether or not compactions should be disabled for the giventableName
per a space quota violation policy.org.apache.hadoop.hbase.shaded.protobuf.generated.RegionServerStatusProtos.FileArchiveNotificationRequest
RegionServerSpaceQuotaManager.buildFileArchiveRequest
(TableName tn, Collection<Map.Entry<String, Long>> archivedFiles) Builds the protobuf message to inform the Master of files being archived.void
MasterQuotaManager.checkAndUpdateNamespaceRegionQuota
(TableName tName, int regions) void
MasterQuotaManager.checkNamespaceTableAndRegionQuota
(TableName tName, int regions) SpaceViolationPolicyEnforcementFactory.create
(RegionServerServices rss, TableName tableName, SpaceQuotaSnapshot snapshot) Constructs the appropriateSpaceViolationPolicyEnforcement
for tables that are in violation of their space quota.(package private) static Put
QuotaTableUtil.createPutForSnapshotSize
(TableName tableName, String snapshot, long size) (package private) static Put
QuotaTableUtil.createPutForSpaceSnapshot
(TableName tableName, SpaceQuotaSnapshot snapshot) (package private) static Scan
QuotaTableUtil.createScanForSpaceSnapshotSizes
(TableName table) SpaceViolationPolicyEnforcementFactory.createWithoutViolation
(RegionServerServices rss, TableName tableName, SpaceQuotaSnapshot snapshot) Creates the "default"SpaceViolationPolicyEnforcement
for a table that isn't in violation.static void
QuotaUtil.deleteTableQuota
(Connection connection, TableName table) 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.void
RegionServerSpaceQuotaManager.disableViolationPolicyEnforcement
(TableName tableName) Disables enforcement on any violation policy on the giventableName
.static void
QuotaUtil.enableTableIfNotEnabled
(Connection conn, TableName tableName) Method to enable a table, if not already enabled.void
RegionServerSpaceQuotaManager.enforceViolationPolicy
(TableName tableName, SpaceQuotaSnapshot snapshot) Enforces the given violationPolicy on the given table in this RegionServer.TableQuotaSnapshotStore.filterBySubject
(TableName table) private static List<QuotaSettings>
QuotaSettingsFactory.fromQuotas
(String userName, TableName tableName, String namespace, String regionServer, org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Quotas quotas) (package private) static QuotaSettings
QuotaSettingsFactory.fromSpace
(TableName table, String namespace, org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.SpaceQuota protoQuota) (package private) static SpaceLimitSettings
SpaceLimitSettings.fromSpaceQuota
(TableName tableName, org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.SpaceQuota proto) Constructs aSpaceLimitSettings
from the provided protobuf message and tablename.(package private) static List<QuotaSettings>
QuotaSettingsFactory.fromTableQuotas
(TableName tableName, org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Quotas quotas) static List<ThrottleSettings>
QuotaSettingsFactory.fromTableThrottles
(TableName tableName, org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Throttle throttle) protected static List<ThrottleSettings>
QuotaSettingsFactory.fromThrottle
(String userName, TableName tableName, String namespace, String regionServer, org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Throttle throttle) (package private) static ThrottleSettings
ThrottleSettings.fromTimedQuota
(String userName, TableName tableName, String namespace, String regionServer, ThrottleType type, org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.TimedQuota timedQuota) (package private) static List<QuotaSettings>
QuotaSettingsFactory.fromUserQuotas
(String userName, TableName tableName, org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Quotas quotas) 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.TableQuotaSnapshotStore.getCurrentState
(TableName table) (package private) FileArchiverNotifier
SnapshotQuotaObserverChore.getNotifierForTable
(TableName tn) Returns the correct instance ofFileArchiverNotifier
for the given table name.(package private) int
QuotaObserverChore.TablesWithQuotas.getNumRegions
(TableName table) Computes the total number of regions in a table.(package private) int
QuotaObserverChore.TablesWithQuotas.getNumReportedRegions
(TableName table, QuotaSnapshotStore<TableName> tableStore) Computes the number of regions reported for a table.ActivePolicyEnforcement.getPolicyEnforcement
(TableName tableName) Returns the properSpaceViolationPolicyEnforcement
implementation for the given table.RegionServerRpcQuotaManager.getQuota
(org.apache.hadoop.security.UserGroupInformation ugi, TableName table, int blockSizeBytes) Returns the quota for an operation.(package private) org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Quotas
TableQuotaSnapshotStore.getQuotaForTable
(TableName table) Fetches the table quota.int
MasterQuotaManager.getRegionCountOfTable
(TableName tName) Returns cached region count, or -1 if quota manager is disabled or table status not foundprotected static byte[]
QuotaTableUtil.getSettingsQualifierForUserTable
(TableName tableName) (package private) long
FileArchiverNotifierImpl.getSizeOfStoreFile
(TableName tn, String regionName, String family, String storeFile) Computes the size of the store file given its name, region and family name in the archive directory.(package private) long
FileArchiverNotifierImpl.getSizeOfStoreFile
(TableName tn, FileArchiverNotifierImpl.StoreFileReference storeFileName) Computes the size of the store files for a single region.(package private) long
FileArchiverNotifierImpl.getSizeOfStoreFiles
(TableName tn, Set<FileArchiverNotifierImpl.StoreFileReference> storeFileNames) Computes the size of each store file instoreFileNames
(package private) long
TableQuotaSnapshotStore.getSnapshotSizesForTable
(TableName tn) Fetches any serialized snapshot sizes from the quota table for thetn
provided.org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.SpaceQuota
TableQuotaSnapshotStore.getSpaceQuota
(TableName subject) QuotaCache.getTableLimiter
(TableName table) Returns the limiter associated to the specified table.UserQuotaState.getTableLimiter
(TableName table) Return the limiter for the specified table associated with this quota.static org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Quotas
QuotaTableUtil.getTableQuota
(Connection connection, TableName table) (package private) SpaceQuotaSnapshot
QuotaObserverChore.getTableQuotaSnapshot
(TableName table) Fetches theSpaceQuotaSnapshot
for the given table.protected static byte[]
QuotaTableUtil.getTableRowKey
(TableName table) TableQuotaSnapshotStore.getTargetState
(TableName table, org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.SpaceQuota spaceQuota) QuotaCache.getUserLimiter
(org.apache.hadoop.security.UserGroupInformation ugi, TableName table) Returns the limiter associated to the specified user/table.static org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Quotas
QuotaTableUtil.getUserQuota
(Connection connection, String user, TableName table) boolean
QuotaObserverChore.TablesWithQuotas.hasNamespaceQuota
(TableName tn) Returns true if the table exists in a namespace with a namespace quota.boolean
QuotaObserverChore.TablesWithQuotas.hasTableQuota
(TableName tn) Returns true if the given table has a table quota.void
SpaceViolationPolicyEnforcement.initialize
(RegionServerServices rss, TableName tableName, SpaceQuotaSnapshot snapshot) Initializes this policy instance.private boolean
MasterQuotaManager.isInViolationAndPolicyDisable
(TableName tableName, QuotaObserverChore quotaObserverChore) Method to check if a table is in violation and policy set on table is DISABLE.static QuotaSettings
QuotaSettingsFactory.limitTableSpace
(TableName tableName, long sizeLimit, SpaceViolationPolicy violationPolicy) Creates aQuotaSettings
object to limit the FileSystem space usage for the given table to the given size in bytes.(package private) static Get
QuotaTableUtil.makeGetForSnapshotSize
(TableName tn, String snapshot) Creates aGet
for the HBase snapshot's size against the given table.static Get
QuotaTableUtil.makeGetForTableQuotas
(TableName table) static Get
QuotaTableUtil.makeQuotaSnapshotGetForTable
(TableName tn) Creates aGet
which returns onlySpaceQuotaSnapshot
from the quota table for a specific table.static Scan
QuotaTableUtil.makeQuotaSnapshotScanForTable
(TableName tn) Creates aScan
which returns onlySpaceQuotaSnapshot
from the quota table for a specific table.protected static void
QuotaTableUtil.parseTableResult
(TableName table, Result result, QuotaTableUtil.TableQuotasVisitor visitor) void
MasterQuotasObserver.postDeleteTable
(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName) void
MasterQuotaManager.removeRegionSizesForTable
(TableName tableName) Removes each region size entry where the RegionInfo references the provided TableName.void
MasterQuotaManager.removeTableFromNamespaceQuota
(TableName tName) Remove table from namespace quota.static QuotaSettings
QuotaSettingsFactory.removeTableSpaceLimit
(TableName tableName) Creates aQuotaSettings
object to remove the FileSystem space quota for the given table.void
TableQuotaSnapshotStore.setCurrentState
(TableName table, SpaceQuotaSnapshot snapshot) void
UserQuotaState.setQuotas
(TableName table, org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Quotas quotas) Add the quota information of the specified table.void
MasterQuotaManager.setTableQuota
(TableName table, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.SetQuotaRequest req) (package private) void
QuotaObserverChore.setTableQuotaSnapshot
(TableName table, SpaceQuotaSnapshot snapshot) Stores the quota state for the given table.void
MasterQuotaManager.setUserQuota
(String userName, TableName table, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.SetQuotaRequest req) private static QuotaSettings
QuotaSettingsFactory.throttle
(String userName, TableName tableName, String namespace, String regionServer, ThrottleType type, long limit, TimeUnit timeUnit, QuotaScope scope) static QuotaSettings
QuotaSettingsFactory.throttleTable
(TableName tableName, ThrottleType type, long limit, TimeUnit timeUnit) Throttle the specified table.static QuotaSettings
QuotaSettingsFactory.throttleTable
(TableName tableName, ThrottleType type, long limit, TimeUnit timeUnit, QuotaScope scope) Throttle the specified table.static QuotaSettings
QuotaSettingsFactory.throttleUser
(String userName, TableName tableName, ThrottleType type, long limit, TimeUnit timeUnit) Throttle the specified user on the specified table.static QuotaSettings
QuotaSettingsFactory.throttleUser
(String userName, TableName tableName, ThrottleType type, long limit, TimeUnit timeUnit, QuotaScope scope) Throttle the specified user on the specified table.void
SpaceQuotaSnapshotNotifier.transitionTable
(TableName tableName, SpaceQuotaSnapshot snapshot) Informs the cluster of the current state of a space quota for a table.void
TableSpaceQuotaSnapshotNotifier.transitionTable
(TableName tableName, SpaceQuotaSnapshot snapshot) static QuotaSettings
QuotaSettingsFactory.unthrottleTable
(TableName tableName) Remove the throttling for the specified table.static QuotaSettings
QuotaSettingsFactory.unthrottleTableByThrottleType
(TableName tableName, ThrottleType type) Remove the throttling for the specified table.static QuotaSettings
QuotaSettingsFactory.unthrottleUser
(String userName, TableName tableName) Remove the throttling for the specified user on the specified table.static QuotaSettings
QuotaSettingsFactory.unthrottleUserByThrottleType
(String userName, TableName tableName, ThrottleType type) Remove the throttling for the specified user on the specified table.(package private) void
QuotaObserverChore.updateTableQuota
(TableName table, SpaceQuotaSnapshot currentSnapshot, SpaceQuotaSnapshot targetSnapshot) Updates the hbase:quota table with the new quota policy for thistable
if necessary.void
QuotaTableUtil.TableQuotasVisitor.visitTableQuotas
(TableName tableName, org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Quotas quotas) void
QuotaTableUtil.UserQuotasVisitor.visitUserQuotas
(String userName, TableName table, org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Quotas quotas) Modifier and TypeMethodDescriptionSnapshotQuotaObserverChore.computeSnapshotSizes
(org.apache.hbase.thirdparty.com.google.common.collect.Multimap<TableName, String> snapshotsToComputeSize) Computes the size of each snapshot provided given the current files referenced by the table.QuotaTableUtil.createDeletesForExistingTableSnapshotSizes
(org.apache.hbase.thirdparty.com.google.common.collect.Multimap<TableName, String> snapshotEntriesToRemove) Returns a list ofDelete
to remove given table snapshot entries to remove from quota tablestatic void
QuotaTableUtil.extractQuotaSnapshot
(Result result, Map<TableName, SpaceQuotaSnapshot> snapshots) Extracts theSpaceViolationPolicy
andTableName
from the providedResult
and adds them to the givenMap
.(package private) void
SpaceQuotaRefresherChore.extractQuotaSnapshot
(Result result, Map<TableName, SpaceQuotaSnapshot> snapshots) Wrapper aroundQuotaTableUtil.extractQuotaSnapshot(Result, Map)
for testing.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) QuotaObserverChore.TablesWithQuotas.filterInsufficientlyReportedTables
(QuotaSnapshotStore<TableName> tableStore) Filters out all tables for which the Master currently doesn't have enough region space reports received from RegionServers yet.(package private) int
QuotaObserverChore.TablesWithQuotas.getNumReportedRegions
(TableName table, QuotaSnapshotStore<TableName> tableStore) Computes the number of regions reported for a table.SnapshotQuotaObserverChore.getSnapshotsFromTables
(Admin admin, Set<TableName> tablesToFetchSnapshotsFrom) Computes a mapping of originatingTableName
to snapshots, when theTableName
exists in the providedSet
.static Get
QuotaTableUtil.makeGetForUserQuotas
(String user, Iterable<TableName> tables, Iterable<String> namespaces) (package private) void
QuotaObserverChore.processNamespacesWithQuotas
(Set<String> namespacesWithQuotas, org.apache.hbase.thirdparty.com.google.common.collect.Multimap<String, TableName> tablesByNamespace) Processes each namespace which has a quota defined and moves all of the tables contained in that namespace into or out of violation of the quota.(package private) void
QuotaObserverChore.processTablesWithQuotas
(Set<TableName> tablesWithTableQuotas) Processes eachTableName
which has a quota defined and moves it in or out of violation based on the space use.(package private) void
SnapshotQuotaObserverChore.pruneNamespaceSnapshots
(org.apache.hbase.thirdparty.com.google.common.collect.Multimap<TableName, String> snapshotsToComputeSize) Removes the snapshot entries that are present in Quota table but not in snapshotsToComputeSize(package private) void
SnapshotQuotaObserverChore.pruneTableSnapshots
(org.apache.hbase.thirdparty.com.google.common.collect.Multimap<TableName, String> snapshotsToComputeSize) Removes the snapshot entries that are present in Quota table but not in snapshotsToComputeSize(package private) void
SnapshotQuotaObserverChore.removeExistingTableSnapshotSizes
(org.apache.hbase.thirdparty.com.google.common.collect.Multimap<TableName, String> snapshotEntriesToRemove) (package private) void
QuotaObserverChore.updateNamespaceQuota
(String namespace, SpaceQuotaSnapshot currentSnapshot, SpaceQuotaSnapshot targetSnapshot, org.apache.hbase.thirdparty.com.google.common.collect.Multimap<String, TableName> tablesByNamespace) Updates the hbase:quota table with the target quota policy for thisnamespace
if necessary.void
RegionServerSpaceQuotaManager.updateQuotaSnapshot
(Map<TableName, SpaceQuotaSnapshot> newSnapshots) Updates the currentSpaceQuotaSnapshot
s for the RegionServer.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) protected
GlobalQuotaSettings
(String userName, TableName tableName, String namespace, String regionServer) protected
GlobalQuotaSettingsImpl
(String username, TableName tableName, String namespace, String regionServer, org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Quotas quotas) protected
GlobalQuotaSettingsImpl
(String userName, TableName tableName, String namespace, String regionServer, org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Throttle throttleProto, Boolean bypassGlobals, org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.SpaceQuota spaceProto) (package private)
QuotaGlobalsSettingsBypass
(String userName, TableName tableName, String namespace, String regionServer, boolean bypassGlobals) protected
QuotaSettings
(String userName, TableName tableName, String namespace, String regionServer) (package private)
SpaceLimitSettings
(TableName tableName) Constructs aSpaceLimitSettings
to remove a space quota on the giventableName
.(package private)
SpaceLimitSettings
(TableName tableName, long sizeLimit, SpaceViolationPolicy violationPolicy) (package private)
SpaceLimitSettings
(TableName tableName, String namespace, org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.SpaceLimitRequest req) (package private)
ThrottleSettings
(String userName, TableName tableName, String namespace, String regionServer, org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.ThrottleRequest proto) ModifierConstructorDescriptionActivePolicyEnforcement
(Map<TableName, SpaceViolationPolicyEnforcement> activePolicies, Map<TableName, SpaceQuotaSnapshot> snapshots, RegionServerServices rss) ActivePolicyEnforcement
(Map<TableName, SpaceViolationPolicyEnforcement> activePolicies, Map<TableName, SpaceQuotaSnapshot> snapshots, RegionServerServices rss, SpaceViolationPolicyEnforcementFactory factory) -
Uses of TableName in org.apache.hadoop.hbase.quotas.policies
Modifier and TypeFieldDescription(package private) TableName
AbstractViolationPolicyEnforcement.tableName
Modifier and TypeMethodDescriptionvoid
AbstractViolationPolicyEnforcement.initialize
(RegionServerServices rss, TableName tableName, SpaceQuotaSnapshot snapshot) void
AbstractViolationPolicyEnforcement.setTableName
(TableName tableName) -
Uses of TableName in org.apache.hadoop.hbase.regionserver
Modifier and TypeMethodDescriptionHStore.getTableName()
Store.getTableName()
StoreContext.getTableName()
Modifier and TypeMethodDescriptionHRegionServer.getOnlineTables()
Gets the online tables in this RS.Modifier and TypeMethodDescriptionprivate org.apache.hadoop.fs.Path
SecureBulkLoadManager.createStagingDir
(org.apache.hadoop.fs.Path baseDir, User user, TableName tableName) List<org.apache.hadoop.fs.Path>
HMobStore.getLocations
(TableName tableName) HRegionServer.getRegions
(TableName tableName) Gets the online regions of the specified table.OnlineRegions.getRegions
(TableName tableName) Get all online regions of a table in this RS.boolean
HRegionServer.reportFileArchivalForQuotas
(TableName tableName, Collection<Map.Entry<String, Long>> archivedFiles) boolean
RegionServerServices.reportFileArchivalForQuotas
(TableName tableName, Collection<Map.Entry<String, Long>> archivedFiles) Reports a collection of files, and their sizes, that belonged to the giventable
were just moved to the archive directory.Modifier and TypeMethodDescriptionvoid
StoreFileWriter.appendMobMetadata
(org.apache.hbase.thirdparty.com.google.common.collect.SetMultimap<TableName, String> mobRefSet) Appends MOB - specific metadata (even if it is empty)private void
RSRpcServices.executeOpenRegionProcedures
(org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.OpenRegionRequest request, Map<TableName, TableDescriptor> tdCache) -
Uses of TableName in org.apache.hadoop.hbase.regionserver.metrics
Modifier and TypeMethodDescriptionprivate void
private static String
MetricsTableRequests.qualifyMetrics
(String prefix, TableName tableName) ModifierConstructorDescriptionMetricsTableRequests
(TableName tableName, org.apache.hadoop.conf.Configuration conf) -
Uses of TableName in org.apache.hadoop.hbase.regionserver.storefiletracker
ModifierConstructorDescriptionInitializeStoreFileTrackerProcedure
(MasterProcedureEnv env, TableName tableName) ModifyColumnFamilyStoreFileTrackerProcedure
(MasterProcedureEnv env, TableName tableName, byte[] family, String dstSFT) protected
ModifyStoreFileTrackerProcedure
(MasterProcedureEnv env, TableName tableName, String dstSFT) ModifyTableStoreFileTrackerProcedure
(MasterProcedureEnv env, TableName tableName, String dstSFT) -
Uses of TableName in org.apache.hadoop.hbase.regionserver.wal
Modifier and TypeFieldDescriptionprivate final ConcurrentMap<TableName,
MutableFastCounter> MetricsWALSourceImpl.perTableAppendCount
private final ConcurrentMap<TableName,
MutableFastCounter> MetricsWALSourceImpl.perTableAppendSize
Modifier and TypeMethodDescriptionvoid
MetricsWALSource.incrementAppendCount
(TableName tableName) Increment the count of wal appendsvoid
MetricsWALSourceImpl.incrementAppendCount
(TableName tableName) void
MetricsWALSource.incrementAppendSize
(TableName tableName, long size) Add the append size.void
MetricsWALSourceImpl.incrementAppendSize
(TableName tableName, long size) -
Uses of TableName in org.apache.hadoop.hbase.replication
Modifier and TypeFieldDescriptionprivate Map<TableName,
? extends Collection<String>> ReplicationPeerConfig.excludeTableCFsMap
ReplicationPeerConfig.ReplicationPeerConfigBuilderImpl.excludeTableCFsMap
ReplicationPeerConfig.ReplicationPeerConfigBuilderImpl.tableCFsMap
private Map<TableName,
? extends Collection<String>> ReplicationPeerConfig.tableCFsMap
Modifier and TypeMethodDescriptionReplicationPeerConfig.getExcludeTableCFsMap()
ReplicationPeer.getTableCFs()
Get replicable (table, cf-list) map of this peerReplicationPeerImpl.getTableCFs()
Get replicable (table, cf-list) map of this peerReplicationPeerConfig.getTableCFsMap()
ReplicationPeerConfig.unmodifiableTableCFsMap
(Map<TableName, List<String>> tableCFsMap) Modifier and TypeMethodDescriptionstatic boolean
ReplicationUtils.contains
(ReplicationPeerConfig peerConfig, TableName tableName) Deprecated.Will be removed in HBase 3.boolean
ReplicationPeerConfig.needToReplicate
(TableName table) Decide whether the table need replicate to the peer clusterboolean
ReplicationPeerConfig.needToReplicate
(TableName table, byte[] family) Decide whether the passed family of the table need replicate to the peer cluster according to this peer config.Modifier and TypeMethodDescriptionprivate static boolean
ReplicationUtils.isTableCFsEqual
(Map<TableName, List<String>> tableCFs1, Map<TableName, List<String>> tableCFs2) ReplicationPeerConfig.ReplicationPeerConfigBuilderImpl.setExcludeTableCFsMap
(Map<TableName, List<String>> excludeTableCFsMap) ReplicationPeerConfig.setExcludeTableCFsMap
(Map<TableName, ? extends Collection<String>> tableCFsMap) Deprecated.as release of 2.0.0, and it will be removed in 3.0.0.ReplicationPeerConfigBuilder.setExcludeTableCFsMap
(Map<TableName, List<String>> tableCFsMap) Sets the mapping of table name to column families which should not be replicated.ReplicationPeerConfig.ReplicationPeerConfigBuilderImpl.setTableCFsMap
(Map<TableName, List<String>> tableCFsMap) ReplicationPeerConfig.setTableCFsMap
(Map<TableName, ? extends Collection<String>> tableCFsMap) Deprecated.as release of 2.0.0, and it will be removed in 3.0.0.ReplicationPeerConfigBuilder.setTableCFsMap
(Map<TableName, List<String>> tableCFsMap) Sets an explicit map of tables and column families in those tables that should be replicated to the given peer.ReplicationPeerConfig.unmodifiableTableCFsMap
(Map<TableName, List<String>> tableCFsMap) -
Uses of TableName in org.apache.hadoop.hbase.replication.master
Modifier and TypeFieldDescriptionstatic final TableName
ReplicationSinkTrackerTableCreator.REPLICATION_SINK_TRACKER_TABLE_NAME
ReplicationSinkTrackerTableCreator.REPLICATION_SINK_TRACKER_TABLE_NAME_STR
table name - can be enabled with config - hbase.regionserver.replication.sink.tracker.enabled -
Uses of TableName in org.apache.hadoop.hbase.replication.regionserver
Modifier and TypeFieldDescriptionRegionReplicaReplicationEndpoint.RegionReplicaSinkWriter.disabledAndDroppedTables
RegionReplicaReplicationEndpoint.RegionReplicaOutputSink.memstoreReplicationEnabled
Modifier and TypeMethodDescriptionvoid
ReplicationSource.addHFileRefs
(TableName tableName, byte[] family, List<Pair<org.apache.hadoop.fs.Path, org.apache.hadoop.fs.Path>> pairs) void
ReplicationSourceInterface.addHFileRefs
(TableName tableName, byte[] family, List<Pair<org.apache.hadoop.fs.Path, org.apache.hadoop.fs.Path>> pairs) Add hfile names to the queue to be replicated.void
ReplicationSourceManager.addHFileRefs
(TableName tableName, byte[] family, List<Pair<org.apache.hadoop.fs.Path, org.apache.hadoop.fs.Path>> pairs) (package private) void
Replication.addHFileRefsToQueue
(TableName tableName, byte[] family, List<Pair<org.apache.hadoop.fs.Path, org.apache.hadoop.fs.Path>> pairs) void
RegionReplicaReplicationEndpoint.RegionReplicaSinkWriter.append
(TableName tableName, byte[] encodedRegionName, byte[] row, List<WAL.Entry> entries) private void
ReplicationSink.batch
(TableName tableName, Collection<List<Row>> allRows, int batchRowSizeThreshold) Do the changes and handle the poolprivate void
ReplicationSink.buildBulkLoadHFileMap
(Map<String, List<Pair<byte[], List<String>>>> bulkLoadHFileMap, TableName table, org.apache.hadoop.hbase.shaded.protobuf.generated.WALProtos.BulkLoadDescriptor bld) private org.apache.hadoop.fs.Path
HFileReplicator.createStagingDir
(org.apache.hadoop.fs.Path baseDir, User user, TableName tableName) boolean
private String
ReplicationSink.getHFilePath
(TableName table, org.apache.hadoop.hbase.shaded.protobuf.generated.WALProtos.BulkLoadDescriptor bld, String storeFile, byte[] family) private boolean
RegionReplicaReplicationEndpoint.RegionReplicaOutputSink.requiresReplication
(TableName tableName, List<WAL.Entry> entries) returns true if the specified entry must be replicated.ModifierConstructorDescriptionRegionReplicaReplayCallable
(ClusterConnection connection, RpcControllerFactory rpcControllerFactory, TableName tableName, HRegionLocation location, RegionInfo regionInfo, byte[] row, List<WAL.Entry> entries, AtomicLong skippedEntries) -
Uses of TableName in org.apache.hadoop.hbase.rest
Modifier and TypeMethodDescriptionprivate org.apache.hbase.thirdparty.javax.ws.rs.core.Response
SchemaResource.replace
(TableName name, TableSchemaModel model, org.apache.hbase.thirdparty.javax.ws.rs.core.UriInfo uriInfo, Admin admin) private org.apache.hbase.thirdparty.javax.ws.rs.core.Response
SchemaResource.update
(TableName name, TableSchemaModel model, org.apache.hbase.thirdparty.javax.ws.rs.core.UriInfo uriInfo, Admin admin) -
Uses of TableName in org.apache.hadoop.hbase.rsgroup
Modifier and TypeMethodDescriptionprivate Pair<Map<TableName,
Map<ServerName, List<RegionInfo>>>, List<RegionPlan>> RSGroupBasedLoadBalancer.correctAssignments
(Map<TableName, Map<ServerName, List<RegionInfo>>> existingAssignments) RSGroupInfoManagerImpl.flushConfigTable
(Map<String, RSGroupInfo> groupMap) (package private) Map<TableName,
Map<ServerName, List<RegionInfo>>> RSGroupAdminServer.getRSGroupAssignmentsByTable
(TableStateManager tableStateManager, String groupName) This is an EXPENSIVE clone.RSGroupInfo.getTables()
Get set of tables that are members of the group.Modifier and TypeMethodDescriptionvoid
boolean
RSGroupInfo.containsTable
(TableName table) RSGroupInfoManager.determineRSGroupInfoForTable
(TableName tableName) DetermineRSGroupInfo
for the given table.RSGroupInfoManagerImpl.determineRSGroupInfoForTable
(TableName tableName) Will try to get the rsgroup fromtableMap
first then try to get the rsgroup fromscript
try to get the rsgroup from theNamespaceDescriptor
lastly.RSGroupAdmin.getRSGroupInfoOfTable
(TableName tableName) GetsRSGroupInfo
for the given table's group.RSGroupAdminClient.getRSGroupInfoOfTable
(TableName tableName) RSGroupAdminServer.getRSGroupInfoOfTable
(TableName tableName) RSGroupInfoManager.getRSGroupOfTable
(TableName tableName) Get the group membership of a tableRSGroupInfoManagerImpl.getRSGroupOfTable
(TableName tableName) void
RSGroupAdminEndpoint.postCompletedModifyTableAction
(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName, TableDescriptor oldDescriptor, TableDescriptor currentDescriptor) void
RSGroupAdminEndpoint.postDeleteTable
(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName) void
RSGroupAdminEndpoint.preModifyTableAction
(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName, TableDescriptor currentDescriptor, TableDescriptor newDescriptor) boolean
RSGroupInfo.removeTable
(TableName table) Modifier and TypeMethodDescriptionvoid
RSGroupInfo.addAllTables
(Collection<TableName> arg) RSGroupBasedLoadBalancer.balanceCluster
(Map<TableName, Map<ServerName, List<RegionInfo>>> loadOfAllTable) Balance by RSGroup.private Pair<Map<TableName,
Map<ServerName, List<RegionInfo>>>, List<RegionPlan>> RSGroupBasedLoadBalancer.correctAssignments
(Map<TableName, Map<ServerName, List<RegionInfo>>> existingAssignments) (package private) void
RSGroupAdminServer.modifyOrMoveTables
(Set<TableName> tables, RSGroupInfo targetGroup) private void
RSGroupAdminServer.moveTableRegionsToGroup
(Set<TableName> tables, RSGroupInfo targetGrp) Moves regions of tables which are not on target group servers.void
RSGroupAdmin.moveTables
(Set<TableName> tables, String targetGroup) Move given set of tables to the specified target RegionServer group.void
RSGroupAdminClient.moveTables
(Set<TableName> tables, String targetGroup) void
RSGroupAdminServer.moveTables
(Set<TableName> tables, String targetGroup) void
RSGroupInfoManager.moveTables
(Set<TableName> tableNames, String groupName) Set the group membership of a set of tablesvoid
RSGroupInfoManagerImpl.moveTables
(Set<TableName> tableNames, String groupName) void
RSGroupBasedLoadBalancer.updateBalancerLoadInfo
(Map<TableName, Map<ServerName, List<RegionInfo>>> loadOfAllTable) -
Uses of TableName in org.apache.hadoop.hbase.security.access
Modifier and TypeFieldDescriptionstatic final TableName
AccessControlClient.ACL_TABLE_NAME
static final TableName
PermissionStorage.ACL_TABLE_NAME
Internal storage table for access control listsprivate TableName
AccessControlFilter.table
private final TableName
AuthResult.table
private TableName
TablePermission.table
private TableName
AuthResult.Params.tableName
private TableName
GetUserPermissionsRequest.Builder.tableName
private TableName
GetUserPermissionsRequest.tableName
private TableName
Permission.Builder.tableName
Modifier and TypeFieldDescriptionprivate Map<TableName,
List<UserPermission>> AccessController.tableAcls
AuthManager.tableCache
Cache for table permission.Modifier and TypeMethodDescriptionprivate TableName
AccessController.getTableName
(RegionCoprocessorEnvironment e) private TableName
AccessController.getTableName
(Region region) AuthResult.getTableName()
GetUserPermissionsRequest.getTableName()
TablePermission.getTableName()
static TableName
ShadedAccessControlUtil.toTableName
(org.apache.hadoop.hbase.shaded.protobuf.generated.HBaseProtos.TableName tableNamePB) Modifier and TypeMethodDescriptionSnapshotScannerHDFSAclController.SnapshotScannerHDFSAclStorage.getUserNamespaceAndTable
(Table aclTable, String userName) Modifier and TypeMethodDescriptionboolean
AuthManager.accessUserTable
(User user, TableName table, Permission.Action action) Checks if the user has access to the full table or at least a family/qualifier for the specified action.boolean
SnapshotScannerHDFSAclHelper.addTableAcl
(TableName tableName, Set<String> users, String operation) Add table user acls(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.addUserTableHdfsAcl
(Table aclTable, String user, TableName tableName) static AuthResult
AuthResult.allow
(String request, String reason, User user, Permission.Action action, TableName table, byte[] family, byte[] qualifier) static AuthResult
AuthResult.allow
(String request, String reason, User user, Permission.Action action, TableName table, Map<byte[], ? extends Collection<?>> families) boolean
AuthManager.authorizeCell
(User user, TableName table, Cell cell, Permission.Action action) Check if user has given action privilige in cell scope.private boolean
AuthManager.authorizeFamily
(Set<TablePermission> permissions, TableName table, byte[] family, Permission.Action action) private boolean
AuthManager.authorizeTable
(Set<TablePermission> permissions, TableName table, byte[] family, byte[] qualifier, Permission.Action action) boolean
AuthManager.authorizeUserFamily
(User user, TableName table, byte[] family, Permission.Action action) Check if user has given action privilige in table:family scope.boolean
AuthManager.authorizeUserTable
(User user, TableName table, byte[] family, byte[] qualifier, Permission.Action action) Check if user has given action privilige in table:family:qualifier scope.boolean
AuthManager.authorizeUserTable
(User user, TableName table, byte[] family, Permission.Action action) Check if user has given action privilige in table:family scope.boolean
AuthManager.authorizeUserTable
(User user, TableName table, Permission.Action action) Check if user has given action privilige in table scope.static org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantRequest
AccessControlUtil.buildGrantRequest
(String username, TableName tableName, byte[] family, byte[] qualifier, boolean mergeExistingPermissions, org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission.Action... actions) Create a request to grant user table permissions.static org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeRequest
AccessControlUtil.buildRevokeRequest
(String username, TableName tableName, byte[] family, byte[] qualifier, org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission.Action... actions) Create a request to revoke user table permissions.void
AccessChecker.checkLockPermissions
(User user, String namespace, TableName tableName, RegionInfo[] regionInfos, String reason) void
AccessController.checkLockPermissions
(ObserverContext<?> ctx, String namespace, TableName tableName, RegionInfo[] regionInfos, String reason) void
NoopAccessChecker.checkLockPermissions
(User user, String namespace, TableName tableName, RegionInfo[] regionInfos, String reason) (package private) void
SnapshotScannerHDFSAclHelper.createTableDirectories
(TableName tableName) void
ZKPermissionWatcher.deleteTableACLNode
(TableName tableName) Delete the acl notify node of table(package private) static void
SnapshotScannerHDFSAclController.SnapshotScannerHDFSAclStorage.deleteTableHdfsAcl
(Table aclTable, TableName tableName) (package private) static void
SnapshotScannerHDFSAclController.SnapshotScannerHDFSAclStorage.deleteUserTableHdfsAcl
(Connection connection, Set<String> users, TableName tableName) (package private) static void
SnapshotScannerHDFSAclController.SnapshotScannerHDFSAclStorage.deleteUserTableHdfsAcl
(Table aclTable, String user, TableName tableName) static AuthResult
AuthResult.deny
(String request, String reason, User user, Permission.Action action, TableName table, byte[] family, byte[] qualifier) static AuthResult
AuthResult.deny
(String request, String reason, User user, Permission.Action action, TableName table, Map<byte[], ? extends Collection<?>> families) private boolean
TablePermission.failCheckTable
(TableName table) SnapshotScannerHDFSAclController.filterUsersToRemoveNsAccessAcl
(Table aclTable, TableName tableName, Set<String> tablesUsers) Remove table user access HDFS acl from namespace directory if the user has no permissions of global, ns of the table or other tables of the ns, eg: Bob has 'ns1:t1' read permission, when delete 'ns1:t1', if Bob has global read permission, '@ns1' read permission or 'ns1:other_tables' read permission, then skip remove Bob access acl in ns1Dirs, otherwise, remove Bob access acl.(package private) org.apache.hadoop.fs.Path
SnapshotScannerHDFSAclHelper.PathHelper.getArchiveTableDir
(TableName tableName) (package private) org.apache.hadoop.fs.Path
SnapshotScannerHDFSAclHelper.PathHelper.getDataTableDir
(TableName tableName) (package private) org.apache.hadoop.fs.Path
SnapshotScannerHDFSAclHelper.PathHelper.getMobTableDir
(TableName tableName) static org.apache.hbase.thirdparty.com.google.common.collect.ListMultimap<String,
UserPermission> PermissionStorage.getTablePermissions
(org.apache.hadoop.conf.Configuration conf, TableName tableName) (package private) List<org.apache.hadoop.fs.Path>
SnapshotScannerHDFSAclHelper.getTableRootPaths
(TableName tableName, boolean includeSnapshotPath) return paths that user will table permission will visitprivate List<org.apache.hadoop.fs.Path>
SnapshotScannerHDFSAclHelper.getTableSnapshotPaths
(TableName tableName) SnapshotScannerHDFSAclController.SnapshotScannerHDFSAclStorage.getTableUsers
(Table aclTable, TableName tableName) (package private) org.apache.hadoop.fs.Path
SnapshotScannerHDFSAclHelper.PathHelper.getTmpTableDir
(TableName tableName) static List<UserPermission>
AccessControlUtil.getUserPermissions
(com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.AccessControlService.BlockingInterface protocol, TableName t) Deprecated.UseAdmin.getUserPermissions(GetUserPermissionsRequest)
instead.static List<UserPermission>
AccessControlUtil.getUserPermissions
(com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.AccessControlService.BlockingInterface protocol, TableName t, byte[] columnFamily, byte[] columnQualifier, String userName) Deprecated.UseAdmin.getUserPermissions(GetUserPermissionsRequest)
instead.SnapshotScannerHDFSAclHelper.getUsersWithTableReadAction
(TableName tableName, boolean includeNamespace, boolean includeGlobal) Return users with table read permissionprivate UserPermission
SnapshotScannerHDFSAclController.getUserTablePermission
(org.apache.hadoop.conf.Configuration conf, String userName, TableName tableName) static List<UserPermission>
PermissionStorage.getUserTablePermissions
(org.apache.hadoop.conf.Configuration conf, TableName tableName, byte[] cf, byte[] cq, String userName, boolean hasFilterUser) Returns the currently granted permissions for a given table as the specified user plus associated permissions.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 void
AccessControlUtil.grant
(com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.AccessControlService.BlockingInterface protocol, String userShortName, TableName tableName, byte[] f, byte[] q, boolean mergeExistingPermissions, Permission.Action... actions) Deprecated.UseAdmin.grant(UserPermission, boolean)
instead.static boolean
AccessControlUtil.hasPermission
(com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.AccessControlService.BlockingInterface protocol, TableName tableName, byte[] columnFamily, byte[] columnQualifier, String userName, Permission.Action[] actions) Deprecated.UseAdmin.hasUserPermissions(String, List)
instead.(package private) static boolean
SnapshotScannerHDFSAclController.SnapshotScannerHDFSAclStorage.hasUserTableHdfsAcl
(Table aclTable, String user, TableName tableName) boolean
TablePermission.implies
(TableName table, byte[] family, byte[] qualifier, Permission.Action action) Check if given action can performs on given table:family:qualifier.boolean
TablePermission.implies
(TableName table, byte[] family, Permission.Action action) Check if given action can performs on given table:family.boolean
TablePermission.implies
(TableName table, KeyValue kv, Permission.Action action) Checks if this permission grants access to perform the given action on the given table and key value.private boolean
SnapshotScannerHDFSAclController.isHdfsAclSet
(Table aclTable, String userName, String namespace, TableName tableName) Check if user global/namespace/table HDFS acls is already setprivate boolean
SnapshotScannerHDFSAclController.isHdfsAclSet
(Table aclTable, String userName, TableName tableName) private boolean
SnapshotScannerHDFSAclController.needHandleTableHdfsAcl
(TableName tableName, String operation) GetUserPermissionsRequest.newBuilder
(TableName tableName) Build a get table permission requeststatic Permission.Builder
Permission.newBuilder
(TableName tableName) Build a table permissionprivate AuthResult
AccessChecker.permissionGranted
(String request, User user, Permission.Action permRequest, TableName tableName, byte[] family, byte[] qualifier) AccessChecker.permissionGranted
(String request, User user, Permission.Action permRequest, TableName tableName, Map<byte[], ? extends Collection<?>> families) Check the current user for authorization to perform a specific action against the given set of row data.NoopAccessChecker.permissionGranted
(String request, User user, Permission.Action permRequest, TableName tableName, Map<byte[], ? extends Collection<?>> families) void
SnapshotScannerHDFSAclController.postCompletedDeleteTableAction
(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName) void
SnapshotScannerHDFSAclController.postCompletedTruncateTableAction
(ObserverContext<MasterCoprocessorEnvironment> c, TableName tableName) void
AccessController.postDeleteTable
(ObserverContext<MasterCoprocessorEnvironment> c, TableName tableName) void
AccessController.postModifyTable
(ObserverContext<MasterCoprocessorEnvironment> c, TableName tableName, TableDescriptor htd) void
SnapshotScannerHDFSAclController.postModifyTable
(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName, TableDescriptor oldDescriptor, TableDescriptor currentDescriptor) void
AccessController.postTruncateTable
(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName) void
AccessController.preDeleteTable
(ObserverContext<MasterCoprocessorEnvironment> c, TableName tableName) void
AccessController.preDisableTable
(ObserverContext<MasterCoprocessorEnvironment> c, TableName tableName) void
AccessController.preEnableTable
(ObserverContext<MasterCoprocessorEnvironment> c, TableName tableName) void
AccessController.preGetUserPermissions
(ObserverContext<MasterCoprocessorEnvironment> ctx, String userName, String namespace, TableName tableName, byte[] family, byte[] qualifier) private void
AccessController.preGetUserPermissions
(User caller, String userName, String namespace, TableName tableName, byte[] family, byte[] qualifier) void
AccessController.preLockHeartbeat
(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName, String description) AccessController.preModifyColumnFamilyStoreFileTracker
(ObserverContext<MasterCoprocessorEnvironment> c, TableName tableName, byte[] family, String dstSFT) AccessController.preModifyTable
(ObserverContext<MasterCoprocessorEnvironment> c, TableName tableName, TableDescriptor currentDesc, TableDescriptor newDesc) CoprocessorWhitelistMasterObserver.preModifyTable
(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName, TableDescriptor currentDesc, TableDescriptor newDesc) AccessController.preModifyTableStoreFileTracker
(ObserverContext<MasterCoprocessorEnvironment> c, TableName tableName, String dstSFT) void
AccessController.preRequestLock
(ObserverContext<MasterCoprocessorEnvironment> ctx, String namespace, TableName tableName, RegionInfo[] regionInfos, String description) void
AccessController.preSetTableQuota
(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName, GlobalQuotaSettings quotas) void
AccessController.preSetUserQuota
(ObserverContext<MasterCoprocessorEnvironment> ctx, String userName, TableName tableName, GlobalQuotaSettings quotas) void
AccessController.preSplitRegion
(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName, byte[] splitRow) void
AccessController.preTableFlush
(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName) void
AccessController.preTruncateTable
(ObserverContext<MasterCoprocessorEnvironment> c, TableName tableName) void
AuthManager.refreshTableCacheFromWritable
(TableName table, byte[] data) Update acl info for table.boolean
SnapshotScannerHDFSAclHelper.removeNamespaceAccessAcl
(TableName tableName, Set<String> removeUsers, String operation) Remove table access acl from namespace dir when delete tablevoid
AuthManager.removeTable
(TableName table) Remove given table from AuthManager's table cache.boolean
SnapshotScannerHDFSAclHelper.removeTableAcl
(TableName tableName, Set<String> users) Remove table acls when modify tableboolean
SnapshotScannerHDFSAclHelper.removeTableDefaultAcl
(TableName tableName, Set<String> removeUsers) Remove default acl from table archive dir when delete table(package private) static void
PermissionStorage.removeTablePermissions
(org.apache.hadoop.conf.Configuration conf, TableName tableName, byte[] column, Table t) Remove specified table column from the acl table.(package private) static void
PermissionStorage.removeTablePermissions
(org.apache.hadoop.conf.Configuration conf, TableName tableName, Table t) Remove specified table from the _acl_ table.private static void
PermissionStorage.removeTablePermissions
(TableName tableName, byte[] column, Table table, boolean closeTable) private void
SnapshotScannerHDFSAclController.removeUserTableHdfsAcl
(Table aclTable, String userName, TableName tableName, UserPermission userPermission) void
AccessChecker.requireAccess
(User user, String request, TableName tableName, Permission.Action... permissions) Authorizes that the current user has any of the given permissions to access the table.void
AccessController.requireAccess
(ObserverContext<?> ctx, String request, TableName tableName, Permission.Action... permissions) void
NoopAccessChecker.requireAccess
(User user, String request, TableName tableName, Permission.Action... permissions) void
AccessChecker.requireGlobalPermission
(User user, String request, Permission.Action perm, TableName tableName, Map<byte[], ? extends Collection<byte[]>> familyMap, String filterUser) Checks that the user has the given global permission.void
AccessController.requireGlobalPermission
(ObserverContext<?> ctx, String request, Permission.Action perm, TableName tableName, Map<byte[], ? extends Collection<byte[]>> familyMap) void
NoopAccessChecker.requireGlobalPermission
(User user, String request, Permission.Action perm, TableName tableName, Map<byte[], ? extends Collection<byte[]>> familyMap, String filterUser) void
AccessChecker.requireNamespacePermission
(User user, String request, String namespace, TableName tableName, Map<byte[], ? extends Collection<byte[]>> familyMap, Permission.Action... permissions) Checks that the user has the given global or namespace permission.void
AccessController.requireNamespacePermission
(ObserverContext<?> ctx, String request, String namespace, TableName tableName, Map<byte[], ? extends Collection<byte[]>> familyMap, Permission.Action... permissions) void
NoopAccessChecker.requireNamespacePermission
(User user, String request, String namespace, TableName tableName, Map<byte[], ? extends Collection<byte[]>> familyMap, Permission.Action... permissions) void
AccessChecker.requirePermission
(User user, String request, TableName tableName, byte[] family, byte[] qualifier, String filterUser, Permission.Action... permissions) Authorizes that the current user has any of the given permissions for the given table, column family and column qualifier.void
AccessController.requirePermission
(ObserverContext<?> ctx, String request, TableName tableName, byte[] family, byte[] qualifier, Permission.Action... permissions) void
NoopAccessChecker.requirePermission
(User user, String request, TableName tableName, byte[] family, byte[] qualifier, String filterUser, Permission.Action... permissions) void
AccessChecker.requireTablePermission
(User user, String request, TableName tableName, byte[] family, byte[] qualifier, Permission.Action... permissions) Authorizes that the current user has any of the given permissions for the given table, column family and column qualifier.void
AccessController.requireTablePermission
(ObserverContext<?> ctx, String request, TableName tableName, byte[] family, byte[] qualifier, Permission.Action... permissions) void
NoopAccessChecker.requireTablePermission
(User user, String request, TableName tableName, byte[] family, byte[] qualifier, Permission.Action... permissions) static void
AccessControlClient.revoke
(Connection connection, TableName tableName, String username, byte[] family, byte[] qualifier, Permission.Action... actions) Revokes the permission on the tablestatic void
AccessControlUtil.revoke
(com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.AccessControlService.BlockingInterface protocol, String userShortName, TableName tableName, byte[] f, byte[] q, Permission.Action... actions) Deprecated.UseAdmin.revoke(UserPermission)
instead.AuthResult.Params.setTableName
(TableName table) private boolean
SnapshotScannerHDFSAclCleaner.tableExists
(TableName tableName) static org.apache.hadoop.hbase.shaded.protobuf.generated.HBaseProtos.TableName
ShadedAccessControlUtil.toProtoTableName
(TableName tableName) private void
AuthManager.updateTableCache
(TableName table, org.apache.hbase.thirdparty.com.google.common.collect.ListMultimap<String, Permission> tablePerms) Updates the internal table permissions cache for specified table.Modifier and TypeMethodDescriptionprivate void
SnapshotScannerHDFSAclHelper.handleTableAcl
(Set<TableName> tableNames, Set<String> users, Set<String> skipNamespaces, Set<TableName> skipTables, SnapshotScannerHDFSAclHelper.HDFSAclOperation.OperationType operationType) void
AccessController.postGetTableDescriptors
(ObserverContext<MasterCoprocessorEnvironment> ctx, List<TableName> tableNamesList, List<TableDescriptor> descriptors, String regex) void
AccessController.preGetTableDescriptors
(ObserverContext<MasterCoprocessorEnvironment> ctx, List<TableName> tableNamesList, List<TableDescriptor> descriptors, String regex) ModifierConstructorDescription(package private)
AccessControlFilter
(AuthManager mgr, User ugi, TableName tableName, AccessControlFilter.Strategy strategy, Map<ByteRange, Integer> cfVsMaxVersions) AuthResult
(boolean allowed, String request, String reason, User user, Permission.Action action, TableName table, byte[] family, byte[] qualifier) AuthResult
(boolean allowed, String request, String reason, User user, Permission.Action action, TableName table, Map<byte[], ? extends Collection<?>> families) private
private
private
GetUserPermissionsRequest
(String userName, String namespace, TableName tableName, byte[] family, byte[] qualifier) (package private)
TablePermission
(TableName table, byte[] family, byte[] qualifier, Permission.Action... assigned) Construct a table:family:qualifier permission. -
Uses of TableName in org.apache.hadoop.hbase.security.visibility
Modifier and TypeFieldDescriptionstatic final TableName
VisibilityConstants.LABELS_TABLE_NAME
Internal storage table for visibility labelsModifier and TypeMethodDescriptionvoid
VisibilityController.preDisableTable
(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName) VisibilityController.preModifyTable
(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName, TableDescriptor currentDescriptor, TableDescriptor newDescriptor) -
Uses of TableName in org.apache.hadoop.hbase.slowlog
Modifier and TypeFieldDescriptionstatic final TableName
SlowLogTableAccessor.SLOW_LOG_TABLE_NAME
hbase:slowlog table name - can be enabled with config - hbase.regionserver.slowlog.systable.enabled -
Uses of TableName in org.apache.hadoop.hbase.snapshot
Modifier and TypeFieldDescriptionprivate final TableName
RestoreSnapshotHelper.snapshotTable
private final TableName
SnapshotInfo.SnapshotStats.snapshotTable
private TableName
CreateSnapshot.tableName
Modifier and TypeMethodDescriptionstatic RegionInfo
RestoreSnapshotHelper.cloneRegionInfo
(TableName tableName, RegionInfo snapshotRegionInfo) private static Pair<org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotFileInfo,
Long> ExportSnapshot.getSnapshotFileAndSize
(org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.conf.Configuration conf, TableName table, String region, String family, String hfile, long size) static void
RestoreSnapshotHelper.restoreSnapshotAcl
(org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotDescription snapshot, TableName newTableName, org.apache.hadoop.conf.Configuration conf) -
Uses of TableName in org.apache.hadoop.hbase.thrift
Modifier and TypeMethodDescriptionprivate static TableName
ThriftHBaseServiceHandler.getTableName
(ByteBuffer buffer) -
Uses of TableName in org.apache.hadoop.hbase.thrift2
Modifier and TypeMethodDescriptionstatic TableName
ThriftUtilities.tableNameFromThrift
(org.apache.hadoop.hbase.thrift2.generated.TTableName tableName) static TableName[]
ThriftUtilities.tableNamesArrayFromThrift
(List<org.apache.hadoop.hbase.thrift2.generated.TTableName> tableNames) Modifier and TypeMethodDescriptionThriftUtilities.tableNamesFromThrift
(List<org.apache.hadoop.hbase.thrift2.generated.TTableName> tableNames) Modifier and TypeMethodDescriptionstatic org.apache.hadoop.hbase.thrift2.generated.TTableName
ThriftUtilities.tableNameFromHBase
(TableName table) static List<org.apache.hadoop.hbase.thrift2.generated.TTableName>
ThriftUtilities.tableNamesFromHBase
(TableName[] in) Modifier and TypeMethodDescriptionstatic List<org.apache.hadoop.hbase.thrift2.generated.TTableName>
ThriftUtilities.tableNamesFromHBase
(List<TableName> in) -
Uses of TableName in org.apache.hadoop.hbase.thrift2.client
Modifier and TypeMethodDescriptionThriftTable.getName()
ThriftAdmin.listTableNames()
ThriftAdmin.listTableNames
(String regex) ThriftAdmin.listTableNames
(String regex, boolean includeSysTables) ThriftAdmin.listTableNames
(Pattern pattern) ThriftAdmin.listTableNames
(Pattern pattern, boolean includeSysTables) ThriftAdmin.listTableNamesByNamespace
(String name) Modifier and TypeMethodDescriptionThriftAdmin.getRegionServerSpaceQuotaSnapshots
(ServerName serverName) ThriftAdmin.getSpaceQuotaTableSizes()
ThriftAdmin.listTableNamesByState
(boolean isEnabled) Modifier and TypeMethodDescriptionvoid
ThriftAdmin.addColumnFamily
(TableName tableName, ColumnFamilyDescriptor columnFamily) ThriftAdmin.addColumnFamilyAsync
(TableName tableName, ColumnFamilyDescriptor columnFamily) ThriftAdmin.clearBlockCache
(TableName tableName) ThriftAdmin.cloneSnapshotAsync
(String snapshotName, TableName tableName, boolean cloneAcl, String customSFT) void
ThriftAdmin.cloneTableSchema
(TableName tableName, TableName newTableName, boolean preserveSplits) void
void
void
ThriftAdmin.compact
(TableName tableName, byte[] columnFamily, CompactType compactType) void
ThriftAdmin.compact
(TableName tableName, CompactType compactType) void
ThriftAdmin.deleteColumn
(TableName tableName, byte[] columnFamily) void
ThriftAdmin.deleteColumnFamily
(TableName tableName, byte[] columnFamily) ThriftAdmin.deleteColumnFamilyAsync
(TableName tableName, byte[] columnFamily) void
ThriftAdmin.deleteTable
(TableName tableName) ThriftAdmin.deleteTableAsync
(TableName tableName) void
ThriftAdmin.disableTable
(TableName tableName) ThriftAdmin.disableTableAsync
(TableName tableName) void
ThriftAdmin.disableTableReplication
(TableName tableName) void
ThriftAdmin.enableTable
(TableName tableName) ThriftAdmin.enableTableAsync
(TableName tableName) void
ThriftAdmin.enableTableReplication
(TableName tableName) void
void
void
ThriftAdmin.flushAsync
(TableName tableName, List<byte[]> columnFamilies) ThriftAdmin.getAlterStatus
(TableName tableName) ThriftConnection.getBufferedMutator
(TableName tableName) ThriftAdmin.getCompactionState
(TableName tableName) ThriftAdmin.getCompactionState
(TableName tableName, CompactType compactType) ThriftAdmin.getCurrentSpaceQuotaSnapshot
(TableName tableName) ThriftAdmin.getDescriptor
(TableName tableName) long
ThriftAdmin.getLastMajorCompactionTimestamp
(TableName tableName) ThriftConnection.getRegionLocator
(TableName tableName) ThriftAdmin.getRegionMetrics
(ServerName serverName, TableName tableName) ThriftAdmin.getRegions
(TableName tableName) ThriftConnection.getTableBuilder
(TableName tableName, ExecutorService pool) Get a TableBuider to build ThriftTable, ThriftTable is NOT thread safeThriftAdmin.getTableDescriptor
(TableName tableName) ThriftAdmin.getTableRegions
(TableName tableName) boolean
ThriftAdmin.isTableAvailable
(TableName tableName) boolean
ThriftAdmin.isTableAvailable
(TableName tableName, byte[][] splitKeys) boolean
ThriftAdmin.isTableDisabled
(TableName tableName) boolean
ThriftAdmin.isTableEnabled
(TableName tableName) void
ThriftAdmin.majorCompact
(TableName tableName) void
ThriftAdmin.majorCompact
(TableName tableName, byte[] columnFamily) void
ThriftAdmin.majorCompact
(TableName tableName, byte[] columnFamily, CompactType compactType) void
ThriftAdmin.majorCompact
(TableName tableName, CompactType compactType) void
ThriftAdmin.modifyColumnFamily
(TableName tableName, ColumnFamilyDescriptor columnFamily) ThriftAdmin.modifyColumnFamilyAsync
(TableName tableName, ColumnFamilyDescriptor columnFamily) ThriftAdmin.modifyColumnFamilyStoreFileTrackerAsync
(TableName tableName, byte[] family, String dstSFT) void
ThriftAdmin.modifyTable
(TableName tableName, TableDescriptor td) ThriftAdmin.modifyTableAsync
(TableName tableName, TableDescriptor td) ThriftAdmin.modifyTableStoreFileTrackerAsync
(TableName tableName, String dstSFT) void
void
void
ThriftAdmin.snapshot
(String snapshotName, TableName tableName, SnapshotType type) void
void
boolean
ThriftAdmin.tableExists
(TableName tableName) void
ThriftAdmin.truncateTable
(TableName tableName, boolean preserveSplits) ThriftAdmin.truncateTableAsync
(TableName tableName, boolean preserveSplits) Modifier and TypeMethodDescriptionThriftAdmin.getTableDescriptorsByTableName
(List<TableName> tableNames) ThriftAdmin.listTableDescriptors
(List<TableName> tableNames) ModifierConstructorDescriptionThriftTable
(TableName tableName, org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client client, org.apache.thrift.transport.TTransport tTransport, org.apache.hadoop.conf.Configuration conf) -
Uses of TableName in org.apache.hadoop.hbase.tool
Modifier and TypeFieldDescriptionstatic final TableName
CanaryTool.DEFAULT_WRITE_TABLE_NAME
private TableName
CanaryTool.RegionTaskResult.tableName
private TableName
CanaryTool.RegionMonitor.writeTableName
Modifier and TypeMethodDescriptionprotected ClientServiceCallable<byte[]>
LoadIncrementalHFiles.buildClientServiceCallable
(Connection conn, TableName tableName, byte[] first, Collection<LoadIncrementalHFiles.LoadQueueItem> lqis, boolean copyFile) Deprecated.BulkLoadHFiles.bulkLoad
(TableName tableName, Map<byte[], List<org.apache.hadoop.fs.Path>> family2Files) Perform a bulk load of the given directory into the given pre-existing table.Perform a bulk load of the given directory into the given pre-existing table.BulkLoadHFilesTool.bulkLoad
(TableName tableName, Map<byte[], List<org.apache.hadoop.fs.Path>> family2Files) private void
LoadIncrementalHFiles.checkRegionIndexValid
(int idx, Pair<byte[][], byte[][]> startEndKeys, TableName tableName) Deprecated.we can consider there is a region hole in following conditions.private void
LoadIncrementalHFiles.createTable
(TableName tableName, org.apache.hadoop.fs.Path hfofDir, Admin admin) Deprecated.If the table is created for the first time, then "completebulkload" reads the files twice.Deprecated.Perform bulk load on the given table.LoadIncrementalHFiles.run
(Map<byte[], List<org.apache.hadoop.fs.Path>> family2Files, TableName tableName) Deprecated.Perform bulk load on the given table.protected final Map<LoadIncrementalHFiles.LoadQueueItem,
ByteBuffer> Deprecated.protected List<LoadIncrementalHFiles.LoadQueueItem>
LoadIncrementalHFiles.tryAtomicRegionLoad
(ClientServiceCallable<byte[]> serviceCallable, TableName tableName, byte[] first, Collection<LoadIncrementalHFiles.LoadQueueItem> lqis) Deprecated.as of release 2.3.0.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.ModifierConstructorDescriptionRegionMonitor
(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) RegionTaskResult
(RegionInfo region, TableName tableName, ServerName serverName, ColumnFamilyDescriptor column) -
Uses of TableName in org.apache.hadoop.hbase.util
Modifier and TypeFieldDescriptionprivate TableName
HBaseFsck.cleanReplicationBarrierTable
Deprecated.(package private) TableName
HbckTableInfo.tableName
Modifier and TypeFieldDescriptionprivate final Map<TableName,
TableDescriptor> FSTableDescriptors.cache
HBaseFsck.orphanTableDirs
Deprecated.HBaseFsck.skippedRegions
Deprecated.HBaseFsck.tablesIncluded
Deprecated.private SortedMap<TableName,
HbckTableInfo> HBaseFsck.tablesInfo
Deprecated.This map from Tablename -> TableInfo contains the structures necessary to detect table consistency problems (holes, dupes, overlaps).private Map<TableName,
TableState> HBaseFsck.tableStates
Deprecated.Modifier and TypeMethodDescriptionHbckTableInfo.getName()
static TableName
CommonFSUtils.getTableName
(org.apache.hadoop.fs.Path tablePath) Returns theTableName
object representing the table directory under path rootdirHbckRegionInfo.getTableName()
static TableName
HFileArchiveUtil.getTableName
(org.apache.hadoop.fs.Path archivePath) Modifier and TypeMethodDescriptionprivate SortedMap<TableName,
HbckTableInfo> HBaseFsck.checkHdfsIntegrity
(boolean fixHoles, boolean fixOverlaps) Deprecated.(package private) SortedMap<TableName,
HbckTableInfo> HBaseFsck.checkIntegrity()
Deprecated.Checks tables integrity.HBaseFsck.getIncludedTables()
Deprecated.private SortedMap<TableName,
HbckTableInfo> HBaseFsck.loadHdfsRegionInfos()
Deprecated.Populate hbi's from regionInfos loaded from file system.static Map<TableName,
TableState.State> ZKDataMigrator.queryForTableStates
(ZKWatcher zkw) Deprecated.Since 2.0.0.Modifier and TypeMethodDescription(package private) static void
RegionSplitter.createPresplitTable
(TableName tableName, RegionSplitter.SplitAlgorithm splitAlgo, String[] columnFamilies, org.apache.hadoop.conf.Configuration conf) private boolean
HBaseFsck.fabricateTableInfo
(FSTableDescriptors fstd, TableName tableName, Set<String> columns) Deprecated.To fabricate a .tableinfo file with following contents
1.Get the current table descriptor for the given table, or null if none exists.static org.apache.hadoop.fs.Path
HFileArchiveUtil.getRegionArchiveDir
(org.apache.hadoop.fs.Path rootDir, TableName tableName, String encodedRegionName) Get the archive directory for a given region under the specified tablestatic org.apache.hadoop.fs.Path
HFileArchiveUtil.getRegionArchiveDir
(org.apache.hadoop.fs.Path rootDir, TableName tableName, org.apache.hadoop.fs.Path regiondir) Get the archive directory for a given region under the specified tablestatic org.apache.hadoop.fs.Path
CommonFSUtils.getRegionDir
(org.apache.hadoop.fs.Path rootdir, TableName tableName, String regionName) Returns thePath
object representing the region directory under path rootdir(package private) static LinkedList<Pair<byte[],
byte[]>> RegionSplitter.getSplits
(Connection connection, TableName tableName, RegionSplitter.SplitAlgorithm splitAlgo) static org.apache.hadoop.fs.Path
HFileArchiveUtil.getStoreArchivePath
(org.apache.hadoop.conf.Configuration conf, TableName tableName, String regionName, String familyName) Get the directory to archive a store directorystatic org.apache.hadoop.fs.Path
HFileArchiveUtil.getTableArchivePath
(org.apache.hadoop.conf.Configuration conf, TableName tableName) Get the path to the table archive directory based on the configured archive directory.static org.apache.hadoop.fs.Path
HFileArchiveUtil.getTableArchivePath
(org.apache.hadoop.fs.Path rootdir, TableName tableName) Get the path to the table archive directory based on the configured archive directory.static TableDescriptor
FSTableDescriptors.getTableDescriptorFromFs
(org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.fs.Path hbaseRootDir, TableName tableName) Returns the latest table descriptor for the given table directly from the file system if it exists, bypassing the local cache.static org.apache.hadoop.fs.Path
CommonFSUtils.getTableDir
(org.apache.hadoop.fs.Path rootdir, TableName tableName) Returns thePath
object representing the table directory under path rootdirprivate org.apache.hadoop.fs.Path
FSTableDescriptors.getTableDir
(TableName tableName) Return the table directory in HDFSprivate static Pair<org.apache.hadoop.fs.Path,
org.apache.hadoop.fs.Path> RegionSplitter.getTableDirAndSplitFile
(org.apache.hadoop.conf.Configuration conf, TableName tableName) private static org.apache.hadoop.hbase.shaded.protobuf.generated.ZooKeeperProtos.DeprecatedTableState.State
ZKDataMigrator.getTableState
(ZKWatcher zkw, TableName tableName) Deprecated.Since 2.0.0.FSUtils.getTableStoreFilePathMap
(Map<String, org.apache.hadoop.fs.Path> map, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.fs.Path hbaseRootDir, TableName tableName) Runs through the HBase rootdir/tablename and creates a reverse lookup map for table StoreFile names to the full Path.FSUtils.getTableStoreFilePathMap
(Map<String, org.apache.hadoop.fs.Path> resultMap, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.fs.Path hbaseRootDir, TableName tableName, org.apache.hadoop.fs.PathFilter sfFilter, ExecutorService executor, FSUtils.ProgressReporter progressReporter) Runs through the HBase rootdir/tablename and creates a reverse lookup map for table StoreFile names to the full Path.FSUtils.getTableStoreFilePathMap
(Map<String, org.apache.hadoop.fs.Path> resultMap, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.fs.Path hbaseRootDir, TableName tableName, org.apache.hadoop.fs.PathFilter sfFilter, ExecutorService executor, HbckErrorReporter progressReporter) Deprecated.Since 2.3.0.static org.apache.hadoop.fs.Path
CommonFSUtils.getWALRegionDir
(org.apache.hadoop.conf.Configuration conf, TableName tableName, String encodedRegionName) Returns the WAL region directory based on the given table name and region namestatic org.apache.hadoop.fs.Path
CommonFSUtils.getWALTableDir
(org.apache.hadoop.conf.Configuration conf, TableName tableName) Returns the Table directory under the WALRootDir for the specified table namestatic org.apache.hadoop.fs.Path
CommonFSUtils.getWrongWALRegionDir
(org.apache.hadoop.conf.Configuration conf, TableName tableName, String encodedRegionName) Deprecated.For compatibility, will be removed in 4.0.0.void
HBaseFsck.includeTable
(TableName table) Deprecated.static boolean
ServerRegionReplicaUtil.isMetaRegionReplicaReplicationEnabled
(org.apache.hadoop.conf.Configuration conf, TableName tn) Returns True if hbase:meta Region Read Replica is enabled.static boolean
ServerRegionReplicaUtil.isRegionReplicaReplicationEnabled
(org.apache.hadoop.conf.Configuration conf, TableName tn) (package private) boolean
HBaseFsck.isTableDisabled
(TableName tableName) Deprecated.Check if the specified region's table is disabled.(package private) boolean
HBaseFsck.isTableIncluded
(TableName table) Deprecated.Only check/fix tables specified by the list, Empty list means all tables are included.<R> void
MultiHConnection.processBatchCallback
(List<? extends Row> actions, TableName tableName, Object[] results, Batch.Callback<R> callback) Randomly pick a connection and process the batch of actions for a given tableRemoves the table descriptor from the local cache and returns it.(package private) static void
RegionSplitter.rollingSplit
(TableName tableName, RegionSplitter.SplitAlgorithm splitAlgo, org.apache.hadoop.conf.Configuration conf) (package private) static LinkedList<Pair<byte[],
byte[]>> RegionSplitter.splitScan
(LinkedList<Pair<byte[], byte[]>> regionList, Connection connection, TableName tableName, RegionSplitter.SplitAlgorithm splitAlgo) Modifier and TypeMethodDescription(package private) TableDescriptor[]
HBaseFsck.getTableDescriptors
(List<TableName> tableNames) Deprecated.private void
HBaseFsck.printTableSummary
(SortedMap<TableName, HbckTableInfo> tablesInfo) Deprecated.Prints summary of all tables found on the system. -
Uses of TableName in org.apache.hadoop.hbase.util.compaction
ModifierConstructorDescriptionMajorCompactor
(org.apache.hadoop.conf.Configuration conf, TableName tableName, Set<String> storesToCompact, int concurrency, long timestamp, long sleepForMs) -
Uses of TableName in org.apache.hadoop.hbase.wal
Modifier and TypeFieldDescriptionprivate TableName
WALKeyImpl.tablename
(package private) final TableName
EntryBuffers.RegionEntryBuffer.tableName
Modifier and TypeMethodDescriptionEntryBuffers.RegionEntryBuffer.getTableName()
WALKey.getTableName()
Returns table nameWALKeyImpl.getTableName()
Returns table nameModifier and TypeMethodDescriptionAbstractRecoveredEditsOutputSink.createRecoveredEditsWriter
(TableName tableName, byte[] region, long seqId) Returns a writer that wraps aWALProvider.Writer
and its Path.private StoreFileWriter
BoundedRecoveredHFilesOutputSink.createRecoveredHFileWriter
(TableName tableName, String regionName, long seqId, String familyName, boolean isMetaTable) RecoveredEditsOutputSink.getRecoveredEditsWriter
(TableName tableName, byte[] region, long seqId) Get a writer and path for a log starting at the given entry.(package private) static org.apache.hadoop.fs.Path
WALSplitUtil.getRegionSplitEditsPath
(TableName tableName, byte[] encodedRegionName, long seqId, String fileNameBeingSplit, String tmpDirName, org.apache.hadoop.conf.Configuration conf) Path to a file under RECOVERED_EDITS_DIR directory of the region found inlogEntry
named for the sequenceid in the passedlogEntry
: e.g.protected void
WALKeyImpl.init
(byte[] encodedRegionName, TableName tablename, long logSeqNum, long now, List<UUID> clusterIds, long nonceGroup, long nonce, MultiVersionConcurrencyControl mvcc, NavigableMap<byte[], Integer> replicationScope, Map<String, byte[]> extendedAttributes) (package private) void
WALKeyImpl.internTableName
(TableName tablename) Drop this instance's tablename byte array and instead hold a reference to the provided tablename.private boolean
WALSplitter.isRegionDirPresentUnderRoot
(TableName tn, String region) (package private) static org.apache.hadoop.fs.Path
WALSplitUtil.tryCreateRecoveredHFilesDir
(org.apache.hadoop.fs.FileSystem rootFS, org.apache.hadoop.conf.Configuration conf, TableName tableName, String encodedRegionName, String familyName) Return path to recovered.hfiles directory of the region's column family: e.g.ModifierConstructorDescription(package private)
RegionEntryBuffer
(TableName tableName, byte[] region) WALKeyImpl
(byte[] encodedRegionName, TableName tablename, long now) WALKeyImpl
(byte[] encodedRegionName, TableName tablename, long logSeqNum, long nonceGroup, long nonce, MultiVersionConcurrencyControl mvcc) Create the log key for writing to somewhere.WALKeyImpl
(byte[] encodedRegionName, TableName tablename, long logSeqNum, long now, List<UUID> clusterIds, long nonceGroup, long nonce, MultiVersionConcurrencyControl mvcc) Create the log key for writing to somewhere.WALKeyImpl
(byte[] encodedRegionName, TableName tablename, long logSeqNum, long now, List<UUID> clusterIds, long nonceGroup, long nonce, MultiVersionConcurrencyControl mvcc, NavigableMap<byte[], Integer> replicationScope) Create the log key for writing to somewhere.WALKeyImpl
(byte[] encodedRegionName, TableName tablename, long logSeqNum, long now, UUID clusterId) WALKeyImpl
(byte[] encodedRegionName, TableName tablename, long now, List<UUID> clusterIds, long nonceGroup, long nonce, MultiVersionConcurrencyControl mvcc) Create the log key for writing to somewhere.WALKeyImpl
(byte[] encodedRegionName, TableName tablename, long now, List<UUID> clusterIds, long nonceGroup, long nonce, MultiVersionConcurrencyControl mvcc, NavigableMap<byte[], Integer> replicationScope) Create the log key for writing to somewhere.WALKeyImpl
(byte[] encodedRegionName, TableName tablename, long now, List<UUID> clusterIds, long nonceGroup, long nonce, MultiVersionConcurrencyControl mvcc, NavigableMap<byte[], Integer> replicationScope, Map<String, byte[]> extendedAttributes) WALKeyImpl
(byte[] encodedRegionName, TableName tablename, long now, NavigableMap<byte[], Integer> replicationScope) WALKeyImpl
(byte[] encodedRegionName, TableName tablename, long now, MultiVersionConcurrencyControl mvcc) WALKeyImpl
(byte[] encodedRegionName, TableName tablename, long now, MultiVersionConcurrencyControl mvcc, NavigableMap<byte[], Integer> replicationScope) WALKeyImpl
(byte[] encodedRegionName, TableName tablename, long now, MultiVersionConcurrencyControl mvcc, NavigableMap<byte[], Integer> replicationScope, Map<String, byte[]> extendedAttributes) -
Uses of TableName in org.apache.hbase.archetypes.exemplars.client
Modifier and TypeFieldDescription(package private) static final TableName
HelloHBase.MY_TABLE_NAME
-
Uses of TableName in org.apache.hbase.archetypes.exemplars.shaded_client
Modifier and TypeFieldDescription(package private) static final TableName
HelloHBase.MY_TABLE_NAME
RegionInfo.getTable(byte[])
.