| Modifier and Type | Class and Description | 
|---|---|
| class  | HTableDescriptorDeprecated. 
 As of release 2.0.0, this will be removed in HBase 3.0.0.
             Use  TableDescriptorBuilderto buildHTableDescriptor. | 
| Modifier and Type | Method and Description | 
|---|---|
| TableDescriptor | TableDescriptors. get(TableName tableName) | 
| TableDescriptor | TableDescriptors. remove(TableName tablename) | 
| Modifier and Type | Method and Description | 
|---|---|
| Map<String,TableDescriptor> | TableDescriptors. getAll()Get Map of all TableDescriptors. | 
| Map<String,TableDescriptor> | TableDescriptors. getByNamespace(String name)Get Map of all NamespaceDescriptors for a given namespace. | 
| Modifier and Type | Method and Description | 
|---|---|
| void | TableDescriptors. add(TableDescriptor htd)Add or update descriptor | 
| Constructor and Description | 
|---|
| HTableDescriptor(TableDescriptor desc)Deprecated.  | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | ImmutableHTableDescriptorDeprecated.  | 
| static class  | TableDescriptorBuilder.ModifyableTableDescriptorTODO: make this private after removing the HTableDescriptor | 
| Modifier and Type | Field and Description | 
|---|---|
| private TableDescriptor | HBaseAdmin.CreateTableFuture. desc | 
| private TableDescriptor | TableSnapshotScanner. htd | 
| static TableDescriptor | TableDescriptorBuilder. NAMESPACE_TABLEDESCTable descriptor for namespace table | 
| Modifier and Type | Field and Description | 
|---|---|
| static Comparator<TableDescriptor> | TableDescriptor. COMPARATOR | 
| static Comparator<TableDescriptor> | TableDescriptor. COMPARATOR_IGNORE_REPLICATION | 
| Modifier and Type | Method and Description | 
|---|---|
| TableDescriptor | TableDescriptorBuilder. build() | 
| static TableDescriptor | TableDescriptorBuilder. copy(TableDescriptor desc) | 
| static TableDescriptor | TableDescriptorBuilder. copy(TableName name,
    TableDescriptor desc) | 
| TableDescriptor | HTable. getDescriptor() | 
| TableDescriptor | Table. getDescriptor()Gets the  table descriptorfor this table. | 
| TableDescriptor | Admin. getDescriptor(TableName tableName)Get a table descriptor. | 
| TableDescriptor | HBaseAdmin. getDescriptor(TableName tableName) | 
| protected TableDescriptor | HBaseAdmin.CreateTableFuture. getTableDescriptor() | 
| protected TableDescriptor | HBaseAdmin.TableFuture. getTableDescriptor() | 
| (package private) static TableDescriptor | HBaseAdmin. getTableDescriptor(TableName tableName,
                  Connection connection,
                  RpcRetryingCallerFactory rpcCallerFactory,
                  RpcControllerFactory rpcControllerFactory,
                  int operationTimeout,
                  int rpcTimeout) | 
| static TableDescriptor | TableDescriptorBuilder. parseFrom(byte[] pbBytes)The input should be created by  TableDescriptorBuilder.toByteArray(org.apache.hadoop.hbase.client.TableDescriptor). | 
| private static TableDescriptor | TableDescriptorBuilder.ModifyableTableDescriptor. parseFrom(byte[] bytes) | 
| Modifier and Type | Method and Description | 
|---|---|
| static List<RegionInfo> | RegionReplicaUtil. addReplicas(TableDescriptor tableDescriptor,
           List<RegionInfo> regions,
           int oldReplicaCount,
           int newReplicaCount)Create any replicas for the regions (the default replicas that was already created is passed to
 the method) | 
| private CompletableFuture<Void> | RawAsyncHBaseAdmin. compareTableWithPeerCluster(TableName tableName,
                           TableDescriptor tableDesc,
                           ReplicationPeerDescription peer,
                           AsyncAdmin peerAdmin) | 
| static TableDescriptorUtils.TableDescriptorDelta | TableDescriptorUtils. computeDelta(TableDescriptor oldTD,
            TableDescriptor newTD)Compares two  TableDescriptorand indicate which columns were added, deleted,
 or modified from oldTD to newTD | 
| static TableDescriptor | TableDescriptorBuilder. copy(TableDescriptor desc) | 
| static TableDescriptor | TableDescriptorBuilder. copy(TableName name,
    TableDescriptor desc) | 
