Uses of Class
org.apache.hadoop.hbase.TableName

Packages that use org.apache.hadoop.hbase.TableName
  • Uses of org.apache.hadoop.hbase.TableName in org.apache.hadoop.hbase

    Fields in org.apache.hadoop.hbase declared as org.apache.hadoop.hbase.TableName in in
    Modifier and Type
    Field
    Description
    static final org.apache.hadoop.hbase.TableName
    HConstants.ENSEMBLE_TABLE_NAME
    The name of the ensemble table
    static final org.apache.hadoop.hbase.TableName
    TableName.META_TABLE_NAME
    The hbase:meta table's name.
    static final org.apache.hadoop.hbase.TableName
    TableName.NAMESPACE_TABLE_NAME
    The Namespace table's name.
    static final org.apache.hadoop.hbase.TableName
    TableName.OLD_META_TABLE_NAME
    TableName for old .META.
    static final org.apache.hadoop.hbase.TableName
    TableName.OLD_ROOT_TABLE_NAME
    TableName for old -ROOT- table.
    Methods in org.apache.hadoop.hbase that return org.apache.hadoop.hbase.TableName in in
    Modifier and Type
    Method
    Description
    org.apache.hadoop.hbase.TableName
    HRegionInfo.getTable()
    Deprecated.
    Get current table name of the region
    static org.apache.hadoop.hbase.TableName
    HRegionInfo.getTable(byte[] regionName)
    Deprecated.
    As of release 2.0.0, this will be removed in HBase 3.0.0 Use RegionInfo.getTable(byte[]).
    org.apache.hadoop.hbase.TableName
    HTableDescriptor.getTableName()
    Deprecated.
    Get the name of the table
    static org.apache.hadoop.hbase.TableName
    TableName.valueOf(byte[] fullName)
    Construct a TableName
    static org.apache.hadoop.hbase.TableName
    TableName.valueOf(byte[] namespace, byte[] qualifier)
     
    static org.apache.hadoop.hbase.TableName
    TableName.valueOf(byte[] fullName, int offset, int length)
    Construct a TableName
    static org.apache.hadoop.hbase.TableName
    TableName.valueOf(String name)
    Construct a TableName
    static org.apache.hadoop.hbase.TableName
    TableName.valueOf(String namespaceAsString, String qualifierAsString)
     
    static org.apache.hadoop.hbase.TableName
    TableName.valueOf(ByteBuffer fullname)
    Construct a TableName
    static org.apache.hadoop.hbase.TableName
    TableName.valueOf(ByteBuffer namespace, ByteBuffer qualifier)
     
    Methods in org.apache.hadoop.hbase that return types with arguments of type org.apache.hadoop.hbase.TableName in in
    Modifier and Type
    Method
    Description
    Map<org.apache.hadoop.hbase.TableName,org.apache.hadoop.hbase.client.RegionStatesCount>
    ClusterMetrics.getTableRegionStatesCount()
    Provide region states count for given table.
    Map<org.apache.hadoop.hbase.TableName,org.apache.hadoop.hbase.client.RegionStatesCount>
    ClusterStatus.getTableRegionStatesCount()
    Deprecated.
     
    static Map<org.apache.hadoop.hbase.TableName,org.apache.hadoop.hbase.client.TableState>
    MetaTableAccessor.getTableStates(org.apache.hadoop.hbase.client.Connection conn)
    Fetch table states from META table
    Methods in org.apache.hadoop.hbase with parameters of type org.apache.hadoop.hbase.TableName in in
    Modifier and Type
    Method
    Description
    int
    TableName.compareTo(org.apache.hadoop.hbase.TableName tableName)
     
    static byte[]
    HRegionInfo.createRegionName(org.apache.hadoop.hbase.TableName tableName, byte[] startKey, byte[] id, boolean newFormat)
    Deprecated.
    As of release 2.0.0, this will be removed in HBase 3.0.0 Use RegionInfo.createRegionName(TableName, byte[], byte[], boolean).
    static byte[]
    HRegionInfo.createRegionName(org.apache.hadoop.hbase.TableName tableName, byte[] startKey, byte[] id, int replicaId, boolean newFormat)
    Deprecated.
    As of release 2.0.0, this will be removed in HBase 3.0.0 Use RegionInfo.createRegionName(TableName, byte[], byte[], int, boolean).
    static byte[]
    HRegionInfo.createRegionName(org.apache.hadoop.hbase.TableName tableName, byte[] startKey, long regionId, boolean newFormat)
    Deprecated.
    As of release 2.0.0, this will be removed in HBase 3.0.0 Use RegionInfo.createRegionName(TableName, byte[], long, boolean).
    static byte[]
    HRegionInfo.createRegionName(org.apache.hadoop.hbase.TableName tableName, byte[] startKey, long regionId, int replicaId, boolean newFormat)
    Deprecated.
    As of release 2.0.0, this will be removed in HBase 3.0.0 Use RegionInfo.createRegionName(TableName, byte[], long, int, boolean).
    static byte[]
    HRegionInfo.createRegionName(org.apache.hadoop.hbase.TableName tableName, byte[] startKey, String id, boolean newFormat)
    Deprecated.
    As of release 2.0.0, this will be removed in HBase 3.0.0 Use RegionInfo.createRegionName(TableName, byte[], String, boolean).
    static void
    MetaTableAccessor.deleteTableState(org.apache.hadoop.hbase.client.Connection connection, org.apache.hadoop.hbase.TableName table)
    Remove state for table from meta
    default boolean
    TableDescriptors.exists(org.apache.hadoop.hbase.TableName tableName)
    Test whether a given table exists, i.e, has a table descriptor.
    org.apache.hadoop.hbase.client.TableDescriptor
    TableDescriptors.get(org.apache.hadoop.hbase.TableName tableName)
    Returns TableDescriptor for tablename
    org.apache.hadoop.hbase.client.BufferedMutator
    SharedConnection.getBufferedMutator(org.apache.hadoop.hbase.TableName tableName)
     
    CellComparatorImpl.getCellComparator(org.apache.hadoop.hbase.TableName tableName)
    Utility method that makes a guess at comparator to use based off passed tableName.
    InnerStoreCellComparator.getInnerStoreCellComparator(org.apache.hadoop.hbase.TableName tableName)
    Utility method that makes a guess at comparator to use based off passed tableName.
    default long
    ClusterMetrics.getLastMajorCompactionTimestamp(org.apache.hadoop.hbase.TableName table)
     
    long
    ClusterStatus.getLastMajorCompactionTsForTable(org.apache.hadoop.hbase.TableName table)
    Deprecated.
    As of release 2.0.0, this will be removed in HBase 3.0.0 Use ClusterMetrics.getLastMajorCompactionTimestamp(TableName) instead.
    org.apache.hadoop.hbase.client.RegionLocator
    SharedConnection.getRegionLocator(org.apache.hadoop.hbase.TableName tableName)
     
    static org.apache.hadoop.hbase.MetaTableAccessor.ReplicationBarrierResult
    MetaTableAccessor.getReplicationBarrierResult(org.apache.hadoop.hbase.client.Connection conn, org.apache.hadoop.hbase.TableName tableName, byte[] row, byte[] encodedRegionName)
     
    static org.apache.hadoop.hbase.client.Scan
    MetaTableAccessor.getScanForTableName(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.TableName tableName)
    This method creates a Scan object that will only scan catalog rows that belong to the specified table.
    org.apache.hadoop.hbase.client.TableBuilder
    SharedConnection.getTableBuilder(org.apache.hadoop.hbase.TableName tableName, ExecutorService pool)
     
    static List<org.apache.hadoop.hbase.util.Pair<String,Long>>
    MetaTableAccessor.getTableEncodedRegionNameAndLastBarrier(org.apache.hadoop.hbase.client.Connection conn, org.apache.hadoop.hbase.TableName tableName)
     
    static List<String>
    MetaTableAccessor.getTableEncodedRegionNamesForSerialReplication(org.apache.hadoop.hbase.client.Connection conn, org.apache.hadoop.hbase.TableName tableName)
     
    static CompletableFuture<List<org.apache.hadoop.hbase.HRegionLocation>>
    AsyncMetaTableAccessor.getTableHRegionLocations(org.apache.hadoop.hbase.client.AsyncTable<org.apache.hadoop.hbase.client.AdvancedScanResultConsumer> metaTable, org.apache.hadoop.hbase.TableName tableName)
    Used to get all region locations for the specific table
    static List<org.apache.hadoop.hbase.client.RegionInfo>
    MetaTableAccessor.getTableRegions(org.apache.hadoop.hbase.client.Connection connection, org.apache.hadoop.hbase.TableName tableName)
    Gets all of the regions of the specified table.
    static List<org.apache.hadoop.hbase.client.RegionInfo>
    MetaTableAccessor.getTableRegions(org.apache.hadoop.hbase.client.Connection connection, org.apache.hadoop.hbase.TableName tableName, boolean excludeOfflinedSplitParents)
    Gets all of the regions of the specified table.
    static List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.client.RegionInfo,org.apache.hadoop.hbase.ServerName>>
    MetaTableAccessor.getTableRegionsAndLocations(org.apache.hadoop.hbase.client.Connection connection, org.apache.hadoop.hbase.TableName tableName)
    Do not use this method to get meta table regions, use methods in MetaTableLocator instead.
    static List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.client.RegionInfo,org.apache.hadoop.hbase.ServerName>>
    MetaTableAccessor.getTableRegionsAndLocations(org.apache.hadoop.hbase.client.Connection connection, org.apache.hadoop.hbase.TableName tableName, boolean excludeOfflinedSplitParents)
    Do not use this method to get meta table regions, use methods in MetaTableLocator instead.
    static byte[]
    MetaTableAccessor.getTableStartRowForMeta(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.MetaTableAccessor.QueryType type)
    Returns start row for scanning META according to query type
    static CompletableFuture<Optional<org.apache.hadoop.hbase.client.TableState>>
    AsyncMetaTableAccessor.getTableState(org.apache.hadoop.hbase.client.AsyncTable<?> metaTable, org.apache.hadoop.hbase.TableName tableName)
     
    static org.apache.hadoop.hbase.client.TableState
    MetaTableAccessor.getTableState(org.apache.hadoop.hbase.client.Connection conn, org.apache.hadoop.hbase.TableName tableName)
    Fetch table state for given table from META table
    static byte[]
    MetaTableAccessor.getTableStopRowForMeta(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.MetaTableAccessor.QueryType type)
    Returns stop row for scanning META according to query type
    static boolean
    TableName.isMetaTableName(org.apache.hadoop.hbase.TableName tn)
    Returns True if tn is the hbase:meta table name.
    org.apache.hadoop.hbase.client.TableDescriptor
    TableDescriptors.remove(org.apache.hadoop.hbase.TableName tablename)
    Returns Instance of table descriptor or null if none found.
    static void
    MetaTableAccessor.scanMeta(org.apache.hadoop.hbase.client.Connection connection, org.apache.hadoop.hbase.MetaTableAccessor.Visitor visitor, org.apache.hadoop.hbase.TableName tableName, byte[] row, int rowLimit)
    Performs a scan of META table for given table starting from given row.
    static void
    MetaTableAccessor.scanMetaForTableRegions(org.apache.hadoop.hbase.client.Connection connection, org.apache.hadoop.hbase.MetaTableAccessor.Visitor visitor, org.apache.hadoop.hbase.TableName tableName)
     
    static void
    MetaTableAccessor.scanMetaForTableRegions(org.apache.hadoop.hbase.client.Connection connection, org.apache.hadoop.hbase.MetaTableAccessor.Visitor visitor, org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.CatalogReplicaMode metaReplicaMode)
     
    AsyncMetaTableAccessor.tableExists(org.apache.hadoop.hbase.client.AsyncTable<?> metaTable, org.apache.hadoop.hbase.TableName tableName)
     
    static void
    MetaTableAccessor.updateTableState(org.apache.hadoop.hbase.client.Connection conn, org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.TableState.State actual)
    Updates state in META Do not use.
    Method parameters in org.apache.hadoop.hbase with type arguments of type org.apache.hadoop.hbase.TableName in in
    Modifier and Type
    Method
    Description
    org.apache.hadoop.hbase.ClusterMetricsBuilder
    ClusterMetricsBuilder.setTableRegionStatesCount(Map<org.apache.hadoop.hbase.TableName,org.apache.hadoop.hbase.client.RegionStatesCount> tableRegionStatesCount)
     
    Constructors in org.apache.hadoop.hbase with parameters of type org.apache.hadoop.hbase.TableName in in
    Modifier
    Constructor
    Description
     
    ConcurrentTableModificationException(org.apache.hadoop.hbase.TableName tableName)
     
     
    HRegionInfo(long regionId, org.apache.hadoop.hbase.TableName tableName, int replicaId)
    Deprecated.
     
     
    HRegionInfo(org.apache.hadoop.hbase.TableName tableName)
    Deprecated.
     
     
    HRegionInfo(org.apache.hadoop.hbase.TableName tableName, byte[] startKey, byte[] endKey)
    Deprecated.
    Construct HRegionInfo with explicit parameters
     
    HRegionInfo(org.apache.hadoop.hbase.TableName tableName, byte[] startKey, byte[] endKey, boolean split)
    Deprecated.
    Construct HRegionInfo with explicit parameters
     
    HRegionInfo(org.apache.hadoop.hbase.TableName tableName, byte[] startKey, byte[] endKey, boolean split, long regionId)
    Deprecated.
    Construct HRegionInfo with explicit parameters
     
    HRegionInfo(org.apache.hadoop.hbase.TableName tableName, byte[] startKey, byte[] endKey, boolean split, long regionId, int replicaId)
    Deprecated.
    Construct HRegionInfo with explicit parameters
     
    HTableDescriptor(org.apache.hadoop.hbase.TableName name)
    Deprecated.
    Construct a table descriptor specifying a TableName object
     
    HTableDescriptor(org.apache.hadoop.hbase.TableName name, org.apache.hadoop.hbase.HTableDescriptor desc)
    Deprecated.
    Construct a table descriptor by cloning the descriptor passed as a parameter but using a different table name.
     
    TableExistsException(org.apache.hadoop.hbase.TableName tableName)
     
     
    TableNotDisabledException(org.apache.hadoop.hbase.TableName tableName)
     
     
    TableNotEnabledException(org.apache.hadoop.hbase.TableName tableName)
     
     
    TableNotFoundException(org.apache.hadoop.hbase.TableName tableName)
     
     
    TableVisitorBase(org.apache.hadoop.hbase.TableName tableName)
     
  • Uses of org.apache.hadoop.hbase.TableName in org.apache.hadoop.hbase.backup

    Methods in org.apache.hadoop.hbase.backup that return org.apache.hadoop.hbase.TableName in in
    Modifier and Type
    Method
    Description
    org.apache.hadoop.hbase.TableName[]
    RestoreRequest.getFromTables()
     
    org.apache.hadoop.hbase.TableName
    BackupTableInfo.getTable()
     
    org.apache.hadoop.hbase.TableName
    BackupInfo.getTableBySnapshot(String snapshotName)
     
    org.apache.hadoop.hbase.TableName[]
    RestoreRequest.getToTables()
     
    Methods in org.apache.hadoop.hbase.backup that return types with arguments of type org.apache.hadoop.hbase.TableName in in
    Modifier and Type
    Method
    Description
    Map<org.apache.hadoop.hbase.TableName,Map<String,Long>>
    BackupInfo.getIncrTimestampMap()
    Get new region server log timestamps after distributed log roll
    List<org.apache.hadoop.hbase.TableName>
    BackupRequest.getTableList()
     
    List<org.apache.hadoop.hbase.TableName>
    BackupInfo.getTableNames()
     
    Set<org.apache.hadoop.hbase.TableName>
    BackupInfo.getTables()
     
    Map<org.apache.hadoop.hbase.TableName,Map<String,Long>>
    BackupInfo.getTableSetTimestampMap()
     
    Methods in org.apache.hadoop.hbase.backup with parameters of type org.apache.hadoop.hbase.TableName in in
    Modifier and Type
    Method
    Description
    void
    BackupInfo.addTables(org.apache.hadoop.hbase.TableName[] tables)
     
    void
    BackupAdmin.addToBackupSet(String name, org.apache.hadoop.hbase.TableName[] tables)
    Add tables to backup set command
    static void
    HBackupFileSystem.checkImageManifestExist(HashMap<org.apache.hadoop.hbase.TableName,org.apache.hadoop.hbase.backup.impl.BackupManifest> backupManifestMap, org.apache.hadoop.hbase.TableName[] tableArray, org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.fs.Path backupRootPath, String backupId)
    Check whether the backup image path and there is manifest file in the path.
    org.apache.hadoop.hbase.backup.BackupTableInfo
    BackupInfo.getBackupTableInfo(org.apache.hadoop.hbase.TableName table)
     
    BackupInfo.getSnapshotName(org.apache.hadoop.hbase.TableName table)
     
    static String
    HBackupFileSystem.getTableBackupDataDir(String backupRootDir, String backupId, org.apache.hadoop.hbase.TableName tableName)
     
    BackupInfo.getTableBackupDir(org.apache.hadoop.hbase.TableName tableName)
     
    static String
    HBackupFileSystem.getTableBackupDir(String backupRootDir, String backupId, org.apache.hadoop.hbase.TableName tableName)
    Given the backup root dir, backup id and the table name, return the backup image location, which is also where the backup manifest file is.
    static org.apache.hadoop.fs.Path
    HBackupFileSystem.getTableBackupPath(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.fs.Path backupRootPath, String backupId)
    Given the backup root dir, backup id and the table name, return the backup image location, which is also where the backup manifest file is.
    void
    BackupAdmin.removeFromBackupSet(String name, org.apache.hadoop.hbase.TableName[] tables)
    Remove tables from backup set
    void
    RestoreJob.run(org.apache.hadoop.fs.Path[] dirPaths, org.apache.hadoop.hbase.TableName[] fromTables, org.apache.hadoop.fs.Path restoreRootDir, org.apache.hadoop.hbase.TableName[] toTables, boolean fullBackupRestore)
    Run restore operation
    void
    BackupInfo.setSnapshotName(org.apache.hadoop.hbase.TableName table, String snapshotName)
     
    org.apache.hadoop.hbase.backup.RestoreRequest.Builder
    RestoreRequest.Builder.withFromTables(org.apache.hadoop.hbase.TableName[] fromTables)
     
    org.apache.hadoop.hbase.backup.RestoreRequest.Builder
    RestoreRequest.Builder.withToTables(org.apache.hadoop.hbase.TableName[] toTables)
     
    Method parameters in org.apache.hadoop.hbase.backup with type arguments of type org.apache.hadoop.hbase.TableName in in
    Modifier and Type
    Method
    Description
    static void
    HBackupFileSystem.checkImageManifestExist(HashMap<org.apache.hadoop.hbase.TableName,org.apache.hadoop.hbase.backup.impl.BackupManifest> backupManifestMap, org.apache.hadoop.hbase.TableName[] tableArray, org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.fs.Path backupRootPath, String backupId)
    Check whether the backup image path and there is manifest file in the path.
    void
    BackupInfo.setBackupTableInfoMap(Map<org.apache.hadoop.hbase.TableName,org.apache.hadoop.hbase.backup.BackupTableInfo> backupTableInfoMap)
     
    void
    BackupInfo.setIncrTimestampMap(Map<org.apache.hadoop.hbase.TableName,Map<String,Long>> prevTableSetTimestampMap)
    Set the new region server log timestamps after distributed log roll
    void
    BackupInfo.setTables(List<org.apache.hadoop.hbase.TableName> tables)
     
    void
    BackupInfo.setTableSetTimestampMap(Map<org.apache.hadoop.hbase.TableName,Map<String,Long>> tableSetTimestampMap)
     
    org.apache.hadoop.hbase.backup.BackupRequest.Builder
    BackupRequest.Builder.withTableList(List<org.apache.hadoop.hbase.TableName> tables)
     
    Constructors in org.apache.hadoop.hbase.backup with parameters of type org.apache.hadoop.hbase.TableName in in
    Modifier
    Constructor
    Description
     
    BackupInfo(String backupId, org.apache.hadoop.hbase.backup.BackupType type, org.apache.hadoop.hbase.TableName[] tables, String targetRootDir)
     
     
    BackupTableInfo(org.apache.hadoop.hbase.TableName table, String targetRootDir, String backupId)
     
  • Uses of org.apache.hadoop.hbase.TableName in org.apache.hadoop.hbase.client

    Fields in org.apache.hadoop.hbase.client declared as org.apache.hadoop.hbase.TableName in in
    Modifier and Type
    Field
    Description
    protected final org.apache.hadoop.hbase.TableName
    ClientScanner.tableName
     
    protected final org.apache.hadoop.hbase.TableName
    RegionAdminServiceCallable.tableName
     
    protected final org.apache.hadoop.hbase.TableName
    RpcRetryingCallerWithReadReplicas.tableName
     
    Methods in org.apache.hadoop.hbase.client that return org.apache.hadoop.hbase.TableName in in
    Modifier and Type
    Method
    Description
    org.apache.hadoop.hbase.TableName
    AsyncBufferedMutator.getName()
    Gets the fully qualified table name instance of the table that this AsyncBufferedMutator writes to.
    org.apache.hadoop.hbase.TableName
    AsyncTable.getName()
    Gets the fully qualified table name instance of this table.
    org.apache.hadoop.hbase.TableName
    AsyncTableRegionLocator.getName()
    Gets the fully qualified table name instance of the table whose region we want to locate.
    org.apache.hadoop.hbase.TableName
    BufferedMutator.getName()
    Gets the fully qualified table name instance of the table that this BufferedMutator writes to.
    org.apache.hadoop.hbase.TableName
    BufferedMutatorImpl.getName()
     
    org.apache.hadoop.hbase.TableName
    HRegionLocator.getName()
     
    org.apache.hadoop.hbase.TableName
    HTable.getName()
     
    org.apache.hadoop.hbase.TableName
    RegionLocator.getName()
    Gets the fully qualified table name instance of this table.
    org.apache.hadoop.hbase.TableName
    Table.getName()
    Gets the fully qualified table name instance of this table.
    protected org.apache.hadoop.hbase.TableName
    ClientScanner.getTable()
     
    org.apache.hadoop.hbase.TableName
    RegionInfo.getTable()
    Returns current table name of the region
    static org.apache.hadoop.hbase.TableName
    RegionInfo.getTable(byte[] regionName)
    Gets the table name from the specified region name.
    org.apache.hadoop.hbase.TableName
    AsyncProcessTask.getTableName()
     
    org.apache.hadoop.hbase.TableName
    BufferedMutatorParams.getTableName()
     
    protected org.apache.hadoop.hbase.TableName
    HBaseAdmin.TableFuture.getTableName()
    Returns the table name
    org.apache.hadoop.hbase.TableName
    RegionServerCallable.getTableName()
     
    org.apache.hadoop.hbase.TableName
    SnapshotDescription.getTableName()
     
    org.apache.hadoop.hbase.TableName
    TableDescriptor.getTableName()
    Get the name of the table
    org.apache.hadoop.hbase.TableName
    TableDescriptorBuilder.ModifyableTableDescriptor.getTableName()
    Get the name of the table
    org.apache.hadoop.hbase.TableName
    TableState.getTableName()
    Table name for state
    org.apache.hadoop.hbase.TableName[]
    Admin.listTableNames()
    List all of the names of userspace tables.
    org.apache.hadoop.hbase.TableName[]
    Admin.listTableNames(String regex)
    Deprecated.
    since 2.0 version and will be removed in 3.0 version.
    org.apache.hadoop.hbase.TableName[]
    Admin.listTableNames(String regex, boolean includeSysTables)
    Deprecated.
    since 2.0 version and will be removed in 3.0 version.
    default org.apache.hadoop.hbase.TableName[]
    Admin.listTableNames(Pattern pattern)
    List all of the names of userspace tables.
    org.apache.hadoop.hbase.TableName[]
    Admin.listTableNames(Pattern pattern, boolean includeSysTables)
    List all of the names of userspace tables.
    org.apache.hadoop.hbase.TableName[]
    HBaseAdmin.listTableNames()
     
    org.apache.hadoop.hbase.TableName[]
    HBaseAdmin.listTableNames(String regex)
     
    org.apache.hadoop.hbase.TableName[]
    HBaseAdmin.listTableNames(String regex, boolean includeSysTables)
     
    org.apache.hadoop.hbase.TableName[]
    HBaseAdmin.listTableNames(Pattern pattern, boolean includeSysTables)
     
    org.apache.hadoop.hbase.TableName[]
    Admin.listTableNamesByNamespace(String name)
    Get list of table names by namespace.
    org.apache.hadoop.hbase.TableName[]
    HBaseAdmin.listTableNamesByNamespace(String name)
     
    Methods in org.apache.hadoop.hbase.client that return types with arguments of type org.apache.hadoop.hbase.TableName in in
    Modifier and Type
    Method
    Description
    Map<org.apache.hadoop.hbase.TableName,? extends org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshotView>
    Admin.getRegionServerSpaceQuotaSnapshots(org.apache.hadoop.hbase.ServerName serverName)
    Fetches the observed SpaceQuotaSnapshotViews observed by a RegionServer.
    CompletableFuture<? extends Map<org.apache.hadoop.hbase.TableName,? extends org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshotView>>
    AsyncAdmin.getRegionServerSpaceQuotaSnapshots(org.apache.hadoop.hbase.ServerName serverName)
    Fetches the observed SpaceQuotaSnapshotViews observed by a RegionServer.
    Map<org.apache.hadoop.hbase.TableName,org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot>
    HBaseAdmin.getRegionServerSpaceQuotaSnapshots(org.apache.hadoop.hbase.ServerName serverName)
     
    Map<org.apache.hadoop.hbase.TableName,Long>
    Admin.getSpaceQuotaTableSizes()
    Fetches the table sizes on the filesystem as tracked by the HBase Master.
    CompletableFuture<Map<org.apache.hadoop.hbase.TableName,Long>>
    AsyncAdmin.getSpaceQuotaTableSizes()
    Fetches the table sizes on the filesystem as tracked by the HBase Master.
    Map<org.apache.hadoop.hbase.TableName,Long>
    HBaseAdmin.getSpaceQuotaTableSizes()
     
    protected Optional<org.apache.hadoop.hbase.TableName>
    AsyncRpcRetryingCaller.getTableName()
     
    List<org.apache.hadoop.hbase.TableName>
    NormalizeTableFilterParams.getTableNames()
     
    default CompletableFuture<List<org.apache.hadoop.hbase.TableName>>
    AsyncAdmin.listTableNames()
    List all of the names of userspace tables.
    CompletableFuture<List<org.apache.hadoop.hbase.TableName>>
    AsyncAdmin.listTableNames(boolean includeSysTables)
    List all of the names of tables.
    CompletableFuture<List<org.apache.hadoop.hbase.TableName>>
    AsyncAdmin.listTableNames(Pattern pattern, boolean includeSysTables)
    List all of the names of userspace tables.
    CompletableFuture<List<org.apache.hadoop.hbase.TableName>>
    AsyncAdmin.listTableNamesByNamespace(String name)
    Get list of table names by namespace.
    List<org.apache.hadoop.hbase.TableName>
    Admin.listTableNamesByState(boolean isEnabled)
    List all enabled or disabled table names
    CompletableFuture<List<org.apache.hadoop.hbase.TableName>>
    AsyncAdmin.listTableNamesByState(boolean isEnabled)
    List all enabled or disabled table names
    List<org.apache.hadoop.hbase.TableName>
    HBaseAdmin.listTableNamesByState(boolean isEnabled)
     
    Methods in org.apache.hadoop.hbase.client with parameters of type org.apache.hadoop.hbase.TableName in in
    Modifier and Type
    Method
    Description
    default void
    Admin.addColumn(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.ColumnFamilyDescriptor columnFamily)
    Deprecated.
    As of release 2.0.0.
    default void
    Admin.addColumnFamily(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.ColumnFamilyDescriptor columnFamily)
    Add a column family to an existing table.
    AsyncAdmin.addColumnFamily(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.ColumnFamilyDescriptor columnFamily)
    Add a column family to an existing table.
    Admin.addColumnFamilyAsync(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.ColumnFamilyDescriptor columnFamily)
    Add a column family to an existing table.
    HBaseAdmin.addColumnFamilyAsync(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.ColumnFamilyDescriptor columnFamily)
     
    void
    ClusterConnection.cacheLocation(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.RegionLocations location)
     
    void
    ConnectionImplementation.cacheLocation(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.RegionLocations location)
    Put a newly discovered HRegionLocation into the cache.
    void
    MetaCache.cacheLocation(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.RegionLocations locations)
    Put a newly discovered HRegionLocation into the cache.
    void
    MetaCache.cacheLocation(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.ServerName source, org.apache.hadoop.hbase.HRegionLocation location)
    Put a newly discovered HRegionLocation into the cache.
    org.apache.hadoop.hbase.CacheEvictionStats
    Admin.clearBlockCache(org.apache.hadoop.hbase.TableName tableName)
    Clear all the blocks corresponding to this table from BlockCache.
    CompletableFuture<org.apache.hadoop.hbase.CacheEvictionStats>
    AsyncAdmin.clearBlockCache(org.apache.hadoop.hbase.TableName tableName)
    Clear all the blocks corresponding to this table from BlockCache.
    org.apache.hadoop.hbase.CacheEvictionStats
    HBaseAdmin.clearBlockCache(org.apache.hadoop.hbase.TableName tableName)
    Clear all the blocks corresponding to this table from BlockCache.
    void
    MetaCache.clearCache(org.apache.hadoop.hbase.TableName tableName)
    Delete all cached entries of a table.
    Synchronized because of calls in cacheLocation which need to be executed atomically
    void
    MetaCache.clearCache(org.apache.hadoop.hbase.TableName tableName, byte[] row)
    Delete a cached location, no matter what it is.
    void
    MetaCache.clearCache(org.apache.hadoop.hbase.TableName tableName, byte[] row, int replicaId)
    Delete a cached location with specific replicaId.
    Synchronized because of calls in cacheLocation which need to be executed atomically
    void
    MetaCache.clearCache(org.apache.hadoop.hbase.TableName tableName, byte[] row, org.apache.hadoop.hbase.ServerName serverName)
    Delete a cached location for a table, row and server.
    void
    ClusterConnection.clearRegionCache(org.apache.hadoop.hbase.TableName tableName)
    Allows flushing the region cache of all locations that pertain to tableName
    void
    ConnectionImplementation.clearRegionCache(org.apache.hadoop.hbase.TableName tableName)
     
    void
    ConnectionImplementation.clearRegionCache(org.apache.hadoop.hbase.TableName tableName, byte[] row)
     
    default void
    Admin.cloneSnapshot(byte[] snapshotName, org.apache.hadoop.hbase.TableName tableName)
    Deprecated.
    since 2.3.0, will be removed in 3.0.0.
    default void
    Admin.cloneSnapshot(String snapshotName, org.apache.hadoop.hbase.TableName tableName)
    Create a new table by cloning the snapshot content.
    default void
    Admin.cloneSnapshot(String snapshotName, org.apache.hadoop.hbase.TableName tableName, boolean restoreAcl)
    Create a new table by cloning the snapshot content.
    default void
    Admin.cloneSnapshot(String snapshotName, org.apache.hadoop.hbase.TableName tableName, boolean restoreAcl, String customSFT)
    Create a new table by cloning the snapshot content.
    AsyncAdmin.cloneSnapshot(String snapshotName, org.apache.hadoop.hbase.TableName tableName)
    Create a new table by cloning the snapshot content.
    AsyncAdmin.cloneSnapshot(String snapshotName, org.apache.hadoop.hbase.TableName tableName, boolean restoreAcl)
    Create a new table by cloning the snapshot content.
    AsyncAdmin.cloneSnapshot(String snapshotName, org.apache.hadoop.hbase.TableName tableName, boolean restoreAcl, String customSFT)
    Create a new table by cloning the snapshot content.
    default Future<Void>
    Admin.cloneSnapshotAsync(String snapshotName, org.apache.hadoop.hbase.TableName tableName)
    Create a new table by cloning the snapshot content, but does not block and wait for it to be completely cloned.
    default Future<Void>
    Admin.cloneSnapshotAsync(String snapshotName, org.apache.hadoop.hbase.TableName tableName, boolean restoreAcl)
    Create a new table by cloning the snapshot content.
    Admin.cloneSnapshotAsync(String snapshotName, org.apache.hadoop.hbase.TableName tableName, boolean restoreAcl, String customSFT)
    Create a new table by cloning the snapshot content.
    HBaseAdmin.cloneSnapshotAsync(String snapshotName, org.apache.hadoop.hbase.TableName tableName, boolean restoreAcl, String customSFT)
     
    void
    Admin.cloneTableSchema(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.TableName newTableName, boolean preserveSplits)
    Create a new table by cloning the existent table schema.
    AsyncAdmin.cloneTableSchema(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.TableName newTableName, boolean preserveSplits)
    Create a new table by cloning the existent table schema.
    void
    HBaseAdmin.cloneTableSchema(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.TableName newTableName, boolean preserveSplits)
     
    void
    Admin.compact(org.apache.hadoop.hbase.TableName tableName)
    Compact a table.
    void
    Admin.compact(org.apache.hadoop.hbase.TableName tableName, byte[] columnFamily)
    Compact a column family within a table.
    void
    Admin.compact(org.apache.hadoop.hbase.TableName tableName, byte[] columnFamily, org.apache.hadoop.hbase.client.CompactType compactType)
    Compact a column family within a table.
    void
    Admin.compact(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.CompactType compactType)
    Compact a table.
    AsyncAdmin.compact(org.apache.hadoop.hbase.TableName tableName)
    Compact a table.
    AsyncAdmin.compact(org.apache.hadoop.hbase.TableName tableName, byte[] columnFamily)
    Compact a column family within a table.
    AsyncAdmin.compact(org.apache.hadoop.hbase.TableName tableName, byte[] columnFamily, org.apache.hadoop.hbase.client.CompactType compactType)
    Compact a column family within a table.
    AsyncAdmin.compact(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.CompactType compactType)
    Compact a table.
    void
    HBaseAdmin.compact(org.apache.hadoop.hbase.TableName tableName)
    Compact a table.
    void
    HBaseAdmin.compact(org.apache.hadoop.hbase.TableName tableName, byte[] columnFamily)
    Compact a column family within a table.
    void
    HBaseAdmin.compact(org.apache.hadoop.hbase.TableName tableName, byte[] columnFamily, org.apache.hadoop.hbase.client.CompactType compactType)
    Compact a column family within a table.
    void
    HBaseAdmin.compact(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.CompactType compactType)
    Compact a table.
    static org.apache.hadoop.hbase.client.TableState
    TableState.convert(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.shaded.protobuf.generated.HBaseProtos.TableState tableState)
    Covert from PB version of TableState
    static org.apache.hadoop.hbase.client.TableDescriptor
    TableDescriptorBuilder.copy(org.apache.hadoop.hbase.TableName name, org.apache.hadoop.hbase.client.TableDescriptor desc)
     
    static org.apache.hadoop.hbase.client.RegionInfo
    RegionInfo.createMobRegionInfo(org.apache.hadoop.hbase.TableName tableName)
    Creates a RegionInfo object for MOB data.
    static byte[]
    RegionInfo.createRegionName(org.apache.hadoop.hbase.TableName tableName, byte[] startKey, byte[] id, boolean newFormat)
    Make a region name of passed parameters.
    static byte[]
    RegionInfo.createRegionName(org.apache.hadoop.hbase.TableName tableName, byte[] startKey, byte[] id, int replicaId, boolean newFormat)
    Make a region name of passed parameters.
    static byte[]
    RegionInfo.createRegionName(org.apache.hadoop.hbase.TableName tableName, byte[] startKey, long regionid, boolean newFormat)
    Make a region name of passed parameters.
    static byte[]
    RegionInfo.createRegionName(org.apache.hadoop.hbase.TableName tableName, byte[] startKey, long regionid, int replicaId, boolean newFormat)
    Make a region name of passed parameters.
    static byte[]
    RegionInfo.createRegionName(org.apache.hadoop.hbase.TableName tableName, byte[] startKey, String id, boolean newFormat)
    Make a region name of passed parameters.
    void
    Admin.deleteColumn(org.apache.hadoop.hbase.TableName tableName, byte[] columnFamily)
    Deprecated.
    As of release 2.0.0.
    void
    HBaseAdmin.deleteColumn(org.apache.hadoop.hbase.TableName tableName, byte[] columnFamily)
    Deprecated.
    Since 2.0.
    default void
    Admin.deleteColumnFamily(org.apache.hadoop.hbase.TableName tableName, byte[] columnFamily)
    Delete a column family from a table.
    AsyncAdmin.deleteColumnFamily(org.apache.hadoop.hbase.TableName tableName, byte[] columnFamily)
    Delete a column family from a table.
    Admin.deleteColumnFamilyAsync(org.apache.hadoop.hbase.TableName tableName, byte[] columnFamily)
    Delete a column family from a table.
    HBaseAdmin.deleteColumnFamilyAsync(org.apache.hadoop.hbase.TableName tableName, byte[] columnFamily)
     
    default void
    Admin.deleteTable(org.apache.hadoop.hbase.TableName tableName)
    Deletes a table.
    AsyncAdmin.deleteTable(org.apache.hadoop.hbase.TableName tableName)
    Deletes a table.
    Admin.deleteTableAsync(org.apache.hadoop.hbase.TableName tableName)
    Deletes the table but does not block and wait for it to be completely removed.
    HBaseAdmin.deleteTableAsync(org.apache.hadoop.hbase.TableName tableName)
     
    default void
    Admin.disableTable(org.apache.hadoop.hbase.TableName tableName)
    Disable table and wait on completion.
    AsyncAdmin.disableTable(org.apache.hadoop.hbase.TableName tableName)
    Disable a table.
    Admin.disableTableAsync(org.apache.hadoop.hbase.TableName tableName)
    Disable the table but does not block and wait for it to be completely disabled.
    HBaseAdmin.disableTableAsync(org.apache.hadoop.hbase.TableName tableName)
     
    void
    Admin.disableTableReplication(org.apache.hadoop.hbase.TableName tableName)
    Disable a table's replication switch.
    AsyncAdmin.disableTableReplication(org.apache.hadoop.hbase.TableName tableName)
    Disable a table's replication switch.
    void
    HBaseAdmin.disableTableReplication(org.apache.hadoop.hbase.TableName tableName)
     
    static <R> void
    HTable.doBatchWithCallback(List<? extends org.apache.hadoop.hbase.client.Row> actions, Object[] results, org.apache.hadoop.hbase.client.coprocessor.Batch.Callback<R> callback, org.apache.hadoop.hbase.client.ClusterConnection connection, ExecutorService pool, org.apache.hadoop.hbase.TableName tableName, Map<String,byte[]> requestAttributes)
     
    default void
    Admin.enableTable(org.apache.hadoop.hbase.TableName tableName)
    Enable a table.
    AsyncAdmin.enableTable(org.apache.hadoop.hbase.TableName tableName)
    Enable a table.
    Admin.enableTableAsync(org.apache.hadoop.hbase.TableName tableName)
    Enable the table but does not block and wait for it to be completely enabled.
    HBaseAdmin.enableTableAsync(org.apache.hadoop.hbase.TableName tableName)
     
    void
    Admin.enableTableReplication(org.apache.hadoop.hbase.TableName tableName)
    Enable a table's replication switch.
    AsyncAdmin.enableTableReplication(org.apache.hadoop.hbase.TableName tableName)
    Enable a table's replication switch.
    void
    HBaseAdmin.enableTableReplication(org.apache.hadoop.hbase.TableName tableName)
     
    void
    Admin.flush(org.apache.hadoop.hbase.TableName tableName)
    Flush a table.
    void
    Admin.flush(org.apache.hadoop.hbase.TableName tableName, byte[] columnFamily)
    Flush the specified column family stores on all regions of the passed table.
    default void
    Admin.flush(org.apache.hadoop.hbase.TableName tableName, List<byte[]> columnFamilies)
    Flush the specified column family stores on all regions of the passed table.
    AsyncAdmin.flush(org.apache.hadoop.hbase.TableName tableName)
    Flush a table.
    AsyncAdmin.flush(org.apache.hadoop.hbase.TableName tableName, byte[] columnFamily)
    Flush the specified column family stores on all regions of the passed table.
    AsyncAdmin.flush(org.apache.hadoop.hbase.TableName tableName, List<byte[]> columnFamilies)
    Flush the specified column family stores on all regions of the passed table.
    void
    HBaseAdmin.flush(org.apache.hadoop.hbase.TableName tableName)
     
    void
    HBaseAdmin.flush(org.apache.hadoop.hbase.TableName tableName, byte[] columnFamily)
     
    Admin.flushAsync(org.apache.hadoop.hbase.TableName tableName, List<byte[]> columnFamilies)
    Flush a table but does not block and wait for it to finish.
    HBaseAdmin.flushAsync(org.apache.hadoop.hbase.TableName tableName, List<byte[]> columnFamilies)
     
    org.apache.hadoop.hbase.util.Pair<Integer,Integer>
    Admin.getAlterStatus(org.apache.hadoop.hbase.TableName tableName)
    Deprecated.
    Since 2.0.0.
    org.apache.hadoop.hbase.util.Pair<Integer,Integer>
    HBaseAdmin.getAlterStatus(org.apache.hadoop.hbase.TableName tableName)
     
    default org.apache.hadoop.hbase.client.AsyncBufferedMutator
    AsyncConnection.getBufferedMutator(org.apache.hadoop.hbase.TableName tableName)
    Retrieve an AsyncBufferedMutator for performing client-side buffering of writes.
    default org.apache.hadoop.hbase.client.AsyncBufferedMutator
    AsyncConnection.getBufferedMutator(org.apache.hadoop.hbase.TableName tableName, ExecutorService pool)
    Retrieve an AsyncBufferedMutator for performing client-side buffering of writes.
    org.apache.hadoop.hbase.client.BufferedMutator
    Connection.getBufferedMutator(org.apache.hadoop.hbase.TableName tableName)
    Retrieve a BufferedMutator for performing client-side buffering of writes.
    org.apache.hadoop.hbase.client.BufferedMutator
    ConnectionImplementation.getBufferedMutator(org.apache.hadoop.hbase.TableName tableName)
     
    org.apache.hadoop.hbase.client.AsyncBufferedMutatorBuilder
    AsyncConnection.getBufferedMutatorBuilder(org.apache.hadoop.hbase.TableName tableName)
    Returns an AsyncBufferedMutatorBuilder for creating AsyncBufferedMutator.
    org.apache.hadoop.hbase.client.AsyncBufferedMutatorBuilder
    AsyncConnection.getBufferedMutatorBuilder(org.apache.hadoop.hbase.TableName tableName, ExecutorService pool)
    Returns an AsyncBufferedMutatorBuilder for creating AsyncBufferedMutator.
    org.apache.hadoop.hbase.client.AsyncBufferedMutatorBuilder
    AsyncConnectionImpl.getBufferedMutatorBuilder(org.apache.hadoop.hbase.TableName tableName)
     
    org.apache.hadoop.hbase.client.AsyncBufferedMutatorBuilder
    AsyncConnectionImpl.getBufferedMutatorBuilder(org.apache.hadoop.hbase.TableName tableName, ExecutorService pool)
     
    org.apache.hadoop.hbase.RegionLocations
    MetaCache.getCachedLocation(org.apache.hadoop.hbase.TableName tableName, byte[] row)
    Search the cache for a location that fits our table and row key.
    org.apache.hadoop.hbase.client.CompactionState
    Admin.getCompactionState(org.apache.hadoop.hbase.TableName tableName)
    Get the current compaction state of a table.
    org.apache.hadoop.hbase.client.CompactionState
    Admin.getCompactionState(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.CompactType compactType)
    Get the current compaction state of a table.
    default CompletableFuture<org.apache.hadoop.hbase.client.CompactionState>
    AsyncAdmin.getCompactionState(org.apache.hadoop.hbase.TableName tableName)
    Get the current compaction state of a table.
    CompletableFuture<org.apache.hadoop.hbase.client.CompactionState>
    AsyncAdmin.getCompactionState(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.CompactType compactType)
    Get the current compaction state of a table.
    org.apache.hadoop.hbase.client.CompactionState
    HBaseAdmin.getCompactionState(org.apache.hadoop.hbase.TableName tableName)
     
    org.apache.hadoop.hbase.client.CompactionState
    HBaseAdmin.getCompactionState(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.CompactType compactType)
    Get the current compaction state of a table.
    org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshotView
    Admin.getCurrentSpaceQuotaSnapshot(org.apache.hadoop.hbase.TableName tableName)
    Returns the Master's view of a quota on the given tableName or null if the Master has no quota information on that table.
    CompletableFuture<? extends org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshotView>
    AsyncAdmin.getCurrentSpaceQuotaSnapshot(org.apache.hadoop.hbase.TableName tableName)
    Returns the Master's view of a quota on the given tableName or null if the Master has no quota information on that table.
    org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot
    HBaseAdmin.getCurrentSpaceQuotaSnapshot(org.apache.hadoop.hbase.TableName tableName)
     
    org.apache.hadoop.hbase.client.TableDescriptor
    Admin.getDescriptor(org.apache.hadoop.hbase.TableName tableName)
    Get a table descriptor.
    CompletableFuture<org.apache.hadoop.hbase.client.TableDescriptor>
    AsyncAdmin.getDescriptor(org.apache.hadoop.hbase.TableName tableName)
    Method for getting the tableDescriptor
    org.apache.hadoop.hbase.client.TableDescriptor
    HBaseAdmin.getDescriptor(org.apache.hadoop.hbase.TableName tableName)
     
    long
    Admin.getLastMajorCompactionTimestamp(org.apache.hadoop.hbase.TableName tableName)
    Get the timestamp of the last major compaction for the passed table The timestamp of the oldest HFile resulting from a major compaction of that table, or 0 if no such HFile could be found.
    AsyncAdmin.getLastMajorCompactionTimestamp(org.apache.hadoop.hbase.TableName tableName)
    Get the timestamp of the last major compaction for the passed table.
    long
    HBaseAdmin.getLastMajorCompactionTimestamp(org.apache.hadoop.hbase.TableName tableName)
     
    int
    MetaCache.getNumberOfCachedRegionLocations(org.apache.hadoop.hbase.TableName tableName)
    Return the number of cached region for a table.
    org.apache.hadoop.hbase.HRegionLocation
    ClusterConnection.getRegionLocation(org.apache.hadoop.hbase.TableName tableName, byte[] row, boolean reload)
    Find region location hosting passed row
    org.apache.hadoop.hbase.HRegionLocation
    ConnectionImplementation.getRegionLocation(org.apache.hadoop.hbase.TableName tableName, byte[] row, boolean reload)
     
    static org.apache.hadoop.hbase.RegionLocations
    RegionAdminServiceCallable.getRegionLocations(org.apache.hadoop.hbase.client.ClusterConnection connection, org.apache.hadoop.hbase.TableName tableName, byte[] row, boolean useCache, int replicaId)
     
    org.apache.hadoop.hbase.client.AsyncTableRegionLocator
    AsyncConnection.getRegionLocator(org.apache.hadoop.hbase.TableName tableName)
    Retrieve a AsyncRegionLocator implementation to inspect region information on a table.
    org.apache.hadoop.hbase.client.AsyncTableRegionLocator
    AsyncConnectionImpl.getRegionLocator(org.apache.hadoop.hbase.TableName tableName)
     
    org.apache.hadoop.hbase.client.RegionLocator
    Connection.getRegionLocator(org.apache.hadoop.hbase.TableName tableName)
    Retrieve a RegionLocator implementation to inspect region information on a table.
    org.apache.hadoop.hbase.client.RegionLocator
    ConnectionImplementation.getRegionLocator(org.apache.hadoop.hbase.TableName tableName)
     
    List<org.apache.hadoop.hbase.RegionMetrics>
    Admin.getRegionMetrics(org.apache.hadoop.hbase.ServerName serverName, org.apache.hadoop.hbase.TableName tableName)
    Get RegionMetrics of all regions hosted on a regionserver for a table.
    CompletableFuture<List<org.apache.hadoop.hbase.RegionMetrics>>
    AsyncAdmin.getRegionMetrics(org.apache.hadoop.hbase.ServerName serverName, org.apache.hadoop.hbase.TableName tableName)
    Get a list of RegionMetrics of all regions hosted on a region server for a table.
    List<org.apache.hadoop.hbase.RegionMetrics>
    HBaseAdmin.getRegionMetrics(org.apache.hadoop.hbase.ServerName serverName, org.apache.hadoop.hbase.TableName tableName)
     
    List<org.apache.hadoop.hbase.client.RegionInfo>
    Admin.getRegions(org.apache.hadoop.hbase.TableName tableName)
    Get the regions of a given table.
    CompletableFuture<List<org.apache.hadoop.hbase.client.RegionInfo>>
    AsyncAdmin.getRegions(org.apache.hadoop.hbase.TableName tableName)
    Get the regions of a given table.
    List<org.apache.hadoop.hbase.client.RegionInfo>
    HBaseAdmin.getRegions(org.apache.hadoop.hbase.TableName tableName)
     
    default org.apache.hadoop.hbase.client.AsyncTable<org.apache.hadoop.hbase.client.AdvancedScanResultConsumer>
    AsyncConnection.getTable(org.apache.hadoop.hbase.TableName tableName)
    Retrieve an AsyncTable implementation for accessing a table.
    default org.apache.hadoop.hbase.client.AsyncTable<org.apache.hadoop.hbase.client.ScanResultConsumer>
    AsyncConnection.getTable(org.apache.hadoop.hbase.TableName tableName, ExecutorService pool)
    Retrieve an AsyncTable implementation for accessing a table.
    default org.apache.hadoop.hbase.client.Table
    Connection.getTable(org.apache.hadoop.hbase.TableName tableName)
    Retrieve a Table implementation for accessing a table.
    default org.apache.hadoop.hbase.client.Table
    Connection.getTable(org.apache.hadoop.hbase.TableName tableName, ExecutorService pool)
    Retrieve a Table implementation for accessing a table.
    org.apache.hadoop.hbase.client.Table
    ConnectionImplementation.getTable(org.apache.hadoop.hbase.TableName tableName)
     
    org.apache.hadoop.hbase.client.AsyncTableBuilder<org.apache.hadoop.hbase.client.AdvancedScanResultConsumer>
    AsyncConnection.getTableBuilder(org.apache.hadoop.hbase.TableName tableName)
    Returns an AsyncTableBuilder for creating AsyncTable.
    org.apache.hadoop.hbase.client.AsyncTableBuilder<org.apache.hadoop.hbase.client.ScanResultConsumer>
    AsyncConnection.getTableBuilder(org.apache.hadoop.hbase.TableName tableName, ExecutorService pool)
    Returns an AsyncTableBuilder for creating AsyncTable.
    org.apache.hadoop.hbase.client.AsyncTableBuilder<org.apache.hadoop.hbase.client.AdvancedScanResultConsumer>
    AsyncConnectionImpl.getTableBuilder(org.apache.hadoop.hbase.TableName tableName)
     
    org.apache.hadoop.hbase.client.AsyncTableBuilder<org.apache.hadoop.hbase.client.ScanResultConsumer>
    AsyncConnectionImpl.getTableBuilder(org.apache.hadoop.hbase.TableName tableName, ExecutorService pool)
     
    org.apache.hadoop.hbase.client.TableBuilder
    Connection.getTableBuilder(org.apache.hadoop.hbase.TableName tableName, ExecutorService pool)
    Returns an TableBuilder for creating Table.
    org.apache.hadoop.hbase.client.TableBuilder
    ConnectionImplementation.getTableBuilder(org.apache.hadoop.hbase.TableName tableName, ExecutorService pool)
     
    org.apache.hadoop.hbase.HTableDescriptor
    Admin.getTableDescriptor(org.apache.hadoop.hbase.TableName tableName)
    Deprecated.
    since 2.0 version and will be removed in 3.0 version.
    org.apache.hadoop.hbase.HTableDescriptor
    HBaseAdmin.getTableDescriptor(org.apache.hadoop.hbase.TableName tableName)
     
    List<org.apache.hadoop.hbase.HRegionInfo>
    Admin.getTableRegions(org.apache.hadoop.hbase.TableName tableName)
    Deprecated.
    As of release 2.0.0, this will be removed in HBase 3.0.0 (HBASE-17980).
    List<org.apache.hadoop.hbase.HRegionInfo>
    HBaseAdmin.getTableRegions(org.apache.hadoop.hbase.TableName tableName)
    Deprecated.
    As of release 2.0.0, this will be removed in HBase 3.0.0 Use HBaseAdmin.getRegions(TableName).
    org.apache.hadoop.hbase.client.TableState
    ClusterConnection.getTableState(org.apache.hadoop.hbase.TableName tableName)
    Retrieve TableState, represent current table state.
    org.apache.hadoop.hbase.client.TableState
    ConnectionImplementation.getTableState(org.apache.hadoop.hbase.TableName tableName)
     
    boolean
    MetaCache.isRegionCached(org.apache.hadoop.hbase.TableName tableName, byte[] row)
    Check the region cache to see whether a region is cached yet or not.
    boolean
    Admin.isTableAvailable(org.apache.hadoop.hbase.TableName tableName)
    Check if a table is available.
    boolean
    Admin.isTableAvailable(org.apache.hadoop.hbase.TableName tableName, byte[][] splitKeys)
    Deprecated.
    Since 2.0.0.
    AsyncAdmin.isTableAvailable(org.apache.hadoop.hbase.TableName tableName)
    Check if a table is available.
    AsyncAdmin.isTableAvailable(org.apache.hadoop.hbase.TableName tableName, byte[][] splitKeys)
    Deprecated.
    Since 2.2.0.
    boolean
    ClusterConnection.isTableAvailable(org.apache.hadoop.hbase.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
    ConnectionImplementation.isTableAvailable(org.apache.hadoop.hbase.TableName tableName, byte[][] splitKeys)
     
    boolean
    HBaseAdmin.isTableAvailable(org.apache.hadoop.hbase.TableName tableName)
     
    boolean
    HBaseAdmin.isTableAvailable(org.apache.hadoop.hbase.TableName tableName, byte[][] splitKeys)
     
    boolean
    Admin.isTableDisabled(org.apache.hadoop.hbase.TableName tableName)
    Check if a table is disabled.
    AsyncAdmin.isTableDisabled(org.apache.hadoop.hbase.TableName tableName)
    Check if a table is disabled.
    boolean
    ClusterConnection.isTableDisabled(org.apache.hadoop.hbase.TableName tableName)
    Check if a table is disabled.
    boolean
    ConnectionImplementation.isTableDisabled(org.apache.hadoop.hbase.TableName tableName)
     
    boolean
    HBaseAdmin.isTableDisabled(org.apache.hadoop.hbase.TableName tableName)
     
    boolean
    Admin.isTableEnabled(org.apache.hadoop.hbase.TableName tableName)
    Check if a table is enabled.
    AsyncAdmin.isTableEnabled(org.apache.hadoop.hbase.TableName tableName)
    Check if a table is enabled.
    boolean
    ClusterConnection.isTableEnabled(org.apache.hadoop.hbase.TableName tableName)
    A table that isTableEnabled == false and isTableDisabled == false is possible.
    boolean
    ConnectionImplementation.isTableEnabled(org.apache.hadoop.hbase.TableName tableName)
     
    boolean
    HBaseAdmin.isTableEnabled(org.apache.hadoop.hbase.TableName tableName)
     
    org.apache.hadoop.hbase.HRegionLocation
    ClusterConnection.locateRegion(org.apache.hadoop.hbase.TableName tableName, byte[] row)
    Find the location of the region of tableName that row lives in.
    org.apache.hadoop.hbase.RegionLocations
    ClusterConnection.locateRegion(org.apache.hadoop.hbase.TableName tableName, byte[] row, boolean useCache, boolean retry)
    Gets the locations of the region in the specified table, tableName, for a given row.
    org.apache.hadoop.hbase.RegionLocations
    ClusterConnection.locateRegion(org.apache.hadoop.hbase.TableName tableName, byte[] row, boolean useCache, boolean retry, int replicaId)
    Gets the locations of the region in the specified table, tableName, for a given row.
    org.apache.hadoop.hbase.HRegionLocation
    ConnectionImplementation.locateRegion(org.apache.hadoop.hbase.TableName tableName, byte[] row)
     
    org.apache.hadoop.hbase.RegionLocations
    ConnectionImplementation.locateRegion(org.apache.hadoop.hbase.TableName tableName, byte[] row, boolean useCache, boolean retry)
     
    org.apache.hadoop.hbase.RegionLocations
    ConnectionImplementation.locateRegion(org.apache.hadoop.hbase.TableName tableName, byte[] row, boolean useCache, boolean retry, int replicaId)
     
    List<org.apache.hadoop.hbase.HRegionLocation>
    ClusterConnection.locateRegions(org.apache.hadoop.hbase.TableName tableName)
    Gets the locations of all regions in the specified table, tableName.
    List<org.apache.hadoop.hbase.HRegionLocation>
    ClusterConnection.locateRegions(org.apache.hadoop.hbase.TableName tableName, boolean useCache, boolean offlined)
    Gets the locations of all regions in the specified table, tableName.
    List<org.apache.hadoop.hbase.HRegionLocation>
    ConnectionImplementation.locateRegions(org.apache.hadoop.hbase.TableName tableName)
     
    List<org.apache.hadoop.hbase.HRegionLocation>
    ConnectionImplementation.locateRegions(org.apache.hadoop.hbase.TableName tableName, boolean useCache, boolean offlined)
     
    void
    Admin.majorCompact(org.apache.hadoop.hbase.TableName tableName)
    Major compact a table.
    void
    Admin.majorCompact(org.apache.hadoop.hbase.TableName tableName, byte[] columnFamily)
    Major compact a column family within a table.
    void
    Admin.majorCompact(org.apache.hadoop.hbase.TableName tableName, byte[] columnFamily, org.apache.hadoop.hbase.client.CompactType compactType)
    Major compact a column family within a table.
    void
    Admin.majorCompact(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.CompactType compactType)
    Major compact a table.
    AsyncAdmin.majorCompact(org.apache.hadoop.hbase.TableName tableName)
    Major compact a table.
    AsyncAdmin.majorCompact(org.apache.hadoop.hbase.TableName tableName, byte[] columnFamily)
    Major compact a column family within a table.
    AsyncAdmin.majorCompact(org.apache.hadoop.hbase.TableName tableName, byte[] columnFamily, org.apache.hadoop.hbase.client.CompactType compactType)
    Major compact a column family within a table.
    AsyncAdmin.majorCompact(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.CompactType compactType)
    Major compact a table.
    void
    HBaseAdmin.majorCompact(org.apache.hadoop.hbase.TableName tableName)
     
    void
    HBaseAdmin.majorCompact(org.apache.hadoop.hbase.TableName tableName, byte[] columnFamily)
    Major compact a column family within a table.
    void
    HBaseAdmin.majorCompact(org.apache.hadoop.hbase.TableName tableName, byte[] columnFamily, org.apache.hadoop.hbase.client.CompactType compactType)
    Major compact a column family within a table.
    void
    HBaseAdmin.majorCompact(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.CompactType compactType)
    Major compact a table.
    default void
    Admin.modifyColumn(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.ColumnFamilyDescriptor columnFamily)
    Deprecated.
    As of release 2.0.0.
    default void
    Admin.modifyColumnFamily(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.ColumnFamilyDescriptor columnFamily)
    Modify an existing column family on a table.
    AsyncAdmin.modifyColumnFamily(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.ColumnFamilyDescriptor columnFamily)
    Modify an existing column family on a table.
    Admin.modifyColumnFamilyAsync(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.ColumnFamilyDescriptor columnFamily)
    Modify an existing column family on a table.
    HBaseAdmin.modifyColumnFamilyAsync(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.ColumnFamilyDescriptor columnFamily)
     
    default void
    Admin.modifyColumnFamilyStoreFileTracker(org.apache.hadoop.hbase.TableName tableName, byte[] family, String dstSFT)
    Change the store file tracker of the given table's given family.
    AsyncAdmin.modifyColumnFamilyStoreFileTracker(org.apache.hadoop.hbase.TableName tableName, byte[] family, String dstSFT)
    Change the store file tracker of the given table's given family.
    Admin.modifyColumnFamilyStoreFileTrackerAsync(org.apache.hadoop.hbase.TableName tableName, byte[] family, String dstSFT)
    Change the store file tracker of the given table's given family.
    HBaseAdmin.modifyColumnFamilyStoreFileTrackerAsync(org.apache.hadoop.hbase.TableName tableName, byte[] family, String dstSFT)
     
    default void
    Admin.modifyTable(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.TableDescriptor td)
    Deprecated.
    since 2.0 version and will be removed in 3.0 version.
    default Future<Void>
    Admin.modifyTableAsync(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.TableDescriptor td)
    Deprecated.
    since 2.0 version and will be removed in 3.0 version.
    default void
    Admin.modifyTableStoreFileTracker(org.apache.hadoop.hbase.TableName tableName, String dstSFT)
    Change the store file tracker of the given table.
    AsyncAdmin.modifyTableStoreFileTracker(org.apache.hadoop.hbase.TableName tableName, String dstSFT)
    Change the store file tracker of the given table.
    Admin.modifyTableStoreFileTrackerAsync(org.apache.hadoop.hbase.TableName tableName, String dstSFT)
    Change the store file tracker of the given table.
    HBaseAdmin.modifyTableStoreFileTrackerAsync(org.apache.hadoop.hbase.TableName tableName, String dstSFT)
     
    static org.apache.hadoop.hbase.client.RegionInfoBuilder
    RegionInfoBuilder.newBuilder(org.apache.hadoop.hbase.TableName tableName)
     
    static org.apache.hadoop.hbase.client.TableDescriptorBuilder
    TableDescriptorBuilder.newBuilder(org.apache.hadoop.hbase.TableName name)
     
    static org.apache.hadoop.hbase.client.TableState
    TableState.parseFrom(org.apache.hadoop.hbase.TableName tableName, byte[] bytes)
     
    List<org.apache.hadoop.hbase.client.Put>
    HTableMultiplexer.put(org.apache.hadoop.hbase.TableName tableName, List<org.apache.hadoop.hbase.client.Put> puts)
    Deprecated.
    The puts request will be buffered by their corresponding buffer queue.
    boolean
    HTableMultiplexer.put(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.Put put)
    Deprecated.
    The put request will be buffered by its corresponding buffer queue.
    boolean
    HTableMultiplexer.put(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.Put put, int maxAttempts)
    Deprecated.
    The put request will be buffered by its corresponding buffer queue.
    org.apache.hadoop.hbase.HRegionLocation
    ClusterConnection.relocateRegion(org.apache.hadoop.hbase.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.
    org.apache.hadoop.hbase.RegionLocations
    ClusterConnection.relocateRegion(org.apache.hadoop.hbase.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.
    org.apache.hadoop.hbase.HRegionLocation
    ConnectionImplementation.relocateRegion(org.apache.hadoop.hbase.TableName tableName, byte[] row)
     
    org.apache.hadoop.hbase.RegionLocations
    ConnectionImplementation.relocateRegion(org.apache.hadoop.hbase.TableName tableName, byte[] row, int replicaId)
     
    org.apache.hadoop.hbase.client.AsyncProcessTask.Builder<T>
    AsyncProcessTask.Builder.setTableName(org.apache.hadoop.hbase.TableName tableName)
     
    default void
    Admin.snapshot(byte[] snapshotName, org.apache.hadoop.hbase.TableName tableName)
    Deprecated.
    since 2.3.0, will be removed in 3.0.0.
    default void
    Admin.snapshot(String snapshotName, org.apache.hadoop.hbase.TableName tableName)
    Take a snapshot for the given table.
    default void
    Admin.snapshot(String snapshotName, org.apache.hadoop.hbase.TableName tableName, Map<String,Object> snapshotProps)
    Create typed snapshot of the table.
    default void
    Admin.snapshot(String snapshotName, org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.SnapshotType type)
    Create typed snapshot of the table.
    default void
    Admin.snapshot(String snapshotName, org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.SnapshotType type, Map<String,Object> snapshotProps)
    Create typed snapshot of the table.
    AsyncAdmin.snapshot(String snapshotName, org.apache.hadoop.hbase.TableName tableName)
    Take a snapshot for the given table.
    AsyncAdmin.snapshot(String snapshotName, org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.SnapshotType type)
    Create typed snapshot of the table.
    void
    Admin.split(org.apache.hadoop.hbase.TableName tableName)
    Split a table.
    void
    Admin.split(org.apache.hadoop.hbase.TableName tableName, byte[] splitPoint)
    Split a table.
    AsyncAdmin.split(org.apache.hadoop.hbase.TableName tableName)
    Split a table.
    AsyncAdmin.split(org.apache.hadoop.hbase.TableName tableName, byte[] splitPoint)
    Split a table.
    void
    HBaseAdmin.split(org.apache.hadoop.hbase.TableName tableName)
     
    void
    HBaseAdmin.split(org.apache.hadoop.hbase.TableName tableName, byte[] splitPoint)
     
    boolean
    Admin.tableExists(org.apache.hadoop.hbase.TableName tableName)
    Check if a table exists.
    AsyncAdmin.tableExists(org.apache.hadoop.hbase.TableName tableName)
    Check if a table exists.
    boolean
    HBaseAdmin.tableExists(org.apache.hadoop.hbase.TableName tableName)
     
    default void
    Admin.truncateTable(org.apache.hadoop.hbase.TableName tableName, boolean preserveSplits)
    Truncate a table.
    AsyncAdmin.truncateTable(org.apache.hadoop.hbase.TableName tableName, boolean preserveSplits)
    Truncate a table.
    Admin.truncateTableAsync(org.apache.hadoop.hbase.TableName tableName, boolean preserveSplits)
    Truncate the table but does not block and wait for it to be completely enabled.
    HBaseAdmin.truncateTableAsync(org.apache.hadoop.hbase.TableName tableName, boolean preserveSplits)
     
    void
    ClusterConnection.updateCachedLocations(org.apache.hadoop.hbase.TableName tableName, byte[] regionName, byte[] rowkey, Object exception, org.apache.hadoop.hbase.ServerName source)
    Update the location cache.
    void
    ConnectionImplementation.updateCachedLocations(org.apache.hadoop.hbase.TableName tableName, byte[] regionName, byte[] rowkey, Object exception, org.apache.hadoop.hbase.ServerName source)
    Update the location with the new value (if the exception is a RegionMovedException) or delete it from the cache.
    void
    MetricsConnection.updateRpc(org.apache.hbase.thirdparty.com.google.protobuf.Descriptors.MethodDescriptor method, org.apache.hadoop.hbase.TableName tableName, org.apache.hbase.thirdparty.com.google.protobuf.Message param, org.apache.hadoop.hbase.client.MetricsConnection.CallStats stats, Throwable e)
    Report RPC context to metrics system.
    Method parameters in org.apache.hadoop.hbase.client with type arguments of type org.apache.hadoop.hbase.TableName in in
    Modifier and Type
    Method
    Description
    default void
    Admin.appendReplicationPeerTableCFs(String id, Map<org.apache.hadoop.hbase.TableName,List<String>> tableCfs)
    Append the replicable table column family config from the specified peer.
    AsyncAdmin.appendReplicationPeerTableCFs(String peerId, Map<org.apache.hadoop.hbase.TableName,List<String>> tableCfs)
    Append the replicable table-cf config of the specified peer
    org.apache.hadoop.hbase.HTableDescriptor[]
    Admin.getTableDescriptorsByTableName(List<org.apache.hadoop.hbase.TableName> tableNames)
    Deprecated.
    since 2.0 version and will be removed in 3.0 version.
    org.apache.hadoop.hbase.HTableDescriptor[]
    HBaseAdmin.getTableDescriptorsByTableName(List<org.apache.hadoop.hbase.TableName> tableNames)
     
    List<org.apache.hadoop.hbase.client.TableDescriptor>
    Admin.listTableDescriptors(List<org.apache.hadoop.hbase.TableName> tableNames)
    Get tableDescriptors.
    CompletableFuture<List<org.apache.hadoop.hbase.client.TableDescriptor>>
    AsyncAdmin.listTableDescriptors(List<org.apache.hadoop.hbase.TableName> tableNames)
    List specific tables including system tables.
    List<org.apache.hadoop.hbase.client.TableDescriptor>
    HBaseAdmin.listTableDescriptors(List<org.apache.hadoop.hbase.TableName> tableNames)
     
    default void
    Admin.removeReplicationPeerTableCFs(String id, Map<org.apache.hadoop.hbase.TableName,List<String>> tableCfs)
    Remove some table-cfs from config of the specified peer.
    AsyncAdmin.removeReplicationPeerTableCFs(String peerId, Map<org.apache.hadoop.hbase.TableName,List<String>> tableCfs)
    Remove some table-cfs from config of the specified peer
    org.apache.hadoop.hbase.client.NormalizeTableFilterParams.Builder
    NormalizeTableFilterParams.Builder.tableNames(List<org.apache.hadoop.hbase.TableName> tableNames)
     
    Constructors in org.apache.hadoop.hbase.client with parameters of type org.apache.hadoop.hbase.TableName in in
    Modifier
    Constructor
    Description
     
    BufferedMutatorParams(org.apache.hadoop.hbase.TableName tableName)
     
     
    ClientAsyncPrefetchScanner(org.apache.hadoop.conf.Configuration configuration, org.apache.hadoop.hbase.client.Scan scan, org.apache.hadoop.hbase.client.Scan scanForMetrics, org.apache.hadoop.hbase.TableName name, org.apache.hadoop.hbase.client.ClusterConnection connection, org.apache.hadoop.hbase.client.RpcRetryingCallerFactory rpcCallerFactory, org.apache.hadoop.hbase.ipc.RpcControllerFactory rpcControllerFactory, ExecutorService pool, int scanReadRpcTimeout, int scannerTimeout, int replicaCallTimeoutMicroSecondScan, org.apache.hadoop.hbase.client.ConnectionConfiguration connectionConfiguration, Map<String,byte[]> requestAttributes)
     
     
    ClientScanner(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.client.Scan scan, org.apache.hadoop.hbase.client.Scan scanForMetrics, org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.ClusterConnection connection, org.apache.hadoop.hbase.client.RpcRetryingCallerFactory rpcFactory, org.apache.hadoop.hbase.ipc.RpcControllerFactory controllerFactory, ExecutorService pool, int scanReadRpcTimeout, int scannerTimeout, int primaryOperationTimeout, org.apache.hadoop.hbase.client.ConnectionConfiguration connectionConfiguration, Map<String,byte[]> requestAttributes)
    Create a new ClientScanner for the specified table Note that the passed Scan's start row maybe changed changed.
     
    ClientServiceCallable(org.apache.hadoop.hbase.client.Connection connection, org.apache.hadoop.hbase.TableName tableName, byte[] row, org.apache.hbase.thirdparty.com.google.protobuf.RpcController rpcController, int priority, Map<String,byte[]> requestAttributes)
     
     
    ClientSimpleScanner(org.apache.hadoop.conf.Configuration configuration, org.apache.hadoop.hbase.client.Scan scan, org.apache.hadoop.hbase.client.Scan scanForMetrics, org.apache.hadoop.hbase.TableName name, org.apache.hadoop.hbase.client.ClusterConnection connection, org.apache.hadoop.hbase.client.RpcRetryingCallerFactory rpcCallerFactory, org.apache.hadoop.hbase.ipc.RpcControllerFactory rpcControllerFactory, ExecutorService pool, int scanReadRpcTimeout, int scannerTimeout, int replicaCallTimeoutMicroSecondScan, org.apache.hadoop.hbase.client.ConnectionConfiguration connectionConfiguration, Map<String,byte[]> requestAttributes)
     
     
    FlushRegionCallable(org.apache.hadoop.hbase.client.ClusterConnection connection, org.apache.hadoop.hbase.ipc.RpcControllerFactory rpcControllerFactory, org.apache.hadoop.hbase.TableName tableName, byte[] regionName, byte[] regionStartKey, boolean writeFlushWalMarker)
     
     
    HRegionLocator(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.ConnectionImplementation connection)
     
     
    ModifyableTableDescriptor(org.apache.hadoop.hbase.TableName name)
    Construct a table descriptor specifying a TableName object
     
    ModifyableTableDescriptor(org.apache.hadoop.hbase.TableName name, org.apache.hadoop.hbase.client.TableDescriptor desc)
    Deprecated.
     
    NoncedRegionServerCallable(org.apache.hadoop.hbase.client.Connection connection, org.apache.hadoop.hbase.TableName tableName, byte[] row, org.apache.hadoop.hbase.ipc.HBaseRpcController rpcController, int priority, Map<String,byte[]> requestAttributes)
     
     
    RegionAdminServiceCallable(org.apache.hadoop.hbase.client.ClusterConnection connection, org.apache.hadoop.hbase.ipc.RpcControllerFactory rpcControllerFactory, org.apache.hadoop.hbase.HRegionLocation location, org.apache.hadoop.hbase.TableName tableName, byte[] row)
     
     
    RegionAdminServiceCallable(org.apache.hadoop.hbase.client.ClusterConnection connection, org.apache.hadoop.hbase.ipc.RpcControllerFactory rpcControllerFactory, org.apache.hadoop.hbase.HRegionLocation location, org.apache.hadoop.hbase.TableName tableName, byte[] row, int replicaId)
     
     
    RegionAdminServiceCallable(org.apache.hadoop.hbase.client.ClusterConnection connection, org.apache.hadoop.hbase.ipc.RpcControllerFactory rpcControllerFactory, org.apache.hadoop.hbase.TableName tableName, byte[] row)
     
     
    RegionServerCallable(org.apache.hadoop.hbase.client.Connection connection, org.apache.hadoop.hbase.TableName tableName, byte[] row, org.apache.hbase.thirdparty.com.google.protobuf.RpcController rpcController, int priority, Map<String,byte[]> requestAttributes)
     
     
    RegionServerCallable(org.apache.hadoop.hbase.client.Connection connection, org.apache.hadoop.hbase.TableName tableName, byte[] row, org.apache.hbase.thirdparty.com.google.protobuf.RpcController rpcController, Map<String,byte[]> requestAttributes)
     
     
    ReversedClientScanner(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.client.Scan scan, org.apache.hadoop.hbase.client.Scan scanForMetrics, org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.ClusterConnection connection, org.apache.hadoop.hbase.client.RpcRetryingCallerFactory rpcFactory, org.apache.hadoop.hbase.ipc.RpcControllerFactory controllerFactory, ExecutorService pool, int scanReadRpcTimeout, int scannerTimeout, int primaryOperationTimeout, org.apache.hadoop.hbase.client.ConnectionConfiguration connectionConfiguration, Map<String,byte[]> requestAttributes)
    Create a new ReversibleClientScanner for the specified table Note that the passed Scan's start row maybe changed.
     
    ReversedScannerCallable(org.apache.hadoop.hbase.client.ClusterConnection connection, org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.Scan scan, org.apache.hadoop.hbase.client.metrics.ScanMetrics scanMetrics, org.apache.hadoop.hbase.ipc.RpcControllerFactory rpcFactory, int replicaId, Map<String,byte[]> requestAttributes)
     
     
    RpcRetryingCallerWithReadReplicas(org.apache.hadoop.hbase.ipc.RpcControllerFactory rpcControllerFactory, org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.ClusterConnection cConnection, org.apache.hadoop.hbase.client.Get get, ExecutorService pool, int retries, int operationTimeout, int rpcTimeout, int timeBeforeReplicas, Map<String,byte[]> requestAttributes)
     
     
    ScannerCallable(org.apache.hadoop.hbase.client.ClusterConnection connection, org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.Scan scan, org.apache.hadoop.hbase.client.metrics.ScanMetrics scanMetrics, org.apache.hadoop.hbase.ipc.RpcControllerFactory rpcControllerFactory, int id, Map<String,byte[]> requestAttributes)
     
     
    SnapshotDescription(String name, org.apache.hadoop.hbase.TableName table)
     
     
    SnapshotDescription(String name, org.apache.hadoop.hbase.TableName table, org.apache.hadoop.hbase.client.SnapshotType type)
     
     
    SnapshotDescription(String name, org.apache.hadoop.hbase.TableName table, org.apache.hadoop.hbase.client.SnapshotType type, String owner)
     
     
    SnapshotDescription(String name, org.apache.hadoop.hbase.TableName table, org.apache.hadoop.hbase.client.SnapshotType type, String owner, long creationTime, int version)
    Deprecated.
    since 2.3.0 and will be removed in 4.0.0.
     
    SnapshotDescription(String name, org.apache.hadoop.hbase.TableName table, org.apache.hadoop.hbase.client.SnapshotType type, String owner, long creationTime, int version, Map<String,Object> snapshotProps)
    SnapshotDescription Parameterized Constructor
     
    SnapshotDescription(String snapshotName, org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.SnapshotType type, Map<String,Object> snapshotProps)
    SnapshotDescription Parameterized Constructor
     
    TableFuture(org.apache.hadoop.hbase.client.HBaseAdmin admin, org.apache.hadoop.hbase.TableName tableName, Long procId)
     
     
    TableState(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.TableState.State state)
    Create instance of TableState.
  • Uses of org.apache.hadoop.hbase.TableName in org.apache.hadoop.hbase.client.example

    Methods in org.apache.hadoop.hbase.client.example with parameters of type org.apache.hadoop.hbase.TableName in in
    Modifier and Type
    Method
    Description
    void
    RefreshHFilesClient.refreshHFiles(org.apache.hadoop.hbase.TableName tableName)
     
    Constructors in org.apache.hadoop.hbase.client.example with parameters of type org.apache.hadoop.hbase.TableName in in
    Modifier
    Constructor
    Description
     
    ReadExampleCallable(org.apache.hadoop.hbase.client.Connection connection, org.apache.hadoop.hbase.TableName tableName)
     
     
    SingleWriteExampleCallable(org.apache.hadoop.hbase.client.Connection connection, org.apache.hadoop.hbase.TableName tableName)
     
     
    WriteExampleCallable(org.apache.hadoop.hbase.client.Connection connection, org.apache.hadoop.hbase.TableName tableName)
     
  • Uses of org.apache.hadoop.hbase.TableName in org.apache.hadoop.hbase.client.locking

    Methods in org.apache.hadoop.hbase.client.locking with parameters of type org.apache.hadoop.hbase.TableName in in
    Modifier and Type
    Method
    Description
    static org.apache.hadoop.hbase.shaded.protobuf.generated.LockServiceProtos.LockRequest
    LockServiceClient.buildLockRequest(org.apache.hadoop.hbase.shaded.protobuf.generated.LockServiceProtos.LockType type, String namespace, org.apache.hadoop.hbase.TableName tableName, List<org.apache.hadoop.hbase.client.RegionInfo> regionInfos, String description, long nonceGroup, long nonce)
     
    org.apache.hadoop.hbase.client.locking.EntityLock
    LockServiceClient.tableLock(org.apache.hadoop.hbase.TableName tableName, boolean exclusive, String description, org.apache.hadoop.hbase.Abortable abort)
    Create a new EntityLock object to acquire an exclusive or shared lock on a table.
  • Uses of org.apache.hadoop.hbase.TableName in org.apache.hadoop.hbase.client.replication

    Methods in org.apache.hadoop.hbase.client.replication that return org.apache.hadoop.hbase.TableName in in
    Modifier and Type
    Method
    Description
    org.apache.hadoop.hbase.TableName
    TableCFs.getTable()
     
    Methods in org.apache.hadoop.hbase.client.replication that return types with arguments of type org.apache.hadoop.hbase.TableName in in
    Modifier and Type
    Method
    Description
    static Map<org.apache.hadoop.hbase.TableName,List<String>>
    ReplicationPeerConfigUtil.convert2Map(org.apache.hadoop.hbase.shaded.protobuf.generated.ReplicationProtos.TableCF[] tableCFs)
    Convert tableCFs Object to Map.
    static Map<org.apache.hadoop.hbase.TableName,List<String>>
    ReplicationAdmin.parseTableCFsFromConfig(String tableCFsConfig)
    Deprecated.
    as release of 2.0.0, and it will be removed in 3.0.0
    static Map<org.apache.hadoop.hbase.TableName,List<String>>
    ReplicationPeerConfigUtil.parseTableCFsFromConfig(String tableCFsConfig)
    Convert tableCFs string into Map.
    Methods in org.apache.hadoop.hbase.client.replication with parameters of type org.apache.hadoop.hbase.TableName in in
    Modifier and Type
    Method
    Description
    void
    ReplicationAdmin.disableTableRep(org.apache.hadoop.hbase.TableName tableName)
    Deprecated.
    use Admin.disableTableReplication(TableName) instead
    void
    ReplicationAdmin.enableTableRep(org.apache.hadoop.hbase.TableName tableName)
    Deprecated.
    use Admin.enableTableReplication(TableName) instead
    Method parameters in org.apache.hadoop.hbase.client.replication with type arguments of type org.apache.hadoop.hbase.TableName in in
    Modifier and Type
    Method
    Description
    void
    ReplicationAdmin.addPeer(String id, org.apache.hadoop.hbase.replication.ReplicationPeerConfig peerConfig, Map<org.apache.hadoop.hbase.TableName,? extends Collection<String>> tableCfs)
    Deprecated.
    as release of 2.0.0, and it will be removed in 3.0.0, use ReplicationAdmin.addPeer(String, ReplicationPeerConfig) instead.
    static org.apache.hadoop.hbase.replication.ReplicationPeerConfig
    ReplicationPeerConfigUtil.appendExcludeTableCFsToReplicationPeerConfig(Map<org.apache.hadoop.hbase.TableName,List<String>> excludeTableCfs, org.apache.hadoop.hbase.replication.ReplicationPeerConfig peerConfig)
     
    void
    ReplicationAdmin.appendPeerTableCFs(String id, Map<org.apache.hadoop.hbase.TableName,? extends Collection<String>> tableCfs)
    Deprecated.
    static org.apache.hadoop.hbase.replication.ReplicationPeerConfig
    ReplicationPeerConfigUtil.appendTableCFsToReplicationPeerConfig(Map<org.apache.hadoop.hbase.TableName,List<String>> tableCfs, org.apache.hadoop.hbase.replication.ReplicationPeerConfig peerConfig)
     
    static org.apache.hadoop.hbase.shaded.protobuf.generated.ReplicationProtos.TableCF[]
    ReplicationPeerConfigUtil.convert(Map<org.apache.hadoop.hbase.TableName,? extends Collection<String>> tableCfs)
    convert map to TableCFs Object
    static String
    ReplicationPeerConfigUtil.convertToString(Map<org.apache.hadoop.hbase.TableName,? extends Collection<String>> tableCfs)
     
    static org.apache.hadoop.hbase.replication.ReplicationPeerConfig
    ReplicationPeerConfigUtil.removeExcludeTableCFsFromReplicationPeerConfig(Map<org.apache.hadoop.hbase.TableName,List<String>> excludeTableCfs, org.apache.hadoop.hbase.replication.ReplicationPeerConfig peerConfig, String id)
     
    void
    ReplicationAdmin.removePeerTableCFs(String id, Map<org.apache.hadoop.hbase.TableName,? extends Collection<String>> tableCfs)
    Deprecated.
    static org.apache.hadoop.hbase.replication.ReplicationPeerConfig
    ReplicationPeerConfigUtil.removeTableCFsFromReplicationPeerConfig(Map<org.apache.hadoop.hbase.TableName,List<String>> tableCfs, org.apache.hadoop.hbase.replication.ReplicationPeerConfig peerConfig, String id)
     
    void
    ReplicationAdmin.setPeerTableCFs(String id, Map<org.apache.hadoop.hbase.TableName,? extends Collection<String>> tableCfs)
    Deprecated.
    Constructors in org.apache.hadoop.hbase.client.replication with parameters of type org.apache.hadoop.hbase.TableName in in
    Modifier
    Constructor
    Description
     
    TableCFs(org.apache.hadoop.hbase.TableName table, Map<String,Integer> cfs)
     
  • Uses of org.apache.hadoop.hbase.TableName in org.apache.hadoop.hbase.client.trace

    Methods in org.apache.hadoop.hbase.client.trace with parameters of type org.apache.hadoop.hbase.TableName in in
    Modifier and Type
    Method
    Description
    org.apache.hadoop.hbase.client.trace.TableOperationSpanBuilder
    TableOperationSpanBuilder.setTableName(org.apache.hadoop.hbase.TableName tableName)
     
    org.apache.hadoop.hbase.client.trace.TableSpanBuilder
    TableSpanBuilder.setTableName(org.apache.hadoop.hbase.TableName tableName)
     
  • Uses of org.apache.hadoop.hbase.TableName in org.apache.hadoop.hbase.coprocessor

    Methods in org.apache.hadoop.hbase.coprocessor with parameters of type org.apache.hadoop.hbase.TableName in in
    Modifier and Type
    Method
    Description
    default void
    MasterObserver.postCompletedDeleteTableAction(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.MasterCoprocessorEnvironment> ctx, org.apache.hadoop.hbase.TableName tableName)
    Called after HMaster deletes a table.
    default void
    MasterObserver.postCompletedDisableTableAction(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.MasterCoprocessorEnvironment> ctx, org.apache.hadoop.hbase.TableName tableName)
    Called after the disableTable operation has been requested.
    default void
    MasterObserver.postCompletedEnableTableAction(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.MasterCoprocessorEnvironment> ctx, org.apache.hadoop.hbase.TableName tableName)
    Called after the enableTable operation has been requested.
    default void
    MasterObserver.postCompletedModifyTableAction(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.MasterCoprocessorEnvironment> ctx, org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.TableDescriptor currentDescriptor)
    Deprecated.
    Since 2.1.
    default void
    MasterObserver.postCompletedModifyTableAction(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.MasterCoprocessorEnvironment> ctx, org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.TableDescriptor oldDescriptor, org.apache.hadoop.hbase.client.TableDescriptor currentDescriptor)
    Called after to modifying a table's properties.
    default void
    MasterObserver.postCompletedTruncateTableAction(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.MasterCoprocessorEnvironment> ctx, org.apache.hadoop.hbase.TableName tableName)
    Called after HMaster truncates a table.
    default void
    MasterObserver.postDeleteTable(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.MasterCoprocessorEnvironment> ctx, org.apache.hadoop.hbase.TableName tableName)
    Called after the deleteTable operation has been requested.
    default void
    MasterObserver.postDisableTable(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.MasterCoprocessorEnvironment> ctx, org.apache.hadoop.hbase.TableName tableName)
    Called after the disableTable operation has been requested.
    default void
    MasterObserver.postEnableTable(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.MasterCoprocessorEnvironment> ctx, org.apache.hadoop.hbase.TableName tableName)
    Called after the enableTable operation has been requested.
    default void
    MasterObserver.postGetUserPermissions(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.MasterCoprocessorEnvironment> ctx, String userName, String namespace, org.apache.hadoop.hbase.TableName tableName, byte[] family, byte[] qualifier)
    Called after getting user permissions.
    default void
    MasterObserver.postModifyColumnFamilyStoreFileTracker(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.MasterCoprocessorEnvironment> ctx, org.apache.hadoop.hbase.TableName tableName, byte[] family, String dstSFT)
    Called after modifying a family store file tracker.
    default void
    MasterObserver.postModifyTable(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.MasterCoprocessorEnvironment> ctx, org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.TableDescriptor currentDescriptor)
    Deprecated.
    Since 2.1.
    default void
    MasterObserver.postModifyTable(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.MasterCoprocessorEnvironment> ctx, org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.TableDescriptor oldDescriptor, org.apache.hadoop.hbase.client.TableDescriptor currentDescriptor)
    Called after the modifyTable operation has been requested.
    default void
    MasterObserver.postModifyTableStoreFileTracker(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.MasterCoprocessorEnvironment> ctx, org.apache.hadoop.hbase.TableName tableName, String dstSFT)
    Called after modifying a table's store file tracker.
    default void
    MasterObserver.postRequestLock(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.MasterCoprocessorEnvironment> ctx, String namespace, org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.RegionInfo[] regionInfos, String description)
    Called after new LockProcedure is queued.
    default void
    MasterObserver.postSetTableQuota(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.MasterCoprocessorEnvironment> ctx, org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.quotas.GlobalQuotaSettings quotas)
    Called after the quota for the table is stored.
    default void
    MasterObserver.postSetUserQuota(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.MasterCoprocessorEnvironment> ctx, String userName, org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.quotas.GlobalQuotaSettings quotas)
    Called after the quota for the user on the specified table is stored.
    default void
    MasterObserver.postTableFlush(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.MasterCoprocessorEnvironment> ctx, org.apache.hadoop.hbase.TableName tableName)
    Called after the table memstore is flushed to disk.
    default void
    MasterObserver.postTruncateTable(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.MasterCoprocessorEnvironment> ctx, org.apache.hadoop.hbase.TableName tableName)
    Called after the truncateTable operation has been requested.
    default void
    MasterObserver.preDeleteTable(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.MasterCoprocessorEnvironment> ctx, org.apache.hadoop.hbase.TableName tableName)
    Called before HMaster deletes a table.
    default void
    MasterObserver.preDeleteTableAction(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.MasterCoprocessorEnvironment> ctx, org.apache.hadoop.hbase.TableName tableName)
    Called before HMaster deletes a table.
    default void
    MasterObserver.preDisableTable(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.MasterCoprocessorEnvironment> ctx, org.apache.hadoop.hbase.TableName tableName)
    Called prior to disabling a table.
    default void
    MasterObserver.preDisableTableAction(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.MasterCoprocessorEnvironment> ctx, org.apache.hadoop.hbase.TableName tableName)
    Called prior to disabling a table.
    default void
    MasterObserver.preEnableTable(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.MasterCoprocessorEnvironment> ctx, org.apache.hadoop.hbase.TableName tableName)
    Called prior to enabling a table.
    default void
    MasterObserver.preEnableTableAction(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.MasterCoprocessorEnvironment> ctx, org.apache.hadoop.hbase.TableName tableName)
    Called prior to enabling a table.
    default void
    MasterObserver.preGetUserPermissions(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.MasterCoprocessorEnvironment> ctx, String userName, String namespace, org.apache.hadoop.hbase.TableName tableName, byte[] family, byte[] qualifier)
    Called before getting user permissions.
    default void
    MasterObserver.preLockHeartbeat(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.MasterCoprocessorEnvironment> ctx, org.apache.hadoop.hbase.TableName tn, String description)
    Called before heartbeat to a lock.
    default String
    MasterObserver.preModifyColumnFamilyStoreFileTracker(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.MasterCoprocessorEnvironment> ctx, org.apache.hadoop.hbase.TableName tableName, byte[] family, String dstSFT)
    Called prior to modifying a family's store file tracker.
    default void
    MasterObserver.preModifyTable(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.MasterCoprocessorEnvironment> ctx, org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.TableDescriptor newDescriptor)
    Deprecated.
    Since 2.1.
    default org.apache.hadoop.hbase.client.TableDescriptor
    MasterObserver.preModifyTable(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.MasterCoprocessorEnvironment> ctx, org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.TableDescriptor currentDescriptor, org.apache.hadoop.hbase.client.TableDescriptor newDescriptor)
    Called prior to modifying a table's properties.
    default void
    MasterObserver.preModifyTableAction(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.MasterCoprocessorEnvironment> ctx, org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.TableDescriptor newDescriptor)
    Deprecated.
    Since 2.1.
    default void
    MasterObserver.preModifyTableAction(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.MasterCoprocessorEnvironment> ctx, org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.TableDescriptor currentDescriptor, org.apache.hadoop.hbase.client.TableDescriptor newDescriptor)
    Called prior to modifying a table's properties.
    default String
    MasterObserver.preModifyTableStoreFileTracker(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.MasterCoprocessorEnvironment> ctx, org.apache.hadoop.hbase.TableName tableName, String dstSFT)
    Called prior to modifying a table's store file tracker.
    default void
    MasterObserver.preRequestLock(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.MasterCoprocessorEnvironment> ctx, String namespace, org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.RegionInfo[] regionInfos, String description)
    Called before new LockProcedure is queued.
    default void
    MasterObserver.preSetTableQuota(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.MasterCoprocessorEnvironment> ctx, org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.quotas.GlobalQuotaSettings quotas)
    Called before the quota for the table is stored.
    default void
    MasterObserver.preSetUserQuota(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.MasterCoprocessorEnvironment> ctx, String userName, org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.quotas.GlobalQuotaSettings quotas)
    Called before the quota for the user on the specified table is stored.
    default void
    MasterObserver.preSplitRegion(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.MasterCoprocessorEnvironment> c, org.apache.hadoop.hbase.TableName tableName, byte[] splitRow)
    Called before the split region procedure is called.
    default void
    MasterObserver.preSplitRegionAction(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.MasterCoprocessorEnvironment> c, org.apache.hadoop.hbase.TableName tableName, byte[] splitRow)
    Called before the region is split.
    default void
    MasterObserver.preTableFlush(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.MasterCoprocessorEnvironment> ctx, org.apache.hadoop.hbase.TableName tableName)
    Called before the table memstore is flushed to disk.
    default void
    MasterObserver.preTruncateTable(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.MasterCoprocessorEnvironment> ctx, org.apache.hadoop.hbase.TableName tableName)
    Called before HMaster truncates a table.
    default void
    MasterObserver.preTruncateTableAction(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.MasterCoprocessorEnvironment> ctx, org.apache.hadoop.hbase.TableName tableName)
    Called before HMaster truncates a table.
    Method parameters in org.apache.hadoop.hbase.coprocessor with type arguments of type org.apache.hadoop.hbase.TableName in in
    Modifier and Type
    Method
    Description
    default void
    MasterObserver.postGetTableDescriptors(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.MasterCoprocessorEnvironment> ctx, List<org.apache.hadoop.hbase.TableName> tableNamesList, List<org.apache.hadoop.hbase.client.TableDescriptor> descriptors, String regex)
    Called after a getTableDescriptors request has been processed.
    default void
    MasterObserver.postMoveTables(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.MasterCoprocessorEnvironment> ctx, Set<org.apache.hadoop.hbase.TableName> tables, String targetGroup)
    Called after servers are moved to target region server group
    default void
    MasterObserver.preGetTableDescriptors(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.MasterCoprocessorEnvironment> ctx, List<org.apache.hadoop.hbase.TableName> tableNamesList, List<org.apache.hadoop.hbase.client.TableDescriptor> descriptors, String regex)
    Called before a getTableDescriptors request has been processed.
    default void
    MasterObserver.preMoveTables(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.MasterCoprocessorEnvironment> ctx, Set<org.apache.hadoop.hbase.TableName> tables, String targetGroup)
    Called before tables are moved to target region server group
  • Uses of org.apache.hadoop.hbase.TableName in org.apache.hadoop.hbase.favored

    Methods in org.apache.hadoop.hbase.favored with parameters of type org.apache.hadoop.hbase.TableName in in
    Modifier and Type
    Method
    Description
    protected List<org.apache.hadoop.hbase.master.RegionPlan>
    FavoredNodeLoadBalancer.balanceTable(org.apache.hadoop.hbase.TableName tableName, Map<org.apache.hadoop.hbase.ServerName,List<org.apache.hadoop.hbase.client.RegionInfo>> loadOfOneTable)
     
  • Uses of org.apache.hadoop.hbase.TableName in org.apache.hadoop.hbase.io

    Methods in org.apache.hadoop.hbase.io that return org.apache.hadoop.hbase.TableName in in
    Modifier and Type
    Method
    Description
    static org.apache.hadoop.hbase.TableName
    HFileLink.getReferencedTableName(String fileName)
    Get the Table name of the referenced link
    Methods in org.apache.hadoop.hbase.io that return types with arguments of type org.apache.hadoop.hbase.TableName in in
    Modifier and Type
    Method
    Description
    static org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.TableName,String>
    HFileLink.parseBackReferenceName(String name)
     
    Methods in org.apache.hadoop.hbase.io with parameters of type org.apache.hadoop.hbase.TableName in in
    Modifier and Type
    Method
    Description
    static org.apache.hadoop.hbase.io.HFileLink
    HFileLink.build(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.TableName table, String region, String family, String hfile)
    Create an HFileLink instance from table/region/family/hfile location
    static String
    HFileLink.create(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.fs.Path dstFamilyPath, String familyName, String dstTableName, String dstRegionName, org.apache.hadoop.hbase.TableName linkedTable, String linkedRegion, String hfileName, boolean createBackRef)
    Create a new HFileLink
    static String
    HFileLink.create(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.fs.Path dstFamilyPath, org.apache.hadoop.hbase.TableName linkedTable, String linkedRegion, String hfileName)
    Create a new HFileLink
    static String
    HFileLink.create(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.fs.Path dstFamilyPath, org.apache.hadoop.hbase.TableName linkedTable, String linkedRegion, String hfileName, boolean createBackRef)
    Create a new HFileLink.
    static String
    HFileLink.createHFileLinkName(org.apache.hadoop.hbase.TableName tableName, String regionName, String hfileName)
    Create a new HFileLink name
    static org.apache.hadoop.fs.Path
    HFileLink.createPath(org.apache.hadoop.hbase.TableName table, String region, String family, String hfile)
    Create an HFileLink relative path for the table/region/family/hfile location
  • Uses of org.apache.hadoop.hbase.TableName in org.apache.hadoop.hbase.ipc

    Methods in org.apache.hadoop.hbase.ipc that return org.apache.hadoop.hbase.TableName in in
    Modifier and Type
    Method
    Description
    org.apache.hadoop.hbase.TableName
    DelegatingHBaseRpcController.getTableName()
     
    default org.apache.hadoop.hbase.TableName
    HBaseRpcController.getTableName()
    Returns Region's table name or null if not available or pertinent.
    org.apache.hadoop.hbase.TableName
    HBaseRpcControllerImpl.getTableName()
     
    Methods in org.apache.hadoop.hbase.ipc with parameters of type org.apache.hadoop.hbase.TableName in in
    Modifier and Type
    Method
    Description
    void
    DelegatingHBaseRpcController.setPriority(org.apache.hadoop.hbase.TableName tn)
     
    void
    HBaseRpcController.setPriority(org.apache.hadoop.hbase.TableName tn)
    Set the priority for this operation.
    void
    HBaseRpcControllerImpl.setPriority(org.apache.hadoop.hbase.TableName tn)
     
    void
    DelegatingHBaseRpcController.setTableName(org.apache.hadoop.hbase.TableName tableName)
     
    default void
    HBaseRpcController.setTableName(org.apache.hadoop.hbase.TableName tableName)
    Sets Region's table name.
    void
    HBaseRpcControllerImpl.setTableName(org.apache.hadoop.hbase.TableName tableName)
     
  • Uses of org.apache.hadoop.hbase.TableName in org.apache.hadoop.hbase.mapred

    Methods in org.apache.hadoop.hbase.mapred that return org.apache.hadoop.hbase.TableName in in
    Modifier and Type
    Method
    Description
    org.apache.hadoop.hbase.TableName
    TableSplit.getTable()
    Returns table name
    Methods in org.apache.hadoop.hbase.mapred with parameters of type org.apache.hadoop.hbase.TableName in in
    Modifier and Type
    Method
    Description
    protected void
    TableInputFormatBase.initializeTable(org.apache.hadoop.hbase.client.Connection connection, org.apache.hadoop.hbase.TableName tableName)
    Allows subclasses to initialize the table information.
    Constructors in org.apache.hadoop.hbase.mapred with parameters of type org.apache.hadoop.hbase.TableName in in
    Modifier
    Constructor
    Description
     
    TableSplit(org.apache.hadoop.hbase.TableName tableName, byte[] startRow, byte[] endRow, String location)
    Constructor
  • Uses of org.apache.hadoop.hbase.TableName in org.apache.hadoop.hbase.mapreduce

    Methods in org.apache.hadoop.hbase.mapreduce that return org.apache.hadoop.hbase.TableName in in
    Modifier and Type
    Method
    Description
    org.apache.hadoop.hbase.TableName
    TableSplit.getTable()
    Returns the table name.
    Methods in org.apache.hadoop.hbase.mapreduce that return types with arguments of type org.apache.hadoop.hbase.TableName in in
    Modifier and Type
    Method
    Description
    static org.apache.hadoop.hbase.util.Triple<org.apache.hadoop.hbase.TableName,org.apache.hadoop.hbase.client.Scan,org.apache.hadoop.fs.Path>
    ExportUtils.getArgumentsFromCommandLine(org.apache.hadoop.conf.Configuration conf, String[] args)
     
    Methods in org.apache.hadoop.hbase.mapreduce with parameters of type org.apache.hadoop.hbase.TableName in in
    Modifier and Type
    Method
    Description
    static void
    TableInputFormat.configureSplitTable(org.apache.hadoop.mapreduce.Job job, org.apache.hadoop.hbase.TableName tableName)
    Sets split table in map-reduce job.
    protected void
    TableInputFormatBase.initializeTable(org.apache.hadoop.hbase.client.Connection connection, org.apache.hadoop.hbase.TableName tableName)
    Allows subclasses to initialize the table information.
    static void
    TableMapReduceUtil.initTableMapperJob(org.apache.hadoop.hbase.TableName table, org.apache.hadoop.hbase.client.Scan scan, Class<? extends org.apache.hadoop.hbase.mapreduce.TableMapper> mapper, Class<?> outputKeyClass, Class<?> outputValueClass, org.apache.hadoop.mapreduce.Job job)
    Use this before submitting a TableMap job.
    Map<org.apache.hadoop.hbase.mapreduce.LoadIncrementalHFiles.LoadQueueItem,ByteBuffer>
    LoadIncrementalHFiles.run(String dirPath, Map<byte[],List<org.apache.hadoop.fs.Path>> map, org.apache.hadoop.hbase.TableName tableName)
    Deprecated.
     
    Constructors in org.apache.hadoop.hbase.mapreduce with parameters of type org.apache.hadoop.hbase.TableName in in
    Modifier
    Constructor
    Description
     
    TableSplit(org.apache.hadoop.hbase.TableName tableName, byte[] startRow, byte[] endRow, String location)
    Creates a new instance without a scanner.
     
    TableSplit(org.apache.hadoop.hbase.TableName tableName, byte[] startRow, byte[] endRow, String location, long length)
    Creates a new instance without a scanner.
     
    TableSplit(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.Scan scan, byte[] startRow, byte[] endRow, String location)
    Creates a new instance while assigning all variables.
     
    TableSplit(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.Scan scan, byte[] startRow, byte[] endRow, String location, long length)
    Creates a new instance while assigning all variables.
     
    TableSplit(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.Scan scan, byte[] startRow, byte[] endRow, String location, String encodedRegionName, long length)
    Creates a new instance while assigning all variables.
  • Uses of org.apache.hadoop.hbase.TableName in org.apache.hadoop.hbase.master

    Methods in org.apache.hadoop.hbase.master that return types with arguments of type org.apache.hadoop.hbase.TableName in in
    Modifier and Type
    Method
    Description
    Map<org.apache.hadoop.hbase.TableName,Integer>
    RegionPlacementMaintainer.getRegionsMovement(org.apache.hadoop.hbase.favored.FavoredNodesPlan newPlan)
    Return how many regions will move per table since their primary RS will change
    Set<org.apache.hadoop.hbase.TableName>
    SnapshotOfRegionAssignmentFromMeta.getTableSet()
    Get the table set
    Map<org.apache.hadoop.hbase.TableName,List<org.apache.hadoop.hbase.client.RegionInfo>>
    SnapshotOfRegionAssignmentFromMeta.getTableToRegionMap()
    Get regions for tables
    List<org.apache.hadoop.hbase.TableName>
    HMaster.listTableNames(String namespace, String regex, boolean includeSysTables)
    Returns the list of table names that match the specified request
    List<org.apache.hadoop.hbase.TableName>
    HMaster.listTableNamesByNamespace(String name)
     
    List<org.apache.hadoop.hbase.TableName>
    MasterServices.listTableNamesByNamespace(String name)
    Get list of table names by namespace
    Methods in org.apache.hadoop.hbase.master with parameters of type org.apache.hadoop.hbase.TableName in in
    Modifier and Type
    Method
    Description
    long
    HMaster.addColumn(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.ColumnFamilyDescriptor column, long nonceGroup, long nonce)
     
    long
    MasterServices.addColumn(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.ColumnFamilyDescriptor column, long nonceGroup, long nonce)
    Add a new column to an existing table
    void
    HMaster.checkTableModifiable(org.apache.hadoop.hbase.TableName tableName)
     
    void
    MasterServices.checkTableModifiable(org.apache.hadoop.hbase.TableName tableName)
    Check table is modifiable; i.e.
    long
    HMaster.deleteColumn(org.apache.hadoop.hbase.TableName tableName, byte[] columnName, long nonceGroup, long nonce)
     
    long
    MasterServices.deleteColumn(org.apache.hadoop.hbase.TableName tableName, byte[] columnName, long nonceGroup, long nonce)
    Delete a column from an existing table
    long
    HMaster.deleteTable(org.apache.hadoop.hbase.TableName tableName, long nonceGroup, long nonce)
     
    long
    MasterServices.deleteTable(org.apache.hadoop.hbase.TableName tableName, long nonceGroup, long nonce)
    Delete a table
    protected void
    TableStateManager.deleteZooKeeper(org.apache.hadoop.hbase.TableName tableName)
    Deprecated.
    Since 2.0.0.
    long
    HMaster.disableTable(org.apache.hadoop.hbase.TableName tableName, long nonceGroup, long nonce)
     
    long
    MasterServices.disableTable(org.apache.hadoop.hbase.TableName tableName, long nonceGroup, long nonce)
    Disable an existing table
    long
    HMaster.enableTable(org.apache.hadoop.hbase.TableName tableName, long nonceGroup, long nonce)
     
    long
    MasterServices.enableTable(org.apache.hadoop.hbase.TableName tableName, long nonceGroup, long nonce)
    Enable an existing table
    void
    AssignmentVerificationReport.fillUp(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.master.SnapshotOfRegionAssignmentFromMeta snapshot, Map<String,Map<String,Float>> regionLocalityMap)
     
    void
    AssignmentVerificationReport.fillUpDispersion(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.master.SnapshotOfRegionAssignmentFromMeta snapshot, org.apache.hadoop.hbase.favored.FavoredNodesPlan newPlan)
    Use this to project the dispersion scores
    long
    HMaster.flushTable(org.apache.hadoop.hbase.TableName tableName, List<byte[]> columnFamilies, long nonceGroup, long nonce)
     
    long
    MasterServices.flushTable(org.apache.hadoop.hbase.TableName tableName, List<byte[]> columnFamilies, long nonceGroup, long nonce)
    Flush an existing table
    org.apache.hadoop.hbase.client.CompactionState
    HMaster.getCompactionState(org.apache.hadoop.hbase.TableName tableName)
    Get the compaction state of the table
    long
    HMaster.getLastMajorCompactionTimestamp(org.apache.hadoop.hbase.TableName table)
     
    long
    MasterServices.getLastMajorCompactionTimestamp(org.apache.hadoop.hbase.TableName table)
     
    org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.GetRegionInfoResponse.CompactionState
    HMaster.getMobCompactionState(org.apache.hadoop.hbase.TableName tableName)
    Gets the mob file compaction state for a specific table.
    org.apache.hadoop.hbase.client.TableState
    TableStateManager.getTableState(org.apache.hadoop.hbase.TableName tableName)
     
    boolean
    TableStateManager.isTablePresent(org.apache.hadoop.hbase.TableName tableName)
     
    boolean
    TableStateManager.isTableState(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.TableState.State... states)
     
    protected void
    MirroringTableStateManager.metaStateDeleted(org.apache.hadoop.hbase.TableName tableName)
    Deprecated.
     
    protected void
    TableStateManager.metaStateDeleted(org.apache.hadoop.hbase.TableName tableName)
     
    protected void
    MirroringTableStateManager.metaStateUpdated(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.TableState.State newState)
    Deprecated.
     
    protected void
    TableStateManager.metaStateUpdated(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.TableState.State newState)
     
    long
    HMaster.modifyColumn(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.ColumnFamilyDescriptor descriptor, long nonceGroup, long nonce)
     
    long
    MasterServices.modifyColumn(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.ColumnFamilyDescriptor descriptor, long nonceGroup, long nonce)
    Modify the column descriptor of an existing column in an existing table
    long
    HMaster.modifyColumnStoreFileTracker(org.apache.hadoop.hbase.TableName tableName, byte[] family, String dstSFT, long nonceGroup, long nonce)
     
    long
    MasterServices.modifyColumnStoreFileTracker(org.apache.hadoop.hbase.TableName tableName, byte[] family, String dstSFT, long nonceGroup, long nonce)
    Modify the store file tracker of an existing column in an existing table
    long
    HMaster.modifyTable(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.TableDescriptor newDescriptor, long nonceGroup, long nonce, boolean reopenRegions)
     
    default long
    MasterServices.modifyTable(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.TableDescriptor descriptor, long nonceGroup, long nonce)
    Modify the descriptor of an existing table
    long
    MasterServices.modifyTable(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.TableDescriptor descriptor, long nonceGroup, long nonce, boolean reopenRegions)
    Modify the descriptor of an existing table
    long
    HMaster.modifyTableStoreFileTracker(org.apache.hadoop.hbase.TableName tableName, String dstSFT, long nonceGroup, long nonce)
     
    long
    MasterServices.modifyTableStoreFileTracker(org.apache.hadoop.hbase.TableName tableName, String dstSFT, long nonceGroup, long nonce)
    Modify the store file tracker of an existing table
    void
    MasterCoprocessorHost.postCompletedDeleteTableAction(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.security.User user)
     
    void
    MasterCoprocessorHost.postCompletedDisableTableAction(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.security.User user)
     
    void
    MasterCoprocessorHost.postCompletedEnableTableAction(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.security.User user)
     
    void
    MasterCoprocessorHost.postCompletedModifyTableAction(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.TableDescriptor oldDescriptor, org.apache.hadoop.hbase.client.TableDescriptor currentDescriptor, org.apache.hadoop.hbase.security.User user)
     
    void
    MasterCoprocessorHost.postCompletedTruncateTableAction(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.security.User user)
     
    void
    MasterCoprocessorHost.postDeleteTable(org.apache.hadoop.hbase.TableName tableName)
     
    void
    MasterCoprocessorHost.postDisableTable(org.apache.hadoop.hbase.TableName tableName)
     
    void
    MasterCoprocessorHost.postEnableTable(org.apache.hadoop.hbase.TableName tableName)
     
    void
    MasterCoprocessorHost.postGetUserPermissions(String userName, String namespace, org.apache.hadoop.hbase.TableName tableName, byte[] family, byte[] qualifier)
     
    void
    MasterCoprocessorHost.postModifyColumnFamilyStoreFileTracker(org.apache.hadoop.hbase.TableName tableName, byte[] family, String dstSFT)
     
    void
    MasterCoprocessorHost.postModifyTable(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.TableDescriptor oldDescriptor, org.apache.hadoop.hbase.client.TableDescriptor currentDescriptor)
     
    void
    MasterCoprocessorHost.postModifyTableStoreFileTracker(org.apache.hadoop.hbase.TableName tableName, String dstSFT)
     
    void
    MasterCoprocessorHost.postRequestLock(String namespace, org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.RegionInfo[] regionInfos, org.apache.hadoop.hbase.procedure2.LockType type, String description)
     
    void
    MasterCoprocessorHost.postSetTableQuota(org.apache.hadoop.hbase.TableName table, org.apache.hadoop.hbase.quotas.GlobalQuotaSettings quotas)
     
    void
    MasterCoprocessorHost.postSetUserQuota(String user, org.apache.hadoop.hbase.TableName table, org.apache.hadoop.hbase.quotas.GlobalQuotaSettings quotas)
     
    void
    MasterCoprocessorHost.postTableFlush(org.apache.hadoop.hbase.TableName tableName)
     
    void
    MasterCoprocessorHost.postTruncateTable(org.apache.hadoop.hbase.TableName tableName)
     
    void
    MasterCoprocessorHost.preDeleteTable(org.apache.hadoop.hbase.TableName tableName)
     
    void
    MasterCoprocessorHost.preDeleteTableAction(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.security.User user)
     
    void
    MasterCoprocessorHost.preDisableTable(org.apache.hadoop.hbase.TableName tableName)
     
    void
    MasterCoprocessorHost.preDisableTableAction(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.security.User user)
     
    void
    MasterCoprocessorHost.preEnableTable(org.apache.hadoop.hbase.TableName tableName)
     
    void
    MasterCoprocessorHost.preEnableTableAction(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.security.User user)
     
    void
    MasterCoprocessorHost.preGetUserPermissions(String userName, String namespace, org.apache.hadoop.hbase.TableName tableName, byte[] family, byte[] qualifier)
     
    MasterCoprocessorHost.preModifyColumnFamilyStoreFileTracker(org.apache.hadoop.hbase.TableName tableName, byte[] family, String dstSFT)
     
    org.apache.hadoop.hbase.client.TableDescriptor
    MasterCoprocessorHost.preModifyTable(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.TableDescriptor currentDescriptor, org.apache.hadoop.hbase.client.TableDescriptor newDescriptor)
     
    void
    MasterCoprocessorHost.preModifyTableAction(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.TableDescriptor currentDescriptor, org.apache.hadoop.hbase.client.TableDescriptor newDescriptor, org.apache.hadoop.hbase.security.User user)
     
    MasterCoprocessorHost.preModifyTableStoreFileTracker(org.apache.hadoop.hbase.TableName tableName, String dstSFT)
     
    void
    MasterCoprocessorHost.preRequestLock(String namespace, org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.RegionInfo[] regionInfos, org.apache.hadoop.hbase.procedure2.LockType type, String description)
     
    void
    MasterCoprocessorHost.preSetTableQuota(org.apache.hadoop.hbase.TableName table, org.apache.hadoop.hbase.quotas.GlobalQuotaSettings quotas)
     
    void
    MasterCoprocessorHost.preSetUserQuota(String user, org.apache.hadoop.hbase.TableName table, org.apache.hadoop.hbase.quotas.GlobalQuotaSettings quotas)
     
    void
    MasterCoprocessorHost.preSplitRegion(org.apache.hadoop.hbase.TableName tableName, byte[] splitRow)
    Invoked just before calling the split region procedure
    void
    MasterCoprocessorHost.preSplitRegionAction(org.apache.hadoop.hbase.TableName tableName, byte[] splitRow, org.apache.hadoop.hbase.security.User user)
    Invoked just before a split
    void
    MasterCoprocessorHost.preTableFlush(org.apache.hadoop.hbase.TableName tableName)
     
    void
    MasterCoprocessorHost.preTruncateTable(org.apache.hadoop.hbase.TableName tableName)
     
    void
    MasterCoprocessorHost.preTruncateTableAction(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.security.User user)
     
    void
    RegionPlacementMaintainer.printDispersionScores(org.apache.hadoop.hbase.TableName table, org.apache.hadoop.hbase.master.SnapshotOfRegionAssignmentFromMeta snapshot, int numRegions, org.apache.hadoop.hbase.favored.FavoredNodesPlan newPlan, boolean simplePrint)
     
    void
    HMaster.reportMobCompactionEnd(org.apache.hadoop.hbase.TableName tableName)
     
    void
    HMaster.reportMobCompactionStart(org.apache.hadoop.hbase.TableName tableName)
     
    void
    TableStateManager.setDeletedTable(org.apache.hadoop.hbase.TableName tableName)
     
    void
    TableStateManager.setTableState(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.TableState.State newState)
    Set table state to provided.
    long
    HMaster.truncateTable(org.apache.hadoop.hbase.TableName tableName, boolean preserveSplits, long nonceGroup, long nonce)
     
    long
    MasterServices.truncateTable(org.apache.hadoop.hbase.TableName tableName, boolean preserveSplits, long nonceGroup, long nonce)
    Truncate a table
    Method parameters in org.apache.hadoop.hbase.master with type arguments of type org.apache.hadoop.hbase.TableName in in
    Modifier and Type
    Method
    Description
    List<org.apache.hadoop.hbase.master.RegionPlan>
    LoadBalancer.balanceCluster(Map<org.apache.hadoop.hbase.TableName,Map<org.apache.hadoop.hbase.ServerName,List<org.apache.hadoop.hbase.client.RegionInfo>>> loadOfAllTable)
    Perform the major balance operation for cluster.
    void
    RegionPlacementMaintainer.checkDifferencesWithOldPlan(Map<org.apache.hadoop.hbase.TableName,Integer> movesPerTable, Map<String,Map<String,Float>> regionLocalityMap, org.apache.hadoop.hbase.favored.FavoredNodesPlan newPlan)
    Compares two plans and check whether the locality dropped or increased (prints the information as a string) also prints the baseline locality
    List<org.apache.hadoop.hbase.client.TableDescriptor>
    HMaster.listTableDescriptors(String namespace, String regex, List<org.apache.hadoop.hbase.TableName> tableNameList, boolean includeSysTables)
    Returns the list of table descriptors that match the specified request
    void
    MasterCoprocessorHost.postGetTableDescriptors(List<org.apache.hadoop.hbase.TableName> tableNamesList, List<org.apache.hadoop.hbase.client.TableDescriptor> descriptors, String regex)
     
    void
    MasterCoprocessorHost.postMoveTables(Set<org.apache.hadoop.hbase.TableName> tables, String targetGroup)
     
    void
    MasterCoprocessorHost.preGetTableDescriptors(List<org.apache.hadoop.hbase.TableName> tableNamesList, List<org.apache.hadoop.hbase.client.TableDescriptor> descriptors, String regex)
     
    void
    MasterCoprocessorHost.preMoveTables(Set<org.apache.hadoop.hbase.TableName> tables, String targetGroup)
     
    default void
    LoadBalancer.updateBalancerLoadInfo(Map<org.apache.hadoop.hbase.TableName,Map<org.apache.hadoop.hbase.ServerName,List<org.apache.hadoop.hbase.client.RegionInfo>>> loadOfAllTable)
    In some scenarios, Balancer needs to update internal status or information according to the current tables load
    Constructor parameters in org.apache.hadoop.hbase.master with type arguments of type org.apache.hadoop.hbase.TableName in in
    Modifier
    Constructor
    Description
     
    SnapshotOfRegionAssignmentFromMeta(org.apache.hadoop.hbase.client.Connection connection, Set<org.apache.hadoop.hbase.TableName> disabledTables, boolean excludeOfflinedSplitParents)
     
  • Uses of org.apache.hadoop.hbase.TableName in org.apache.hadoop.hbase.mob

    Methods in org.apache.hadoop.hbase.mob that return types with arguments of type org.apache.hadoop.hbase.TableName in in
    Modifier and Type
    Method
    Description
    static org.apache.hbase.thirdparty.com.google.common.collect.ImmutableSetMultimap.Builder<org.apache.hadoop.hbase.TableName,String>
    MobUtils.deserializeMobFileRefs(byte[] bytes)
    Deserialize the set of referenced mob hfiles from store file metadata.
    static Optional<org.apache.hadoop.hbase.TableName>
    MobUtils.getTableName(org.apache.hadoop.hbase.Cell cell)
    Get the table name from when this cell was written into a mob hfile as a TableName.
    Methods in org.apache.hadoop.hbase.mob with parameters of type org.apache.hadoop.hbase.TableName in in
    Modifier and Type
    Method
    Description
    void
    RSMobFileCleanerChore.archiveMobFiles(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.TableName tableName, byte[] family, List<org.apache.hadoop.fs.Path> storeFiles)
    Archives the mob files.
    static void
    MobUtils.cleanExpiredMobFiles(org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.ColumnFamilyDescriptor columnDescriptor, org.apache.hadoop.hbase.io.hfile.CacheConfig cacheConfig, long current)
    Cleans the expired mob files.
    static void
    MobFileCleanupUtil.cleanupObsoleteMobFiles(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.TableName table, org.apache.hadoop.hbase.client.Admin admin)
    Performs housekeeping file cleaning (called by MOB Cleaner chore)
    static org.apache.hadoop.fs.Path
    MobUtils.getMobFamilyPath(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.TableName tableName, String familyName)
    Gets the family dir of the mob files.
    static org.apache.hadoop.hbase.client.RegionInfo
    MobUtils.getMobRegionInfo(org.apache.hadoop.hbase.TableName tableName)
    Gets the RegionInfo of the mob files.
    static org.apache.hadoop.fs.Path
    MobUtils.getMobRegionPath(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.TableName tableName)
    Gets the region dir of the mob files.
    static org.apache.hadoop.fs.Path
    MobUtils.getMobRegionPath(org.apache.hadoop.fs.Path rootDir, org.apache.hadoop.hbase.TableName tableName)
    Gets the region dir of the mob files under the specified root dir.
    static org.apache.hadoop.fs.Path
    MobUtils.getMobTableDir(org.apache.hadoop.fs.Path rootDir, org.apache.hadoop.hbase.TableName tableName)
    Gets the table dir of the mob files under the qualified HBase root dir.
    static boolean
    MobUtils.isMobRegionName(org.apache.hadoop.hbase.TableName tableName, byte[] regionName)
    Gets whether the current region name follows the pattern of a mob region name.
    static boolean
    MobUtils.removeMobFiles(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.fs.Path tableDir, byte[] family, Collection<org.apache.hadoop.hbase.regionserver.HStoreFile> storeFiles)
    Archives the mob files.
    Method parameters in org.apache.hadoop.hbase.mob with type arguments of type org.apache.hadoop.hbase.TableName in in
    Modifier and Type
    Method
    Description
    static byte[]
    MobUtils.serializeMobFileRefs(org.apache.hbase.thirdparty.com.google.common.collect.SetMultimap<org.apache.hadoop.hbase.TableName,String> mobRefSet)
    Serialize a set of referenced mob hfiles
  • Uses of org.apache.hadoop.hbase.TableName in org.apache.hadoop.hbase.namequeues

    Fields in org.apache.hadoop.hbase.namequeues declared as org.apache.hadoop.hbase.TableName in in
    Modifier and Type
    Field
    Description
    static final org.apache.hadoop.hbase.TableName
    WALEventTrackerTableAccessor.WAL_EVENT_TRACKER_TABLE_NAME
    WALEventTrackerTableAccessor.WAL_EVENT_TRACKER_TABLE_NAME_STR table name - can be enabled with config - hbase.regionserver.wal.event.tracker.enabled
  • Uses of org.apache.hadoop.hbase.TableName in org.apache.hadoop.hbase.namespace

    Methods in org.apache.hadoop.hbase.namespace with parameters of type org.apache.hadoop.hbase.TableName in in
    Modifier and Type
    Method
    Description
    void
    NamespaceAuditor.checkQuotaToCreateTable(org.apache.hadoop.hbase.TableName tName, int regions)
    Check quota to create table.
    void
    NamespaceAuditor.checkQuotaToUpdateRegion(org.apache.hadoop.hbase.TableName tName, int regions)
    Check and update region count quota for an existing table.
    int
    NamespaceAuditor.getRegionCountOfTable(org.apache.hadoop.hbase.TableName tName)
    Get region count for table
    void
    NamespaceAuditor.removeFromNamespaceUsage(org.apache.hadoop.hbase.TableName tableName)
     
  • Uses of org.apache.hadoop.hbase.TableName in org.apache.hadoop.hbase.quotas

    Fields in org.apache.hadoop.hbase.quotas declared as org.apache.hadoop.hbase.TableName in in
    Modifier and Type
    Field
    Description
    static final org.apache.hadoop.hbase.TableName
    QuotaTableUtil.QUOTA_TABLE_NAME
    System table for quotas
    Methods in org.apache.hadoop.hbase.quotas that return org.apache.hadoop.hbase.TableName in in
    Modifier and Type
    Method
    Description
    protected static org.apache.hadoop.hbase.TableName
    QuotaTableUtil.getTableFromRowKey(byte[] key)
     
    org.apache.hadoop.hbase.TableName
    QuotaSettings.getTableName()
     
    Methods in org.apache.hadoop.hbase.quotas that return types with arguments of type org.apache.hadoop.hbase.TableName in in
    Modifier and Type
    Method
    Description
    Map<org.apache.hadoop.hbase.TableName,org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot>
    RegionServerSpaceQuotaManager.copyQuotaSnapshots()
    Copies the last SpaceQuotaSnapshots that were recorded.
    Map<org.apache.hadoop.hbase.TableName,org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot>
    SpaceQuotaRefresherChore.fetchSnapshotsFromQuotaTable()
    Reads all quota snapshots from the quota table.
    static Map<org.apache.hadoop.hbase.TableName,org.apache.hadoop.hbase.quotas.QuotaState>
    QuotaUtil.fetchTableQuotas(org.apache.hadoop.hbase.client.Connection connection, List<org.apache.hadoop.hbase.client.Get> gets, Map<org.apache.hadoop.hbase.TableName,Double> tableMachineFactors)
     
    Map<org.apache.hadoop.hbase.TableName,org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot>
    RegionServerSpaceQuotaManager.getActivePoliciesAsMap()
    Converts a map of table to SpaceViolationPolicyEnforcements into SpaceViolationPolicys.
    Map<org.apache.hadoop.hbase.TableName,org.apache.hadoop.hbase.quotas.SpaceViolationPolicyEnforcement>
    ActivePolicyEnforcement.getPolicies()
    Returns an unmodifiable version of the active SpaceViolationPolicyEnforcements.
    static Map<org.apache.hadoop.hbase.TableName,org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot>
    QuotaTableUtil.getSnapshots(org.apache.hadoop.hbase.client.Connection conn)
    Fetches all SpaceQuotaSnapshot objects from the hbase:quota table.
    Map<org.apache.hadoop.hbase.TableName,org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot>
    QuotaObserverChore.getTableQuotaSnapshots()
    Returns an unmodifiable view over the current SpaceQuotaSnapshot objects for each HBase table with a quota defined.
    static org.apache.hbase.thirdparty.com.google.common.collect.Multimap<org.apache.hadoop.hbase.TableName,String>
    QuotaTableUtil.getTableSnapshots(org.apache.hadoop.hbase.client.Connection conn)
    Returns a multimap for all existing table snapshot entries.
    Methods in org.apache.hadoop.hbase.quotas with parameters of type org.apache.hadoop.hbase.TableName in in
    Modifier and Type
    Method
    Description
    static void
    QuotaUtil.addTableQuota(org.apache.hadoop.hbase.client.Connection connection, org.apache.hadoop.hbase.TableName table, org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Quotas data)
     
    static void
    QuotaUtil.addUserQuota(org.apache.hadoop.hbase.client.Connection connection, String user, org.apache.hadoop.hbase.TableName table, org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Quotas data)
     
    boolean
    RegionServerSpaceQuotaManager.areCompactionsDisabled(org.apache.hadoop.hbase.TableName tableName)
    Returns whether or not compactions should be disabled for the given tableName per a space quota violation policy.
    org.apache.hadoop.hbase.shaded.protobuf.generated.RegionServerStatusProtos.FileArchiveNotificationRequest
    RegionServerSpaceQuotaManager.buildFileArchiveRequest(org.apache.hadoop.hbase.TableName tn, Collection<Map.Entry<String,Long>> archivedFiles)
    Builds the protobuf message to inform the Master of files being archived.
    void
    MasterQuotaManager.checkAndUpdateNamespaceRegionQuota(org.apache.hadoop.hbase.TableName tName, int regions)
     
    void
    MasterQuotaManager.checkNamespaceTableAndRegionQuota(org.apache.hadoop.hbase.TableName tName, int regions)
     
    org.apache.hadoop.hbase.quotas.SpaceViolationPolicyEnforcement
    SpaceViolationPolicyEnforcementFactory.create(org.apache.hadoop.hbase.regionserver.RegionServerServices rss, org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot snapshot)
    Constructs the appropriate SpaceViolationPolicyEnforcement for tables that are in violation of their space quota.
    org.apache.hadoop.hbase.quotas.SpaceViolationPolicyEnforcement
    SpaceViolationPolicyEnforcementFactory.createWithoutViolation(org.apache.hadoop.hbase.regionserver.RegionServerServices rss, org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot snapshot)
    Creates the "default" SpaceViolationPolicyEnforcement for a table that isn't in violation.
    static void
    QuotaUtil.deleteTableQuota(org.apache.hadoop.hbase.client.Connection connection, org.apache.hadoop.hbase.TableName table)
     
    static void
    QuotaUtil.deleteUserQuota(org.apache.hadoop.hbase.client.Connection connection, String user, org.apache.hadoop.hbase.TableName table)
     
    static void
    QuotaUtil.disableTableIfNotDisabled(org.apache.hadoop.hbase.client.Connection conn, org.apache.hadoop.hbase.TableName tableName)
    Method to disable a table, if not already disabled.
    void
    RegionServerSpaceQuotaManager.disableViolationPolicyEnforcement(org.apache.hadoop.hbase.TableName tableName)
    Disables enforcement on any violation policy on the given tableName.
    static void
    QuotaUtil.enableTableIfNotEnabled(org.apache.hadoop.hbase.client.Connection conn, org.apache.hadoop.hbase.TableName tableName)
    Method to enable a table, if not already enabled.
    void
    RegionServerSpaceQuotaManager.enforceViolationPolicy(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot snapshot)
    Enforces the given violationPolicy on the given table in this RegionServer.
    Iterable<Map.Entry<org.apache.hadoop.hbase.client.RegionInfo,Long>>
    TableQuotaSnapshotStore.filterBySubject(org.apache.hadoop.hbase.TableName table)
     
    static List<org.apache.hadoop.hbase.quotas.ThrottleSettings>
    QuotaSettingsFactory.fromTableThrottles(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Throttle throttle)
     
    protected static List<org.apache.hadoop.hbase.quotas.ThrottleSettings>
    QuotaSettingsFactory.fromThrottle(String userName, org.apache.hadoop.hbase.TableName tableName, String namespace, String regionServer, org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Throttle throttle)
     
    org.apache.hadoop.hbase.quotas.FileArchiverNotifier
    FileArchiverNotifierFactory.get(org.apache.hadoop.hbase.client.Connection conn, org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.hbase.TableName tn)
    Creates or obtains a FileArchiverNotifier instance for the given args.
    org.apache.hadoop.hbase.quotas.FileArchiverNotifier
    FileArchiverNotifierFactoryImpl.get(org.apache.hadoop.hbase.client.Connection conn, org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.hbase.TableName tn)
    Returns the FileArchiverNotifier instance for the given TableName.
    static org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot
    QuotaTableUtil.getCurrentSnapshotFromQuotaTable(org.apache.hadoop.hbase.client.Connection conn, org.apache.hadoop.hbase.TableName tableName)
    Returns the current space quota snapshot of the given tableName from QuotaTableUtil.QUOTA_TABLE_NAME or null if the no quota information is available for that tableName.
    org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot
    TableQuotaSnapshotStore.getCurrentState(org.apache.hadoop.hbase.TableName table)
     
    org.apache.hadoop.hbase.quotas.SpaceViolationPolicyEnforcement
    ActivePolicyEnforcement.getPolicyEnforcement(org.apache.hadoop.hbase.TableName tableName)
    Returns the proper SpaceViolationPolicyEnforcement implementation for the given table.
    org.apache.hadoop.hbase.quotas.OperationQuota
    RegionServerRpcQuotaManager.getQuota(org.apache.hadoop.security.UserGroupInformation ugi, org.apache.hadoop.hbase.TableName table, int blockSizeBytes)
    Returns the quota for an operation.
    int
    MasterQuotaManager.getRegionCountOfTable(org.apache.hadoop.hbase.TableName tName)
    Returns cached region count, or -1 if quota manager is disabled or table status not found
    protected static byte[]
    QuotaTableUtil.getSettingsQualifierForUserTable(org.apache.hadoop.hbase.TableName tableName)
     
    org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.SpaceQuota
    TableQuotaSnapshotStore.getSpaceQuota(org.apache.hadoop.hbase.TableName subject)
     
    org.apache.hadoop.hbase.quotas.QuotaLimiter
    QuotaCache.getTableLimiter(org.apache.hadoop.hbase.TableName table)
    Returns the limiter associated to the specified table.
    org.apache.hadoop.hbase.quotas.QuotaLimiter
    UserQuotaState.getTableLimiter(org.apache.hadoop.hbase.TableName table)
    Return the limiter for the specified table associated with this quota.
    static org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Quotas
    QuotaTableUtil.getTableQuota(org.apache.hadoop.hbase.client.Connection connection, org.apache.hadoop.hbase.TableName table)
     
    protected static byte[]
    QuotaTableUtil.getTableRowKey(org.apache.hadoop.hbase.TableName table)
     
    org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot
    TableQuotaSnapshotStore.getTargetState(org.apache.hadoop.hbase.TableName table, org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.SpaceQuota spaceQuota)
     
    org.apache.hadoop.hbase.quotas.QuotaLimiter
    QuotaCache.getUserLimiter(org.apache.hadoop.security.UserGroupInformation ugi, org.apache.hadoop.hbase.TableName table)
    Returns the limiter associated to the specified user/table.
    static org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Quotas
    QuotaTableUtil.getUserQuota(org.apache.hadoop.hbase.client.Connection connection, String user, org.apache.hadoop.hbase.TableName table)
     
    void
    SpaceViolationPolicyEnforcement.initialize(org.apache.hadoop.hbase.regionserver.RegionServerServices rss, org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot snapshot)
    Initializes this policy instance.
    static org.apache.hadoop.hbase.quotas.QuotaSettings
    QuotaSettingsFactory.limitTableSpace(org.apache.hadoop.hbase.TableName tableName, long sizeLimit, org.apache.hadoop.hbase.quotas.SpaceViolationPolicy violationPolicy)
    Creates a QuotaSettings object to limit the FileSystem space usage for the given table to the given size in bytes.
    static org.apache.hadoop.hbase.client.Get
    QuotaTableUtil.makeGetForTableQuotas(org.apache.hadoop.hbase.TableName table)
     
    static org.apache.hadoop.hbase.client.Get
    QuotaTableUtil.makeQuotaSnapshotGetForTable(org.apache.hadoop.hbase.TableName tn)
    Creates a Get which returns only SpaceQuotaSnapshot from the quota table for a specific table.
    static org.apache.hadoop.hbase.client.Scan
    QuotaTableUtil.makeQuotaSnapshotScanForTable(org.apache.hadoop.hbase.TableName tn)
    Creates a Scan which returns only SpaceQuotaSnapshot from the quota table for a specific table.
    protected static void
    QuotaTableUtil.parseTableResult(org.apache.hadoop.hbase.TableName table, org.apache.hadoop.hbase.client.Result result, org.apache.hadoop.hbase.quotas.QuotaTableUtil.TableQuotasVisitor visitor)
     
    void
    MasterQuotasObserver.postDeleteTable(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.MasterCoprocessorEnvironment> ctx, org.apache.hadoop.hbase.TableName tableName)
     
    void
    MasterQuotaManager.removeRegionSizesForTable(org.apache.hadoop.hbase.TableName tableName)
    Removes each region size entry where the RegionInfo references the provided TableName.
    void
    MasterQuotaManager.removeTableFromNamespaceQuota(org.apache.hadoop.hbase.TableName tName)
    Remove table from namespace quota.
    static org.apache.hadoop.hbase.quotas.QuotaSettings
    QuotaSettingsFactory.removeTableSpaceLimit(org.apache.hadoop.hbase.TableName tableName)
    Creates a QuotaSettings object to remove the FileSystem space quota for the given table.
    void
    TableQuotaSnapshotStore.setCurrentState(org.apache.hadoop.hbase.TableName table, org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot snapshot)
     
    void
    UserQuotaState.setQuotas(org.apache.hadoop.hbase.TableName table, org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Quotas quotas)
    Add the quota information of the specified table.
    void
    MasterQuotaManager.setTableQuota(org.apache.hadoop.hbase.TableName table, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.SetQuotaRequest req)
     
    void
    MasterQuotaManager.setUserQuota(String userName, org.apache.hadoop.hbase.TableName table, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.SetQuotaRequest req)
     
    static org.apache.hadoop.hbase.quotas.QuotaSettings
    QuotaSettingsFactory.throttleTable(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.quotas.ThrottleType type, long limit, TimeUnit timeUnit)
    Throttle the specified table.
    static org.apache.hadoop.hbase.quotas.QuotaSettings
    QuotaSettingsFactory.throttleTable(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.quotas.ThrottleType type, long limit, TimeUnit timeUnit, org.apache.hadoop.hbase.quotas.QuotaScope scope)
    Throttle the specified table.
    static org.apache.hadoop.hbase.quotas.QuotaSettings
    QuotaSettingsFactory.throttleUser(String userName, org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.quotas.ThrottleType type, long limit, TimeUnit timeUnit)
    Throttle the specified user on the specified table.
    static org.apache.hadoop.hbase.quotas.QuotaSettings
    QuotaSettingsFactory.throttleUser(String userName, org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.quotas.ThrottleType type, long limit, TimeUnit timeUnit, org.apache.hadoop.hbase.quotas.QuotaScope scope)
    Throttle the specified user on the specified table.
    void
    SpaceQuotaSnapshotNotifier.transitionTable(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot snapshot)
    Informs the cluster of the current state of a space quota for a table.
    void
    TableSpaceQuotaSnapshotNotifier.transitionTable(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot snapshot)
     
    static org.apache.hadoop.hbase.quotas.QuotaSettings
    QuotaSettingsFactory.unthrottleTable(org.apache.hadoop.hbase.TableName tableName)
    Remove the throttling for the specified table.
    static org.apache.hadoop.hbase.quotas.QuotaSettings
    QuotaSettingsFactory.unthrottleTableByThrottleType(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.quotas.ThrottleType type)
    Remove the throttling for the specified table.
    static org.apache.hadoop.hbase.quotas.QuotaSettings
    QuotaSettingsFactory.unthrottleUser(String userName, org.apache.hadoop.hbase.TableName tableName)
    Remove the throttling for the specified user on the specified table.
    static org.apache.hadoop.hbase.quotas.QuotaSettings
    QuotaSettingsFactory.unthrottleUserByThrottleType(String userName, org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.quotas.ThrottleType type)
    Remove the throttling for the specified user on the specified table.
    void
    QuotaTableUtil.TableQuotasVisitor.visitTableQuotas(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Quotas quotas)
     
    void
    QuotaTableUtil.UserQuotasVisitor.visitUserQuotas(String userName, org.apache.hadoop.hbase.TableName table, org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Quotas quotas)
     
    Method parameters in org.apache.hadoop.hbase.quotas with type arguments of type org.apache.hadoop.hbase.TableName in in
    Modifier and Type
    Method
    Description
    static void
    QuotaTableUtil.extractQuotaSnapshot(org.apache.hadoop.hbase.client.Result result, Map<org.apache.hadoop.hbase.TableName,org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot> snapshots)
    Extracts the SpaceViolationPolicy and TableName from the provided Result and adds them to the given Map.
    static Map<org.apache.hadoop.hbase.TableName,org.apache.hadoop.hbase.quotas.QuotaState>
    QuotaUtil.fetchTableQuotas(org.apache.hadoop.hbase.client.Connection connection, List<org.apache.hadoop.hbase.client.Get> gets, Map<org.apache.hadoop.hbase.TableName,Double> tableMachineFactors)
     
    static Map<String,org.apache.hadoop.hbase.quotas.UserQuotaState>
    QuotaUtil.fetchUserQuotas(org.apache.hadoop.hbase.client.Connection connection, List<org.apache.hadoop.hbase.client.Get> gets, Map<org.apache.hadoop.hbase.TableName,Double> tableMachineQuotaFactors, double factor)
     
    static org.apache.hadoop.hbase.client.Get
    QuotaTableUtil.makeGetForUserQuotas(String user, Iterable<org.apache.hadoop.hbase.TableName> tables, Iterable<String> namespaces)
     
    void
    RegionServerSpaceQuotaManager.updateQuotaSnapshot(Map<org.apache.hadoop.hbase.TableName,org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot> newSnapshots)
    Updates the current SpaceQuotaSnapshots for the RegionServer.
    Constructors in org.apache.hadoop.hbase.quotas with parameters of type org.apache.hadoop.hbase.TableName in in
    Modifier
    Constructor
    Description
     
    FileArchiverNotifierImpl(org.apache.hadoop.hbase.client.Connection conn, org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.hbase.TableName tn)
     
    protected
    GlobalQuotaSettings(String userName, org.apache.hadoop.hbase.TableName tableName, String namespace, String regionServer)
     
    protected
    GlobalQuotaSettingsImpl(String username, org.apache.hadoop.hbase.TableName tableName, String namespace, String regionServer, org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Quotas quotas)
     
    protected
    GlobalQuotaSettingsImpl(String userName, org.apache.hadoop.hbase.TableName tableName, String namespace, String regionServer, org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Throttle throttleProto, Boolean bypassGlobals, org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.SpaceQuota spaceProto)
     
    protected
    QuotaSettings(String userName, org.apache.hadoop.hbase.TableName tableName, String namespace, String regionServer)
     
    Constructor parameters in org.apache.hadoop.hbase.quotas with type arguments of type org.apache.hadoop.hbase.TableName in in
    Modifier
    Constructor
    Description
     
    ActivePolicyEnforcement(Map<org.apache.hadoop.hbase.TableName,org.apache.hadoop.hbase.quotas.SpaceViolationPolicyEnforcement> activePolicies, Map<org.apache.hadoop.hbase.TableName,org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot> snapshots, org.apache.hadoop.hbase.regionserver.RegionServerServices rss)
     
     
    ActivePolicyEnforcement(Map<org.apache.hadoop.hbase.TableName,org.apache.hadoop.hbase.quotas.SpaceViolationPolicyEnforcement> activePolicies, Map<org.apache.hadoop.hbase.TableName,org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot> snapshots, org.apache.hadoop.hbase.regionserver.RegionServerServices rss, org.apache.hadoop.hbase.quotas.SpaceViolationPolicyEnforcementFactory factory)
     
  • Uses of org.apache.hadoop.hbase.TableName in org.apache.hadoop.hbase.quotas.policies

    Methods in org.apache.hadoop.hbase.quotas.policies that return org.apache.hadoop.hbase.TableName in in
    Modifier and Type
    Method
    Description
    org.apache.hadoop.hbase.TableName
    AbstractViolationPolicyEnforcement.getTableName()
     
    Methods in org.apache.hadoop.hbase.quotas.policies with parameters of type org.apache.hadoop.hbase.TableName in in
    Modifier and Type
    Method
    Description
    void
    AbstractViolationPolicyEnforcement.initialize(org.apache.hadoop.hbase.regionserver.RegionServerServices rss, org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot snapshot)
     
    void
    AbstractViolationPolicyEnforcement.setTableName(org.apache.hadoop.hbase.TableName tableName)
     
  • Uses of org.apache.hadoop.hbase.TableName in org.apache.hadoop.hbase.regionserver

    Methods in org.apache.hadoop.hbase.regionserver that return org.apache.hadoop.hbase.TableName in in
    Modifier and Type
    Method
    Description
    org.apache.hadoop.hbase.TableName
    HStore.getTableName()
     
    org.apache.hadoop.hbase.TableName
    Store.getTableName()
     
    org.apache.hadoop.hbase.TableName
    StoreContext.getTableName()
     
    Methods in org.apache.hadoop.hbase.regionserver that return types with arguments of type org.apache.hadoop.hbase.TableName in in
    Modifier and Type
    Method
    Description
    Set<org.apache.hadoop.hbase.TableName>
    HRegionServer.getOnlineTables()
    Gets the online tables in this RS.
    Methods in org.apache.hadoop.hbase.regionserver with parameters of type org.apache.hadoop.hbase.TableName in in
    Modifier and Type
    Method
    Description
    List<org.apache.hadoop.fs.Path>
    HMobStore.getLocations(org.apache.hadoop.hbase.TableName tableName)
     
    List<org.apache.hadoop.hbase.regionserver.HRegion>
    HRegionServer.getRegions(org.apache.hadoop.hbase.TableName tableName)
    Gets the online regions of the specified table.
    List<? extends org.apache.hadoop.hbase.regionserver.Region>
    OnlineRegions.getRegions(org.apache.hadoop.hbase.TableName tableName)
    Get all online regions of a table in this RS.
    boolean
    HRegionServer.reportFileArchivalForQuotas(org.apache.hadoop.hbase.TableName tableName, Collection<Map.Entry<String,Long>> archivedFiles)
     
    boolean
    RegionServerServices.reportFileArchivalForQuotas(org.apache.hadoop.hbase.TableName tableName, Collection<Map.Entry<String,Long>> archivedFiles)
    Reports a collection of files, and their sizes, that belonged to the given table were just moved to the archive directory.
    Method parameters in org.apache.hadoop.hbase.regionserver with type arguments of type org.apache.hadoop.hbase.TableName in in
    Modifier and Type
    Method
    Description
    void
    StoreFileWriter.appendMobMetadata(org.apache.hbase.thirdparty.com.google.common.collect.SetMultimap<org.apache.hadoop.hbase.TableName,String> mobRefSet)
    Appends MOB - specific metadata (even if it is empty)
  • Uses of org.apache.hadoop.hbase.TableName in org.apache.hadoop.hbase.regionserver.metrics

    Constructors in org.apache.hadoop.hbase.regionserver.metrics with parameters of type org.apache.hadoop.hbase.TableName in in
    Modifier
    Constructor
    Description
     
    MetricsTableRequests(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.conf.Configuration conf)
     
  • Uses of org.apache.hadoop.hbase.TableName in org.apache.hadoop.hbase.regionserver.storefiletracker

    Methods in org.apache.hadoop.hbase.regionserver.storefiletracker that return org.apache.hadoop.hbase.TableName in in
    Modifier and Type
    Method
    Description
    org.apache.hadoop.hbase.TableName
    ModifyStoreFileTrackerProcedure.getTableName()
     
    Constructors in org.apache.hadoop.hbase.regionserver.storefiletracker with parameters of type org.apache.hadoop.hbase.TableName in in
    Modifier
    Constructor
    Description
     
    InitializeStoreFileTrackerProcedure(org.apache.hadoop.hbase.master.procedure.MasterProcedureEnv env, org.apache.hadoop.hbase.TableName tableName)
     
     
    ModifyColumnFamilyStoreFileTrackerProcedure(org.apache.hadoop.hbase.master.procedure.MasterProcedureEnv env, org.apache.hadoop.hbase.TableName tableName, byte[] family, String dstSFT)
     
    protected
    ModifyStoreFileTrackerProcedure(org.apache.hadoop.hbase.master.procedure.MasterProcedureEnv env, org.apache.hadoop.hbase.TableName tableName, String dstSFT)
     
     
    ModifyTableStoreFileTrackerProcedure(org.apache.hadoop.hbase.master.procedure.MasterProcedureEnv env, org.apache.hadoop.hbase.TableName tableName, String dstSFT)
     
  • Uses of org.apache.hadoop.hbase.TableName in org.apache.hadoop.hbase.regionserver.wal

    Methods in org.apache.hadoop.hbase.regionserver.wal with parameters of type org.apache.hadoop.hbase.TableName in in
    Modifier and Type
    Method
    Description
    void
    MetricsWALSource.incrementAppendCount(org.apache.hadoop.hbase.TableName tableName)
    Increment the count of wal appends
    void
    MetricsWALSourceImpl.incrementAppendCount(org.apache.hadoop.hbase.TableName tableName)
     
    void
    MetricsWALSource.incrementAppendSize(org.apache.hadoop.hbase.TableName tableName, long size)
    Add the append size.
    void
    MetricsWALSourceImpl.incrementAppendSize(org.apache.hadoop.hbase.TableName tableName, long size)
     
  • Uses of org.apache.hadoop.hbase.TableName in org.apache.hadoop.hbase.replication

    Methods in org.apache.hadoop.hbase.replication that return types with arguments of type org.apache.hadoop.hbase.TableName in in
    Modifier and Type
    Method
    Description
    Map<org.apache.hadoop.hbase.TableName,List<String>>
    ReplicationPeerConfig.getExcludeTableCFsMap()
     
    Map<org.apache.hadoop.hbase.TableName,List<String>>
    ReplicationPeer.getTableCFs()
    Get replicable (table, cf-list) map of this peer
    Map<org.apache.hadoop.hbase.TableName,List<String>>
    ReplicationPeerImpl.getTableCFs()
    Get replicable (table, cf-list) map of this peer
    Map<org.apache.hadoop.hbase.TableName,List<String>>
    ReplicationPeerConfig.getTableCFsMap()
     
    Methods in org.apache.hadoop.hbase.replication with parameters of type org.apache.hadoop.hbase.TableName in in
    Modifier and Type
    Method
    Description
    static boolean
    ReplicationUtils.contains(org.apache.hadoop.hbase.replication.ReplicationPeerConfig peerConfig, org.apache.hadoop.hbase.TableName tableName)
    Deprecated.
    Will be removed in HBase 3.
    boolean
    ReplicationPeerConfig.needToReplicate(org.apache.hadoop.hbase.TableName table)
    Decide whether the table need replicate to the peer cluster
    boolean
    ReplicationPeerConfig.needToReplicate(org.apache.hadoop.hbase.TableName table, byte[] family)
    Decide whether the passed family of the table need replicate to the peer cluster according to this peer config.
    Method parameters in org.apache.hadoop.hbase.replication with type arguments of type org.apache.hadoop.hbase.TableName in in
    Modifier and Type
    Method
    Description
    org.apache.hadoop.hbase.replication.ReplicationPeerConfig
    ReplicationPeerConfig.setExcludeTableCFsMap(Map<org.apache.hadoop.hbase.TableName,? extends Collection<String>> tableCFsMap)
    Deprecated.
    as release of 2.0.0, and it will be removed in 3.0.0.
    org.apache.hadoop.hbase.replication.ReplicationPeerConfigBuilder
    ReplicationPeerConfigBuilder.setExcludeTableCFsMap(Map<org.apache.hadoop.hbase.TableName,List<String>> tableCFsMap)
    Sets the mapping of table name to column families which should not be replicated.
    org.apache.hadoop.hbase.replication.ReplicationPeerConfig
    ReplicationPeerConfig.setTableCFsMap(Map<org.apache.hadoop.hbase.TableName,? extends Collection<String>> tableCFsMap)
    Deprecated.
    as release of 2.0.0, and it will be removed in 3.0.0.
    org.apache.hadoop.hbase.replication.ReplicationPeerConfigBuilder
    ReplicationPeerConfigBuilder.setTableCFsMap(Map<org.apache.hadoop.hbase.TableName,List<String>> tableCFsMap)
    Sets an explicit map of tables and column families in those tables that should be replicated to the given peer.
  • Uses of org.apache.hadoop.hbase.TableName in org.apache.hadoop.hbase.rsgroup

    Fields in org.apache.hadoop.hbase.rsgroup declared as org.apache.hadoop.hbase.TableName in in
    Modifier and Type
    Field
    Description
    static final org.apache.hadoop.hbase.TableName
    RSGroupInfoManager.RSGROUP_TABLE_NAME
     
    Methods in org.apache.hadoop.hbase.rsgroup that return types with arguments of type org.apache.hadoop.hbase.TableName in in
    Modifier and Type
    Method
    Description
    SortedSet<org.apache.hadoop.hbase.TableName>
    RSGroupInfo.getTables()
    Get set of tables that are members of the group.
    Methods in org.apache.hadoop.hbase.rsgroup with parameters of type org.apache.hadoop.hbase.TableName in in
    Modifier and Type
    Method
    Description
    void
    RSGroupInfo.addTable(org.apache.hadoop.hbase.TableName table)
     
    boolean
    RSGroupInfo.containsTable(org.apache.hadoop.hbase.TableName table)
     
    org.apache.hadoop.hbase.rsgroup.RSGroupInfo
    RSGroupInfoManager.determineRSGroupInfoForTable(org.apache.hadoop.hbase.TableName tableName)
    Determine RSGroupInfo for the given table.
    org.apache.hadoop.hbase.rsgroup.RSGroupInfo
    RSGroupAdmin.getRSGroupInfoOfTable(org.apache.hadoop.hbase.TableName tableName)
    Gets RSGroupInfo for the given table's group.
    org.apache.hadoop.hbase.rsgroup.RSGroupInfo
    RSGroupAdminClient.getRSGroupInfoOfTable(org.apache.hadoop.hbase.TableName tableName)
     
    org.apache.hadoop.hbase.rsgroup.RSGroupInfo
    RSGroupAdminServer.getRSGroupInfoOfTable(org.apache.hadoop.hbase.TableName tableName)
     
    RSGroupInfoManager.getRSGroupOfTable(org.apache.hadoop.hbase.TableName tableName)
    Get the group membership of a table
    void
    RSGroupAdminEndpoint.postCompletedModifyTableAction(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.MasterCoprocessorEnvironment> ctx, org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.TableDescriptor oldDescriptor, org.apache.hadoop.hbase.client.TableDescriptor currentDescriptor)
     
    void
    RSGroupAdminEndpoint.postDeleteTable(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.MasterCoprocessorEnvironment> ctx, org.apache.hadoop.hbase.TableName tableName)
     
    void
    RSGroupAdminEndpoint.preModifyTableAction(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.MasterCoprocessorEnvironment> ctx, org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.TableDescriptor currentDescriptor, org.apache.hadoop.hbase.client.TableDescriptor newDescriptor)
     
    boolean
    RSGroupInfo.removeTable(org.apache.hadoop.hbase.TableName table)
     
    Method parameters in org.apache.hadoop.hbase.rsgroup with type arguments of type org.apache.hadoop.hbase.TableName in in
    Modifier and Type
    Method
    Description
    void
    RSGroupInfo.addAllTables(Collection<org.apache.hadoop.hbase.TableName> arg)
     
    List<org.apache.hadoop.hbase.master.RegionPlan>
    RSGroupBasedLoadBalancer.balanceCluster(Map<org.apache.hadoop.hbase.TableName,Map<org.apache.hadoop.hbase.ServerName,List<org.apache.hadoop.hbase.client.RegionInfo>>> loadOfAllTable)
    Balance by RSGroup.
    void
    RSGroupAdmin.moveTables(Set<org.apache.hadoop.hbase.TableName> tables, String targetGroup)
    Move given set of tables to the specified target RegionServer group.
    void
    RSGroupAdminClient.moveTables(Set<org.apache.hadoop.hbase.TableName> tables, String targetGroup)
     
    void
    RSGroupAdminServer.moveTables(Set<org.apache.hadoop.hbase.TableName> tables, String targetGroup)
     
    void
    RSGroupInfoManager.moveTables(Set<org.apache.hadoop.hbase.TableName> tableNames, String groupName)
    Set the group membership of a set of tables
    void
    RSGroupBasedLoadBalancer.updateBalancerLoadInfo(Map<org.apache.hadoop.hbase.TableName,Map<org.apache.hadoop.hbase.ServerName,List<org.apache.hadoop.hbase.client.RegionInfo>>> loadOfAllTable)
     
  • Uses of org.apache.hadoop.hbase.TableName in org.apache.hadoop.hbase.shaded.protobuf

    Methods in org.apache.hadoop.hbase.shaded.protobuf that return org.apache.hadoop.hbase.TableName in in
    Modifier and Type
    Method
    Description
    static org.apache.hadoop.hbase.TableName[]
    ProtobufUtil.getTableNameArray(List<org.apache.hadoop.hbase.shaded.protobuf.generated.HBaseProtos.TableName> tableNamesList)
     
    static org.apache.hadoop.hbase.TableName
    ProtobufUtil.toTableName(org.apache.hadoop.hbase.shaded.protobuf.generated.HBaseProtos.TableName tableNamePB)
     
    Methods in org.apache.hadoop.hbase.shaded.protobuf that return types with arguments of type org.apache.hadoop.hbase.TableName in in
    Modifier and Type
    Method
    Description
    static List<org.apache.hadoop.hbase.TableName>
    ProtobufUtil.toTableNameList(List<org.apache.hadoop.hbase.shaded.protobuf.generated.HBaseProtos.TableName> tableNamesList)
     
    Methods in org.apache.hadoop.hbase.shaded.protobuf with parameters of type org.apache.hadoop.hbase.TableName in in
    Modifier and Type
    Method
    Description
    static org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.AddColumnRequest
    RequestConverter.buildAddColumnRequest(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.ColumnFamilyDescriptor column, long nonceGroup, long nonce)
    Create a protocol buffer AddColumnRequest
    static org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.DeleteColumnRequest
    RequestConverter.buildDeleteColumnRequest(org.apache.hadoop.hbase.TableName tableName, byte[] columnName, long nonceGroup, long nonce)
    Create a protocol buffer DeleteColumnRequest
    static org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.DeleteTableRequest
    RequestConverter.buildDeleteTableRequest(org.apache.hadoop.hbase.TableName tableName, long nonceGroup, long nonce)
    Creates a protocol buffer DeleteTableRequest
    static org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.DisableTableRequest
    RequestConverter.buildDisableTableRequest(org.apache.hadoop.hbase.TableName tableName, long nonceGroup, long nonce)
    Creates a protocol buffer DisableTableRequest
    static org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.EnableTableRequest
    RequestConverter.buildEnableTableRequest(org.apache.hadoop.hbase.TableName tableName, long nonceGroup, long nonce)
    Creates a protocol buffer EnableTableRequest
    static org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.FlushTableRequest
    RequestConverter.buildFlushTableRequest(org.apache.hadoop.hbase.TableName tableName, List<byte[]> columnFamilies, long nonceGroup, long nonce)
     
    static org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.GetRegionLoadRequest
    RequestConverter.buildGetRegionLoadRequest(org.apache.hadoop.hbase.TableName tableName)
    Create a protocol buffer GetRegionLoadRequest for all regions/regions of a table.
    static org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.GetSchemaAlterStatusRequest
    RequestConverter.buildGetSchemaAlterStatusRequest(org.apache.hadoop.hbase.TableName tableName)
    Creates a protocol buffer GetSchemaAlterStatusRequest
    static org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.GetTableDescriptorsRequest
    RequestConverter.buildGetTableDescriptorsRequest(org.apache.hadoop.hbase.TableName tableName)
    Creates a protocol buffer GetTableDescriptorsRequest for a single table
    static org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.GetTableStateRequest
    RequestConverter.buildGetTableStateRequest(org.apache.hadoop.hbase.TableName tableName)
    Creates a protocol buffer GetTableStateRequest
    static org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.ModifyColumnRequest
    RequestConverter.buildModifyColumnRequest(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.ColumnFamilyDescriptor column, long nonceGroup, long nonce)
    Create a protocol buffer ModifyColumnRequest
    static org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.ModifyColumnStoreFileTrackerRequest
    RequestConverter.buildModifyColumnStoreFileTrackerRequest(org.apache.hadoop.hbase.TableName tableName, byte[] family, String dstSFT, long nonceGroup, long nonce)
     
    static org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.ModifyTableRequest
    RequestConverter.buildModifyTableRequest(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.TableDescriptor tableDesc, long nonceGroup, long nonce, boolean reopenRegions)
    Creates a protocol buffer ModifyTableRequest
    static org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.ModifyTableStoreFileTrackerRequest
    RequestConverter.buildModifyTableStoreFileTrackerRequest(org.apache.hadoop.hbase.TableName tableName, String dstSFT, long nonceGroup, long nonce)
     
    static org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.TruncateTableRequest
    RequestConverter.buildTruncateTableRequest(org.apache.hadoop.hbase.TableName tableName, boolean preserveSplits, long nonceGroup, long nonce)
    Creates a protocol buffer TruncateTableRequest
    static org.apache.hadoop.hbase.shaded.protobuf.generated.WALProtos.BulkLoadDescriptor
    ProtobufUtil.toBulkLoadDescriptor(org.apache.hadoop.hbase.TableName tableName, org.apache.hbase.thirdparty.com.google.protobuf.ByteString encodedRegionName, Map<byte[],List<org.apache.hadoop.fs.Path>> storeFiles, Map<String,Long> storeFilesSize, long bulkloadSeqId)
    Generates a marker for the WAL so that we propagate the notion of a bulk region load throughout the WAL.
    static org.apache.hadoop.hbase.shaded.protobuf.generated.WALProtos.BulkLoadDescriptor
    ProtobufUtil.toBulkLoadDescriptor(org.apache.hadoop.hbase.TableName tableName, org.apache.hbase.thirdparty.com.google.protobuf.ByteString encodedRegionName, Map<byte[],List<org.apache.hadoop.fs.Path>> storeFiles, Map<String,Long> storeFilesSize, long bulkloadSeqId, List<String> clusterIds, boolean replicate)
     
    static org.apache.hadoop.hbase.shaded.protobuf.generated.HBaseProtos.TableName
    ProtobufUtil.toProtoTableName(org.apache.hadoop.hbase.TableName tableName)
     
    Method parameters in org.apache.hadoop.hbase.shaded.protobuf with type arguments of type org.apache.hadoop.hbase.TableName in in
    Modifier and Type
    Method
    Description
    static org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.GetTableDescriptorsRequest
    RequestConverter.buildGetTableDescriptorsRequest(List<org.apache.hadoop.hbase.TableName> tableNames)
    Creates a protocol buffer GetTableDescriptorsRequest
    static List<org.apache.hadoop.hbase.shaded.protobuf.generated.HBaseProtos.TableName>
    ProtobufUtil.toProtoTableNameList(List<org.apache.hadoop.hbase.TableName> tableNameList)
     
  • Uses of org.apache.hadoop.hbase.TableName in org.apache.hadoop.hbase.slowlog

    Fields in org.apache.hadoop.hbase.slowlog declared as org.apache.hadoop.hbase.TableName in in
    Modifier and Type
    Field
    Description
    static final org.apache.hadoop.hbase.TableName
    SlowLogTableAccessor.SLOW_LOG_TABLE_NAME
    hbase:slowlog table name - can be enabled with config - hbase.regionserver.slowlog.systable.enabled
  • Uses of org.apache.hadoop.hbase.TableName in org.apache.hadoop.hbase.snapshot

    Methods in org.apache.hadoop.hbase.snapshot with parameters of type org.apache.hadoop.hbase.TableName in in
    Modifier and Type
    Method
    Description
    static org.apache.hadoop.hbase.client.RegionInfo
    RestoreSnapshotHelper.cloneRegionInfo(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.RegionInfo snapshotRegionInfo)
     
    static void
    RestoreSnapshotHelper.restoreSnapshotAcl(org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotDescription snapshot, org.apache.hadoop.hbase.TableName newTableName, org.apache.hadoop.conf.Configuration conf)
     
    Constructors in org.apache.hadoop.hbase.snapshot with parameters of type org.apache.hadoop.hbase.TableName in in
    Modifier
    Constructor
    Description
     
    TablePartiallyOpenException(org.apache.hadoop.hbase.TableName tableName)
     
  • Uses of org.apache.hadoop.hbase.TableName in org.apache.hadoop.hbase.util

    Methods in org.apache.hadoop.hbase.util that return org.apache.hadoop.hbase.TableName in in
    Modifier and Type
    Method
    Description
    org.apache.hadoop.hbase.TableName
    HbckTableInfo.getName()
     
    static org.apache.hadoop.hbase.TableName
    CommonFSUtils.getTableName(org.apache.hadoop.fs.Path tablePath)
    Returns the TableName object representing the table directory under path rootdir
    org.apache.hadoop.hbase.TableName
    HbckRegionInfo.getTableName()
     
    static org.apache.hadoop.hbase.TableName
    HFileArchiveUtil.getTableName(org.apache.hadoop.fs.Path archivePath)
     
    Methods in org.apache.hadoop.hbase.util that return types with arguments of type org.apache.hadoop.hbase.TableName in in
    Modifier and Type
    Method
    Description
    static Map<org.apache.hadoop.hbase.TableName,org.apache.hadoop.hbase.client.TableState.State>
    ZKDataMigrator.queryForTableStates(org.apache.hadoop.hbase.zookeeper.ZKWatcher zkw)
    Deprecated.
    Since 2.0.0.
    Methods in org.apache.hadoop.hbase.util with parameters of type org.apache.hadoop.hbase.TableName in in
    Modifier and Type
    Method
    Description
    org.apache.hadoop.hbase.client.TableDescriptor
    FSTableDescriptors.get(org.apache.hadoop.hbase.TableName tableName)
    Get the current table descriptor for the given table, or null if none exists.
    static org.apache.hadoop.fs.Path
    HFileArchiveUtil.getRegionArchiveDir(org.apache.hadoop.fs.Path rootDir, org.apache.hadoop.hbase.TableName tableName, String encodedRegionName)
    Get the archive directory for a given region under the specified table
    static org.apache.hadoop.fs.Path
    HFileArchiveUtil.getRegionArchiveDir(org.apache.hadoop.fs.Path rootDir, org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.fs.Path regiondir)
    Get the archive directory for a given region under the specified table
    static org.apache.hadoop.fs.Path
    CommonFSUtils.getRegionDir(org.apache.hadoop.fs.Path rootdir, org.apache.hadoop.hbase.TableName tableName, String regionName)
    Returns the Path object representing the region directory under path rootdir
    static org.apache.hadoop.fs.Path
    HFileArchiveUtil.getStoreArchivePath(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.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, org.apache.hadoop.hbase.TableName tableName)
    Get the path to the table archive directory based on the configured archive directory.
    static org.apache.hadoop.fs.Path
    HFileArchiveUtil.getTableArchivePath(org.apache.hadoop.fs.Path rootdir, org.apache.hadoop.hbase.TableName tableName)
    Get the path to the table archive directory based on the configured archive directory.
    static org.apache.hadoop.hbase.client.TableDescriptor
    FSTableDescriptors.getTableDescriptorFromFs(org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.fs.Path hbaseRootDir, org.apache.hadoop.hbase.TableName tableName)
    Returns the latest table descriptor for the given table directly from the file system if it exists, bypassing the local cache.
    static org.apache.hadoop.fs.Path
    CommonFSUtils.getTableDir(org.apache.hadoop.fs.Path rootdir, org.apache.hadoop.hbase.TableName tableName)
    Returns the Path object 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, org.apache.hadoop.hbase.TableName tableName)
    Runs through the HBase rootdir/tablename and creates a reverse lookup map for table StoreFile names to the full Path.
    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, org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.fs.PathFilter sfFilter, ExecutorService executor, org.apache.hadoop.hbase.util.FSUtils.ProgressReporter progressReporter)
    Runs through the HBase rootdir/tablename and creates a reverse lookup map for table StoreFile names to the full Path.
    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, org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.fs.PathFilter sfFilter, ExecutorService executor, org.apache.hadoop.hbase.util.HbckErrorReporter progressReporter)
    Deprecated.
    Since 2.3.0.
    static org.apache.hadoop.fs.Path
    CommonFSUtils.getWALRegionDir(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.TableName tableName, String encodedRegionName)
    Returns the WAL region directory based on the given table name and region name
    static org.apache.hadoop.fs.Path
    CommonFSUtils.getWALTableDir(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.TableName tableName)
    Returns the Table directory under the WALRootDir for the specified table name
    static org.apache.hadoop.fs.Path
    CommonFSUtils.getWrongWALRegionDir(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.TableName tableName, String encodedRegionName)
    Deprecated.
    For compatibility, will be removed in 4.0.0.
    void
    HBaseFsck.includeTable(org.apache.hadoop.hbase.TableName table)
    Deprecated.
     
    static boolean
    ServerRegionReplicaUtil.isMetaRegionReplicaReplicationEnabled(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.TableName tn)
    Returns True if hbase:meta Region Read Replica is enabled.
    static boolean
    ServerRegionReplicaUtil.isRegionReplicaReplicationEnabled(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.TableName tn)
     
    <R> void
    MultiHConnection.processBatchCallback(List<? extends org.apache.hadoop.hbase.client.Row> actions, org.apache.hadoop.hbase.TableName tableName, Object[] results, org.apache.hadoop.hbase.client.coprocessor.Batch.Callback<R> callback)
    Randomly pick a connection and process the batch of actions for a given table
    org.apache.hadoop.hbase.client.TableDescriptor
    FSTableDescriptors.remove(org.apache.hadoop.hbase.TableName tablename)
    Removes the table descriptor from the local cache and returns it.
  • Uses of org.apache.hadoop.hbase.TableName in org.apache.hadoop.hbase.util.compaction

    Fields in org.apache.hadoop.hbase.util.compaction declared as org.apache.hadoop.hbase.TableName in in
    Modifier and Type
    Field
    Description
    protected org.apache.hadoop.hbase.TableName
    MajorCompactor.tableName
     
    Constructors in org.apache.hadoop.hbase.util.compaction with parameters of type org.apache.hadoop.hbase.TableName in in
    Modifier
    Constructor
    Description
     
    MajorCompactor(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.TableName tableName, Set<String> storesToCompact, int concurrency, long timestamp, long sleepForMs)
     
  • Uses of org.apache.hadoop.hbase.TableName in org.apache.hadoop.hbase.wal

    Methods in org.apache.hadoop.hbase.wal that return org.apache.hadoop.hbase.TableName in in
    Modifier and Type
    Method
    Description
    org.apache.hadoop.hbase.TableName
    EntryBuffers.RegionEntryBuffer.getTableName()
     
    org.apache.hadoop.hbase.TableName
    WALKey.getTableName()
    Returns table name
    org.apache.hadoop.hbase.TableName
    WALKeyImpl.getTableName()
    Returns table name
    Methods in org.apache.hadoop.hbase.wal with parameters of type org.apache.hadoop.hbase.TableName in in
    Modifier and Type
    Method
    Description
    protected void
    WALKeyImpl.init(byte[] encodedRegionName, org.apache.hadoop.hbase.TableName tablename, long logSeqNum, long now, List<UUID> clusterIds, long nonceGroup, long nonce, org.apache.hadoop.hbase.regionserver.MultiVersionConcurrencyControl mvcc, NavigableMap<byte[],Integer> replicationScope, Map<String,byte[]> extendedAttributes)
     
    Constructors in org.apache.hadoop.hbase.wal with parameters of type org.apache.hadoop.hbase.TableName in in
    Modifier
    Constructor
    Description
     
    WALKeyImpl(byte[] encodedRegionName, org.apache.hadoop.hbase.TableName tablename, long now)
     
     
    WALKeyImpl(byte[] encodedRegionName, org.apache.hadoop.hbase.TableName tablename, long logSeqNum, long nonceGroup, long nonce, org.apache.hadoop.hbase.regionserver.MultiVersionConcurrencyControl mvcc)
    Create the log key for writing to somewhere.
     
    WALKeyImpl(byte[] encodedRegionName, org.apache.hadoop.hbase.TableName tablename, long logSeqNum, long now, List<UUID> clusterIds, long nonceGroup, long nonce, org.apache.hadoop.hbase.regionserver.MultiVersionConcurrencyControl mvcc)
    Create the log key for writing to somewhere.
     
    WALKeyImpl(byte[] encodedRegionName, org.apache.hadoop.hbase.TableName tablename, long logSeqNum, long now, List<UUID> clusterIds, long nonceGroup, long nonce, org.apache.hadoop.hbase.regionserver.MultiVersionConcurrencyControl mvcc, NavigableMap<byte[],Integer> replicationScope)
    Create the log key for writing to somewhere.
     
    WALKeyImpl(byte[] encodedRegionName, org.apache.hadoop.hbase.TableName tablename, long logSeqNum, long now, UUID clusterId)
     
     
    WALKeyImpl(byte[] encodedRegionName, org.apache.hadoop.hbase.TableName tablename, long now, List<UUID> clusterIds, long nonceGroup, long nonce, org.apache.hadoop.hbase.regionserver.MultiVersionConcurrencyControl mvcc)
    Create the log key for writing to somewhere.
     
    WALKeyImpl(byte[] encodedRegionName, org.apache.hadoop.hbase.TableName tablename, long now, List<UUID> clusterIds, long nonceGroup, long nonce, org.apache.hadoop.hbase.regionserver.MultiVersionConcurrencyControl mvcc, NavigableMap<byte[],Integer> replicationScope)
    Create the log key for writing to somewhere.
     
    WALKeyImpl(byte[] encodedRegionName, org.apache.hadoop.hbase.TableName tablename, long now, List<UUID> clusterIds, long nonceGroup, long nonce, org.apache.hadoop.hbase.regionserver.MultiVersionConcurrencyControl mvcc, NavigableMap<byte[],Integer> replicationScope, Map<String,byte[]> extendedAttributes)
     
     
    WALKeyImpl(byte[] encodedRegionName, org.apache.hadoop.hbase.TableName tablename, long now, NavigableMap<byte[],Integer> replicationScope)
     
     
    WALKeyImpl(byte[] encodedRegionName, org.apache.hadoop.hbase.TableName tablename, long now, org.apache.hadoop.hbase.regionserver.MultiVersionConcurrencyControl mvcc)
     
     
    WALKeyImpl(byte[] encodedRegionName, org.apache.hadoop.hbase.TableName tablename, long now, org.apache.hadoop.hbase.regionserver.MultiVersionConcurrencyControl mvcc, NavigableMap<byte[],Integer> replicationScope)
     
     
    WALKeyImpl(byte[] encodedRegionName, org.apache.hadoop.hbase.TableName tablename, long now, org.apache.hadoop.hbase.regionserver.MultiVersionConcurrencyControl mvcc, NavigableMap<byte[],Integer> replicationScope, Map<String,byte[]> extendedAttributes)