Uses of Interface
org.apache.hadoop.hbase.client.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.hbase
Modifier 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 TableDescriptor
PerformanceEvaluation.getTableDescriptor
(PerformanceEvaluation.TestOptions opts) Create an HTableDescriptor from provided TestOptions.Returns Instance of table descriptor or null if none found.Modifier and TypeMethodDescriptionTableDescriptors.getAll()
Get Map of all TableDescriptors.TableDescriptors.getByNamespace
(String name) Get Map of all NamespaceDescriptors for a given namespace.Modifier 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 int
HBaseTestingUtility.createPreSplitLoadTestTable
(org.apache.hadoop.conf.Configuration conf, TableDescriptor desc, ColumnFamilyDescriptor hcd) Deprecated.Creates a pre-split table for load testing.static int
HBaseTestingUtility.createPreSplitLoadTestTable
(org.apache.hadoop.conf.Configuration conf, TableDescriptor desc, ColumnFamilyDescriptor[] hcds, int numRegionsPerServer) Deprecated.Creates a pre-split table for load testing.static int
HBaseTestingUtility.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 int
HBaseTestingUtility.createPreSplitLoadTestTable
(org.apache.hadoop.conf.Configuration conf, TableDescriptor desc, ColumnFamilyDescriptor hcd, int numRegionsPerServer) Deprecated.Creates a pre-split table for load testing.static HRegion
HBaseTestingUtility.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 HRegion
HBaseTestingUtility.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 HRegion
HBaseTestingUtility.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 HRegion
HBaseTestingUtility.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 void
HBaseTestingUtility.modifyTableSync
(Admin admin, TableDescriptor desc) Deprecated.since 3.0.0 and will be removed in 4.0.0.default void
TableDescriptors.update
(TableDescriptor htd) Add or update descriptor.void
TableDescriptors.update
(TableDescriptor htd, boolean cacheOnly) Add or update descriptorvoid
HBaseTestingUtility.verifyTableDescriptorIgnoreTableName
(TableDescriptor ltd, TableDescriptor rtd) Deprecated. -
Uses of TableDescriptor in org.apache.hadoop.hbase.backup.impl
Modifier and TypeMethodDescriptionstatic TableDescriptor
BackupSystemTable.getSystemTableDescriptor
(org.apache.hadoop.conf.Configuration conf) Get backup system table descriptorstatic TableDescriptor
BackupSystemTable.getSystemTableForBulkLoadedDataDescriptor
(org.apache.hadoop.conf.Configuration conf) Get backup system table descriptorModifier and TypeMethodDescriptionprivate void
BackupSystemTable.createSystemTable
(Admin admin, TableDescriptor descriptor) -
Uses of TableDescriptor in org.apache.hadoop.hbase.backup.util
Modifier and TypeMethodDescription(package private) TableDescriptor
RestoreTool.getTableDesc
(TableName tableName) Get table descriptorprivate TableDescriptor
RestoreTool.getTableDescriptor
(org.apache.hadoop.fs.FileSystem fileSys, TableName tableName, String lastIncrBackupId) Modifier and TypeMethodDescriptionprivate void
RestoreTool.checkAndCreateTable
(Connection conn, TableName targetTableName, ArrayList<org.apache.hadoop.fs.Path> regionDirList, TableDescriptor htd, boolean truncateIfExists) Prepare the table for bulkload, most codes copied fromcreateTable
method inBulkLoadHFilesTool
.(package private) void
RestoreTool.modifyTableSync
(Connection conn, TableDescriptor desc) -
Uses of TableDescriptor in org.apache.hadoop.hbase.client
Modifier and TypeClassDescriptionprivate static final class
Modifier and TypeFieldDescriptionprivate TableDescriptor
TableSnapshotScanner.htd
static final TableDescriptor
TableDescriptorBuilder.NAMESPACE_TABLEDESC
Deprecated.since 3.0.0 and will be removed in 4.0.0.Modifier and TypeFieldDescriptionstatic final Comparator<TableDescriptor>
TableDescriptor.COMPARATOR
static final Comparator<TableDescriptor>
TableDescriptor.COMPARATOR_IGNORE_REPLICATION
Modifier and TypeMethodDescriptionTableDescriptorBuilder.build()
static TableDescriptor
TableDescriptorBuilder.copy
(TableDescriptor desc) static TableDescriptor
TableDescriptorBuilder.copy
(TableName name, TableDescriptor desc) Admin.getDescriptor
(TableName tableName) Get a table descriptor.AdminOverAsyncAdmin.getDescriptor
(TableName tableName) Table.getDescriptor()
Gets thetable descriptor
for this table.TableOverAsyncTable.getDescriptor()
private static TableDescriptor
TableDescriptorBuilder.ModifyableTableDescriptor.parseFrom
(byte[] bytes) static TableDescriptor
TableDescriptorBuilder.parseFrom
(byte[] pbBytes) The input should be created byTableDescriptorBuilder.toByteArray(org.apache.hadoop.hbase.client.TableDescriptor)
.Modifier and TypeMethodDescriptionstatic Comparator<TableDescriptor>
TableDescriptor.getComparator
(Comparator<ColumnFamilyDescriptor> cfComparator) AsyncAdmin.getDescriptor
(TableName tableName) Method for getting the tableDescriptorAsyncHBaseAdmin.getDescriptor
(TableName tableName) AsyncTable.getDescriptor()
Gets theTableDescriptor
for 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) Modifier and TypeMethodDescriptionprivate CompletableFuture<Void>
RawAsyncHBaseAdmin.compareTableWithPeerCluster
(TableName tableName, TableDescriptor tableDesc, ReplicationPeerDescription peer, AsyncAdmin peerAdmin) TableDescriptorUtils.computeDelta
(TableDescriptor oldTD, TableDescriptor newTD) Compares twoTableDescriptor
and indicate which columns were added, deleted, or modified from oldTD to newTDstatic TableDescriptor
TableDescriptorBuilder.copy
(TableDescriptor desc) static TableDescriptor
TableDescriptorBuilder.copy
(TableName name, TableDescriptor desc) default void
Admin.createTable
(TableDescriptor desc) Creates a new table.default void
Admin.createTable
(TableDescriptor desc, byte[][] splitKeys) Creates a new table with an initial set of empty regions defined by the specified split keys.void
Admin.createTable
(TableDescriptor desc, byte[] startKey, byte[] endKey, int numRegions) Creates a new table with the specified number of regions.void
AdminOverAsyncAdmin.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 void
Admin.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 TableDescriptorBuilder
TableDescriptorBuilder.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 prefixModifierConstructorDescriptionClientSideRegionScanner
(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) private
private
ModifyableTableDescriptor
(TableName name, TableDescriptor desc) Construct a table descriptor by cloning the descriptor passed as a parameter.private
private
TableDescriptorDelta
(TableDescriptor oldTD, TableDescriptor newTD) -
Uses of TableDescriptor in org.apache.hadoop.hbase.constraint
Modifier and TypeMethodDescriptionstatic boolean
Constraints.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.Entry
in the descriptor for the specified classstatic boolean
Constraints.has
(TableDescriptor desc, Class<? extends Constraint> clazz) Check to see if the Constraint is currently set. -
Uses of TableDescriptor in org.apache.hadoop.hbase.coprocessor
Modifier and TypeMethodDescriptiondefault TableDescriptor
MasterObserver.preCreateTableRegionsInfos
(ObserverContext<MasterCoprocessorEnvironment> ctx, TableDescriptor desc) Called before we create the region infos for this table.default TableDescriptor
MasterObserver.preModifyTable
(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName, TableDescriptor currentDescriptor, TableDescriptor newDescriptor) Called prior to modifying a table's properties.Modifier and TypeMethodDescriptiondefault void
MasterObserver.postCloneSnapshot
(ObserverContext<MasterCoprocessorEnvironment> ctx, SnapshotDescription snapshot, TableDescriptor tableDescriptor) Called after a snapshot clone operation has been requested.default void
MasterObserver.postCompletedCreateTableAction
(ObserverContext<MasterCoprocessorEnvironment> ctx, TableDescriptor desc, RegionInfo[] regions) Called after the createTable operation has been requested.default void
MasterObserver.postCompletedModifyTableAction
(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName, TableDescriptor oldDescriptor, TableDescriptor currentDescriptor) Called after to modifying a table's properties.default void
MasterObserver.postCompletedSnapshotAction
(ObserverContext<MasterCoprocessorEnvironment> ctx, SnapshotDescription snapshot, TableDescriptor tableDescriptor) Called after the snapshot operation has been completed.default void
MasterObserver.postCreateTable
(ObserverContext<MasterCoprocessorEnvironment> ctx, TableDescriptor desc, RegionInfo[] regions) Called after the createTable operation has been requested.default void
MasterObserver.postModifyTable
(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName, TableDescriptor oldDescriptor, TableDescriptor currentDescriptor) Called after the modifyTable operation has been requested.default void
MasterObserver.postRestoreSnapshot
(ObserverContext<MasterCoprocessorEnvironment> ctx, SnapshotDescription snapshot, TableDescriptor tableDescriptor) Called after a snapshot restore operation has been requested.default void
MasterObserver.postSnapshot
(ObserverContext<MasterCoprocessorEnvironment> ctx, SnapshotDescription snapshot, TableDescriptor tableDescriptor) Called after the snapshot operation has been requested.default void
MasterObserver.preCloneSnapshot
(ObserverContext<MasterCoprocessorEnvironment> ctx, SnapshotDescription snapshot, TableDescriptor tableDescriptor) Called before a snapshot is cloned.default void
MasterObserver.preCreateTable
(ObserverContext<MasterCoprocessorEnvironment> ctx, TableDescriptor desc, RegionInfo[] regions) Called before a new table is created byHMaster
.default void
MasterObserver.preCreateTableAction
(ObserverContext<MasterCoprocessorEnvironment> ctx, TableDescriptor desc, RegionInfo[] regions) Called before a new table is created byHMaster
.default TableDescriptor
MasterObserver.preCreateTableRegionsInfos
(ObserverContext<MasterCoprocessorEnvironment> ctx, TableDescriptor desc) Called before we create the region infos for this table.default TableDescriptor
MasterObserver.preModifyTable
(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName, TableDescriptor currentDescriptor, TableDescriptor newDescriptor) Called prior to modifying a table's properties.default void
MasterObserver.preModifyTableAction
(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName, TableDescriptor currentDescriptor, TableDescriptor newDescriptor) Called prior to modifying a table's properties.default void
MasterObserver.preRestoreSnapshot
(ObserverContext<MasterCoprocessorEnvironment> ctx, SnapshotDescription snapshot, TableDescriptor tableDescriptor) Called before a snapshot is restored.default void
MasterObserver.preSnapshot
(ObserverContext<MasterCoprocessorEnvironment> ctx, SnapshotDescription snapshot, TableDescriptor tableDescriptor) Called before a new snapshot is taken.Modifier and TypeMethodDescriptiondefault void
MasterObserver.postGetTableNames
(ObserverContext<MasterCoprocessorEnvironment> ctx, List<TableDescriptor> descriptors, String regex) Called after a getTableNames request has been processed.default void
MasterObserver.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.example
Modifier and TypeMethodDescriptionvoid
ExampleMasterObserverWithMetrics.postCreateTable
(ObserverContext<MasterCoprocessorEnvironment> ctx, TableDescriptor desc, RegionInfo[] regions) void
ExampleMasterObserverWithMetrics.preCreateTable
(ObserverContext<MasterCoprocessorEnvironment> ctx, TableDescriptor desc, RegionInfo[] regions) -
Uses of TableDescriptor in org.apache.hadoop.hbase.fs
Modifier and TypeMethodDescriptionstatic boolean
ErasureCodingUtils.needsSync
(TableDescriptor oldDescriptor, TableDescriptor newDescriptor) Check if EC policy is different between two descriptorsstatic void
ErasureCodingUtils.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.mapred
ModifierConstructorDescriptionTableSnapshotRegionSplit
(TableDescriptor htd, RegionInfo regionInfo, List<String> locations, Scan scan, org.apache.hadoop.fs.Path restoreDir) -
Uses of TableDescriptor in org.apache.hadoop.hbase.mapreduce
Modifier and TypeFieldDescriptionprivate TableDescriptor
TableSnapshotInputFormatImpl.InputSplit.htd
private TableDescriptor
HFileOutputFormat2.TableInfo.tableDesctiptor
Modifier and TypeMethodDescriptionTableSnapshotInputFormatImpl.InputSplit.getHtd()
HFileOutputFormat2.TableInfo.getTableDescriptor()
TableSnapshotInputFormatImpl.InputSplit.getTableDescriptor()
Modifier 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 void
HFileOutputFormat2.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 void
HFileOutputFormat2.configureIncrementalLoadMap
(org.apache.hadoop.mapreduce.Job job, TableDescriptor tableDescriptor) Modifier and TypeMethodDescription(package private) static String
HFileOutputFormat2.serializeColumnFamilyAttribute
(Function<ColumnFamilyDescriptor, String> fn, List<TableDescriptor> allTables) ModifierConstructorDescriptionInputSplit
(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.master
Modifier and TypeMethodDescriptionHMaster.TableDescriptorGetter.get()
MasterCoprocessorHost.preCreateTableRegionsInfos
(TableDescriptor desc) MasterCoprocessorHost.preModifyTable
(TableName tableName, TableDescriptor currentDescriptor, TableDescriptor newDescriptor) Modifier 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 namespaceModifier and TypeMethodDescriptionprivate void
HMaster.createMissingCFsInMetaDuringUpgrade
(TableDescriptor metaDescriptor) long
HMaster.createSystemTable
(TableDescriptor tableDescriptor) long
MasterServices.createSystemTable
(TableDescriptor tableDescriptor) Create a system table using the given table definition.long
HMaster.createTable
(TableDescriptor tableDescriptor, byte[][] splitKeys, long nonceGroup, long nonce) long
MasterServices.createTable
(TableDescriptor desc, byte[][] splitKeys, long nonceGroup, long nonce) Create a table using the given table definition.long
HMaster.modifyTable
(TableName tableName, TableDescriptor newDescriptor, long nonceGroup, long nonce, boolean reopenRegions) default long
MasterServices.modifyTable
(TableName tableName, TableDescriptor descriptor, long nonceGroup, long nonce) Modify the descriptor of an existing tablelong
MasterServices.modifyTable
(TableName tableName, TableDescriptor descriptor, long nonceGroup, long nonce, boolean reopenRegions) Modify the descriptor of an existing tablevoid
MasterCoprocessorHost.postCloneSnapshot
(SnapshotDescription snapshot, TableDescriptor hTableDescriptor) void
MasterCoprocessorHost.postCompletedCreateTableAction
(TableDescriptor htd, RegionInfo[] regions, User user) void
MasterCoprocessorHost.postCompletedModifyTableAction
(TableName tableName, TableDescriptor oldDescriptor, TableDescriptor currentDescriptor, User user) void
MasterCoprocessorHost.postCompletedSnapshotAction
(SnapshotDescription snapshot, TableDescriptor hTableDescriptor) void
MasterCoprocessorHost.postCreateTable
(TableDescriptor htd, RegionInfo[] regions) void
MasterCoprocessorHost.postModifyTable
(TableName tableName, TableDescriptor oldDescriptor, TableDescriptor currentDescriptor) void
MasterCoprocessorHost.postRestoreSnapshot
(SnapshotDescription snapshot, TableDescriptor hTableDescriptor) void
MasterCoprocessorHost.postSnapshot
(SnapshotDescription snapshot, TableDescriptor hTableDescriptor, User user) void
MasterCoprocessorHost.preCloneSnapshot
(SnapshotDescription snapshot, TableDescriptor hTableDescriptor) void
MasterCoprocessorHost.preCreateTable
(TableDescriptor htd, RegionInfo[] regions) void
MasterCoprocessorHost.preCreateTableAction
(TableDescriptor htd, RegionInfo[] regions, User user) MasterCoprocessorHost.preCreateTableRegionsInfos
(TableDescriptor desc) MasterCoprocessorHost.preModifyTable
(TableName tableName, TableDescriptor currentDescriptor, TableDescriptor newDescriptor) void
MasterCoprocessorHost.preModifyTableAction
(TableName tableName, TableDescriptor currentDescriptor, TableDescriptor newDescriptor, User user) void
MasterCoprocessorHost.preRestoreSnapshot
(SnapshotDescription snapshot, TableDescriptor hTableDescriptor) void
MasterCoprocessorHost.preSnapshot
(SnapshotDescription snapshot, TableDescriptor hTableDescriptor, User user) Modifier and TypeMethodDescriptionprivate static void
HMaster.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.void
MasterCoprocessorHost.postGetTableNames
(List<TableDescriptor> descriptors, String regex) void
MasterCoprocessorHost.preGetTableNames
(List<TableDescriptor> descriptors, String regex) -
Uses of TableDescriptor in org.apache.hadoop.hbase.master.assignment
Modifier and TypeMethodDescriptionprivate TableDescriptor
RegionStateStore.getDescriptor
(TableName tableName) Modifier and TypeMethodDescriptionprivate int
RegionStateStore.getRegionReplication
(TableDescriptor htd) private boolean
RegionStateStore.hasGlobalReplicationScope
(TableDescriptor htd) void
RegionStateStore.mergeRegions
(RegionInfo child, RegionInfo[] parents, ServerName serverName, TableDescriptor htd) void
RegionStateStore.splitRegion
(RegionInfo parent, RegionInfo splitA, RegionInfo splitB, ServerName serverName, TableDescriptor htd) Splits the region into two in an atomic operation. -
Uses of TableDescriptor in org.apache.hadoop.hbase.master.balancer
Modifier and TypeMethodDescriptionprivate TableDescriptor
RegionHDFSBlockLocationFinder.getDescriptor
(TableName tableName) return TableDescriptor for a given tableNameClusterInfoProvider.getTableDescriptor
(TableName tableName) Get the table descriptor for the given table.MasterClusterInfoProvider.getTableDescriptor
(TableName tableName) Modifier 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.normalizer
Modifier and TypeFieldDescriptionprivate final TableDescriptor
SimpleRegionNormalizer.NormalizeContext.tableDescriptor
Modifier and TypeMethodDescriptionRegionNormalizer.computePlansForTable
(TableDescriptor tableDescriptor) Computes a list of normalizer actions to perform on the target table.SimpleRegionNormalizer.computePlansForTable
(TableDescriptor tableDescriptor) private double
SimpleRegionNormalizer.getAverageRegionSizeMb
(List<RegionInfo> tableRegions, TableDescriptor tableDescriptor) Also make sure tableRegions contains regions of the same tableprivate boolean
SimpleRegionNormalizer.proceedWithMergePlanning
(TableDescriptor tableDescriptor) private boolean
SimpleRegionNormalizer.proceedWithSplitPlanning
(TableDescriptor tableDescriptor) -
Uses of TableDescriptor in org.apache.hadoop.hbase.master.procedure
Modifier and TypeFieldDescriptionprivate TableDescriptor
SnapshotProcedure.htd
private TableDescriptor
ModifyTableDescriptorProcedure.modifiedTableDescriptor
private TableDescriptor
ModifyTableProcedure.modifiedTableDescriptor
private TableDescriptor
RestoreSnapshotProcedure.modifiedTableDescriptor
private TableDescriptor
RestoreSnapshotProcedure.oldTableDescriptor
private TableDescriptor
CloneSnapshotProcedure.tableDescriptor
private TableDescriptor
CreateTableProcedure.tableDescriptor
private TableDescriptor
TruncateTableProcedure.tableDescriptor
private TableDescriptor
ModifyTableProcedure.unmodifiedTableDescriptor
Modifier and TypeMethodDescriptionprivate TableDescriptor
SnapshotProcedure.loadTableDescriptorSnapshot
(MasterProcedureEnv env) private static TableDescriptor
InitMetaProcedure.writeFsLayout
(org.apache.hadoop.fs.Path rootDir, org.apache.hadoop.conf.Configuration conf) Modifier 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.Modifier and TypeMethodDescriptionprivate static void
CreateTableProcedure.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) private void
ModifyTableProcedure.deleteFromFs
(MasterProcedureEnv env, TableDescriptor oldTableDescriptor, TableDescriptor newTableDescriptor) Removes from hdfs the families that are not longer present in the new table descriptor.private void
ModifyTableProcedure.initialize
(TableDescriptor unmodifiedTableDescriptor, boolean shouldCheckDescriptor) private static boolean
ModifyTableProcedure.isDeleteColumnFamily
(TableDescriptor originalDescriptor, TableDescriptor newDescriptor) Find out whether all column families in unmodifiedTableDescriptor also exists in the modifiedTableDescriptor.private boolean
ModifyTableProcedure.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.ModifierConstructorDescriptionCloneSnapshotProcedure
(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.region
Modifier and TypeFieldDescriptionprivate static final TableDescriptor
MasterRegionFactory.TABLE_DESC
private TableDescriptor
MasterRegionParams.tableDescriptor
Modifier and TypeMethodDescriptionMasterRegionParams.tableDescriptor()
private static TableDescriptor
MasterRegionFactory.withTrackerConfigs
(org.apache.hadoop.conf.Configuration conf) Modifier and TypeMethodDescriptionprivate static HRegion
MasterRegion.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 HRegion
MasterRegion.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 void
MasterRegion.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.snapshot
Modifier and TypeMethodDescriptionprivate TableDescriptor
TakeSnapshotHandler.loadTableDescriptor()
private TableDescriptor
SnapshotManager.sanityCheckBeforeSnapshot
(org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotDescription snapshot, boolean checkTable) Check if the snapshot can be taken.Modifier and TypeMethodDescription(package private) long
SnapshotManager.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 long
SnapshotManager.cloneSnapshot
(org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotDescription reqSnapshot, TableName tableName, org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotDescription snapshot, TableDescriptor snapshotTableDesc, NonceKey nonceKey, boolean restoreAcl, String customSFT) Clone the specified snapshot.private long
SnapshotManager.restoreSnapshot
(org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotDescription snapshot, TableDescriptor tableDescriptor, NonceKey nonceKey, boolean restoreAcl) Restore the specified snapshot.private long
SnapshotManager.restoreSnapshot
(org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotDescription reqSnapshot, TableName tableName, org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotDescription snapshot, TableDescriptor snapshotTableDesc, NonceKey nonceKey, boolean restoreAcl) Restore the specified snapshot. -
Uses of TableDescriptor in org.apache.hadoop.hbase.mob
Modifier and TypeMethodDescriptionvoid
ExpiredMobFileCleaner.cleanExpiredMobFiles
(TableDescriptor htd, ColumnFamilyDescriptor family) Cleans the MOB files when they're expired and their min versions are 0.static void
MobUtils.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 boolean
MobUtils.hasMobColumns
(TableDescriptor htd) Checks whether this table has mob-enabled columns.void
MobFileCompactionChore.performMajorCompactionInBatches
(Admin admin, TableDescriptor htd, ColumnFamilyDescriptor hcd) -
Uses of TableDescriptor in org.apache.hadoop.hbase.quotas
Modifier and TypeFieldDescriptionstatic final TableDescriptor
QuotaUtil.QUOTA_TABLE_DESC
Table descriptor for Quota internal table -
Uses of TableDescriptor in org.apache.hadoop.hbase.regionserver
Modifier and TypeMethodDescriptionHRegion.getTableDescriptor()
Region.getTableDescriptor()
Returns table descriptor for this regionModifier and TypeMethodDescriptionprivate void
CompactionTool.CompactionWorker.compactRegion
(org.apache.hadoop.fs.Path tableDir, TableDescriptor htd, org.apache.hadoop.fs.Path regionDir, boolean compactOnce, boolean major) private void
CompactionTool.CompactionWorker.compactStoreFiles
(org.apache.hadoop.fs.Path tableDir, TableDescriptor htd, RegionInfo hri, String familyName, boolean compactOnce, boolean major) Execute the actual compaction job.static HDFSBlocksDistribution
HRegion.computeHDFSBlocksDistribution
(org.apache.hadoop.conf.Configuration conf, TableDescriptor tableDescriptor, RegionInfo regionInfo) This is a helper function to compute HDFS block distribution on demandstatic HDFSBlocksDistribution
HRegion.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 RegionSplitRestriction
RegionSplitRestriction.create
(TableDescriptor tableDescriptor, org.apache.hadoop.conf.Configuration conf) Create the RegionSplitRestriction configured for the given table.static HRegion
HRegion.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 HRegion
HRegion.createHRegion
(RegionInfo info, org.apache.hadoop.fs.Path rootDir, org.apache.hadoop.conf.Configuration conf, TableDescriptor hTableDescriptor, WAL wal) static HRegion
HRegion.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 HRegion
HRegion.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.Configuration
StoreUtils.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 HStore
CompactionTool.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) void
DelimitedKeyPrefixRegionSplitRestriction.initialize
(TableDescriptor tableDescriptor, org.apache.hadoop.conf.Configuration conf) void
KeyPrefixRegionSplitRestriction.initialize
(TableDescriptor tableDescriptor, org.apache.hadoop.conf.Configuration conf) void
NoRegionSplitRestriction.initialize
(TableDescriptor tableDescriptor, org.apache.hadoop.conf.Configuration conf) abstract void
RegionSplitRestriction.initialize
(TableDescriptor tableDescriptor, org.apache.hadoop.conf.Configuration conf) Initialize the RegionSplitRestriction instancestatic HRegion
HRegion.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_IMPL
configuration property.static HRegion
HRegion.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 HRegion
HRegion.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 HRegion
HRegion.openHRegion
(org.apache.hadoop.fs.Path rootDir, RegionInfo info, TableDescriptor htd, WAL wal, org.apache.hadoop.conf.Configuration conf) Open a Region.static HRegion
HRegion.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 HRegion
HRegion.openHRegion
(RegionInfo info, TableDescriptor htd, WAL wal, org.apache.hadoop.conf.Configuration conf) Open a Region.static HRegion
HRegion.openHRegion
(RegionInfo info, TableDescriptor htd, WAL wal, org.apache.hadoop.conf.Configuration conf, RegionServerServices rsServices, CancelableProgressable reporter) Open a Region.static HRegion
HRegion.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 HRegion
HRegion.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)void
HRegion.setTableDescriptor
(TableDescriptor desc) static void
RegionCoprocessorHost.testTableCoprocessorAttrs
(org.apache.hadoop.conf.Configuration conf, TableDescriptor htd) Sanity check the table coprocessor attributes of the supplied schema.static HRegion
HRegion.warmupHRegion
(RegionInfo info, TableDescriptor htd, WAL wal, org.apache.hadoop.conf.Configuration conf, RegionServerServices rsServices, CancelableProgressable reporter) Modifier and TypeMethodDescriptionprivate void
RSRpcServices.executeOpenRegionProcedures
(org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.OpenRegionRequest request, Map<TableName, TableDescriptor> tdCache) ModifierConstructorDescriptionHRegion
(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.handler
Modifier and TypeFieldDescriptionprivate final TableDescriptor
OpenRegionHandler.htd
Deprecated.private final TableDescriptor
AssignRegionHandler.tableDesc
Modifier and TypeMethodDescriptionstatic AssignRegionHandler
AssignRegionHandler.create
(HRegionServer server, RegionInfo regionInfo, long openProcId, TableDescriptor tableDesc, long masterSystemTime, long initiatingMasterActiveTime) ModifierConstructorDescriptionAssignRegionHandler
(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.protected
OpenRegionHandler
(Server server, RegionServerServices rsServices, RegionInfo regionInfo, TableDescriptor htd, long masterSystemTime, EventType eventType) Deprecated. -
Uses of TableDescriptor in org.apache.hadoop.hbase.regionserver.regionreplication
ModifierConstructorDescriptionRegionReplicationSink
(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.storefiletracker
Modifier and TypeMethodDescriptionprotected TableDescriptor
ModifyColumnFamilyStoreFileTrackerProcedure.createFinishTableDescriptor
(TableDescriptor current) protected abstract TableDescriptor
ModifyStoreFileTrackerProcedure.createFinishTableDescriptor
(TableDescriptor current) protected TableDescriptor
ModifyTableStoreFileTrackerProcedure.createFinishTableDescriptor
(TableDescriptor current) protected TableDescriptor
ModifyColumnFamilyStoreFileTrackerProcedure.createMigrationTableDescriptor
(org.apache.hadoop.conf.Configuration conf, TableDescriptor current) protected abstract TableDescriptor
ModifyStoreFileTrackerProcedure.createMigrationTableDescriptor
(org.apache.hadoop.conf.Configuration conf, TableDescriptor current) protected TableDescriptor
ModifyTableStoreFileTrackerProcedure.createMigrationTableDescriptor
(org.apache.hadoop.conf.Configuration conf, TableDescriptor current) protected TableDescriptor
ModifyColumnFamilyStoreFileTrackerProcedure.createRestoreTableDescriptor
(TableDescriptor current, String restoreSFT) protected abstract TableDescriptor
ModifyStoreFileTrackerProcedure.createRestoreTableDescriptor
(TableDescriptor current, String restoreSFT) protected TableDescriptor
ModifyTableStoreFileTrackerProcedure.createRestoreTableDescriptor
(TableDescriptor current, String restoreSFT) static TableDescriptor
StoreFileTrackerFactory.updateWithTrackerConfigs
(org.apache.hadoop.conf.Configuration conf, TableDescriptor descriptor) Modifier and TypeMethodDescriptionprotected Optional<TableDescriptor>
InitializeStoreFileTrackerProcedure.modify
(MasterProcedureEnv env, TableDescriptor current) Modifier and TypeMethodDescriptionstatic void
StoreFileTrackerValidationUtils.checkForCreateTable
(org.apache.hadoop.conf.Configuration conf, TableDescriptor table) Pre check when creating a new table.static void
StoreFileTrackerValidationUtils.checkForModifyTable
(org.apache.hadoop.conf.Configuration conf, TableDescriptor oldTable, TableDescriptor newTable, boolean isTableDisabled) Pre check when modifying a table.private static void
StoreFileTrackerValidationUtils.checkForNewFamily
(org.apache.hadoop.conf.Configuration conf, TableDescriptor table, ColumnFamilyDescriptor family) static StoreFileTracker
StoreFileTrackerFactory.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 StoreFileTracker
StoreFileTrackerFactory.create
(org.apache.hadoop.conf.Configuration conf, TableDescriptor td, ColumnFamilyDescriptor cfd, HRegionFileSystem regionFs, boolean isPrimaryReplica) protected org.apache.hadoop.conf.Configuration
ModifyColumnFamilyStoreFileTrackerProcedure.createConf
(org.apache.hadoop.conf.Configuration conf, TableDescriptor current) protected abstract org.apache.hadoop.conf.Configuration
ModifyStoreFileTrackerProcedure.createConf
(org.apache.hadoop.conf.Configuration conf, TableDescriptor current) protected org.apache.hadoop.conf.Configuration
ModifyTableStoreFileTrackerProcedure.createConf
(org.apache.hadoop.conf.Configuration conf, TableDescriptor current) protected TableDescriptor
ModifyColumnFamilyStoreFileTrackerProcedure.createFinishTableDescriptor
(TableDescriptor current) protected abstract TableDescriptor
ModifyStoreFileTrackerProcedure.createFinishTableDescriptor
(TableDescriptor current) protected TableDescriptor
ModifyTableStoreFileTrackerProcedure.createFinishTableDescriptor
(TableDescriptor current) protected TableDescriptor
ModifyColumnFamilyStoreFileTrackerProcedure.createMigrationTableDescriptor
(org.apache.hadoop.conf.Configuration conf, TableDescriptor current) protected abstract TableDescriptor
ModifyStoreFileTrackerProcedure.createMigrationTableDescriptor
(org.apache.hadoop.conf.Configuration conf, TableDescriptor current) protected TableDescriptor
ModifyTableStoreFileTrackerProcedure.createMigrationTableDescriptor
(org.apache.hadoop.conf.Configuration conf, TableDescriptor current) protected TableDescriptor
ModifyColumnFamilyStoreFileTrackerProcedure.createRestoreTableDescriptor
(TableDescriptor current, String restoreSFT) protected abstract TableDescriptor
ModifyStoreFileTrackerProcedure.createRestoreTableDescriptor
(TableDescriptor current, String restoreSFT) protected TableDescriptor
ModifyTableStoreFileTrackerProcedure.createRestoreTableDescriptor
(TableDescriptor current, String restoreSFT) private static org.apache.hadoop.conf.Configuration
StoreFileTrackerFactory.mergeConfigurations
(org.apache.hadoop.conf.Configuration global, TableDescriptor table, ColumnFamilyDescriptor family) protected Optional<TableDescriptor>
InitializeStoreFileTrackerProcedure.modify
(MasterProcedureEnv env, TableDescriptor current) protected void
ModifyColumnFamilyStoreFileTrackerProcedure.preCheck
(TableDescriptor current) protected abstract void
ModifyStoreFileTrackerProcedure.preCheck
(TableDescriptor current) protected void
ModifyTableStoreFileTrackerProcedure.preCheck
(TableDescriptor current) static TableDescriptor
StoreFileTrackerFactory.updateWithTrackerConfigs
(org.apache.hadoop.conf.Configuration conf, TableDescriptor descriptor) static void
StoreFileTrackerValidationUtils.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.replication
Modifier and TypeMethodDescriptionstatic TableDescriptor
ReplicationStorageFactory.createReplicationQueueTableDescriptor
(TableName tableName) -
Uses of TableDescriptor in org.apache.hadoop.hbase.rest
-
Uses of TableDescriptor in org.apache.hadoop.hbase.rest.model
Modifier and TypeMethodDescriptionTableSchemaModel.getTableDescriptor()
Returns a table descriptor -
Uses of TableDescriptor in org.apache.hadoop.hbase.rsgroup
Modifier and TypeFieldDescriptionprivate static final TableDescriptor
RSGroupInfoManagerImpl.RSGROUP_TABLE_DESC
Table descriptor forhbase:rsgroup
catalog tableModifier and TypeMethodDescriptionprotected Optional<TableDescriptor>
MigrateRSGroupProcedure.modify
(MasterProcedureEnv env, TableDescriptor current) Modifier and TypeMethodDescriptionprotected Optional<TableDescriptor>
MigrateRSGroupProcedure.modify
(MasterProcedureEnv env, TableDescriptor current) Modifier and TypeMethodDescriptionstatic RSGroupInfo
RSGroupUtil.fillTables
(RSGroupInfo rsGroupInfo, Collection<TableDescriptor> tds) Fill the tables field forRSGroupInfo
, for backward compatibility. -
Uses of TableDescriptor in org.apache.hadoop.hbase.security.access
Modifier and TypeMethodDescriptionAccessController.preModifyTable
(ObserverContext<MasterCoprocessorEnvironment> c, TableName tableName, TableDescriptor currentDesc, TableDescriptor newDesc) CoprocessorWhitelistMasterObserver.preModifyTable
(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName, TableDescriptor currentDesc, TableDescriptor newDesc) Modifier and TypeMethodDescription(package private) boolean
SnapshotScannerHDFSAclHelper.isAclSyncToHdfsEnabled
(TableDescriptor tableDescriptor) (package private) static boolean
PermissionStorage.isAclTable
(TableDescriptor desc) Returnstrue
if the given table is_acl_
metadata table.private boolean
SnapshotScannerHDFSAclController.needHandleTableHdfsAcl
(TableDescriptor tableDescriptor, String operation) void
AccessController.postCompletedCreateTableAction
(ObserverContext<MasterCoprocessorEnvironment> c, TableDescriptor desc, RegionInfo[] regions) void
SnapshotScannerHDFSAclController.postCompletedCreateTableAction
(ObserverContext<MasterCoprocessorEnvironment> c, TableDescriptor desc, RegionInfo[] regions) void
SnapshotScannerHDFSAclController.postCompletedSnapshotAction
(ObserverContext<MasterCoprocessorEnvironment> c, SnapshotDescription snapshot, TableDescriptor tableDescriptor) void
AccessController.postModifyTable
(ObserverContext<MasterCoprocessorEnvironment> c, TableName tableName, TableDescriptor oldDesc, TableDescriptor currentDesc) void
SnapshotScannerHDFSAclController.postModifyTable
(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName, TableDescriptor oldDescriptor, TableDescriptor currentDescriptor) void
AccessController.preCloneSnapshot
(ObserverContext<MasterCoprocessorEnvironment> ctx, SnapshotDescription snapshot, TableDescriptor hTableDescriptor) void
AccessController.preCreateTable
(ObserverContext<MasterCoprocessorEnvironment> c, TableDescriptor desc, RegionInfo[] regions) Observer implementationsvoid
CoprocessorWhitelistMasterObserver.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) void
AccessController.preRestoreSnapshot
(ObserverContext<MasterCoprocessorEnvironment> ctx, SnapshotDescription snapshot, TableDescriptor hTableDescriptor) void
AccessController.preSnapshot
(ObserverContext<MasterCoprocessorEnvironment> ctx, SnapshotDescription snapshot, TableDescriptor hTableDescriptor) private static void
CoprocessorWhitelistMasterObserver.verifyCoprocessors
(ObserverContext<MasterCoprocessorEnvironment> ctx, TableDescriptor htd) Perform the validation checks for a coprocessor to determine if the path is white listed or not.Modifier and TypeMethodDescriptionvoid
AccessController.postGetTableNames
(ObserverContext<MasterCoprocessorEnvironment> ctx, List<TableDescriptor> descriptors, String regex) -
Uses of TableDescriptor in org.apache.hadoop.hbase.security.visibility
Modifier and TypeMethodDescriptionVisibilityController.preModifyTable
(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName, TableDescriptor currentDescriptor, TableDescriptor newDescriptor) Modifier and TypeMethodDescriptionVisibilityController.preModifyTable
(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName, TableDescriptor currentDescriptor, TableDescriptor newDescriptor) -
Uses of TableDescriptor in org.apache.hadoop.hbase.snapshot
Modifier and TypeFieldDescriptionprivate final TableDescriptor
RestoreSnapshotHelper.RestoreMetaChanges.htd
private TableDescriptor
SnapshotManifest.htd
private final TableDescriptor
RestoreSnapshotHelper.tableDesc
Modifier and TypeMethodDescriptionRestoreSnapshotHelper.RestoreMetaChanges.getTableDescriptor()
SnapshotManifest.getTableDescriptor()
Get the table descriptor from the SnapshotModifier and TypeMethodDescriptionvoid
SnapshotManifest.addTableDescriptor
(TableDescriptor htd) Add the table descriptor to the snapshot manifest(package private) static org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotRegionManifest
SnapshotManifestV1.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) ModifierConstructorDescriptionRestoreMetaChanges
(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.thrift2
Modifier and TypeMethodDescriptionstatic TableDescriptor
ThriftUtilities.tableDescriptorFromThrift
(org.apache.hadoop.hbase.thrift2.generated.TTableDescriptor in) Modifier and TypeMethodDescriptionstatic List<TableDescriptor>
ThriftUtilities.tableDescriptorsFromThrift
(List<org.apache.hadoop.hbase.thrift2.generated.TTableDescriptor> in) Modifier and TypeMethodDescriptionstatic org.apache.hadoop.hbase.thrift2.generated.TTableDescriptor
ThriftUtilities.tableDescriptorFromHBase
(TableDescriptor in) static List<org.apache.hadoop.hbase.thrift2.generated.TTableDescriptor>
ThriftUtilities.tableDescriptorsFromHBase
(TableDescriptor[] in) Modifier and TypeMethodDescriptionstatic List<org.apache.hadoop.hbase.thrift2.generated.TTableDescriptor>
ThriftUtilities.tableDescriptorsFromHBase
(List<TableDescriptor> in) -
Uses of TableDescriptor in org.apache.hadoop.hbase.thrift2.client
Modifier and TypeMethodDescriptionThriftAdmin.getDescriptor
(TableName tableName) ThriftTable.getDescriptor()
Modifier 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) Modifier and TypeMethodDescriptionvoid
ThriftAdmin.createTable
(TableDescriptor desc) void
ThriftAdmin.createTable
(TableDescriptor desc, byte[][] splitKeys) void
ThriftAdmin.createTable
(TableDescriptor desc, byte[] startKey, byte[] endKey, int numRegions) ThriftAdmin.createTableAsync
(TableDescriptor desc) ThriftAdmin.createTableAsync
(TableDescriptor desc, byte[][] splitKeys) void
ThriftAdmin.modifyTable
(TableDescriptor td) ThriftAdmin.modifyTableAsync
(TableDescriptor td) ThriftAdmin.modifyTableAsync
(TableDescriptor td, boolean reopenRegions) -
Uses of TableDescriptor in org.apache.hadoop.hbase.tool
Modifier 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 void
BulkLoadHFilesTool.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.util
Modifier and TypeFieldDescriptionprivate final Map<TableName,
TableDescriptor> FSTableDescriptors.cache
(package private) final Set<TableDescriptor>
HbckTableInfo.htds
Modifier and TypeMethodDescriptionGet the current table descriptor for the given table, or null if none exists.(package private) TableDescriptor
HbckTableInfo.getTableDescriptor()
Returns descriptor common to all regions.static TableDescriptor
FSTableDescriptors.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 TableDescriptor
FSTableDescriptors.getTableDescriptorFromFs
(org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.fs.Path hbaseRootDir, TableName tableName) Returns the latest table descriptor for the given table directly from the file system if it exists, bypassing the local cache.(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 TableDescriptor
FSTableDescriptors.tryUpdateAndGetMetaTableDescriptor
(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.fs.Path rootdir) Modifier 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) Modifier and TypeMethodDescriptionprivate static void
TableDescriptorChecker.checkBloomFilterType
(org.apache.hadoop.conf.Configuration conf, TableDescriptor td) static void
TableDescriptorChecker.checkClassLoading
(org.apache.hadoop.conf.Configuration conf, TableDescriptor td) private static void
TableDescriptorChecker.checkCompactionPolicy
(org.apache.hadoop.conf.Configuration conf, TableDescriptor td) static void
TableDescriptorChecker.checkCompression
(org.apache.hadoop.conf.Configuration conf, TableDescriptor td) static void
TableDescriptorChecker.checkEncryption
(org.apache.hadoop.conf.Configuration conf, TableDescriptor td) private static void
TableDescriptorChecker.checkReplicationScope
(org.apache.hadoop.conf.Configuration conf, TableDescriptor td) static HRegion
HBaseFsckRepair.createHDFSRegionDir
(org.apache.hadoop.conf.Configuration conf, RegionInfo hri, TableDescriptor htd) Creates, flushes, and closes a new region.static int
LoadTestUtil.createPreSplitLoadTestTable
(org.apache.hadoop.conf.Configuration conf, TableDescriptor desc, ColumnFamilyDescriptor hcd) Creates a pre-split table for load testing.static int
LoadTestUtil.createPreSplitLoadTestTable
(org.apache.hadoop.conf.Configuration conf, TableDescriptor desc, ColumnFamilyDescriptor[] hcds, int numRegionsPerServer) Creates a pre-split table for load testing.static int
LoadTestUtil.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 int
LoadTestUtil.createPreSplitLoadTestTable
(org.apache.hadoop.conf.Configuration conf, TableDescriptor desc, ColumnFamilyDescriptor hcd, int numRegionsPerServer) Creates a pre-split table for load testing.static RegionInfo
ModifyRegionUtils.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.boolean
FSTableDescriptors.createTableDescriptor
(TableDescriptor htd) Create new TableDescriptor in HDFS.boolean
FSTableDescriptors.createTableDescriptor
(TableDescriptor htd, boolean forceCreation) Create new TableDescriptor in HDFS.static boolean
FSTableDescriptors.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.boolean
FSTableDescriptors.createTableDescriptorForTableDirectory
(org.apache.hadoop.fs.Path tableDir, TableDescriptor htd, boolean forceCreation) Create a new TableDescriptor in HDFS in the specified table directory.static void
TableDescriptorChecker.sanityCheck
(org.apache.hadoop.conf.Configuration c, TableDescriptor td) Checks whether the table conforms to some sane limits, and configured values (compression, etc) work.void
FSTableDescriptors.update
(TableDescriptor td, boolean cacheOnly) (package private) org.apache.hadoop.fs.Path
FSTableDescriptors.updateTableDescriptor
(TableDescriptor td) private static org.apache.hadoop.fs.Path
FSTableDescriptors.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.Modifier and TypeMethodDescriptionprivate void
FSTableDescriptors.internalGet
(org.apache.hadoop.fs.Path dir, Map<String, TableDescriptor> tds, AtomicBoolean allvisited) -
Uses of TableDescriptor in org.apache.hadoop.hbase.util.compaction
Modifier and TypeMethodDescriptionprivate Optional<MajorCompactionRequest>
MajorCompactionTTLRequest.createRequest
(Connection connection, TableDescriptor htd) private boolean
MajorCompactorTTL.doesAnyColFamilyHaveTTL
(TableDescriptor htd) MajorCompactionTTLRequest.getStoresRequiringCompaction
(TableDescriptor htd) (package private) static Optional<MajorCompactionRequest>
MajorCompactionTTLRequest.newRequest
(Connection connection, RegionInfo info, TableDescriptor htd) ModifierConstructorDescriptionMajorCompactorTTL
(org.apache.hadoop.conf.Configuration conf, TableDescriptor htd, int concurrency, long sleepForMs) -
Uses of TableDescriptor in org.apache.hadoop.hbase.wal
Modifier and TypeMethodDescriptionprivate static TableDescriptor
WALPerformanceEvaluation.createHTableDescriptor
(int regionNum, int numFamilies) Modifier and TypeMethodDescriptionprivate HRegion
WALPerformanceEvaluation.openRegion
(org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.fs.Path dir, TableDescriptor htd, WALFactory wals, long whenToRoll, LogRoller roller) ModifierConstructorDescription(package private)
WALPutBenchmark
(HRegion region, TableDescriptor htd, long numIterations, boolean noSync, int syncInterval)