| void | Admin. createTable(TableDescriptor desc)Creates a new table. | 
| CompletableFuture<Void> | AsyncAdmin. createTable(TableDescriptor desc)Creates a new table. | 
| CompletableFuture<Void> | RawAsyncHBaseAdmin. createTable(TableDescriptor desc) | 
| CompletableFuture<Void> | AsyncHBaseAdmin. createTable(TableDescriptor desc) | 
| void | HBaseAdmin. createTable(TableDescriptor desc) | 
| void | Admin. createTable(TableDescriptor desc,
           byte[][] splitKeys)Creates a new table with an initial set of empty regions defined by the specified split keys. | 
| CompletableFuture<Void> | AsyncAdmin. createTable(TableDescriptor desc,
           byte[][] splitKeys)Creates a new table with an initial set of empty regions defined by the specified split keys. | 
| CompletableFuture<Void> | RawAsyncHBaseAdmin. createTable(TableDescriptor desc,
           byte[][] splitKeys) | 
| CompletableFuture<Void> | AsyncHBaseAdmin. createTable(TableDescriptor desc,
           byte[][] splitKeys) | 
| void | HBaseAdmin. createTable(TableDescriptor desc,
           byte[][] splitKeys) | 
| void | Admin. createTable(TableDescriptor desc,
           byte[] startKey,
           byte[] endKey,
           int numRegions)Creates a new table with the specified number of regions. | 
| CompletableFuture<Void> | AsyncAdmin. createTable(TableDescriptor desc,
           byte[] startKey,
           byte[] endKey,
           int numRegions)Creates a new table with the specified number of regions. | 
| CompletableFuture<Void> | RawAsyncHBaseAdmin. createTable(TableDescriptor desc,
           byte[] startKey,
           byte[] endKey,
           int numRegions) | 
| CompletableFuture<Void> | AsyncHBaseAdmin. createTable(TableDescriptor desc,
           byte[] startKey,
           byte[] endKey,
           int numRegions) | 
| void | HBaseAdmin. createTable(TableDescriptor desc,
           byte[] startKey,
           byte[] endKey,
           int numRegions) | 
| Future<Void> | Admin. createTableAsync(TableDescriptor desc)Creates a new table but does not block and wait for it to come online. | 
| Future<Void> | HBaseAdmin. createTableAsync(TableDescriptor desc) | 
| Future<Void> | Admin. createTableAsync(TableDescriptor desc,
                byte[][] splitKeys)Creates a new table but does not block and wait for it to come online. | 
| Future<Void> | HBaseAdmin. createTableAsync(TableDescriptor desc,
                byte[][] splitKeys) | 
| void | Admin. modifyTable(TableDescriptor td)Modify an existing table, more IRB friendly version. | 
| CompletableFuture<Void> | AsyncAdmin. modifyTable(TableDescriptor desc)Modify an existing table, more IRB friendly version. | 
| CompletableFuture<Void> | RawAsyncHBaseAdmin. modifyTable(TableDescriptor desc) | 
| CompletableFuture<Void> | AsyncHBaseAdmin. modifyTable(TableDescriptor desc) | 
| void | HBaseAdmin. modifyTable(TableDescriptor td) | 
| void | Admin. modifyTable(TableName tableName,
           TableDescriptor td)Deprecated. 
 since 2.0 version and will be removed in 3.0 version.
             use  Admin.modifyTable(TableDescriptor) | 
| void | HBaseAdmin. modifyTable(TableName tableName,
           TableDescriptor td) | 
| Future<Void> | Admin. modifyTableAsync(TableDescriptor td)Modify an existing table, more IRB (ruby) friendly version. | 
| Future<Void> | HBaseAdmin. modifyTableAsync(TableDescriptor td) | 
| Future<Void> | Admin. modifyTableAsync(TableName tableName,
                TableDescriptor td)Deprecated. 
 since 2.0 version and will be removed in 3.0 version.
             use  Admin.modifyTableAsync(TableDescriptor) | 
| Future<Void> | HBaseAdmin. modifyTableAsync(TableName tableName,
                TableDescriptor td) | 
| static TableDescriptorBuilder | TableDescriptorBuilder. newBuilder(TableDescriptor desc)Copy all values, families, and name from the input. | 
| static byte[] | TableDescriptorBuilder. toByteArray(TableDescriptor desc) | 
| Constructor and Description | 
|---|
| ClientSideRegionScanner(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) | 
| CreateTableFuture(HBaseAdmin admin,
                 TableDescriptor desc,
                 byte[][] splitKeys,
                 org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.CreateTableResponse response) | 
