| Modifier and Type | Field and Description | 
|---|---|
| static TableName | TableName. META_TABLE_NAMEThe hbase:meta table's name. | 
| static TableName | TableName. NAMESPACE_TABLE_NAMEThe Namespace table's name. | 
| static TableName | TableName. OLD_META_TABLE_NAMETableName for old .META. | 
| static TableName | TableName. OLD_ROOT_TABLE_NAMETableName for old -ROOT- table. | 
| Modifier and Type | Method and Description | 
|---|---|
| TableName | HRegionInfo. getTable()Get current table name of the region | 
| static TableName | HRegionInfo. getTable(byte[] regionName)Gets the table name from the specified region name. | 
| TableName | HTableDescriptor. getTableName()Get the name of the table | 
| static TableName | TableName. valueOf(byte[] fullName) | 
| static TableName | TableName. valueOf(byte[] namespace,
       byte[] qualifier) | 
| static TableName | TableName. valueOf(ByteBuffer namespace,
       ByteBuffer qualifier) | 
| static TableName | TableName. valueOf(String name) | 
| static TableName | TableName. valueOf(String namespaceAsString,
       String qualifierAsString) | 
| Modifier and Type | Method and Description | 
|---|---|
| Set<TableName> | TableStateManager. getTablesInStates(org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Table.State... states) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | TableStateManager. checkAndRemoveTableState(TableName tableName,
                        org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Table.State states,
                        boolean deletePermanentState)If the table is found in the given state the in-memory state is removed. | 
| int | TableName. compareTo(TableName tableName)For performance reasons, the ordering is not lexicographic. | 
| static byte[] | HRegionInfo. createRegionName(TableName tableName,
                byte[] startKey,
                byte[] id,
                boolean newFormat)Make a region name of passed parameters. | 
| static byte[] | HRegionInfo. createRegionName(TableName tableName,
                byte[] startKey,
                byte[] id,
                int replicaId,
                boolean newFormat)Make a region name of passed parameters. | 
| static byte[] | HRegionInfo. createRegionName(TableName tableName,
                byte[] startKey,
                long regionid,
                boolean newFormat)Make a region name of passed parameters. | 
| static byte[] | HRegionInfo. createRegionName(TableName tableName,
                byte[] startKey,
                long regionid,
                int replicaId,
                boolean newFormat)Make a region name of passed parameters. | 
| static byte[] | HRegionInfo. createRegionName(TableName tableName,
                byte[] startKey,
                String id,
                boolean newFormat)Make a region name of passed parameters. | 
| HTableDescriptor | TableDescriptors. get(TableName tableName) | 
| long | ClusterStatus. getLastMajorCompactionTsForTable(TableName table) | 
| static int | MetaTableAccessor. getRegionCount(org.apache.hadoop.conf.Configuration c,
              TableName tableName)Count regions in  hbase:metafor passed table. | 
| static int | MetaTableAccessor. getRegionCount(Connection connection,
              TableName tableName)Count regions in  hbase:metafor passed table. | 
| static Scan | MetaTableAccessor. getScanForTableName(TableName tableName)This method creates a Scan object that will only scan catalog rows that
 belong to the specified table. | 
| HTableInterface | CoprocessorEnvironment. getTable(TableName tableName) | 
| HTableInterface | CoprocessorEnvironment. getTable(TableName tableName,
        ExecutorService service) | 
| static List<HRegionInfo> | MetaTableAccessor. getTableRegions(ZooKeeperWatcher zkw,
               Connection connection,
               TableName tableName)Gets all of the regions of the specified table. | 
| static List<HRegionInfo> | MetaTableAccessor. getTableRegions(ZooKeeperWatcher zkw,
               Connection connection,
               TableName tableName,
               boolean excludeOfflinedSplitParents)Gets all of the regions of the specified table. | 
| static List<HRegionInfo> | MetaTableAccessor. getTableRegions(ZooKeeperWatcher zkw,
               Connection connection,
               TableName tableName,
               boolean excludeOfflinedSplitParents,
               boolean excludeReplicaRegions)Gets all of the regions of the specified table. | 
| static List<Pair<HRegionInfo,ServerName>> | MetaTableAccessor. getTableRegionsAndLocations(ZooKeeperWatcher zkw,
                           Connection connection,
                           TableName tableName) | 
| static List<Pair<HRegionInfo,ServerName>> | MetaTableAccessor. getTableRegionsAndLocations(ZooKeeperWatcher zkw,
                           Connection connection,
                           TableName tableName,
                           boolean excludeOfflinedSplitParents) | 
| static List<Pair<HRegionInfo,ServerName>> | MetaTableAccessor. getTableRegionsAndLocations(ZooKeeperWatcher zkw,
                           Connection connection,
                           TableName tableName,
                           boolean excludeOfflinedSplitParents,
                           boolean excludeReplicaRegions) | 
| boolean | TableStateManager. isTablePresent(TableName tableName)Checks if table is present. | 
| boolean | TableStateManager. isTableState(TableName tableName,
            boolean checkSource,
            org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Table.State... states) | 
| boolean | TableStateManager. isTableState(TableName tableName,
            org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Table.State... states) | 
| HTableDescriptor | TableDescriptors. remove(TableName tablename) | 
| void | TableStateManager. setDeletedTable(TableName tableName)Mark table as deleted. | 
| HTableDescriptor | HTableDescriptor. setName(TableName name)Deprecated.  | 
| void | TableStateManager. setTableState(TableName tableName,
             org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Table.State state)Sets the table into desired state. | 
| boolean | TableStateManager. setTableStateIfInStates(TableName tableName,
                       org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Table.State newState,
                       org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Table.State... states)Sets the specified table into the newState, but only if the table is already in
 one of the possibleCurrentStates (otherwise no operation is performed). | 
| boolean | TableStateManager. setTableStateIfNotInStates(TableName tableName,
                          org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Table.State newState,
                          org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Table.State... states)Sets the specified table into the newState, but only if the table is NOT in
 one of the possibleCurrentStates (otherwise no operation is performed). | 
| static boolean | MetaTableAccessor. tableExists(Connection connection,
           TableName tableName)Checks if the specified table exists. | 
| Constructor and Description | 
|---|
| HRegionInfo(long regionId,
           TableName tableName,
           int replicaId) | 
| HRegionInfo(TableName tableName) | 
| HRegionInfo(TableName tableName,
           byte[] startKey,
           byte[] endKey)Construct HRegionInfo with explicit parameters | 
| HRegionInfo(TableName tableName,
           byte[] startKey,
           byte[] endKey,
           boolean split)Construct HRegionInfo with explicit parameters | 
| HRegionInfo(TableName tableName,
           byte[] startKey,
           byte[] endKey,
           boolean split,
           long regionid)Construct HRegionInfo with explicit parameters | 
| HRegionInfo(TableName tableName,
           byte[] startKey,
           byte[] endKey,
           boolean split,
           long regionid,
           int replicaId)Construct HRegionInfo with explicit parameters | 
| HTableDescriptor(TableName name)Construct a table descriptor specifying a TableName object | 
| HTableDescriptor(TableName name,
                HColumnDescriptor[] families) INTERNAL  Private constructor used internally creating table descriptors for
 catalog tables,  hbase:metaand-ROOT-. | 
| HTableDescriptor(TableName name,
                HColumnDescriptor[] families,
                Map<ImmutableBytesWritable,ImmutableBytesWritable> values) INTERNAL Private constructor used internally creating table descriptors for
 catalog tables,  hbase:metaand-ROOT-. | 
| HTableDescriptor(TableName name,
                HTableDescriptor desc)Construct a table descriptor by cloning the descriptor passed as a parameter
 but using a different table name. | 
| TableExistsException(TableName tableName) | 
| TableNotDisabledException(TableName tableName) | 
| TableNotEnabledException(TableName tableName) | 
| TableNotFoundException(TableName tableName) | 
| Modifier and Type | Field and Description | 
|---|---|
| protected TableName | RegionAdminServiceCallable. tableName | 
| protected TableName | RpcRetryingCallerWithReadReplicas. tableName | 
| protected TableName | RegionServerCallable. tableName | 
| Modifier and Type | Method and Description | 
|---|---|
| TableName | HTableWrapper. getName() | 
| TableName | BufferedMutatorImpl. getName() | 
| TableName | Table. getName()Gets the fully qualified table name instance of this table. | 
| TableName | HRegionLocator. getName() | 
| TableName | BufferedMutator. getName()Gets the fully qualified table name instance of the table that this BufferedMutator writes to. | 
| TableName | HTable. getName() | 
| TableName | RegionLocator. getName()Gets the fully qualified table name instance of this table. | 
| protected TableName | ClientScanner. getTable() | 
| TableName | BufferedMutatorParams. getTableName() | 
| TableName | RegionServerCallable. getTableName() | 
| TableName[] | Admin. listTableNames()List all of the names of userspace tables. | 
| TableName[] | HConnection. listTableNames()Deprecated. 
 Use  Admin.listTables()instead. | 
| TableName[] | HBaseAdmin. listTableNames() | 
| TableName[] | Admin. listTableNames(Pattern pattern)List all of the names of userspace tables. | 
| TableName[] | HBaseAdmin. listTableNames(Pattern pattern) | 
| TableName[] | Admin. listTableNames(Pattern pattern,
              boolean includeSysTables)List all of the names of userspace tables. | 
| TableName[] | HBaseAdmin. listTableNames(Pattern pattern,
              boolean includeSysTables) | 
| TableName[] | Admin. listTableNames(String regex)List all of the names of userspace tables. | 
| TableName[] | HBaseAdmin. listTableNames(String regex) | 
| TableName[] | Admin. listTableNames(String regex,
              boolean includeSysTables)List all of the names of userspace tables. | 
| TableName[] | HBaseAdmin. listTableNames(String regex,
              boolean includeSysTables) | 
| TableName[] | Admin. listTableNamesByNamespace(String name)Get list of table names by namespace | 
| TableName[] | HBaseAdmin. listTableNamesByNamespace(String name)Get list of table names by namespace | 
| Modifier and Type | Method and Description | 
|---|---|
| void | Admin. addColumn(TableName tableName,
         HColumnDescriptor column)Add a column to an existing table. | 
| void | HBaseAdmin. addColumn(TableName tableName,
         HColumnDescriptor column)Add a column to an existing table. | 
| static NavigableMap<HRegionInfo,ServerName> | MetaScanner. allTableRegions(org.apache.hadoop.conf.Configuration conf,
               Connection connection,
               TableName tableName,
               boolean offlined)Deprecated. 
 | 
| static NavigableMap<HRegionInfo,ServerName> | MetaScanner. allTableRegions(Connection connection,
               TableName tableName)Lists all of the table regions currently in META. | 
| void | MetaCache. cacheLocation(TableName tableName,
             RegionLocations locations)Put a newly discovered HRegionLocation into the cache. | 
| void | ClusterConnection. cacheLocation(TableName tableName,
             RegionLocations location) | 
| void | MetaCache. cacheLocation(TableName tableName,
             ServerName source,
             HRegionLocation location)Put a newly discovered HRegionLocation into the cache. | 
| void | MetaCache. clearCache(TableName tableName)Delete all cached entries of a table. | 
| void | MetaCache. clearCache(TableName tableName,
          byte[] row)Delete a cached location, no matter what it is. | 
| void | MetaCache. clearCache(TableName tableName,
          byte[] row,
          int replicaId)Delete a cached location with specific replicaId. | 
| void | MetaCache. clearCache(TableName tableName,
          byte[] row,
          ServerName serverName)Delete a cached location for a table, row and server | 
| void | ClusterConnection. clearRegionCache(TableName tableName)Allows flushing the region cache of all locations that pertain to
  tableName | 
| void | HConnection. clearRegionCache(TableName tableName)Deprecated. 
 internal method, do not use thru HConnection | 
| void | Admin. cloneSnapshot(byte[] snapshotName,
             TableName tableName)Create a new table by cloning the snapshot content. | 
| void | HBaseAdmin. cloneSnapshot(byte[] snapshotName,
             TableName tableName)Create a new table by cloning the snapshot content. | 
| void | Admin. cloneSnapshot(String snapshotName,
             TableName tableName)Create a new table by cloning the snapshot content. | 
| void | HBaseAdmin. cloneSnapshot(String snapshotName,
             TableName tableName) | 
| void | Admin. cloneSnapshot(String snapshotName,
             TableName tableName,
             boolean restoreAcl)Create a new table by cloning the snapshot content. | 
| void | HBaseAdmin. cloneSnapshot(String snapshotName,
             TableName tableName,
             boolean restoreAcl)Create a new table by cloning the snapshot content. | 
| void | Admin. compact(TableName tableName)Compact a table. | 
| void | HBaseAdmin. compact(TableName tableName)Compact a table. | 
| void | Admin. compact(TableName tableName,
       byte[] columnFamily)Compact a column family within a table. | 
| void | HBaseAdmin. compact(TableName tableName,
       byte[] columnFamily)Compact a column family within a table. | 
| static HTableInterface | HTableWrapper. createWrapper(List<HTableInterface> openTables,
             TableName tableName,
             CoprocessorHost.Environment env,
             ExecutorService pool) | 
| void | Admin. deleteColumn(TableName tableName,
            byte[] columnName)Delete a column from a table. | 
| void | HBaseAdmin. deleteColumn(TableName tableName,
            byte[] columnName)Delete a column from a table. | 
| void | Admin. deleteTable(TableName tableName)Deletes a table. | 
| void | HBaseAdmin. deleteTable(TableName tableName)Deletes a table. | 
| void | Admin. disableTable(TableName tableName)Disable table and wait on completion. | 
| void | HBaseAdmin. disableTable(TableName tableName)Disable table and wait on completion. | 
| void | Admin. disableTableAsync(TableName tableName)Starts the disable of a table. | 
| void | HBaseAdmin. disableTableAsync(TableName tableName)Starts the disable of a table. | 
| void | Admin. enableTable(TableName tableName)Enable a table. | 
| void | HBaseAdmin. enableTable(TableName tableName)Enable a table. | 
| void | Admin. enableTableAsync(TableName tableName)Brings a table on-line (enables it). | 
| void | HBaseAdmin. enableTableAsync(TableName tableName)Brings a table on-line (enables it). | 
| void | Admin. flush(TableName tableName)Flush a table. | 
| void | HBaseAdmin. flush(TableName tableName)Flush a table. | 
| Pair<Integer,Integer> | Admin. getAlterStatus(TableName tableName)Get the status of alter command - indicates how many regions have received the updated schema
 Asynchronous operation. | 
| Pair<Integer,Integer> | HBaseAdmin. getAlterStatus(TableName tableName)Get the status of alter command - indicates how many regions have received
 the updated schema Asynchronous operation. | 
| BufferedMutator | Connection. getBufferedMutator(TableName tableName)
 Retrieve a  BufferedMutatorfor performing client-side buffering of writes. | 
| RegionLocations | MetaCache. getCachedLocation(TableName tableName,
                 byte[] row)Search the cache for a location that fits our table and row key. | 
| org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse.CompactionState | Admin. getCompactionState(TableName tableName)Get the current compaction state of a table. | 
| org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse.CompactionState | HBaseAdmin. getCompactionState(TableName tableName)Get the current compaction state of a table. | 
| HTableDescriptor | HConnection. getHTableDescriptor(TableName tableName)Deprecated.  | 
| long | Admin. getLastMajorCompactionTimestamp(TableName tableName)Get the timestamp of the last major compaction for the passed table
 The timestamp of the oldest HFile resulting from a major compaction of that table,
 or 0 if no such HFile could be found. | 
| long | HBaseAdmin. getLastMajorCompactionTimestamp(TableName tableName) | 
| int | MetaCache. getNumberOfCachedRegionLocations(TableName tableName)Return the number of cached region for a table. | 
| static boolean | HTable. getRegionCachePrefetch(org.apache.hadoop.conf.Configuration conf,
                      TableName tableName)Deprecated. 
 always return false since 0.99 | 
| boolean | HConnection. getRegionCachePrefetch(TableName tableName)Deprecated. 
 always return false since 0.99 | 
| static boolean | HTable. getRegionCachePrefetch(TableName tableName)Deprecated. 
 always return false since 0.99 | 
| HRegionLocation | ClusterConnection. getRegionLocation(TableName tableName,
                 byte[] row,
                 boolean reload)Find region location hosting passed row | 
| HRegionLocation | HConnection. getRegionLocation(TableName tableName,
                 byte[] row,
                 boolean reload)Deprecated. 
 internal method, do not use thru HConnection | 
