Uses of Class
org.apache.hadoop.hbase.TableName
Package
Description
Provides HBase Client
Table of Contents
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.
Multi Cluster Replication
-
Uses of org.apache.hadoop.hbase.TableName in org.apache.hadoop.hbase
Modifier and TypeFieldDescriptionstatic final org.apache.hadoop.hbase.TableName
HConstants.ENSEMBLE_TABLE_NAME
The name of the ensemble tablestatic final org.apache.hadoop.hbase.TableName
TableName.META_TABLE_NAME
The hbase:meta table's name.static final org.apache.hadoop.hbase.TableName
TableName.NAMESPACE_TABLE_NAME
Deprecated.since 3.0.0 and will be removed in 4.0.0.static final org.apache.hadoop.hbase.TableName
TableName.OLD_META_TABLE_NAME
TableName for old .META.static final org.apache.hadoop.hbase.TableName
TableName.OLD_ROOT_TABLE_NAME
TableName for old -ROOT- table.Modifier and TypeMethodDescriptionstatic org.apache.hadoop.hbase.TableName
TableName.valueOf
(byte[] fullName) Construct a TableNamestatic org.apache.hadoop.hbase.TableName
TableName.valueOf
(byte[] namespace, byte[] qualifier) static org.apache.hadoop.hbase.TableName
TableName.valueOf
(byte[] fullName, int offset, int length) Construct a TableNamestatic org.apache.hadoop.hbase.TableName
TableName.valueOf
(String name) Construct a TableNamestatic org.apache.hadoop.hbase.TableName
static org.apache.hadoop.hbase.TableName
TableName.valueOf
(ByteBuffer fullname) Construct a TableNamestatic org.apache.hadoop.hbase.TableName
TableName.valueOf
(ByteBuffer namespace, ByteBuffer qualifier) Modifier and TypeMethodDescriptionMap<org.apache.hadoop.hbase.TableName,
org.apache.hadoop.hbase.client.RegionStatesCount> ClusterMetrics.getTableRegionStatesCount()
Provide region states count for given table.static Map<org.apache.hadoop.hbase.TableName,
org.apache.hadoop.hbase.client.TableState> MetaTableAccessor.getTableStates
(org.apache.hadoop.hbase.client.Connection conn) Fetch table states from META tableModifier and TypeMethodDescriptionvoid
HBaseTestingUtility.compact
(org.apache.hadoop.hbase.TableName tableName, boolean major) Deprecated.Compact all of a table's reagion in the mini hbase clustervoid
MiniHBaseCluster.compact
(org.apache.hadoop.hbase.TableName tableName, boolean major) Deprecated.Call flushCache on all regions of the specified table.int
TableName.compareTo
(org.apache.hadoop.hbase.TableName tableName) int
HBaseTestingUtility.countRows
(org.apache.hadoop.hbase.TableName tableName) Deprecated.Return the number of rows in the given table.org.apache.hadoop.hbase.regionserver.HRegion
HBaseTestingUtility.createLocalHRegion
(org.apache.hadoop.hbase.TableName tableName, byte[] startKey, byte[] stopKey, org.apache.hadoop.conf.Configuration conf, boolean isReadOnly, org.apache.hadoop.hbase.client.Durability durability, org.apache.hadoop.hbase.wal.WAL wal, byte[]... families) Deprecated.Return a region on which you must callHBaseTestingUtility.closeRegionAndWAL(HRegion)
when done.org.apache.hadoop.hbase.regionserver.HRegion
HBaseTestingUtility.createLocalHRegionWithInMemoryFlags
(org.apache.hadoop.hbase.TableName tableName, byte[] startKey, byte[] stopKey, org.apache.hadoop.conf.Configuration conf, boolean isReadOnly, org.apache.hadoop.hbase.client.Durability durability, org.apache.hadoop.hbase.wal.WAL wal, boolean[] compactedMemStore, byte[]... families) Deprecated.org.apache.hadoop.hbase.client.TableDescriptorBuilder
HBaseTestingUtility.createModifyableTableDescriptor
(org.apache.hadoop.hbase.TableName name, int minVersions, int versions, int ttl, org.apache.hadoop.hbase.KeepDeletedCells keepDeleted) Deprecated.org.apache.hadoop.hbase.client.Table
HBaseTestingUtility.createMultiRegionTable
(org.apache.hadoop.hbase.TableName tableName, byte[] family) Deprecated.Create a table with multiple regions.org.apache.hadoop.hbase.client.Table
HBaseTestingUtility.createMultiRegionTable
(org.apache.hadoop.hbase.TableName tableName, byte[][] families) Deprecated.Create a table with multiple regions.org.apache.hadoop.hbase.client.Table
HBaseTestingUtility.createMultiRegionTable
(org.apache.hadoop.hbase.TableName tableName, byte[][] families, int numVersions) Deprecated.Create a table with multiple regions.org.apache.hadoop.hbase.client.Table
HBaseTestingUtility.createMultiRegionTable
(org.apache.hadoop.hbase.TableName tableName, byte[] family, int numRegions) Deprecated.Create a table with multiple regions.org.apache.hadoop.hbase.client.Table
HBaseTestingUtility.createMultiRegionTable
(org.apache.hadoop.hbase.TableName tableName, int replicaCount, byte[][] families) Deprecated.Create a table with multiple regions.static int
HBaseTestingUtility.createPreSplitLoadTestTable
(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.TableName tableName, byte[][] columnFamilies, org.apache.hadoop.hbase.io.compress.Compression.Algorithm compression, org.apache.hadoop.hbase.io.encoding.DataBlockEncoding dataBlockEncoding, int numRegionsPerServer, int regionReplication, org.apache.hadoop.hbase.client.Durability durability) Deprecated.Creates a pre-split table for load testing.static int
HBaseTestingUtility.createPreSplitLoadTestTable
(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.TableName tableName, byte[] columnFamily, org.apache.hadoop.hbase.io.compress.Compression.Algorithm compression, org.apache.hadoop.hbase.io.encoding.DataBlockEncoding dataBlockEncoding) Deprecated.Creates a pre-split table for load testing.static int
HBaseTestingUtility.createPreSplitLoadTestTable
(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.TableName tableName, byte[] columnFamily, org.apache.hadoop.hbase.io.compress.Compression.Algorithm compression, org.apache.hadoop.hbase.io.encoding.DataBlockEncoding dataBlockEncoding, int numRegionsPerServer, int regionReplication, org.apache.hadoop.hbase.client.Durability durability) Deprecated.Creates a pre-split table for load testing.org.apache.hadoop.hbase.client.Table
HBaseTestingUtility.createRandomTable
(org.apache.hadoop.hbase.TableName tableName, Collection<String> families, int maxVersions, int numColsPerRow, int numFlushes, int numRegions, int numRowsPerFlush) Deprecated.Creates a random table with the given parametersorg.apache.hadoop.hbase.client.Table
HBaseTestingUtility.createTable
(org.apache.hadoop.hbase.TableName tableName, byte[] family) Deprecated.Create a table.org.apache.hadoop.hbase.client.Table
HBaseTestingUtility.createTable
(org.apache.hadoop.hbase.TableName tableName, byte[][] families) Deprecated.Create a table.org.apache.hadoop.hbase.client.Table
HBaseTestingUtility.createTable
(org.apache.hadoop.hbase.TableName tableName, byte[][] families, byte[][] splitKeys) Deprecated.Create a table.org.apache.hadoop.hbase.client.Table
HBaseTestingUtility.createTable
(org.apache.hadoop.hbase.TableName tableName, byte[][] families, byte[][] splitKeys, int replicaCount) Deprecated.Create a table.org.apache.hadoop.hbase.client.Table
HBaseTestingUtility.createTable
(org.apache.hadoop.hbase.TableName tableName, byte[][] families, byte[][] splitKeys, int replicaCount, org.apache.hadoop.conf.Configuration c) Deprecated.Create a table.org.apache.hadoop.hbase.client.Table
HBaseTestingUtility.createTable
(org.apache.hadoop.hbase.TableName tableName, byte[][] families, int numVersions) Deprecated.Create a table.org.apache.hadoop.hbase.client.Table
HBaseTestingUtility.createTable
(org.apache.hadoop.hbase.TableName tableName, byte[][] families, int[] numVersions) Deprecated.Create a table.org.apache.hadoop.hbase.client.Table
HBaseTestingUtility.createTable
(org.apache.hadoop.hbase.TableName tableName, byte[][] families, int numVersions, byte[][] splitKeys) Deprecated.Create a table.org.apache.hadoop.hbase.client.Table
HBaseTestingUtility.createTable
(org.apache.hadoop.hbase.TableName tableName, byte[][] families, int numVersions, byte[] startKey, byte[] endKey, int numRegions) Deprecated.org.apache.hadoop.hbase.client.Table
HBaseTestingUtility.createTable
(org.apache.hadoop.hbase.TableName tableName, byte[][] families, int numVersions, int blockSize) Deprecated.Create a table.org.apache.hadoop.hbase.client.Table
HBaseTestingUtility.createTable
(org.apache.hadoop.hbase.TableName tableName, byte[][] families, int numVersions, int blockSize, String cpName) Deprecated.org.apache.hadoop.hbase.client.Table
HBaseTestingUtility.createTable
(org.apache.hadoop.hbase.TableName tableName, byte[] family, byte[][] splitRows) Deprecated.Create a table.org.apache.hadoop.hbase.client.Table
HBaseTestingUtility.createTable
(org.apache.hadoop.hbase.TableName tableName, byte[] family, int numVersions) Deprecated.Create a table.org.apache.hadoop.hbase.client.Table
HBaseTestingUtility.createTable
(org.apache.hadoop.hbase.TableName tableName, String family) Deprecated.Create a table.org.apache.hadoop.hbase.client.Table
HBaseTestingUtility.createTable
(org.apache.hadoop.hbase.TableName tableName, String[] families) Deprecated.Create a table.org.apache.hadoop.hbase.client.TableDescriptor
HBaseTestingUtility.createTableDescriptor
(org.apache.hadoop.hbase.TableName name) Deprecated.Create a table of namename
.org.apache.hadoop.hbase.client.TableDescriptor
HBaseTestingUtility.createTableDescriptor
(org.apache.hadoop.hbase.TableName tableName, byte[] family) Deprecated.org.apache.hadoop.hbase.client.TableDescriptor
HBaseTestingUtility.createTableDescriptor
(org.apache.hadoop.hbase.TableName tableName, byte[][] families, int maxVersions) Deprecated.org.apache.hadoop.hbase.client.TableDescriptor
HBaseTestingUtility.createTableDescriptor
(org.apache.hadoop.hbase.TableName name, int minVersions, int versions, int ttl, org.apache.hadoop.hbase.KeepDeletedCells keepDeleted) Deprecated.void
HBaseTestingUtility.deleteTable
(org.apache.hadoop.hbase.TableName tableName) Deprecated.Drop an existing tableorg.apache.hadoop.hbase.client.Table
HBaseTestingUtility.deleteTableData
(org.apache.hadoop.hbase.TableName tableName) Deprecated.Provide an existing table name to truncate.void
HBaseTestingUtility.deleteTableIfAny
(org.apache.hadoop.hbase.TableName tableName) Deprecated.Drop an existing tablestatic void
MetaTableAccessor.deleteTableState
(org.apache.hadoop.hbase.client.Connection connection, org.apache.hadoop.hbase.TableName table) Remove state for table from metadefault boolean
TableDescriptors.exists
(org.apache.hadoop.hbase.TableName tableName) Test whether a given table exists, i.e, has a table descriptor.HBaseTestingUtility.explainTableAvailability
(org.apache.hadoop.hbase.TableName tableName) Deprecated.HBaseTestingUtility.explainTableState
(org.apache.hadoop.hbase.TableName table, org.apache.hadoop.hbase.client.TableState.State state) Deprecated.org.apache.hadoop.hbase.client.TableState
HBaseTestingUtility.findLastTableState
(org.apache.hadoop.hbase.TableName table) Deprecated.List<org.apache.hadoop.hbase.regionserver.HRegion>
MiniHBaseCluster.findRegionsForTable
(org.apache.hadoop.hbase.TableName tableName) Deprecated.void
HBaseTestingUtility.flush
(org.apache.hadoop.hbase.TableName tableName) Deprecated.Flushes all caches in the mini hbase clustervoid
MiniHBaseCluster.flushcache
(org.apache.hadoop.hbase.TableName tableName) Deprecated.Call flushCache on all regions of the specified table.org.apache.hadoop.hbase.client.TableDescriptor
TableDescriptors.get
(org.apache.hadoop.hbase.TableName tableName) Returns TableDescriptor for tablenamestatic CellComparator
CellComparatorImpl.getCellComparator
(org.apache.hadoop.hbase.TableName tableName) Utility method that makes a guess at comparator to use based off passed tableName.static CellComparator
InnerStoreCellComparator.getInnerStoreCellComparator
(org.apache.hadoop.hbase.TableName tableName) Utility method that makes a guess at comparator to use based off passed tableName.default long
ClusterMetrics.getLastMajorCompactionTimestamp
(org.apache.hadoop.hbase.TableName table) List<byte[]>
HBaseTestingUtility.getMetaTableRows
(org.apache.hadoop.hbase.TableName tableName) Deprecated.Returns all rows from the hbase:meta table for a given user tableint
HBaseTestingUtility.getNumHFiles
(org.apache.hadoop.hbase.TableName tableName, byte[] family) Deprecated.int
HBaseTestingUtility.getNumHFilesForRS
(org.apache.hadoop.hbase.regionserver.HRegionServer rs, org.apache.hadoop.hbase.TableName tableName, byte[] family) Deprecated.List<org.apache.hadoop.hbase.regionserver.HRegion>
MiniHBaseCluster.getRegions
(org.apache.hadoop.hbase.TableName tableName) Deprecated.List<org.apache.hadoop.hbase.regionserver.HRegion>
MockRegionServerServices.getRegions
(org.apache.hadoop.hbase.TableName tableName) org.apache.hadoop.hbase.regionserver.HRegionServer
HBaseTestingUtility.getRSForFirstRegionInTable
(org.apache.hadoop.hbase.TableName tableName) Deprecated.Tool to get the reference to the region server object that holds the region of the specified user table.static org.apache.hadoop.hbase.client.Scan
MetaTableAccessor.getScanForTableName
(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.TableName tableName) This method creates a Scan object that will only scan catalog rows that belong to the specified table.abstract org.apache.hadoop.hbase.ServerName
HBaseCluster.getServerHoldingRegion
(org.apache.hadoop.hbase.TableName tn, byte[] regionName) Deprecated.Get the ServerName of region server serving the specified regionorg.apache.hadoop.hbase.ServerName
MiniHBaseCluster.getServerHoldingRegion
(org.apache.hadoop.hbase.TableName tn, byte[] regionName) Deprecated.org.apache.hadoop.hbase.regionserver.HRegion
HBaseTestingUtility.getSplittableRegion
(org.apache.hadoop.hbase.TableName tableName, int maxAttempts) Deprecated.Retrieves a splittable region randomly from tableNamestatic CompletableFuture<List<org.apache.hadoop.hbase.HRegionLocation>>
ClientMetaTableAccessor.getTableHRegionLocations
(org.apache.hadoop.hbase.client.AsyncTable<org.apache.hadoop.hbase.client.AdvancedScanResultConsumer> metaTable, org.apache.hadoop.hbase.TableName tableName) Used to get all region locations for the specific tablestatic List<org.apache.hadoop.hbase.client.RegionInfo>
MetaTableAccessor.getTableRegions
(org.apache.hadoop.hbase.client.Connection connection, org.apache.hadoop.hbase.TableName tableName) Gets all of the regions of the specified table.static List<org.apache.hadoop.hbase.client.RegionInfo>
MetaTableAccessor.getTableRegions
(org.apache.hadoop.hbase.client.Connection connection, org.apache.hadoop.hbase.TableName tableName, boolean excludeOfflinedSplitParents) Gets all of the regions of the specified table.static List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.client.RegionInfo,
org.apache.hadoop.hbase.ServerName>> MetaTableAccessor.getTableRegionsAndLocations
(org.apache.hadoop.hbase.client.Connection connection, org.apache.hadoop.hbase.TableName tableName) Do not use this method to get meta table regions, use methods in MetaTableLocator instead.static List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.client.RegionInfo,
org.apache.hadoop.hbase.ServerName>> MetaTableAccessor.getTableRegionsAndLocations
(org.apache.hadoop.hbase.client.Connection connection, org.apache.hadoop.hbase.TableName tableName, boolean excludeOfflinedSplitParents) Do not use this method to get meta table regions, use methods in MetaTableLocator instead.static byte[]
ClientMetaTableAccessor.getTableStartRowForMeta
(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.ClientMetaTableAccessor.QueryType type) Returns start row for scanning META according to query typestatic CompletableFuture<Optional<org.apache.hadoop.hbase.client.TableState>>
ClientMetaTableAccessor.getTableState
(org.apache.hadoop.hbase.client.AsyncTable<?> metaTable, org.apache.hadoop.hbase.TableName tableName) static org.apache.hadoop.hbase.client.TableState
MetaTableAccessor.getTableState
(org.apache.hadoop.hbase.client.Connection conn, org.apache.hadoop.hbase.TableName tableName) Fetch table state for given table from META tablestatic byte[]
ClientMetaTableAccessor.getTableStopRowForMeta
(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.ClientMetaTableAccessor.QueryType type) Returns stop row for scanning META according to query typestatic boolean
TableName.isMetaTableName
(org.apache.hadoop.hbase.TableName tn) Returns True iftn
is the hbase:meta table name.<any>
HBaseTestingUtility.predicateTableAvailable
(org.apache.hadoop.hbase.TableName tableName) Deprecated.Returns aPredicate
for checking that table is enabled<any>
HBaseTestingUtility.predicateTableDisabled
(org.apache.hadoop.hbase.TableName tableName) Deprecated.Returns aPredicate
for checking that table is enabled<any>
HBaseTestingUtility.predicateTableEnabled
(org.apache.hadoop.hbase.TableName tableName) Deprecated.Returns aPredicate
for checking that table is enabledorg.apache.hadoop.hbase.client.TableDescriptor
TableDescriptors.remove
(org.apache.hadoop.hbase.TableName tablename) Returns Instance of table descriptor or null if none found.boolean
MockRegionServerServices.reportFileArchivalForQuotas
(org.apache.hadoop.hbase.TableName tableName, Collection<Map.Entry<String, Long>> archivedFiles) static void
MetaTableAccessor.scanMeta
(org.apache.hadoop.hbase.client.Connection connection, org.apache.hadoop.hbase.ClientMetaTableAccessor.Visitor visitor, org.apache.hadoop.hbase.TableName tableName, byte[] row, int rowLimit) Performs a scan of META table for given table starting from given row.static void
MetaTableAccessor.scanMetaForTableRegions
(org.apache.hadoop.hbase.client.Connection connection, org.apache.hadoop.hbase.ClientMetaTableAccessor.Visitor visitor, org.apache.hadoop.hbase.TableName tableName) static void
HBaseTestingUtility.setReplicas
(org.apache.hadoop.hbase.client.Admin admin, org.apache.hadoop.hbase.TableName table, int replicaCount) Deprecated.Set the number of Region replicas.static CompletableFuture<Boolean>
ClientMetaTableAccessor.tableExists
(org.apache.hadoop.hbase.client.AsyncTable<?> metaTable, org.apache.hadoop.hbase.TableName tableName) org.apache.hadoop.hbase.client.Table
HBaseTestingUtility.truncateTable
(org.apache.hadoop.hbase.TableName tableName) Deprecated.Truncate a table using the admin command.org.apache.hadoop.hbase.client.Table
HBaseTestingUtility.truncateTable
(org.apache.hadoop.hbase.TableName tableName, boolean preserveRegions) Deprecated.Truncate a table using the admin command.static void
MetaTableAccessor.updateTableState
(org.apache.hadoop.hbase.client.Connection conn, org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.TableState.State actual) Updates state in META Do not use.void
HBaseTestingUtility.waitTableAvailable
(org.apache.hadoop.hbase.TableName table) Deprecated.Wait until all regions in a table have been assigned.void
HBaseTestingUtility.waitTableAvailable
(org.apache.hadoop.hbase.TableName table, long timeoutMillis) Deprecated.void
HBaseTestingUtility.waitTableDisabled
(org.apache.hadoop.hbase.TableName table, long millisTimeout) Deprecated.void
HBaseTestingUtility.waitTableEnabled
(org.apache.hadoop.hbase.TableName table) Deprecated.Waits for a table to be 'enabled'.void
HBaseTestingUtility.waitTableEnabled
(org.apache.hadoop.hbase.TableName table, long timeoutMillis) Deprecated.void
HBaseTestingUtility.waitUntilAllRegionsAssigned
(org.apache.hadoop.hbase.TableName tableName) Deprecated.Wait until all regions for a table in hbase:meta have a non-empty info:server, up to a configuable timeout value (default is 60 seconds) This means all regions have been deployed, master has been informed and updated hbase:meta with the regions deployed server.void
HBaseTestingUtility.waitUntilAllRegionsAssigned
(org.apache.hadoop.hbase.TableName tableName, long timeout) Deprecated.Wait until all regions for a table in hbase:meta have a non-empty info:server, or until timeout.Modifier and TypeMethodDescriptionorg.apache.hadoop.hbase.ClusterMetricsBuilder
ClusterMetricsBuilder.setTableRegionStatesCount
(Map<org.apache.hadoop.hbase.TableName, org.apache.hadoop.hbase.client.RegionStatesCount> tableRegionStatesCount) ModifierConstructorDescriptionConcurrentTableModificationException
(org.apache.hadoop.hbase.TableName tableName) TableExistsException
(org.apache.hadoop.hbase.TableName tableName) TableNotDisabledException
(org.apache.hadoop.hbase.TableName tableName) TableNotEnabledException
(org.apache.hadoop.hbase.TableName tableName) TableNotFoundException
(org.apache.hadoop.hbase.TableName tableName) -
Uses of org.apache.hadoop.hbase.TableName in org.apache.hadoop.hbase.backup
Modifier and TypeMethodDescriptionorg.apache.hadoop.hbase.TableName[]
RestoreRequest.getFromTables()
org.apache.hadoop.hbase.TableName
BackupTableInfo.getTable()
org.apache.hadoop.hbase.TableName
BackupInfo.getTableBySnapshot
(String snapshotName) org.apache.hadoop.hbase.TableName[]
RestoreRequest.getToTables()
Modifier and TypeMethodDescriptionBackupInfo.getIncrTimestampMap()
Get new region server log timestamps after distributed log rollList<org.apache.hadoop.hbase.TableName>
BackupRequest.getTableList()
List<org.apache.hadoop.hbase.TableName>
BackupInfo.getTableNames()
Set<org.apache.hadoop.hbase.TableName>
BackupInfo.getTables()
BackupInfo.getTableSetTimestampMap()
Modifier and TypeMethodDescriptionvoid
BackupInfo.addTables
(org.apache.hadoop.hbase.TableName[] tables) void
BackupAdmin.addToBackupSet
(String name, org.apache.hadoop.hbase.TableName[] tables) Add tables to backup set commandorg.apache.hadoop.hbase.backup.BackupTableInfo
BackupInfo.getBackupTableInfo
(org.apache.hadoop.hbase.TableName table) BackupInfo.getSnapshotName
(org.apache.hadoop.hbase.TableName table) BackupInfo.getTableBackupDir
(org.apache.hadoop.hbase.TableName tableName) static String
HBackupFileSystem.getTableBackupDir
(String backupRootDir, String backupId, org.apache.hadoop.hbase.TableName tableName) Given the backup root dir, backup id and the table name, return the backup image location.static org.apache.hadoop.fs.Path
HBackupFileSystem.getTableBackupPath
(org.apache.hadoop.hbase.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, org.apache.hadoop.hbase.TableName[] tables) Remove tables from backup setvoid
RestoreJob.run
(org.apache.hadoop.fs.Path[] dirPaths, org.apache.hadoop.hbase.TableName[] fromTables, org.apache.hadoop.fs.Path restoreRootDir, org.apache.hadoop.hbase.TableName[] toTables, boolean fullBackupRestore) Run restore operationvoid
BackupInfo.setSnapshotName
(org.apache.hadoop.hbase.TableName table, String snapshotName) org.apache.hadoop.hbase.backup.RestoreRequest.Builder
RestoreRequest.Builder.withFromTables
(org.apache.hadoop.hbase.TableName[] fromTables) org.apache.hadoop.hbase.backup.RestoreRequest.Builder
RestoreRequest.Builder.withToTables
(org.apache.hadoop.hbase.TableName[] toTables) Modifier and TypeMethodDescriptionvoid
BackupInfo.setBackupTableInfoMap
(Map<org.apache.hadoop.hbase.TableName, org.apache.hadoop.hbase.backup.BackupTableInfo> backupTableInfoMap) void
BackupInfo.setIncrTimestampMap
(Map<org.apache.hadoop.hbase.TableName, Map<String, Long>> prevTableSetTimestampMap) Set the new region server log timestamps after distributed log rollvoid
BackupInfo.setTables
(List<org.apache.hadoop.hbase.TableName> tables) void
BackupInfo.setTableSetTimestampMap
(Map<org.apache.hadoop.hbase.TableName, Map<String, Long>> tableSetTimestampMap) org.apache.hadoop.hbase.backup.BackupRequest.Builder
BackupRequest.Builder.withTableList
(List<org.apache.hadoop.hbase.TableName> tables) -
Uses of org.apache.hadoop.hbase.TableName in org.apache.hadoop.hbase.client
Modifier and TypeMethodDescriptionorg.apache.hadoop.hbase.TableName
AsyncBufferedMutator.getName()
Gets the fully qualified table name instance of the table that thisAsyncBufferedMutator
writes to.org.apache.hadoop.hbase.TableName
AsyncTable.getName()
Gets the fully qualified table name instance of this table.org.apache.hadoop.hbase.TableName
AsyncTableRegionLocator.getName()
Gets the fully qualified table name instance of the table whose region we want to locate.org.apache.hadoop.hbase.TableName
BufferedMutator.getName()
Gets the fully qualified table name instance of the table that this BufferedMutator writes to.org.apache.hadoop.hbase.TableName
RegionLocator.getName()
Gets the fully qualified table name instance of this table.org.apache.hadoop.hbase.TableName
Table.getName()
Gets the fully qualified table name instance of this table.org.apache.hadoop.hbase.TableName
RegionInfo.getTable()
Returns current table name of the regionstatic org.apache.hadoop.hbase.TableName
RegionInfo.getTable
(byte[] regionName) Gets the table name from the specified region name.org.apache.hadoop.hbase.TableName
BufferedMutatorParams.getTableName()
org.apache.hadoop.hbase.TableName
SnapshotDescription.getTableName()
org.apache.hadoop.hbase.TableName
TableDescriptor.getTableName()
Get the name of the tableorg.apache.hadoop.hbase.TableName
TableState.getTableName()
Table name for stateorg.apache.hadoop.hbase.TableName[]
Admin.listTableNames()
List all of the names of userspace tables.default org.apache.hadoop.hbase.TableName[]
Admin.listTableNames
(Pattern pattern) List all of the names of userspace tables.org.apache.hadoop.hbase.TableName[]
Admin.listTableNames
(Pattern pattern, boolean includeSysTables) List all of the names of userspace tables.org.apache.hadoop.hbase.TableName[]
Admin.listTableNamesByNamespace
(String name) Get list of table names by namespace.Modifier and TypeMethodDescriptionAdmin.getConfiguredNamespacesAndTablesInRSGroup
(String groupName) Get the namespaces and tables which have this RegionServer group in descriptor.CompletableFuture<org.apache.hadoop.hbase.util.Pair<List<String>,
List<org.apache.hadoop.hbase.TableName>>> AsyncAdmin.getConfiguredNamespacesAndTablesInRSGroup
(String groupName) Get the namespaces and tables which have this RegionServer group in descriptor.Map<org.apache.hadoop.hbase.TableName,
? extends org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshotView> Admin.getRegionServerSpaceQuotaSnapshots
(org.apache.hadoop.hbase.ServerName serverName) Fetches the observedSpaceQuotaSnapshotView
s observed by a RegionServer.CompletableFuture<? extends Map<org.apache.hadoop.hbase.TableName,
? extends org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshotView>> AsyncAdmin.getRegionServerSpaceQuotaSnapshots
(org.apache.hadoop.hbase.ServerName serverName) Fetches the observedSpaceQuotaSnapshotView
s observed by a RegionServer.Admin.getSpaceQuotaTableSizes()
Fetches the table sizes on the filesystem as tracked by the HBase Master.CompletableFuture<Map<org.apache.hadoop.hbase.TableName,
Long>> AsyncAdmin.getSpaceQuotaTableSizes()
Fetches the table sizes on the filesystem as tracked by the HBase Master.protected Optional<org.apache.hadoop.hbase.TableName>
AsyncRpcRetryingCaller.getTableName()
List<org.apache.hadoop.hbase.TableName>
NormalizeTableFilterParams.getTableNames()
default CompletableFuture<List<org.apache.hadoop.hbase.TableName>>
AsyncAdmin.listTableNames()
List all of the names of userspace tables.CompletableFuture<List<org.apache.hadoop.hbase.TableName>>
AsyncAdmin.listTableNames
(boolean includeSysTables) List all of the names of tables.CompletableFuture<List<org.apache.hadoop.hbase.TableName>>
AsyncAdmin.listTableNames
(Pattern pattern, boolean includeSysTables) List all of the names of userspace tables.CompletableFuture<List<org.apache.hadoop.hbase.TableName>>
AsyncAdmin.listTableNamesByNamespace
(String name) Get list of table names by namespace.List<org.apache.hadoop.hbase.TableName>
Admin.listTableNamesByState
(boolean isEnabled) List all enabled or disabled table namesCompletableFuture<List<org.apache.hadoop.hbase.TableName>>
AsyncAdmin.listTableNamesByState
(boolean isEnabled) List all enabled or disabled table namesList<org.apache.hadoop.hbase.TableName>
Admin.listTablesInRSGroup
(String groupName) Get all tables in this RegionServer group.CompletableFuture<List<org.apache.hadoop.hbase.TableName>>
AsyncAdmin.listTablesInRSGroup
(String groupName) Get all tables in this RegionServer group.Modifier and TypeMethodDescriptiondefault void
Admin.addColumnFamily
(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.ColumnFamilyDescriptor columnFamily) Add a column family to an existing table.AsyncAdmin.addColumnFamily
(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.ColumnFamilyDescriptor columnFamily) Add a column family to an existing table.Admin.addColumnFamilyAsync
(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.ColumnFamilyDescriptor columnFamily) Add a column family to an existing table.AsyncClusterConnection.bulkLoad
(org.apache.hadoop.hbase.TableName tableName, List<org.apache.hadoop.hbase.util.Pair<byte[], String>> familyPaths, byte[] row, boolean assignSeqNum, org.apache.hadoop.security.token.Token<?> userToken, String bulkToken, boolean copyFiles, List<String> clusterIds, boolean replicate) Securely bulk load a list of HFiles, passing additional list of clusters ids tracking clusters where the given bulk load has already been processed (important for bulk loading replication).AsyncClusterConnection.cleanupBulkLoad
(org.apache.hadoop.hbase.TableName tableName, String bulkToken) Clean up after finishing bulk load, no matter success or not.org.apache.hadoop.hbase.CacheEvictionStats
Admin.clearBlockCache
(org.apache.hadoop.hbase.TableName tableName) Clear all the blocks corresponding to this table from BlockCache.CompletableFuture<org.apache.hadoop.hbase.CacheEvictionStats>
AsyncAdmin.clearBlockCache
(org.apache.hadoop.hbase.TableName tableName) Clear all the blocks corresponding to this table from BlockCache.default void
Admin.cloneSnapshot
(String snapshotName, org.apache.hadoop.hbase.TableName tableName) Create a new table by cloning the snapshot content.default void
Admin.cloneSnapshot
(String snapshotName, org.apache.hadoop.hbase.TableName tableName, boolean restoreAcl) Create a new table by cloning the snapshot content.default void
Admin.cloneSnapshot
(String snapshotName, org.apache.hadoop.hbase.TableName tableName, boolean restoreAcl, String customSFT) Create a new table by cloning the snapshot content.default CompletableFuture<Void>
AsyncAdmin.cloneSnapshot
(String snapshotName, org.apache.hadoop.hbase.TableName tableName) Create a new table by cloning the snapshot content.default CompletableFuture<Void>
AsyncAdmin.cloneSnapshot
(String snapshotName, org.apache.hadoop.hbase.TableName tableName, boolean restoreAcl) Create a new table by cloning the snapshot content.AsyncAdmin.cloneSnapshot
(String snapshotName, org.apache.hadoop.hbase.TableName tableName, boolean restoreAcl, String customSFT) Create a new table by cloning the snapshot content.Admin.cloneSnapshotAsync
(String snapshotName, org.apache.hadoop.hbase.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, org.apache.hadoop.hbase.TableName tableName, boolean restoreAcl) Create a new table by cloning the snapshot content.Admin.cloneSnapshotAsync
(String snapshotName, org.apache.hadoop.hbase.TableName tableName, boolean restoreAcl, String customSFT) Create a new table by cloning the snapshot content.void
Admin.cloneTableSchema
(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.TableName newTableName, boolean preserveSplits) Create a new table by cloning the existent table schema.AsyncAdmin.cloneTableSchema
(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.TableName newTableName, boolean preserveSplits) Create a new table by cloning the existent table schema.void
Admin.compact
(org.apache.hadoop.hbase.TableName tableName) Compact a table.void
Admin.compact
(org.apache.hadoop.hbase.TableName tableName, byte[] columnFamily) Compact a column family within a table.void
Admin.compact
(org.apache.hadoop.hbase.TableName tableName, byte[] columnFamily, org.apache.hadoop.hbase.client.CompactType compactType) Compact a column family within a table.void
Admin.compact
(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.CompactType compactType) Compact a table.default CompletableFuture<Void>
AsyncAdmin.compact
(org.apache.hadoop.hbase.TableName tableName) Compact a table.default CompletableFuture<Void>
AsyncAdmin.compact
(org.apache.hadoop.hbase.TableName tableName, byte[] columnFamily) Compact a column family within a table.AsyncAdmin.compact
(org.apache.hadoop.hbase.TableName tableName, byte[] columnFamily, org.apache.hadoop.hbase.client.CompactType compactType) Compact a column family within a table.AsyncAdmin.compact
(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.CompactType compactType) Compact a table.static org.apache.hadoop.hbase.client.TableState
TableState.convert
(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.shaded.protobuf.generated.HBaseProtos.TableState tableState) Covert from PB version of TableStatestatic org.apache.hadoop.hbase.client.TableDescriptor
TableDescriptorBuilder.copy
(org.apache.hadoop.hbase.TableName name, org.apache.hadoop.hbase.client.TableDescriptor desc) static org.apache.hadoop.hbase.client.RegionInfo
RegionInfo.createMobRegionInfo
(org.apache.hadoop.hbase.TableName tableName) Creates a RegionInfo object for MOB data.static byte[]
RegionInfo.createRegionName
(org.apache.hadoop.hbase.TableName tableName, byte[] startKey, byte[] id, boolean newFormat) Make a region name of passed parameters.static byte[]
RegionInfo.createRegionName
(org.apache.hadoop.hbase.TableName tableName, byte[] startKey, byte[] id, int replicaId, boolean newFormat) Make a region name of passed parameters.static byte[]
RegionInfo.createRegionName
(org.apache.hadoop.hbase.TableName tableName, byte[] startKey, long regionid, boolean newFormat) Make a region name of passed parameters.static byte[]
RegionInfo.createRegionName
(org.apache.hadoop.hbase.TableName tableName, byte[] startKey, long regionid, int replicaId, boolean newFormat) Make a region name of passed parameters.static byte[]
RegionInfo.createRegionName
(org.apache.hadoop.hbase.TableName tableName, byte[] startKey, String id, boolean newFormat) Make a region name of passed parameters.default void
Admin.deleteColumnFamily
(org.apache.hadoop.hbase.TableName tableName, byte[] columnFamily) Delete a column family from a table.AsyncAdmin.deleteColumnFamily
(org.apache.hadoop.hbase.TableName tableName, byte[] columnFamily) Delete a column family from a table.Admin.deleteColumnFamilyAsync
(org.apache.hadoop.hbase.TableName tableName, byte[] columnFamily) Delete a column family from a table.default void
Admin.deleteTable
(org.apache.hadoop.hbase.TableName tableName) Deletes a table.AsyncAdmin.deleteTable
(org.apache.hadoop.hbase.TableName tableName) Deletes a table.Admin.deleteTableAsync
(org.apache.hadoop.hbase.TableName tableName) Deletes the table but does not block and wait for it to be completely removed.default void
Admin.disableTable
(org.apache.hadoop.hbase.TableName tableName) Disable table and wait on completion.AsyncAdmin.disableTable
(org.apache.hadoop.hbase.TableName tableName) Disable a table.Admin.disableTableAsync
(org.apache.hadoop.hbase.TableName tableName) Disable the table but does not block and wait for it to be completely disabled.void
Admin.disableTableReplication
(org.apache.hadoop.hbase.TableName tableName) Disable a table's replication switch.AsyncAdmin.disableTableReplication
(org.apache.hadoop.hbase.TableName tableName) Disable a table's replication switch.default void
Admin.enableTable
(org.apache.hadoop.hbase.TableName tableName) Enable a table.AsyncAdmin.enableTable
(org.apache.hadoop.hbase.TableName tableName) Enable a table.Admin.enableTableAsync
(org.apache.hadoop.hbase.TableName tableName) Enable the table but does not block and wait for it to be completely enabled.void
Admin.enableTableReplication
(org.apache.hadoop.hbase.TableName tableName) Enable a table's replication switch.AsyncAdmin.enableTableReplication
(org.apache.hadoop.hbase.TableName tableName) Enable a table's replication switch.void
Admin.flush
(org.apache.hadoop.hbase.TableName tableName) Flush a table.void
Admin.flush
(org.apache.hadoop.hbase.TableName tableName, byte[] columnFamily) Flush the specified column family stores on all regions of the passed table.void
Admin.flush
(org.apache.hadoop.hbase.TableName tableName, List<byte[]> columnFamilies) Flush the specified column family stores on all regions of the passed table.AsyncAdmin.flush
(org.apache.hadoop.hbase.TableName tableName) Flush a table.AsyncAdmin.flush
(org.apache.hadoop.hbase.TableName tableName, byte[] columnFamily) Flush the specified column family stores on all regions of the passed table.AsyncAdmin.flush
(org.apache.hadoop.hbase.TableName tableName, List<byte[]> columnFamilies) Flush the specified column family stores on all regions of the passed table.default org.apache.hadoop.hbase.client.AsyncBufferedMutator
AsyncConnection.getBufferedMutator
(org.apache.hadoop.hbase.TableName tableName) Retrieve anAsyncBufferedMutator
for performing client-side buffering of writes.default org.apache.hadoop.hbase.client.AsyncBufferedMutator
AsyncConnection.getBufferedMutator
(org.apache.hadoop.hbase.TableName tableName, ExecutorService pool) Retrieve anAsyncBufferedMutator
for performing client-side buffering of writes.default org.apache.hadoop.hbase.client.BufferedMutator
Connection.getBufferedMutator
(org.apache.hadoop.hbase.TableName tableName) Retrieve aBufferedMutator
for performing client-side buffering of writes.org.apache.hadoop.hbase.client.BufferedMutator
SharedConnection.getBufferedMutator
(org.apache.hadoop.hbase.TableName tableName) org.apache.hadoop.hbase.client.AsyncBufferedMutatorBuilder
AsyncConnection.getBufferedMutatorBuilder
(org.apache.hadoop.hbase.TableName tableName) Returns anAsyncBufferedMutatorBuilder
for creatingAsyncBufferedMutator
.org.apache.hadoop.hbase.client.AsyncBufferedMutatorBuilder
AsyncConnection.getBufferedMutatorBuilder
(org.apache.hadoop.hbase.TableName tableName, ExecutorService pool) Returns anAsyncBufferedMutatorBuilder
for creatingAsyncBufferedMutator
.org.apache.hadoop.hbase.client.AsyncBufferedMutatorBuilder
AsyncConnectionImpl.getBufferedMutatorBuilder
(org.apache.hadoop.hbase.TableName tableName) org.apache.hadoop.hbase.client.AsyncBufferedMutatorBuilder
AsyncConnectionImpl.getBufferedMutatorBuilder
(org.apache.hadoop.hbase.TableName tableName, ExecutorService pool) org.apache.hadoop.hbase.client.AsyncBufferedMutatorBuilder
SharedAsyncConnection.getBufferedMutatorBuilder
(org.apache.hadoop.hbase.TableName tableName) org.apache.hadoop.hbase.client.AsyncBufferedMutatorBuilder
SharedAsyncConnection.getBufferedMutatorBuilder
(org.apache.hadoop.hbase.TableName tableName, ExecutorService pool) org.apache.hadoop.hbase.client.CompactionState
Admin.getCompactionState
(org.apache.hadoop.hbase.TableName tableName) Get the current compaction state of a table.org.apache.hadoop.hbase.client.CompactionState
Admin.getCompactionState
(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.CompactType compactType) Get the current compaction state of a table.default CompletableFuture<org.apache.hadoop.hbase.client.CompactionState>
AsyncAdmin.getCompactionState
(org.apache.hadoop.hbase.TableName tableName) Get the current compaction state of a table.CompletableFuture<org.apache.hadoop.hbase.client.CompactionState>
AsyncAdmin.getCompactionState
(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.CompactType compactType) Get the current compaction state of a table.org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshotView
Admin.getCurrentSpaceQuotaSnapshot
(org.apache.hadoop.hbase.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 org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshotView>
AsyncAdmin.getCurrentSpaceQuotaSnapshot
(org.apache.hadoop.hbase.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.org.apache.hadoop.hbase.client.TableDescriptor
Admin.getDescriptor
(org.apache.hadoop.hbase.TableName tableName) Get a table descriptor.CompletableFuture<org.apache.hadoop.hbase.client.TableDescriptor>
AsyncAdmin.getDescriptor
(org.apache.hadoop.hbase.TableName tableName) Method for getting the tableDescriptorlong
Admin.getLastMajorCompactionTimestamp
(org.apache.hadoop.hbase.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
(org.apache.hadoop.hbase.TableName tableName) Get the timestamp of the last major compaction for the passed table.CompletableFuture<org.apache.hadoop.hbase.RegionLocations>
AsyncClusterConnection.getRegionLocations
(org.apache.hadoop.hbase.TableName tableName, byte[] row, boolean reload) Return all the replicas for a region.org.apache.hadoop.hbase.client.AsyncTableRegionLocator
AsyncConnection.getRegionLocator
(org.apache.hadoop.hbase.TableName tableName) Retrieve a AsyncRegionLocator implementation to inspect region information on a table.org.apache.hadoop.hbase.client.AsyncTableRegionLocator
AsyncConnectionImpl.getRegionLocator
(org.apache.hadoop.hbase.TableName tableName) org.apache.hadoop.hbase.client.RegionLocator
Connection.getRegionLocator
(org.apache.hadoop.hbase.TableName tableName) Retrieve a RegionLocator implementation to inspect region information on a table.org.apache.hadoop.hbase.client.AsyncTableRegionLocator
SharedAsyncConnection.getRegionLocator
(org.apache.hadoop.hbase.TableName tableName) org.apache.hadoop.hbase.client.RegionLocator
SharedConnection.getRegionLocator
(org.apache.hadoop.hbase.TableName tableName) List<org.apache.hadoop.hbase.RegionMetrics>
Admin.getRegionMetrics
(org.apache.hadoop.hbase.ServerName serverName, org.apache.hadoop.hbase.TableName tableName) GetRegionMetrics
of all regions hosted on a regionserver for a table.CompletableFuture<List<org.apache.hadoop.hbase.RegionMetrics>>
AsyncAdmin.getRegionMetrics
(org.apache.hadoop.hbase.ServerName serverName, org.apache.hadoop.hbase.TableName tableName) Get a list ofRegionMetrics
of all regions hosted on a region server for a table.List<org.apache.hadoop.hbase.client.RegionInfo>
Admin.getRegions
(org.apache.hadoop.hbase.TableName tableName) Get the regions of a given table.CompletableFuture<List<org.apache.hadoop.hbase.client.RegionInfo>>
AsyncAdmin.getRegions
(org.apache.hadoop.hbase.TableName tableName) Get the regions of a given table.org.apache.hadoop.hbase.rsgroup.RSGroupInfo
Admin.getRSGroup
(org.apache.hadoop.hbase.TableName tableName) Get group info for the given tableCompletableFuture<org.apache.hadoop.hbase.rsgroup.RSGroupInfo>
AsyncAdmin.getRSGroup
(org.apache.hadoop.hbase.TableName tableName) Get group info for the given tabledefault org.apache.hadoop.hbase.client.AsyncTable<org.apache.hadoop.hbase.client.AdvancedScanResultConsumer>
AsyncConnection.getTable
(org.apache.hadoop.hbase.TableName tableName) Retrieve anAsyncTable
implementation for accessing a table.default org.apache.hadoop.hbase.client.AsyncTable<org.apache.hadoop.hbase.client.ScanResultConsumer>
AsyncConnection.getTable
(org.apache.hadoop.hbase.TableName tableName, ExecutorService pool) Retrieve anAsyncTable
implementation for accessing a table.default org.apache.hadoop.hbase.client.Table
Connection.getTable
(org.apache.hadoop.hbase.TableName tableName) Retrieve a Table implementation for accessing a table.default org.apache.hadoop.hbase.client.Table
Connection.getTable
(org.apache.hadoop.hbase.TableName tableName, ExecutorService pool) Retrieve a Table implementation for accessing a table.org.apache.hadoop.hbase.client.AsyncTableBuilder<org.apache.hadoop.hbase.client.AdvancedScanResultConsumer>
AsyncConnection.getTableBuilder
(org.apache.hadoop.hbase.TableName tableName) Returns anAsyncTableBuilder
for creatingAsyncTable
.org.apache.hadoop.hbase.client.AsyncTableBuilder<org.apache.hadoop.hbase.client.ScanResultConsumer>
AsyncConnection.getTableBuilder
(org.apache.hadoop.hbase.TableName tableName, ExecutorService pool) Returns anAsyncTableBuilder
for creatingAsyncTable
.org.apache.hadoop.hbase.client.AsyncTableBuilder<org.apache.hadoop.hbase.client.AdvancedScanResultConsumer>
AsyncConnectionImpl.getTableBuilder
(org.apache.hadoop.hbase.TableName tableName) org.apache.hadoop.hbase.client.AsyncTableBuilder<org.apache.hadoop.hbase.client.ScanResultConsumer>
AsyncConnectionImpl.getTableBuilder
(org.apache.hadoop.hbase.TableName tableName, ExecutorService pool) org.apache.hadoop.hbase.client.TableBuilder
Connection.getTableBuilder
(org.apache.hadoop.hbase.TableName tableName, ExecutorService pool) Returns anTableBuilder
for creatingTable
.org.apache.hadoop.hbase.client.AsyncTableBuilder<org.apache.hadoop.hbase.client.AdvancedScanResultConsumer>
SharedAsyncConnection.getTableBuilder
(org.apache.hadoop.hbase.TableName tableName) org.apache.hadoop.hbase.client.AsyncTableBuilder<org.apache.hadoop.hbase.client.ScanResultConsumer>
SharedAsyncConnection.getTableBuilder
(org.apache.hadoop.hbase.TableName tableName, ExecutorService pool) org.apache.hadoop.hbase.client.TableBuilder
SharedConnection.getTableBuilder
(org.apache.hadoop.hbase.TableName tableName, ExecutorService pool) boolean
Admin.isTableAvailable
(org.apache.hadoop.hbase.TableName tableName) Check if a table is available.AsyncAdmin.isTableAvailable
(org.apache.hadoop.hbase.TableName tableName) Check if a table is available.boolean
Admin.isTableDisabled
(org.apache.hadoop.hbase.TableName tableName) Check if a table is disabled.AsyncAdmin.isTableDisabled
(org.apache.hadoop.hbase.TableName tableName) Check if a table is disabled.boolean
Admin.isTableEnabled
(org.apache.hadoop.hbase.TableName tableName) Check if a table is enabled.AsyncAdmin.isTableEnabled
(org.apache.hadoop.hbase.TableName tableName) Check if a table is enabled.void
Admin.majorCompact
(org.apache.hadoop.hbase.TableName tableName) Major compact a table.void
Admin.majorCompact
(org.apache.hadoop.hbase.TableName tableName, byte[] columnFamily) Major compact a column family within a table.void
Admin.majorCompact
(org.apache.hadoop.hbase.TableName tableName, byte[] columnFamily, org.apache.hadoop.hbase.client.CompactType compactType) Major compact a column family within a table.void
Admin.majorCompact
(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.CompactType compactType) Major compact a table.default CompletableFuture<Void>
AsyncAdmin.majorCompact
(org.apache.hadoop.hbase.TableName tableName) Major compact a table.default CompletableFuture<Void>
AsyncAdmin.majorCompact
(org.apache.hadoop.hbase.TableName tableName, byte[] columnFamily) Major compact a column family within a table.AsyncAdmin.majorCompact
(org.apache.hadoop.hbase.TableName tableName, byte[] columnFamily, org.apache.hadoop.hbase.client.CompactType compactType) Major compact a column family within a table.AsyncAdmin.majorCompact
(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.CompactType compactType) Major compact a table.default void
Admin.modifyColumnFamily
(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.ColumnFamilyDescriptor columnFamily) Modify an existing column family on a table.AsyncAdmin.modifyColumnFamily
(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.ColumnFamilyDescriptor columnFamily) Modify an existing column family on a table.Admin.modifyColumnFamilyAsync
(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.ColumnFamilyDescriptor columnFamily) Modify an existing column family on a table.default void
Admin.modifyColumnFamilyStoreFileTracker
(org.apache.hadoop.hbase.TableName tableName, byte[] family, String dstSFT) Change the store file tracker of the given table's given family.AsyncAdmin.modifyColumnFamilyStoreFileTracker
(org.apache.hadoop.hbase.TableName tableName, byte[] family, String dstSFT) Change the store file tracker of the given table's given family.Admin.modifyColumnFamilyStoreFileTrackerAsync
(org.apache.hadoop.hbase.TableName tableName, byte[] family, String dstSFT) Change the store file tracker of the given table's given family.default void
Admin.modifyTableStoreFileTracker
(org.apache.hadoop.hbase.TableName tableName, String dstSFT) Change the store file tracker of the given table.AsyncAdmin.modifyTableStoreFileTracker
(org.apache.hadoop.hbase.TableName tableName, String dstSFT) Change the store file tracker of the given table.Admin.modifyTableStoreFileTrackerAsync
(org.apache.hadoop.hbase.TableName tableName, String dstSFT) Change the store file tracker of the given table.static org.apache.hadoop.hbase.client.RegionInfoBuilder
RegionInfoBuilder.newBuilder
(org.apache.hadoop.hbase.TableName tableName) static org.apache.hadoop.hbase.client.TableDescriptorBuilder
TableDescriptorBuilder.newBuilder
(org.apache.hadoop.hbase.TableName name) static org.apache.hadoop.hbase.client.TableState
TableState.parseFrom
(org.apache.hadoop.hbase.TableName tableName, byte[] bytes) AsyncClusterConnection.prepareBulkLoad
(org.apache.hadoop.hbase.TableName tableName) Return the token for this bulk load.default void
Admin.snapshot
(String snapshotName, org.apache.hadoop.hbase.TableName tableName) Take a snapshot for the given table.default void
Admin.snapshot
(String snapshotName, org.apache.hadoop.hbase.TableName tableName, Map<String, Object> snapshotProps) Create typed snapshot of the table.default void
Admin.snapshot
(String snapshotName, org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.SnapshotType type) Create typed snapshot of the table.default void
Admin.snapshot
(String snapshotName, org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.SnapshotType type, Map<String, Object> snapshotProps) Create typed snapshot of the table.default CompletableFuture<Void>
AsyncAdmin.snapshot
(String snapshotName, org.apache.hadoop.hbase.TableName tableName) Take a snapshot for the given table.default CompletableFuture<Void>
AsyncAdmin.snapshot
(String snapshotName, org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.SnapshotType type) Create typed snapshot of the table.void
Admin.split
(org.apache.hadoop.hbase.TableName tableName) Split a table.void
Admin.split
(org.apache.hadoop.hbase.TableName tableName, byte[] splitPoint) Split a table.AsyncAdmin.split
(org.apache.hadoop.hbase.TableName tableName) Split a table.AsyncAdmin.split
(org.apache.hadoop.hbase.TableName tableName, byte[] splitPoint) Split a table.boolean
Admin.tableExists
(org.apache.hadoop.hbase.TableName tableName) Check if a table exists.AsyncAdmin.tableExists
(org.apache.hadoop.hbase.TableName tableName) Check if a table exists.default void
Admin.truncateTable
(org.apache.hadoop.hbase.TableName tableName, boolean preserveSplits) Truncate a table.AsyncAdmin.truncateTable
(org.apache.hadoop.hbase.TableName tableName, boolean preserveSplits) Truncate a table.Admin.truncateTableAsync
(org.apache.hadoop.hbase.TableName tableName, boolean preserveSplits) Truncate the table but does not block and wait for it to be completely enabled.void
MetricsConnection.updateRpc
(org.apache.hbase.thirdparty.com.google.protobuf.Descriptors.MethodDescriptor method, org.apache.hadoop.hbase.TableName tableName, org.apache.hbase.thirdparty.com.google.protobuf.Message param, org.apache.hadoop.hbase.client.MetricsConnection.CallStats stats, Throwable e) Report RPC context to metrics system.Modifier and TypeMethodDescriptiondefault void
Admin.appendReplicationPeerTableCFs
(String id, Map<org.apache.hadoop.hbase.TableName, List<String>> tableCfs) Append the replicable table column family config from the specified peer.AsyncAdmin.appendReplicationPeerTableCFs
(String peerId, Map<org.apache.hadoop.hbase.TableName, List<String>> tableCfs) Append the replicable table-cf config of the specified peerList<org.apache.hadoop.hbase.client.TableDescriptor>
Admin.listTableDescriptors
(List<org.apache.hadoop.hbase.TableName> tableNames) Get tableDescriptors.CompletableFuture<List<org.apache.hadoop.hbase.client.TableDescriptor>>
AsyncAdmin.listTableDescriptors
(List<org.apache.hadoop.hbase.TableName> tableNames) List specific tables including system tables.default void
Admin.removeReplicationPeerTableCFs
(String id, Map<org.apache.hadoop.hbase.TableName, List<String>> tableCfs) Remove some table-cfs from config of the specified peer.AsyncAdmin.removeReplicationPeerTableCFs
(String peerId, Map<org.apache.hadoop.hbase.TableName, List<String>> tableCfs) Remove some table-cfs from config of the specified peervoid
Set the RegionServer group for tablesSet the RegionServer group for tablesorg.apache.hadoop.hbase.client.NormalizeTableFilterParams.Builder
NormalizeTableFilterParams.Builder.tableNames
(List<org.apache.hadoop.hbase.TableName> tableNames) ModifierConstructorDescriptionBufferedMutatorParams
(org.apache.hadoop.hbase.TableName tableName) SnapshotDescription
(String name, org.apache.hadoop.hbase.TableName table) SnapshotDescription
(String name, org.apache.hadoop.hbase.TableName table, org.apache.hadoop.hbase.client.SnapshotType type) SnapshotDescription
(String name, org.apache.hadoop.hbase.TableName table, org.apache.hadoop.hbase.client.SnapshotType type, String owner) SnapshotDescription
(String name, org.apache.hadoop.hbase.TableName table, org.apache.hadoop.hbase.client.SnapshotType type, String owner, long creationTime, int version) Deprecated.since 2.3.0 and will be removed in 4.0.0.SnapshotDescription
(String name, org.apache.hadoop.hbase.TableName table, org.apache.hadoop.hbase.client.SnapshotType type, String owner, long creationTime, int version, Map<String, Object> snapshotProps) SnapshotDescription Parameterized ConstructorSnapshotDescription
(String snapshotName, org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.SnapshotType type, Map<String, Object> snapshotProps) SnapshotDescription Parameterized ConstructorTableState
(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.TableState.State state) Create instance of TableState. -
Uses of org.apache.hadoop.hbase.TableName in org.apache.hadoop.hbase.client.example
Modifier and TypeMethodDescriptionvoid
RefreshHFilesClient.refreshHFiles
(org.apache.hadoop.hbase.TableName tableName) ModifierConstructorDescriptionReadExampleCallable
(org.apache.hadoop.hbase.client.Connection connection, org.apache.hadoop.hbase.TableName tableName) SingleWriteExampleCallable
(org.apache.hadoop.hbase.client.Connection connection, org.apache.hadoop.hbase.TableName tableName) WriteExampleCallable
(org.apache.hadoop.hbase.client.Connection connection, org.apache.hadoop.hbase.TableName tableName) -
Uses of org.apache.hadoop.hbase.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, org.apache.hadoop.hbase.TableName tableName, List<org.apache.hadoop.hbase.client.RegionInfo> regionInfos, String description, long nonceGroup, long nonce) org.apache.hadoop.hbase.client.locking.EntityLock
LockServiceClient.tableLock
(org.apache.hadoop.hbase.TableName tableName, boolean exclusive, String description, org.apache.hadoop.hbase.Abortable abort) Create a new EntityLock object to acquire an exclusive or shared lock on a table. -
Uses of org.apache.hadoop.hbase.TableName in org.apache.hadoop.hbase.client.replication
Modifier and TypeMethodDescriptionorg.apache.hadoop.hbase.TableName
TableCFs.getTable()
Modifier and TypeMethodDescriptionReplicationPeerConfigUtil.convert2Map
(org.apache.hadoop.hbase.shaded.protobuf.generated.ReplicationProtos.TableCF[] tableCFs) Convert tableCFs Object to Map.ReplicationPeerConfigUtil.parseTableCFsFromConfig
(String tableCFsConfig) Convert tableCFs string into Map.Modifier and TypeMethodDescriptionstatic org.apache.hadoop.hbase.replication.ReplicationPeerConfig
ReplicationPeerConfigUtil.appendExcludeTableCFsToReplicationPeerConfig
(Map<org.apache.hadoop.hbase.TableName, List<String>> excludeTableCfs, org.apache.hadoop.hbase.replication.ReplicationPeerConfig peerConfig) static org.apache.hadoop.hbase.replication.ReplicationPeerConfig
ReplicationPeerConfigUtil.appendTableCFsToReplicationPeerConfig
(Map<org.apache.hadoop.hbase.TableName, List<String>> tableCfs, org.apache.hadoop.hbase.replication.ReplicationPeerConfig peerConfig) static org.apache.hadoop.hbase.shaded.protobuf.generated.ReplicationProtos.TableCF[]
ReplicationPeerConfigUtil.convert
(Map<org.apache.hadoop.hbase.TableName, ? extends Collection<String>> tableCfs) convert map to TableCFs Objectstatic String
ReplicationPeerConfigUtil.convertToString
(Map<org.apache.hadoop.hbase.TableName, ? extends Collection<String>> tableCfs) static org.apache.hadoop.hbase.replication.ReplicationPeerConfig
ReplicationPeerConfigUtil.removeExcludeTableCFsFromReplicationPeerConfig
(Map<org.apache.hadoop.hbase.TableName, List<String>> excludeTableCfs, org.apache.hadoop.hbase.replication.ReplicationPeerConfig peerConfig, String id) static org.apache.hadoop.hbase.replication.ReplicationPeerConfig
ReplicationPeerConfigUtil.removeTableCFsFromReplicationPeerConfig
(Map<org.apache.hadoop.hbase.TableName, List<String>> tableCfs, org.apache.hadoop.hbase.replication.ReplicationPeerConfig peerConfig, String id) -
Uses of org.apache.hadoop.hbase.TableName in org.apache.hadoop.hbase.client.trace
Modifier and TypeMethodDescriptionorg.apache.hadoop.hbase.client.trace.TableOperationSpanBuilder
TableOperationSpanBuilder.setTableName
(org.apache.hadoop.hbase.TableName tableName) org.apache.hadoop.hbase.client.trace.TableSpanBuilder
TableSpanBuilder.setTableName
(org.apache.hadoop.hbase.TableName tableName) -
Uses of org.apache.hadoop.hbase.TableName in org.apache.hadoop.hbase.coprocessor
Modifier and TypeMethodDescriptiondefault void
MasterObserver.postCompletedDeleteTableAction
(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.MasterCoprocessorEnvironment> ctx, org.apache.hadoop.hbase.TableName tableName) Called afterHMaster
deletes a table.default void
MasterObserver.postCompletedDisableTableAction
(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.MasterCoprocessorEnvironment> ctx, org.apache.hadoop.hbase.TableName tableName) Called after the disableTable operation has been requested.default void
MasterObserver.postCompletedEnableTableAction
(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.MasterCoprocessorEnvironment> ctx, org.apache.hadoop.hbase.TableName tableName) Called after the enableTable operation has been requested.default void
MasterObserver.postCompletedModifyTableAction
(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.MasterCoprocessorEnvironment> ctx, org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.TableDescriptor oldDescriptor, org.apache.hadoop.hbase.client.TableDescriptor currentDescriptor) Called after to modifying a table's properties.default void
MasterObserver.postCompletedTruncateTableAction
(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.MasterCoprocessorEnvironment> ctx, org.apache.hadoop.hbase.TableName tableName) Called afterHMaster
truncates a table.default void
MasterObserver.postDeleteTable
(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.MasterCoprocessorEnvironment> ctx, org.apache.hadoop.hbase.TableName tableName) Called after the deleteTable operation has been requested.default void
MasterObserver.postDisableTable
(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.MasterCoprocessorEnvironment> ctx, org.apache.hadoop.hbase.TableName tableName) Called after the disableTable operation has been requested.default void
MasterObserver.postEnableTable
(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.MasterCoprocessorEnvironment> ctx, org.apache.hadoop.hbase.TableName tableName) Called after the enableTable operation has been requested.default void
MasterObserver.postGetRSGroupInfoOfTable
(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.MasterCoprocessorEnvironment> ctx, org.apache.hadoop.hbase.TableName tableName) Called after getting region server group info of the passed tableName.default void
MasterObserver.postGetUserPermissions
(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.MasterCoprocessorEnvironment> ctx, String userName, String namespace, org.apache.hadoop.hbase.TableName tableName, byte[] family, byte[] qualifier) Called after getting user permissions.default void
MasterObserver.postModifyColumnFamilyStoreFileTracker
(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.MasterCoprocessorEnvironment> ctx, org.apache.hadoop.hbase.TableName tableName, byte[] family, String dstSFT) Called after modifying a family store file tracker.default void
MasterObserver.postModifyTable
(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.MasterCoprocessorEnvironment> ctx, org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.TableDescriptor oldDescriptor, org.apache.hadoop.hbase.client.TableDescriptor currentDescriptor) Called after the modifyTable operation has been requested.default void
MasterObserver.postModifyTableStoreFileTracker
(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.MasterCoprocessorEnvironment> ctx, org.apache.hadoop.hbase.TableName tableName, String dstSFT) Called after modifying a table's store file tracker.default void
MasterObserver.postRequestLock
(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.MasterCoprocessorEnvironment> ctx, String namespace, org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.RegionInfo[] regionInfos, String description) Called after new LockProcedure is queued.default void
MasterObserver.postSetTableQuota
(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.MasterCoprocessorEnvironment> ctx, org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.quotas.GlobalQuotaSettings quotas) Called after the quota for the table is stored.default void
MasterObserver.postSetUserQuota
(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.MasterCoprocessorEnvironment> ctx, String userName, org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.quotas.GlobalQuotaSettings quotas) Called after the quota for the user on the specified table is stored.default void
MasterObserver.postTableFlush
(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.MasterCoprocessorEnvironment> ctx, org.apache.hadoop.hbase.TableName tableName) Called after the table memstore is flushed to disk.default void
MasterObserver.postTruncateTable
(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.MasterCoprocessorEnvironment> ctx, org.apache.hadoop.hbase.TableName tableName) Called after the truncateTable operation has been requested.default void
MasterObserver.preDeleteTable
(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.MasterCoprocessorEnvironment> ctx, org.apache.hadoop.hbase.TableName tableName) Called beforeHMaster
deletes a table.default void
MasterObserver.preDeleteTableAction
(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.MasterCoprocessorEnvironment> ctx, org.apache.hadoop.hbase.TableName tableName) Called beforeHMaster
deletes a table.default void
MasterObserver.preDisableTable
(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.MasterCoprocessorEnvironment> ctx, org.apache.hadoop.hbase.TableName tableName) Called prior to disabling a table.default void
MasterObserver.preDisableTableAction
(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.MasterCoprocessorEnvironment> ctx, org.apache.hadoop.hbase.TableName tableName) Called prior to disabling a table.default void
MasterObserver.preEnableTable
(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.MasterCoprocessorEnvironment> ctx, org.apache.hadoop.hbase.TableName tableName) Called prior to enabling a table.default void
MasterObserver.preEnableTableAction
(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.MasterCoprocessorEnvironment> ctx, org.apache.hadoop.hbase.TableName tableName) Called prior to enabling a table.default void
MasterObserver.preGetRSGroupInfoOfTable
(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.MasterCoprocessorEnvironment> ctx, org.apache.hadoop.hbase.TableName tableName) Called before getting region server group info of the passed tableName.default void
MasterObserver.preGetUserPermissions
(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.MasterCoprocessorEnvironment> ctx, String userName, String namespace, org.apache.hadoop.hbase.TableName tableName, byte[] family, byte[] qualifier) Called before getting user permissions.default void
MasterObserver.preLockHeartbeat
(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.MasterCoprocessorEnvironment> ctx, org.apache.hadoop.hbase.TableName tn, String description) Called before heartbeat to a lock.default String
MasterObserver.preModifyColumnFamilyStoreFileTracker
(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.MasterCoprocessorEnvironment> ctx, org.apache.hadoop.hbase.TableName tableName, byte[] family, String dstSFT) Called prior to modifying a family's store file tracker.default org.apache.hadoop.hbase.client.TableDescriptor
MasterObserver.preModifyTable
(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.MasterCoprocessorEnvironment> ctx, org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.TableDescriptor currentDescriptor, org.apache.hadoop.hbase.client.TableDescriptor newDescriptor) Called prior to modifying a table's properties.default void
MasterObserver.preModifyTableAction
(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.MasterCoprocessorEnvironment> ctx, org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.TableDescriptor currentDescriptor, org.apache.hadoop.hbase.client.TableDescriptor newDescriptor) Called prior to modifying a table's properties.default String
MasterObserver.preModifyTableStoreFileTracker
(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.MasterCoprocessorEnvironment> ctx, org.apache.hadoop.hbase.TableName tableName, String dstSFT) Called prior to modifying a table's store file tracker.default void
MasterObserver.preRequestLock
(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.MasterCoprocessorEnvironment> ctx, String namespace, org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.RegionInfo[] regionInfos, String description) Called before new LockProcedure is queued.default void
MasterObserver.preSetTableQuota
(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.MasterCoprocessorEnvironment> ctx, org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.quotas.GlobalQuotaSettings quotas) Called before the quota for the table is stored.default void
MasterObserver.preSetUserQuota
(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.MasterCoprocessorEnvironment> ctx, String userName, org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.quotas.GlobalQuotaSettings quotas) Called before the quota for the user on the specified table is stored.default void
MasterObserver.preSplitRegion
(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.MasterCoprocessorEnvironment> c, org.apache.hadoop.hbase.TableName tableName, byte[] splitRow) Called before the split region procedure is called.default void
MasterObserver.preSplitRegionAction
(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.MasterCoprocessorEnvironment> c, org.apache.hadoop.hbase.TableName tableName, byte[] splitRow) Called before the region is split.default void
MasterObserver.preTableFlush
(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.MasterCoprocessorEnvironment> ctx, org.apache.hadoop.hbase.TableName tableName) Called before the table memstore is flushed to disk.default void
MasterObserver.preTruncateTable
(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.MasterCoprocessorEnvironment> ctx, org.apache.hadoop.hbase.TableName tableName) Called beforeHMaster
truncates a table.default void
MasterObserver.preTruncateTableAction
(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.MasterCoprocessorEnvironment> ctx, org.apache.hadoop.hbase.TableName tableName) Called beforeHMaster
truncates a table.Modifier and TypeMethodDescriptiondefault void
MasterObserver.postGetTableDescriptors
(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.MasterCoprocessorEnvironment> ctx, List<org.apache.hadoop.hbase.TableName> tableNamesList, List<org.apache.hadoop.hbase.client.TableDescriptor> descriptors, String regex) Called after a getTableDescriptors request has been processed.default void
MasterObserver.postMoveTables
(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.MasterCoprocessorEnvironment> ctx, Set<org.apache.hadoop.hbase.TableName> tables, String targetGroup) Called after servers are moved to target region server groupdefault void
MasterObserver.preGetTableDescriptors
(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.MasterCoprocessorEnvironment> ctx, List<org.apache.hadoop.hbase.TableName> tableNamesList, List<org.apache.hadoop.hbase.client.TableDescriptor> descriptors, String regex) Called before a getTableDescriptors request has been processed.default void
MasterObserver.preMoveTables
(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.MasterCoprocessorEnvironment> ctx, Set<org.apache.hadoop.hbase.TableName> tables, String targetGroup) Called before tables are moved to target region server group -
Uses of org.apache.hadoop.hbase.TableName in org.apache.hadoop.hbase.favored
-
Uses of org.apache.hadoop.hbase.TableName in org.apache.hadoop.hbase.io
Modifier and TypeMethodDescriptionstatic org.apache.hadoop.hbase.TableName
HFileLink.getReferencedTableName
(String fileName) Get the Table name of the referenced linkModifier and TypeMethodDescriptionstatic org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.TableName,
String> HFileLink.parseBackReferenceName
(String name) Modifier and TypeMethodDescriptionstatic org.apache.hadoop.hbase.io.HFileLink
HFileLink.build
(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.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, org.apache.hadoop.hbase.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, org.apache.hadoop.hbase.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, org.apache.hadoop.hbase.TableName linkedTable, String linkedRegion, String hfileName, boolean createBackRef) Create a new HFileLink.static String
HFileLink.createHFileLinkName
(org.apache.hadoop.hbase.TableName tableName, String regionName, String hfileName) Create a new HFileLink namestatic org.apache.hadoop.fs.Path
HFileLink.createPath
(org.apache.hadoop.hbase.TableName table, String region, String family, String hfile) Create an HFileLink relative path for the table/region/family/hfile location -
Uses of org.apache.hadoop.hbase.TableName in org.apache.hadoop.hbase.ipc
Modifier and TypeMethodDescriptionorg.apache.hadoop.hbase.TableName
DelegatingHBaseRpcController.getTableName()
default org.apache.hadoop.hbase.TableName
HBaseRpcController.getTableName()
Returns Region's table name or null if not available or pertinent.org.apache.hadoop.hbase.TableName
HBaseRpcControllerImpl.getTableName()
Modifier and TypeMethodDescriptionvoid
DelegatingHBaseRpcController.setPriority
(org.apache.hadoop.hbase.TableName tn) void
HBaseRpcController.setPriority
(org.apache.hadoop.hbase.TableName tn) Set the priority for this operation.void
HBaseRpcControllerImpl.setPriority
(org.apache.hadoop.hbase.TableName tn) void
DelegatingHBaseRpcController.setTableName
(org.apache.hadoop.hbase.TableName tableName) default void
HBaseRpcController.setTableName
(org.apache.hadoop.hbase.TableName tableName) Sets Region's table name.void
HBaseRpcControllerImpl.setTableName
(org.apache.hadoop.hbase.TableName tableName) -
Uses of org.apache.hadoop.hbase.TableName in org.apache.hadoop.hbase.mapred
Modifier and TypeMethodDescriptionorg.apache.hadoop.hbase.TableName
TableSplit.getTable()
Returns table nameModifier and TypeMethodDescriptionprotected void
TableInputFormatBase.initializeTable
(org.apache.hadoop.hbase.client.Connection connection, org.apache.hadoop.hbase.TableName tableName) Allows subclasses to initialize the table information.ModifierConstructorDescriptionTableSplit
(org.apache.hadoop.hbase.TableName tableName, byte[] startRow, byte[] endRow, String location) Constructor -
Uses of org.apache.hadoop.hbase.TableName in org.apache.hadoop.hbase.mapreduce
Modifier and TypeMethodDescriptionorg.apache.hadoop.hbase.TableName
TableSplit.getTable()
Returns the table name.Modifier and TypeMethodDescriptionstatic org.apache.hadoop.hbase.util.Triple<org.apache.hadoop.hbase.TableName,
org.apache.hadoop.hbase.client.Scan, org.apache.hadoop.fs.Path> ExportUtils.getArgumentsFromCommandLine
(org.apache.hadoop.conf.Configuration conf, String[] args) Modifier and TypeMethodDescriptionstatic void
TableInputFormat.configureSplitTable
(org.apache.hadoop.mapreduce.Job job, org.apache.hadoop.hbase.TableName tableName) Sets split table in map-reduce job.protected void
TableInputFormatBase.initializeTable
(org.apache.hadoop.hbase.client.Connection connection, org.apache.hadoop.hbase.TableName tableName) Allows subclasses to initialize the table information.static void
TableMapReduceUtil.initTableMapperJob
(org.apache.hadoop.hbase.TableName table, org.apache.hadoop.hbase.client.Scan scan, Class<? extends org.apache.hadoop.hbase.mapreduce.TableMapper> mapper, Class<?> outputKeyClass, Class<?> outputValueClass, org.apache.hadoop.mapreduce.Job job) Use this before submitting a TableMap job.ModifierConstructorDescriptionTableSplit
(org.apache.hadoop.hbase.TableName tableName, byte[] startRow, byte[] endRow, String location) Creates a new instance without a scanner.TableSplit
(org.apache.hadoop.hbase.TableName tableName, byte[] startRow, byte[] endRow, String location, long length) Creates a new instance without a scanner.TableSplit
(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.Scan scan, byte[] startRow, byte[] endRow, String location) Creates a new instance while assigning all variables.TableSplit
(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.Scan scan, byte[] startRow, byte[] endRow, String location, long length) Creates a new instance while assigning all variables.TableSplit
(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.Scan scan, byte[] startRow, byte[] endRow, String location, String encodedRegionName, long length) Creates a new instance while assigning all variables. -
Uses of org.apache.hadoop.hbase.TableName in org.apache.hadoop.hbase.master
Modifier and TypeMethodDescriptionRegionPlacementMaintainer.getRegionsMovement
(org.apache.hadoop.hbase.favored.FavoredNodesPlan newPlan) Return how many regions will move per table since their primary RS will changeSet<org.apache.hadoop.hbase.TableName>
SnapshotOfRegionAssignmentFromMeta.getTableSet()
Get the table setSnapshotOfRegionAssignmentFromMeta.getTableToRegionMap()
Get regions for tablesList<org.apache.hadoop.hbase.TableName>
Returns the list of table names that match the specified requestList<org.apache.hadoop.hbase.TableName>
HMaster.listTableNamesByNamespace
(String name) List<org.apache.hadoop.hbase.TableName>
MasterServices.listTableNamesByNamespace
(String name) Get list of table names by namespaceModifier and TypeMethodDescriptionlong
HMaster.addColumn
(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.ColumnFamilyDescriptor column, long nonceGroup, long nonce) long
MasterServices.addColumn
(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.ColumnFamilyDescriptor column, long nonceGroup, long nonce) Add a new column to an existing tablevoid
HMaster.checkTableModifiable
(org.apache.hadoop.hbase.TableName tableName) void
MasterServices.checkTableModifiable
(org.apache.hadoop.hbase.TableName tableName) Check table is modifiable; i.e.long
HMaster.deleteColumn
(org.apache.hadoop.hbase.TableName tableName, byte[] columnName, long nonceGroup, long nonce) long
MasterServices.deleteColumn
(org.apache.hadoop.hbase.TableName tableName, byte[] columnName, long nonceGroup, long nonce) Delete a column from an existing tablelong
HMaster.deleteTable
(org.apache.hadoop.hbase.TableName tableName, long nonceGroup, long nonce) long
MasterServices.deleteTable
(org.apache.hadoop.hbase.TableName tableName, long nonceGroup, long nonce) Delete a tablelong
HMaster.disableTable
(org.apache.hadoop.hbase.TableName tableName, long nonceGroup, long nonce) long
MasterServices.disableTable
(org.apache.hadoop.hbase.TableName tableName, long nonceGroup, long nonce) Disable an existing tablelong
HMaster.enableTable
(org.apache.hadoop.hbase.TableName tableName, long nonceGroup, long nonce) long
MasterServices.enableTable
(org.apache.hadoop.hbase.TableName tableName, long nonceGroup, long nonce) Enable an existing tablevoid
AssignmentVerificationReport.fillUp
(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.master.SnapshotOfRegionAssignmentFromMeta snapshot, Map<String, Map<String, Float>> regionLocalityMap) void
AssignmentVerificationReport.fillUpDispersion
(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.master.SnapshotOfRegionAssignmentFromMeta snapshot, org.apache.hadoop.hbase.favored.FavoredNodesPlan newPlan) Use this to project the dispersion scoreslong
HMaster.flushTable
(org.apache.hadoop.hbase.TableName tableName, List<byte[]> columnFamilies, long nonceGroup, long nonce) long
MasterServices.flushTable
(org.apache.hadoop.hbase.TableName tableName, List<byte[]> columnFamilies, long nonceGroup, long nonce) Flush an existing tableorg.apache.hadoop.hbase.client.CompactionState
HMaster.getCompactionState
(org.apache.hadoop.hbase.TableName tableName) Get the compaction state of the tablelong
HMaster.getLastMajorCompactionTimestamp
(org.apache.hadoop.hbase.TableName table) long
MasterServices.getLastMajorCompactionTimestamp
(org.apache.hadoop.hbase.TableName table) org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.GetRegionInfoResponse.CompactionState
HMaster.getMobCompactionState
(org.apache.hadoop.hbase.TableName tableName) Gets the mob file compaction state for a specific table.org.apache.hadoop.hbase.client.TableState
TableStateManager.getTableState
(org.apache.hadoop.hbase.TableName tableName) boolean
TableStateManager.isTablePresent
(org.apache.hadoop.hbase.TableName tableName) boolean
TableStateManager.isTableState
(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.TableState.State... states) long
HMaster.modifyColumn
(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.ColumnFamilyDescriptor descriptor, long nonceGroup, long nonce) long
MasterServices.modifyColumn
(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.ColumnFamilyDescriptor descriptor, long nonceGroup, long nonce) Modify the column descriptor of an existing column in an existing tablelong
HMaster.modifyColumnStoreFileTracker
(org.apache.hadoop.hbase.TableName tableName, byte[] family, String dstSFT, long nonceGroup, long nonce) long
MasterServices.modifyColumnStoreFileTracker
(org.apache.hadoop.hbase.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
(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.TableDescriptor newDescriptor, long nonceGroup, long nonce, boolean reopenRegions) default long
MasterServices.modifyTable
(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.TableDescriptor descriptor, long nonceGroup, long nonce) Modify the descriptor of an existing tablelong
MasterServices.modifyTable
(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.TableDescriptor descriptor, long nonceGroup, long nonce, boolean reopenRegions) Modify the descriptor of an existing tablelong
HMaster.modifyTableStoreFileTracker
(org.apache.hadoop.hbase.TableName tableName, String dstSFT, long nonceGroup, long nonce) long
MasterServices.modifyTableStoreFileTracker
(org.apache.hadoop.hbase.TableName tableName, String dstSFT, long nonceGroup, long nonce) Modify the store file tracker of an existing tablevoid
MasterCoprocessorHost.postCompletedDeleteTableAction
(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.security.User user) void
MasterCoprocessorHost.postCompletedDisableTableAction
(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.security.User user) void
MasterCoprocessorHost.postCompletedEnableTableAction
(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.security.User user) void
MasterCoprocessorHost.postCompletedModifyTableAction
(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.TableDescriptor oldDescriptor, org.apache.hadoop.hbase.client.TableDescriptor currentDescriptor, org.apache.hadoop.hbase.security.User user) void
MasterCoprocessorHost.postCompletedTruncateTableAction
(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.security.User user) void
MasterCoprocessorHost.postDeleteTable
(org.apache.hadoop.hbase.TableName tableName) void
MasterCoprocessorHost.postDisableTable
(org.apache.hadoop.hbase.TableName tableName) void
MasterCoprocessorHost.postEnableTable
(org.apache.hadoop.hbase.TableName tableName) void
MasterCoprocessorHost.postGetRSGroupInfoOfTable
(org.apache.hadoop.hbase.TableName tableName) void
MasterCoprocessorHost.postGetUserPermissions
(String userName, String namespace, org.apache.hadoop.hbase.TableName tableName, byte[] family, byte[] qualifier) void
MasterCoprocessorHost.postModifyColumnFamilyStoreFileTracker
(org.apache.hadoop.hbase.TableName tableName, byte[] family, String dstSFT) void
MasterCoprocessorHost.postModifyTable
(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.TableDescriptor oldDescriptor, org.apache.hadoop.hbase.client.TableDescriptor currentDescriptor) void
MasterCoprocessorHost.postModifyTableStoreFileTracker
(org.apache.hadoop.hbase.TableName tableName, String dstSFT) void
MasterCoprocessorHost.postRequestLock
(String namespace, org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.RegionInfo[] regionInfos, org.apache.hadoop.hbase.procedure2.LockType type, String description) void
MasterCoprocessorHost.postSetTableQuota
(org.apache.hadoop.hbase.TableName table, org.apache.hadoop.hbase.quotas.GlobalQuotaSettings quotas) void
MasterCoprocessorHost.postSetUserQuota
(String user, org.apache.hadoop.hbase.TableName table, org.apache.hadoop.hbase.quotas.GlobalQuotaSettings quotas) void
MasterCoprocessorHost.postTableFlush
(org.apache.hadoop.hbase.TableName tableName) void
MasterCoprocessorHost.postTruncateTable
(org.apache.hadoop.hbase.TableName tableName) void
MasterCoprocessorHost.preDeleteTable
(org.apache.hadoop.hbase.TableName tableName) void
MasterCoprocessorHost.preDeleteTableAction
(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.security.User user) void
MasterCoprocessorHost.preDisableTable
(org.apache.hadoop.hbase.TableName tableName) void
MasterCoprocessorHost.preDisableTableAction
(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.security.User user) void
MasterCoprocessorHost.preEnableTable
(org.apache.hadoop.hbase.TableName tableName) void
MasterCoprocessorHost.preEnableTableAction
(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.security.User user) void
MasterCoprocessorHost.preGetRSGroupInfoOfTable
(org.apache.hadoop.hbase.TableName tableName) void
MasterCoprocessorHost.preGetUserPermissions
(String userName, String namespace, org.apache.hadoop.hbase.TableName tableName, byte[] family, byte[] qualifier) MasterCoprocessorHost.preModifyColumnFamilyStoreFileTracker
(org.apache.hadoop.hbase.TableName tableName, byte[] family, String dstSFT) org.apache.hadoop.hbase.client.TableDescriptor
MasterCoprocessorHost.preModifyTable
(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.TableDescriptor currentDescriptor, org.apache.hadoop.hbase.client.TableDescriptor newDescriptor) void
MasterCoprocessorHost.preModifyTableAction
(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.TableDescriptor currentDescriptor, org.apache.hadoop.hbase.client.TableDescriptor newDescriptor, org.apache.hadoop.hbase.security.User user) MasterCoprocessorHost.preModifyTableStoreFileTracker
(org.apache.hadoop.hbase.TableName tableName, String dstSFT) void
MasterCoprocessorHost.preRequestLock
(String namespace, org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.RegionInfo[] regionInfos, org.apache.hadoop.hbase.procedure2.LockType type, String description) void
MasterCoprocessorHost.preSetTableQuota
(org.apache.hadoop.hbase.TableName table, org.apache.hadoop.hbase.quotas.GlobalQuotaSettings quotas) void
MasterCoprocessorHost.preSetUserQuota
(String user, org.apache.hadoop.hbase.TableName table, org.apache.hadoop.hbase.quotas.GlobalQuotaSettings quotas) void
MasterCoprocessorHost.preSplitRegion
(org.apache.hadoop.hbase.TableName tableName, byte[] splitRow) Invoked just before calling the split region procedurevoid
MasterCoprocessorHost.preSplitRegionAction
(org.apache.hadoop.hbase.TableName tableName, byte[] splitRow, org.apache.hadoop.hbase.security.User user) Invoked just before a splitvoid
MasterCoprocessorHost.preTableFlush
(org.apache.hadoop.hbase.TableName tableName) void
MasterCoprocessorHost.preTruncateTable
(org.apache.hadoop.hbase.TableName tableName) void
MasterCoprocessorHost.preTruncateTableAction
(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.security.User user) void
RegionPlacementMaintainer.printDispersionScores
(org.apache.hadoop.hbase.TableName table, org.apache.hadoop.hbase.master.SnapshotOfRegionAssignmentFromMeta snapshot, int numRegions, org.apache.hadoop.hbase.favored.FavoredNodesPlan newPlan, boolean simplePrint) void
HMaster.reportMobCompactionEnd
(org.apache.hadoop.hbase.TableName tableName) void
HMaster.reportMobCompactionStart
(org.apache.hadoop.hbase.TableName tableName) void
TableStateManager.setDeletedTable
(org.apache.hadoop.hbase.TableName tableName) void
TableStateManager.setTableState
(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.TableState.State newState) Set table state to provided.long
HMaster.truncateTable
(org.apache.hadoop.hbase.TableName tableName, boolean preserveSplits, long nonceGroup, long nonce) long
MasterServices.truncateTable
(org.apache.hadoop.hbase.TableName tableName, boolean preserveSplits, long nonceGroup, long nonce) Truncate a tableModifier and TypeMethodDescriptionList<org.apache.hadoop.hbase.master.RegionPlan>
LoadBalancer.balanceCluster
(Map<org.apache.hadoop.hbase.TableName, Map<org.apache.hadoop.hbase.ServerName, List<org.apache.hadoop.hbase.client.RegionInfo>>> loadOfAllTable) Perform the major balance operation for cluster.void
RegionPlacementMaintainer.checkDifferencesWithOldPlan
(Map<org.apache.hadoop.hbase.TableName, Integer> movesPerTable, Map<String, Map<String, Float>> regionLocalityMap, org.apache.hadoop.hbase.favored.FavoredNodesPlan newPlan) Compares two plans and check whether the locality dropped or increased (prints the information as a string) also prints the baseline localityList<org.apache.hadoop.hbase.client.TableDescriptor>
HMaster.listTableDescriptors
(String namespace, String regex, List<org.apache.hadoop.hbase.TableName> tableNameList, boolean includeSysTables) Returns the list of table descriptors that match the specified requestvoid
MasterCoprocessorHost.postGetTableDescriptors
(List<org.apache.hadoop.hbase.TableName> tableNamesList, List<org.apache.hadoop.hbase.client.TableDescriptor> descriptors, String regex) void
MasterCoprocessorHost.postMoveTables
(Set<org.apache.hadoop.hbase.TableName> tables, String targetGroup) void
MasterCoprocessorHost.preGetTableDescriptors
(List<org.apache.hadoop.hbase.TableName> tableNamesList, List<org.apache.hadoop.hbase.client.TableDescriptor> descriptors, String regex) void
MasterCoprocessorHost.preMoveTables
(Set<org.apache.hadoop.hbase.TableName> tables, String targetGroup) default void
LoadBalancer.updateBalancerLoadInfo
(Map<org.apache.hadoop.hbase.TableName, Map<org.apache.hadoop.hbase.ServerName, List<org.apache.hadoop.hbase.client.RegionInfo>>> loadOfAllTable) In some scenarios, Balancer needs to update internal status or information according to the current tables loadModifierConstructorDescriptionSnapshotOfRegionAssignmentFromMeta
(org.apache.hadoop.hbase.client.Connection connection, Set<org.apache.hadoop.hbase.TableName> disabledTables, boolean excludeOfflinedSplitParents) -
Uses of org.apache.hadoop.hbase.TableName in org.apache.hadoop.hbase.mob
Modifier and TypeMethodDescriptionstatic org.apache.hbase.thirdparty.com.google.common.collect.ImmutableSetMultimap.Builder<org.apache.hadoop.hbase.TableName,
String> MobUtils.deserializeMobFileRefs
(byte[] bytes) Deserialize the set of referenced mob hfiles from store file metadata.static Optional<org.apache.hadoop.hbase.TableName>
MobUtils.getTableName
(org.apache.hadoop.hbase.ExtendedCell cell) Get the table name from when this cell was written into a mob hfile as a TableName.Modifier and TypeMethodDescriptionvoid
RSMobFileCleanerChore.archiveMobFiles
(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.TableName tableName, byte[] family, List<org.apache.hadoop.fs.Path> storeFiles) Archives the mob files.static void
MobFileCleanupUtil.cleanupObsoleteMobFiles
(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.TableName table, org.apache.hadoop.hbase.client.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, org.apache.hadoop.hbase.TableName tableName, String familyName) Gets the family dir of the mob files.static org.apache.hadoop.hbase.client.RegionInfo
MobUtils.getMobRegionInfo
(org.apache.hadoop.hbase.TableName tableName) Gets the RegionInfo of the mob files.static org.apache.hadoop.fs.Path
MobUtils.getMobRegionPath
(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.TableName tableName) Gets the region dir of the mob files.static org.apache.hadoop.fs.Path
MobUtils.getMobRegionPath
(org.apache.hadoop.fs.Path rootDir, org.apache.hadoop.hbase.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.conf.Configuration conf, org.apache.hadoop.hbase.TableName tableName) static org.apache.hadoop.fs.Path
MobUtils.getMobTableDir
(org.apache.hadoop.fs.Path rootDir, org.apache.hadoop.hbase.TableName tableName) Gets the table dir of the mob files under the qualified HBase root dir.static boolean
MobUtils.isMobRegionName
(org.apache.hadoop.hbase.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, org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.fs.Path tableDir, byte[] family, Collection<org.apache.hadoop.hbase.regionserver.HStoreFile> storeFiles) Archives the mob files.Modifier and TypeMethodDescriptionstatic byte[]
MobUtils.serializeMobFileRefs
(org.apache.hbase.thirdparty.com.google.common.collect.SetMultimap<org.apache.hadoop.hbase.TableName, String> mobRefSet) Serialize a set of referenced mob hfiles -
Uses of org.apache.hadoop.hbase.TableName in org.apache.hadoop.hbase.namequeues
Modifier and TypeFieldDescriptionstatic final org.apache.hadoop.hbase.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 org.apache.hadoop.hbase.TableName in org.apache.hadoop.hbase.namespace
Modifier and TypeMethodDescriptionvoid
NamespaceAuditor.checkQuotaToCreateTable
(org.apache.hadoop.hbase.TableName tName, int regions) Check quota to create table.void
NamespaceAuditor.checkQuotaToUpdateRegion
(org.apache.hadoop.hbase.TableName tName, int regions) Check and update region count quota for an existing table.int
NamespaceAuditor.getRegionCountOfTable
(org.apache.hadoop.hbase.TableName tName) Get region count for tablevoid
NamespaceAuditor.removeFromNamespaceUsage
(org.apache.hadoop.hbase.TableName tableName) -
Uses of org.apache.hadoop.hbase.TableName in org.apache.hadoop.hbase.quotas
Modifier and TypeFieldDescriptionstatic final org.apache.hadoop.hbase.TableName
QuotaTableUtil.QUOTA_TABLE_NAME
System table for quotasModifier and TypeMethodDescriptionprotected static org.apache.hadoop.hbase.TableName
QuotaTableUtil.getTableFromRowKey
(byte[] key) org.apache.hadoop.hbase.TableName
QuotaSettings.getTableName()
Modifier and TypeMethodDescriptionMap<org.apache.hadoop.hbase.TableName,
org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot> RegionServerSpaceQuotaManager.copyQuotaSnapshots()
Copies the lastSpaceQuotaSnapshot
s that were recorded.Map<org.apache.hadoop.hbase.TableName,
org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot> SpaceQuotaRefresherChore.fetchSnapshotsFromQuotaTable()
Reads all quota snapshots from the quota table.static Map<org.apache.hadoop.hbase.TableName,
org.apache.hadoop.hbase.quotas.QuotaState> QuotaUtil.fetchTableQuotas
(org.apache.hadoop.hbase.client.Connection connection, List<org.apache.hadoop.hbase.client.Get> gets, Map<org.apache.hadoop.hbase.TableName, Double> tableMachineFactors) Map<org.apache.hadoop.hbase.TableName,
org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot> RegionServerSpaceQuotaManager.getActivePoliciesAsMap()
Converts a map of table toSpaceViolationPolicyEnforcement
s intoSpaceViolationPolicy
s.Map<org.apache.hadoop.hbase.TableName,
org.apache.hadoop.hbase.quotas.SpaceViolationPolicyEnforcement> ActivePolicyEnforcement.getPolicies()
Returns an unmodifiable version of the activeSpaceViolationPolicyEnforcement
s.static Map<org.apache.hadoop.hbase.TableName,
org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot> QuotaTableUtil.getSnapshots
(org.apache.hadoop.hbase.client.Connection conn) Fetches allSpaceQuotaSnapshot
objects from thehbase:quota
table.Map<org.apache.hadoop.hbase.TableName,
org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot> QuotaObserverChore.getTableQuotaSnapshots()
Returns an unmodifiable view over the currentSpaceQuotaSnapshot
objects for each HBase table with a quota defined.static org.apache.hbase.thirdparty.com.google.common.collect.Multimap<org.apache.hadoop.hbase.TableName,
String> QuotaTableUtil.getTableSnapshots
(org.apache.hadoop.hbase.client.Connection conn) Returns a multimap for all existing table snapshot entries.Modifier and TypeMethodDescriptionstatic void
QuotaUtil.addTableQuota
(org.apache.hadoop.hbase.client.Connection connection, org.apache.hadoop.hbase.TableName table, org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Quotas data) static void
QuotaUtil.addUserQuota
(org.apache.hadoop.hbase.client.Connection connection, String user, org.apache.hadoop.hbase.TableName table, org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Quotas data) boolean
RegionServerSpaceQuotaManager.areCompactionsDisabled
(org.apache.hadoop.hbase.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
(org.apache.hadoop.hbase.TableName tn, Collection<Map.Entry<String, Long>> archivedFiles) Builds the protobuf message to inform the Master of files being archived.void
MasterQuotaManager.checkAndUpdateNamespaceRegionQuota
(org.apache.hadoop.hbase.TableName tName, int regions) void
MasterQuotaManager.checkNamespaceTableAndRegionQuota
(org.apache.hadoop.hbase.TableName tName, int regions) org.apache.hadoop.hbase.quotas.SpaceViolationPolicyEnforcement
SpaceViolationPolicyEnforcementFactory.create
(org.apache.hadoop.hbase.regionserver.RegionServerServices rss, org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot snapshot) Constructs the appropriateSpaceViolationPolicyEnforcement
for tables that are in violation of their space quota.org.apache.hadoop.hbase.quotas.SpaceViolationPolicyEnforcement
SpaceViolationPolicyEnforcementFactory.createWithoutViolation
(org.apache.hadoop.hbase.regionserver.RegionServerServices rss, org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot snapshot) Creates the "default"SpaceViolationPolicyEnforcement
for a table that isn't in violation.static void
QuotaUtil.deleteTableQuota
(org.apache.hadoop.hbase.client.Connection connection, org.apache.hadoop.hbase.TableName table) static void
QuotaUtil.deleteUserQuota
(org.apache.hadoop.hbase.client.Connection connection, String user, org.apache.hadoop.hbase.TableName table) static void
QuotaUtil.disableTableIfNotDisabled
(org.apache.hadoop.hbase.client.Connection conn, org.apache.hadoop.hbase.TableName tableName) Method to disable a table, if not already disabled.void
RegionServerSpaceQuotaManager.disableViolationPolicyEnforcement
(org.apache.hadoop.hbase.TableName tableName) Disables enforcement on any violation policy on the giventableName
.static void
QuotaUtil.enableTableIfNotEnabled
(org.apache.hadoop.hbase.client.Connection conn, org.apache.hadoop.hbase.TableName tableName) Method to enable a table, if not already enabled.void
RegionServerSpaceQuotaManager.enforceViolationPolicy
(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot snapshot) Enforces the given violationPolicy on the given table in this RegionServer.TableQuotaSnapshotStore.filterBySubject
(org.apache.hadoop.hbase.TableName table) static List<org.apache.hadoop.hbase.quotas.ThrottleSettings>
QuotaSettingsFactory.fromTableThrottles
(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Throttle throttle) protected static List<org.apache.hadoop.hbase.quotas.ThrottleSettings>
QuotaSettingsFactory.fromThrottle
(String userName, org.apache.hadoop.hbase.TableName tableName, String namespace, String regionServer, org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Throttle throttle) org.apache.hadoop.hbase.quotas.FileArchiverNotifier
FileArchiverNotifierFactory.get
(org.apache.hadoop.hbase.client.Connection conn, org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.hbase.TableName tn) Creates or obtains aFileArchiverNotifier
instance for the given args.org.apache.hadoop.hbase.quotas.FileArchiverNotifier
FileArchiverNotifierFactoryImpl.get
(org.apache.hadoop.hbase.client.Connection conn, org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.hbase.TableName tn) Returns theFileArchiverNotifier
instance for the givenTableName
.static org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot
QuotaTableUtil.getCurrentSnapshotFromQuotaTable
(org.apache.hadoop.hbase.client.Connection conn, org.apache.hadoop.hbase.TableName tableName) Returns the current space quota snapshot of the giventableName
fromQuotaTableUtil.QUOTA_TABLE_NAME
or null if the no quota information is available for that tableName.org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot
TableQuotaSnapshotStore.getCurrentState
(org.apache.hadoop.hbase.TableName table) org.apache.hadoop.hbase.quotas.SpaceViolationPolicyEnforcement
ActivePolicyEnforcement.getPolicyEnforcement
(org.apache.hadoop.hbase.TableName tableName) Returns the properSpaceViolationPolicyEnforcement
implementation for the given table.org.apache.hadoop.hbase.quotas.OperationQuota
RegionServerRpcQuotaManager.getQuota
(org.apache.hadoop.security.UserGroupInformation ugi, org.apache.hadoop.hbase.TableName table, int blockSizeBytes) Returns the quota for an operation.int
MasterQuotaManager.getRegionCountOfTable
(org.apache.hadoop.hbase.TableName tName) Returns cached region count, or -1 if quota manager is disabled or table status not foundprotected static byte[]
QuotaTableUtil.getSettingsQualifierForUserTable
(org.apache.hadoop.hbase.TableName tableName) org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.SpaceQuota
TableQuotaSnapshotStore.getSpaceQuota
(org.apache.hadoop.hbase.TableName subject) org.apache.hadoop.hbase.quotas.QuotaLimiter
QuotaCache.getTableLimiter
(org.apache.hadoop.hbase.TableName table) Returns the limiter associated to the specified table.org.apache.hadoop.hbase.quotas.QuotaLimiter
UserQuotaState.getTableLimiter
(org.apache.hadoop.hbase.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
(org.apache.hadoop.hbase.client.Connection connection, org.apache.hadoop.hbase.TableName table) protected static byte[]
QuotaTableUtil.getTableRowKey
(org.apache.hadoop.hbase.TableName table) org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot
TableQuotaSnapshotStore.getTargetState
(org.apache.hadoop.hbase.TableName table, org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.SpaceQuota spaceQuota) org.apache.hadoop.hbase.quotas.QuotaLimiter
QuotaCache.getUserLimiter
(org.apache.hadoop.security.UserGroupInformation ugi, org.apache.hadoop.hbase.TableName table) Returns the limiter associated to the specified user/table.static org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Quotas
QuotaTableUtil.getUserQuota
(org.apache.hadoop.hbase.client.Connection connection, String user, org.apache.hadoop.hbase.TableName table) void
SpaceViolationPolicyEnforcement.initialize
(org.apache.hadoop.hbase.regionserver.RegionServerServices rss, org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot snapshot) Initializes this policy instance.static org.apache.hadoop.hbase.quotas.QuotaSettings
QuotaSettingsFactory.limitTableSpace
(org.apache.hadoop.hbase.TableName tableName, long sizeLimit, org.apache.hadoop.hbase.quotas.SpaceViolationPolicy violationPolicy) Creates aQuotaSettings
object to limit the FileSystem space usage for the given table to the given size in bytes.static org.apache.hadoop.hbase.client.Get
QuotaTableUtil.makeGetForTableQuotas
(org.apache.hadoop.hbase.TableName table) static org.apache.hadoop.hbase.client.Get
QuotaTableUtil.makeQuotaSnapshotGetForTable
(org.apache.hadoop.hbase.TableName tn) Creates aGet
which returns onlySpaceQuotaSnapshot
from the quota table for a specific table.static org.apache.hadoop.hbase.client.Scan
QuotaTableUtil.makeQuotaSnapshotScanForTable
(org.apache.hadoop.hbase.TableName tn) Creates aScan
which returns onlySpaceQuotaSnapshot
from the quota table for a specific table.protected static void
QuotaTableUtil.parseTableResult
(org.apache.hadoop.hbase.TableName table, org.apache.hadoop.hbase.client.Result result, org.apache.hadoop.hbase.quotas.QuotaTableUtil.TableQuotasVisitor visitor) void
MasterQuotasObserver.postDeleteTable
(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.MasterCoprocessorEnvironment> ctx, org.apache.hadoop.hbase.TableName tableName) void
MasterQuotaManager.removeRegionSizesForTable
(org.apache.hadoop.hbase.TableName tableName) Removes each region size entry where the RegionInfo references the provided TableName.void
MasterQuotaManager.removeTableFromNamespaceQuota
(org.apache.hadoop.hbase.TableName tName) Remove table from namespace quota.static org.apache.hadoop.hbase.quotas.QuotaSettings
QuotaSettingsFactory.removeTableSpaceLimit
(org.apache.hadoop.hbase.TableName tableName) Creates aQuotaSettings
object to remove the FileSystem space quota for the given table.void
TableQuotaSnapshotStore.setCurrentState
(org.apache.hadoop.hbase.TableName table, org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot snapshot) void
UserQuotaState.setQuotas
(org.apache.hadoop.hbase.TableName table, org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Quotas quotas) Add the quota information of the specified table.void
MasterQuotaManager.setTableQuota
(org.apache.hadoop.hbase.TableName table, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.SetQuotaRequest req) void
MasterQuotaManager.setUserQuota
(String userName, org.apache.hadoop.hbase.TableName table, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.SetQuotaRequest req) static org.apache.hadoop.hbase.quotas.QuotaSettings
QuotaSettingsFactory.throttleTable
(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.quotas.ThrottleType type, long limit, TimeUnit timeUnit) Throttle the specified table.static org.apache.hadoop.hbase.quotas.QuotaSettings
QuotaSettingsFactory.throttleTable
(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.quotas.ThrottleType type, long limit, TimeUnit timeUnit, org.apache.hadoop.hbase.quotas.QuotaScope scope) Throttle the specified table.static org.apache.hadoop.hbase.quotas.QuotaSettings
QuotaSettingsFactory.throttleUser
(String userName, org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.quotas.ThrottleType type, long limit, TimeUnit timeUnit) Throttle the specified user on the specified table.static org.apache.hadoop.hbase.quotas.QuotaSettings
QuotaSettingsFactory.throttleUser
(String userName, org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.quotas.ThrottleType type, long limit, TimeUnit timeUnit, org.apache.hadoop.hbase.quotas.QuotaScope scope) Throttle the specified user on the specified table.void
SpaceQuotaSnapshotNotifier.transitionTable
(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot snapshot) Informs the cluster of the current state of a space quota for a table.void
TableSpaceQuotaSnapshotNotifier.transitionTable
(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot snapshot) static org.apache.hadoop.hbase.quotas.QuotaSettings
QuotaSettingsFactory.unthrottleTable
(org.apache.hadoop.hbase.TableName tableName) Remove the throttling for the specified table.static org.apache.hadoop.hbase.quotas.QuotaSettings
QuotaSettingsFactory.unthrottleTableByThrottleType
(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.quotas.ThrottleType type) Remove the throttling for the specified table.static org.apache.hadoop.hbase.quotas.QuotaSettings
QuotaSettingsFactory.unthrottleUser
(String userName, org.apache.hadoop.hbase.TableName tableName) Remove the throttling for the specified user on the specified table.static org.apache.hadoop.hbase.quotas.QuotaSettings
QuotaSettingsFactory.unthrottleUserByThrottleType
(String userName, org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.quotas.ThrottleType type) Remove the throttling for the specified user on the specified table.void
QuotaTableUtil.TableQuotasVisitor.visitTableQuotas
(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Quotas quotas) void
QuotaTableUtil.UserQuotasVisitor.visitUserQuotas
(String userName, org.apache.hadoop.hbase.TableName table, org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Quotas quotas) Modifier and TypeMethodDescriptionstatic void
QuotaTableUtil.extractQuotaSnapshot
(org.apache.hadoop.hbase.client.Result result, Map<org.apache.hadoop.hbase.TableName, org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot> snapshots) Extracts theSpaceViolationPolicy
andTableName
from the providedResult
and adds them to the givenMap
.static Map<org.apache.hadoop.hbase.TableName,
org.apache.hadoop.hbase.quotas.QuotaState> QuotaUtil.fetchTableQuotas
(org.apache.hadoop.hbase.client.Connection connection, List<org.apache.hadoop.hbase.client.Get> gets, Map<org.apache.hadoop.hbase.TableName, Double> tableMachineFactors) QuotaUtil.fetchUserQuotas
(org.apache.hadoop.hbase.client.Connection connection, List<org.apache.hadoop.hbase.client.Get> gets, Map<org.apache.hadoop.hbase.TableName, Double> tableMachineQuotaFactors, double factor) static org.apache.hadoop.hbase.client.Get
QuotaTableUtil.makeGetForUserQuotas
(String user, Iterable<org.apache.hadoop.hbase.TableName> tables, Iterable<String> namespaces) void
RegionServerSpaceQuotaManager.updateQuotaSnapshot
(Map<org.apache.hadoop.hbase.TableName, org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot> newSnapshots) Updates the currentSpaceQuotaSnapshot
s for the RegionServer.ModifierConstructorDescriptionFileArchiverNotifierImpl
(org.apache.hadoop.hbase.client.Connection conn, org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.hbase.TableName tn) protected
GlobalQuotaSettings
(String userName, org.apache.hadoop.hbase.TableName tableName, String namespace, String regionServer) protected
GlobalQuotaSettingsImpl
(String username, org.apache.hadoop.hbase.TableName tableName, String namespace, String regionServer, org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Quotas quotas) protected
GlobalQuotaSettingsImpl
(String userName, org.apache.hadoop.hbase.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) protected
QuotaSettings
(String userName, org.apache.hadoop.hbase.TableName tableName, String namespace, String regionServer) ModifierConstructorDescriptionActivePolicyEnforcement
(Map<org.apache.hadoop.hbase.TableName, org.apache.hadoop.hbase.quotas.SpaceViolationPolicyEnforcement> activePolicies, Map<org.apache.hadoop.hbase.TableName, org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot> snapshots, org.apache.hadoop.hbase.regionserver.RegionServerServices rss) ActivePolicyEnforcement
(Map<org.apache.hadoop.hbase.TableName, org.apache.hadoop.hbase.quotas.SpaceViolationPolicyEnforcement> activePolicies, Map<org.apache.hadoop.hbase.TableName, org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot> snapshots, org.apache.hadoop.hbase.regionserver.RegionServerServices rss, org.apache.hadoop.hbase.quotas.SpaceViolationPolicyEnforcementFactory factory) -
Uses of org.apache.hadoop.hbase.TableName in org.apache.hadoop.hbase.quotas.policies
Modifier and TypeMethodDescriptionorg.apache.hadoop.hbase.TableName
AbstractViolationPolicyEnforcement.getTableName()
Modifier and TypeMethodDescriptionvoid
AbstractViolationPolicyEnforcement.initialize
(org.apache.hadoop.hbase.regionserver.RegionServerServices rss, org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot snapshot) void
AbstractViolationPolicyEnforcement.setTableName
(org.apache.hadoop.hbase.TableName tableName) -
Uses of org.apache.hadoop.hbase.TableName in org.apache.hadoop.hbase.regionserver
Modifier and TypeMethodDescriptionorg.apache.hadoop.hbase.TableName
HStore.getTableName()
org.apache.hadoop.hbase.TableName
Store.getTableName()
org.apache.hadoop.hbase.TableName
StoreContext.getTableName()
Modifier and TypeMethodDescriptionSet<org.apache.hadoop.hbase.TableName>
HRegionServer.getOnlineTables()
Gets the online tables in this RS.Modifier and TypeMethodDescriptionList<org.apache.hadoop.fs.Path>
HMobStore.getLocations
(org.apache.hadoop.hbase.TableName tableName) List<org.apache.hadoop.hbase.regionserver.HRegion>
HRegionServer.getRegions
(org.apache.hadoop.hbase.TableName tableName) Gets the online regions of the specified table.List<? extends org.apache.hadoop.hbase.regionserver.Region>
OnlineRegions.getRegions
(org.apache.hadoop.hbase.TableName tableName) Get all online regions of a table in this RS.List<org.apache.hadoop.hbase.regionserver.HRegion>
RegionServerServices.getRegions
(org.apache.hadoop.hbase.TableName tableName) boolean
HRegionServer.reportFileArchivalForQuotas
(org.apache.hadoop.hbase.TableName tableName, Collection<Map.Entry<String, Long>> archivedFiles) boolean
RegionServerServices.reportFileArchivalForQuotas
(org.apache.hadoop.hbase.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<org.apache.hadoop.hbase.TableName, String> mobRefSet) Appends MOB - specific metadata (even if it is empty) -
Uses of org.apache.hadoop.hbase.TableName in org.apache.hadoop.hbase.regionserver.metrics
ModifierConstructorDescriptionMetricsTableRequests
(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.conf.Configuration conf) -
Uses of org.apache.hadoop.hbase.TableName in org.apache.hadoop.hbase.regionserver.storefiletracker
Modifier and TypeMethodDescriptionorg.apache.hadoop.hbase.TableName
ModifyStoreFileTrackerProcedure.getTableName()
ModifierConstructorDescriptionInitializeStoreFileTrackerProcedure
(org.apache.hadoop.hbase.master.procedure.MasterProcedureEnv env, org.apache.hadoop.hbase.TableName tableName) ModifyColumnFamilyStoreFileTrackerProcedure
(org.apache.hadoop.hbase.master.procedure.MasterProcedureEnv env, org.apache.hadoop.hbase.TableName tableName, byte[] family, String dstSFT) protected
ModifyStoreFileTrackerProcedure
(org.apache.hadoop.hbase.master.procedure.MasterProcedureEnv env, org.apache.hadoop.hbase.TableName tableName, String dstSFT) ModifyTableStoreFileTrackerProcedure
(org.apache.hadoop.hbase.master.procedure.MasterProcedureEnv env, org.apache.hadoop.hbase.TableName tableName, String dstSFT) -
Uses of org.apache.hadoop.hbase.TableName in org.apache.hadoop.hbase.regionserver.wal
Modifier and TypeMethodDescriptionvoid
MetricsWALSource.incrementAppendCount
(org.apache.hadoop.hbase.TableName tableName) Increment the count of wal appendsvoid
MetricsWALSourceImpl.incrementAppendCount
(org.apache.hadoop.hbase.TableName tableName) void
MetricsWALSource.incrementAppendSize
(org.apache.hadoop.hbase.TableName tableName, long size) Add the append size.void
MetricsWALSourceImpl.incrementAppendSize
(org.apache.hadoop.hbase.TableName tableName, long size) -
Uses of org.apache.hadoop.hbase.TableName in org.apache.hadoop.hbase.replication
Modifier and TypeFieldDescriptionstatic final org.apache.hadoop.hbase.TableName
ReplicationStorageFactory.REPLICATION_QUEUE_TABLE_NAME_DEFAULT
Modifier and TypeMethodDescriptionReplicationPeerConfig.getExcludeTableCFsMap()
ReplicationPeer.getTableCFs()
Get replicable (table, cf-list) map of this peerReplicationPeerImpl.getTableCFs()
ReplicationPeerConfig.getTableCFsMap()
Modifier and TypeMethodDescriptionstatic org.apache.hadoop.hbase.client.TableDescriptor
ReplicationStorageFactory.createReplicationQueueTableDescriptor
(org.apache.hadoop.hbase.TableName tableName) static org.apache.hadoop.hbase.replication.ReplicationBarrierFamilyFormat.ReplicationBarrierResult
ReplicationBarrierFamilyFormat.getReplicationBarrierResult
(org.apache.hadoop.hbase.client.Connection conn, org.apache.hadoop.hbase.TableName tableName, byte[] row, byte[] encodedRegionName) static org.apache.hadoop.hbase.replication.ReplicationQueueStorage
ReplicationStorageFactory.getReplicationQueueStorage
(org.apache.hadoop.hbase.client.Connection conn, org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.TableName tableName) Create a newReplicationQueueStorage
.ReplicationBarrierFamilyFormat.getTableEncodedRegionNameAndLastBarrier
(org.apache.hadoop.hbase.client.Connection conn, org.apache.hadoop.hbase.TableName tableName) ReplicationBarrierFamilyFormat.getTableEncodedRegionNamesForSerialReplication
(org.apache.hadoop.hbase.client.Connection conn, org.apache.hadoop.hbase.TableName tableName) static boolean
ReplicationStorageFactory.isReplicationQueueTable
(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.TableName tableName) boolean
ReplicationPeerConfig.needToReplicate
(org.apache.hadoop.hbase.TableName table) Decide whether the table need replicate to the peer clusterboolean
ReplicationPeerConfig.needToReplicate
(org.apache.hadoop.hbase.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 TypeMethodDescriptionorg.apache.hadoop.hbase.replication.ReplicationPeerConfigBuilder
ReplicationPeerConfigBuilder.setExcludeTableCFsMap
(Map<org.apache.hadoop.hbase.TableName, List<String>> tableCFsMap) Sets the mapping of table name to column families which should not be replicated.org.apache.hadoop.hbase.replication.ReplicationPeerConfigBuilder
ReplicationPeerConfigBuilder.setTableCFsMap
(Map<org.apache.hadoop.hbase.TableName, List<String>> tableCFsMap) Sets an explicit map of tables and column families in those tables that should be replicated to the given peer.ModifierConstructorDescriptionTableReplicationQueueStorage
(org.apache.hadoop.hbase.client.Connection conn, org.apache.hadoop.hbase.TableName tableName) -
Uses of org.apache.hadoop.hbase.TableName in org.apache.hadoop.hbase.rsgroup
Modifier and TypeMethodDescriptionSortedSet<org.apache.hadoop.hbase.TableName>
RSGroupInfo.getTables()
Deprecated.Since 3.0.0, will be removed in 4.0.0.static List<org.apache.hadoop.hbase.TableName>
RSGroupUtil.listTablesInRSGroup
(org.apache.hadoop.hbase.master.MasterServices master, String groupName) Modifier and TypeMethodDescriptionvoid
RSGroupInfo.addTable
(org.apache.hadoop.hbase.TableName table) Deprecated.Since 3.0.0, will be removed in 4.0.0.boolean
RSGroupInfo.containsTable
(org.apache.hadoop.hbase.TableName table) Deprecated.Since 3.0.0, will be removed in 4.0.0.RSGroupInfoManager.determineRSGroupInfoForTable
(org.apache.hadoop.hbase.TableName tableName) DetermineRSGroupInfo
for the given table.org.apache.hadoop.hbase.rsgroup.RSGroupInfo
RSGroupInfoManager.getRSGroupForTable
(org.apache.hadoop.hbase.TableName tableName) GetRSGroupInfo
for the given table.static Optional<org.apache.hadoop.hbase.rsgroup.RSGroupInfo>
RSGroupUtil.getRSGroupInfo
(org.apache.hadoop.hbase.master.MasterServices master, org.apache.hadoop.hbase.rsgroup.RSGroupInfoManager manager, org.apache.hadoop.hbase.TableName tableName) Will try to get the rsgroup fromTableDescriptor
first, and then try to get the rsgroup from theNamespaceDescriptor
.org.apache.hadoop.hbase.rsgroup.RSGroupInfo
RSGroupAdminClient.getRSGroupInfoOfTable
(org.apache.hadoop.hbase.TableName tableName) Deprecated.GetsRSGroupInfo
for the given table's group.boolean
RSGroupInfo.removeTable
(org.apache.hadoop.hbase.TableName table) Deprecated.Since 3.0.0, will be removed in 4.0.0.Modifier and TypeMethodDescriptionvoid
RSGroupInfo.addAllTables
(Collection<org.apache.hadoop.hbase.TableName> arg) Deprecated.Since 3.0.0, will be removed in 4.0.0.List<org.apache.hadoop.hbase.master.RegionPlan>
RSGroupBasedLoadBalancer.balanceCluster
(Map<org.apache.hadoop.hbase.TableName, Map<org.apache.hadoop.hbase.ServerName, List<org.apache.hadoop.hbase.client.RegionInfo>>> loadOfAllTable) Balance by RSGroup.void
Deprecated.Move given set of tables to the specified target RegionServer group.void
Set group for tables.void
RSGroupBasedLoadBalancer.updateBalancerLoadInfo
(Map<org.apache.hadoop.hbase.TableName, Map<org.apache.hadoop.hbase.ServerName, List<org.apache.hadoop.hbase.client.RegionInfo>>> loadOfAllTable) ModifierConstructorDescriptionMigrateRSGroupProcedure
(org.apache.hadoop.hbase.master.procedure.MasterProcedureEnv env, org.apache.hadoop.hbase.TableName tableName) -
Uses of org.apache.hadoop.hbase.TableName in org.apache.hadoop.hbase.shaded.protobuf
Modifier and TypeMethodDescriptionstatic org.apache.hadoop.hbase.TableName[]
ProtobufUtil.getTableNameArray
(List<org.apache.hadoop.hbase.shaded.protobuf.generated.HBaseProtos.TableName> tableNamesList) static org.apache.hadoop.hbase.TableName
ProtobufUtil.toTableName
(org.apache.hadoop.hbase.shaded.protobuf.generated.HBaseProtos.TableName tableNamePB) Modifier and TypeMethodDescriptionstatic List<org.apache.hadoop.hbase.TableName>
ProtobufUtil.toTableNameList
(List<org.apache.hadoop.hbase.shaded.protobuf.generated.HBaseProtos.TableName> tableNamesList) Modifier and TypeMethodDescriptionstatic org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.AddColumnRequest
RequestConverter.buildAddColumnRequest
(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.ColumnFamilyDescriptor column, long nonceGroup, long nonce) Create a protocol buffer AddColumnRequeststatic org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.DeleteColumnRequest
RequestConverter.buildDeleteColumnRequest
(org.apache.hadoop.hbase.TableName tableName, byte[] columnName, long nonceGroup, long nonce) Create a protocol buffer DeleteColumnRequeststatic org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.DeleteTableRequest
RequestConverter.buildDeleteTableRequest
(org.apache.hadoop.hbase.TableName tableName, long nonceGroup, long nonce) Creates a protocol buffer DeleteTableRequeststatic org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.DisableTableRequest
RequestConverter.buildDisableTableRequest
(org.apache.hadoop.hbase.TableName tableName, long nonceGroup, long nonce) Creates a protocol buffer DisableTableRequeststatic org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.EnableTableRequest
RequestConverter.buildEnableTableRequest
(org.apache.hadoop.hbase.TableName tableName, long nonceGroup, long nonce) Creates a protocol buffer EnableTableRequeststatic org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.FlushTableRequest
RequestConverter.buildFlushTableRequest
(org.apache.hadoop.hbase.TableName tableName, List<byte[]> columnFamilies, long nonceGroup, long nonce) static org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.GetRegionLoadRequest
RequestConverter.buildGetRegionLoadRequest
(org.apache.hadoop.hbase.TableName tableName) Create a protocol buffer GetRegionLoadRequest for all regions/regions of a table.static org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.GetTableDescriptorsRequest
RequestConverter.buildGetTableDescriptorsRequest
(org.apache.hadoop.hbase.TableName tableName) Creates a protocol buffer GetTableDescriptorsRequest for a single tablestatic org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.ModifyColumnRequest
RequestConverter.buildModifyColumnRequest
(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.ColumnFamilyDescriptor column, long nonceGroup, long nonce) Create a protocol buffer ModifyColumnRequeststatic org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.ModifyColumnStoreFileTrackerRequest
RequestConverter.buildModifyColumnStoreFileTrackerRequest
(org.apache.hadoop.hbase.TableName tableName, byte[] family, String dstSFT, long nonceGroup, long nonce) static org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.ModifyTableRequest
RequestConverter.buildModifyTableRequest
(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.TableDescriptor tableDesc, long nonceGroup, long nonce, boolean reopenRegions) Creates a protocol buffer ModifyTableRequeststatic org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.ModifyTableStoreFileTrackerRequest
RequestConverter.buildModifyTableStoreFileTrackerRequest
(org.apache.hadoop.hbase.TableName tableName, String dstSFT, long nonceGroup, long nonce) static org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.TruncateTableRequest
RequestConverter.buildTruncateTableRequest
(org.apache.hadoop.hbase.TableName tableName, boolean preserveSplits, long nonceGroup, long nonce) Creates a protocol buffer TruncateTableRequeststatic org.apache.hadoop.hbase.shaded.protobuf.generated.WALProtos.BulkLoadDescriptor
ProtobufUtil.toBulkLoadDescriptor
(org.apache.hadoop.hbase.TableName tableName, org.apache.hbase.thirdparty.com.google.protobuf.ByteString encodedRegionName, Map<byte[], List<org.apache.hadoop.fs.Path>> storeFiles, Map<String, Long> storeFilesSize, long bulkloadSeqId) Generates a marker for the WAL so that we propagate the notion of a bulk region load throughout the WAL.static org.apache.hadoop.hbase.shaded.protobuf.generated.WALProtos.BulkLoadDescriptor
ProtobufUtil.toBulkLoadDescriptor
(org.apache.hadoop.hbase.TableName tableName, org.apache.hbase.thirdparty.com.google.protobuf.ByteString encodedRegionName, Map<byte[], List<org.apache.hadoop.fs.Path>> storeFiles, Map<String, Long> storeFilesSize, long bulkloadSeqId, List<String> clusterIds, boolean replicate) static org.apache.hadoop.hbase.shaded.protobuf.generated.HBaseProtos.TableName
ProtobufUtil.toProtoTableName
(org.apache.hadoop.hbase.TableName tableName) Modifier and TypeMethodDescriptionstatic org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.GetTableDescriptorsRequest
RequestConverter.buildGetTableDescriptorsRequest
(List<org.apache.hadoop.hbase.TableName> tableNames) Creates a protocol buffer GetTableDescriptorsRequeststatic List<org.apache.hadoop.hbase.shaded.protobuf.generated.HBaseProtos.TableName>
ProtobufUtil.toProtoTableNameList
(List<org.apache.hadoop.hbase.TableName> tableNameList) -
Uses of org.apache.hadoop.hbase.TableName in org.apache.hadoop.hbase.slowlog
Modifier and TypeFieldDescriptionstatic final org.apache.hadoop.hbase.TableName
SlowLogTableAccessor.SLOW_LOG_TABLE_NAME
hbase:slowlog table name - can be enabled with config - hbase.regionserver.slowlog.systable.enabled -
Uses of org.apache.hadoop.hbase.TableName in org.apache.hadoop.hbase.snapshot
Modifier and TypeMethodDescriptionstatic org.apache.hadoop.hbase.client.RegionInfo
RestoreSnapshotHelper.cloneRegionInfo
(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.RegionInfo snapshotRegionInfo) static void
RestoreSnapshotHelper.restoreSnapshotAcl
(org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotDescription snapshot, org.apache.hadoop.hbase.TableName newTableName, org.apache.hadoop.conf.Configuration conf) ModifierConstructorDescriptionTablePartiallyOpenException
(org.apache.hadoop.hbase.TableName tableName) -
Uses of org.apache.hadoop.hbase.TableName in org.apache.hadoop.hbase.util
Modifier and TypeFieldDescriptionprotected final org.apache.hadoop.hbase.TableName
MultiThreadedAction.tableName
Modifier and TypeMethodDescriptionorg.apache.hadoop.hbase.TableName
HbckTableInfo.getName()
static org.apache.hadoop.hbase.TableName
CommonFSUtils.getTableName
(org.apache.hadoop.fs.Path tablePath) Returns theTableName
object representing the table directory under path rootdirorg.apache.hadoop.hbase.TableName
HbckRegionInfo.getTableName()
static org.apache.hadoop.hbase.TableName
HFileArchiveUtil.getTableName
(org.apache.hadoop.fs.Path archivePath) Modifier and TypeMethodDescriptionprotected void
LoadTestTool.applyColumnFamilyOptions
(org.apache.hadoop.hbase.TableName tableName, byte[][] columnFamilies) Apply column family options such as Bloom filters, compression, and data block encoding.static int
LoadTestUtil.createPreSplitLoadTestTable
(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.TableName tableName, byte[][] columnFamilies, org.apache.hadoop.hbase.io.compress.Compression.Algorithm compression, org.apache.hadoop.hbase.io.encoding.DataBlockEncoding dataBlockEncoding, int numRegionsPerServer, int regionReplication, org.apache.hadoop.hbase.client.Durability durability) Creates a pre-split table for load testing.static int
LoadTestUtil.createPreSplitLoadTestTable
(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.TableName tableName, byte[] columnFamily, org.apache.hadoop.hbase.io.compress.Compression.Algorithm compression, org.apache.hadoop.hbase.io.encoding.DataBlockEncoding dataBlockEncoding) Creates a pre-split table for load testing.static int
LoadTestUtil.createPreSplitLoadTestTable
(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.TableName tableName, byte[] columnFamily, org.apache.hadoop.hbase.io.compress.Compression.Algorithm compression, org.apache.hadoop.hbase.io.encoding.DataBlockEncoding dataBlockEncoding, int numRegionsPerServer, int regionReplication, org.apache.hadoop.hbase.client.Durability durability) Creates a pre-split table for load testing.org.apache.hadoop.hbase.client.TableDescriptor
FSTableDescriptors.get
(org.apache.hadoop.hbase.TableName tableName) 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, org.apache.hadoop.hbase.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, org.apache.hadoop.hbase.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, org.apache.hadoop.hbase.TableName tableName, String regionName) Returns thePath
object representing the region directory under path rootdirstatic org.apache.hadoop.fs.Path
HFileArchiveUtil.getStoreArchivePath
(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.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, org.apache.hadoop.hbase.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, org.apache.hadoop.hbase.TableName tableName) Get the path to the table archive directory based on the configured archive directory.static org.apache.hadoop.hbase.client.TableDescriptor
FSTableDescriptors.getTableDescriptorFromFs
(org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.fs.Path hbaseRootDir, org.apache.hadoop.hbase.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, org.apache.hadoop.hbase.TableName tableName) Returns thePath
object representing the table directory under path rootdirFSUtils.getTableStoreFilePathMap
(Map<String, org.apache.hadoop.fs.Path> map, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.fs.Path hbaseRootDir, org.apache.hadoop.hbase.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, org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.fs.PathFilter sfFilter, ExecutorService executor, org.apache.hadoop.hbase.util.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, org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.fs.PathFilter sfFilter, ExecutorService executor, org.apache.hadoop.hbase.util.HbckErrorReporter progressReporter) Deprecated.Since 2.3.0.static org.apache.hadoop.fs.Path
CommonFSUtils.getWALRegionDir
(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.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, org.apache.hadoop.hbase.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, org.apache.hadoop.hbase.TableName tableName, String encodedRegionName) Deprecated.For compatibility, will be removed in 4.0.0.void
HBaseFsck.includeTable
(org.apache.hadoop.hbase.TableName table) Deprecated.static boolean
ServerRegionReplicaUtil.isMetaRegionReplicaReplicationEnabled
(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.TableName tn) Returns True if hbase:meta Region Read Replica is enabled.static boolean
ServerRegionReplicaUtil.isRegionReplicaReplicationEnabled
(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.TableName tn) org.apache.hadoop.hbase.client.TableDescriptor
FSTableDescriptors.remove
(org.apache.hadoop.hbase.TableName tablename) Removes the table descriptor from the local cache and returns it.ModifierConstructorDescriptionMultiThreadedAction
(org.apache.hadoop.hbase.util.test.LoadTestDataGenerator dataGen, org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.TableName tableName, String actionLetter) MultiThreadedReader
(org.apache.hadoop.hbase.util.test.LoadTestDataGenerator dataGen, org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.TableName tableName, double verifyPercent) MultiThreadedReaderWithACL
(org.apache.hadoop.hbase.util.test.LoadTestDataGenerator dataGen, org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.TableName tableName, double verifyPercent, String userNames) MultiThreadedUpdater
(org.apache.hadoop.hbase.util.test.LoadTestDataGenerator dataGen, org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.TableName tableName, double updatePercent) MultiThreadedUpdaterWithACL
(org.apache.hadoop.hbase.util.test.LoadTestDataGenerator dataGen, org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.TableName tableName, double updatePercent, org.apache.hadoop.hbase.security.User userOwner, String userNames) MultiThreadedWriter
(org.apache.hadoop.hbase.util.test.LoadTestDataGenerator dataGen, org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.TableName tableName) MultiThreadedWriterBase
(org.apache.hadoop.hbase.util.test.LoadTestDataGenerator dataGen, org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.TableName tableName, String actionLetter) MultiThreadedWriterWithACL
(org.apache.hadoop.hbase.util.test.LoadTestDataGenerator dataGen, org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.security.User userOwner) -
Uses of org.apache.hadoop.hbase.TableName in org.apache.hadoop.hbase.util.compaction
Modifier and TypeFieldDescriptionprotected org.apache.hadoop.hbase.TableName
MajorCompactor.tableName
-
Uses of org.apache.hadoop.hbase.TableName in org.apache.hadoop.hbase.wal
Modifier and TypeMethodDescriptionorg.apache.hadoop.hbase.TableName
WALKey.getTableName()
Returns table nameorg.apache.hadoop.hbase.TableName
WALKeyImpl.getTableName()
Returns table nameModifier and TypeMethodDescriptionprotected void
WALKeyImpl.init
(byte[] encodedRegionName, org.apache.hadoop.hbase.TableName tablename, long logSeqNum, long now, List<UUID> clusterIds, long nonceGroup, long nonce, org.apache.hadoop.hbase.regionserver.MultiVersionConcurrencyControl mvcc, NavigableMap<byte[], Integer> replicationScope, Map<String, byte[]> extendedAttributes) ModifierConstructorDescriptionWALKeyImpl
(byte[] encodedRegionName, org.apache.hadoop.hbase.TableName tablename, long now) WALKeyImpl
(byte[] encodedRegionName, org.apache.hadoop.hbase.TableName tablename, long logSeqNum, long nonceGroup, long nonce, org.apache.hadoop.hbase.regionserver.MultiVersionConcurrencyControl mvcc) Create the log key for writing to somewhere.WALKeyImpl
(byte[] encodedRegionName, org.apache.hadoop.hbase.TableName tablename, long logSeqNum, long now, List<UUID> clusterIds, long nonceGroup, long nonce, org.apache.hadoop.hbase.regionserver.MultiVersionConcurrencyControl mvcc) Create the log key for writing to somewhere.WALKeyImpl
(byte[] encodedRegionName, org.apache.hadoop.hbase.TableName tablename, long logSeqNum, long now, List<UUID> clusterIds, long nonceGroup, long nonce, org.apache.hadoop.hbase.regionserver.MultiVersionConcurrencyControl mvcc, NavigableMap<byte[], Integer> replicationScope) Create the log key for writing to somewhere.WALKeyImpl
(byte[] encodedRegionName, org.apache.hadoop.hbase.TableName tablename, long logSeqNum, long now, UUID clusterId) WALKeyImpl
(byte[] encodedRegionName, org.apache.hadoop.hbase.TableName tablename, long logSeqNum, long now, UUID clusterId, org.apache.hadoop.hbase.regionserver.MultiVersionConcurrencyControl mvcc) WALKeyImpl
(byte[] encodedRegionName, org.apache.hadoop.hbase.TableName tablename, long now, List<UUID> clusterIds, long nonceGroup, long nonce, org.apache.hadoop.hbase.regionserver.MultiVersionConcurrencyControl mvcc) Create the log key for writing to somewhere.WALKeyImpl
(byte[] encodedRegionName, org.apache.hadoop.hbase.TableName tablename, long now, List<UUID> clusterIds, long nonceGroup, long nonce, org.apache.hadoop.hbase.regionserver.MultiVersionConcurrencyControl mvcc, NavigableMap<byte[], Integer> replicationScope) Create the log key for writing to somewhere.WALKeyImpl
(byte[] encodedRegionName, org.apache.hadoop.hbase.TableName tablename, long now, List<UUID> clusterIds, long nonceGroup, long nonce, org.apache.hadoop.hbase.regionserver.MultiVersionConcurrencyControl mvcc, NavigableMap<byte[], Integer> replicationScope, Map<String, byte[]> extendedAttributes) WALKeyImpl
(byte[] encodedRegionName, org.apache.hadoop.hbase.TableName tablename, long now, NavigableMap<byte[], Integer> replicationScope) WALKeyImpl
(byte[] encodedRegionName, org.apache.hadoop.hbase.TableName tablename, long now, org.apache.hadoop.hbase.regionserver.MultiVersionConcurrencyControl mvcc) WALKeyImpl
(byte[] encodedRegionName, org.apache.hadoop.hbase.TableName tablename, long now, org.apache.hadoop.hbase.regionserver.MultiVersionConcurrencyControl mvcc, NavigableMap<byte[], Integer> replicationScope) WALKeyImpl
(byte[] encodedRegionName, org.apache.hadoop.hbase.TableName tablename, long now, org.apache.hadoop.hbase.regionserver.MultiVersionConcurrencyControl mvcc, NavigableMap<byte[], Integer> replicationScope, Map<String, byte[]> extendedAttributes)