| ImmutableHTableDescriptor(TableDescriptor desc)Deprecated.  | 
| ModifyableTableDescriptor(TableDescriptor desc) | 
| ModifyableTableDescriptor(TableName name,
                         TableDescriptor desc)Deprecated.  | 
| TableDescriptorBuilder(TableDescriptor desc) | 
| TableDescriptorDelta(TableDescriptor oldTD,
                    TableDescriptor newTD) | 
| Modifier and Type | Method and Description | 
|---|---|
| (package private) static List<? extends Constraint> | Constraints. getConstraints(TableDescriptor desc,
              ClassLoader classloader)Get the constraints stored in the table descriptor | 
| Modifier and Type | Method and Description | 
|---|---|
| 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. | 
| Modifier and Type | Method and Description | 
|---|---|
| default 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 currentDescriptor)Deprecated. 
 Since 2.1. Will be removed in 3.0. | 
| default void | MasterObserver. postCompletedModifyTableAction(ObserverContext<MasterCoprocessorEnvironment> ctx,
                              TableName tableName,
                              TableDescriptor oldDescriptor,
                              TableDescriptor currentDescriptor)Called after to modifying a table's properties. | 
| 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 currentDescriptor)Deprecated. 
 Since 2.1. Will be removed in 3.0. | 
| 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 by
  HMaster. | 
| default void | MasterObserver. preCreateTableAction(ObserverContext<MasterCoprocessorEnvironment> ctx,
                    TableDescriptor desc,
                    RegionInfo[] regions)Called before a new table is created by
  HMaster. | 
| default TableDescriptor | MasterObserver. preCreateTableRegionsInfos(ObserverContext<MasterCoprocessorEnvironment> ctx,
                          TableDescriptor desc)Called before we create the region infos for this table. | 
| default void | MasterObserver. preModifyTable(ObserverContext<MasterCoprocessorEnvironment> ctx,
              TableName tableName,
              TableDescriptor newDescriptor)Deprecated. 
 Since 2.1. Will be removed in 3.0. | 
| default TableDescriptor | MasterObserver. preModifyTable(ObserverContext<MasterCoprocessorEnvironment> ctx,
              TableName tableName,
              TableDescriptor currentDescriptor,
              TableDescriptor newDescriptor)Called prior to modifying a table's properties. | 
| default void | MasterObserver. preModifyTableAction(ObserverContext<MasterCoprocessorEnvironment> ctx,
                    TableName tableName,
                    TableDescriptor newDescriptor)Deprecated. 
 Since 2.1. Will be removed in 3.0. | 
| 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 Type | Method and Description | 
|---|---|
| default void | MasterObserver. postGetTableDescriptors(ObserverContext<MasterCoprocessorEnvironment> ctx,
                       List<TableName> tableNamesList,
                       List<TableDescriptor> descriptors,
                       String regex)Called after a getTableDescriptors request has been processed. | 
| default void | MasterObserver. postGetTableNames(ObserverContext<MasterCoprocessorEnvironment> ctx,
                 List<TableDescriptor> descriptors,
                 String regex)Called after a getTableNames request has been processed. | 
| default void | MasterObserver. preGetTableDescriptors(ObserverContext<MasterCoprocessorEnvironment> ctx,
                      List<TableName> tableNamesList,
                      List<TableDescriptor> descriptors,
                      String regex)Called before a getTableDescriptors request has been processed. | 
| default void | MasterObserver. preGetTableNames(ObserverContext<MasterCoprocessorEnvironment> ctx,
                List<TableDescriptor> descriptors,
                String regex)Called before a getTableNames request has been processed. | 
| Modifier and Type | Method and Description | 
|---|---|
| void | ExampleMasterObserverWithMetrics. postCreateTable(ObserverContext<MasterCoprocessorEnvironment> ctx,
               TableDescriptor desc,
               RegionInfo[] regions) | 
| void | ExampleMasterObserverWithMetrics. preCreateTable(ObserverContext<MasterCoprocessorEnvironment> ctx,
              TableDescriptor desc,
              RegionInfo[] regions) | 