| static RegionLocations | RegionAdminServiceCallable. getRegionLocations(ClusterConnection connection,
                  TableName tableName,
                  byte[] row,
                  boolean useCache,
                  int replicaId) | 
| RegionLocator | Connection. getRegionLocator(TableName tableName)Retrieve a RegionLocator implementation to inspect region information on a table. | 
| RegionLocator | HConnection. getRegionLocator(TableName tableName)Deprecated.  Retrieve a RegionLocator implementation to inspect region information on a table. | 
| Table | Connection. getTable(TableName tableName)Retrieve a Table implementation for accessing a table. | 
| HTableInterface | HConnection. getTable(TableName tableName)Deprecated.  Retrieve an HTableInterface implementation for access to a table. | 
| Table | Connection. getTable(TableName tableName,
        ExecutorService pool)Retrieve a Table implementation for accessing a table. | 
| HTableInterface | HConnection. getTable(TableName tableName,
        ExecutorService pool)Deprecated.  Retrieve an HTableInterface implementation for access to a table. | 
| HTableDescriptor | Admin. getTableDescriptor(TableName tableName)Method for getting the tableDescriptor | 
| HTableDescriptor | HBaseAdmin. getTableDescriptor(TableName tableName)Method for getting the tableDescriptor | 
| List<HRegionInfo> | Admin. getTableRegions(TableName tableName)Get the regions of a given table. | 
| List<HRegionInfo> | HBaseAdmin. getTableRegions(TableName tableName)get the regions of a given table. | 
| boolean | MetaCache. isRegionCached(TableName tableName,
              byte[] row)Check the region cache to see whether a region is cached yet or not. | 
| boolean | Admin. isTableAvailable(TableName tableName) | 
| boolean | HConnection. isTableAvailable(TableName tableName)Deprecated.  | 
| boolean | HBaseAdmin. isTableAvailable(TableName tableName) | 
| boolean | Admin. isTableAvailable(TableName tableName,
                byte[][] splitKeys)Use this api to check if the table has been created with the specified number of splitkeys
 which was used while creating the given table. | 
| boolean | ClusterConnection. isTableAvailable(TableName tableName,
                byte[][] splitKeys)Use this api to check if the table has been created with the specified number of
 splitkeys which was used while creating the given table. | 
| boolean | HConnection. isTableAvailable(TableName tableName,
                byte[][] splitKeys)Deprecated. 
 internal method, do not use thru HConnection | 
| boolean | HBaseAdmin. isTableAvailable(TableName tableName,
                byte[][] splitKeys)Use this api to check if the table has been created with the specified number of
 splitkeys which was used while creating the given table. | 
| boolean | Admin. isTableDisabled(TableName tableName) | 
| boolean | HConnection. isTableDisabled(TableName tableName)Deprecated.  | 
| boolean | HBaseAdmin. isTableDisabled(TableName tableName) | 
| static boolean | HTable. isTableEnabled(org.apache.hadoop.conf.Configuration conf,
              TableName tableName) | 
| boolean | Admin. isTableEnabled(TableName tableName) | 
| boolean | HConnection. isTableEnabled(TableName tableName)Deprecated.  A table that isTableEnabled == false and isTableDisabled == false
 is possible. | 
| static boolean | HTable. isTableEnabled(TableName tableName)Deprecated. 
 | 
| boolean | HBaseAdmin. isTableEnabled(TableName tableName) | 
| static List<RegionLocations> | MetaScanner. listTableRegionLocations(org.apache.hadoop.conf.Configuration conf,
                        Connection connection,
                        TableName tableName)Lists table regions and locations grouped by region range from META. | 
| HRegionLocation | ClusterConnection. locateRegion(TableName tableName,
            byte[] row)Find the location of the region of tableName that row
 lives in. | 
| HRegionLocation | HConnection. locateRegion(TableName tableName,
            byte[] row)Deprecated. 
 internal method, do not use thru HConnection | 
| RegionLocations | ClusterConnection. locateRegion(TableName tableName,
            byte[] row,
            boolean useCache,
            boolean retry) | 
| RegionLocations | ClusterConnection. locateRegion(TableName tableName,
            byte[] row,
            boolean useCache,
            boolean retry,
            int replicaId) | 
| List<HRegionLocation> | ClusterConnection. locateRegions(TableName tableName)Gets the locations of all regions in the specified table, tableName. | 
| List<HRegionLocation> | HConnection. locateRegions(TableName tableName)Deprecated. 
 internal method, do not use thru HConnection | 
| List<HRegionLocation> | ClusterConnection. locateRegions(TableName tableName,
             boolean useCache,
             boolean offlined)Gets the locations of all regions in the specified table, tableName. | 
| List<HRegionLocation> | HConnection. locateRegions(TableName tableName,
             boolean useCache,
             boolean offlined)Deprecated. 
 internal method, do not use thru HConnection | 
| void | Admin. majorCompact(TableName tableName)Major compact a table. | 
| void | HBaseAdmin. majorCompact(TableName tableName)Major compact a table. | 
| void | Admin. majorCompact(TableName tableName,
            byte[] columnFamily)Major compact a column family within a table. | 
| void | HBaseAdmin. majorCompact(TableName tableName,
            byte[] columnFamily)Major compact a column family within a table. | 
| static void | MetaScanner. metaScan(Connection connection,
        MetaScanner.MetaScannerVisitor visitor,
        TableName userTableName)Scans the meta table and calls a visitor on each RowResult. | 
| static void | MetaScanner. metaScan(Connection connection,
        MetaScanner.MetaScannerVisitor visitor,
        TableName userTableName,
        byte[] row,
        int rowLimit)Scans the meta table and calls a visitor on each RowResult. | 
| void | Admin. modifyColumn(TableName tableName,
            HColumnDescriptor descriptor)Modify an existing column family on a table. | 
| void | HBaseAdmin. modifyColumn(TableName tableName,
            HColumnDescriptor descriptor)Modify an existing column family on a table. | 
| void | Admin. modifyTable(TableName tableName,
           HTableDescriptor htd)Modify an existing table, more IRB friendly version. | 
| void | HBaseAdmin. modifyTable(TableName tableName,
           HTableDescriptor htd)Modify an existing table, more IRB friendly version. | 
| void | HConnection. processBatch(List<? extends Row> actions,
            TableName tableName,
            ExecutorService pool,
            Object[] results)Deprecated. 
 since 0.96 - Use  Table.batch(java.util.List<? extends org.apache.hadoop.hbase.client.Row>, java.lang.Object[])instead | 
| <R> void | HConnection. processBatchCallback(List<? extends Row> list,
                    TableName tableName,
                    ExecutorService pool,
                    Object[] results,
                    Batch.Callback<R> callback) | 
| List<Put> | HTableMultiplexer. put(TableName tableName,
   List<Put> puts)The puts request will be buffered by their corresponding buffer queue. | 
| boolean | HTableMultiplexer. put(TableName tableName,
   Put put)The put request will be buffered by its corresponding buffer queue. | 
| boolean | HTableMultiplexer. put(TableName tableName,
   Put put,
   int maxAttempts)The put request will be buffered by its corresponding buffer queue. | 
| HRegionLocation | ClusterConnection. relocateRegion(TableName tableName,
              byte[] row)Find the location of the region of tableName that row
 lives in, ignoring any value that might be in the cache. | 
| HRegionLocation | HConnection. relocateRegion(TableName tableName,
              byte[] row)Deprecated. 
 internal method, do not use thru HConnection | 
| RegionLocations | ClusterConnection. relocateRegion(TableName tableName,
              byte[] row,
              int replicaId)Find the location of the region of tableName that row
 lives in, ignoring any value that might be in the cache. | 
| static void | HTable. setRegionCachePrefetch(org.apache.hadoop.conf.Configuration conf,
                      TableName tableName,
                      boolean enable)Deprecated. 
 does nothing since 0.99 | 
| void | HConnection. setRegionCachePrefetch(TableName tableName,
                      boolean enable)Deprecated. 
 does nothing since since 0.99 | 
| static void | HTable. setRegionCachePrefetch(TableName tableName,
                      boolean enable)Deprecated. 
 does nothing since 0.99 | 
