Uses of Class
org.apache.hadoop.hbase.TableName
Packages that use 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
Fields in org.apache.hadoop.hbase declared as org.apache.hadoop.hbase.TableName in inModifier and TypeFieldDescriptionstatic final org.apache.hadoop.hbase.TableNameHConstants.ENSEMBLE_TABLE_NAMEThe name of the ensemble tablestatic final org.apache.hadoop.hbase.TableNameTableName.META_TABLE_NAMEThe hbase:meta table's name.static final org.apache.hadoop.hbase.TableNameTableName.NAMESPACE_TABLE_NAMEDeprecated.since 3.0.0 and will be removed in 4.0.0.static final org.apache.hadoop.hbase.TableNameTableName.OLD_META_TABLE_NAMETableName for old .META.static final org.apache.hadoop.hbase.TableNameTableName.OLD_ROOT_TABLE_NAMETableName for old -ROOT- table.Methods in org.apache.hadoop.hbase that return org.apache.hadoop.hbase.TableName in inModifier and TypeMethodDescriptionstatic org.apache.hadoop.hbase.TableNameTableName.valueOf(byte[] fullName) Construct a TableNamestatic org.apache.hadoop.hbase.TableNameTableName.valueOf(byte[] namespace, byte[] qualifier) static org.apache.hadoop.hbase.TableNameTableName.valueOf(byte[] fullName, int offset, int length) Construct a TableNamestatic org.apache.hadoop.hbase.TableNameTableName.valueOf(String name) Construct a TableNamestatic org.apache.hadoop.hbase.TableNamestatic org.apache.hadoop.hbase.TableNameTableName.valueOf(ByteBuffer fullname) Construct a TableNamestatic org.apache.hadoop.hbase.TableNameTableName.valueOf(ByteBuffer namespace, ByteBuffer qualifier) Methods in org.apache.hadoop.hbase that return types with arguments of type org.apache.hadoop.hbase.TableName in inModifier 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 tableMethods in org.apache.hadoop.hbase with parameters of type org.apache.hadoop.hbase.TableName in inModifier and TypeMethodDescriptionvoidHBaseTestingUtility.compact(org.apache.hadoop.hbase.TableName tableName, boolean major) Deprecated.Compact all of a table's reagion in the mini hbase clustervoidMiniHBaseCluster.compact(org.apache.hadoop.hbase.TableName tableName, boolean major) Deprecated.Call flushCache on all regions of the specified table.intTableName.compareTo(org.apache.hadoop.hbase.TableName tableName) intHBaseTestingUtility.countRows(org.apache.hadoop.hbase.TableName tableName) Deprecated.Return the number of rows in the given table.org.apache.hadoop.hbase.regionserver.HRegionHBaseTestingUtility.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.HRegionHBaseTestingUtility.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.TableDescriptorBuilderHBaseTestingUtility.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.TableHBaseTestingUtility.createMultiRegionTable(org.apache.hadoop.hbase.TableName tableName, byte[] family) Deprecated.Create a table with multiple regions.org.apache.hadoop.hbase.client.TableHBaseTestingUtility.createMultiRegionTable(org.apache.hadoop.hbase.TableName tableName, byte[][] families) Deprecated.Create a table with multiple regions.org.apache.hadoop.hbase.client.TableHBaseTestingUtility.createMultiRegionTable(org.apache.hadoop.hbase.TableName tableName, byte[][] families, int numVersions) Deprecated.Create a table with multiple regions.org.apache.hadoop.hbase.client.TableHBaseTestingUtility.createMultiRegionTable(org.apache.hadoop.hbase.TableName tableName, byte[] family, int numRegions) Deprecated.Create a table with multiple regions.org.apache.hadoop.hbase.client.TableHBaseTestingUtility.createMultiRegionTable(org.apache.hadoop.hbase.TableName tableName, int replicaCount, byte[][] families) Deprecated.Create a table with multiple regions.static intHBaseTestingUtility.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 intHBaseTestingUtility.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 intHBaseTestingUtility.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.TableHBaseTestingUtility.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.TableHBaseTestingUtility.createTable(org.apache.hadoop.hbase.TableName tableName, byte[] family) Deprecated.Create a table.org.apache.hadoop.hbase.client.TableHBaseTestingUtility.createTable(org.apache.hadoop.hbase.TableName tableName, byte[][] families) Deprecated.Create a table.org.apache.hadoop.hbase.client.TableHBaseTestingUtility.createTable(org.apache.hadoop.hbase.TableName tableName, byte[][] families, byte[][] splitKeys) Deprecated.Create a table.org.apache.hadoop.hbase.client.TableHBaseTestingUtility.createTable(org.apache.hadoop.hbase.TableName tableName, byte[][] families, byte[][] splitKeys, int replicaCount) Deprecated.Create a table.org.apache.hadoop.hbase.client.TableHBaseTestingUtility.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.TableHBaseTestingUtility.createTable(org.apache.hadoop.hbase.TableName tableName, byte[][] families, int numVersions) Deprecated.Create a table.org.apache.hadoop.hbase.client.TableHBaseTestingUtility.createTable(org.apache.hadoop.hbase.TableName tableName, byte[][] families, int[] numVersions) Deprecated.Create a table.org.apache.hadoop.hbase.client.TableHBaseTestingUtility.createTable(org.apache.hadoop.hbase.TableName tableName, byte[][] families, int numVersions, byte[][] splitKeys) Deprecated.Create a table.org.apache.hadoop.hbase.client.TableHBaseTestingUtility.createTable(org.apache.hadoop.hbase.TableName tableName, byte[][] families, int numVersions, byte[] startKey, byte[] endKey, int numRegions) Deprecated.org.apache.hadoop.hbase.client.TableHBaseTestingUtility.createTable(org.apache.hadoop.hbase.TableName tableName, byte[][] families, int numVersions, int blockSize) Deprecated.Create a table.org.apache.hadoop.hbase.client.TableHBaseTestingUtility.createTable(org.apache.hadoop.hbase.TableName tableName, byte[][] families, int numVersions, int blockSize, String cpName) Deprecated.org.apache.hadoop.hbase.client.TableHBaseTestingUtility.createTable(org.apache.hadoop.hbase.TableName tableName, byte[] family, byte[][] splitRows) Deprecated.Create a table.org.apache.hadoop.hbase.client.TableHBaseTestingUtility.createTable(org.apache.hadoop.hbase.TableName tableName, byte[] family, int numVersions) Deprecated.Create a table.org.apache.hadoop.hbase.client.TableHBaseTestingUtility.createTable(org.apache.hadoop.hbase.TableName tableName, String family) Deprecated.Create a table.org.apache.hadoop.hbase.client.TableHBaseTestingUtility.createTable(org.apache.hadoop.hbase.TableName tableName, String[] families) Deprecated.Create a table.org.apache.hadoop.hbase.client.TableDescriptorHBaseTestingUtility.createTableDescriptor(org.apache.hadoop.hbase.TableName name) Deprecated.Create a table of namename.org.apache.hadoop.hbase.client.TableDescriptorHBaseTestingUtility.createTableDescriptor(org.apache.hadoop.hbase.TableName tableName, byte[] family) Deprecated.org.apache.hadoop.hbase.client.TableDescriptorHBaseTestingUtility.createTableDescriptor(org.apache.hadoop.hbase.TableName tableName, byte[][] families, int maxVersions) Deprecated.org.apache.hadoop.hbase.client.TableDescriptorHBaseTestingUtility.createTableDescriptor(org.apache.hadoop.hbase.TableName name, int minVersions, int versions, int ttl, org.apache.hadoop.hbase.KeepDeletedCells keepDeleted) Deprecated.voidHBaseTestingUtility.deleteTable(org.apache.hadoop.hbase.TableName tableName) Deprecated.Drop an existing tableorg.apache.hadoop.hbase.client.TableHBaseTestingUtility.deleteTableData(org.apache.hadoop.hbase.TableName tableName) Deprecated.Provide an existing table name to truncate.voidHBaseTestingUtility.deleteTableIfAny(org.apache.hadoop.hbase.TableName tableName) Deprecated.Drop an existing tablestatic voidMetaTableAccessor.deleteTableState(org.apache.hadoop.hbase.client.Connection connection, org.apache.hadoop.hbase.TableName table) Remove state for table from metadefault booleanTableDescriptors.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.TableStateHBaseTestingUtility.findLastTableState(org.apache.hadoop.hbase.TableName table) Deprecated.List<org.apache.hadoop.hbase.regionserver.HRegion>MiniHBaseCluster.findRegionsForTable(org.apache.hadoop.hbase.TableName tableName) Deprecated.voidHBaseTestingUtility.flush(org.apache.hadoop.hbase.TableName tableName) Deprecated.Flushes all caches in the mini hbase clustervoidMiniHBaseCluster.flushcache(org.apache.hadoop.hbase.TableName tableName) Deprecated.Call flushCache on all regions of the specified table.org.apache.hadoop.hbase.client.TableDescriptorTableDescriptors.get(org.apache.hadoop.hbase.TableName tableName) Returns TableDescriptor for tablenamestatic CellComparatorCellComparatorImpl.getCellComparator(org.apache.hadoop.hbase.TableName tableName) Utility method that makes a guess at comparator to use based off passed tableName.static CellComparatorInnerStoreCellComparator.getInnerStoreCellComparator(org.apache.hadoop.hbase.TableName tableName) Utility method that makes a guess at comparator to use based off passed tableName.default longClusterMetrics.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 tableintHBaseTestingUtility.getNumHFiles(org.apache.hadoop.hbase.TableName tableName, byte[] family) Deprecated.intHBaseTestingUtility.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.HRegionServerHBaseTestingUtility.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.ScanMetaTableAccessor.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.ServerNameHBaseCluster.getServerHoldingRegion(org.apache.hadoop.hbase.TableName tn, byte[] regionName) Deprecated.Get the ServerName of region server serving the specified regionorg.apache.hadoop.hbase.ServerNameMiniHBaseCluster.getServerHoldingRegion(org.apache.hadoop.hbase.TableName tn, byte[] regionName) Deprecated.org.apache.hadoop.hbase.regionserver.HRegionHBaseTestingUtility.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.TableStateMetaTableAccessor.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 booleanTableName.isMetaTableName(org.apache.hadoop.hbase.TableName tn) Returns True iftnis the hbase:meta table name.<any>HBaseTestingUtility.predicateTableAvailable(org.apache.hadoop.hbase.TableName tableName) Deprecated.Returns aPredicatefor checking that table is enabled<any>HBaseTestingUtility.predicateTableDisabled(org.apache.hadoop.hbase.TableName tableName) Deprecated.Returns aPredicatefor checking that table is enabled<any>HBaseTestingUtility.predicateTableEnabled(org.apache.hadoop.hbase.TableName tableName) Deprecated.Returns aPredicatefor checking that table is enabledorg.apache.hadoop.hbase.client.TableDescriptorTableDescriptors.remove(org.apache.hadoop.hbase.TableName tablename) Returns Instance of table descriptor or null if none found.booleanMockRegionServerServices.reportFileArchivalForQuotas(org.apache.hadoop.hbase.TableName tableName, Collection<Map.Entry<String, Long>> archivedFiles) static voidMetaTableAccessor.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 voidMetaTableAccessor.scanMetaForTableRegions(org.apache.hadoop.hbase.client.Connection connection, org.apache.hadoop.hbase.ClientMetaTableAccessor.Visitor visitor, org.apache.hadoop.hbase.TableName tableName) static voidHBaseTestingUtility.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.TableHBaseTestingUtility.truncateTable(org.apache.hadoop.hbase.TableName tableName) Deprecated.Truncate a table using the admin command.org.apache.hadoop.hbase.client.TableHBaseTestingUtility.truncateTable(org.apache.hadoop.hbase.TableName tableName, boolean preserveRegions) Deprecated.Truncate a table using the admin command.static voidMetaTableAccessor.updateTableState(org.apache.hadoop.hbase.client.Connection conn, org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.TableState.State actual) Updates state in META Do not use.voidHBaseTestingUtility.waitTableAvailable(org.apache.hadoop.hbase.TableName table) Deprecated.Wait until all regions in a table have been assigned.voidHBaseTestingUtility.waitTableAvailable(org.apache.hadoop.hbase.TableName table, long timeoutMillis) Deprecated.voidHBaseTestingUtility.waitTableDisabled(org.apache.hadoop.hbase.TableName table, long millisTimeout) Deprecated.voidHBaseTestingUtility.waitTableEnabled(org.apache.hadoop.hbase.TableName table) Deprecated.Waits for a table to be 'enabled'.voidHBaseTestingUtility.waitTableEnabled(org.apache.hadoop.hbase.TableName table, long timeoutMillis) Deprecated.voidHBaseTestingUtility.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.voidHBaseTestingUtility.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.Method parameters in org.apache.hadoop.hbase with type arguments of type org.apache.hadoop.hbase.TableName in inModifier and TypeMethodDescriptionorg.apache.hadoop.hbase.ClusterMetricsBuilderClusterMetricsBuilder.setTableRegionStatesCount(Map<org.apache.hadoop.hbase.TableName, org.apache.hadoop.hbase.client.RegionStatesCount> tableRegionStatesCount) Constructors in org.apache.hadoop.hbase with parameters of type org.apache.hadoop.hbase.TableName in inModifierConstructorDescriptionConcurrentTableModificationException(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
Methods in org.apache.hadoop.hbase.backup that return org.apache.hadoop.hbase.TableName in inModifier and TypeMethodDescriptionorg.apache.hadoop.hbase.TableName[]RestoreRequest.getFromTables()org.apache.hadoop.hbase.TableNameBackupTableInfo.getTable()org.apache.hadoop.hbase.TableNameBackupInfo.getTableBySnapshot(String snapshotName) org.apache.hadoop.hbase.TableName[]RestoreRequest.getToTables()Methods in org.apache.hadoop.hbase.backup that return types with arguments of type org.apache.hadoop.hbase.TableName in inModifier and TypeMethodDescriptionprotected Set<org.apache.hadoop.hbase.TableName>BackupHFileCleaner.fetchFullyBackedUpTables(org.apache.hadoop.hbase.backup.impl.BackupSystemTable tbl) BackupInfo.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()Methods in org.apache.hadoop.hbase.backup with parameters of type org.apache.hadoop.hbase.TableName in inModifier and TypeMethodDescriptionvoidBackupInfo.addTables(org.apache.hadoop.hbase.TableName[] tables) voidBackupAdmin.addToBackupSet(String name, org.apache.hadoop.hbase.TableName[] tables) Add tables to backup set commandorg.apache.hadoop.hbase.backup.BackupTableInfoBackupInfo.getBackupTableInfo(org.apache.hadoop.hbase.TableName table) BackupInfo.getSnapshotName(org.apache.hadoop.hbase.TableName table) BackupInfo.getTableBackupDir(org.apache.hadoop.hbase.TableName tableName) static StringHBackupFileSystem.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.PathHBackupFileSystem.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.voidBackupMasterObserver.postDeleteTable(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.MasterCoprocessorEnvironment> ctx, org.apache.hadoop.hbase.TableName tableName) voidBackupMasterObserver.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) voidBackupMasterObserver.postTruncateTable(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.MasterCoprocessorEnvironment> ctx, org.apache.hadoop.hbase.TableName tableName) voidBackupAdmin.removeFromBackupSet(String name, org.apache.hadoop.hbase.TableName[] tables) Remove tables from backup setvoidRestoreJob.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 operationvoidBackupInfo.setSnapshotName(org.apache.hadoop.hbase.TableName table, String snapshotName) org.apache.hadoop.hbase.backup.RestoreRequest.BuilderRestoreRequest.Builder.withFromTables(org.apache.hadoop.hbase.TableName[] fromTables) org.apache.hadoop.hbase.backup.RestoreRequest.BuilderRestoreRequest.Builder.withToTables(org.apache.hadoop.hbase.TableName[] toTables) Method parameters in org.apache.hadoop.hbase.backup with type arguments of type org.apache.hadoop.hbase.TableName in inModifier and TypeMethodDescriptionvoidBackupInfo.setBackupTableInfoMap(Map<org.apache.hadoop.hbase.TableName, org.apache.hadoop.hbase.backup.BackupTableInfo> backupTableInfoMap) voidBackupInfo.setIncrTimestampMap(Map<org.apache.hadoop.hbase.TableName, Map<String, Long>> prevTableSetTimestampMap) Set the new region server log timestamps after distributed log rollvoidBackupInfo.setTables(List<org.apache.hadoop.hbase.TableName> tables) voidBackupInfo.setTableSetTimestampMap(Map<org.apache.hadoop.hbase.TableName, Map<String, Long>> tableSetTimestampMap) org.apache.hadoop.hbase.backup.BackupRequest.BuilderBackupRequest.Builder.withTableList(List<org.apache.hadoop.hbase.TableName> tables) Constructors in org.apache.hadoop.hbase.backup with parameters of type org.apache.hadoop.hbase.TableName in in -
Uses of org.apache.hadoop.hbase.TableName in org.apache.hadoop.hbase.client
Methods in org.apache.hadoop.hbase.client that return org.apache.hadoop.hbase.TableName in inModifier and TypeMethodDescriptionorg.apache.hadoop.hbase.TableNameAsyncBufferedMutator.getName()Gets the fully qualified table name instance of the table that thisAsyncBufferedMutatorwrites to.org.apache.hadoop.hbase.TableNameAsyncTable.getName()Gets the fully qualified table name instance of this table.org.apache.hadoop.hbase.TableNameAsyncTableRegionLocator.getName()Gets the fully qualified table name instance of the table whose region we want to locate.org.apache.hadoop.hbase.TableNameBufferedMutator.getName()Gets the fully qualified table name instance of the table that this BufferedMutator writes to.org.apache.hadoop.hbase.TableNameRegionLocator.getName()Gets the fully qualified table name instance of this table.org.apache.hadoop.hbase.TableNameTable.getName()Gets the fully qualified table name instance of this table.org.apache.hadoop.hbase.TableNameRegionInfo.getTable()Returns current table name of the regionstatic org.apache.hadoop.hbase.TableNameRegionInfo.getTable(byte[] regionName) Gets the table name from the specified region name.org.apache.hadoop.hbase.TableNameBufferedMutatorParams.getTableName()org.apache.hadoop.hbase.TableNameSnapshotDescription.getTableName()org.apache.hadoop.hbase.TableNameTableDescriptor.getTableName()Get the name of the tableorg.apache.hadoop.hbase.TableNameTableState.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.Methods in org.apache.hadoop.hbase.client that return types with arguments of type org.apache.hadoop.hbase.TableName in inModifier 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 observedSpaceQuotaSnapshotViews 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 observedSpaceQuotaSnapshotViews 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.Methods in org.apache.hadoop.hbase.client with parameters of type org.apache.hadoop.hbase.TableName in inModifier and TypeMethodDescriptiondefault voidAdmin.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.CacheEvictionStatsAdmin.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 voidAdmin.cloneSnapshot(String snapshotName, org.apache.hadoop.hbase.TableName tableName) Create a new table by cloning the snapshot content.default voidAdmin.cloneSnapshot(String snapshotName, org.apache.hadoop.hbase.TableName tableName, boolean restoreAcl) Create a new table by cloning the snapshot content.default voidAdmin.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.voidAdmin.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.voidAdmin.compact(org.apache.hadoop.hbase.TableName tableName) Compact a table.voidAdmin.compact(org.apache.hadoop.hbase.TableName tableName, byte[] columnFamily) Compact a column family within a table.voidAdmin.compact(org.apache.hadoop.hbase.TableName tableName, byte[] columnFamily, org.apache.hadoop.hbase.client.CompactType compactType) Compact a column family within a table.voidAdmin.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.TableStateTableState.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.TableDescriptorTableDescriptorBuilder.copy(org.apache.hadoop.hbase.TableName name, org.apache.hadoop.hbase.client.TableDescriptor desc) static org.apache.hadoop.hbase.client.RegionInfoRegionInfo.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 voidAdmin.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 voidAdmin.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 voidAdmin.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.voidAdmin.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 voidAdmin.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.voidAdmin.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.voidAdmin.flush(org.apache.hadoop.hbase.TableName tableName) Flush a table.voidAdmin.flush(org.apache.hadoop.hbase.TableName tableName, byte[] columnFamily) Flush the specified column family stores on all regions of the passed table.voidAdmin.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.AsyncBufferedMutatorAsyncConnection.getBufferedMutator(org.apache.hadoop.hbase.TableName tableName) Retrieve anAsyncBufferedMutatorfor performing client-side buffering of writes.default org.apache.hadoop.hbase.client.AsyncBufferedMutatorAsyncConnection.getBufferedMutator(org.apache.hadoop.hbase.TableName tableName, ExecutorService pool) Retrieve anAsyncBufferedMutatorfor performing client-side buffering of writes.default org.apache.hadoop.hbase.client.BufferedMutatorConnection.getBufferedMutator(org.apache.hadoop.hbase.TableName tableName) Retrieve aBufferedMutatorfor performing client-side buffering of writes.org.apache.hadoop.hbase.client.BufferedMutatorSharedConnection.getBufferedMutator(org.apache.hadoop.hbase.TableName tableName) org.apache.hadoop.hbase.client.AsyncBufferedMutatorBuilderAsyncConnection.getBufferedMutatorBuilder(org.apache.hadoop.hbase.TableName tableName) Returns anAsyncBufferedMutatorBuilderfor creatingAsyncBufferedMutator.org.apache.hadoop.hbase.client.AsyncBufferedMutatorBuilderAsyncConnection.getBufferedMutatorBuilder(org.apache.hadoop.hbase.TableName tableName, ExecutorService pool) Returns anAsyncBufferedMutatorBuilderfor creatingAsyncBufferedMutator.org.apache.hadoop.hbase.client.AsyncBufferedMutatorBuilderAsyncConnectionImpl.getBufferedMutatorBuilder(org.apache.hadoop.hbase.TableName tableName) org.apache.hadoop.hbase.client.AsyncBufferedMutatorBuilderAsyncConnectionImpl.getBufferedMutatorBuilder(org.apache.hadoop.hbase.TableName tableName, ExecutorService pool) org.apache.hadoop.hbase.client.AsyncBufferedMutatorBuilderSharedAsyncConnection.getBufferedMutatorBuilder(org.apache.hadoop.hbase.TableName tableName) org.apache.hadoop.hbase.client.AsyncBufferedMutatorBuilderSharedAsyncConnection.getBufferedMutatorBuilder(org.apache.hadoop.hbase.TableName tableName, ExecutorService pool) org.apache.hadoop.hbase.client.CompactionStateAdmin.getCompactionState(org.apache.hadoop.hbase.TableName tableName) Get the current compaction state of a table.org.apache.hadoop.hbase.client.CompactionStateAdmin.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.SpaceQuotaSnapshotViewAdmin.getCurrentSpaceQuotaSnapshot(org.apache.hadoop.hbase.TableName tableName) Returns the Master's view of a quota on the giventableNameor 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 giventableNameor null if the Master has no quota information on that table.org.apache.hadoop.hbase.client.TableDescriptorAdmin.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 tableDescriptorlongAdmin.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.AsyncTableRegionLocatorAsyncConnection.getRegionLocator(org.apache.hadoop.hbase.TableName tableName) Retrieve a AsyncRegionLocator implementation to inspect region information on a table.org.apache.hadoop.hbase.client.AsyncTableRegionLocatorAsyncConnectionImpl.getRegionLocator(org.apache.hadoop.hbase.TableName tableName) org.apache.hadoop.hbase.client.RegionLocatorConnection.getRegionLocator(org.apache.hadoop.hbase.TableName tableName) Retrieve a RegionLocator implementation to inspect region information on a table.org.apache.hadoop.hbase.client.AsyncTableRegionLocatorSharedAsyncConnection.getRegionLocator(org.apache.hadoop.hbase.TableName tableName) org.apache.hadoop.hbase.client.RegionLocatorSharedConnection.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) GetRegionMetricsof 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 ofRegionMetricsof 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.RSGroupInfoAdmin.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 anAsyncTableimplementation 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 anAsyncTableimplementation for accessing a table.default org.apache.hadoop.hbase.client.TableConnection.getTable(org.apache.hadoop.hbase.TableName tableName) Retrieve a Table implementation for accessing a table.default org.apache.hadoop.hbase.client.TableConnection.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 anAsyncTableBuilderfor creatingAsyncTable.org.apache.hadoop.hbase.client.AsyncTableBuilder<org.apache.hadoop.hbase.client.ScanResultConsumer>AsyncConnection.getTableBuilder(org.apache.hadoop.hbase.TableName tableName, ExecutorService pool) Returns anAsyncTableBuilderfor 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.TableBuilderConnection.getTableBuilder(org.apache.hadoop.hbase.TableName tableName, ExecutorService pool) Returns anTableBuilderfor 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.TableBuilderSharedConnection.getTableBuilder(org.apache.hadoop.hbase.TableName tableName, ExecutorService pool) booleanAdmin.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.booleanAdmin.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.booleanAdmin.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.voidAdmin.majorCompact(org.apache.hadoop.hbase.TableName tableName) Major compact a table.voidAdmin.majorCompact(org.apache.hadoop.hbase.TableName tableName, byte[] columnFamily) Major compact a column family within a table.voidAdmin.majorCompact(org.apache.hadoop.hbase.TableName tableName, byte[] columnFamily, org.apache.hadoop.hbase.client.CompactType compactType) Major compact a column family within a table.voidAdmin.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 voidAdmin.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 voidAdmin.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 voidAdmin.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.RegionInfoBuilderRegionInfoBuilder.newBuilder(org.apache.hadoop.hbase.TableName tableName) static org.apache.hadoop.hbase.client.TableDescriptorBuilderTableDescriptorBuilder.newBuilder(org.apache.hadoop.hbase.TableName name) static org.apache.hadoop.hbase.client.TableStateTableState.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 voidAdmin.snapshot(String snapshotName, org.apache.hadoop.hbase.TableName tableName) Take a snapshot for the given table.default voidAdmin.snapshot(String snapshotName, org.apache.hadoop.hbase.TableName tableName, Map<String, Object> snapshotProps) Create typed snapshot of the table.default voidAdmin.snapshot(String snapshotName, org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.SnapshotType type) Create typed snapshot of the table.default voidAdmin.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.voidAdmin.split(org.apache.hadoop.hbase.TableName tableName) Split a table.voidAdmin.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.booleanAdmin.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 voidAdmin.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.voidMetricsConnection.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.Method parameters in org.apache.hadoop.hbase.client with type arguments of type org.apache.hadoop.hbase.TableName in inModifier and TypeMethodDescriptiondefault voidAdmin.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 voidAdmin.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 peervoidSet the RegionServer group for tablesSet the RegionServer group for tablesorg.apache.hadoop.hbase.client.NormalizeTableFilterParams.BuilderNormalizeTableFilterParams.Builder.tableNames(List<org.apache.hadoop.hbase.TableName> tableNames) Constructors in org.apache.hadoop.hbase.client with parameters of type org.apache.hadoop.hbase.TableName in inModifierConstructorDescriptionBufferedMutatorParams(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
Methods in org.apache.hadoop.hbase.client.example with parameters of type org.apache.hadoop.hbase.TableName in inModifier and TypeMethodDescriptionvoidRefreshHFilesClient.refreshHFiles(org.apache.hadoop.hbase.TableName tableName) Constructors in org.apache.hadoop.hbase.client.example with parameters of type org.apache.hadoop.hbase.TableName in inModifierConstructorDescriptionReadExampleCallable(org.apache.hadoop.hbase.client.Connection connection, org.apache.hadoop.hbase.TableName tableName) SingleWriteExampleCallable(org.apache.hadoop.hbase.client.Connection connection, org.apache.hadoop.hbase.TableName tableName) WriteExampleCallable(org.apache.hadoop.hbase.client.Connection connection, org.apache.hadoop.hbase.TableName tableName) -
Uses of org.apache.hadoop.hbase.TableName in org.apache.hadoop.hbase.client.locking
Methods in org.apache.hadoop.hbase.client.locking with parameters of type org.apache.hadoop.hbase.TableName in inModifier and TypeMethodDescriptionstatic org.apache.hadoop.hbase.shaded.protobuf.generated.LockServiceProtos.LockRequestLockServiceClient.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.EntityLockLockServiceClient.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
Methods in org.apache.hadoop.hbase.client.replication that return org.apache.hadoop.hbase.TableName in inModifier and TypeMethodDescriptionorg.apache.hadoop.hbase.TableNameTableCFs.getTable()Methods in org.apache.hadoop.hbase.client.replication that return types with arguments of type org.apache.hadoop.hbase.TableName in inModifier 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.Method parameters in org.apache.hadoop.hbase.client.replication with type arguments of type org.apache.hadoop.hbase.TableName in inModifier and TypeMethodDescriptionstatic org.apache.hadoop.hbase.replication.ReplicationPeerConfigReplicationPeerConfigUtil.appendExcludeTableCFsToReplicationPeerConfig(Map<org.apache.hadoop.hbase.TableName, List<String>> excludeTableCfs, org.apache.hadoop.hbase.replication.ReplicationPeerConfig peerConfig) static org.apache.hadoop.hbase.replication.ReplicationPeerConfigReplicationPeerConfigUtil.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 StringReplicationPeerConfigUtil.convertToString(Map<org.apache.hadoop.hbase.TableName, ? extends Collection<String>> tableCfs) static org.apache.hadoop.hbase.replication.ReplicationPeerConfigReplicationPeerConfigUtil.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.ReplicationPeerConfigReplicationPeerConfigUtil.removeTableCFsFromReplicationPeerConfig(Map<org.apache.hadoop.hbase.TableName, List<String>> tableCfs, org.apache.hadoop.hbase.replication.ReplicationPeerConfig peerConfig, String id) Constructors in org.apache.hadoop.hbase.client.replication with parameters of type org.apache.hadoop.hbase.TableName in in -
Uses of org.apache.hadoop.hbase.TableName in org.apache.hadoop.hbase.client.trace
Methods in org.apache.hadoop.hbase.client.trace with parameters of type org.apache.hadoop.hbase.TableName in inModifier and TypeMethodDescriptionorg.apache.hadoop.hbase.client.trace.TableOperationSpanBuilderTableOperationSpanBuilder.setTableName(org.apache.hadoop.hbase.TableName tableName) org.apache.hadoop.hbase.client.trace.TableSpanBuilderTableSpanBuilder.setTableName(org.apache.hadoop.hbase.TableName tableName) -
Uses of org.apache.hadoop.hbase.TableName in org.apache.hadoop.hbase.coprocessor
Methods in org.apache.hadoop.hbase.coprocessor with parameters of type org.apache.hadoop.hbase.TableName in inModifier and TypeMethodDescriptiondefault voidMasterObserver.postCompletedDeleteTableAction(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.MasterCoprocessorEnvironment> ctx, org.apache.hadoop.hbase.TableName tableName) Called afterHMasterdeletes a table.default voidMasterObserver.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 voidMasterObserver.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 voidMasterObserver.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 voidMasterObserver.postCompletedTruncateTableAction(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.MasterCoprocessorEnvironment> ctx, org.apache.hadoop.hbase.TableName tableName) Called afterHMastertruncates a table.default voidMasterObserver.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 voidMasterObserver.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 voidMasterObserver.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 voidMasterObserver.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 voidMasterObserver.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 voidMasterObserver.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 voidMasterObserver.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 voidMasterObserver.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 voidMasterObserver.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 voidMasterObserver.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 voidMasterObserver.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 voidMasterObserver.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 voidMasterObserver.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 voidMasterObserver.preDeleteTable(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.MasterCoprocessorEnvironment> ctx, org.apache.hadoop.hbase.TableName tableName) Called beforeHMasterdeletes a table.default voidMasterObserver.preDeleteTableAction(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.MasterCoprocessorEnvironment> ctx, org.apache.hadoop.hbase.TableName tableName) Called beforeHMasterdeletes a table.default voidMasterObserver.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 voidMasterObserver.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 voidMasterObserver.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 voidMasterObserver.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 voidMasterObserver.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 voidMasterObserver.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 voidMasterObserver.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 StringMasterObserver.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.TableDescriptorMasterObserver.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 voidMasterObserver.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 StringMasterObserver.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 voidMasterObserver.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 voidMasterObserver.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 voidMasterObserver.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 voidMasterObserver.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 voidMasterObserver.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 voidMasterObserver.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 voidMasterObserver.preTruncateTable(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.MasterCoprocessorEnvironment> ctx, org.apache.hadoop.hbase.TableName tableName) Called beforeHMastertruncates a table.default voidMasterObserver.preTruncateTableAction(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.MasterCoprocessorEnvironment> ctx, org.apache.hadoop.hbase.TableName tableName) Called beforeHMastertruncates a table.Method parameters in org.apache.hadoop.hbase.coprocessor with type arguments of type org.apache.hadoop.hbase.TableName in inModifier and TypeMethodDescriptiondefault voidMasterObserver.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 voidMasterObserver.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 voidMasterObserver.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 voidMasterObserver.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
Methods in org.apache.hadoop.hbase.favored with parameters of type org.apache.hadoop.hbase.TableName in in -
Uses of org.apache.hadoop.hbase.TableName in org.apache.hadoop.hbase.io
Methods in org.apache.hadoop.hbase.io that return org.apache.hadoop.hbase.TableName in inModifier and TypeMethodDescriptionstatic org.apache.hadoop.hbase.TableNameHFileLink.getReferencedTableName(String fileName) Get the Table name of the referenced linkMethods in org.apache.hadoop.hbase.io that return types with arguments of type org.apache.hadoop.hbase.TableName in inModifier and TypeMethodDescriptionstatic org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.TableName,String> HFileLink.parseBackReferenceName(String name) Methods in org.apache.hadoop.hbase.io with parameters of type org.apache.hadoop.hbase.TableName in inModifier and TypeMethodDescriptionstatic org.apache.hadoop.hbase.io.HFileLinkHFileLink.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 StringHFileLink.createHFileLinkName(org.apache.hadoop.hbase.TableName tableName, String regionName, String hfileName) Create a new HFileLink namestatic org.apache.hadoop.fs.PathHFileLink.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
Methods in org.apache.hadoop.hbase.ipc that return org.apache.hadoop.hbase.TableName in inModifier and TypeMethodDescriptionorg.apache.hadoop.hbase.TableNameDelegatingHBaseRpcController.getTableName()default org.apache.hadoop.hbase.TableNameHBaseRpcController.getTableName()Returns Region's table name or null if not available or pertinent.org.apache.hadoop.hbase.TableNameHBaseRpcControllerImpl.getTableName()Methods in org.apache.hadoop.hbase.ipc with parameters of type org.apache.hadoop.hbase.TableName in inModifier and TypeMethodDescriptionvoidDelegatingHBaseRpcController.setPriority(org.apache.hadoop.hbase.TableName tn) voidHBaseRpcController.setPriority(org.apache.hadoop.hbase.TableName tn) Set the priority for this operation.voidHBaseRpcControllerImpl.setPriority(org.apache.hadoop.hbase.TableName tn) voidDelegatingHBaseRpcController.setTableName(org.apache.hadoop.hbase.TableName tableName) default voidHBaseRpcController.setTableName(org.apache.hadoop.hbase.TableName tableName) Sets Region's table name.voidHBaseRpcControllerImpl.setTableName(org.apache.hadoop.hbase.TableName tableName) -
Uses of org.apache.hadoop.hbase.TableName in org.apache.hadoop.hbase.mapred
Methods in org.apache.hadoop.hbase.mapred that return org.apache.hadoop.hbase.TableName in inModifier and TypeMethodDescriptionorg.apache.hadoop.hbase.TableNameTableSplit.getTable()Returns table nameMethods in org.apache.hadoop.hbase.mapred with parameters of type org.apache.hadoop.hbase.TableName in inModifier and TypeMethodDescriptionprotected voidTableInputFormatBase.initializeTable(org.apache.hadoop.hbase.client.Connection connection, org.apache.hadoop.hbase.TableName tableName) Allows subclasses to initialize the table information.Constructors in org.apache.hadoop.hbase.mapred with parameters of type org.apache.hadoop.hbase.TableName in inModifierConstructorDescriptionTableSplit(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
Methods in org.apache.hadoop.hbase.mapreduce that return org.apache.hadoop.hbase.TableName in inModifier and TypeMethodDescriptionorg.apache.hadoop.hbase.TableNameTableSplit.getTable()Returns the table name.Methods in org.apache.hadoop.hbase.mapreduce that return types with arguments of type org.apache.hadoop.hbase.TableName in inModifier 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) Methods in org.apache.hadoop.hbase.mapreduce with parameters of type org.apache.hadoop.hbase.TableName in inModifier and TypeMethodDescriptionstatic voidTableInputFormat.configureSplitTable(org.apache.hadoop.mapreduce.Job job, org.apache.hadoop.hbase.TableName tableName) Sets split table in map-reduce job.protected voidTableInputFormatBase.initializeTable(org.apache.hadoop.hbase.client.Connection connection, org.apache.hadoop.hbase.TableName tableName) Allows subclasses to initialize the table information.static voidTableMapReduceUtil.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.Constructors in org.apache.hadoop.hbase.mapreduce with parameters of type org.apache.hadoop.hbase.TableName in inModifierConstructorDescriptionTableSplit(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
Methods in org.apache.hadoop.hbase.master that return types with arguments of type org.apache.hadoop.hbase.TableName in inModifier 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 namespaceMethods in org.apache.hadoop.hbase.master with parameters of type org.apache.hadoop.hbase.TableName in inModifier and TypeMethodDescriptionlongHMaster.addColumn(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.ColumnFamilyDescriptor column, long nonceGroup, long nonce) longMasterServices.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 tablevoidHMaster.checkTableModifiable(org.apache.hadoop.hbase.TableName tableName) voidMasterServices.checkTableModifiable(org.apache.hadoop.hbase.TableName tableName) Check table is modifiable; i.e.longHMaster.deleteColumn(org.apache.hadoop.hbase.TableName tableName, byte[] columnName, long nonceGroup, long nonce) longMasterServices.deleteColumn(org.apache.hadoop.hbase.TableName tableName, byte[] columnName, long nonceGroup, long nonce) Delete a column from an existing tablelongHMaster.deleteTable(org.apache.hadoop.hbase.TableName tableName, long nonceGroup, long nonce) longMasterServices.deleteTable(org.apache.hadoop.hbase.TableName tableName, long nonceGroup, long nonce) Delete a tablelongHMaster.disableTable(org.apache.hadoop.hbase.TableName tableName, long nonceGroup, long nonce) longMasterServices.disableTable(org.apache.hadoop.hbase.TableName tableName, long nonceGroup, long nonce) Disable an existing tablelongHMaster.enableTable(org.apache.hadoop.hbase.TableName tableName, long nonceGroup, long nonce) longMasterServices.enableTable(org.apache.hadoop.hbase.TableName tableName, long nonceGroup, long nonce) Enable an existing tablevoidAssignmentVerificationReport.fillUp(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.master.SnapshotOfRegionAssignmentFromMeta snapshot, Map<String, Map<String, Float>> regionLocalityMap) voidAssignmentVerificationReport.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 scoreslongHMaster.flushTable(org.apache.hadoop.hbase.TableName tableName, List<byte[]> columnFamilies, long nonceGroup, long nonce) longMasterServices.flushTable(org.apache.hadoop.hbase.TableName tableName, List<byte[]> columnFamilies, long nonceGroup, long nonce) Flush an existing tableorg.apache.hadoop.hbase.client.CompactionStateHMaster.getCompactionState(org.apache.hadoop.hbase.TableName tableName) Get the compaction state of the tablelongHMaster.getLastMajorCompactionTimestamp(org.apache.hadoop.hbase.TableName table) longMasterServices.getLastMajorCompactionTimestamp(org.apache.hadoop.hbase.TableName table) org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.GetRegionInfoResponse.CompactionStateHMaster.getMobCompactionState(org.apache.hadoop.hbase.TableName tableName) Gets the mob file compaction state for a specific table.org.apache.hadoop.hbase.client.TableStateTableStateManager.getTableState(org.apache.hadoop.hbase.TableName tableName) booleanTableStateManager.isTablePresent(org.apache.hadoop.hbase.TableName tableName) booleanTableStateManager.isTableState(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.TableState.State... states) longHMaster.modifyColumn(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.ColumnFamilyDescriptor descriptor, long nonceGroup, long nonce) longMasterServices.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 tablelongHMaster.modifyColumnStoreFileTracker(org.apache.hadoop.hbase.TableName tableName, byte[] family, String dstSFT, long nonceGroup, long nonce) longMasterServices.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 tablelongHMaster.modifyTable(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.TableDescriptor newDescriptor, long nonceGroup, long nonce, boolean reopenRegions) default longMasterServices.modifyTable(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.TableDescriptor descriptor, long nonceGroup, long nonce) Modify the descriptor of an existing tablelongMasterServices.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 tablelongHMaster.modifyTableStoreFileTracker(org.apache.hadoop.hbase.TableName tableName, String dstSFT, long nonceGroup, long nonce) longMasterServices.modifyTableStoreFileTracker(org.apache.hadoop.hbase.TableName tableName, String dstSFT, long nonceGroup, long nonce) Modify the store file tracker of an existing tablevoidMasterCoprocessorHost.postCompletedDeleteTableAction(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.security.User user) voidMasterCoprocessorHost.postCompletedDisableTableAction(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.security.User user) voidMasterCoprocessorHost.postCompletedEnableTableAction(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.security.User user) voidMasterCoprocessorHost.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) voidMasterCoprocessorHost.postCompletedTruncateTableAction(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.security.User user) voidMasterCoprocessorHost.postDeleteTable(org.apache.hadoop.hbase.TableName tableName) voidMasterCoprocessorHost.postDisableTable(org.apache.hadoop.hbase.TableName tableName) voidMasterCoprocessorHost.postEnableTable(org.apache.hadoop.hbase.TableName tableName) voidMasterCoprocessorHost.postGetRSGroupInfoOfTable(org.apache.hadoop.hbase.TableName tableName) voidMasterCoprocessorHost.postGetUserPermissions(String userName, String namespace, org.apache.hadoop.hbase.TableName tableName, byte[] family, byte[] qualifier) voidMasterCoprocessorHost.postModifyColumnFamilyStoreFileTracker(org.apache.hadoop.hbase.TableName tableName, byte[] family, String dstSFT) voidMasterCoprocessorHost.postModifyTable(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.TableDescriptor oldDescriptor, org.apache.hadoop.hbase.client.TableDescriptor currentDescriptor) voidMasterCoprocessorHost.postModifyTableStoreFileTracker(org.apache.hadoop.hbase.TableName tableName, String dstSFT) voidMasterCoprocessorHost.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) voidMasterCoprocessorHost.postSetTableQuota(org.apache.hadoop.hbase.TableName table, org.apache.hadoop.hbase.quotas.GlobalQuotaSettings quotas) voidMasterCoprocessorHost.postSetUserQuota(String user, org.apache.hadoop.hbase.TableName table, org.apache.hadoop.hbase.quotas.GlobalQuotaSettings quotas) voidMasterCoprocessorHost.postTableFlush(org.apache.hadoop.hbase.TableName tableName) voidMasterCoprocessorHost.postTruncateTable(org.apache.hadoop.hbase.TableName tableName) voidMasterCoprocessorHost.preDeleteTable(org.apache.hadoop.hbase.TableName tableName) voidMasterCoprocessorHost.preDeleteTableAction(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.security.User user) voidMasterCoprocessorHost.preDisableTable(org.apache.hadoop.hbase.TableName tableName) voidMasterCoprocessorHost.preDisableTableAction(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.security.User user) voidMasterCoprocessorHost.preEnableTable(org.apache.hadoop.hbase.TableName tableName) voidMasterCoprocessorHost.preEnableTableAction(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.security.User user) voidMasterCoprocessorHost.preGetRSGroupInfoOfTable(org.apache.hadoop.hbase.TableName tableName) voidMasterCoprocessorHost.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.TableDescriptorMasterCoprocessorHost.preModifyTable(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.TableDescriptor currentDescriptor, org.apache.hadoop.hbase.client.TableDescriptor newDescriptor) voidMasterCoprocessorHost.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) voidMasterCoprocessorHost.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) voidMasterCoprocessorHost.preSetTableQuota(org.apache.hadoop.hbase.TableName table, org.apache.hadoop.hbase.quotas.GlobalQuotaSettings quotas) voidMasterCoprocessorHost.preSetUserQuota(String user, org.apache.hadoop.hbase.TableName table, org.apache.hadoop.hbase.quotas.GlobalQuotaSettings quotas) voidMasterCoprocessorHost.preSplitRegion(org.apache.hadoop.hbase.TableName tableName, byte[] splitRow) Invoked just before calling the split region procedurevoidMasterCoprocessorHost.preSplitRegionAction(org.apache.hadoop.hbase.TableName tableName, byte[] splitRow, org.apache.hadoop.hbase.security.User user) Invoked just before a splitvoidMasterCoprocessorHost.preTableFlush(org.apache.hadoop.hbase.TableName tableName) voidMasterCoprocessorHost.preTruncateTable(org.apache.hadoop.hbase.TableName tableName) voidMasterCoprocessorHost.preTruncateTableAction(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.security.User user) voidRegionPlacementMaintainer.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) voidHMaster.reportMobCompactionEnd(org.apache.hadoop.hbase.TableName tableName) voidHMaster.reportMobCompactionStart(org.apache.hadoop.hbase.TableName tableName) voidTableStateManager.setDeletedTable(org.apache.hadoop.hbase.TableName tableName) voidTableStateManager.setTableState(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.TableState.State newState) Set table state to provided.longHMaster.truncateTable(org.apache.hadoop.hbase.TableName tableName, boolean preserveSplits, long nonceGroup, long nonce) longMasterServices.truncateTable(org.apache.hadoop.hbase.TableName tableName, boolean preserveSplits, long nonceGroup, long nonce) Truncate a tableMethod parameters in org.apache.hadoop.hbase.master with type arguments of type org.apache.hadoop.hbase.TableName in inModifier 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.voidRegionPlacementMaintainer.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 requestvoidMasterCoprocessorHost.postGetTableDescriptors(List<org.apache.hadoop.hbase.TableName> tableNamesList, List<org.apache.hadoop.hbase.client.TableDescriptor> descriptors, String regex) voidMasterCoprocessorHost.postMoveTables(Set<org.apache.hadoop.hbase.TableName> tables, String targetGroup) voidMasterCoprocessorHost.preGetTableDescriptors(List<org.apache.hadoop.hbase.TableName> tableNamesList, List<org.apache.hadoop.hbase.client.TableDescriptor> descriptors, String regex) voidMasterCoprocessorHost.preMoveTables(Set<org.apache.hadoop.hbase.TableName> tables, String targetGroup) default voidLoadBalancer.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 loadConstructor parameters in org.apache.hadoop.hbase.master with type arguments of type org.apache.hadoop.hbase.TableName in inModifierConstructorDescriptionSnapshotOfRegionAssignmentFromMeta(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
Methods in org.apache.hadoop.hbase.mob that return types with arguments of type org.apache.hadoop.hbase.TableName in inModifier 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.Methods in org.apache.hadoop.hbase.mob with parameters of type org.apache.hadoop.hbase.TableName in inModifier and TypeMethodDescriptionvoidRSMobFileCleanerChore.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 voidMobFileCleanupUtil.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.PathMobUtils.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.RegionInfoMobUtils.getMobRegionInfo(org.apache.hadoop.hbase.TableName tableName) Gets the RegionInfo of the mob files.static org.apache.hadoop.fs.PathMobUtils.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.PathMobUtils.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.PathMobUtils.getMobTableDir(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.TableName tableName) static org.apache.hadoop.fs.PathMobUtils.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 booleanMobUtils.isMobRegionName(org.apache.hadoop.hbase.TableName tableName, byte[] regionName) Gets whether the current region name follows the pattern of a mob region name.static booleanMobUtils.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.Method parameters in org.apache.hadoop.hbase.mob with type arguments of type org.apache.hadoop.hbase.TableName in inModifier 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
Fields in org.apache.hadoop.hbase.namequeues declared as org.apache.hadoop.hbase.TableName in inModifier and TypeFieldDescriptionstatic final org.apache.hadoop.hbase.TableNameWALEventTrackerTableAccessor.WAL_EVENT_TRACKER_TABLE_NAMEWALEventTrackerTableAccessor.WAL_EVENT_TRACKER_TABLE_NAME_STRtable 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
Methods in org.apache.hadoop.hbase.namespace with parameters of type org.apache.hadoop.hbase.TableName in inModifier and TypeMethodDescriptionvoidNamespaceAuditor.checkQuotaToCreateTable(org.apache.hadoop.hbase.TableName tName, int regions) Check quota to create table.voidNamespaceAuditor.checkQuotaToUpdateRegion(org.apache.hadoop.hbase.TableName tName, int regions) Check and update region count quota for an existing table.intNamespaceAuditor.getRegionCountOfTable(org.apache.hadoop.hbase.TableName tName) Get region count for tablevoidNamespaceAuditor.removeFromNamespaceUsage(org.apache.hadoop.hbase.TableName tableName) -
Uses of org.apache.hadoop.hbase.TableName in org.apache.hadoop.hbase.quotas
Fields in org.apache.hadoop.hbase.quotas declared as org.apache.hadoop.hbase.TableName in inModifier and TypeFieldDescriptionstatic final org.apache.hadoop.hbase.TableNameQuotaTableUtil.QUOTA_TABLE_NAMESystem table for quotasMethods in org.apache.hadoop.hbase.quotas that return org.apache.hadoop.hbase.TableName in inModifier and TypeMethodDescriptionprotected static org.apache.hadoop.hbase.TableNameQuotaTableUtil.getTableFromRowKey(byte[] key) org.apache.hadoop.hbase.TableNameQuotaSettings.getTableName()Methods in org.apache.hadoop.hbase.quotas that return types with arguments of type org.apache.hadoop.hbase.TableName in inModifier and TypeMethodDescriptionMap<org.apache.hadoop.hbase.TableName,org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot> RegionServerSpaceQuotaManager.copyQuotaSnapshots()Copies the lastSpaceQuotaSnapshots 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.conf.Configuration conf, org.apache.hadoop.hbase.client.Connection connection, 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 toSpaceViolationPolicyEnforcements intoSpaceViolationPolicys.Map<org.apache.hadoop.hbase.TableName,org.apache.hadoop.hbase.quotas.SpaceViolationPolicyEnforcement> ActivePolicyEnforcement.getPolicies()Returns an unmodifiable version of the activeSpaceViolationPolicyEnforcements.static Map<org.apache.hadoop.hbase.TableName,org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot> QuotaTableUtil.getSnapshots(org.apache.hadoop.hbase.client.Connection conn) Fetches allSpaceQuotaSnapshotobjects from thehbase:quotatable.Map<org.apache.hadoop.hbase.TableName,org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot> QuotaObserverChore.getTableQuotaSnapshots()Returns an unmodifiable view over the currentSpaceQuotaSnapshotobjects 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.Methods in org.apache.hadoop.hbase.quotas with parameters of type org.apache.hadoop.hbase.TableName in inModifier and TypeMethodDescriptionstatic voidQuotaUtil.addTableQuota(org.apache.hadoop.hbase.client.Connection connection, org.apache.hadoop.hbase.TableName table, org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Quotas data) static voidQuotaUtil.addUserQuota(org.apache.hadoop.hbase.client.Connection connection, String user, org.apache.hadoop.hbase.TableName table, org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Quotas data) booleanRegionServerSpaceQuotaManager.areCompactionsDisabled(org.apache.hadoop.hbase.TableName tableName) Returns whether or not compactions should be disabled for the giventableNameper a space quota violation policy.org.apache.hadoop.hbase.shaded.protobuf.generated.RegionServerStatusProtos.FileArchiveNotificationRequestRegionServerSpaceQuotaManager.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.voidMasterQuotaManager.checkAndUpdateNamespaceRegionQuota(org.apache.hadoop.hbase.TableName tName, int regions) voidMasterQuotaManager.checkNamespaceTableAndRegionQuota(org.apache.hadoop.hbase.TableName tName, int regions) org.apache.hadoop.hbase.quotas.SpaceViolationPolicyEnforcementSpaceViolationPolicyEnforcementFactory.create(org.apache.hadoop.hbase.regionserver.RegionServerServices rss, org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot snapshot) Constructs the appropriateSpaceViolationPolicyEnforcementfor tables that are in violation of their space quota.org.apache.hadoop.hbase.quotas.SpaceViolationPolicyEnforcementSpaceViolationPolicyEnforcementFactory.createWithoutViolation(org.apache.hadoop.hbase.regionserver.RegionServerServices rss, org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot snapshot) Creates the "default"SpaceViolationPolicyEnforcementfor a table that isn't in violation.static voidQuotaUtil.deleteTableQuota(org.apache.hadoop.hbase.client.Connection connection, org.apache.hadoop.hbase.TableName table) static voidQuotaUtil.deleteUserQuota(org.apache.hadoop.hbase.client.Connection connection, String user, org.apache.hadoop.hbase.TableName table) static voidQuotaUtil.disableTableIfNotDisabled(org.apache.hadoop.hbase.client.Connection conn, org.apache.hadoop.hbase.TableName tableName) Method to disable a table, if not already disabled.voidRegionServerSpaceQuotaManager.disableViolationPolicyEnforcement(org.apache.hadoop.hbase.TableName tableName) Disables enforcement on any violation policy on the giventableName.static voidQuotaUtil.enableTableIfNotEnabled(org.apache.hadoop.hbase.client.Connection conn, org.apache.hadoop.hbase.TableName tableName) Method to enable a table, if not already enabled.voidRegionServerSpaceQuotaManager.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.FileArchiverNotifierFileArchiverNotifierFactory.get(org.apache.hadoop.hbase.client.Connection conn, org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.hbase.TableName tn) Creates or obtains aFileArchiverNotifierinstance for the given args.org.apache.hadoop.hbase.quotas.FileArchiverNotifierFileArchiverNotifierFactoryImpl.get(org.apache.hadoop.hbase.client.Connection conn, org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.hbase.TableName tn) Returns theFileArchiverNotifierinstance for the givenTableName.static org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshotQuotaTableUtil.getCurrentSnapshotFromQuotaTable(org.apache.hadoop.hbase.client.Connection conn, org.apache.hadoop.hbase.TableName tableName) Returns the current space quota snapshot of the giventableNamefromQuotaTableUtil.QUOTA_TABLE_NAMEor null if the no quota information is available for that tableName.org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshotTableQuotaSnapshotStore.getCurrentState(org.apache.hadoop.hbase.TableName table) org.apache.hadoop.hbase.quotas.SpaceViolationPolicyEnforcementActivePolicyEnforcement.getPolicyEnforcement(org.apache.hadoop.hbase.TableName tableName) Returns the properSpaceViolationPolicyEnforcementimplementation for the given table.org.apache.hadoop.hbase.quotas.OperationQuotaRegionServerRpcQuotaManager.getQuota(org.apache.hadoop.security.UserGroupInformation ugi, org.apache.hadoop.hbase.TableName table, int blockSizeBytes) Returns the quota for an operation.intMasterQuotaManager.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.SpaceQuotaTableQuotaSnapshotStore.getSpaceQuota(org.apache.hadoop.hbase.TableName subject) org.apache.hadoop.hbase.quotas.QuotaLimiterQuotaCache.getTableLimiter(org.apache.hadoop.hbase.TableName table) Returns the limiter associated to the specified table.org.apache.hadoop.hbase.quotas.QuotaLimiterUserQuotaState.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.QuotasQuotaTableUtil.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.SpaceQuotaSnapshotTableQuotaSnapshotStore.getTargetState(org.apache.hadoop.hbase.TableName table, org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.SpaceQuota spaceQuota) org.apache.hadoop.hbase.quotas.QuotaLimiterQuotaCache.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.QuotasQuotaTableUtil.getUserQuota(org.apache.hadoop.hbase.client.Connection connection, String user, org.apache.hadoop.hbase.TableName table) voidSpaceViolationPolicyEnforcement.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.QuotaSettingsQuotaSettingsFactory.limitTableSpace(org.apache.hadoop.hbase.TableName tableName, long sizeLimit, org.apache.hadoop.hbase.quotas.SpaceViolationPolicy violationPolicy) Creates aQuotaSettingsobject to limit the FileSystem space usage for the given table to the given size in bytes.static org.apache.hadoop.hbase.client.GetQuotaTableUtil.makeQuotaSnapshotGetForTable(org.apache.hadoop.hbase.TableName tn) Creates aGetwhich returns onlySpaceQuotaSnapshotfrom the quota table for a specific table.static org.apache.hadoop.hbase.client.ScanQuotaTableUtil.makeQuotaSnapshotScanForTable(org.apache.hadoop.hbase.TableName tn) Creates aScanwhich returns onlySpaceQuotaSnapshotfrom the quota table for a specific table.protected static voidQuotaTableUtil.parseTableResult(org.apache.hadoop.hbase.TableName table, org.apache.hadoop.hbase.client.Result result, org.apache.hadoop.hbase.quotas.QuotaTableUtil.TableQuotasVisitor visitor) voidMasterQuotasObserver.postDeleteTable(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.MasterCoprocessorEnvironment> ctx, org.apache.hadoop.hbase.TableName tableName) voidMasterQuotaManager.removeRegionSizesForTable(org.apache.hadoop.hbase.TableName tableName) Removes each region size entry where the RegionInfo references the provided TableName.voidMasterQuotaManager.removeTableFromNamespaceQuota(org.apache.hadoop.hbase.TableName tName) Remove table from namespace quota.static org.apache.hadoop.hbase.quotas.QuotaSettingsQuotaSettingsFactory.removeTableSpaceLimit(org.apache.hadoop.hbase.TableName tableName) Creates aQuotaSettingsobject to remove the FileSystem space quota for the given table.voidTableQuotaSnapshotStore.setCurrentState(org.apache.hadoop.hbase.TableName table, org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot snapshot) voidUserQuotaState.setQuotas(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.TableName table, org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Quotas quotas) Add the quota information of the specified table.voidMasterQuotaManager.setTableQuota(org.apache.hadoop.hbase.TableName table, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.SetQuotaRequest req) voidMasterQuotaManager.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.QuotaSettingsQuotaSettingsFactory.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.QuotaSettingsQuotaSettingsFactory.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.QuotaSettingsQuotaSettingsFactory.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.QuotaSettingsQuotaSettingsFactory.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.voidSpaceQuotaSnapshotNotifier.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.voidTableSpaceQuotaSnapshotNotifier.transitionTable(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot snapshot) static org.apache.hadoop.hbase.quotas.QuotaSettingsQuotaSettingsFactory.unthrottleTable(org.apache.hadoop.hbase.TableName tableName) Remove the throttling for the specified table.static org.apache.hadoop.hbase.quotas.QuotaSettingsQuotaSettingsFactory.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.QuotaSettingsQuotaSettingsFactory.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.QuotaSettingsQuotaSettingsFactory.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.voidQuotaTableUtil.TableQuotasVisitor.visitTableQuotas(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Quotas quotas) voidQuotaTableUtil.UserQuotasVisitor.visitUserQuotas(String userName, org.apache.hadoop.hbase.TableName table, org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Quotas quotas) Method parameters in org.apache.hadoop.hbase.quotas with type arguments of type org.apache.hadoop.hbase.TableName in inModifier and TypeMethodDescriptionstatic voidQuotaTableUtil.extractQuotaSnapshot(org.apache.hadoop.hbase.client.Result result, Map<org.apache.hadoop.hbase.TableName, org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot> snapshots) Extracts theSpaceViolationPolicyandTableNamefrom the providedResultand adds them to the givenMap.static Map<org.apache.hadoop.hbase.TableName,org.apache.hadoop.hbase.quotas.QuotaState> QuotaUtil.fetchTableQuotas(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.client.Connection connection, Map<org.apache.hadoop.hbase.TableName, Double> tableMachineFactors) QuotaUtil.fetchUserQuotas(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.client.Connection connection, Map<org.apache.hadoop.hbase.TableName, Double> tableMachineQuotaFactors, double factor) voidRegionServerSpaceQuotaManager.updateQuotaSnapshot(Map<org.apache.hadoop.hbase.TableName, org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot> newSnapshots) Updates the currentSpaceQuotaSnapshots for the RegionServer.Constructors in org.apache.hadoop.hbase.quotas with parameters of type org.apache.hadoop.hbase.TableName in inModifierConstructorDescriptionFileArchiverNotifierImpl(org.apache.hadoop.hbase.client.Connection conn, org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.hbase.TableName tn) protectedGlobalQuotaSettings(String userName, org.apache.hadoop.hbase.TableName tableName, String namespace, String regionServer) protectedGlobalQuotaSettingsImpl(String username, org.apache.hadoop.hbase.TableName tableName, String namespace, String regionServer, org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Quotas quotas) protectedGlobalQuotaSettingsImpl(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) protectedQuotaSettings(String userName, org.apache.hadoop.hbase.TableName tableName, String namespace, String regionServer) Constructor parameters in org.apache.hadoop.hbase.quotas with type arguments of type org.apache.hadoop.hbase.TableName in inModifierConstructorDescriptionActivePolicyEnforcement(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
Methods in org.apache.hadoop.hbase.quotas.policies that return org.apache.hadoop.hbase.TableName in inModifier and TypeMethodDescriptionorg.apache.hadoop.hbase.TableNameAbstractViolationPolicyEnforcement.getTableName()Methods in org.apache.hadoop.hbase.quotas.policies with parameters of type org.apache.hadoop.hbase.TableName in inModifier and TypeMethodDescriptionvoidAbstractViolationPolicyEnforcement.initialize(org.apache.hadoop.hbase.regionserver.RegionServerServices rss, org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot snapshot) voidAbstractViolationPolicyEnforcement.setTableName(org.apache.hadoop.hbase.TableName tableName) -
Uses of org.apache.hadoop.hbase.TableName in org.apache.hadoop.hbase.regionserver
Methods in org.apache.hadoop.hbase.regionserver that return org.apache.hadoop.hbase.TableName in inModifier and TypeMethodDescriptionorg.apache.hadoop.hbase.TableNameHStore.getTableName()org.apache.hadoop.hbase.TableNameStore.getTableName()org.apache.hadoop.hbase.TableNameStoreContext.getTableName()Methods in org.apache.hadoop.hbase.regionserver that return types with arguments of type org.apache.hadoop.hbase.TableName in inModifier and TypeMethodDescriptionSet<org.apache.hadoop.hbase.TableName>HRegionServer.getOnlineTables()Gets the online tables in this RS.Methods in org.apache.hadoop.hbase.regionserver with parameters of type org.apache.hadoop.hbase.TableName in inModifier 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) booleanHRegionServer.reportFileArchivalForQuotas(org.apache.hadoop.hbase.TableName tableName, Collection<Map.Entry<String, Long>> archivedFiles) booleanRegionServerServices.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 giventablewere just moved to the archive directory.Method parameters in org.apache.hadoop.hbase.regionserver with type arguments of type org.apache.hadoop.hbase.TableName in inModifier and TypeMethodDescriptionvoidStoreFileWriter.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
Constructors in org.apache.hadoop.hbase.regionserver.metrics with parameters of type org.apache.hadoop.hbase.TableName in inModifierConstructorDescriptionMetricsTableRequests(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
Methods in org.apache.hadoop.hbase.regionserver.storefiletracker that return org.apache.hadoop.hbase.TableName in inModifier and TypeMethodDescriptionorg.apache.hadoop.hbase.TableNameModifyStoreFileTrackerProcedure.getTableName()Methods in org.apache.hadoop.hbase.regionserver.storefiletracker with parameters of type org.apache.hadoop.hbase.TableName in inModifier and TypeMethodDescriptionStoreFileTracker.createHFileLink(org.apache.hadoop.hbase.TableName linkedTable, String linkedRegion, String hfileName, boolean createBackRef) Create a new HFileLinkConstructors in org.apache.hadoop.hbase.regionserver.storefiletracker with parameters of type org.apache.hadoop.hbase.TableName in inModifierConstructorDescriptionInitializeStoreFileTrackerProcedure(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) protectedModifyStoreFileTrackerProcedure(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
Methods in org.apache.hadoop.hbase.regionserver.wal with parameters of type org.apache.hadoop.hbase.TableName in inModifier and TypeMethodDescriptionvoidMetricsWALSource.incrementAppendCount(org.apache.hadoop.hbase.TableName tableName) Increment the count of wal appendsvoidMetricsWALSourceImpl.incrementAppendCount(org.apache.hadoop.hbase.TableName tableName) voidMetricsWALSource.incrementAppendSize(org.apache.hadoop.hbase.TableName tableName, long size) Add the append size.voidMetricsWALSourceImpl.incrementAppendSize(org.apache.hadoop.hbase.TableName tableName, long size) -
Uses of org.apache.hadoop.hbase.TableName in org.apache.hadoop.hbase.replication
Fields in org.apache.hadoop.hbase.replication declared as org.apache.hadoop.hbase.TableName in inModifier and TypeFieldDescriptionstatic final org.apache.hadoop.hbase.TableNameReplicationStorageFactory.REPLICATION_QUEUE_TABLE_NAME_DEFAULTMethods in org.apache.hadoop.hbase.replication that return types with arguments of type org.apache.hadoop.hbase.TableName in inModifier and TypeMethodDescriptionReplicationPeerConfig.getExcludeTableCFsMap()ReplicationPeer.getTableCFs()Get replicable (table, cf-list) map of this peerReplicationPeerImpl.getTableCFs()ReplicationPeerConfig.getTableCFsMap()Methods in org.apache.hadoop.hbase.replication with parameters of type org.apache.hadoop.hbase.TableName in inModifier and TypeMethodDescriptionstatic org.apache.hadoop.hbase.client.TableDescriptorReplicationStorageFactory.createReplicationQueueTableDescriptor(org.apache.hadoop.hbase.TableName tableName) static org.apache.hadoop.hbase.replication.ReplicationBarrierFamilyFormat.ReplicationBarrierResultReplicationBarrierFamilyFormat.getReplicationBarrierResult(org.apache.hadoop.hbase.client.Connection conn, org.apache.hadoop.hbase.TableName tableName, byte[] row, byte[] encodedRegionName) static org.apache.hadoop.hbase.replication.ReplicationQueueStorageReplicationStorageFactory.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 booleanReplicationStorageFactory.isReplicationQueueTable(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.TableName tableName) booleanReplicationPeerConfig.needToReplicate(org.apache.hadoop.hbase.TableName table) Decide whether the table need replicate to the peer clusterbooleanReplicationPeerConfig.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.Method parameters in org.apache.hadoop.hbase.replication with type arguments of type org.apache.hadoop.hbase.TableName in inModifier and TypeMethodDescriptionorg.apache.hadoop.hbase.replication.ReplicationPeerConfigBuilderReplicationPeerConfigBuilder.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.ReplicationPeerConfigBuilderReplicationPeerConfigBuilder.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.Constructors in org.apache.hadoop.hbase.replication with parameters of type org.apache.hadoop.hbase.TableName in inModifierConstructorDescriptionTableReplicationQueueStorage(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
Methods in org.apache.hadoop.hbase.rsgroup that return types with arguments of type org.apache.hadoop.hbase.TableName in inModifier 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) Methods in org.apache.hadoop.hbase.rsgroup with parameters of type org.apache.hadoop.hbase.TableName in inModifier and TypeMethodDescriptionvoidRSGroupInfo.addTable(org.apache.hadoop.hbase.TableName table) Deprecated.Since 3.0.0, will be removed in 4.0.0.booleanRSGroupInfo.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) DetermineRSGroupInfofor the given table.org.apache.hadoop.hbase.rsgroup.RSGroupInfoRSGroupInfoManager.getRSGroupForTable(org.apache.hadoop.hbase.TableName tableName) GetRSGroupInfofor 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 fromTableDescriptorfirst, and then try to get the rsgroup from theNamespaceDescriptor.org.apache.hadoop.hbase.rsgroup.RSGroupInfoRSGroupAdminClient.getRSGroupInfoOfTable(org.apache.hadoop.hbase.TableName tableName) Deprecated.GetsRSGroupInfofor the given table's group.booleanRSGroupInfo.removeTable(org.apache.hadoop.hbase.TableName table) Deprecated.Since 3.0.0, will be removed in 4.0.0.Method parameters in org.apache.hadoop.hbase.rsgroup with type arguments of type org.apache.hadoop.hbase.TableName in inModifier and TypeMethodDescriptionvoidRSGroupInfo.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.voidDeprecated.Move given set of tables to the specified target RegionServer group.voidSet group for tables.voidRSGroupBasedLoadBalancer.updateBalancerLoadInfo(Map<org.apache.hadoop.hbase.TableName, Map<org.apache.hadoop.hbase.ServerName, List<org.apache.hadoop.hbase.client.RegionInfo>>> loadOfAllTable) Constructors in org.apache.hadoop.hbase.rsgroup with parameters of type org.apache.hadoop.hbase.TableName in inModifierConstructorDescriptionMigrateRSGroupProcedure(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
Methods in org.apache.hadoop.hbase.shaded.protobuf that return org.apache.hadoop.hbase.TableName in inModifier 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.TableNameProtobufUtil.toTableName(org.apache.hadoop.hbase.shaded.protobuf.generated.HBaseProtos.TableName tableNamePB) Methods in org.apache.hadoop.hbase.shaded.protobuf that return types with arguments of type org.apache.hadoop.hbase.TableName in inModifier and TypeMethodDescriptionstatic List<org.apache.hadoop.hbase.TableName>ProtobufUtil.toTableNameList(List<org.apache.hadoop.hbase.shaded.protobuf.generated.HBaseProtos.TableName> tableNamesList) Methods in org.apache.hadoop.hbase.shaded.protobuf with parameters of type org.apache.hadoop.hbase.TableName in inModifier and TypeMethodDescriptionstatic org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.AddColumnRequestRequestConverter.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.DeleteColumnRequestRequestConverter.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.DeleteTableRequestRequestConverter.buildDeleteTableRequest(org.apache.hadoop.hbase.TableName tableName, long nonceGroup, long nonce) Creates a protocol buffer DeleteTableRequeststatic org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.DisableTableRequestRequestConverter.buildDisableTableRequest(org.apache.hadoop.hbase.TableName tableName, long nonceGroup, long nonce) Creates a protocol buffer DisableTableRequeststatic org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.EnableTableRequestRequestConverter.buildEnableTableRequest(org.apache.hadoop.hbase.TableName tableName, long nonceGroup, long nonce) Creates a protocol buffer EnableTableRequeststatic org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.FlushTableRequestRequestConverter.buildFlushTableRequest(org.apache.hadoop.hbase.TableName tableName, List<byte[]> columnFamilies, long nonceGroup, long nonce) static org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.GetRegionLoadRequestRequestConverter.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.GetTableDescriptorsRequestRequestConverter.buildGetTableDescriptorsRequest(org.apache.hadoop.hbase.TableName tableName) Creates a protocol buffer GetTableDescriptorsRequest for a single tablestatic org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.ModifyColumnRequestRequestConverter.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.ModifyColumnStoreFileTrackerRequestRequestConverter.buildModifyColumnStoreFileTrackerRequest(org.apache.hadoop.hbase.TableName tableName, byte[] family, String dstSFT, long nonceGroup, long nonce) static org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.ModifyTableRequestRequestConverter.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.ModifyTableStoreFileTrackerRequestRequestConverter.buildModifyTableStoreFileTrackerRequest(org.apache.hadoop.hbase.TableName tableName, String dstSFT, long nonceGroup, long nonce) static org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.TruncateTableRequestRequestConverter.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.BulkLoadDescriptorProtobufUtil.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.BulkLoadDescriptorProtobufUtil.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.TableNameProtobufUtil.toProtoTableName(org.apache.hadoop.hbase.TableName tableName) Method parameters in org.apache.hadoop.hbase.shaded.protobuf with type arguments of type org.apache.hadoop.hbase.TableName in inModifier and TypeMethodDescriptionstatic org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.GetTableDescriptorsRequestRequestConverter.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
Fields in org.apache.hadoop.hbase.slowlog declared as org.apache.hadoop.hbase.TableName in inModifier and TypeFieldDescriptionstatic final org.apache.hadoop.hbase.TableNameSlowLogTableAccessor.SLOW_LOG_TABLE_NAMEhbase: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
Methods in org.apache.hadoop.hbase.snapshot that return org.apache.hadoop.hbase.TableName in inModifier and TypeMethodDescriptionorg.apache.hadoop.hbase.TableNameSnapshotRegionLocator.getName()Methods in org.apache.hadoop.hbase.snapshot with parameters of type org.apache.hadoop.hbase.TableName in inModifier and TypeMethodDescriptionstatic org.apache.hadoop.hbase.client.RegionInfoRestoreSnapshotHelper.cloneRegionInfo(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.RegionInfo snapshotRegionInfo) static org.apache.hadoop.hbase.snapshot.SnapshotRegionLocatorSnapshotRegionLocator.create(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.TableName table) static voidRestoreSnapshotHelper.restoreSnapshotAcl(org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotDescription snapshot, org.apache.hadoop.hbase.TableName newTableName, org.apache.hadoop.conf.Configuration conf) static voidSnapshotRegionLocator.setSnapshotManifestDir(org.apache.hadoop.conf.Configuration conf, String dir, org.apache.hadoop.hbase.TableName table) static booleanSnapshotRegionLocator.shouldUseSnapshotRegionLocator(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.TableName table) Constructors in org.apache.hadoop.hbase.snapshot with parameters of type org.apache.hadoop.hbase.TableName in inModifierConstructorDescriptionTablePartiallyOpenException(org.apache.hadoop.hbase.TableName tableName) -
Uses of org.apache.hadoop.hbase.TableName in org.apache.hadoop.hbase.util
Fields in org.apache.hadoop.hbase.util declared as org.apache.hadoop.hbase.TableName in inModifier and TypeFieldDescriptionprotected final org.apache.hadoop.hbase.TableNameMultiThreadedAction.tableNameMethods in org.apache.hadoop.hbase.util that return org.apache.hadoop.hbase.TableName in inModifier and TypeMethodDescriptionorg.apache.hadoop.hbase.TableNameHbckTableInfo.getName()static org.apache.hadoop.hbase.TableNameCommonFSUtils.getTableName(org.apache.hadoop.fs.Path tablePath) Returns theTableNameobject representing the table directory under path rootdirorg.apache.hadoop.hbase.TableNameHbckRegionInfo.getTableName()static org.apache.hadoop.hbase.TableNameHFileArchiveUtil.getTableName(org.apache.hadoop.fs.Path archivePath) Methods in org.apache.hadoop.hbase.util with parameters of type org.apache.hadoop.hbase.TableName in inModifier and TypeMethodDescriptionprotected voidLoadTestTool.applyColumnFamilyOptions(org.apache.hadoop.hbase.TableName tableName, byte[][] columnFamilies) Apply column family options such as Bloom filters, compression, and data block encoding.static intLoadTestUtil.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 intLoadTestUtil.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 intLoadTestUtil.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.TableDescriptorFSTableDescriptors.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.PathHFileArchiveUtil.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.PathHFileArchiveUtil.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.PathCommonFSUtils.getRegionDir(org.apache.hadoop.fs.Path rootdir, org.apache.hadoop.hbase.TableName tableName, String regionName) Returns thePathobject representing the region directory under path rootdirstatic org.apache.hadoop.fs.PathHFileArchiveUtil.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.PathHFileArchiveUtil.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.PathHFileArchiveUtil.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.TableDescriptorFSTableDescriptors.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.PathCommonFSUtils.getTableDir(org.apache.hadoop.fs.Path rootdir, org.apache.hadoop.hbase.TableName tableName) Returns thePathobject 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.PathCommonFSUtils.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.PathCommonFSUtils.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.PathCommonFSUtils.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.voidHBaseFsck.includeTable(org.apache.hadoop.hbase.TableName table) Deprecated.static booleanServerRegionReplicaUtil.isMetaRegionReplicaReplicationEnabled(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.TableName tn) Returns True if hbase:meta Region Read Replica is enabled.static booleanServerRegionReplicaUtil.isRegionReplicaReplicationEnabled(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.TableName tn) org.apache.hadoop.hbase.client.TableDescriptorFSTableDescriptors.remove(org.apache.hadoop.hbase.TableName tablename) Removes the table descriptor from the local cache and returns it.Constructors in org.apache.hadoop.hbase.util with parameters of type org.apache.hadoop.hbase.TableName in inModifierConstructorDescriptionMultiThreadedAction(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
Fields in org.apache.hadoop.hbase.util.compaction declared as org.apache.hadoop.hbase.TableName in inModifier and TypeFieldDescriptionprotected org.apache.hadoop.hbase.TableNameMajorCompactor.tableNameConstructors in org.apache.hadoop.hbase.util.compaction with parameters of type org.apache.hadoop.hbase.TableName in in -
Uses of org.apache.hadoop.hbase.TableName in org.apache.hadoop.hbase.wal
Methods in org.apache.hadoop.hbase.wal that return org.apache.hadoop.hbase.TableName in inModifier and TypeMethodDescriptionorg.apache.hadoop.hbase.TableNameWALKey.getTableName()Returns table nameorg.apache.hadoop.hbase.TableNameWALKeyImpl.getTableName()Returns table nameMethods in org.apache.hadoop.hbase.wal with parameters of type org.apache.hadoop.hbase.TableName in inModifier and TypeMethodDescriptionprotected voidWALKeyImpl.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) Constructors in org.apache.hadoop.hbase.wal with parameters of type org.apache.hadoop.hbase.TableName in inModifierConstructorDescriptionWALKeyImpl(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)