| Modifier and Type | Field and Description | 
|---|---|
| private TableDescriptor | TableSnapshotInputFormatImpl.InputSplit. htd | 
| private TableDescriptor | HFileOutputFormat2.TableInfo. tableDesctiptor | 
| Modifier and Type | Method and Description | 
|---|---|
| TableDescriptor | TableSnapshotInputFormatImpl.InputSplit. getHtd() | 
| TableDescriptor | HFileOutputFormat2.TableInfo. getTableDescriptor() | 
| TableDescriptor | TableSnapshotInputFormatImpl.InputSplit. getTableDescriptor() | 
| Modifier and Type | Method and Description | 
|---|---|
| private static List<String> | TableSnapshotInputFormatImpl. calculateLocationsForInputSplit(org.apache.hadoop.conf.Configuration conf,
                               TableDescriptor htd,
                               HRegionInfo hri,
                               org.apache.hadoop.fs.Path tableDir,
                               boolean localityEnabled)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 Type | Method and Description | 
|---|---|
| (package private) static String | HFileOutputFormat2. serializeColumnFamilyAttribute(Function<ColumnFamilyDescriptor,String> fn,
                              List<TableDescriptor> allTables) | 
| Constructor and Description | 
|---|
| InputSplit(TableDescriptor htd,
          HRegionInfo regionInfo,
          List<String> locations,
          Scan scan,
          org.apache.hadoop.fs.Path restoreDir) | 
| TableInfo(TableDescriptor tableDesctiptor,
         RegionLocator regionLocator) | 
| Modifier and Type | Method and Description | 
|---|---|
| TableDescriptor | HMaster.TableDescriptorGetter. get() | 
| private TableDescriptor | CatalogJanitor. getDescriptor(TableName tableName) | 
| TableDescriptor | MasterCoprocessorHost. preCreateTableRegionsInfos(TableDescriptor desc) | 
| TableDescriptor | MasterCoprocessorHost. preModifyTable(TableName tableName,
              TableDescriptor currentDescriptor,
              TableDescriptor newDescriptor) | 
| static TableDescriptor | MasterFileSystem. setInfoFamilyCachingForMeta(TableDescriptor metaDescriptor,
                           boolean b)Enable in memory caching for hbase:meta | 
| Modifier and Type | Method and Description | 
|---|---|
| private List<TableDescriptor> | HMaster. getTableDescriptors(List<TableDescriptor> htds,
                   String namespace,
                   String regex,
                   List<TableName> tableNameList,
                   boolean includeSysTables) | 
| List<TableDescriptor> | HMaster. listTableDescriptors(String namespace,
                    String regex,
                    List<TableName> tableNameList,
                    boolean includeSysTables)Returns the list of table descriptors that match the specified request | 
| List<TableDescriptor> | MasterServices. listTableDescriptorsByNamespace(String name)Get list of table descriptors by namespace | 
| List<TableDescriptor> | HMaster. listTableDescriptorsByNamespace(String name) | 
| Modifier and Type | Method and Description | 
|---|---|
| long | MasterServices. createSystemTable(TableDescriptor tableDescriptor)Create a system table using the given table definition. | 
| long | HMaster. createSystemTable(TableDescriptor tableDescriptor) | 
| long | MasterServices. createTable(TableDescriptor desc,
           byte[][] splitKeys,
           long nonceGroup,
           long nonce)Create a table using the given table definition. | 
| long | HMaster. createTable(TableDescriptor tableDescriptor,
           byte[][] splitKeys,
           long nonceGroup,
           long nonce) | 
| long | MasterServices. modifyTable(TableName tableName,
           TableDescriptor descriptor,
           long nonceGroup,
           long nonce)Modify the descriptor of an existing table | 
| long | HMaster. modifyTable(TableName tableName,
           TableDescriptor newDescriptor,
           long nonceGroup,
           long nonce) | 
| void | 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. 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) | 
| void | MasterCoprocessorHost. preCloneSnapshot(SnapshotDescription snapshot,
                TableDescriptor hTableDescriptor) | 
| void | MasterCoprocessorHost. preCreateTable(TableDescriptor htd,
              RegionInfo[] regions) | 
| void | MasterCoprocessorHost. preCreateTableAction(TableDescriptor htd,
                    RegionInfo[] regions,
                    User user) | 
| TableDescriptor | MasterCoprocessorHost. preCreateTableRegionsInfos(TableDescriptor desc) | 
| TableDescriptor | 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) | 
| static TableDescriptor | MasterFileSystem. setInfoFamilyCachingForMeta(TableDescriptor metaDescriptor,
                           boolean b)Enable in memory caching for hbase:meta | 
