Uses of Interface
org.apache.hadoop.hbase.client.TableDescriptor
Packages that use TableDescriptor
Package
Description
Provides HBase Client
Restrict the domain of a data attribute, often times to fulfill business rules/requirements.
Table of Contents
Provides HBase MapReduce
Input/OutputFormats, a table indexing MapReduce job, and utility methods.
Provides HBase MapReduce
Input/OutputFormats, a table indexing MapReduce job, and utility methods.
The Region Normalizer subsystem is responsible for coaxing all the regions in a table toward
 a "normal" size, according to their storefile size.
Multi Cluster Replication
HBase REST
Provides an HBase Thrift
service.
- 
Uses of TableDescriptor in org.apache.hadoop.hbaseMethods in org.apache.hadoop.hbase that return TableDescriptorModifier and TypeMethodDescriptionHBaseTestingUtility.createTableDescriptor(TableName name) Deprecated.Create a table of namename.HBaseTestingUtility.createTableDescriptor(TableName tableName, byte[] family) Deprecated.HBaseTestingUtility.createTableDescriptor(TableName tableName, byte[][] families, int maxVersions) Deprecated.HBaseTestingUtility.createTableDescriptor(TableName name, int minVersions, int versions, int ttl, KeepDeletedCells keepDeleted) Deprecated.Returns TableDescriptor for tablenameprotected static TableDescriptorPerformanceEvaluation.getTableDescriptor(PerformanceEvaluation.TestOptions opts) Create an HTableDescriptor from provided TestOptions.Returns Instance of table descriptor or null if none found.Methods in org.apache.hadoop.hbase that return types with arguments of type TableDescriptorModifier and TypeMethodDescriptionTableDescriptors.getAll()Get Map of all TableDescriptors.TableDescriptors.getByNamespace(String name) Get Map of all NamespaceDescriptors for a given namespace.Methods in org.apache.hadoop.hbase with parameters of type TableDescriptorModifier and TypeMethodDescriptionHBaseTestingUtility.createLocalHRegion(RegionInfo info, org.apache.hadoop.conf.Configuration conf, TableDescriptor desc, WAL wal) Deprecated.Create an HRegion that writes to the local tmp dirs with specified walHBaseTestingUtility.createLocalHRegion(RegionInfo info, TableDescriptor desc) Deprecated.Create an HRegion that writes to the local tmp dirs.HBaseTestingUtility.createLocalHRegion(TableDescriptor desc, byte[] startKey, byte[] endKey) Deprecated.Create an HRegion that writes to the local tmp dirsHBaseTestingUtility.createMultiRegionsInMeta(org.apache.hadoop.conf.Configuration conf, TableDescriptor htd, byte[][] startKeys) Deprecated.Create rows in hbase:meta for regions of the specified table with the specified start keys.static intHBaseTestingUtility.createPreSplitLoadTestTable(org.apache.hadoop.conf.Configuration conf, TableDescriptor desc, ColumnFamilyDescriptor hcd) Deprecated.Creates a pre-split table for load testing.static intHBaseTestingUtility.createPreSplitLoadTestTable(org.apache.hadoop.conf.Configuration conf, TableDescriptor desc, ColumnFamilyDescriptor[] hcds, int numRegionsPerServer) Deprecated.Creates a pre-split table for load testing.static intHBaseTestingUtility.createPreSplitLoadTestTable(org.apache.hadoop.conf.Configuration conf, TableDescriptor td, ColumnFamilyDescriptor[] cds, RegionSplitter.SplitAlgorithm splitter, int numRegionsPerServer) Deprecated.Creates a pre-split table for load testing.static intHBaseTestingUtility.createPreSplitLoadTestTable(org.apache.hadoop.conf.Configuration conf, TableDescriptor desc, ColumnFamilyDescriptor hcd, int numRegionsPerServer) Deprecated.Creates a pre-split table for load testing.static HRegionHBaseTestingUtility.createRegionAndWAL(RegionInfo info, org.apache.hadoop.fs.Path rootDir, org.apache.hadoop.conf.Configuration conf, TableDescriptor htd) Deprecated.Create a region with it's own WAL.static HRegionHBaseTestingUtility.createRegionAndWAL(RegionInfo info, org.apache.hadoop.fs.Path rootDir, org.apache.hadoop.conf.Configuration conf, TableDescriptor htd, boolean initialize) Deprecated.Create a region with it's own WAL.static HRegionHBaseTestingUtility.createRegionAndWAL(RegionInfo info, org.apache.hadoop.fs.Path rootDir, org.apache.hadoop.conf.Configuration conf, TableDescriptor htd, BlockCache blockCache) Deprecated.Create a region with it's own WAL.static HRegionHBaseTestingUtility.createRegionAndWAL(RegionInfo info, org.apache.hadoop.fs.Path rootDir, org.apache.hadoop.conf.Configuration conf, TableDescriptor htd, MobFileCache mobFileCache) Deprecated.Create a region with it's own WAL.HBaseTestingUtility.createTable(TableDescriptor htd, byte[][] splitRows) Deprecated.Create a table.HBaseTestingUtility.createTable(TableDescriptor htd, byte[][] families, byte[][] splitKeys, org.apache.hadoop.conf.Configuration c) Deprecated.Create a table.HBaseTestingUtility.createTable(TableDescriptor htd, byte[][] families, byte[][] splitKeys, BloomType type, int blockSize, org.apache.hadoop.conf.Configuration c) Deprecated.Create a table.HBaseTestingUtility.createTable(TableDescriptor htd, byte[][] families, org.apache.hadoop.conf.Configuration c) Deprecated.Create a table.static voidHBaseTestingUtility.modifyTableSync(Admin admin, TableDescriptor desc) Deprecated.since 3.0.0 and will be removed in 4.0.0.default voidTableDescriptors.update(TableDescriptor htd) Add or update descriptor.voidTableDescriptors.update(TableDescriptor htd, boolean cacheOnly) Add or update descriptorvoidHBaseTestingUtility.verifyTableDescriptorIgnoreTableName(TableDescriptor ltd, TableDescriptor rtd) Deprecated.
- 
Uses of TableDescriptor in org.apache.hadoop.hbase.backupMethods in org.apache.hadoop.hbase.backup with parameters of type TableDescriptorModifier and TypeMethodDescriptionvoidBackupMasterObserver.postModifyTable(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName, TableDescriptor oldDescriptor, TableDescriptor currentDescriptor) 
- 
Uses of TableDescriptor in org.apache.hadoop.hbase.backup.implMethods in org.apache.hadoop.hbase.backup.impl that return TableDescriptorModifier and TypeMethodDescriptionstatic TableDescriptorBackupSystemTable.getSystemTableDescriptor(org.apache.hadoop.conf.Configuration conf) Get backup system table descriptorstatic TableDescriptorBackupSystemTable.getSystemTableForBulkLoadedDataDescriptor(org.apache.hadoop.conf.Configuration conf) Get backup system table descriptorMethods in org.apache.hadoop.hbase.backup.impl with parameters of type TableDescriptorModifier and TypeMethodDescriptionprivate voidBackupSystemTable.createSystemTable(Admin admin, TableDescriptor descriptor) 
- 
Uses of TableDescriptor in org.apache.hadoop.hbase.backup.utilMethods in org.apache.hadoop.hbase.backup.util that return TableDescriptorModifier and TypeMethodDescription(package private) TableDescriptorRestoreTool.getTableDesc(TableName tableName) Get table descriptorprivate TableDescriptorRestoreTool.getTableDescriptor(org.apache.hadoop.fs.FileSystem fileSys, TableName tableName, String lastIncrBackupId) Methods in org.apache.hadoop.hbase.backup.util with parameters of type TableDescriptorModifier and TypeMethodDescriptionprivate voidRestoreTool.checkAndCreateTable(Connection conn, TableName targetTableName, ArrayList<org.apache.hadoop.fs.Path> regionDirList, TableDescriptor htd, boolean truncateIfExists) Prepare the table for bulkload, most codes copied fromcreateTablemethod inBulkLoadHFilesTool.(package private) voidRestoreTool.modifyTableSync(Connection conn, TableDescriptor desc) 
- 
Uses of TableDescriptor in org.apache.hadoop.hbase.clientClasses in org.apache.hadoop.hbase.client that implement TableDescriptorModifier and TypeClassDescriptionprivate static final classFields in org.apache.hadoop.hbase.client declared as TableDescriptorModifier and TypeFieldDescriptionprivate TableDescriptorTableSnapshotScanner.htdstatic final TableDescriptorTableDescriptorBuilder.NAMESPACE_TABLEDESCDeprecated.since 3.0.0 and will be removed in 4.0.0.Fields in org.apache.hadoop.hbase.client with type parameters of type TableDescriptorModifier and TypeFieldDescriptionstatic final Comparator<TableDescriptor>TableDescriptor.COMPARATORstatic final Comparator<TableDescriptor>TableDescriptor.COMPARATOR_IGNORE_REPLICATIONMethods in org.apache.hadoop.hbase.client that return TableDescriptorModifier and TypeMethodDescriptionTableDescriptorBuilder.build()static TableDescriptorTableDescriptorBuilder.copy(TableDescriptor desc) static TableDescriptorTableDescriptorBuilder.copy(TableName name, TableDescriptor desc) Admin.getDescriptor(TableName tableName) Get a table descriptor.AdminOverAsyncAdmin.getDescriptor(TableName tableName) Table.getDescriptor()Gets thetable descriptorfor this table.TableOverAsyncTable.getDescriptor()private static TableDescriptorTableDescriptorBuilder.ModifyableTableDescriptor.parseFrom(byte[] bytes) static TableDescriptorTableDescriptorBuilder.parseFrom(byte[] pbBytes) The input should be created byTableDescriptorBuilder.toByteArray(org.apache.hadoop.hbase.client.TableDescriptor).Methods in org.apache.hadoop.hbase.client that return types with arguments of type TableDescriptorModifier and TypeMethodDescriptionstatic Comparator<TableDescriptor>TableDescriptor.getComparator(Comparator<ColumnFamilyDescriptor> cfComparator) AsyncAdmin.getDescriptor(TableName tableName) Method for getting the tableDescriptorAsyncHBaseAdmin.getDescriptor(TableName tableName) AsyncTable.getDescriptor()Gets theTableDescriptorfor this table.AsyncTableImpl.getDescriptor()RawAsyncHBaseAdmin.getDescriptor(TableName tableName) RawAsyncTableImpl.getDescriptor()private CompletableFuture<List<TableDescriptor>>RawAsyncHBaseAdmin.getTableDescriptors(org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.GetTableDescriptorsRequest request) Admin.listTableDescriptors()List all the userspace tables.Admin.listTableDescriptors(boolean includeSysTables) List all userspace tables and whether or not include system tables.Admin.listTableDescriptors(List<TableName> tableNames) Get tableDescriptors.default List<TableDescriptor>Admin.listTableDescriptors(Pattern pattern) List all the userspace tables that match the given pattern.Admin.listTableDescriptors(Pattern pattern, boolean includeSysTables) List all the tables matching the given pattern.AdminOverAsyncAdmin.listTableDescriptors()AdminOverAsyncAdmin.listTableDescriptors(boolean includeSysTables) AdminOverAsyncAdmin.listTableDescriptors(List<TableName> tableNames) AdminOverAsyncAdmin.listTableDescriptors(Pattern pattern, boolean includeSysTables) default CompletableFuture<List<TableDescriptor>>AsyncAdmin.listTableDescriptors()List all the userspace tables.AsyncAdmin.listTableDescriptors(boolean includeSysTables) List all the tables.AsyncAdmin.listTableDescriptors(List<TableName> tableNames) List specific tables including system tables.AsyncAdmin.listTableDescriptors(Pattern pattern, boolean includeSysTables) List all the tables matching the given pattern.AsyncHBaseAdmin.listTableDescriptors(boolean includeSysTables) AsyncHBaseAdmin.listTableDescriptors(List<TableName> tableNames) AsyncHBaseAdmin.listTableDescriptors(Pattern pattern, boolean includeSysTables) RawAsyncHBaseAdmin.listTableDescriptors(boolean includeSysTables) RawAsyncHBaseAdmin.listTableDescriptors(List<TableName> tableNames) RawAsyncHBaseAdmin.listTableDescriptors(Pattern pattern, boolean includeSysTables) Admin.listTableDescriptorsByNamespace(byte[] name) Get list of table descriptors by namespace.AdminOverAsyncAdmin.listTableDescriptorsByNamespace(byte[] name) AsyncAdmin.listTableDescriptorsByNamespace(String name) Get list of table descriptors by namespace.AsyncHBaseAdmin.listTableDescriptorsByNamespace(String name) RawAsyncHBaseAdmin.listTableDescriptorsByNamespace(String name) Admin.listTableDescriptorsByState(boolean isEnabled) List all enabled or disabled tablesAdminOverAsyncAdmin.listTableDescriptorsByState(boolean isEnabled) AsyncAdmin.listTableDescriptorsByState(boolean isEnabled) List all enabled or disabled table descriptorsAsyncHBaseAdmin.listTableDescriptorsByState(boolean isEnabled) RawAsyncHBaseAdmin.listTableDescriptorsByState(boolean isEnabled) Methods in org.apache.hadoop.hbase.client with parameters of type TableDescriptorModifier and TypeMethodDescriptionprivate CompletableFuture<Void>RawAsyncHBaseAdmin.compareTableWithPeerCluster(TableName tableName, TableDescriptor tableDesc, ReplicationPeerDescription peer, AsyncAdmin peerAdmin) TableDescriptorUtils.computeDelta(TableDescriptor oldTD, TableDescriptor newTD) Compares twoTableDescriptorand indicate which columns were added, deleted, or modified from oldTD to newTDstatic TableDescriptorTableDescriptorBuilder.copy(TableDescriptor desc) static TableDescriptorTableDescriptorBuilder.copy(TableName name, TableDescriptor desc) default voidAdmin.createTable(TableDescriptor desc) Creates a new table.default voidAdmin.createTable(TableDescriptor desc, byte[][] splitKeys) Creates a new table with an initial set of empty regions defined by the specified split keys.voidAdmin.createTable(TableDescriptor desc, byte[] startKey, byte[] endKey, int numRegions) Creates a new table with the specified number of regions.voidAdminOverAsyncAdmin.createTable(TableDescriptor desc, byte[] startKey, byte[] endKey, int numRegions) AsyncAdmin.createTable(TableDescriptor desc) Creates a new table.AsyncAdmin.createTable(TableDescriptor desc, byte[][] splitKeys) Creates a new table with an initial set of empty regions defined by the specified split keys.AsyncAdmin.createTable(TableDescriptor desc, byte[] startKey, byte[] endKey, int numRegions) Creates a new table with the specified number of regions.AsyncHBaseAdmin.createTable(TableDescriptor desc) AsyncHBaseAdmin.createTable(TableDescriptor desc, byte[][] splitKeys) AsyncHBaseAdmin.createTable(TableDescriptor desc, byte[] startKey, byte[] endKey, int numRegions) RawAsyncHBaseAdmin.createTable(TableDescriptor desc) RawAsyncHBaseAdmin.createTable(TableDescriptor desc, byte[][] splitKeys) RawAsyncHBaseAdmin.createTable(TableDescriptor desc, byte[] startKey, byte[] endKey, int numRegions) Admin.createTableAsync(TableDescriptor desc) Creates a new table but does not block and wait for it to come online.Admin.createTableAsync(TableDescriptor desc, byte[][] splitKeys) Creates a new table but does not block and wait for it to come online.AdminOverAsyncAdmin.createTableAsync(TableDescriptor desc) AdminOverAsyncAdmin.createTableAsync(TableDescriptor desc, byte[][] splitKeys) default voidAdmin.modifyTable(TableDescriptor td) Modify an existing table, more IRB friendly version.default CompletableFuture<Void>AsyncAdmin.modifyTable(TableDescriptor desc) Modify an existing table, more IRB friendly version.AsyncAdmin.modifyTable(TableDescriptor desc, boolean reopenRegions) Modify an existing table, more IRB friendly version.AsyncHBaseAdmin.modifyTable(TableDescriptor desc) AsyncHBaseAdmin.modifyTable(TableDescriptor desc, boolean reopenRegions) RawAsyncHBaseAdmin.modifyTable(TableDescriptor desc) RawAsyncHBaseAdmin.modifyTable(TableDescriptor desc, boolean reopenRegions) Admin.modifyTableAsync(TableDescriptor td) Modify an existing table, more IRB (ruby) friendly version.Admin.modifyTableAsync(TableDescriptor td, boolean reopenRegions) The same asAdmin.modifyTableAsync(TableDescriptor td), except for the reopenRegions parameter, which controls whether the process of modifying the table should reopen all regions.AdminOverAsyncAdmin.modifyTableAsync(TableDescriptor td) AdminOverAsyncAdmin.modifyTableAsync(TableDescriptor td, boolean reopenRegions) static TableDescriptorBuilderTableDescriptorBuilder.newBuilder(TableDescriptor desc) Copy all values, families, and name from the input.static byte[]TableDescriptorBuilder.toByteArray(TableDescriptor desc) Returns This instance serialized with pb with pb magic prefixConstructors in org.apache.hadoop.hbase.client with parameters of type TableDescriptorModifierConstructorDescriptionClientSideRegionScanner(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.fs.Path rootDir, TableDescriptor htd, RegionInfo hri, Scan scan, ScanMetrics scanMetrics) privateprivateModifyableTableDescriptor(TableName name, TableDescriptor desc) Construct a table descriptor by cloning the descriptor passed as a parameter.privateprivateTableDescriptorDelta(TableDescriptor oldTD, TableDescriptor newTD) 
- 
Uses of TableDescriptor in org.apache.hadoop.hbase.constraintMethods in org.apache.hadoop.hbase.constraint with parameters of type TableDescriptorModifier and TypeMethodDescriptionstatic booleanConstraints.enabled(TableDescriptor desc, Class<? extends Constraint> clazz) Check to see if the given constraint is enabled.(package private) static List<? extends Constraint>Constraints.getConstraints(TableDescriptor desc, ClassLoader classloader) Get the constraints stored in the table descriptorConstraints.getKeyValueForClass(TableDescriptor desc, Class<? extends Constraint> clazz) Get the kvMap.Entryin the descriptor for the specified classstatic booleanConstraints.has(TableDescriptor desc, Class<? extends Constraint> clazz) Check to see if the Constraint is currently set.
- 
Uses of TableDescriptor in org.apache.hadoop.hbase.coprocessorMethods in org.apache.hadoop.hbase.coprocessor that return TableDescriptorModifier and TypeMethodDescriptiondefault TableDescriptorMasterObserver.preCreateTableRegionsInfos(ObserverContext<MasterCoprocessorEnvironment> ctx, TableDescriptor desc) Called before we create the region infos for this table.default TableDescriptorMasterObserver.preModifyTable(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName, TableDescriptor currentDescriptor, TableDescriptor newDescriptor) Called prior to modifying a table's properties.Methods in org.apache.hadoop.hbase.coprocessor with parameters of type TableDescriptorModifier and TypeMethodDescriptiondefault voidMasterObserver.postCloneSnapshot(ObserverContext<MasterCoprocessorEnvironment> ctx, SnapshotDescription snapshot, TableDescriptor tableDescriptor) Called after a snapshot clone operation has been requested.default voidMasterObserver.postCompletedCreateTableAction(ObserverContext<MasterCoprocessorEnvironment> ctx, TableDescriptor desc, RegionInfo[] regions) Called after the createTable operation has been requested.default voidMasterObserver.postCompletedModifyTableAction(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName, TableDescriptor oldDescriptor, TableDescriptor currentDescriptor) Called after to modifying a table's properties.default voidMasterObserver.postCompletedSnapshotAction(ObserverContext<MasterCoprocessorEnvironment> ctx, SnapshotDescription snapshot, TableDescriptor tableDescriptor) Called after the snapshot operation has been completed.default voidMasterObserver.postCreateTable(ObserverContext<MasterCoprocessorEnvironment> ctx, TableDescriptor desc, RegionInfo[] regions) Called after the createTable operation has been requested.default voidMasterObserver.postModifyTable(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName, TableDescriptor oldDescriptor, TableDescriptor currentDescriptor) Called after the modifyTable operation has been requested.default voidMasterObserver.postRestoreSnapshot(ObserverContext<MasterCoprocessorEnvironment> ctx, SnapshotDescription snapshot, TableDescriptor tableDescriptor) Called after a snapshot restore operation has been requested.default voidMasterObserver.postSnapshot(ObserverContext<MasterCoprocessorEnvironment> ctx, SnapshotDescription snapshot, TableDescriptor tableDescriptor) Called after the snapshot operation has been requested.default voidMasterObserver.preCloneSnapshot(ObserverContext<MasterCoprocessorEnvironment> ctx, SnapshotDescription snapshot, TableDescriptor tableDescriptor) Called before a snapshot is cloned.default voidMasterObserver.preCreateTable(ObserverContext<MasterCoprocessorEnvironment> ctx, TableDescriptor desc, RegionInfo[] regions) Called before a new table is created byHMaster.default voidMasterObserver.preCreateTableAction(ObserverContext<MasterCoprocessorEnvironment> ctx, TableDescriptor desc, RegionInfo[] regions) Called before a new table is created byHMaster.default TableDescriptorMasterObserver.preCreateTableRegionsInfos(ObserverContext<MasterCoprocessorEnvironment> ctx, TableDescriptor desc) Called before we create the region infos for this table.default TableDescriptorMasterObserver.preModifyTable(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName, TableDescriptor currentDescriptor, TableDescriptor newDescriptor) Called prior to modifying a table's properties.default voidMasterObserver.preModifyTableAction(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName, TableDescriptor currentDescriptor, TableDescriptor newDescriptor) Called prior to modifying a table's properties.default voidMasterObserver.preRestoreSnapshot(ObserverContext<MasterCoprocessorEnvironment> ctx, SnapshotDescription snapshot, TableDescriptor tableDescriptor) Called before a snapshot is restored.default voidMasterObserver.preSnapshot(ObserverContext<MasterCoprocessorEnvironment> ctx, SnapshotDescription snapshot, TableDescriptor tableDescriptor) Called before a new snapshot is taken.Method parameters in org.apache.hadoop.hbase.coprocessor with type arguments of type TableDescriptorModifier and TypeMethodDescriptiondefault voidMasterObserver.postGetTableNames(ObserverContext<MasterCoprocessorEnvironment> ctx, List<TableDescriptor> descriptors, String regex) Called after a getTableNames request has been processed.default voidMasterObserver.preGetTableNames(ObserverContext<MasterCoprocessorEnvironment> ctx, List<TableDescriptor> descriptors, String regex) Called before a getTableNames request has been processed.
- 
Uses of TableDescriptor in org.apache.hadoop.hbase.coprocessor.exampleMethods in org.apache.hadoop.hbase.coprocessor.example with parameters of type TableDescriptorModifier and TypeMethodDescriptionvoidExampleMasterObserverWithMetrics.postCreateTable(ObserverContext<MasterCoprocessorEnvironment> ctx, TableDescriptor desc, RegionInfo[] regions) voidExampleMasterObserverWithMetrics.preCreateTable(ObserverContext<MasterCoprocessorEnvironment> ctx, TableDescriptor desc, RegionInfo[] regions) 
- 
Uses of TableDescriptor in org.apache.hadoop.hbase.fsMethods in org.apache.hadoop.hbase.fs with parameters of type TableDescriptorModifier and TypeMethodDescriptionstatic booleanErasureCodingUtils.needsSync(TableDescriptor oldDescriptor, TableDescriptor newDescriptor) Check if EC policy is different between two descriptorsstatic voidErasureCodingUtils.sync(org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.fs.Path rootDir, TableDescriptor newDescriptor) Sync the EC policy state from the newDescriptor onto the FS for the table dir of the provided table descriptor.
- 
Uses of TableDescriptor in org.apache.hadoop.hbase.mapredConstructors in org.apache.hadoop.hbase.mapred with parameters of type TableDescriptorModifierConstructorDescriptionTableSnapshotRegionSplit(TableDescriptor htd, RegionInfo regionInfo, List<String> locations, Scan scan, org.apache.hadoop.fs.Path restoreDir) 
- 
Uses of TableDescriptor in org.apache.hadoop.hbase.mapreduceFields in org.apache.hadoop.hbase.mapreduce declared as TableDescriptorModifier and TypeFieldDescriptionprivate TableDescriptorTableSnapshotInputFormatImpl.InputSplit.htdprivate TableDescriptorHFileOutputFormat2.TableInfo.tableDesctiptorMethods in org.apache.hadoop.hbase.mapreduce that return TableDescriptorModifier and TypeMethodDescriptionTableSnapshotInputFormatImpl.InputSplit.getHtd()HFileOutputFormat2.TableInfo.getTableDescriptor()TableSnapshotInputFormatImpl.InputSplit.getTableDescriptor()Methods in org.apache.hadoop.hbase.mapreduce with parameters of type TableDescriptorModifier and TypeMethodDescriptionTableSnapshotInputFormatImpl.calculateLocationsForInputSplit(org.apache.hadoop.conf.Configuration conf, TableDescriptor htd, RegionInfo hri, org.apache.hadoop.fs.Path tableDir) Compute block locations for snapshot files (which will get the locations for referred hfiles) only when localityEnabled is true.static voidHFileOutputFormat2.configureIncrementalLoad(org.apache.hadoop.mapreduce.Job job, TableDescriptor tableDescriptor, RegionLocator regionLocator) Configure a MapReduce Job to perform an incremental load into the given table.static voidHFileOutputFormat2.configureIncrementalLoadMap(org.apache.hadoop.mapreduce.Job job, TableDescriptor tableDescriptor) Method parameters in org.apache.hadoop.hbase.mapreduce with type arguments of type TableDescriptorModifier and TypeMethodDescription(package private) static StringHFileOutputFormat2.serializeColumnFamilyAttribute(Function<ColumnFamilyDescriptor, String> fn, List<TableDescriptor> allTables) Constructors in org.apache.hadoop.hbase.mapreduce with parameters of type TableDescriptorModifierConstructorDescriptionInputSplit(TableDescriptor htd, RegionInfo regionInfo, List<String> locations, Scan scan, org.apache.hadoop.fs.Path restoreDir) TableInfo(TableDescriptor tableDesctiptor, RegionLocator regionLocator) TableSnapshotRegionSplit(TableDescriptor htd, RegionInfo regionInfo, List<String> locations, Scan scan, org.apache.hadoop.fs.Path restoreDir) 
- 
Uses of TableDescriptor in org.apache.hadoop.hbase.masterMethods in org.apache.hadoop.hbase.master that return TableDescriptorModifier and TypeMethodDescriptionHMaster.TableDescriptorGetter.get()MasterCoprocessorHost.preCreateTableRegionsInfos(TableDescriptor desc) MasterCoprocessorHost.preModifyTable(TableName tableName, TableDescriptor currentDescriptor, TableDescriptor newDescriptor) Methods in org.apache.hadoop.hbase.master that return types with arguments of type TableDescriptorModifier and TypeMethodDescriptionprivate List<TableDescriptor>HMaster.getTableDescriptors(List<TableDescriptor> htds, String namespace, String regex, List<TableName> tableNameList, boolean includeSysTables) Return a list of table table descriptors after applying any provided filter parameters.HMaster.listTableDescriptors(String namespace, String regex, List<TableName> tableNameList, boolean includeSysTables) Returns the list of table descriptors that match the specified requestHMaster.listTableDescriptorsByNamespace(String name) MasterServices.listTableDescriptorsByNamespace(String name) Get list of table descriptors by namespaceMethods in org.apache.hadoop.hbase.master with parameters of type TableDescriptorModifier and TypeMethodDescriptionprivate voidHMaster.createMissingCFsInMetaDuringUpgrade(TableDescriptor metaDescriptor) longHMaster.createSystemTable(TableDescriptor tableDescriptor) longMasterServices.createSystemTable(TableDescriptor tableDescriptor) Create a system table using the given table definition.longHMaster.createTable(TableDescriptor tableDescriptor, byte[][] splitKeys, long nonceGroup, long nonce) longMasterServices.createTable(TableDescriptor desc, byte[][] splitKeys, long nonceGroup, long nonce) Create a table using the given table definition.longHMaster.modifyTable(TableName tableName, TableDescriptor newDescriptor, long nonceGroup, long nonce, boolean reopenRegions) default longMasterServices.modifyTable(TableName tableName, TableDescriptor descriptor, long nonceGroup, long nonce) Modify the descriptor of an existing tablelongMasterServices.modifyTable(TableName tableName, TableDescriptor descriptor, long nonceGroup, long nonce, boolean reopenRegions) Modify the descriptor of an existing tablevoidMasterCoprocessorHost.postCloneSnapshot(SnapshotDescription snapshot, TableDescriptor hTableDescriptor) voidMasterCoprocessorHost.postCompletedCreateTableAction(TableDescriptor htd, RegionInfo[] regions, User user) voidMasterCoprocessorHost.postCompletedModifyTableAction(TableName tableName, TableDescriptor oldDescriptor, TableDescriptor currentDescriptor, User user) voidMasterCoprocessorHost.postCompletedSnapshotAction(SnapshotDescription snapshot, TableDescriptor hTableDescriptor) voidMasterCoprocessorHost.postCreateTable(TableDescriptor htd, RegionInfo[] regions) voidMasterCoprocessorHost.postModifyTable(TableName tableName, TableDescriptor oldDescriptor, TableDescriptor currentDescriptor) voidMasterCoprocessorHost.postRestoreSnapshot(SnapshotDescription snapshot, TableDescriptor hTableDescriptor) voidMasterCoprocessorHost.postSnapshot(SnapshotDescription snapshot, TableDescriptor hTableDescriptor, User user) voidMasterCoprocessorHost.preCloneSnapshot(SnapshotDescription snapshot, TableDescriptor hTableDescriptor) voidMasterCoprocessorHost.preCreateTable(TableDescriptor htd, RegionInfo[] regions) voidMasterCoprocessorHost.preCreateTableAction(TableDescriptor htd, RegionInfo[] regions, User user) MasterCoprocessorHost.preCreateTableRegionsInfos(TableDescriptor desc) MasterCoprocessorHost.preModifyTable(TableName tableName, TableDescriptor currentDescriptor, TableDescriptor newDescriptor) voidMasterCoprocessorHost.preModifyTableAction(TableName tableName, TableDescriptor currentDescriptor, TableDescriptor newDescriptor, User user) voidMasterCoprocessorHost.preRestoreSnapshot(SnapshotDescription snapshot, TableDescriptor hTableDescriptor) voidMasterCoprocessorHost.preSnapshot(SnapshotDescription snapshot, TableDescriptor hTableDescriptor, User user) Method parameters in org.apache.hadoop.hbase.master with type arguments of type TableDescriptorModifier and TypeMethodDescriptionprivate static voidHMaster.filterTablesByRegex(Collection<TableDescriptor> descriptors, Pattern pattern) Removes the table descriptors that don't match the pattern.private List<TableDescriptor>HMaster.getTableDescriptors(List<TableDescriptor> htds, String namespace, String regex, List<TableName> tableNameList, boolean includeSysTables) Return a list of table table descriptors after applying any provided filter parameters.voidMasterCoprocessorHost.postGetTableNames(List<TableDescriptor> descriptors, String regex) voidMasterCoprocessorHost.preGetTableNames(List<TableDescriptor> descriptors, String regex) 
- 
Uses of TableDescriptor in org.apache.hadoop.hbase.master.assignmentFields in org.apache.hadoop.hbase.master.assignment declared as TableDescriptorModifier and TypeFieldDescriptionprivate final TableDescriptorSplitTableRegionProcedure.StoreFileSplitter.htdMethods in org.apache.hadoop.hbase.master.assignment that return TableDescriptorModifier and TypeMethodDescriptionprivate TableDescriptorRegionStateStore.getDescriptor(TableName tableName) Methods in org.apache.hadoop.hbase.master.assignment with parameters of type TableDescriptorModifier and TypeMethodDescriptionprivate intRegionStateStore.getRegionReplication(TableDescriptor htd) private booleanRegionStateStore.hasGlobalReplicationScope(TableDescriptor htd) voidRegionStateStore.mergeRegions(RegionInfo child, RegionInfo[] parents, ServerName serverName, TableDescriptor htd) voidRegionStateStore.splitRegion(RegionInfo parent, RegionInfo splitA, RegionInfo splitB, ServerName serverName, TableDescriptor htd) Splits the region into two in an atomic operation.private Pair<org.apache.hadoop.fs.Path,org.apache.hadoop.fs.Path> SplitTableRegionProcedure.splitStoreFile(HRegionFileSystem regionFs, TableDescriptor htd, ColumnFamilyDescriptor hcd, HStoreFile sf) Constructors in org.apache.hadoop.hbase.master.assignment with parameters of type TableDescriptorModifierConstructorDescriptionStoreFileSplitter(HRegionFileSystem regionFs, TableDescriptor htd, ColumnFamilyDescriptor hcd, HStoreFile sf) Constructor that takes what it needs to split
- 
Uses of TableDescriptor in org.apache.hadoop.hbase.master.balancerMethods in org.apache.hadoop.hbase.master.balancer that return TableDescriptorModifier and TypeMethodDescriptionprivate TableDescriptorRegionHDFSBlockLocationFinder.getDescriptor(TableName tableName) return TableDescriptor for a given tableNameClusterInfoProvider.getTableDescriptor(TableName tableName) Get the table descriptor for the given table.MasterClusterInfoProvider.getTableDescriptor(TableName tableName) Methods in org.apache.hadoop.hbase.master.balancer with parameters of type TableDescriptorModifier and TypeMethodDescriptionClusterInfoProvider.computeHDFSBlocksDistribution(org.apache.hadoop.conf.Configuration conf, TableDescriptor tableDescriptor, RegionInfo regionInfo) Compute the block distribution for the given region.MasterClusterInfoProvider.computeHDFSBlocksDistribution(org.apache.hadoop.conf.Configuration conf, TableDescriptor tableDescriptor, RegionInfo regionInfo) 
- 
Uses of TableDescriptor in org.apache.hadoop.hbase.master.httpMethod parameters in org.apache.hadoop.hbase.master.http with type arguments of type TableDescriptorModifier and TypeMethodDescriptionstatic StringMasterStatusUtil.getUserTables(HMaster master, List<TableDescriptor> tables) 
- 
Uses of TableDescriptor in org.apache.hadoop.hbase.master.normalizerFields in org.apache.hadoop.hbase.master.normalizer declared as TableDescriptorModifier and TypeFieldDescriptionprivate final TableDescriptorSimpleRegionNormalizer.NormalizeContext.tableDescriptorMethods in org.apache.hadoop.hbase.master.normalizer with parameters of type TableDescriptorModifier and TypeMethodDescriptionRegionNormalizer.computePlansForTable(TableDescriptor tableDescriptor) Computes a list of normalizer actions to perform on the target table.SimpleRegionNormalizer.computePlansForTable(TableDescriptor tableDescriptor) private doubleSimpleRegionNormalizer.getAverageRegionSizeMb(List<RegionInfo> tableRegions, TableDescriptor tableDescriptor) Also make sure tableRegions contains regions of the same tableprivate booleanSimpleRegionNormalizer.proceedWithMergePlanning(TableDescriptor tableDescriptor) private booleanSimpleRegionNormalizer.proceedWithSplitPlanning(TableDescriptor tableDescriptor) Constructors in org.apache.hadoop.hbase.master.normalizer with parameters of type TableDescriptor
- 
Uses of TableDescriptor in org.apache.hadoop.hbase.master.procedureFields in org.apache.hadoop.hbase.master.procedure declared as TableDescriptorModifier and TypeFieldDescriptionprivate TableDescriptorSnapshotProcedure.htdprivate TableDescriptorModifyTableDescriptorProcedure.modifiedTableDescriptorprivate TableDescriptorModifyTableProcedure.modifiedTableDescriptorprivate TableDescriptorRestoreSnapshotProcedure.modifiedTableDescriptorprivate TableDescriptorRestoreSnapshotProcedure.oldTableDescriptorprivate TableDescriptorCloneSnapshotProcedure.tableDescriptorprivate TableDescriptorCreateTableProcedure.tableDescriptorprivate TableDescriptorTruncateTableProcedure.tableDescriptorprivate TableDescriptorModifyTableProcedure.unmodifiedTableDescriptorMethods in org.apache.hadoop.hbase.master.procedure that return TableDescriptorModifier and TypeMethodDescriptionprivate TableDescriptorSnapshotProcedure.loadTableDescriptorSnapshot(MasterProcedureEnv env) private static TableDescriptorInitMetaProcedure.writeFsLayout(org.apache.hadoop.fs.Path rootDir, org.apache.hadoop.conf.Configuration conf) Methods in org.apache.hadoop.hbase.master.procedure that return types with arguments of type TableDescriptorModifier and TypeMethodDescriptionprotected abstract Optional<TableDescriptor>ModifyTableDescriptorProcedure.modify(MasterProcedureEnv env, TableDescriptor current) Sub class should implement this method to modify the table descriptor, such as storing the rs group information.Methods in org.apache.hadoop.hbase.master.procedure with parameters of type TableDescriptorModifier and TypeMethodDescriptionprivate static voidCreateTableProcedure.addRegionsToMeta(MasterProcedureEnv env, TableDescriptor tableDescriptor, List<RegionInfo> regionInfos) Add the specified set of regions to the hbase:meta table.protected static List<RegionInfo>CreateTableProcedure.addTableToMeta(MasterProcedureEnv env, TableDescriptor tableDescriptor, List<RegionInfo> regions) private List<RegionInfo>CloneSnapshotProcedure.createFilesystemLayout(MasterProcedureEnv env, TableDescriptor tableDescriptor, List<RegionInfo> newRegions) Create regions in file system.private List<RegionInfo>CloneSnapshotProcedure.createFsLayout(MasterProcedureEnv env, TableDescriptor tableDescriptor, List<RegionInfo> newRegions, CreateTableProcedure.CreateHdfsRegions hdfsRegionHandler) Create region layout in file system.protected static List<RegionInfo>CreateTableProcedure.createFsLayout(MasterProcedureEnv env, TableDescriptor tableDescriptor, List<RegionInfo> newRegions) protected static List<RegionInfo>CreateTableProcedure.createFsLayout(MasterProcedureEnv env, TableDescriptor tableDescriptor, List<RegionInfo> newRegions, CreateTableProcedure.CreateHdfsRegions hdfsRegionHandler) static SnapshotProcedureRecoverySnapshotUtils.createSnapshotProcedure(MasterProcedureEnv env, TableName tableName, String snapshotName, TableDescriptor tableDescriptor) Creates a SnapshotProcedure for soft drop functionality.private voidModifyTableProcedure.deleteFromFs(MasterProcedureEnv env, TableDescriptor oldTableDescriptor, TableDescriptor newTableDescriptor) Removes from hdfs the families that are not longer present in the new table descriptor.static longRecoverySnapshotUtils.getRecoverySnapshotTtl(MasterProcedureEnv env, TableDescriptor tableDescriptor) Gets the TTL that should be used for snapshots created before destructive schema actions.private voidModifyTableProcedure.initialize(TableDescriptor unmodifiedTableDescriptor, boolean shouldCheckDescriptor) private static booleanModifyTableProcedure.isDeleteColumnFamily(TableDescriptor originalDescriptor, TableDescriptor newDescriptor) Find out whether all column families in unmodifiedTableDescriptor also exists in the modifiedTableDescriptor.private booleanModifyTableProcedure.isTablePropertyModified(TableDescriptor oldDescriptor, TableDescriptor newDescriptor, String key) Comparing the value associated with a given key across two TableDescriptor instances' properties.protected abstract Optional<TableDescriptor>ModifyTableDescriptorProcedure.modify(MasterProcedureEnv env, TableDescriptor current) Sub class should implement this method to modify the table descriptor, such as storing the rs group information.static ReopenTableRegionsProcedureReopenTableRegionsProcedure.throttled(org.apache.hadoop.conf.Configuration conf, TableDescriptor desc) Create a new ReopenTableRegionsProcedure respecting the throttling configuration for the table.Constructors in org.apache.hadoop.hbase.master.procedure with parameters of type TableDescriptorModifierConstructorDescriptionCloneSnapshotProcedure(MasterProcedureEnv env, TableDescriptor tableDescriptor, org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotDescription snapshot) CloneSnapshotProcedure(MasterProcedureEnv env, TableDescriptor tableDescriptor, org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotDescription snapshot, boolean restoreAcl) ConstructorCloneSnapshotProcedure(MasterProcedureEnv env, TableDescriptor tableDescriptor, org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotDescription snapshot, boolean restoreAcl, String customSFT) CreateTableProcedure(MasterProcedureEnv env, TableDescriptor tableDescriptor, RegionInfo[] newRegions) CreateTableProcedure(MasterProcedureEnv env, TableDescriptor tableDescriptor, RegionInfo[] newRegions, ProcedurePrepareLatch syncLatch) ModifyTableProcedure(MasterProcedureEnv env, TableDescriptor htd, ProcedurePrepareLatch latch) ModifyTableProcedure(MasterProcedureEnv env, TableDescriptor newTableDescriptor, ProcedurePrepareLatch latch, TableDescriptor oldTableDescriptor, boolean shouldCheckDescriptor, boolean reopenRegions) RestoreSnapshotProcedure(MasterProcedureEnv env, TableDescriptor oldTableDescriptor, TableDescriptor modifiedTableDescriptor, org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotDescription snapshot, boolean restoreAcl) ConstructorRestoreSnapshotProcedure(MasterProcedureEnv env, TableDescriptor tableDescriptor, org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotDescription snapshot) RestoreSnapshotProcedure(MasterProcedureEnv env, TableDescriptor tableDescriptor, org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotDescription snapshot, boolean restoreAcl) 
- 
Uses of TableDescriptor in org.apache.hadoop.hbase.master.regionFields in org.apache.hadoop.hbase.master.region declared as TableDescriptorModifier and TypeFieldDescriptionprivate static final TableDescriptorMasterRegionFactory.TABLE_DESCprivate TableDescriptorMasterRegionParams.tableDescriptorMethods in org.apache.hadoop.hbase.master.region that return TableDescriptorModifier and TypeMethodDescriptionMasterRegionParams.tableDescriptor()private static TableDescriptorMasterRegionFactory.withTrackerConfigs(org.apache.hadoop.conf.Configuration conf) Methods in org.apache.hadoop.hbase.master.region with parameters of type TableDescriptorModifier and TypeMethodDescriptionprivate static HRegionMasterRegion.bootstrap(org.apache.hadoop.conf.Configuration conf, TableDescriptor td, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.fs.Path rootDir, org.apache.hadoop.fs.FileSystem walFs, org.apache.hadoop.fs.Path walRootDir, WALFactory walFactory, MasterRegionWALRoller walRoller, String serverName, boolean touchInitializingFlag) private static HRegionMasterRegion.open(org.apache.hadoop.conf.Configuration conf, TableDescriptor td, RegionInfo regionInfo, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.fs.Path rootDir, org.apache.hadoop.fs.FileSystem walFs, org.apache.hadoop.fs.Path walRootDir, WALFactory walFactory, MasterRegionWALRoller walRoller, String serverName) MasterRegionParams.tableDescriptor(TableDescriptor tableDescriptor) private static voidMasterRegion.tryMigrate(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.fs.Path tableDir, RegionInfo regionInfo, TableDescriptor oldTd, TableDescriptor newTd) 
- 
Uses of TableDescriptor in org.apache.hadoop.hbase.master.snapshotFields in org.apache.hadoop.hbase.master.snapshot declared as TableDescriptorMethods in org.apache.hadoop.hbase.master.snapshot that return TableDescriptorModifier and TypeMethodDescriptionprivate TableDescriptorTakeSnapshotHandler.loadTableDescriptor()private TableDescriptorSnapshotManager.sanityCheckBeforeSnapshot(org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotDescription snapshot, boolean checkTable) Check if the snapshot can be taken.Methods in org.apache.hadoop.hbase.master.snapshot with parameters of type TableDescriptorModifier and TypeMethodDescription(package private) longSnapshotManager.cloneSnapshot(org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotDescription snapshot, TableDescriptor tableDescriptor, NonceKey nonceKey, boolean restoreAcl, String customSFT) Clone the specified snapshot into a new table.private longSnapshotManager.cloneSnapshot(org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotDescription reqSnapshot, TableName tableName, org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotDescription snapshot, TableDescriptor snapshotTableDesc, NonceKey nonceKey, boolean restoreAcl, String customSFT) Clone the specified snapshot.private longSnapshotManager.restoreSnapshot(org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotDescription snapshot, TableDescriptor tableDescriptor, NonceKey nonceKey, boolean restoreAcl) Restore the specified snapshot.private longSnapshotManager.restoreSnapshot(org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotDescription reqSnapshot, TableName tableName, org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotDescription snapshot, TableDescriptor snapshotTableDesc, NonceKey nonceKey, boolean restoreAcl) Restore the specified snapshot.
- 
Uses of TableDescriptor in org.apache.hadoop.hbase.mobMethods in org.apache.hadoop.hbase.mob with parameters of type TableDescriptorModifier and TypeMethodDescriptionvoidExpiredMobFileCleaner.cleanExpiredMobFiles(TableDescriptor htd, ColumnFamilyDescriptor family) Cleans the MOB files when they're expired and their min versions are 0.static voidMobUtils.cleanExpiredMobFiles(org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.conf.Configuration conf, TableDescriptor htd, ColumnFamilyDescriptor columnDescriptor, CacheConfig cacheConfig, long current) Cleans the expired mob files.static List<ColumnFamilyDescriptor>MobUtils.getMobColumnFamilies(TableDescriptor htd) Get list of Mob column families (if any exists)static booleanMobUtils.hasMobColumns(TableDescriptor htd) Checks whether this table has mob-enabled columns.voidMobFileCompactionChore.performMajorCompactionInBatches(Admin admin, TableDescriptor htd, ColumnFamilyDescriptor hcd) 
- 
Uses of TableDescriptor in org.apache.hadoop.hbase.quotasFields in org.apache.hadoop.hbase.quotas declared as TableDescriptorModifier and TypeFieldDescriptionstatic final TableDescriptorQuotaUtil.QUOTA_TABLE_DESCTable descriptor for Quota internal table
- 
Uses of TableDescriptor in org.apache.hadoop.hbase.regionserverFields in org.apache.hadoop.hbase.regionserver declared as TableDescriptorMethods in org.apache.hadoop.hbase.regionserver that return TableDescriptorModifier and TypeMethodDescriptionHRegion.getTableDescriptor()Region.getTableDescriptor()Returns table descriptor for this regionMethods in org.apache.hadoop.hbase.regionserver with parameters of type TableDescriptorModifier and TypeMethodDescriptionprivate voidCompactionTool.CompactionWorker.compactRegion(org.apache.hadoop.fs.Path tableDir, TableDescriptor htd, org.apache.hadoop.fs.Path regionDir, boolean compactOnce, boolean major) private voidCompactionTool.CompactionWorker.compactStoreFiles(org.apache.hadoop.fs.Path tableDir, TableDescriptor htd, RegionInfo hri, String familyName, boolean compactOnce, boolean major) Execute the actual compaction job.static HDFSBlocksDistributionHRegion.computeHDFSBlocksDistribution(org.apache.hadoop.conf.Configuration conf, TableDescriptor tableDescriptor, RegionInfo regionInfo) This is a helper function to compute HDFS block distribution on demandstatic HDFSBlocksDistributionHRegion.computeHDFSBlocksDistribution(org.apache.hadoop.conf.Configuration conf, TableDescriptor tableDescriptor, RegionInfo regionInfo, org.apache.hadoop.fs.Path tablePath) This is a helper function to compute HDFS block distribution on demandstatic RegionSplitRestrictionRegionSplitRestriction.create(TableDescriptor tableDescriptor, org.apache.hadoop.conf.Configuration conf) Create the RegionSplitRestriction configured for the given table.static HRegionHRegion.createHRegion(org.apache.hadoop.conf.Configuration conf, RegionInfo regionInfo, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.fs.Path tableDir, TableDescriptor tableDesc) Create a region under the given table directory.static HRegionHRegion.createHRegion(RegionInfo info, org.apache.hadoop.fs.Path rootDir, org.apache.hadoop.conf.Configuration conf, TableDescriptor hTableDescriptor, WAL wal) static HRegionHRegion.createHRegion(RegionInfo info, org.apache.hadoop.fs.Path rootDir, org.apache.hadoop.conf.Configuration conf, TableDescriptor hTableDescriptor, WAL wal, boolean initialize) Convenience method creating new HRegions.static HRegionHRegion.createHRegion(RegionInfo info, org.apache.hadoop.fs.Path rootDir, org.apache.hadoop.conf.Configuration conf, TableDescriptor hTableDescriptor, WAL wal, boolean initialize, RegionServerServices rsRpcServices) Convenience method creating new HRegions.static org.apache.hadoop.conf.ConfigurationStoreUtils.createStoreConfiguration(org.apache.hadoop.conf.Configuration conf, TableDescriptor td, ColumnFamilyDescriptor cfd) static Class<? extends FlushPolicy>FlushPolicyFactory.getFlushPolicyClass(TableDescriptor htd, org.apache.hadoop.conf.Configuration conf) Get FlushPolicy class for the given table.static Class<? extends RegionSplitPolicy>RegionSplitPolicy.getSplitPolicyClass(TableDescriptor htd, org.apache.hadoop.conf.Configuration conf) private static HStoreCompactionTool.CompactionWorker.getStore(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.fs.Path tableDir, TableDescriptor htd, RegionInfo hri, String familyName) (package private) static List<RegionCoprocessorHost.TableCoprocessorAttribute>RegionCoprocessorHost.getTableCoprocessorAttrsFromSchema(org.apache.hadoop.conf.Configuration conf, TableDescriptor htd) voidDelimitedKeyPrefixRegionSplitRestriction.initialize(TableDescriptor tableDescriptor, org.apache.hadoop.conf.Configuration conf) voidKeyPrefixRegionSplitRestriction.initialize(TableDescriptor tableDescriptor, org.apache.hadoop.conf.Configuration conf) voidNoRegionSplitRestriction.initialize(TableDescriptor tableDescriptor, org.apache.hadoop.conf.Configuration conf) abstract voidRegionSplitRestriction.initialize(TableDescriptor tableDescriptor, org.apache.hadoop.conf.Configuration conf) Initialize the RegionSplitRestriction instancestatic HRegionHRegion.newHRegion(org.apache.hadoop.fs.Path tableDir, WAL wal, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.conf.Configuration conf, RegionInfo regionInfo, TableDescriptor htd, RegionServerServices rsServices) A utility method to create new instances of HRegion based on theHConstants.REGION_IMPLconfiguration property.static HRegionHRegion.openHRegion(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.fs.Path rootDir, RegionInfo info, TableDescriptor htd, WAL wal) Open a Region.static HRegionHRegion.openHRegion(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.fs.Path rootDir, RegionInfo info, TableDescriptor htd, WAL wal, RegionServerServices rsServices, CancelableProgressable reporter) Open a Region.static HRegionHRegion.openHRegion(org.apache.hadoop.fs.Path rootDir, RegionInfo info, TableDescriptor htd, WAL wal, org.apache.hadoop.conf.Configuration conf) Open a Region.static HRegionHRegion.openHRegion(org.apache.hadoop.fs.Path rootDir, RegionInfo info, TableDescriptor htd, WAL wal, org.apache.hadoop.conf.Configuration conf, RegionServerServices rsServices, CancelableProgressable reporter) Open a Region.static HRegionHRegion.openHRegion(RegionInfo info, TableDescriptor htd, WAL wal, org.apache.hadoop.conf.Configuration conf) Open a Region.static HRegionHRegion.openHRegion(RegionInfo info, TableDescriptor htd, WAL wal, org.apache.hadoop.conf.Configuration conf, RegionServerServices rsServices, CancelableProgressable reporter) Open a Region.static HRegionHRegion.openHRegionFromTableDir(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.fs.Path tableDir, RegionInfo info, TableDescriptor htd, WAL wal, RegionServerServices rsServices, CancelableProgressable reporter) Open a Region.static HRegionHRegion.openReadOnlyFileSystemHRegion(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.fs.Path tableDir, RegionInfo info, TableDescriptor htd) Open a Region on a read-only file-system (like hdfs snapshots)voidHRegion.setTableDescriptor(TableDescriptor desc) static voidRegionCoprocessorHost.testTableCoprocessorAttrs(org.apache.hadoop.conf.Configuration conf, TableDescriptor htd) Sanity check the table coprocessor attributes of the supplied schema.static HRegionHRegion.warmupHRegion(RegionInfo info, TableDescriptor htd, WAL wal, org.apache.hadoop.conf.Configuration conf, RegionServerServices rsServices, CancelableProgressable reporter) Method parameters in org.apache.hadoop.hbase.regionserver with type arguments of type TableDescriptorModifier and TypeMethodDescriptionprivate voidRSRpcServices.executeOpenRegionProcedures(org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.OpenRegionRequest request, Map<TableName, TableDescriptor> tdCache) Constructors in org.apache.hadoop.hbase.regionserver with parameters of type TableDescriptorModifierConstructorDescriptionHRegion(org.apache.hadoop.fs.Path tableDir, WAL wal, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.conf.Configuration confParam, RegionInfo regionInfo, TableDescriptor htd, RegionServerServices rsServices) Deprecated.Use other constructors.HRegion(HRegionFileSystem fs, WAL wal, org.apache.hadoop.conf.Configuration confParam, TableDescriptor htd, RegionServerServices rsServices) HRegion constructor.
- 
Uses of TableDescriptor in org.apache.hadoop.hbase.regionserver.compactionsMethods in org.apache.hadoop.hbase.regionserver.compactions with parameters of type TableDescriptorModifier and TypeMethodDescriptionstatic voidCustomCellTieredUtils.checkForModifyTable(TableDescriptor newTable) 
- 
Uses of TableDescriptor in org.apache.hadoop.hbase.regionserver.handlerFields in org.apache.hadoop.hbase.regionserver.handler declared as TableDescriptorModifier and TypeFieldDescriptionprivate final TableDescriptorOpenRegionHandler.htdDeprecated.private final TableDescriptorAssignRegionHandler.tableDescMethods in org.apache.hadoop.hbase.regionserver.handler with parameters of type TableDescriptorModifier and TypeMethodDescriptionstatic AssignRegionHandlerAssignRegionHandler.create(HRegionServer server, RegionInfo regionInfo, long openProcId, TableDescriptor tableDesc, long masterSystemTime, long initiatingMasterActiveTime) Constructors in org.apache.hadoop.hbase.regionserver.handler with parameters of type TableDescriptorModifierConstructorDescriptionAssignRegionHandler(HRegionServer server, RegionInfo regionInfo, long openProcId, TableDescriptor tableDesc, long masterSystemTime, long initiatingMasterActiveTime, EventType eventType) OpenMetaHandler(Server server, RegionServerServices rsServices, RegionInfo regionInfo, TableDescriptor htd, long masterSystemTime) OpenPriorityRegionHandler(Server server, RegionServerServices rsServices, RegionInfo regionInfo, TableDescriptor htd, long masterSystemTime) OpenRegionHandler(Server server, RegionServerServices rsServices, RegionInfo regionInfo, TableDescriptor htd, long masterSystemTime) Deprecated.protectedOpenRegionHandler(Server server, RegionServerServices rsServices, RegionInfo regionInfo, TableDescriptor htd, long masterSystemTime, EventType eventType) Deprecated.
- 
Uses of TableDescriptor in org.apache.hadoop.hbase.regionserver.regionreplicationFields in org.apache.hadoop.hbase.regionserver.regionreplication declared as TableDescriptorConstructors in org.apache.hadoop.hbase.regionserver.regionreplication with parameters of type TableDescriptorModifierConstructorDescriptionRegionReplicationSink(org.apache.hadoop.conf.Configuration conf, RegionInfo primary, TableDescriptor td, RegionReplicationBufferManager manager, Runnable flushRequester, AsyncClusterConnection conn) 
- 
Uses of TableDescriptor in org.apache.hadoop.hbase.regionserver.storefiletrackerMethods in org.apache.hadoop.hbase.regionserver.storefiletracker that return TableDescriptorModifier and TypeMethodDescriptionprotected TableDescriptorModifyColumnFamilyStoreFileTrackerProcedure.createFinishTableDescriptor(TableDescriptor current) protected abstract TableDescriptorModifyStoreFileTrackerProcedure.createFinishTableDescriptor(TableDescriptor current) protected TableDescriptorModifyTableStoreFileTrackerProcedure.createFinishTableDescriptor(TableDescriptor current) protected TableDescriptorModifyColumnFamilyStoreFileTrackerProcedure.createMigrationTableDescriptor(org.apache.hadoop.conf.Configuration conf, TableDescriptor current) protected abstract TableDescriptorModifyStoreFileTrackerProcedure.createMigrationTableDescriptor(org.apache.hadoop.conf.Configuration conf, TableDescriptor current) protected TableDescriptorModifyTableStoreFileTrackerProcedure.createMigrationTableDescriptor(org.apache.hadoop.conf.Configuration conf, TableDescriptor current) protected TableDescriptorModifyColumnFamilyStoreFileTrackerProcedure.createRestoreTableDescriptor(TableDescriptor current, String restoreSFT) protected abstract TableDescriptorModifyStoreFileTrackerProcedure.createRestoreTableDescriptor(TableDescriptor current, String restoreSFT) protected TableDescriptorModifyTableStoreFileTrackerProcedure.createRestoreTableDescriptor(TableDescriptor current, String restoreSFT) static TableDescriptorStoreFileTrackerFactory.updateWithTrackerConfigs(org.apache.hadoop.conf.Configuration conf, TableDescriptor descriptor) Methods in org.apache.hadoop.hbase.regionserver.storefiletracker that return types with arguments of type TableDescriptorModifier and TypeMethodDescriptionprotected Optional<TableDescriptor>InitializeStoreFileTrackerProcedure.modify(MasterProcedureEnv env, TableDescriptor current) Methods in org.apache.hadoop.hbase.regionserver.storefiletracker with parameters of type TableDescriptorModifier and TypeMethodDescriptionstatic voidStoreFileTrackerValidationUtils.checkForCreateTable(org.apache.hadoop.conf.Configuration conf, TableDescriptor table) Pre check when creating a new table.static voidStoreFileTrackerValidationUtils.checkForModifyTable(org.apache.hadoop.conf.Configuration conf, TableDescriptor oldTable, TableDescriptor newTable, boolean isTableDisabled) Pre check when modifying a table.private static voidStoreFileTrackerValidationUtils.checkForNewFamily(org.apache.hadoop.conf.Configuration conf, TableDescriptor table, ColumnFamilyDescriptor family) static StoreFileTrackerStoreFileTrackerFactory.create(org.apache.hadoop.conf.Configuration conf, TableDescriptor td, ColumnFamilyDescriptor cfd, HRegionFileSystem regionFs) Used at master side when splitting/merging regions, as we do not have a Store, thus no StoreContext at master side.static StoreFileTrackerStoreFileTrackerFactory.create(org.apache.hadoop.conf.Configuration conf, TableDescriptor td, ColumnFamilyDescriptor cfd, HRegionFileSystem regionFs, boolean isPrimaryReplica) protected org.apache.hadoop.conf.ConfigurationModifyColumnFamilyStoreFileTrackerProcedure.createConf(org.apache.hadoop.conf.Configuration conf, TableDescriptor current) protected abstract org.apache.hadoop.conf.ConfigurationModifyStoreFileTrackerProcedure.createConf(org.apache.hadoop.conf.Configuration conf, TableDescriptor current) protected org.apache.hadoop.conf.ConfigurationModifyTableStoreFileTrackerProcedure.createConf(org.apache.hadoop.conf.Configuration conf, TableDescriptor current) protected TableDescriptorModifyColumnFamilyStoreFileTrackerProcedure.createFinishTableDescriptor(TableDescriptor current) protected abstract TableDescriptorModifyStoreFileTrackerProcedure.createFinishTableDescriptor(TableDescriptor current) protected TableDescriptorModifyTableStoreFileTrackerProcedure.createFinishTableDescriptor(TableDescriptor current) protected TableDescriptorModifyColumnFamilyStoreFileTrackerProcedure.createMigrationTableDescriptor(org.apache.hadoop.conf.Configuration conf, TableDescriptor current) protected abstract TableDescriptorModifyStoreFileTrackerProcedure.createMigrationTableDescriptor(org.apache.hadoop.conf.Configuration conf, TableDescriptor current) protected TableDescriptorModifyTableStoreFileTrackerProcedure.createMigrationTableDescriptor(org.apache.hadoop.conf.Configuration conf, TableDescriptor current) protected TableDescriptorModifyColumnFamilyStoreFileTrackerProcedure.createRestoreTableDescriptor(TableDescriptor current, String restoreSFT) protected abstract TableDescriptorModifyStoreFileTrackerProcedure.createRestoreTableDescriptor(TableDescriptor current, String restoreSFT) protected TableDescriptorModifyTableStoreFileTrackerProcedure.createRestoreTableDescriptor(TableDescriptor current, String restoreSFT) private static org.apache.hadoop.conf.ConfigurationStoreFileTrackerFactory.mergeConfigurations(org.apache.hadoop.conf.Configuration global, TableDescriptor table, ColumnFamilyDescriptor family) protected Optional<TableDescriptor>InitializeStoreFileTrackerProcedure.modify(MasterProcedureEnv env, TableDescriptor current) protected voidModifyColumnFamilyStoreFileTrackerProcedure.preCheck(TableDescriptor current) protected abstract voidModifyStoreFileTrackerProcedure.preCheck(TableDescriptor current) protected voidModifyTableStoreFileTrackerProcedure.preCheck(TableDescriptor current) static TableDescriptorStoreFileTrackerFactory.updateWithTrackerConfigs(org.apache.hadoop.conf.Configuration conf, TableDescriptor descriptor) static voidStoreFileTrackerValidationUtils.validatePreRestoreSnapshot(TableDescriptor currentTableDesc, TableDescriptor snapshotTableDesc, org.apache.hadoop.conf.Configuration baseConf) Makes sure restoring a snapshot does not break the current SFT setup follows StoreUtils.createStoreConfiguration
- 
Uses of TableDescriptor in org.apache.hadoop.hbase.replicationMethods in org.apache.hadoop.hbase.replication that return TableDescriptorModifier and TypeMethodDescriptionstatic TableDescriptorReplicationStorageFactory.createReplicationQueueTableDescriptor(TableName tableName) 
- 
Uses of TableDescriptor in org.apache.hadoop.hbase.restMethods in org.apache.hadoop.hbase.rest that return TableDescriptor
- 
Uses of TableDescriptor in org.apache.hadoop.hbase.rest.modelMethods in org.apache.hadoop.hbase.rest.model that return TableDescriptorModifier and TypeMethodDescriptionTableSchemaModel.getTableDescriptor()Returns a table descriptorConstructors in org.apache.hadoop.hbase.rest.model with parameters of type TableDescriptor
- 
Uses of TableDescriptor in org.apache.hadoop.hbase.rsgroupFields in org.apache.hadoop.hbase.rsgroup declared as TableDescriptorModifier and TypeFieldDescriptionprivate static final TableDescriptorRSGroupInfoManagerImpl.RSGROUP_TABLE_DESCTable descriptor forhbase:rsgroupcatalog tableMethods in org.apache.hadoop.hbase.rsgroup that return types with arguments of type TableDescriptorModifier and TypeMethodDescriptionprotected Optional<TableDescriptor>MigrateRSGroupProcedure.modify(MasterProcedureEnv env, TableDescriptor current) Methods in org.apache.hadoop.hbase.rsgroup with parameters of type TableDescriptorModifier and TypeMethodDescriptionprotected Optional<TableDescriptor>MigrateRSGroupProcedure.modify(MasterProcedureEnv env, TableDescriptor current) Method parameters in org.apache.hadoop.hbase.rsgroup with type arguments of type TableDescriptorModifier and TypeMethodDescriptionstatic RSGroupInfoRSGroupUtil.fillTables(RSGroupInfo rsGroupInfo, Collection<TableDescriptor> tds) Fill the tables field forRSGroupInfo, for backward compatibility.
- 
Uses of TableDescriptor in org.apache.hadoop.hbase.security.accessMethods in org.apache.hadoop.hbase.security.access that return TableDescriptorModifier and TypeMethodDescriptionAccessController.preModifyTable(ObserverContext<MasterCoprocessorEnvironment> c, TableName tableName, TableDescriptor currentDesc, TableDescriptor newDesc) CoprocessorWhitelistMasterObserver.preModifyTable(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName, TableDescriptor currentDesc, TableDescriptor newDesc) Methods in org.apache.hadoop.hbase.security.access with parameters of type TableDescriptorModifier and TypeMethodDescription(package private) booleanSnapshotScannerHDFSAclHelper.isAclSyncToHdfsEnabled(TableDescriptor tableDescriptor) (package private) static booleanPermissionStorage.isAclTable(TableDescriptor desc) Returnstrueif the given table is_acl_metadata table.private booleanSnapshotScannerHDFSAclController.needHandleTableHdfsAcl(TableDescriptor tableDescriptor, String operation) voidAccessController.postCompletedCreateTableAction(ObserverContext<MasterCoprocessorEnvironment> c, TableDescriptor desc, RegionInfo[] regions) voidSnapshotScannerHDFSAclController.postCompletedCreateTableAction(ObserverContext<MasterCoprocessorEnvironment> c, TableDescriptor desc, RegionInfo[] regions) voidSnapshotScannerHDFSAclController.postCompletedSnapshotAction(ObserverContext<MasterCoprocessorEnvironment> c, SnapshotDescription snapshot, TableDescriptor tableDescriptor) voidAccessController.postModifyTable(ObserverContext<MasterCoprocessorEnvironment> c, TableName tableName, TableDescriptor oldDesc, TableDescriptor currentDesc) voidSnapshotScannerHDFSAclController.postModifyTable(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName, TableDescriptor oldDescriptor, TableDescriptor currentDescriptor) voidAccessController.preCloneSnapshot(ObserverContext<MasterCoprocessorEnvironment> ctx, SnapshotDescription snapshot, TableDescriptor hTableDescriptor) voidAccessController.preCreateTable(ObserverContext<MasterCoprocessorEnvironment> c, TableDescriptor desc, RegionInfo[] regions) Observer implementationsvoidCoprocessorWhitelistMasterObserver.preCreateTable(ObserverContext<MasterCoprocessorEnvironment> ctx, TableDescriptor htd, RegionInfo[] regions) AccessController.preModifyTable(ObserverContext<MasterCoprocessorEnvironment> c, TableName tableName, TableDescriptor currentDesc, TableDescriptor newDesc) CoprocessorWhitelistMasterObserver.preModifyTable(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName, TableDescriptor currentDesc, TableDescriptor newDesc) voidAccessController.preRestoreSnapshot(ObserverContext<MasterCoprocessorEnvironment> ctx, SnapshotDescription snapshot, TableDescriptor hTableDescriptor) voidAccessController.preSnapshot(ObserverContext<MasterCoprocessorEnvironment> ctx, SnapshotDescription snapshot, TableDescriptor hTableDescriptor) private static voidCoprocessorWhitelistMasterObserver.verifyCoprocessors(ObserverContext<MasterCoprocessorEnvironment> ctx, TableDescriptor htd) Perform the validation checks for a coprocessor to determine if the path is white listed or not.Method parameters in org.apache.hadoop.hbase.security.access with type arguments of type TableDescriptorModifier and TypeMethodDescriptionvoidAccessController.postGetTableNames(ObserverContext<MasterCoprocessorEnvironment> ctx, List<TableDescriptor> descriptors, String regex) 
- 
Uses of TableDescriptor in org.apache.hadoop.hbase.security.visibilityMethods in org.apache.hadoop.hbase.security.visibility that return TableDescriptorModifier and TypeMethodDescriptionVisibilityController.preModifyTable(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName, TableDescriptor currentDescriptor, TableDescriptor newDescriptor) Methods in org.apache.hadoop.hbase.security.visibility with parameters of type TableDescriptorModifier and TypeMethodDescriptionVisibilityController.preModifyTable(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName, TableDescriptor currentDescriptor, TableDescriptor newDescriptor) 
- 
Uses of TableDescriptor in org.apache.hadoop.hbase.snapshotFields in org.apache.hadoop.hbase.snapshot declared as TableDescriptorModifier and TypeFieldDescriptionprivate final TableDescriptorRestoreSnapshotHelper.RestoreMetaChanges.htdprivate TableDescriptorSnapshotManifest.htdprivate final TableDescriptorRestoreSnapshotHelper.tableDescMethods in org.apache.hadoop.hbase.snapshot that return TableDescriptorModifier and TypeMethodDescriptionRestoreSnapshotHelper.RestoreMetaChanges.getTableDescriptor()SnapshotManifest.getTableDescriptor()Get the table descriptor from the SnapshotMethods in org.apache.hadoop.hbase.snapshot with parameters of type TableDescriptorModifier and TypeMethodDescriptionvoidSnapshotManifest.addTableDescriptor(TableDescriptor htd) Add the table descriptor to the snapshot manifest(package private) static org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotRegionManifestSnapshotManifestV1.buildManifestFromDisk(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.fs.Path tableDir, RegionInfo regionInfo, TableDescriptor htd) private List<StoreFileInfo>SnapshotManifest.getStoreFiles(org.apache.hadoop.fs.Path storePath, TableDescriptor htd, ColumnFamilyDescriptor hcd, RegionInfo regionInfo) (package private) static List<org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotRegionManifest>SnapshotManifestV1.loadRegionManifests(org.apache.hadoop.conf.Configuration conf, Executor executor, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.fs.Path snapshotDir, org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotDescription desc, TableDescriptor htd) Constructors in org.apache.hadoop.hbase.snapshot with parameters of type TableDescriptorModifierConstructorDescriptionRestoreMetaChanges(TableDescriptor htd, Map<String, Pair<String, String>> parentsMap) RestoreSnapshotHelper(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.fs.FileSystem fs, SnapshotManifest manifest, TableDescriptor tableDescriptor, org.apache.hadoop.fs.Path rootDir, ForeignExceptionDispatcher monitor, MonitoredTask status) RestoreSnapshotHelper(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.fs.FileSystem fs, SnapshotManifest manifest, TableDescriptor tableDescriptor, org.apache.hadoop.fs.Path rootDir, ForeignExceptionDispatcher monitor, MonitoredTask status, boolean createBackRefs) 
- 
Uses of TableDescriptor in org.apache.hadoop.hbase.thrift2Methods in org.apache.hadoop.hbase.thrift2 that return TableDescriptorModifier and TypeMethodDescriptionstatic TableDescriptorThriftUtilities.tableDescriptorFromThrift(org.apache.hadoop.hbase.thrift2.generated.TTableDescriptor in) Methods in org.apache.hadoop.hbase.thrift2 that return types with arguments of type TableDescriptorModifier and TypeMethodDescriptionstatic List<TableDescriptor>ThriftUtilities.tableDescriptorsFromThrift(List<org.apache.hadoop.hbase.thrift2.generated.TTableDescriptor> in) Methods in org.apache.hadoop.hbase.thrift2 with parameters of type TableDescriptorModifier and TypeMethodDescriptionstatic org.apache.hadoop.hbase.thrift2.generated.TTableDescriptorThriftUtilities.tableDescriptorFromHBase(TableDescriptor in) static List<org.apache.hadoop.hbase.thrift2.generated.TTableDescriptor>ThriftUtilities.tableDescriptorsFromHBase(TableDescriptor[] in) Method parameters in org.apache.hadoop.hbase.thrift2 with type arguments of type TableDescriptorModifier and TypeMethodDescriptionstatic List<org.apache.hadoop.hbase.thrift2.generated.TTableDescriptor>ThriftUtilities.tableDescriptorsFromHBase(List<TableDescriptor> in) 
- 
Uses of TableDescriptor in org.apache.hadoop.hbase.thrift2.clientMethods in org.apache.hadoop.hbase.thrift2.client that return TableDescriptorModifier and TypeMethodDescriptionThriftAdmin.getDescriptor(TableName tableName) ThriftTable.getDescriptor()Methods in org.apache.hadoop.hbase.thrift2.client that return types with arguments of type TableDescriptorModifier and TypeMethodDescriptionThriftAdmin.listTableDescriptors()ThriftAdmin.listTableDescriptors(boolean includeSysTables) ThriftAdmin.listTableDescriptors(List<TableName> tableNames) ThriftAdmin.listTableDescriptors(Pattern pattern) ThriftAdmin.listTableDescriptors(Pattern pattern, boolean includeSysTables) ThriftAdmin.listTableDescriptorsByNamespace(byte[] name) ThriftAdmin.listTableDescriptorsByState(boolean isEnabled) Methods in org.apache.hadoop.hbase.thrift2.client with parameters of type TableDescriptorModifier and TypeMethodDescriptionvoidThriftAdmin.createTable(TableDescriptor desc) voidThriftAdmin.createTable(TableDescriptor desc, byte[][] splitKeys) voidThriftAdmin.createTable(TableDescriptor desc, byte[] startKey, byte[] endKey, int numRegions) ThriftAdmin.createTableAsync(TableDescriptor desc) ThriftAdmin.createTableAsync(TableDescriptor desc, byte[][] splitKeys) voidThriftAdmin.modifyTable(TableDescriptor td) ThriftAdmin.modifyTableAsync(TableDescriptor td) ThriftAdmin.modifyTableAsync(TableDescriptor td, boolean reopenRegions) 
- 
Uses of TableDescriptor in org.apache.hadoop.hbase.toolMethods in org.apache.hadoop.hbase.tool with parameters of type TableDescriptorModifier and TypeMethodDescriptionCanaryTool.sniff(Admin admin, CanaryTool.Sink sink, TableDescriptor tableDesc, ExecutorService executor, CanaryTool.RegionTask.TaskType taskType, boolean rawScanEnabled, LongAdder rwLatency, boolean readAllCF) private List<BulkLoadHFiles.LoadQueueItem>BulkLoadHFilesTool.splitStoreFile(AsyncTableRegionLocator loc, BulkLoadHFiles.LoadQueueItem item, TableDescriptor tableDesc, byte[] splitKey) private static voidBulkLoadHFilesTool.validateFamiliesInHFiles(TableDescriptor tableDesc, Deque<BulkLoadHFiles.LoadQueueItem> queue, boolean silence) Checks whether there is any invalid family name in HFiles to be bulk loaded.
- 
Uses of TableDescriptor in org.apache.hadoop.hbase.utilFields in org.apache.hadoop.hbase.util with type parameters of type TableDescriptorModifier and TypeFieldDescriptionprivate final Map<TableName,TableDescriptor> FSTableDescriptors.cache(package private) final Set<TableDescriptor>HbckTableInfo.htdsMethods in org.apache.hadoop.hbase.util that return TableDescriptorModifier and TypeMethodDescriptionGet the current table descriptor for the given table, or null if none exists.(package private) TableDescriptorHbckTableInfo.getTableDescriptor()Returns descriptor common to all regions.static TableDescriptorFSTableDescriptors.getTableDescriptorFromFs(org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.fs.Path tableDir) Returns the latest table descriptor for the table located at the given directory directly from the file system if it exists.static TableDescriptorFSTableDescriptors.getTableDescriptorFromFs(org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.fs.Path hbaseRootDir, TableName tableName) Returns the latest table descriptor for the given table directly from the file system if it exists, bypassing the local cache.(package private) TableDescriptor[]HBaseFsck.getTableDescriptors(List<TableName> tableNames) Deprecated.(package private) TableDescriptor[]HBaseFsck.getTables(AtomicInteger numSkipped) Deprecated.Return a list of user-space table names whose metadata have not been modified in the last few milliseconds specified by timelag if any of the REGIONINFO_QUALIFIER, SERVER_QUALIFIER, STARTCODE_QUALIFIER, SPLITA_QUALIFIER, SPLITB_QUALIFIER have not changed in the last milliseconds specified by timelag, then the table is a candidate to be returned.Removes the table descriptor from the local cache and returns it.static TableDescriptorFSTableDescriptors.tryUpdateAndGetMetaTableDescriptor(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.fs.Path rootdir) Methods in org.apache.hadoop.hbase.util that return types with arguments of type TableDescriptorModifier and TypeMethodDescriptionFSTableDescriptors.getAll()Returns a map from table name to table descriptor for all tables.FSTableDescriptors.getByNamespace(String name) Find descriptors by namespace.private static Optional<Pair<org.apache.hadoop.fs.FileStatus,TableDescriptor>> FSTableDescriptors.getTableDescriptorFromFs(org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.fs.Path tableDir, boolean readonly) Methods in org.apache.hadoop.hbase.util with parameters of type TableDescriptorModifier and TypeMethodDescriptionprivate static voidTableDescriptorChecker.checkBloomFilterType(org.apache.hadoop.conf.Configuration conf, TableDescriptor td) static voidTableDescriptorChecker.checkClassLoading(org.apache.hadoop.conf.Configuration conf, TableDescriptor td) private static voidTableDescriptorChecker.checkCompactionPolicy(org.apache.hadoop.conf.Configuration conf, TableDescriptor td) static voidTableDescriptorChecker.checkCompression(org.apache.hadoop.conf.Configuration conf, TableDescriptor td) private static voidTableDescriptorChecker.checkDateTieredCompactionForTimeRangeDataTiering(org.apache.hadoop.conf.Configuration conf, TableDescriptor td) static voidTableDescriptorChecker.checkEncryption(org.apache.hadoop.conf.Configuration conf, TableDescriptor td) private static voidTableDescriptorChecker.checkReplicationScope(org.apache.hadoop.conf.Configuration conf, TableDescriptor td) static HRegionHBaseFsckRepair.createHDFSRegionDir(org.apache.hadoop.conf.Configuration conf, RegionInfo hri, TableDescriptor htd) Creates, flushes, and closes a new region.static intLoadTestUtil.createPreSplitLoadTestTable(org.apache.hadoop.conf.Configuration conf, TableDescriptor desc, ColumnFamilyDescriptor hcd) Creates a pre-split table for load testing.static intLoadTestUtil.createPreSplitLoadTestTable(org.apache.hadoop.conf.Configuration conf, TableDescriptor desc, ColumnFamilyDescriptor[] hcds, int numRegionsPerServer) Creates a pre-split table for load testing.static intLoadTestUtil.createPreSplitLoadTestTable(org.apache.hadoop.conf.Configuration conf, TableDescriptor td, ColumnFamilyDescriptor[] cds, RegionSplitter.SplitAlgorithm splitter, int numRegionsPerServer) Creates a pre-split table for load testing.static intLoadTestUtil.createPreSplitLoadTestTable(org.apache.hadoop.conf.Configuration conf, TableDescriptor desc, ColumnFamilyDescriptor hcd, int numRegionsPerServer) Creates a pre-split table for load testing.static RegionInfoModifyRegionUtils.createRegion(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.fs.Path rootDir, TableDescriptor tableDescriptor, RegionInfo newRegion, ModifyRegionUtils.RegionFillTask task) Create new set of regions on the specified file-system.static RegionInfo[]ModifyRegionUtils.createRegionInfos(TableDescriptor tableDescriptor, byte[][] splitKeys) static List<RegionInfo>ModifyRegionUtils.createRegions(ThreadPoolExecutor exec, org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.fs.Path rootDir, TableDescriptor tableDescriptor, RegionInfo[] newRegions, ModifyRegionUtils.RegionFillTask task) Create new set of regions on the specified file-system.static List<RegionInfo>ModifyRegionUtils.createRegions(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.fs.Path rootDir, TableDescriptor tableDescriptor, RegionInfo[] newRegions, ModifyRegionUtils.RegionFillTask task) Create new set of regions on the specified file-system.booleanFSTableDescriptors.createTableDescriptor(TableDescriptor htd) Create new TableDescriptor in HDFS.booleanFSTableDescriptors.createTableDescriptor(TableDescriptor htd, boolean forceCreation) Create new TableDescriptor in HDFS.static booleanFSTableDescriptors.createTableDescriptorForTableDirectory(org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.fs.Path tableDir, TableDescriptor htd, boolean forceCreation) Create a new TableDescriptor in HDFS in the specified table directory.booleanFSTableDescriptors.createTableDescriptorForTableDirectory(org.apache.hadoop.fs.Path tableDir, TableDescriptor htd, boolean forceCreation) Create a new TableDescriptor in HDFS in the specified table directory.static voidTableDescriptorChecker.sanityCheck(org.apache.hadoop.conf.Configuration c, TableDescriptor td) Checks whether the table conforms to some sane limits, and configured values (compression, etc) work.voidFSTableDescriptors.update(TableDescriptor td, boolean cacheOnly) (package private) org.apache.hadoop.fs.PathFSTableDescriptors.updateTableDescriptor(TableDescriptor td) private static org.apache.hadoop.fs.PathFSTableDescriptors.writeTableDescriptor(org.apache.hadoop.fs.FileSystem fs, TableDescriptor td, org.apache.hadoop.fs.Path tableDir, org.apache.hadoop.fs.FileStatus currentDescriptorFile) Attempts to write a new table descriptor to the given table's directory.Method parameters in org.apache.hadoop.hbase.util with type arguments of type TableDescriptorModifier and TypeMethodDescriptionprivate voidFSTableDescriptors.internalGet(org.apache.hadoop.fs.Path dir, Map<String, TableDescriptor> tds, AtomicBoolean allvisited) 
- 
Uses of TableDescriptor in org.apache.hadoop.hbase.util.compactionFields in org.apache.hadoop.hbase.util.compaction declared as TableDescriptorMethods in org.apache.hadoop.hbase.util.compaction with parameters of type TableDescriptorModifier and TypeMethodDescriptionprivate Optional<MajorCompactionRequest>MajorCompactionTTLRequest.createRequest(Connection connection, TableDescriptor htd) private booleanMajorCompactorTTL.doesAnyColFamilyHaveTTL(TableDescriptor htd) MajorCompactionTTLRequest.getStoresRequiringCompaction(TableDescriptor htd) (package private) static Optional<MajorCompactionRequest>MajorCompactionTTLRequest.newRequest(Connection connection, RegionInfo info, TableDescriptor htd) Constructors in org.apache.hadoop.hbase.util.compaction with parameters of type TableDescriptorModifierConstructorDescriptionMajorCompactorTTL(org.apache.hadoop.conf.Configuration conf, TableDescriptor htd, int concurrency, long sleepForMs) 
- 
Uses of TableDescriptor in org.apache.hadoop.hbase.walMethods in org.apache.hadoop.hbase.wal that return TableDescriptorModifier and TypeMethodDescriptionprivate static TableDescriptorWALPerformanceEvaluation.createHTableDescriptor(int regionNum, int numFamilies) Methods in org.apache.hadoop.hbase.wal with parameters of type TableDescriptorModifier and TypeMethodDescriptionprivate HRegionWALPerformanceEvaluation.openRegion(org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.fs.Path dir, TableDescriptor htd, WALFactory wals, long whenToRoll, LogRoller roller) Constructors in org.apache.hadoop.hbase.wal with parameters of type TableDescriptorModifierConstructorDescription(package private)WALPutBenchmark(HRegion region, TableDescriptor htd, long numIterations, boolean noSync, int syncInterval)