| void | Admin. snapshot(byte[] snapshotName,
        TableName tableName)public void snapshot(final String snapshotName, Create a timestamp consistent snapshot for the
 given table. | 
| void | HBaseAdmin. snapshot(byte[] snapshotName,
        TableName tableName)public void snapshot(final String snapshotName,
 Create a timestamp consistent snapshot for the given table. | 
| void | Admin. snapshot(String snapshotName,
        TableName tableName)Take a snapshot for the given table. | 
| void | HBaseAdmin. snapshot(String snapshotName,
        TableName tableName)Take a snapshot for the given table. | 
| void | Admin. snapshot(String snapshotName,
        TableName tableName,
        org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Type type)Deprecated.  | 
| void | HBaseAdmin. snapshot(String snapshotName,
        TableName tableName,
        org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Type type)Create typed snapshot of the table. | 
| void | Admin. split(TableName tableName)Split a table. | 
| void | HBaseAdmin. split(TableName tableName)Split a table. | 
| void | Admin. split(TableName tableName,
     byte[] splitPoint)Split a table. | 
| void | HBaseAdmin. split(TableName tableName,
     byte[] splitPoint)Split a table. | 
| boolean | Admin. tableExists(TableName tableName) | 
| boolean | HBaseAdmin. tableExists(TableName tableName) | 
| void | Admin. truncateTable(TableName tableName,
             boolean preserveSplits)Truncate a table. | 
| void | HBaseAdmin. truncateTable(TableName tableName,
             boolean preserveSplits)Truncate a table. | 
| void | ClusterConnection. updateCachedLocations(TableName tableName,
                     byte[] regionName,
                     byte[] rowkey,
                     Object exception,
                     ServerName source)Update the location cache. | 
| void | HConnection. updateCachedLocations(TableName tableName,
                     byte[] regionName,
                     byte[] rowkey,
                     Object exception,
                     ServerName source)Deprecated. 
 internal method, do not use thru HConnection | 
| void | HConnection. updateCachedLocations(TableName tableName,
                     byte[] rowkey,
                     Object exception,
                     HRegionLocation source)Deprecated.  | 
| Modifier and Type | Method and Description | 
|---|---|
| HTableDescriptor[] | HConnection. getHTableDescriptorsByTableName(List<TableName> tableNames)Deprecated. 
 Use  Admin.getTableDescriptor(TableName)instead. | 
| HTableDescriptor[] | Admin. getTableDescriptorsByTableName(List<TableName> tableNames)Get tableDescriptors | 
| HTableDescriptor[] | HBaseAdmin. getTableDescriptorsByTableName(List<TableName> tableNames)Get tableDescriptors | 
| Constructor and Description | 
|---|
| BufferedMutatorParams(TableName tableName) | 
| ClientScanner(org.apache.hadoop.conf.Configuration conf,
             Scan scan,
             TableName tableName,
             ClusterConnection connection,
             RpcRetryingCallerFactory rpcFactory,
             RpcControllerFactory controllerFactory,
             ExecutorService pool,
             int primaryOperationTimeout)Create a new ClientScanner for the specified table Note that the passed  Scan's start
 row maybe changed changed. | 
| ClientSimpleScanner(org.apache.hadoop.conf.Configuration configuration,
                   Scan scan,
                   TableName name,
                   ClusterConnection connection,
                   RpcRetryingCallerFactory rpcCallerFactory,
                   RpcControllerFactory rpcControllerFactory,
                   ExecutorService pool,
                   int replicaCallTimeoutMicroSecondScan) | 
| FlushRegionCallable(ClusterConnection connection,
                   RpcControllerFactory rpcControllerFactory,
                   TableName tableName,
                   byte[] regionName,
                   byte[] regionStartKey,
                   boolean writeFlushWalMarker) | 
| HRegionLocator(TableName tableName,
              ClusterConnection connection) | 
| HTable(org.apache.hadoop.conf.Configuration conf,
      TableName tableName)Deprecated. 
 Constructing HTable objects manually has been deprecated. Please use
  Connectionto instantiate aTableinstead. | 
| HTable(org.apache.hadoop.conf.Configuration conf,
      TableName tableName,
      ExecutorService pool)Deprecated. 
 Constructing HTable objects manually has been deprecated. Please use
  Connectionto instantiate aTableinstead. | 
| HTable(TableName tableName,
      ClusterConnection connection,
      ConnectionConfiguration tableConfig,
      RpcRetryingCallerFactory rpcCallerFactory,
      RpcControllerFactory rpcControllerFactory,
      ExecutorService pool)Creates an object to access a HBase table. | 
| HTable(TableName tableName,
      Connection connection)Deprecated. 
 Do not use. | 
| HTable(TableName tableName,
      Connection connection,
      ExecutorService pool)Deprecated. 
 Do not use, internal ctor. | 
| MetaScanner.TableMetaScannerVisitor(TableName tableName) | 
| PayloadCarryingServerCallable(Connection connection,
                             TableName tableName,
                             byte[] row,
                             RpcControllerFactory rpcControllerFactory) | 
| PayloadCarryingServerCallable(Connection connection,
                             TableName tableName,
                             byte[] row,
                             RpcControllerFactory rpcControllerFactory,
                             int priority) | 
| RegionAdminServiceCallable(ClusterConnection connection,
                          RpcControllerFactory rpcControllerFactory,
                          HRegionLocation location,
                          TableName tableName,
                          byte[] row) | 
| RegionAdminServiceCallable(ClusterConnection connection,
                          RpcControllerFactory rpcControllerFactory,
                          HRegionLocation location,
                          TableName tableName,
                          byte[] row,
                          int replicaId) | 
| RegionAdminServiceCallable(ClusterConnection connection,
                          RpcControllerFactory rpcControllerFactory,
                          TableName tableName,
                          byte[] row) | 
| RegionServerCallable(Connection connection,
                    TableName tableName,
                    byte[] row) | 
| RegionServerCallable(Connection connection,
                    TableName tableName,
                    byte[] row,
                    int priority) | 
| ReversedClientScanner(org.apache.hadoop.conf.Configuration conf,
                     Scan scan,
                     TableName tableName,
                     ClusterConnection connection,
                     RpcRetryingCallerFactory rpcFactory,
                     RpcControllerFactory controllerFactory,
                     ExecutorService pool,
                     int primaryOperationTimeout)Create a new ReversibleClientScanner for the specified table Note that the passed
  Scan's start row maybe changed. | 
| ReversedScannerCallable(ClusterConnection connection,
                       TableName tableName,
                       Scan scan,
                       ScanMetrics scanMetrics,
                       RpcControllerFactory rpcFactory) | 
| ReversedScannerCallable(ClusterConnection connection,
                       TableName tableName,
                       Scan scan,
                       ScanMetrics scanMetrics,
                       RpcControllerFactory rpcFactory,
                       int replicaId) | 
| RpcRetryingCallerWithReadReplicas(RpcControllerFactory rpcControllerFactory,
                                 TableName tableName,
                                 ClusterConnection cConnection,
                                 Get get,
                                 ExecutorService pool,
                                 int retries,
                                 int callTimeout,
                                 int timeBeforeReplicas) | 
| ScannerCallable(ClusterConnection connection,
               TableName tableName,
               Scan scan,
               ScanMetrics scanMetrics,
               RpcControllerFactory rpcControllerFactory) | 
| ScannerCallable(ClusterConnection connection,
               TableName tableName,
               Scan scan,
               ScanMetrics scanMetrics,
               RpcControllerFactory rpcControllerFactory,
               int id) | 
| Modifier and Type | Method and Description | 
|---|---|
| <R,S,P extends com.google.protobuf.Message,Q extends com.google.protobuf.Message,T extends com.google.protobuf.Message>  | AggregationClient. avg(TableName tableName,
   ColumnInterpreter<R,S,P,Q,T> ci,
   Scan scan)This is the client side interface/handle for calling the average method for
 a given cf-cq combination. | 
| <R,S,P extends com.google.protobuf.Message,Q extends com.google.protobuf.Message,T extends com.google.protobuf.Message>  | AggregationClient. max(TableName tableName,
   ColumnInterpreter<R,S,P,Q,T> ci,
   Scan scan)It gives the maximum value of a column for a given column family for the
 given range. | 
| <R,S,P extends com.google.protobuf.Message,Q extends com.google.protobuf.Message,T extends com.google.protobuf.Message>  | AggregationClient. median(TableName tableName,
      ColumnInterpreter<R,S,P,Q,T> ci,
      Scan scan)This is the client side interface/handler for calling the median method for a
 given cf-cq combination. | 
| <R,S,P extends com.google.protobuf.Message,Q extends com.google.protobuf.Message,T extends com.google.protobuf.Message>  | AggregationClient. min(TableName tableName,
   ColumnInterpreter<R,S,P,Q,T> ci,
   Scan scan)It gives the minimum value of a column for a given column family for the
 given range. | 
| String | SecureBulkLoadClient. prepareBulkLoad(TableName tableName) | 
| <R,S,P extends com.google.protobuf.Message,Q extends com.google.protobuf.Message,T extends com.google.protobuf.Message>  | AggregationClient. rowCount(TableName tableName,
        ColumnInterpreter<R,S,P,Q,T> ci,
        Scan scan)It gives the row count, by summing up the individual results obtained from
 regions. | 
| <R,S,P extends com.google.protobuf.Message,Q extends com.google.protobuf.Message,T extends com.google.protobuf.Message>  | AggregationClient. std(TableName tableName,
   ColumnInterpreter<R,S,P,Q,T> ci,
   Scan scan)This is the client side interface/handle for calling the std method for a
 given cf-cq combination. | 
| <R,S,P extends com.google.protobuf.Message,Q extends com.google.protobuf.Message,T extends com.google.protobuf.Message>  | AggregationClient. sum(TableName tableName,
   ColumnInterpreter<R,S,P,Q,T> ci,
   Scan scan)It sums up the value returned from various regions. | 
| Modifier and Type | Method and Description | 
|---|---|
| void | RefreshHFilesClient. refreshHFiles(TableName tableName) | 
| Constructor and Description | 
|---|
| MultiThreadedClientExample.ReadExampleCallable(Connection connection,
                                              TableName tableName) | 
| MultiThreadedClientExample.SingleWriteExampleCallable(Connection connection,
                                                     TableName tableName) | 
| MultiThreadedClientExample.WriteExampleCallable(Connection connection,
                                               TableName tableName) | 
| Modifier and Type | Method and Description | 
|---|---|
| static Map<TableName,List<String>> | ReplicationAdmin. parseTableCFsFromConfig(String tableCFsConfig) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | ReplicationAdmin. disableTableRep(TableName tableName)Disable a table's replication switch. | 
| void | ReplicationAdmin. enableTableRep(TableName tableName)Enable a table's replication switch. | 
| Modifier and Type | Method and Description | 
|---|---|
| void | ReplicationAdmin. addPeer(String id,
       ReplicationPeerConfig peerConfig,
       Map<TableName,? extends Collection<String>> tableCfs)Add a new remote slave cluster for replication. | 
| void | ReplicationAdmin. appendPeerTableCFs(String id,
                  Map<TableName,? extends Collection<String>> tableCfs)Append the replicable table-cf config of the specified peer | 
| void | ReplicationAdmin. removePeerTableCFs(String id,
                  Map<TableName,? extends Collection<String>> tableCfs)Remove some table-cfs from config of the specified peer | 
| void | ReplicationAdmin. setPeerTableCFs(String id,
               Map<TableName,? extends Collection<String>> tableCfs)Set the replicable table-cf config of the specified peer | 
| Modifier and Type | Method and Description | 
|---|---|
| HTableInterface | CoprocessorHost.Environment. getTable(TableName tableName)Open a table from within the Coprocessor environment | 
| HTableInterface | CoprocessorHost.Environment. getTable(TableName tableName,
        ExecutorService pool)Open a table from within the Coprocessor environment | 
| void | BaseMasterAndRegionObserver. postAddColumn(ObserverContext<MasterCoprocessorEnvironment> ctx,
             TableName tableName,
             HColumnDescriptor column) | 
| void | MasterObserver. postAddColumn(ObserverContext<MasterCoprocessorEnvironment> ctx,
             TableName tableName,
             HColumnDescriptor column)Called after the new column family has been created. | 
| void | BaseMasterObserver. postAddColumn(ObserverContext<MasterCoprocessorEnvironment> ctx,
             TableName tableName,
             HColumnDescriptor column) | 
| void | BaseMasterAndRegionObserver. postAddColumnHandler(ObserverContext<MasterCoprocessorEnvironment> ctx,
                    TableName tableName,
                    HColumnDescriptor column) | 
| void | MasterObserver. postAddColumnHandler(ObserverContext<MasterCoprocessorEnvironment> ctx,
                    TableName tableName,
                    HColumnDescriptor column)Called after the new column family has been created. | 
| void | BaseMasterObserver. postAddColumnHandler(ObserverContext<MasterCoprocessorEnvironment> ctx,
                    TableName tableName,
                    HColumnDescriptor column) | 
| void | BaseMasterAndRegionObserver. postDeleteColumn(ObserverContext<MasterCoprocessorEnvironment> ctx,
                TableName tableName,
                byte[] c) | 
| void | MasterObserver. postDeleteColumn(ObserverContext<MasterCoprocessorEnvironment> ctx,
                TableName tableName,
                byte[] c)Called after the column family has been deleted. | 
| void | BaseMasterObserver. postDeleteColumn(ObserverContext<MasterCoprocessorEnvironment> ctx,
                TableName tableName,
                byte[] c) | 
| void | BaseMasterAndRegionObserver. postDeleteColumnHandler(ObserverContext<MasterCoprocessorEnvironment> ctx,
                       TableName tableName,
                       byte[] c) | 
| void | MasterObserver. postDeleteColumnHandler(ObserverContext<MasterCoprocessorEnvironment> ctx,
                       TableName tableName,
                       byte[] c)Called after the column family has been deleted. | 
| void | BaseMasterObserver. postDeleteColumnHandler(ObserverContext<MasterCoprocessorEnvironment> ctx,
                       TableName tableName,
                       byte[] c) | 
| void | BaseMasterAndRegionObserver. postDeleteTable(ObserverContext<MasterCoprocessorEnvironment> ctx,
               TableName tableName) | 
| void | MasterObserver. postDeleteTable(ObserverContext<MasterCoprocessorEnvironment> ctx,
               TableName tableName)Called after the deleteTable operation has been requested. | 
| void | BaseMasterObserver. postDeleteTable(ObserverContext<MasterCoprocessorEnvironment> ctx,
               TableName tableName) | 
| void | BaseMasterAndRegionObserver. postDeleteTableHandler(ObserverContext<MasterCoprocessorEnvironment> ctx,
                      TableName tableName) | 
| void | MasterObserver. postDeleteTableHandler(ObserverContext<MasterCoprocessorEnvironment> ctx,
                      TableName tableName)Called after  HMasterdeletes a
 table. | 
| void | BaseMasterObserver. postDeleteTableHandler(ObserverContext<MasterCoprocessorEnvironment> ctx,
                      TableName tableName) | 
| void | BaseMasterAndRegionObserver. postDisableTable(ObserverContext<MasterCoprocessorEnvironment> ctx,
                TableName tableName) | 
| void | MasterObserver. postDisableTable(ObserverContext<MasterCoprocessorEnvironment> ctx,
                TableName tableName)Called after the disableTable operation has been requested. | 
| void | BaseMasterObserver. postDisableTable(ObserverContext<MasterCoprocessorEnvironment> ctx,
                TableName tableName) | 
| void | BaseMasterAndRegionObserver. postDisableTableHandler(ObserverContext<MasterCoprocessorEnvironment> ctx,
                       TableName tableName) | 
| void | MasterObserver. postDisableTableHandler(ObserverContext<MasterCoprocessorEnvironment> ctx,
                       TableName tableName)Called after the disableTable operation has been requested. | 
| void | BaseMasterObserver. postDisableTableHandler(ObserverContext<MasterCoprocessorEnvironment> ctx,
                       TableName tableName) | 
| void | BaseMasterAndRegionObserver. postEnableTable(ObserverContext<MasterCoprocessorEnvironment> ctx,
               TableName tableName) | 
| void | MasterObserver. postEnableTable(ObserverContext<MasterCoprocessorEnvironment> ctx,
               TableName tableName)Called after the enableTable operation has been requested. | 
| void | BaseMasterObserver. postEnableTable(ObserverContext<MasterCoprocessorEnvironment> ctx,
               TableName tableName) | 
| void | BaseMasterAndRegionObserver. postEnableTableHandler(ObserverContext<MasterCoprocessorEnvironment> ctx,
                      TableName tableName) | 
| void | MasterObserver. postEnableTableHandler(ObserverContext<MasterCoprocessorEnvironment> ctx,
                      TableName tableName)Called after the enableTable operation has been requested. | 
| void | BaseMasterObserver. postEnableTableHandler(ObserverContext<MasterCoprocessorEnvironment> ctx,
                      TableName tableName) | 
| void | BaseMasterAndRegionObserver. postModifyColumn(ObserverContext<MasterCoprocessorEnvironment> ctx,
                TableName tableName,
                HColumnDescriptor descriptor) | 
| void | MasterObserver. postModifyColumn(ObserverContext<MasterCoprocessorEnvironment> ctx,
                TableName tableName,
                HColumnDescriptor descriptor)Called after the column family has been updated. | 
| void | BaseMasterObserver. postModifyColumn(ObserverContext<MasterCoprocessorEnvironment> ctx,
                TableName tableName,
                HColumnDescriptor descriptor) | 
| void | BaseMasterAndRegionObserver. postModifyColumnHandler(ObserverContext<MasterCoprocessorEnvironment> ctx,
                       TableName tableName,
                       HColumnDescriptor descriptor) | 
| void | MasterObserver. postModifyColumnHandler(ObserverContext<MasterCoprocessorEnvironment> ctx,
                       TableName tableName,
                       HColumnDescriptor descriptor)Called after the column family has been updated. | 
| void | BaseMasterObserver. postModifyColumnHandler(ObserverContext<MasterCoprocessorEnvironment> ctx,
                       TableName tableName,
                       HColumnDescriptor descriptor) | 
| void | BaseMasterAndRegionObserver. postModifyTable(ObserverContext<MasterCoprocessorEnvironment> ctx,
               TableName tableName,
               HTableDescriptor htd) | 
| void | MasterObserver. postModifyTable(ObserverContext<MasterCoprocessorEnvironment> ctx,
               TableName tableName,
               HTableDescriptor htd)Called after the modifyTable operation has been requested. | 
| void | BaseMasterObserver. postModifyTable(ObserverContext<MasterCoprocessorEnvironment> ctx,
               TableName tableName,
               HTableDescriptor htd) | 
| void | BaseMasterAndRegionObserver. postModifyTableHandler(ObserverContext<MasterCoprocessorEnvironment> ctx,
                      TableName tableName,
                      HTableDescriptor htd) | 
| void | MasterObserver. postModifyTableHandler(ObserverContext<MasterCoprocessorEnvironment> ctx,
                      TableName tableName,
                      HTableDescriptor htd)Called after to modifying a table's properties. | 
| void | BaseMasterObserver. postModifyTableHandler(ObserverContext<MasterCoprocessorEnvironment> ctx,
                      TableName tableName,
                      HTableDescriptor htd) | 
| void | BaseMasterAndRegionObserver. postSetTableQuota(ObserverContext<MasterCoprocessorEnvironment> ctx,
                 TableName tableName,
                 org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Quotas quotas) | 
| void | MasterObserver. postSetTableQuota(ObserverContext<MasterCoprocessorEnvironment> ctx,
                 TableName tableName,
                 org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Quotas quotas)Called after the quota for the table is stored. | 
| void | BaseMasterObserver. postSetTableQuota(ObserverContext<MasterCoprocessorEnvironment> ctx,
                 TableName tableName,
                 org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Quotas quotas) | 
| void | BaseMasterAndRegionObserver. postSetUserQuota(ObserverContext<MasterCoprocessorEnvironment> ctx,
                String userName,
                TableName tableName,
                org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Quotas quotas) | 
| void | MasterObserver. postSetUserQuota(ObserverContext<MasterCoprocessorEnvironment> ctx,
                String userName,
                TableName tableName,
                org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Quotas quotas)Called after the quota for the user on the specified table is stored. | 
| void | BaseMasterObserver. postSetUserQuota(ObserverContext<MasterCoprocessorEnvironment> ctx,
                String userName,
                TableName tableName,
                org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Quotas quotas) | 
| void | BaseMasterAndRegionObserver. postTableFlush(ObserverContext<MasterCoprocessorEnvironment> ctx,
              TableName tableName) | 
| void | MasterObserver. postTableFlush(ObserverContext<MasterCoprocessorEnvironment> ctx,
              TableName tableName)Called after the table memstore is flushed to disk. | 
| void | BaseMasterObserver. postTableFlush(ObserverContext<MasterCoprocessorEnvironment> ctx,
              TableName tableName) | 
| void | BaseMasterAndRegionObserver. postTruncateTable(ObserverContext<MasterCoprocessorEnvironment> ctx,
                 TableName tableName) | 
| void | MasterObserver. postTruncateTable(ObserverContext<MasterCoprocessorEnvironment> ctx,
                 TableName tableName)Called after the truncateTable operation has been requested. | 
| void | BaseMasterObserver. postTruncateTable(ObserverContext<MasterCoprocessorEnvironment> ctx,
                 TableName tableName) | 
| void | BaseMasterAndRegionObserver. postTruncateTableHandler(ObserverContext<MasterCoprocessorEnvironment> ctx,
                        TableName tableName) | 
| void | MasterObserver. postTruncateTableHandler(ObserverContext<MasterCoprocessorEnvironment> ctx,
                        TableName tableName)Called after  HMastertruncates a
 table. | 
| void | BaseMasterObserver. postTruncateTableHandler(ObserverContext<MasterCoprocessorEnvironment> ctx,
                        TableName tableName) | 
| void | BaseMasterAndRegionObserver. preAddColumn(ObserverContext<MasterCoprocessorEnvironment> ctx,
            TableName tableName,
            HColumnDescriptor column) | 
| void | MasterObserver. preAddColumn(ObserverContext<MasterCoprocessorEnvironment> ctx,
            TableName tableName,
            HColumnDescriptor column)Called prior to adding a new column family to the table. | 
| void | BaseMasterObserver. preAddColumn(ObserverContext<MasterCoprocessorEnvironment> ctx,
            TableName tableName,
            HColumnDescriptor column) | 
| void | BaseMasterAndRegionObserver. preAddColumnHandler(ObserverContext<MasterCoprocessorEnvironment> ctx,
                   TableName tableName,
                   HColumnDescriptor column) | 
| void | MasterObserver. preAddColumnHandler(ObserverContext<MasterCoprocessorEnvironment> ctx,
                   TableName tableName,
                   HColumnDescriptor column)Called prior to adding a new column family to the table. | 
| void | BaseMasterObserver. preAddColumnHandler(ObserverContext<MasterCoprocessorEnvironment> ctx,
                   TableName tableName,
                   HColumnDescriptor column) | 
| void | BaseMasterAndRegionObserver. preDeleteColumn(ObserverContext<MasterCoprocessorEnvironment> ctx,
               TableName tableName,
               byte[] c) | 
| void | MasterObserver. preDeleteColumn(ObserverContext<MasterCoprocessorEnvironment> ctx,
               TableName tableName,
               byte[] c)Called prior to deleting the entire column family. | 
| void | BaseMasterObserver. preDeleteColumn(ObserverContext<MasterCoprocessorEnvironment> ctx,
               TableName tableName,
               byte[] c) | 
| void | BaseMasterAndRegionObserver. preDeleteColumnHandler(ObserverContext<MasterCoprocessorEnvironment> ctx,
                      TableName tableName,
                      byte[] c) | 
| void | MasterObserver. preDeleteColumnHandler(ObserverContext<MasterCoprocessorEnvironment> ctx,
                      TableName tableName,
                      byte[] c)Called prior to deleting the entire column family. | 
| void | BaseMasterObserver. preDeleteColumnHandler(ObserverContext<MasterCoprocessorEnvironment> ctx,
                      TableName tableName,
                      byte[] c) | 
| void | BaseMasterAndRegionObserver. preDeleteTable(ObserverContext<MasterCoprocessorEnvironment> ctx,
              TableName tableName) | 
| void | MasterObserver. preDeleteTable(ObserverContext<MasterCoprocessorEnvironment> ctx,
              TableName tableName)Called before  HMasterdeletes a
 table. | 
| void | BaseMasterObserver. preDeleteTable(ObserverContext<MasterCoprocessorEnvironment> ctx,
              TableName tableName) | 
| void | BaseMasterAndRegionObserver. preDeleteTableHandler(ObserverContext<MasterCoprocessorEnvironment> ctx,
                     TableName tableName) | 
| void | MasterObserver. preDeleteTableHandler(ObserverContext<MasterCoprocessorEnvironment> ctx,
                     TableName tableName)Called before  HMasterdeletes a
 table. | 
| void | BaseMasterObserver. preDeleteTableHandler(ObserverContext<MasterCoprocessorEnvironment> ctx,
                     TableName tableName) | 
| void | BaseMasterAndRegionObserver. preDisableTable(ObserverContext<MasterCoprocessorEnvironment> ctx,
               TableName tableName) | 
| void | MasterObserver. preDisableTable(ObserverContext<MasterCoprocessorEnvironment> ctx,
               TableName tableName)Called prior to disabling a table. | 
| void | BaseMasterObserver. preDisableTable(ObserverContext<MasterCoprocessorEnvironment> ctx,
               TableName tableName) | 
| void | BaseMasterAndRegionObserver. preDisableTableHandler(ObserverContext<MasterCoprocessorEnvironment> ctx,
                      TableName tableName) | 
| void | MasterObserver. preDisableTableHandler(ObserverContext<MasterCoprocessorEnvironment> ctx,
                      TableName tableName)Called prior to disabling a table. | 
| void | BaseMasterObserver. preDisableTableHandler(ObserverContext<MasterCoprocessorEnvironment> ctx,
                      TableName tableName) | 
| void | BaseMasterAndRegionObserver. preEnableTable(ObserverContext<MasterCoprocessorEnvironment> ctx,
              TableName tableName) | 
| void | MasterObserver. preEnableTable(ObserverContext<MasterCoprocessorEnvironment> ctx,
              TableName tableName)Called prior to enabling a table. | 
| void | BaseMasterObserver. preEnableTable(ObserverContext<MasterCoprocessorEnvironment> ctx,
              TableName tableName) | 
| void | BaseMasterAndRegionObserver. preEnableTableHandler(ObserverContext<MasterCoprocessorEnvironment> ctx,
                     TableName tableName) | 
| void | MasterObserver. preEnableTableHandler(ObserverContext<MasterCoprocessorEnvironment> ctx,
                     TableName tableName)Called prior to enabling a table. | 
| void | BaseMasterObserver. preEnableTableHandler(ObserverContext<MasterCoprocessorEnvironment> ctx,
                     TableName tableName) | 
| void | BaseMasterAndRegionObserver. preModifyColumn(ObserverContext<MasterCoprocessorEnvironment> ctx,
               TableName tableName,
               HColumnDescriptor descriptor) | 
| void | MasterObserver. preModifyColumn(ObserverContext<MasterCoprocessorEnvironment> ctx,
               TableName tableName,
               HColumnDescriptor descriptor)Called prior to modifying a column family's attributes. | 
| void | BaseMasterObserver. preModifyColumn(ObserverContext<MasterCoprocessorEnvironment> ctx,
               TableName tableName,
               HColumnDescriptor descriptor) | 
| void | BaseMasterAndRegionObserver. preModifyColumnHandler(ObserverContext<MasterCoprocessorEnvironment> ctx,
                      TableName tableName,
                      HColumnDescriptor descriptor) | 
| void | MasterObserver. preModifyColumnHandler(ObserverContext<MasterCoprocessorEnvironment> ctx,
                      TableName tableName,
                      HColumnDescriptor descriptor)Called prior to modifying a column family's attributes. | 
| void | BaseMasterObserver. preModifyColumnHandler(ObserverContext<MasterCoprocessorEnvironment> ctx,
                      TableName tableName,
                      HColumnDescriptor descriptor) | 
| void | BaseMasterAndRegionObserver. preModifyTable(ObserverContext<MasterCoprocessorEnvironment> ctx,
              TableName tableName,
              HTableDescriptor htd) | 
| void | MasterObserver. preModifyTable(ObserverContext<MasterCoprocessorEnvironment> ctx,
              TableName tableName,
              HTableDescriptor htd)Called prior to modifying a table's properties. | 
| void | BaseMasterObserver. preModifyTable(ObserverContext<MasterCoprocessorEnvironment> ctx,
              TableName tableName,
              HTableDescriptor htd) | 
| void | BaseMasterAndRegionObserver. preModifyTableHandler(ObserverContext<MasterCoprocessorEnvironment> ctx,
                     TableName tableName,
                     HTableDescriptor htd) | 
| void | MasterObserver. preModifyTableHandler(ObserverContext<MasterCoprocessorEnvironment> ctx,
                     TableName tableName,
                     HTableDescriptor htd)Called prior to modifying a table's properties. | 
| void | BaseMasterObserver. preModifyTableHandler(ObserverContext<MasterCoprocessorEnvironment> ctx,
                     TableName tableName,
                     HTableDescriptor htd) | 
| void | BaseMasterAndRegionObserver. preSetTableQuota(ObserverContext<MasterCoprocessorEnvironment> ctx,
                TableName tableName,
                org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Quotas quotas) | 
| void | MasterObserver. preSetTableQuota(ObserverContext<MasterCoprocessorEnvironment> ctx,
                TableName tableName,
                org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Quotas quotas)Called before the quota for the table is stored. | 
| void | BaseMasterObserver. preSetTableQuota(ObserverContext<MasterCoprocessorEnvironment> ctx,
                TableName tableName,
                org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Quotas quotas) | 
| void | BaseMasterAndRegionObserver. preSetUserQuota(ObserverContext<MasterCoprocessorEnvironment> ctx,
               String userName,
               TableName tableName,
               org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Quotas quotas) | 
| void | MasterObserver. preSetUserQuota(ObserverContext<MasterCoprocessorEnvironment> ctx,
               String userName,
               TableName tableName,
               org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Quotas quotas)Called before the quota for the user on the specified table is stored. | 
| void | BaseMasterObserver. preSetUserQuota(ObserverContext<MasterCoprocessorEnvironment> ctx,
               String userName,
               TableName tableName,
               org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Quotas quotas) | 
| void | BaseMasterAndRegionObserver. preTableFlush(ObserverContext<MasterCoprocessorEnvironment> ctx,
             TableName tableName) | 
| void | MasterObserver. preTableFlush(ObserverContext<MasterCoprocessorEnvironment> ctx,
             TableName tableName)Called before the table memstore is flushed to disk. | 
| void | BaseMasterObserver. preTableFlush(ObserverContext<MasterCoprocessorEnvironment> ctx,
             TableName tableName) | 
| void | BaseMasterAndRegionObserver. preTruncateTable(ObserverContext<MasterCoprocessorEnvironment> ctx,
                TableName tableName) | 
| void | MasterObserver. preTruncateTable(ObserverContext<MasterCoprocessorEnvironment> ctx,
                TableName tableName)Called before  HMastertruncates a
 table. | 
| void | BaseMasterObserver. preTruncateTable(ObserverContext<MasterCoprocessorEnvironment> ctx,
                TableName tableName) | 
| void | BaseMasterAndRegionObserver. preTruncateTableHandler(ObserverContext<MasterCoprocessorEnvironment> ctx,
                       TableName tableName) | 
| void | MasterObserver. preTruncateTableHandler(ObserverContext<MasterCoprocessorEnvironment> ctx,
                       TableName tableName)Called before  HMastertruncates a
 table. | 
| void | BaseMasterObserver. preTruncateTableHandler(ObserverContext<MasterCoprocessorEnvironment> ctx,
                       TableName tableName) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | BaseMasterAndRegionObserver. postGetTableDescriptors(ObserverContext<MasterCoprocessorEnvironment> ctx,
                       List<TableName> tableNamesList,
                       List<HTableDescriptor> descriptors,
                       String regex) | 
| void | MasterObserver. postGetTableDescriptors(ObserverContext<MasterCoprocessorEnvironment> ctx,
                       List<TableName> tableNamesList,
                       List<HTableDescriptor> descriptors,
                       String regex)Called after a getTableDescriptors request has been processed. | 
| void | BaseMasterObserver. postGetTableDescriptors(ObserverContext<MasterCoprocessorEnvironment> ctx,
                       List<TableName> tableNamesList,
                       List<HTableDescriptor> descriptors,
                       String regex) | 
| void | BaseMasterAndRegionObserver. postMoveServersAndTables(ObserverContext<MasterCoprocessorEnvironment> ctx,
                        Set<Address> servers,
                        Set<TableName> tables,
                        String targetGroup) | 
| void | MasterObserver. postMoveServersAndTables(ObserverContext<MasterCoprocessorEnvironment> ctx,
                        Set<Address> servers,
                        Set<TableName> tables,
                        String targetGroup)Called after servers are moved to target region server group | 
| void | BaseMasterObserver. postMoveServersAndTables(ObserverContext<MasterCoprocessorEnvironment> ctx,
                        Set<Address> servers,
                        Set<TableName> tables,
                        String targetGroup) | 
| void | BaseMasterAndRegionObserver. postMoveTables(ObserverContext<MasterCoprocessorEnvironment> ctx,
              Set<TableName> tables,
              String targetGroup) | 
| void | MasterObserver. postMoveTables(ObserverContext<MasterCoprocessorEnvironment> ctx,
              Set<TableName> tables,
              String targetGroup)Called after servers are moved to target region server group | 
| void | BaseMasterObserver. postMoveTables(ObserverContext<MasterCoprocessorEnvironment> ctx,
              Set<TableName> tables,
              String targetGroup) | 
| void | BaseMasterAndRegionObserver. preGetTableDescriptors(ObserverContext<MasterCoprocessorEnvironment> ctx,
                      List<TableName> tableNamesList,
                      List<HTableDescriptor> descriptors) | 
| void | MasterObserver. preGetTableDescriptors(ObserverContext<MasterCoprocessorEnvironment> ctx,
                      List<TableName> tableNamesList,
                      List<HTableDescriptor> descriptors)Deprecated. 
 Use preGetTableDescriptors with regex instead. | 
| void | BaseMasterObserver. preGetTableDescriptors(ObserverContext<MasterCoprocessorEnvironment> ctx,
                      List<TableName> tableNamesList,
                      List<HTableDescriptor> descriptors) | 
| void | BaseMasterAndRegionObserver. preGetTableDescriptors(ObserverContext<MasterCoprocessorEnvironment> ctx,
                      List<TableName> tableNamesList,
                      List<HTableDescriptor> descriptors,
                      String regex) | 
| void | MasterObserver. preGetTableDescriptors(ObserverContext<MasterCoprocessorEnvironment> ctx,
                      List<TableName> tableNamesList,
                      List<HTableDescriptor> descriptors,
                      String regex)Called before a getTableDescriptors request has been processed. | 
| void | BaseMasterObserver. preGetTableDescriptors(ObserverContext<MasterCoprocessorEnvironment> ctx,
                      List<TableName> tableNamesList,
                      List<HTableDescriptor> descriptors,
                      String regex) | 
| void | BaseMasterAndRegionObserver. preMoveServersAndTables(ObserverContext<MasterCoprocessorEnvironment> ctx,
                       Set<Address> servers,
                       Set<TableName> tables,
                       String targetGroup) | 
| void | MasterObserver. preMoveServersAndTables(ObserverContext<MasterCoprocessorEnvironment> ctx,
                       Set<Address> servers,
                       Set<TableName> tables,
                       String targetGroup)Called before servers are moved to target region server group | 
| void | BaseMasterObserver. preMoveServersAndTables(ObserverContext<MasterCoprocessorEnvironment> ctx,
                       Set<Address> servers,
                       Set<TableName> tables,
                       String targetGroup) | 
| void | BaseMasterAndRegionObserver. preMoveTables(ObserverContext<MasterCoprocessorEnvironment> ctx,
             Set<TableName> tables,
             String targetGroup) | 
| void | MasterObserver. preMoveTables(ObserverContext<MasterCoprocessorEnvironment> ctx,
             Set<TableName> tables,
             String targetGroup)Called before tables are moved to target region server group | 
| void | BaseMasterObserver. preMoveTables(ObserverContext<MasterCoprocessorEnvironment> ctx,
             Set<TableName> tables,
             String targetGroup) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | ExampleMasterObserverWithMetrics. preDisableTable(ObserverContext<MasterCoprocessorEnvironment> ctx,
               TableName tableName) | 
| Modifier and Type | Method and Description | 
|---|---|
| static TableName | HFileLink. getReferencedTableName(String fileName)Get the Table name of the referenced link | 
| Modifier and Type | Method and Description | 
|---|---|
| static HFileLink | HFileLink. build(org.apache.hadoop.conf.Configuration conf,
     TableName table,
     String region,
     String family,
     String hfile)Create an HFileLink instance from table/region/family/hfile location | 
| static boolean | HFileLink. create(org.apache.hadoop.conf.Configuration conf,
      org.apache.hadoop.fs.FileSystem fs,
      org.apache.hadoop.fs.Path dstFamilyPath,
      TableName linkedTable,
      String linkedRegion,
      String hfileName)Create a new HFileLink | 
| static boolean | HFileLink. create(org.apache.hadoop.conf.Configuration conf,
      org.apache.hadoop.fs.FileSystem fs,
      org.apache.hadoop.fs.Path dstFamilyPath,
      TableName linkedTable,
      String linkedRegion,
      String hfileName,
      boolean createBackRef)Create a new HFileLink | 
| static String | HFileLink. createHFileLinkName(TableName tableName,
                   String regionName,
                   String hfileName)Create a new HFileLink name | 
| static org.apache.hadoop.fs.Path | HFileLink. createPath(TableName table,
          String region,
          String family,
          String hfile)Create an HFileLink relative path for the table/region/family/hfile location | 
| Modifier and Type | Method and Description | 
|---|---|
| void | HBaseRpcController. setPriority(TableName tn) | 
| void | HBaseRpcControllerImpl. setPriority(TableName tn) | 
| void | DelegatingHBaseRpcController. setPriority(TableName tn) | 
| Constructor and Description | 
|---|
| RegionCoprocessorRpcChannel(ClusterConnection conn,
                           TableName table,
                           byte[] row) | 
| Modifier and Type | Method and Description | 
|---|---|
| TableName | TableSplit. getTable() | 
| Modifier and Type | Method and Description | 
|---|---|
| protected void | TableInputFormatBase. initializeTable(Connection connection,
               TableName tableName)Allows subclasses to initialize the table information. | 
| Constructor and Description | 
|---|
| TableSplit(TableName tableName,
          byte[] startRow,
          byte[] endRow,
          String location)Constructor | 
| Modifier and Type | Method and Description | 
|---|---|
| TableName | TableSplit. getTable()Returns the table name. | 
| Modifier and Type | Method and Description | 
|---|---|
| static void | TableInputFormat. configureSplitTable(org.apache.hadoop.mapreduce.Job job,
                   TableName tableName)Sets split table in map-reduce job. | 
| protected void | TableInputFormatBase. initializeTable(Connection connection,
               TableName tableName)Allows subclasses to initialize the table information. | 
| static void | TableMapReduceUtil. initTableMapperJob(TableName table,
                  Scan scan,
                  Class<? extends TableMapper> mapper,
                  Class<?> outputKeyClass,
                  Class<?> outputValueClass,
                  org.apache.hadoop.mapreduce.Job job)Use this before submitting a TableMap job. | 
| protected List<LoadIncrementalHFiles.LoadQueueItem> | LoadIncrementalHFiles. tryAtomicRegionLoad(Connection conn,
                   TableName tableName,
                   byte[] first,
                   Collection<LoadIncrementalHFiles.LoadQueueItem> lqis)Attempts to do an atomic load of many hfiles into a region. | 
| Constructor and Description | 
|---|
| TableSplit(TableName tableName,
          byte[] startRow,
          byte[] endRow,
          String location)Creates a new instance without a scanner. | 
| TableSplit(TableName tableName,
          byte[] startRow,
          byte[] endRow,
          String location,
          long length)Creates a new instance without a scanner. | 
| TableSplit(TableName tableName,
          Scan scan,
          byte[] startRow,
          byte[] endRow,
          String location)Creates a new instance while assigning all variables. | 
| TableSplit(TableName tableName,
          Scan scan,
          byte[] startRow,
          byte[] endRow,
          String location,
          long length)Creates a new instance while assigning all variables. | 
| TableSplit(TableName tableName,
          Scan scan,
          byte[] startRow,
          byte[] endRow,
          String location,
          String encodedRegionName,
          long length)Creates a new instance while assigning all variables. | 
| Modifier and Type | Method and Description | 
|---|---|
| protected Map<TableName,Map<ServerName,List<HRegionInfo>>> | RegionStates. getAssignmentsByTable()This is an EXPENSIVE clone. | 
| Map<TableName,Integer> | RegionPlacementMaintainer. getRegionsMovement(FavoredNodesPlan newPlan)Return how many regions will move per table since their primary RS will
 change | 
| Set<TableName> | SnapshotOfRegionAssignmentFromMeta. getTableSet()Get the table set | 
| Map<TableName,List<HRegionInfo>> | SnapshotOfRegionAssignmentFromMeta. getTableToRegionMap()Get regions for tables | 
| List<TableName> | HMaster. listTableNames(String namespace,
              String regex,
              boolean includeSysTables)Returns the list of table names that match the specified request | 
| List<TableName> | HMaster. listTableNamesByNamespace(String name) | 
| List<TableName> | MasterServices. listTableNamesByNamespace(String name)Get list of table names by namespace | 
| Modifier and Type | Method and Description | 
|---|---|
| void | HMaster. addColumn(TableName tableName,
         HColumnDescriptor columnDescriptor,
         long nonceGroup,
         long nonce) | 
| void | MasterServices. addColumn(TableName tableName,
         HColumnDescriptor column,
         long nonceGroup,
         long nonce)Add a new column to an existing table | 
| List<RegionPlan> | LoadBalancer. balanceCluster(TableName tableName,
              Map<ServerName,List<HRegionInfo>> clusterState)Perform the major balance operation | 
| void | HMaster. checkTableModifiable(TableName tableName) | 
| void | MasterServices. checkTableModifiable(TableName tableName)Check table is modifiable; i.e. | 
| void | HMaster. deleteColumn(TableName tableName,
            byte[] columnName,
            long nonceGroup,
            long nonce) | 
| void | MasterServices. deleteColumn(TableName tableName,
            byte[] columnName,
            long nonceGroup,
            long nonce)Delete a column from an existing table | 
| long | HMaster. deleteTable(TableName tableName,
           long nonceGroup,
           long nonce) | 
| long | MasterServices. deleteTable(TableName tableName,
           long nonceGroup,
           long nonce)Delete a table | 
| long | HMaster. disableTable(TableName tableName,
            long nonceGroup,
            long nonce) | 
| long | MasterServices. disableTable(TableName tableName,
            long nonceGroup,
            long nonce)Disable an existing table | 
| long | HMaster. enableTable(TableName tableName,
           long nonceGroup,
           long nonce) | 
| long | MasterServices. enableTable(TableName tableName,
           long nonceGroup,
           long nonce)Enable an existing table | 
| void | AssignmentVerificationReport. fillUp(TableName tableName,
      SnapshotOfRegionAssignmentFromMeta snapshot,
      Map<String,Map<String,Float>> regionLocalityMap) | 
| void | AssignmentVerificationReport. fillUpDispersion(TableName tableName,
                SnapshotOfRegionAssignmentFromMeta snapshot,
                FavoredNodesPlan newPlan)Use this to project the dispersion scores | 
| long | HMaster. getLastMajorCompactionTimestamp(TableName table) | 
| long | MasterServices. getLastMajorCompactionTimestamp(TableName table) | 
| Map<RegionState.State,List<HRegionInfo>> | RegionStates. getRegionByStateOfTable(TableName tableName)Gets current state of all regions of the table. | 
| List<HRegionInfo> | RegionStates. getRegionsOfTable(TableName tableName)Gets the online regions of the specified table. | 
| Pair<Integer,Integer> | AssignmentManager. getReopenStatus(TableName tableName)Used by the client to identify if all regions have the schema updates | 
| void | HMaster. modifyColumn(TableName tableName,
            HColumnDescriptor descriptor,
            long nonceGroup,
            long nonce) | 
| void | MasterServices. modifyColumn(TableName tableName,
            HColumnDescriptor descriptor,
            long nonceGroup,
            long nonce)Modify the column descriptor of an existing column in an existing table | 
| void | HMaster. modifyTable(TableName tableName,
           HTableDescriptor descriptor,
           long nonceGroup,
           long nonce) | 
| void | MasterServices. modifyTable(TableName tableName,
           HTableDescriptor descriptor,
           long nonceGroup,
           long nonce)Modify the descriptor of an existing table | 
| void | MasterCoprocessorHost. postAddColumn(TableName tableName,
             HColumnDescriptor column) | 
| void | MasterCoprocessorHost. postAddColumnHandler(TableName tableName,
                    HColumnDescriptor column) | 
| void | MasterCoprocessorHost. postDeleteColumn(TableName tableName,
                byte[] c) | 
| void | MasterCoprocessorHost. postDeleteColumnHandler(TableName tableName,
                       byte[] c) | 
| void | MasterCoprocessorHost. postDeleteTable(TableName tableName) | 
| void | MasterCoprocessorHost. postDeleteTableHandler(TableName tableName) | 
| void | MasterCoprocessorHost. postDisableTable(TableName tableName) | 
| void | MasterCoprocessorHost. postDisableTableHandler(TableName tableName) | 
| void | MasterCoprocessorHost. postEnableTable(TableName tableName) | 
| void | MasterCoprocessorHost. postEnableTableHandler(TableName tableName) | 
| void | MasterCoprocessorHost. postModifyColumn(TableName tableName,
                HColumnDescriptor descriptor) | 
| void | MasterCoprocessorHost. postModifyColumnHandler(TableName tableName,
                       HColumnDescriptor descriptor) | 
| void | MasterCoprocessorHost. postModifyTable(TableName tableName,
               HTableDescriptor htd) | 
| void | MasterCoprocessorHost. postModifyTableHandler(TableName tableName,
                      HTableDescriptor htd) | 
| void | MasterCoprocessorHost. postSetTableQuota(TableName table,
                 org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Quotas quotas) | 
| void | MasterCoprocessorHost. postSetUserQuota(String user,
                TableName table,
                org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Quotas quotas) | 
| void | MasterCoprocessorHost. postTableFlush(TableName tableName) | 
| void | MasterCoprocessorHost. postTruncateTable(TableName tableName) | 
| void | MasterCoprocessorHost. postTruncateTableHandler(TableName tableName) | 
| boolean | MasterCoprocessorHost. preAddColumn(TableName tableName,
            HColumnDescriptor column) | 
| boolean | MasterCoprocessorHost. preAddColumnHandler(TableName tableName,
                   HColumnDescriptor column) | 
| boolean | MasterCoprocessorHost. preDeleteColumn(TableName tableName,
               byte[] c) | 
| boolean | MasterCoprocessorHost. preDeleteColumnHandler(TableName tableName,
                      byte[] c) | 
| void | MasterCoprocessorHost. preDeleteTable(TableName tableName) | 
| void | MasterCoprocessorHost. preDeleteTableHandler(TableName tableName) | 
| void | MasterCoprocessorHost. preDisableTable(TableName tableName) | 
| void | MasterCoprocessorHost. preDisableTableHandler(TableName tableName) | 
| void | MasterCoprocessorHost. preEnableTable(TableName tableName) | 
| void | MasterCoprocessorHost. preEnableTableHandler(TableName tableName) | 
| boolean | MasterCoprocessorHost. preModifyColumn(TableName tableName,
               HColumnDescriptor descriptor) | 
| boolean | MasterCoprocessorHost. preModifyColumnHandler(TableName tableName,
                      HColumnDescriptor descriptor) | 
| void | MasterCoprocessorHost. preModifyTable(TableName tableName,
              HTableDescriptor htd) | 
| void | MasterCoprocessorHost. preModifyTableHandler(TableName tableName,
                     HTableDescriptor htd) | 
| void | MasterCoprocessorHost. preSetTableQuota(TableName table,
                org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Quotas quotas) | 
| void | MasterCoprocessorHost. preSetUserQuota(String user,
               TableName table,
               org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Quotas quotas) | 
| void | MasterCoprocessorHost. preTableFlush(TableName tableName) | 
| void | MasterCoprocessorHost. preTruncateTable(TableName tableName) | 
| void | MasterCoprocessorHost. preTruncateTableHandler(TableName tableName) | 
| void | RegionPlacementMaintainer. printDispersionScores(TableName table,
                     SnapshotOfRegionAssignmentFromMeta snapshot,
                     int numRegions,
                     FavoredNodesPlan newPlan,
                     boolean simplePrint) | 
| abstract TableLockManager.TableLock | TableLockManager. readLock(TableName tableName,
        String purpose)Returns a TableLock for locking the table for shared access among read-lock holders | 
| TableLockManager.TableLock | TableLockManager.NullTableLockManager. readLock(TableName tableName,
        String purpose) | 
| protected void | AssignmentManager. setEnabledTable(TableName tableName) | 
| void | RegionStates. tableDeleted(TableName tableName)A table is deleted. | 
| abstract void | TableLockManager. tableDeleted(TableName tableName)Called after a table has been deleted, and after the table lock is  released. | 
| void | TableLockManager.NullTableLockManager. tableDeleted(TableName tableName) | 
| void | HMaster. truncateTable(TableName tableName,
             boolean preserveSplits,
             long nonceGroup,
             long nonce) | 
| void | MasterServices. truncateTable(TableName tableName,
             boolean preserveSplits,
             long nonceGroup,
             long nonce)Truncate a table | 
| abstract TableLockManager.TableLock | TableLockManager. writeLock(TableName tableName,
         String purpose)Returns a TableLock for locking the table for exclusive access | 
| TableLockManager.TableLock | TableLockManager.NullTableLockManager. writeLock(TableName tableName,
         String purpose) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | RegionPlacementMaintainer. checkDifferencesWithOldPlan(Map<TableName,Integer> movesPerTable,
                           Map<String,Map<String,Float>> regionLocalityMap,
                           FavoredNodesPlan newPlan)Compares two plans and check whether the locality dropped or increased
 (prints the information as a string) also prints the baseline locality | 
| List<HTableDescriptor> | HMaster. listTableDescriptors(String namespace,
                    String regex,
                    List<TableName> tableNameList,
                    boolean includeSysTables)Returns the list of table descriptors that match the specified request | 
| void | MasterCoprocessorHost. postGetTableDescriptors(List<TableName> tableNamesList,
                       List<HTableDescriptor> descriptors,
                       String regex) | 
| void | MasterCoprocessorHost. postMoveServersAndTables(Set<Address> servers,
                        Set<TableName> tables,
                        String targetGroup) | 
| void | MasterCoprocessorHost. postMoveTables(Set<TableName> tables,
              String targetGroup) | 
| boolean | MasterCoprocessorHost. preGetTableDescriptors(List<TableName> tableNamesList,
                      List<HTableDescriptor> descriptors)Deprecated.  | 
| boolean | MasterCoprocessorHost. preGetTableDescriptors(List<TableName> tableNamesList,
                      List<HTableDescriptor> descriptors,
                      String regex) | 
| void | MasterCoprocessorHost. preMoveServersAndTables(Set<Address> servers,
                       Set<TableName> tables,
                       String targetGroup) | 
| void | MasterCoprocessorHost. preMoveTables(Set<TableName> tables,
             String targetGroup) | 
| Constructor and Description | 
|---|
| SnapshotOfRegionAssignmentFromMeta(Connection connection,
                                  Set<TableName> disabledTables,
                                  boolean excludeOfflinedSplitParents) | 
| Modifier and Type | Method and Description | 
|---|---|
| List<RegionPlan> | StochasticLoadBalancer. balanceCluster(TableName tableName,
              Map<ServerName,List<HRegionInfo>> clusterState) | 
| List<RegionPlan> | FavoredNodeLoadBalancer. balanceCluster(TableName tableName,
              Map<ServerName,List<HRegionInfo>> clusterState) | 
| List<RegionPlan> | SimpleLoadBalancer. balanceCluster(TableName tableName,
              Map<ServerName,List<HRegionInfo>> clusterState) | 
| Modifier and Type | Field and Description | 
|---|---|
| protected TableName | TableEventHandler. tableName | 
| Modifier and Type | Method and Description | 
|---|---|
| protected List<HRegionInfo> | CreateTableHandler. handleCreateHdfsRegions(org.apache.hadoop.fs.Path tableRootDir,
                       TableName tableName)Create the on-disk structure for the table, and returns the regions info. | 
| Constructor and Description | 
|---|
| DisableTableHandler(Server server,
                   TableName tableName,
                   AssignmentManager assignmentManager,
                   TableLockManager tableLockManager,
                   boolean skipTableStateCheck) | 
| EnableTableHandler(MasterServices services,
                  TableName tableName,
                  AssignmentManager assignmentManager,
                  TableLockManager tableLockManager,
                  boolean skipTableStateCheck) | 
| EnableTableHandler(Server server,
                  TableName tableName,
                  AssignmentManager assignmentManager,
                  TableLockManager tableLockManager,
                  boolean skipTableStateCheck) | 
| TableEventHandler(EventType eventType,
                 TableName tableName,
                 Server server,
                 MasterServices masterServices) | 
| Modifier and Type | Method and Description | 
|---|---|
| List<NormalizationPlan> | SimpleRegionNormalizer. computePlanForTable(TableName table)Computes next most "urgent" normalization action on the table. | 
| List<NormalizationPlan> | RegionNormalizer. computePlanForTable(TableName table)Computes next optimal normalization plan. | 
| Modifier and Type | Method and Description | 
|---|---|
| TableName | DeleteTableProcedure. getTableName() | 
| TableName | DeleteNamespaceProcedure. getTableName() | 
| TableName | ModifyColumnFamilyProcedure. getTableName() | 
| TableName | TableProcedureInterface. getTableName() | 
| TableName | TruncateTableProcedure. getTableName() | 
| TableName | CreateNamespaceProcedure. getTableName() | 
| TableName | AddColumnFamilyProcedure. getTableName() | 
| TableName | DeleteColumnFamilyProcedure. getTableName() | 
| TableName | EnableTableProcedure. getTableName() | 
| TableName | ModifyNamespaceProcedure. getTableName() | 
| TableName | DisableTableProcedure. getTableName() | 
| TableName | ModifyTableProcedure. getTableName() | 
| TableName | CreateTableProcedure. getTableName() | 
| Modifier and Type | Method and Description | 
|---|---|
| protected static void | CreateTableProcedure. assignRegions(MasterProcedureEnv env,
             TableName tableName,
             List<HRegionInfo> regions) | 
| static void | MasterDDLOperationHelper. checkTableModifiable(MasterProcedureEnv env,
                    TableName tableName)Check whether a table is modifiable - exists and either offline or online with config set | 
| List<HRegionInfo> | CreateTableProcedure.CreateHdfsRegions. createHdfsRegions(MasterProcedureEnv env,
                 org.apache.hadoop.fs.Path tableRootDir,
                 TableName tableName,
                 List<HRegionInfo> newRegions) | 
| protected static void | DeleteTableProcedure. deleteAssignmentState(MasterProcedureEnv env,
                     TableName tableName) | 
| static void | MasterDDLOperationHelper. deleteColumnFamilyFromFileSystem(MasterProcedureEnv env,
                                TableName tableName,
                                List<HRegionInfo> regionInfoList,
                                byte[] familyName)Remove the column family from the file system | 
| protected static void | DeleteTableProcedure. deleteFromFs(MasterProcedureEnv env,
            TableName tableName,
            List<HRegionInfo> regions,
            boolean archive) | 
| protected static void | DeleteTableProcedure. deleteFromMeta(MasterProcedureEnv env,
              TableName tableName,
              List<HRegionInfo> regions) | 
| protected static void | DeleteTableProcedure. deleteTableDescriptorCache(MasterProcedureEnv env,
                          TableName tableName) | 
| protected static void | DeleteTableProcedure. deleteTableStates(MasterProcedureEnv env,
                 TableName tableName) | 
| protected static List<HRegionInfo> | ProcedureSyncWait. getRegionsFromMeta(MasterProcedureEnv env,
                  TableName tableName) | 
| protected static List<HRegionInfo> | ProcedureSyncWait. getRegionsFromMeta(MasterProcedureEnv env,
                  TableName tableName,
                  boolean excludeOfflinedSplitParents,
                  boolean excludeReplicaRegions) | 
| protected static org.apache.hadoop.hbase.master.procedure.DisableTableProcedure.MarkRegionOfflineOpResult | DisableTableProcedure. markRegionsOffline(MasterProcedureEnv env,
                  TableName tableName,
                  Boolean retryRequired)Mark regions of the table offline with retries | 
| protected static void | EnableTableProcedure. markRegionsOnline(MasterProcedureEnv env,
                 TableName tableName,
                 Boolean retryRequired)Mark offline regions of the table online with retry | 
| protected boolean | MasterProcedureScheduler. markTableAsDeleted(TableName table)Tries to remove the queue and the table-lock of the specified table. | 
| void | MasterProcedureScheduler. releaseTableExclusiveLock(Procedure procedure,
                         TableName table)Release the exclusive lock taken with tryAcquireTableWrite() | 
| void | MasterProcedureScheduler. releaseTableSharedLock(Procedure procedure,
                      TableName table)Release the shared lock taken with tryAcquireTableRead() | 
| static boolean | MasterDDLOperationHelper. reOpenAllRegions(MasterProcedureEnv env,
                TableName tableName,
                List<HRegionInfo> regionInfoList)Reopen all regions from a table after a schema change operation. | 
| protected static void | DisableTableProcedure. setTableStateToDisabled(MasterProcedureEnv env,
                       TableName tableName)Mark table state to Disabled | 
| protected static void | DisableTableProcedure. setTableStateToDisabling(MasterProcedureEnv env,
                        TableName tableName)Mark table state to Disabling | 
| protected static void | EnableTableProcedure. setTableStateToEnabled(MasterProcedureEnv env,
                      TableName tableName)Mark table state to Enabled | 
| protected static void | EnableTableProcedure. setTableStateToEnabling(MasterProcedureEnv env,
                       TableName tableName)Mark table state to Enabling | 
| boolean | MasterProcedureScheduler. tryAcquireTableExclusiveLock(Procedure procedure,
                            TableName table)Try to acquire the exclusive lock on the specified table. | 
| boolean | MasterProcedureScheduler. tryAcquireTableSharedLock(Procedure procedure,
                         TableName table)Try to acquire the shared lock on the specified table. | 
| protected static void | CreateTableProcedure. updateTableDescCache(MasterProcedureEnv env,
                    TableName tableName) | 
| Modifier and Type | Field and Description | 
|---|---|
| protected TableName | TakeSnapshotHandler. snapshotTable | 
| Modifier and Type | Method and Description | 
|---|---|
| protected List<HRegionInfo> | CloneSnapshotHandler. handleCreateHdfsRegions(org.apache.hadoop.fs.Path tableRootDir,
                       TableName tableName)Create the on-disk regions, using the tableRootDir provided by the CreateTableHandler. | 
| void | SnapshotManager. setSnapshotHandlerForTesting(TableName tableName,
                            SnapshotSentinel handler)Set the handler for the current snapshot | 
| Modifier and Type | Method and Description | 
|---|---|
| void | NamespaceAuditor. checkQuotaToCreateTable(TableName tName,
                       int regions)Check quota to create table. | 
| void | NamespaceAuditor. checkQuotaToUpdateRegion(TableName tName,
                        int regions)Check and update region count quota for an existing table. | 
| int | NamespaceAuditor. getRegionCountOfTable(TableName tName)Get region count for table | 
| void | NamespaceAuditor. removeFromNamespaceUsage(TableName tableName) | 
| Modifier and Type | Method and Description | 
|---|---|
| static TableName[] | ProtobufUtil. getTableNameArray(List<org.apache.hadoop.hbase.protobuf.generated.TableProtos.TableName> tableNamesList) | 
| static TableName | ProtobufUtil. toTableName(org.apache.hadoop.hbase.protobuf.generated.TableProtos.TableName tableNamePB) | 
| Modifier and Type | Method and Description | 
|---|---|
| static org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AddColumnRequest | RequestConverter. buildAddColumnRequest(TableName tableName,
                     HColumnDescriptor column,
                     long nonceGroup,
                     long nonce)Create a protocol buffer AddColumnRequest | 
| static org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteColumnRequest | RequestConverter. buildDeleteColumnRequest(TableName tableName,
                        byte[] columnName,
                        long nonceGroup,
                        long nonce)Create a protocol buffer DeleteColumnRequest | 
| static org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteTableRequest | RequestConverter. buildDeleteTableRequest(TableName tableName,
                       long nonceGroup,
                       long nonce)Creates a protocol buffer DeleteTableRequest | 
| static org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DisableTableRequest | RequestConverter. buildDisableTableRequest(TableName tableName,
                        long nonceGroup,
                        long nonce)Creates a protocol buffer DisableTableRequest | 
| static org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableTableRequest | RequestConverter. buildEnableTableRequest(TableName tableName,
                       long nonceGroup,
                       long nonce)Creates a protocol buffer EnableTableRequest | 
| static org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetSchemaAlterStatusRequest | RequestConverter. buildGetSchemaAlterStatusRequest(TableName tableName)Creates a protocol buffer GetSchemaAlterStatusRequest | 
| static org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsRequest | RequestConverter. buildGetTableDescriptorsRequest(TableName tableName)Creates a protocol buffer GetTableDescriptorsRequest for a single table | 
| static org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantRequest | RequestConverter. buildGrantRequest(String username,
                 TableName tableName,
                 byte[] family,
                 byte[] qualifier,
                 boolean mergeExistingPermissions,
                 org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission.Action... actions)Create a request to grant user permissions. | 
| static org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyColumnRequest | RequestConverter. buildModifyColumnRequest(TableName tableName,
                        HColumnDescriptor column,
                        long nonceGroup,
                        long nonce)Create a protocol buffer ModifyColumnRequest | 
| static org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyTableRequest | RequestConverter. buildModifyTableRequest(TableName tableName,
                       HTableDescriptor hTableDesc,
                       long nonceGroup,
                       long nonce)Creates a protocol buffer ModifyTableRequest | 
| static org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeRequest | RequestConverter. buildRevokeRequest(String username,
                  TableName tableName,
                  byte[] family,
                  byte[] qualifier,
                  org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission.Action... actions)Create a request to revoke user permissions. | 
| static org.apache.hadoop.hbase.protobuf.generated.MasterProtos.TruncateTableRequest | RequestConverter. buildTruncateTableRequest(TableName tableName,
                         boolean preserveSplits,
                         long nonceGroup,
                         long nonce)Creates a protocol buffer TruncateTableRequest | 
| static List<UserPermission> | ProtobufUtil. getUserPermissions(com.google.protobuf.RpcController controller,
                  org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.AccessControlService.BlockingInterface protocol,
                  TableName t)A utility used to get user table permissions. | 
| static void | ProtobufUtil. grant(com.google.protobuf.RpcController controller,
     org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.AccessControlService.BlockingInterface protocol,
     String userShortName,
     TableName tableName,
     byte[] f,
     byte[] q,
     boolean mergeExistingPermissions,
     Permission.Action... actions)A utility used to grant a user table permissions. | 
| static void | ProtobufUtil. revoke(com.google.protobuf.RpcController controller,
      org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.AccessControlService.BlockingInterface protocol,
      String userShortName,
      TableName tableName,
      byte[] f,
      byte[] q,
      Permission.Action... actions)A utility used to revoke a user's table permissions. | 
| static org.apache.hadoop.hbase.protobuf.generated.WALProtos.BulkLoadDescriptor | ProtobufUtil. toBulkLoadDescriptor(TableName tableName,
                    com.google.protobuf.ByteString encodedRegionName,
                    Map<byte[],List<org.apache.hadoop.fs.Path>> storeFiles,
                    Map<String,Long> storeFilesSize,
                    long bulkloadSeqId)Deprecated. 
 use toBulkLoadDescriptor(TableName tableName, ByteString encodedRegionName,
 Map | 
| static org.apache.hadoop.hbase.protobuf.generated.WALProtos.BulkLoadDescriptor | ProtobufUtil. toBulkLoadDescriptor(TableName tableName,
                    com.google.protobuf.ByteString encodedRegionName,
                    Map<byte[],List<org.apache.hadoop.fs.Path>> storeFiles,
                    Map<String,Long> storeFilesSize,
                    long bulkloadSeqId,
                    List<String> clusterIds)Generates a marker for the WAL so that we propagate the notion of a bulk region load
 throughout the WAL, keeping track of clusters who already applied the bulk event via
 the passed clusterIds parameter. | 
| static org.apache.hadoop.hbase.protobuf.generated.TableProtos.TableName | ProtobufUtil. toProtoTableName(TableName tableName) | 
| Modifier and Type | Method and Description | 
|---|---|
| static org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsRequest | RequestConverter. buildGetTableDescriptorsRequest(List<TableName> tableNames)Creates a protocol buffer GetTableDescriptorsRequest | 
| Modifier and Type | Field and Description | 
|---|---|
| static TableName | QuotaTableUtil. QUOTA_TABLE_NAMESystem table for quotas | 
| Modifier and Type | Method and Description | 
|---|---|
| protected static TableName | QuotaTableUtil. getTableFromRowKey(byte[] key) | 
| TableName | QuotaSettings. getTableName() | 
| Modifier and Type | Method and Description | 
|---|---|
| static Map<TableName,QuotaState> | QuotaUtil. fetchTableQuotas(Connection connection,
                List<Get> gets) | 
| Modifier and Type | Method and Description | 
|---|---|
| static void | QuotaUtil. addTableQuota(Connection connection,
             TableName table,
             org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Quotas data) | 
| static void | QuotaUtil. addUserQuota(Connection connection,
            String user,
            TableName table,
            org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Quotas data) | 
| void | MasterQuotaManager. checkAndUpdateNamespaceRegionQuota(TableName tName,
                                  int regions) | 
| void | MasterQuotaManager. checkNamespaceTableAndRegionQuota(TableName tName,
                                 int regions) | 
| static void | QuotaUtil. deleteTableQuota(Connection connection,
                TableName table) | 
| static void | QuotaUtil. deleteUserQuota(Connection connection,
               String user,
               TableName table) | 
| OperationQuota | RegionServerQuotaManager. getQuota(org.apache.hadoop.security.UserGroupInformation ugi,
        TableName table)Returns the quota for an operation. | 
| int | MasterQuotaManager. getRegionCountOfTable(TableName tName) | 
| protected static byte[] | QuotaTableUtil. getSettingsQualifierForUserTable(TableName tableName) | 
| QuotaLimiter | QuotaCache. getTableLimiter(TableName table)Returns the limiter associated to the specified table. | 
| QuotaLimiter | UserQuotaState. getTableLimiter(TableName table)Return the limiter for the specified table associated with this quota. | 
| static org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Quotas | QuotaTableUtil. getTableQuota(Connection connection,
             TableName table) | 
| protected static byte[] | QuotaTableUtil. getTableRowKey(TableName table) | 
| QuotaLimiter | QuotaCache. getUserLimiter(org.apache.hadoop.security.UserGroupInformation ugi,
              TableName table)Returns the limiter associated to the specified user/table. | 
| static org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Quotas | QuotaTableUtil. getUserQuota(Connection connection,
            String user,
            TableName table) | 
| static Get | QuotaTableUtil. makeGetForTableQuotas(TableName table) | 
| protected static void | QuotaTableUtil. parseTableResult(TableName table,
                Result result,
                QuotaTableUtil.TableQuotasVisitor visitor) | 
| void | MasterQuotaManager. removeTableFromNamespaceQuota(TableName tName)Remove table from namespace quota. | 
| void | UserQuotaState. setQuotas(TableName table,
         org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Quotas quotas)Add the quota information of the specified table. | 
| void | MasterQuotaManager. setTableQuota(TableName table,
             org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaRequest req) | 
| void | MasterQuotaManager. setUserQuota(String userName,
            TableName table,
            org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaRequest req) | 
| static QuotaSettings | QuotaSettingsFactory. throttleTable(TableName tableName,
             ThrottleType type,
             long limit,
             TimeUnit timeUnit)Throttle the specified table. | 
| static QuotaSettings | QuotaSettingsFactory. throttleUser(String userName,
            TableName tableName,
            ThrottleType type,
            long limit,
            TimeUnit timeUnit)Throttle the specified user on the specified table. | 
| static QuotaSettings | QuotaSettingsFactory. unthrottleTable(TableName tableName)Remove the throttling for the specified table. | 
| static QuotaSettings | QuotaSettingsFactory. unthrottleUser(String userName,
              TableName tableName)Remove the throttling for the specified user on the specified table. | 
| void | QuotaTableUtil.TableQuotasVisitor. visitTableQuotas(TableName tableName,
                org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Quotas quotas) | 
| void | QuotaTableUtil.UserQuotasVisitor. visitUserQuotas(String userName,
               TableName table,
               org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Quotas quotas) | 
| Modifier and Type | Method and Description | 
|---|---|
| static Get | QuotaTableUtil. makeGetForUserQuotas(String user,
                    Iterable<TableName> tables,
                    Iterable<String> namespaces) | 
| Constructor and Description | 
|---|
| QuotaSettings(String userName,
             TableName tableName,
             String namespace) | 
| Modifier and Type | Method and Description | 
|---|---|
| TableName | Store. getTableName() | 
| TableName | HStore. getTableName() | 
| Modifier and Type | Method and Description | 
|---|---|
| Set<TableName> | RegionServerServices. getOnlineTables() | 
| Set<TableName> | HRegionServer. getOnlineTables()Gets the online tables in this RS. | 
| Modifier and Type | Method and Description | 
|---|---|
| List<Region> | HRegionServer. getOnlineRegions(TableName tableName)Gets the online regions of the specified table. | 
| List<Region> | OnlineRegions. getOnlineRegions(TableName tableName)Get all online regions of a table in this RS. | 
| static String | MetricsTableLatenciesImpl. qualifyMetricsName(TableName tableName,
                  String metric) | 
| void | MetricsRegionServer. updateAppend(TableName tn,
            long t) | 
| void | RegionServerTableMetrics. updateAppend(TableName table,
            long time) | 
| void | MetricsRegionServer. updateDelete(TableName tn,
            long t) | 
| void | RegionServerTableMetrics. updateDelete(TableName table,
            long time) | 
| void | MetricsRegionServer. updateDeleteBatch(TableName tn,
                 long t) | 
| void | RegionServerTableMetrics. updateDeleteBatch(TableName table,
                 long time) | 
| void | MetricsRegionServer. updateGet(TableName tn,
         long t) | 
| void | RegionServerTableMetrics. updateGet(TableName table,
         long time) | 
| void | MetricsRegionServer. updateIncrement(TableName tn,
               long t) | 
| void | RegionServerTableMetrics. updateIncrement(TableName table,
               long time) | 
| void | MetricsRegionServer. updatePut(TableName tn,
         long t) | 
| void | RegionServerTableMetrics. updatePut(TableName table,
         long time) | 
| void | MetricsRegionServer. updatePutBatch(TableName tn,
              long t) | 
| void | RegionServerTableMetrics. updatePutBatch(TableName table,
              long time) | 
| void | MetricsRegionServer. updateReadQueryMeter(TableName tn) | 
| void | MetricsRegionServer. updateReadQueryMeter(TableName tn,
                    long count) | 
| void | MetricsRegionServer. updateScanSize(TableName tn,
              long scanSize) | 
| void | RegionServerTableMetrics. updateScanSize(TableName table,
              long size) | 
| void | MetricsRegionServer. updateScanTime(TableName tn,
              long t) | 
| void | RegionServerTableMetrics. updateScanTime(TableName table,
              long time) | 
| void | RegionServerTableMetrics. updateTableReadQueryMeter(TableName table) | 
| void | MetricsTableQueryMeterImpl. updateTableReadQueryMeter(TableName tableName) | 
| void | MetricsTableQueryMeter. updateTableReadQueryMeter(TableName tableName)Update table read QPS | 
| void | RegionServerTableMetrics. updateTableReadQueryMeter(TableName table,
                         long count) | 
| void | MetricsTableQueryMeterImpl. updateTableReadQueryMeter(TableName tableName,
                         long count) | 
| void | MetricsTableQueryMeter. updateTableReadQueryMeter(TableName tableName,
                         long count)Update table read QPS | 
| void | RegionServerTableMetrics. updateTableWriteQueryMeter(TableName table) | 
| void | MetricsTableQueryMeterImpl. updateTableWriteQueryMeter(TableName tableName) | 
| void | MetricsTableQueryMeter. updateTableWriteQueryMeter(TableName tableName)Update table write QPS | 
| void | RegionServerTableMetrics. updateTableWriteQueryMeter(TableName table,
                          long count) | 
| void | MetricsTableQueryMeterImpl. updateTableWriteQueryMeter(TableName tableName,
                          long count) | 
| void | MetricsTableQueryMeter. updateTableWriteQueryMeter(TableName tableName,
                          long count)Update table write QPS | 
| void | MetricsRegionServer. updateWriteQueryMeter(TableName tn) | 
| void | MetricsRegionServer. updateWriteQueryMeter(TableName tn,
                     long count) | 
| Constructor and Description | 
|---|
| HLogKey(byte[] encodedRegionName,
       TableName tablename)Deprecated.  | 
| HLogKey(byte[] encodedRegionName,
       TableName tablename,
       long now)Deprecated.  | 
| HLogKey(byte[] encodedRegionName,
       TableName tablename,
       long now,
       List<UUID> clusterIds,
       long nonceGroup,
       long nonce,
       MultiVersionConcurrencyControl mvcc)Deprecated.  Create the log key for writing to somewhere. | 
| HLogKey(byte[] encodedRegionName,
       TableName tablename,
       long logSeqNum,
       long now,
       List<UUID> clusterIds,
       long nonceGroup,
       long nonce,
       MultiVersionConcurrencyControl mvcc)Deprecated.  Create the log key for writing to somewhere. | 
| HLogKey(byte[] encodedRegionName,
       TableName tablename,
       long logSeqNum,
       long nonceGroup,
       long nonce,
       MultiVersionConcurrencyControl mvcc)Deprecated.  Create the log key for writing to somewhere. | 
| HLogKey(byte[] encodedRegionName,
       TableName tablename,
       long logSeqNum,
       long now,
       UUID clusterId)Deprecated.  | 
| HLogKey(byte[] encodedRegionName,
       TableName tablename,
       long now,
       MultiVersionConcurrencyControl mvcc)Deprecated.  | 
| ReplayHLogKey(byte[] encodedRegionName,
             TableName tablename,
             long now,
             List<UUID> clusterIds,
             long nonceGroup,
             long nonce,
             MultiVersionConcurrencyControl mvcc) | 
| ReplayHLogKey(byte[] encodedRegionName,
             TableName tablename,
             long logSeqNum,
             long now,
             List<UUID> clusterIds,
             long nonceGroup,
             long nonce,
             MultiVersionConcurrencyControl mvcc) | 
| WALEditsReplaySink(org.apache.hadoop.conf.Configuration conf,
                  TableName tableName,
                  HConnection conn)Create a sink for WAL log entries replay | 
| Modifier and Type | Method and Description | 
|---|---|
| static Map<TableName,List<String>> | ReplicationSerDeHelper. convert2Map(org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableCF[] tableCFs)Convert tableCFs Object to Map. | 
| Map<TableName,List<String>> | ReplicationPeersZKImpl. getPeerTableCFsConfig(String id) | 
| Map<TableName,List<String>> | ReplicationPeers. getPeerTableCFsConfig(String peerId)Get the table and column-family list of the peer from ZK. | 
| Map<TableName,List<String>> | ReplicationPeerZKImpl. getTableCFs()Get replicable (table, cf-list) map of this peer | 
| Map<TableName,List<String>> | ReplicationPeer. getTableCFs()Get replicable (table, cf-list) map of this peer | 
| Map<TableName,List<String>> | ReplicationPeersZKImpl. getTableCFs(String id) | 
| Map<TableName,List<String>> | ReplicationPeers. getTableCFs(String peerId)Get the table and column-family-list map of the peer. | 
| Map<TableName,List<String>> | ReplicationPeerConfig. getTableCFsMap() | 
| static Map<TableName,List<String>> | ReplicationSerDeHelper. parseTableCFsFromConfig(String tableCFsConfig)Convert tableCFs string into Map. | 
| Modifier and Type | Method and Description | 
|---|---|
| static org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableCF[] | ReplicationSerDeHelper. convert(Map<TableName,? extends Collection<String>> tableCfs)convert map to TableCFs Object | 
| static String | ReplicationSerDeHelper. convertToString(Map<TableName,? extends Collection<String>> tableCfs) | 
| void | ReplicationPeersZKImpl. setPeerTableCFsConfig(String id,
                     Map<TableName,? extends Collection<String>> tableCFs) | 
| void | ReplicationPeers. setPeerTableCFsConfig(String peerId,
                     Map<TableName,? extends Collection<String>> tableCFs)Set the table and column-family list of the peer to ZK. | 
| void | ReplicationPeerConfig. setTableCFsMap(Map<TableName,? extends Collection<String>> tableCFsMap) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | ReplicationSource. addHFileRefs(TableName tableName,
            byte[] family,
            List<Pair<org.apache.hadoop.fs.Path,org.apache.hadoop.fs.Path>> pairs) | 
| void | ReplicationSourceManager. addHFileRefs(TableName tableName,
            byte[] family,
            List<Pair<org.apache.hadoop.fs.Path,org.apache.hadoop.fs.Path>> pairs) | 
| void | ReplicationSourceInterface. addHFileRefs(TableName tableName,
            byte[] family,
            List<Pair<org.apache.hadoop.fs.Path,org.apache.hadoop.fs.Path>> pairs)Add hfile names to the queue to be replicated. | 
| protected void | ReplicationSink. batch(TableName tableName,
     Collection<List<Row>> allRows)Do the changes and handle the pool | 
| Modifier and Type | Method and Description | 
|---|---|
| TableName | RemoteHTable. getName() | 
| Modifier and Type | Field and Description | 
|---|---|
| static TableName | RSGroupInfoManager. RSGROUP_TABLE_NAME | 
| Modifier and Type | Method and Description | 
|---|---|
| NavigableSet<TableName> | RSGroupInfo. getTables()Set of tables that are members of this group | 
| Modifier and Type | Method and Description | 
|---|---|
| void | RSGroupInfo. addAllTables(Collection<TableName> arg) | 
| void | RSGroupAdmin. moveServersAndTables(Set<Address> servers,
                    Set<TableName> tables,
                    String targetGroup)Move given set of servers and tables to the specified target RegionServer group. | 
| void | RSGroupAdminServer. moveServersAndTables(Set<Address> servers,
                    Set<TableName> tables,
                    String targetGroup) | 
| void | RSGroupInfoManagerImpl. moveServersAndTables(Set<Address> servers,
                    Set<TableName> tables,
                    String srcGroup,
                    String dstGroup) | 
| void | RSGroupInfoManager. moveServersAndTables(Set<Address> servers,
                    Set<TableName> tables,
                    String srcGroup,
                    String dstGroup)Move servers and tables to a new group. | 
| void | RSGroupAdmin. moveTables(Set<TableName> tables,
          String targetGroup)Move given set of tables to the specified target RegionServer group. | 
| void | RSGroupAdminServer. moveTables(Set<TableName> tables,
          String targetGroup) | 
| void | RSGroupInfoManagerImpl. moveTables(Set<TableName> tableNames,
          String groupName) | 
| void | RSGroupInfoManager. moveTables(Set<TableName> tableNames,
          String groupName)Set the group membership of a set of tables | 
| void | RSGroupAdminEndpoint. postGetTableDescriptors(ObserverContext<MasterCoprocessorEnvironment> ctx,
                       List<TableName> tableNamesList,
                       List<HTableDescriptor> descriptors,
                       String regex) | 
| void | RSGroupAdminEndpoint. postMoveServersAndTables(ObserverContext<MasterCoprocessorEnvironment> ctx,
                        Set<Address> servers,
                        Set<TableName> tables,
                        String targetGroup) | 
| void | RSGroupAdminEndpoint. postMoveTables(ObserverContext<MasterCoprocessorEnvironment> ctx,
              Set<TableName> tables,
              String targetGroup) | 
| void | RSGroupAdminEndpoint. preGetTableDescriptors(ObserverContext<MasterCoprocessorEnvironment> ctx,
                      List<TableName> tableNamesList,
                      List<HTableDescriptor> descriptors) | 
| void | RSGroupAdminEndpoint. preGetTableDescriptors(ObserverContext<MasterCoprocessorEnvironment> ctx,
                      List<TableName> tableNamesList,
                      List<HTableDescriptor> descriptors,
                      String regex) | 
| void | RSGroupAdminEndpoint. preMoveServersAndTables(ObserverContext<MasterCoprocessorEnvironment> ctx,
                       Set<Address> servers,
                       Set<TableName> tables,
                       String targetGroup) | 
| void | RSGroupAdminEndpoint. preMoveTables(ObserverContext<MasterCoprocessorEnvironment> ctx,
             Set<TableName> tables,
             String targetGroup) | 
| Modifier and Type | Field and Description | 
|---|---|
| static TableName | AccessControlLists. ACL_TABLE_NAMEInternal storage table for access control lists | 
| static TableName | AccessControlClient. ACL_TABLE_NAME | 
| Modifier and Type | Method and Description | 
|---|---|
| TableName | AuthResult. getTableName() | 
| TableName | TablePermission. getTableName() | 
| Modifier and Type | Method and Description | 
|---|---|
| static AuthResult | AuthResult. allow(String request,
     String reason,
     User user,
     Permission.Action action,
     TableName table,
     byte[] family,
     byte[] qualifier) | 
| static AuthResult | AuthResult. allow(String request,
     String reason,
     User user,
     Permission.Action action,
     TableName table,
     Map<byte[],? extends Collection<?>> families) | 
| boolean | TableAuthManager. authorize(User user,
         TableName table,
         byte[] family,
         byte[] qualifier,
         Permission.Action action) | 
| boolean | TableAuthManager. authorize(User user,
         TableName table,
         byte[] family,
         Permission.Action action) | 
| boolean | TableAuthManager. authorize(User user,
         TableName table,
         Cell cell,
         Permission.Action action)Authorize a user for a given KV. | 
| boolean | TableAuthManager. authorizeGroup(String groupName,
              TableName table,
              byte[] family,
              byte[] qualifier,
              Permission.Action action)Checks authorization to a given table, column family and column for a group, based
 on the stored permissions. | 
| boolean | TableAuthManager. authorizeUser(User user,
             TableName table,
             byte[] family,
             byte[] qualifier,
             Permission.Action action) | 
| boolean | TableAuthManager. authorizeUser(User user,
             TableName table,
             byte[] family,
             Permission.Action action)Checks authorization to a given table and column family for a user, based on the
 stored user permissions. | 
| void | ZKPermissionWatcher. deleteTableACLNode(TableName tableName)Delete the acl notify node of table | 
| static AuthResult | AuthResult. deny(String request,
    String reason,
    User user,
    Permission.Action action,
    TableName table,
    byte[] family,
    byte[] qualifier) | 
| static AuthResult | AuthResult. deny(String request,
    String reason,
    User user,
    Permission.Action action,
    TableName table,
    Map<byte[],? extends Collection<?>> families) | 
| static com.google.common.collect.ListMultimap<String,TablePermission> | AccessControlLists. getTablePermissions(org.apache.hadoop.conf.Configuration conf,
                   TableName tableName) | 
| static void | AccessControlClient. grant(org.apache.hadoop.conf.Configuration conf,
     TableName tableName,
     String userName,
     byte[] family,
     byte[] qual,
     Permission.Action... actions)Deprecated. 
 | 
| static void | AccessControlClient. grant(Connection connection,
     TableName tableName,
     String userName,
     byte[] family,
     byte[] qual,
     boolean mergeExistingPermissions,
     Permission.Action... actions)Grants permission on the specified table for the specified user | 
| static void | AccessControlClient. grant(Connection connection,
     TableName tableName,
     String userName,
     byte[] family,
     byte[] qual,
     Permission.Action... actions)Grants permission on the specified table for the specified user. | 
| boolean | TableAuthManager. groupHasAccess(String groupName,
              TableName table,
              Permission.Action action)Checks if the user has access to the full table or at least a family/qualifier
 for the specified action. | 
| boolean | TableAuthManager. hasAccess(User user,
         TableName table,
         Permission.Action action) | 
| boolean | TablePermission. implies(TableName table,
       byte[] family,
       byte[] qualifier,
       Permission.Action action)Checks that a given table operation is authorized by this permission
 instance. | 
| boolean | TablePermission. implies(TableName table,
       KeyValue kv,
       Permission.Action action)Checks if this permission grants access to perform the given action on
 the given table and key value. | 
| boolean | TablePermission. matchesFamily(TableName table,
             byte[] family,
             Permission.Action action)Returns  trueif this permission matches the given column
 family at least. | 
| boolean | TablePermission. matchesFamilyQualifier(TableName table,
                      byte[] family,
                      byte[] qualifier,
                      Permission.Action action)Returns if the given permission matches the given qualifier. | 
| boolean | TableAuthManager. matchPermission(User user,
               TableName table,
               byte[] family,
               byte[] qualifier,
               Permission.Action action) | 
| boolean | TableAuthManager. matchPermission(User user,
               TableName table,
               byte[] family,
               Permission.Action action)Returns true if the given user has a  TablePermissionmatching up
 to the column family portion of a permission. | 
| void | AccessController. postDeleteColumn(ObserverContext<MasterCoprocessorEnvironment> c,
                TableName tableName,
                byte[] col) | 
| void | AccessController. postDeleteTable(ObserverContext<MasterCoprocessorEnvironment> c,
               TableName tableName) | 
| void | AccessController. postModifyTable(ObserverContext<MasterCoprocessorEnvironment> c,
               TableName tableName,
               HTableDescriptor htd) | 
| void | AccessController. postTruncateTable(ObserverContext<MasterCoprocessorEnvironment> ctx,
                 TableName tableName) | 
| void | AccessController. preAddColumn(ObserverContext<MasterCoprocessorEnvironment> c,
            TableName tableName,
            HColumnDescriptor column) | 
| void | AccessController. preDeleteColumn(ObserverContext<MasterCoprocessorEnvironment> c,
               TableName tableName,
               byte[] col) | 
| void | AccessController. preDeleteTable(ObserverContext<MasterCoprocessorEnvironment> c,
              TableName tableName) | 
| void | AccessController. preDisableTable(ObserverContext<MasterCoprocessorEnvironment> c,
               TableName tableName) | 
| void | AccessController. preEnableTable(ObserverContext<MasterCoprocessorEnvironment> c,
              TableName tableName) | 
| void | AccessController. preModifyColumn(ObserverContext<MasterCoprocessorEnvironment> c,
               TableName tableName,
               HColumnDescriptor descriptor) | 
| void | AccessController. preModifyTable(ObserverContext<MasterCoprocessorEnvironment> c,
              TableName tableName,
              HTableDescriptor htd) | 
| void | AccessController. preSetTableQuota(ObserverContext<MasterCoprocessorEnvironment> ctx,
                TableName tableName,
                org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Quotas quotas) | 
| void | AccessController. preSetUserQuota(ObserverContext<MasterCoprocessorEnvironment> ctx,
               String userName,
               TableName tableName,
               org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Quotas quotas) | 
| void | AccessController. preTableFlush(ObserverContext<MasterCoprocessorEnvironment> ctx,
             TableName tableName) | 
| void | AccessController. preTruncateTable(ObserverContext<MasterCoprocessorEnvironment> c,
                TableName tableName) | 
| void | TableAuthManager. refreshTableCacheFromWritable(TableName table,
                             byte[] data) | 
| void | TableAuthManager. removeTable(TableName table) | 
| void | AccessController. requireAccess(String request,
             TableName tableName,
             Permission.Action... permissions)Authorizes that the current user has any of the given permissions to access the table. | 
| void | AccessChecker. requireAccess(User user,
             String request,
             TableName tableName,
             Permission.Action... permissions)Authorizes that the current user has any of the given permissions to access the table. | 
| void | AccessController. requireGlobalPermission(String request,
                       Permission.Action perm,
                       TableName tableName,
                       Map<byte[],? extends Collection<byte[]>> familyMap)Checks that the user has the given global permission. | 
| void | AccessChecker. requireGlobalPermission(User user,
                       String request,
                       Permission.Action perm,
                       TableName tableName,
                       Map<byte[],? extends Collection<byte[]>> familyMap)Checks that the user has the given global permission. | 
| void | AccessController. requireNamespacePermission(String request,
                          String namespace,
                          TableName tableName,
                          Map<byte[],? extends Collection<byte[]>> familyMap,
                          Permission.Action... permissions)Checks that the user has the given global or namespace permission. | 
| void | AccessChecker. requireNamespacePermission(User user,
                          String request,
                          String namespace,
                          TableName tableName,
                          Map<byte[],? extends Collection<byte[]>> familyMap,
                          Permission.Action... permissions)Checks that the user has the given global or namespace permission. | 
| void | AccessController. requirePermission(String request,
                 TableName tableName,
                 byte[] family,
                 byte[] qualifier,
                 Permission.Action... permissions)Authorizes that the current user has any of the given permissions for the
 given table, column family and column qualifier. | 
| void | AccessChecker. requirePermission(User user,
                 String request,
                 TableName tableName,
                 byte[] family,
                 byte[] qualifier,
                 Permission.Action... permissions)Authorizes that the current user has any of the given permissions for the
 given table, column family and column qualifier. | 
| void | AccessController. requireTablePermission(String request,
                      TableName tableName,
                      byte[] family,
                      byte[] qualifier,
                      Permission.Action... permissions)Authorizes that the current user has any of the given permissions for the
 given table, column family and column qualifier. | 
| void | AccessChecker. requireTablePermission(User user,
                      String request,
                      TableName tableName,
                      byte[] family,
                      byte[] qualifier,
                      Permission.Action... permissions)Authorizes that the current user has any of the given permissions for the
 given table, column family and column qualifier. | 
| static void | AccessControlClient. revoke(org.apache.hadoop.conf.Configuration conf,
      TableName tableName,
      String username,
      byte[] family,
      byte[] qualifier,
      Permission.Action... actions)Deprecated. 
 | 
| static void | AccessControlClient. revoke(Connection connection,
      TableName tableName,
      String username,
      byte[] family,
      byte[] qualifier,
      Permission.Action... actions)Revokes the permission on the table | 
| void | TableAuthManager. setTableGroupPermissions(String group,
                        TableName table,
                        List<TablePermission> perms)Overwrites the existing permission set for a group and triggers an update
 for zookeeper synchronization. | 
| AuthResult.Params | AuthResult.Params. setTableName(TableName table) | 
| void | TablePermission. setTableName(TableName table) | 
| void | TableAuthManager. setTableUserPermissions(String username,
                       TableName table,
                       List<TablePermission> perms)Overwrites the existing permission set for a given user for a table, and
 triggers an update for zookeeper synchronization. | 
| boolean | TableAuthManager. userHasAccess(User user,
             TableName table,
             Permission.Action action)Checks if the user has access to the full table or at least a family/qualifier
 for the specified action. | 
| void | TableAuthManager. writeTableToZooKeeper(TableName table,
                     org.apache.hadoop.hbase.security.access.TableAuthManager.PermissionCache<TablePermission> tablePerms) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | AccessController. postGetTableDescriptors(ObserverContext<MasterCoprocessorEnvironment> ctx,
                       List<TableName> tableNamesList,
                       List<HTableDescriptor> descriptors,
                       String regex) | 
| void | AccessController. preGetTableDescriptors(ObserverContext<MasterCoprocessorEnvironment> ctx,
                      List<TableName> tableNamesList,
                      List<HTableDescriptor> descriptors,
                      String regex) | 
| void | AccessController. preMoveServersAndTables(ObserverContext<MasterCoprocessorEnvironment> ctx,
                       Set<Address> servers,
                       Set<TableName> tables,
                       String targetGroup) | 
| void | AccessController. preMoveTables(ObserverContext<MasterCoprocessorEnvironment> ctx,
             Set<TableName> tables,
             String targetGroup) | 
| Constructor and Description | 
|---|
| AuthResult(boolean allowed,
          String request,
          String reason,
          User user,
          Permission.Action action,
          TableName table,
          byte[] family,
          byte[] qualifier) | 
| AuthResult(boolean allowed,
          String request,
          String reason,
          User user,
          Permission.Action action,
          TableName table,
          Map<byte[],? extends Collection<?>> families) | 
| TablePermission(String namespace,
               TableName table,
               byte[] family,
               byte[] qualifier,
               byte[] actionCodes)Creates a new permission for the given namespace or table, family and column qualifier,
 allowing the actions matching the provided byte codes to be performed. | 
| TablePermission(String namespace,
               TableName table,
               byte[] family,
               byte[] qualifier,
               Permission.Action... assigned)Creates a new permission for the given namespace or table, restricted to the given
 column family and qualifier, allowing the assigned actions to be performed. | 
| TablePermission(TableName table,
               byte[] family,
               byte[] qualifier,
               byte[] actionCodes)Creates a new permission for the given table, family and column qualifier,
 allowing the actions matching the provided byte codes to be performed. | 
| TablePermission(TableName table,
               byte[] family,
               byte[] qualifier,
               Permission.Action... assigned)Creates a new permission for the given table, restricted to the given
 column family and qualifier, allowing the assigned actions to be performed. | 
| TablePermission(TableName table,
               byte[] family,
               Permission.Action... assigned)Create a new permission for the given table and (optionally) column family,
 allowing the given actions. | 
| UserPermission(byte[] user,
              TableName table,
              byte[] family,
              byte[] qualifier,
              byte[] actionCodes)Creates a new instance for the given user, table, column family and
 qualifier, matching the actions with the given codes. | 
| UserPermission(byte[] user,
              TableName table,
              byte[] family,
              byte[] qualifier,
              Permission.Action... assigned)Creates a new permission for the given user, table, column family and
 column qualifier. | 
| UserPermission(byte[] user,
              TableName table,
              byte[] family,
              Permission.Action... assigned)Creates a new instance for the given user, table and column family. | 
| Modifier and Type | Field and Description | 
|---|---|
| static TableName | VisibilityConstants. LABELS_TABLE_NAMEInternal storage table for visibility labels | 
| Modifier and Type | Method and Description | 
|---|---|
| void | VisibilityController. preAddColumn(ObserverContext<MasterCoprocessorEnvironment> ctx,
            TableName tableName,
            HColumnDescriptor column) | 
| void | VisibilityController. preDeleteColumn(ObserverContext<MasterCoprocessorEnvironment> ctx,
               TableName tableName,
               byte[] c) | 
| void | VisibilityController. preDisableTable(ObserverContext<MasterCoprocessorEnvironment> ctx,
               TableName tableName) | 
| void | VisibilityController. preModifyColumn(ObserverContext<MasterCoprocessorEnvironment> ctx,
               TableName tableName,
               HColumnDescriptor descriptor) | 
| void | VisibilityController. preModifyTable(ObserverContext<MasterCoprocessorEnvironment> ctx,
              TableName tableName,
              HTableDescriptor htd) | 
| Modifier and Type | Method and Description | 
|---|---|
| static HRegionInfo | RestoreSnapshotHelper. cloneRegionInfo(TableName tableName,
               HRegionInfo snapshotRegionInfo) | 
| static void | RestoreSnapshotHelper. restoreSnapshotACL(org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription snapshot,
                  TableName newTableName,
                  org.apache.hadoop.conf.Configuration conf) | 
| Constructor and Description | 
|---|
| TablePartiallyOpenException(TableName tableName) | 
| Modifier and Type | Field and Description | 
|---|---|
| static TableName | CanaryTool. DEFAULT_WRITE_TABLE_NAME | 
| Modifier and Type | Method and Description | 
|---|---|
| TableName | CanaryTool.RegionTaskResult. getTableName() | 
| Constructor and Description | 
|---|
| CanaryTool.RegionTaskResult(HRegionInfo region,
                           TableName tableName,
                           ServerName serverName) | 
| Modifier and Type | Method and Description | 
|---|---|
| TableName | HBaseFsck.TableInfo. getName() | 
| TableName | HBaseFsck.HbckInfo. getTableName() | 
| static TableName | FSUtils. getTableName(org.apache.hadoop.fs.Path tablePath)Returns the  TableNameobject representing
 the table directory under
 path rootdir | 
| Modifier and Type | Method and Description | 
|---|---|
| void | FSTableDescriptors. deleteTableDescriptorIfExists(TableName tableName)Deletes all the table descriptor files from the file system. | 
| HTableDescriptor | FSTableDescriptors. get(TableName tablename)Get the current table descriptor for the given table, or null if none exists. | 
| com.google.common.collect.Multimap<byte[],HBaseFsck.HbckInfo> | HBaseFsck. getOverlapGroups(TableName table) | 
| static org.apache.hadoop.fs.Path | HFileArchiveUtil. getRegionArchiveDir(org.apache.hadoop.fs.Path rootDir,
                   TableName tableName,
                   org.apache.hadoop.fs.Path regiondir)Get the archive directory for a given region under the specified table | 
| static org.apache.hadoop.fs.Path | HFileArchiveUtil. getRegionArchiveDir(org.apache.hadoop.fs.Path rootDir,
                   TableName tableName,
                   String encodedRegionName)Get the archive directory for a given region under the specified table | 
| static org.apache.hadoop.fs.Path | HFileArchiveUtil. getStoreArchivePath(org.apache.hadoop.conf.Configuration conf,
                   TableName tableName,
                   String regionName,
                   String familyName)Get the directory to archive a store directory | 
| static org.apache.hadoop.fs.Path | HFileArchiveUtil. getTableArchivePath(org.apache.hadoop.conf.Configuration conf,
                   TableName tableName)Get the path to the table archive directory based on the configured archive directory. | 
| static org.apache.hadoop.fs.Path | HFileArchiveUtil. getTableArchivePath(org.apache.hadoop.fs.Path rootdir,
                   TableName tableName)Get the path to the table archive directory based on the configured archive directory. | 
| static HTableDescriptor | 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. | 
| static HTableDescriptor | FSTableDescriptors. getTableDescriptorFromFs(org.apache.hadoop.fs.FileSystem fs,
                        org.apache.hadoop.fs.Path hbaseRootDir,
                        TableName tableName,
                        boolean rewritePb)Returns the latest table descriptor for the table located at the given directory
 directly from the file system if it exists. | 
| static org.apache.hadoop.fs.Path | FSUtils. getTableDir(org.apache.hadoop.fs.Path rootdir,
           TableName tableName)Returns the  Pathobject representing the table directory under
 path rootdir | 
| static Map<String,org.apache.hadoop.fs.Path> | FSUtils. getTableStoreFilePathMap(Map<String,org.apache.hadoop.fs.Path> map,
                        org.apache.hadoop.fs.FileSystem fs,
                        org.apache.hadoop.fs.Path hbaseRootDir,
                        TableName tableName)Runs through the HBase rootdir/tablename and creates a reverse lookup map for
 table StoreFile names to the full Path. | 
| static Map<String,org.apache.hadoop.fs.Path> | FSUtils. getTableStoreFilePathMap(Map<String,org.apache.hadoop.fs.Path> resultMap,
                        org.apache.hadoop.fs.FileSystem fs,
                        org.apache.hadoop.fs.Path hbaseRootDir,
                        TableName tableName,
                        org.apache.hadoop.fs.PathFilter sfFilter,
                        ExecutorService executor,
                        HBaseFsck.ErrorReporter errors)Runs through the HBase rootdir/tablename and creates a reverse lookup map for
 table StoreFile names to the full Path. | 
| static org.apache.hadoop.fs.Path | FSUtils. getWALRegionDir(org.apache.hadoop.conf.Configuration conf,
               TableName tableName,
               String encodedRegionName)Returns the WAL region directory based on the region info | 
| static org.apache.hadoop.fs.Path | FSUtils. getWALTableDir(org.apache.hadoop.conf.Configuration conf,
              TableName tableName)Returns the Table directory under the WALRootDir for the specified table name | 
| static org.apache.hadoop.fs.Path | FSUtils. getWrongWALRegionDir(org.apache.hadoop.conf.Configuration conf,
                    TableName tableName,
                    String encodedRegionName)Deprecated. 
 For compatibility, will be removed in 4.0.0. | 
| void | HBaseFsck. includeTable(TableName table) | 
| boolean | FSTableDescriptors. isTableInfoExists(TableName tableName)Checks if a current table info file exists for the given table | 
| <R> void | MultiHConnection. processBatchCallback(List<? extends Row> actions,
                    TableName tableName,
                    Object[] results,
                    Batch.Callback<R> callback)Randomly pick a connection and process the batch of actions for a given table | 
| HTableDescriptor | FSTableDescriptors. remove(TableName tablename)Removes the table descriptor from the local cache and returns it. | 
| Modifier and Type | Field and Description | 
|---|---|
| protected TableName | WALKey. tablename | 
| Modifier and Type | Method and Description | 
|---|---|
| TableName | WALKey. getTablename() | 
| TableName | WALSplitter.RegionEntryBuffer. getTableName() | 
| Modifier and Type | Method and Description | 
|---|---|
| protected void | WALKey. init(byte[] encodedRegionName,
    TableName tablename,
    long logSeqNum,
    long now,
    List<UUID> clusterIds,
    long nonceGroup,
    long nonce,
    MultiVersionConcurrencyControl mvcc) | 
| Constructor and Description | 
|---|
| WALKey(byte[] encodedRegionName,
      TableName tablename) | 
| WALKey(byte[] encodedRegionName,
      TableName tablename,
      long now) | 
| WALKey(byte[] encodedRegionName,
      TableName tablename,
      long now,
      List<UUID> clusterIds,
      long nonceGroup,
      long nonce,
      MultiVersionConcurrencyControl mvcc)Create the log key for writing to somewhere. | 
| WALKey(byte[] encodedRegionName,
      TableName tablename,
      long logSeqNum,
      long now,
      List<UUID> clusterIds,
      long nonceGroup,
      long nonce,
      MultiVersionConcurrencyControl mvcc)Create the log key for writing to somewhere. | 
| WALKey(byte[] encodedRegionName,
      TableName tablename,
      long logSeqNum,
      long nonceGroup,
      long nonce,
      MultiVersionConcurrencyControl mvcc)Create the log key for writing to somewhere. | 
| WALKey(byte[] encodedRegionName,
      TableName tablename,
      long logSeqNum,
      long now,
      UUID clusterId) | 
| WALKey(byte[] encodedRegionName,
      TableName tablename,
      long now,
      MultiVersionConcurrencyControl mvcc) | 
| Modifier and Type | Method and Description | 
|---|---|
| static Set<TableName> | ZKTableStateClientSideReader. getDisabledOrDisablingTables(ZooKeeperWatcher zkw)Gets a list of all the tables set as disabled in zookeeper. | 
| static Set<TableName> | ZKTableStateClientSideReader. getDisabledTables(ZooKeeperWatcher zkw)Gets a list of all the tables set as disabled in zookeeper. | 
| static Set<TableName> | ZKTableStateClientSideReader. getEnablingTables(ZooKeeperWatcher zkw)Gets a list of all the tables set as enabling in zookeeper. | 
| Set<TableName> | ZKTableStateManager. getTablesInStates(org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Table.State... states)Gets a list of all the tables set as disabling in zookeeper. | 
| Modifier and Type | Method and Description | 
|---|---|
| void | ZKTableStateManager. checkAndRemoveTableState(TableName tableName,
                        org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Table.State states,
                        boolean deletePermanentState)If the table is found in the given state the in-memory state is removed. | 
| static boolean | ZKTableStateClientSideReader. isDisabledTable(ZooKeeperWatcher zkw,
               TableName tableName)Go to zookeeper and see if state of table is  ZooKeeperProtos.Table.State#DISABLED. | 
| static boolean | ZKTableStateClientSideReader. isDisablingOrDisabledTable(ZooKeeperWatcher zkw,
                          TableName tableName)Go to zookeeper and see if state of table is  ZooKeeperProtos.Table.State#DISABLINGofZooKeeperProtos.Table.State#DISABLED. | 
| static boolean | ZKTableStateClientSideReader. isEnabledTable(ZooKeeperWatcher zkw,
              TableName tableName)Go to zookeeper and see if state of table is  ZooKeeperProtos.Table.State#ENABLED. | 
| boolean | ZKTableStateManager. isTablePresent(TableName tableName)check if table is present. | 
| boolean | ZKTableStateManager. isTableState(TableName tableName,
            boolean checkSource,
            org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Table.State... states)Checks if table is marked in specified state in ZK. | 
| boolean | ZKTableStateManager. isTableState(TableName tableName,
            org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Table.State... states)Checks if table is marked in specified state in ZK (using cache only). | 
| void | ZKTableStateManager. setDeletedTable(TableName tableName)Deletes the table in zookeeper. | 
| void | ZKTableStateManager. setTableState(TableName tableName,
             org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Table.State state)Sets table state in ZK. | 
| boolean | ZKTableStateManager. setTableStateIfInStates(TableName tableName,
                       org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Table.State newState,
                       org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Table.State... states)Checks and sets table state in ZK. | 
| boolean | ZKTableStateManager. setTableStateIfNotInStates(TableName tableName,
                          org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Table.State newState,
                          org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Table.State... states)Checks and sets table state in ZK. | 
Copyright © 2007–2019 The Apache Software Foundation. All rights reserved.