| Modifier and Type | Method and Description | 
|---|---|
| private 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) | 
| void | MasterCoprocessorHost. postGetTableDescriptors(List<TableName> tableNamesList,
                       List<TableDescriptor> descriptors,
                       String regex) | 
| void | MasterCoprocessorHost. postGetTableNames(List<TableDescriptor> descriptors,
                 String regex) | 
| void | MasterCoprocessorHost. preGetTableDescriptors(List<TableName> tableNamesList,
                      List<TableDescriptor> descriptors,
                      String regex) | 
| void | MasterCoprocessorHost. preGetTableNames(List<TableDescriptor> descriptors,
                String regex) | 
| Modifier and Type | Method and Description | 
|---|---|
| private TableDescriptor | RegionStateStore. getTableDescriptor(TableName tableName) | 
| Modifier and Type | Method and Description | 
|---|---|
| private int | RegionStateStore. getRegionReplication(TableDescriptor htd) | 
| private boolean | RegionStateStore. hasGlobalReplicationScope(TableDescriptor htd) | 
| Modifier and Type | Method and Description | 
|---|---|
| protected TableDescriptor | RegionLocationFinder. getTableDescriptor(TableName tableName)return TableDescriptor for a given tableName | 
| Modifier and Type | Field and Description | 
|---|---|
| private TableDescriptor | ModifyTableProcedure. modifiedTableDescriptor | 
| private TableDescriptor | RestoreSnapshotProcedure. modifiedTableDescriptor | 
| private TableDescriptor | TruncateTableProcedure. tableDescriptor | 
| private TableDescriptor | CreateTableProcedure. tableDescriptor | 
| private TableDescriptor | CloneSnapshotProcedure. tableDescriptor | 
| private TableDescriptor | ModifyTableProcedure. unmodifiedTableDescriptor | 
| Modifier and Type | Method and Description | 
|---|---|
| private static void | CreateTableProcedure. addRegionsToMeta(MasterProcedureEnv env,
                TableDescriptor tableDescriptor,
                List<RegionInfo> regionInfos)Add the specified set of regions to the hbase:meta table. | 
| private static void | ModifyTableProcedure. addRegionsToMeta(MasterProcedureEnv env,
                TableDescriptor tableDescriptor,
                List<RegionInfo> regionInfos) | 
| 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. | 
| 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 List<RegionInfo> | CloneSnapshotProcedure. createFsLayout(MasterProcedureEnv env,
              TableDescriptor tableDescriptor,
              List<RegionInfo> newRegions,
              CreateTableProcedure.CreateHdfsRegions hdfsRegionHandler)Create region layout in file system. | 
| 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. initilize(TableDescriptor unmodifiedTableDescriptor,
         boolean shouldCheckDescriptor) | 
| protected static void | CreateTableProcedure. moveTempDirectoryToHBaseRoot(MasterProcedureEnv env,
                            TableDescriptor tableDescriptor,
                            org.apache.hadoop.fs.Path tempTableDir) | 
| private void | CloneSnapshotProcedure. moveTempMobDirectoryToHBaseRoot(MasterFileSystem mfs,
                               TableDescriptor tableDescriptor,
                               org.apache.hadoop.fs.Path tempMobTableDir)Move table temp mob directory to the hbase root location | 
| private void | ModifyTableProcedure. updateReplicaColumnsIfNeeded(MasterProcedureEnv env,
                            TableDescriptor oldTableDescriptor,
                            TableDescriptor newTableDescriptor)update replica column families if necessary. | 
| Constructor and Description | 
|---|
| CloneSnapshotProcedure(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)Constructor | 
| CreateTableProcedure(MasterProcedureEnv env,
                    TableDescriptor tableDescriptor,
                    RegionInfo[] newRegions) | 
| CreateTableProcedure(MasterProcedureEnv env,
                    TableDescriptor tableDescriptor,
                    RegionInfo[] newRegions,
                    ProcedurePrepareLatch syncLatch) | 
| ModifyTableProcedure(MasterProcedureEnv env,
                    TableDescriptor htd) | 
| ModifyTableProcedure(MasterProcedureEnv env,
                    TableDescriptor htd,
                    ProcedurePrepareLatch latch) | 
| ModifyTableProcedure(MasterProcedureEnv env,
                    TableDescriptor newTableDescriptor,
                    ProcedurePrepareLatch latch,
                    TableDescriptor oldTableDescriptor,
                    boolean shouldCheckDescriptor) | 
| RestoreSnapshotProcedure(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)Constructor | 
| Modifier and Type | Field and Description | 
|---|---|
| protected TableDescriptor | TakeSnapshotHandler. htd | 
| Modifier and Type | Method and Description | 
|---|---|
| private TableDescriptor | TakeSnapshotHandler. loadTableDescriptor() | 
| Modifier and Type | Method and Description | 
|---|---|
| (package private) long | SnapshotManager. cloneSnapshot(org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotDescription snapshot,
             TableDescriptor tableDescriptor,
             NonceKey nonceKey,
             boolean restoreAcl)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)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. | 
| Modifier and Type | Method and Description | 
|---|---|
| static boolean | MobUtils. hasMobColumns(TableDescriptor htd)Checks whether this table has mob-enabled columns. | 
| Modifier and Type | Field and Description | 
|---|---|
| private TableDescriptor | HRegion. htableDescriptor | 
| Modifier and Type | Method and Description | 
|---|---|
| TableDescriptor | Region. getTableDescriptor() | 
| TableDescriptor | HRegion. getTableDescriptor() | 
| Modifier and Type | Method and Description | 
|---|---|
| private 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 demand | 
| static 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 demand | 
| 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 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,
        org.apache.hadoop.fs.Path tempDir)Create a "mock" HStore that uses the tmpDir specified by the user and
 the store dir to compact as source. | 
| (package private) static List<RegionCoprocessorHost.TableCoprocessorAttribute> | RegionCoprocessorHost. getTableCoprocessorAttrsFromSchema(org.apache.hadoop.conf.Configuration conf,
                                  TableDescriptor htd) | 
| boolean | HRegionFileSystem. hasReferences(TableDescriptor htd)Check whether region has Reference file | 
| static 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 the
  HConstants.REGION_IMPLconfiguration property. | 
| static HRegion | HRegion. openHRegion(org.apache.hadoop.conf.Configuration conf,
           org.apache.hadoop.fs.FileSystem fs,
           org.apache.hadoop.fs.Path rootDir,
           org.apache.hadoop.fs.Path tableDir,
           RegionInfo info,
           TableDescriptor htd,
           WAL wal,
           RegionServerServices rsServices,
           CancelableProgressable reporter)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)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. 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) | 
| (package private) 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 void | HRegion. warmupHRegion(RegionInfo info,
             TableDescriptor htd,
             WAL wal,
             org.apache.hadoop.conf.Configuration conf,
             RegionServerServices rsServices,
             CancelableProgressable reporter) | 
| Modifier and Type | Method and Description | 
|---|---|
| private void | RSRpcServices. executeOpenRegionProcedures(org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.OpenRegionRequest request,
                           Map<TableName,TableDescriptor> tdCache) | 
| Constructor and Description | 
|---|
| HRegion(HRegionFileSystem fs,
       WAL wal,
       org.apache.hadoop.conf.Configuration confParam,
       TableDescriptor htd,
       RegionServerServices rsServices)HRegion constructor. | 
| HRegion(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. | 
| Modifier and Type | Field and Description | 
|---|---|
| private TableDescriptor | OpenRegionHandler. htdDeprecated.  | 
| private TableDescriptor | AssignRegionHandler. tableDesc | 
| Modifier and Type | Method and Description | 
|---|---|
| static AssignRegionHandler | AssignRegionHandler. create(HRegionServer server,
      RegionInfo regionInfo,
      long openProcId,
      TableDescriptor tableDesc,
      long masterSystemTime) | 
| Constructor and Description | 
|---|
| AssignRegionHandler(HRegionServer server,
                   RegionInfo regionInfo,
                   long openProcId,
                   TableDescriptor tableDesc,
                   long masterSystemTime,
                   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.  | 
| OpenRegionHandler(Server server,
                 RegionServerServices rsServices,
                 RegionInfo regionInfo,
                 TableDescriptor htd,
                 long masterSystemTime,
                 EventType eventType)Deprecated.  | 
| Modifier and Type | Method and Description | 
|---|---|
| TableDescriptor | RemoteHTable. getDescriptor() | 
| Modifier and Type | Field and Description | 
|---|---|
| private static TableDescriptor | RSGroupInfoManagerImpl. RSGROUP_TABLE_DESCTable descriptor for  hbase:rsgroupcatalog table | 
| Modifier and Type | Method and Description | 
|---|---|
| (package private) void | RSGroupAdminEndpoint. assignTableToGroup(TableDescriptor desc) | 
| void | RSGroupAdminEndpoint. postCreateTable(ObserverContext<MasterCoprocessorEnvironment> ctx,
               TableDescriptor desc,
               RegionInfo[] regions) | 
| void | RSGroupAdminEndpoint. preCloneSnapshot(ObserverContext<MasterCoprocessorEnvironment> ctx,
                SnapshotDescription snapshot,
                TableDescriptor desc) | 
| void | RSGroupAdminEndpoint. preCreateTableAction(ObserverContext<MasterCoprocessorEnvironment> ctx,
                    TableDescriptor desc,
                    RegionInfo[] regions) | 
| (package private) boolean | RSGroupAdminEndpoint. rsgroupHasServersOnline(TableDescriptor desc) | 
| Modifier and Type | Method and Description | 
|---|---|
| TableDescriptor | CoprocessorWhitelistMasterObserver. preModifyTable(ObserverContext<MasterCoprocessorEnvironment> ctx,
              TableName tableName,
              TableDescriptor currentDesc,
              TableDescriptor newDesc) | 
| TableDescriptor | AccessController. preModifyTable(ObserverContext<MasterCoprocessorEnvironment> c,
              TableName tableName,
              TableDescriptor currentDesc,
              TableDescriptor newDesc) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | AccessController. postGetTableDescriptors(ObserverContext<MasterCoprocessorEnvironment> ctx,
                       List<TableName> tableNamesList,
                       List<TableDescriptor> descriptors,
                       String regex) | 
| void | AccessController. postGetTableNames(ObserverContext<MasterCoprocessorEnvironment> ctx,
                 List<TableDescriptor> descriptors,
                 String regex) | 
| void | AccessController. preGetTableDescriptors(ObserverContext<MasterCoprocessorEnvironment> ctx,
                      List<TableName> tableNamesList,
                      List<TableDescriptor> descriptors,
                      String regex) | 
| Modifier and Type | Method and Description | 
|---|---|
| TableDescriptor | VisibilityController. preModifyTable(ObserverContext<MasterCoprocessorEnvironment> ctx,
              TableName tableName,
              TableDescriptor currentDescriptor,
              TableDescriptor newDescriptor) | 
| Modifier and Type | Method and Description | 
|---|---|
| TableDescriptor | VisibilityController. preModifyTable(ObserverContext<MasterCoprocessorEnvironment> ctx,
              TableName tableName,
              TableDescriptor currentDescriptor,
              TableDescriptor newDescriptor) | 
| Modifier and Type | Field and Description | 
|---|---|
| private TableDescriptor | SnapshotManifest. htd | 
| private TableDescriptor | RestoreSnapshotHelper.RestoreMetaChanges. htd | 
| private TableDescriptor | RestoreSnapshotHelper. tableDesc | 
| Modifier and Type | Method and Description | 
|---|---|
| TableDescriptor | SnapshotManifest. getTableDescriptor()Get the table descriptor from the Snapshot | 
| TableDescriptor | RestoreSnapshotHelper.RestoreMetaChanges. getTableDescriptor() | 
| Modifier and Type | Method and Description | 
|---|---|
| void | SnapshotManifest. addTableDescriptor(TableDescriptor htd)Add the table descriptor to the snapshot manifest | 
| Constructor and Description | 
|---|
| RestoreMetaChanges(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) | 
| Modifier and Type | Method and Description | 
|---|---|
| static TableDescriptor | ThriftUtilities. tableDescriptorFromThrift(org.apache.hadoop.hbase.thrift2.generated.TTableDescriptor in) | 
| Modifier and Type | Method and Description | 
|---|---|
| static List<TableDescriptor> | ThriftUtilities. tableDescriptorsFromThrift(List<org.apache.hadoop.hbase.thrift2.generated.TTableDescriptor> in) | 
| Modifier and Type | Method and Description | 
|---|---|
| static 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 Type | Method and Description | 
|---|---|
| static List<org.apache.hadoop.hbase.thrift2.generated.TTableDescriptor> | ThriftUtilities. tableDescriptorsFromHBase(List<TableDescriptor> in) | 
| Modifier and Type | Method and Description | 
|---|---|
| TableDescriptor | ThriftTable. getDescriptor() | 
| TableDescriptor | ThriftAdmin. getDescriptor(TableName tableName) | 
| Modifier and Type | Method and Description | 
|---|---|
| List<TableDescriptor> | ThriftAdmin. listTableDescriptors() | 
| List<TableDescriptor> | ThriftAdmin. listTableDescriptors(List<TableName> tableNames) | 
| List<TableDescriptor> | ThriftAdmin. listTableDescriptors(Pattern pattern) | 
| List<TableDescriptor> | ThriftAdmin. listTableDescriptors(Pattern pattern,
                    boolean includeSysTables) | 
| List<TableDescriptor> | ThriftAdmin. listTableDescriptorsByNamespace(byte[] name) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | ThriftAdmin. createTable(TableDescriptor desc) | 
| void | ThriftAdmin. createTable(TableDescriptor desc,
           byte[][] splitKeys) | 
| void | ThriftAdmin. createTable(TableDescriptor desc,
           byte[] startKey,
           byte[] endKey,
           int numRegions) | 
| Future<Void> | ThriftAdmin. createTableAsync(TableDescriptor desc) | 
| Future<Void> | ThriftAdmin. createTableAsync(TableDescriptor desc,
                byte[][] splitKeys) | 
| void | ThriftAdmin. modifyTable(TableDescriptor td) | 
| void | ThriftAdmin. modifyTable(TableName tableName,
           TableDescriptor td) | 
| Future<Void> | ThriftAdmin. modifyTableAsync(TableDescriptor td) | 
| Future<Void> | ThriftAdmin. modifyTableAsync(TableName tableName,
                TableDescriptor td) | 
| Modifier and Type | Method and Description | 
|---|---|
| static String | MasterStatusTmplImpl. getUserTables(HMaster master,
             List<TableDescriptor> tables) | 
| Modifier and Type | Method and Description | 
|---|---|
| private static List<Future<Void>> | CanaryTool. sniff(Admin admin,
     CanaryTool.Sink sink,
     TableDescriptor tableDesc,
     ExecutorService executor,
     CanaryTool.RegionTask.TaskType taskType,
     boolean rawScanEnabled,
     LongAdder rwLatency) | 
| Modifier and Type | Field and Description | 
|---|---|
| private TableDescriptor | FSTableDescriptors. metaTableDescriptorTable descriptor for  hbase:metacatalog table | 
| Modifier and Type | Field and Description | 
|---|---|
| private Map<TableName,TableDescriptor> | FSTableDescriptors. cache | 
| (package private) Set<TableDescriptor> | HbckTableInfo. htds | 
| Modifier and Type | Method and Description | 
|---|---|
| static TableDescriptor | FSTableDescriptors. createMetaTableDescriptor(org.apache.hadoop.conf.Configuration conf) | 
| TableDescriptor | FSTableDescriptors. get(TableName tablename)Get the current table descriptor for the given table, or null if none exists. | 
| (package private) TableDescriptor | HbckTableInfo. getTableDescriptor() | 
| 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. | 
| private static TableDescriptor | FSTableDescriptors. readTableDescriptor(org.apache.hadoop.fs.FileSystem fs,
                   org.apache.hadoop.fs.FileStatus status) | 
| TableDescriptor | FSTableDescriptors. remove(TableName tablename)Removes the table descriptor from the local cache and returns it. | 
| Modifier and Type | Method and Description | 
|---|---|
| Map<String,TableDescriptor> | FSTableDescriptors. getAll()Returns a map from table name to table descriptor for all tables. | 
| Map<String,TableDescriptor> | FSTableDescriptors. getByNamespace(String name)Find descriptors by namespace. | 
| Modifier and Type | Method and Description | 
|---|---|
| void | FSTableDescriptors. add(TableDescriptor htd)Adds (or updates) the table descriptor to the FileSystem
 and updates the local cache with it. | 
| 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(TableDescriptor td) | 
| static void | TableDescriptorChecker. checkEncryption(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 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(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(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. | 
| boolean | FSTableDescriptors. createTableDescriptor(TableDescriptor htd)Create new TableDescriptor in HDFS. | 
| boolean | FSTableDescriptors. createTableDescriptor(TableDescriptor htd,
                     boolean forceCreation)Create new TableDescriptor in HDFS. | 
| 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. | 
| (package private) org.apache.hadoop.fs.Path | FSTableDescriptors. updateTableDescriptor(TableDescriptor td)Update table descriptor on the file system | 
| private static org.apache.hadoop.fs.Path | FSTableDescriptors. writeTableDescriptor(org.apache.hadoop.fs.FileSystem fs,
                    TableDescriptor htd,
                    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. | 
| private static void | FSTableDescriptors. writeTD(org.apache.hadoop.fs.FileSystem fs,
       org.apache.hadoop.fs.Path p,
       TableDescriptor htd) | 
Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.