Modifier and Type | Field and Description |
---|---|
static TableName |
HConstants.ENSEMBLE_TABLE_NAME
The name of the ensemble table
|
static TableName |
TableName.META_TABLE_NAME
The hbase:meta table's name.
|
static TableName |
TableName.NAMESPACE_TABLE_NAME
The Namespace table's name.
|
static TableName |
TableName.OLD_META_TABLE_NAME
TableName for old .META.
|
static TableName |
TableName.OLD_ROOT_TABLE_NAME
TableName for old -ROOT- table.
|
private static TableName |
RSGroupTableAccessor.RSGROUP_TABLE_NAME |
private TableName |
HRegionInfo.tableName
Deprecated.
|
private TableName |
MetaTableAccessor.TableVisitorBase.tableName |
Modifier and Type | Field and Description |
---|---|
private static Set<TableName> |
TableName.tableCache
|
private Map<TableName,RegionStatesCount> |
ClusterMetricsBuilder.tableRegionStatesCount |
private Map<TableName,RegionStatesCount> |
ClusterMetricsBuilder.ClusterMetricsImpl.tableRegionStatesCount |
Modifier and Type | Method and Description |
---|---|
private static TableName |
TableName.createTableNameIfNecessary(ByteBuffer bns,
ByteBuffer qns)
Check that the object does not exist already.
|
private static TableName |
TableName.getADummyTableName(String qualifier)
It is used to create table names for old META, and ROOT table.
|
TableName |
HRegionInfo.getTable()
Deprecated.
Get current table name of the region n
|
static 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[]) . |
TableName |
HTableDescriptor.getTableName()
Deprecated.
Get the name of the table n
|
static TableName |
TableName.valueOf(byte[] fullName)
Construct a TableName
|
static TableName |
TableName.valueOf(byte[] namespace,
byte[] qualifier) |
static TableName |
TableName.valueOf(byte[] fullName,
int offset,
int length)
Construct a TableName
|
static TableName |
TableName.valueOf(ByteBuffer fullname)
Construct a TableName
|
static TableName |
TableName.valueOf(ByteBuffer namespace,
ByteBuffer qualifier) |
static TableName |
TableName.valueOf(String name)
Construct a TableName
|
static TableName |
TableName.valueOf(String namespaceAsString,
String qualifierAsString) |
Modifier and Type | Method and Description |
---|---|
Map<TableName,RegionStatesCount> |
ClusterStatus.getTableRegionStatesCount()
Deprecated.
|
Map<TableName,RegionStatesCount> |
ClusterMetrics.getTableRegionStatesCount()
Provide region states count for given table.
|
Map<TableName,RegionStatesCount> |
ClusterMetricsBuilder.ClusterMetricsImpl.getTableRegionStatesCount() |
static Map<TableName,TableState> |
MetaTableAccessor.getTableStates(Connection conn)
Fetch table states from META table
|
Modifier and Type | Method and Description |
---|---|
int |
TableName.compareTo(TableName tableName) |
static byte[] |
HRegionInfo.createRegionName(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(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(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(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(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(Connection connection,
TableName table)
Remove state for table from meta
|
default boolean |
TableDescriptors.exists(TableName tableName)
Test whether a given table exists, i.e, has a table descriptor.
|
TableDescriptor |
TableDescriptors.get(TableName tableName)
Returns TableDescriptor for tablename
|
BufferedMutator |
SharedConnection.getBufferedMutator(TableName tableName) |
static CellComparator |
CellComparatorImpl.getCellComparator(TableName tableName)
Utility method that makes a guess at comparator to use based off passed tableName.
|
private static RegionInfo |
MetaTableAccessor.getClosestRegionInfo(Connection connection,
TableName tableName,
byte[] row)
Returns Get closest metatable region row to passed
row |
default long |
ClusterMetrics.getLastMajorCompactionTimestamp(TableName table) |
long |
ClusterStatus.getLastMajorCompactionTsForTable(TableName table)
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use
ClusterMetrics.getLastMajorCompactionTimestamp(TableName) instead. |
RegionLocator |
SharedConnection.getRegionLocator(TableName tableName) |
static MetaTableAccessor.ReplicationBarrierResult |
MetaTableAccessor.getReplicationBarrierResult(Connection conn,
TableName tableName,
byte[] row,
byte[] encodedRegionName) |
static Scan |
MetaTableAccessor.getScanForTableName(org.apache.hadoop.conf.Configuration conf,
TableName tableName)
This method creates a Scan object that will only scan catalog rows that belong to the specified
table.
|
TableBuilder |
SharedConnection.getTableBuilder(TableName tableName,
ExecutorService pool) |
static List<Pair<String,Long>> |
MetaTableAccessor.getTableEncodedRegionNameAndLastBarrier(Connection conn,
TableName tableName) |
static List<String> |
MetaTableAccessor.getTableEncodedRegionNamesForSerialReplication(Connection conn,
TableName tableName) |
static CompletableFuture<List<HRegionLocation>> |
AsyncMetaTableAccessor.getTableHRegionLocations(AsyncTable<AdvancedScanResultConsumer> metaTable,
TableName tableName)
Used to get all region locations for the specific table
|
static List<RegionInfo> |
MetaTableAccessor.getTableRegions(Connection connection,
TableName tableName)
Gets all of the regions of the specified table.
|
static List<RegionInfo> |
MetaTableAccessor.getTableRegions(Connection connection,
TableName tableName,
boolean excludeOfflinedSplitParents)
Gets all of the regions of the specified table.
|
private static CompletableFuture<List<Pair<RegionInfo,ServerName>>> |
AsyncMetaTableAccessor.getTableRegionsAndLocations(AsyncTable<AdvancedScanResultConsumer> metaTable,
TableName tableName,
boolean excludeOfflinedSplitParents)
Used to get table regions' info and server.
|
static List<Pair<RegionInfo,ServerName>> |
MetaTableAccessor.getTableRegionsAndLocations(Connection connection,
TableName tableName)
Do not use this method to get meta table regions, use methods in MetaTableLocator instead.
|
static List<Pair<RegionInfo,ServerName>> |
MetaTableAccessor.getTableRegionsAndLocations(Connection connection,
TableName tableName,
boolean excludeOfflinedSplitParents)
Do not use this method to get meta table regions, use methods in MetaTableLocator instead.
|
private static byte[] |
AsyncMetaTableAccessor.getTableStartRowForMeta(TableName tableName,
MetaTableAccessor.QueryType type) |
static byte[] |
MetaTableAccessor.getTableStartRowForMeta(TableName tableName,
MetaTableAccessor.QueryType type)
Returns start row for scanning META according to query type
|
static CompletableFuture<Optional<TableState>> |
AsyncMetaTableAccessor.getTableState(AsyncTable<?> metaTable,
TableName tableName) |
static TableState |
MetaTableAccessor.getTableState(Connection conn,
TableName tableName)
Fetch table state for given table from META table
|
private static byte[] |
AsyncMetaTableAccessor.getTableStopRowForMeta(TableName tableName,
MetaTableAccessor.QueryType type) |
static byte[] |
MetaTableAccessor.getTableStopRowForMeta(TableName tableName,
MetaTableAccessor.QueryType type)
Returns stop row for scanning META according to query type
|
static boolean |
TableName.isMetaTableName(TableName tn)
Returns True if
tn is the hbase:meta table name. |
TableDescriptor |
TableDescriptors.remove(TableName tablename)
Returns Instance of table descriptor or null if none found.
|
private static CompletableFuture<Void> |
AsyncMetaTableAccessor.scanMeta(AsyncTable<AdvancedScanResultConsumer> metaTable,
TableName tableName,
MetaTableAccessor.QueryType type,
MetaTableAccessor.Visitor visitor)
Performs a scan of META table for given table.
|
static void |
MetaTableAccessor.scanMeta(Connection connection,
MetaTableAccessor.Visitor visitor,
TableName tableName,
byte[] row,
int rowLimit)
Performs a scan of META table for given table starting from given row.
|
private static void |
MetaTableAccessor.scanMeta(Connection connection,
TableName table,
MetaTableAccessor.QueryType type,
int maxRows,
MetaTableAccessor.Visitor visitor,
CatalogReplicaMode metaReplicaMode) |
static void |
MetaTableAccessor.scanMetaForTableRegions(Connection connection,
MetaTableAccessor.Visitor visitor,
TableName tableName) |
static void |
MetaTableAccessor.scanMetaForTableRegions(Connection connection,
MetaTableAccessor.Visitor visitor,
TableName tableName,
CatalogReplicaMode metaReplicaMode) |
static CompletableFuture<Boolean> |
AsyncMetaTableAccessor.tableExists(AsyncTable<?> metaTable,
TableName tableName) |
static void |
MetaTableAccessor.updateTableState(Connection conn,
TableName tableName,
TableState.State actual)
Updates state in META Do not use.
|
Modifier and Type | Method and Description |
---|---|
ClusterMetricsBuilder |
ClusterMetricsBuilder.setTableRegionStatesCount(Map<TableName,RegionStatesCount> tableRegionStatesCount) |
Constructor and Description |
---|
ConcurrentTableModificationException(TableName tableName) |
HRegionInfo(long regionId,
TableName tableName)
Deprecated.
Private constructor used constructing HRegionInfo for the first meta regions
|
HRegionInfo(long regionId,
TableName tableName,
int replicaId)
Deprecated.
|
HRegionInfo(TableName tableName)
Deprecated.
|
HRegionInfo(TableName tableName,
byte[] startKey,
byte[] endKey)
Deprecated.
Construct HRegionInfo with explicit parameters
|
HRegionInfo(TableName tableName,
byte[] startKey,
byte[] endKey,
boolean split)
Deprecated.
Construct HRegionInfo with explicit parameters
|
HRegionInfo(TableName tableName,
byte[] startKey,
byte[] endKey,
boolean split,
long regionId)
Deprecated.
Construct HRegionInfo with explicit parameters
|
HRegionInfo(TableName tableName,
byte[] startKey,
byte[] endKey,
boolean split,
long regionId,
int replicaId)
Deprecated.
Construct HRegionInfo with explicit parameters
|
HTableDescriptor(TableName name)
Deprecated.
Construct a table descriptor specifying a TableName object
|
HTableDescriptor(TableName name,
HTableDescriptor desc)
Deprecated.
Construct a table descriptor by cloning the descriptor passed as a parameter but using a
different table name.
|
TableExistsException(TableName tableName) |
TableNotDisabledException(TableName tableName) |
TableNotEnabledException(TableName tableName) |
TableNotFoundException(TableName tableName) |
TableVisitorBase(TableName tableName) |
Constructor and Description |
---|
ClusterMetricsImpl(String hbaseVersion,
List<ServerName> deadServerNames,
List<ServerName> unknownServerNames,
Map<ServerName,ServerMetrics> liveServerMetrics,
ServerName masterName,
List<ServerName> backupMasterNames,
List<RegionState> regionsInTransition,
String clusterId,
List<String> masterCoprocessorNames,
Boolean balancerOn,
int masterInfoPort,
List<ServerName> serversName,
Map<TableName,RegionStatesCount> tableRegionStatesCount,
List<ServerTask> masterTasks) |
Modifier and Type | Field and Description |
---|---|
private TableName |
TableDescriptorBuilder.ModifyableTableDescriptor.name |
private TableName |
SnapshotDescription.table |
private TableName |
RegionCoprocessorRpcChannel.table |
private TableName |
AsyncClientScanner.tableName |
private TableName |
CatalogReplicaLoadBalanceSimpleSelector.tableName |
private TableName |
HTable.tableName |
private TableName |
HRegionLocator.tableName |
private TableName |
MutableRegionInfo.tableName |
private TableName |
TableState.tableName |
protected TableName |
TableBuilderBase.tableName |
protected TableName |
AsyncTableBuilderBase.tableName |
private TableName |
AsyncTableRegionLocatorImpl.tableName |
private TableName |
AsyncBatchRpcRetryingCaller.tableName |
private TableName |
ScannerCallableWithReplicas.tableName |
private TableName |
RegionInfoBuilder.tableName |
private TableName |
RawAsyncTableImpl.tableName |
private TableName |
AsyncProcessTask.tableName |
private TableName |
AsyncProcessTask.Builder.tableName |
private TableName |
AsyncRequestFutureImpl.tableName |
private TableName |
AsyncRpcRetryingCallerFactory.SingleRequestCallerBuilder.tableName |
private TableName |
AsyncRpcRetryingCallerFactory.BatchCallerBuilder.tableName |
private TableName |
BufferedMutatorImpl.tableName |
protected TableName |
ClientScanner.tableName |
private TableName |
BufferedMutatorParams.tableName |
private TableName |
RegionServerCallable.tableName |
protected TableName |
RegionAdminServiceCallable.tableName |
private TableName |
AsyncTableResultScanner.tableName |
protected TableName |
RawAsyncHBaseAdmin.TableProcedureBiConsumer.tableName |
private TableName |
RegionCoprocessorRpcChannelImpl.tableName |
protected TableName |
RpcRetryingCallerWithReadReplicas.tableName |
private TableName |
HBaseAdmin.TableFuture.tableName |
private TableName |
AsyncSingleRequestRpcRetryingCaller.tableName |
Modifier and Type | Field and Description |
---|---|
private ConcurrentMap<TableName,AsyncNonMetaRegionLocator.TableCache> |
AsyncNonMetaRegionLocator.cache |
private ConcurrentMap<TableName,ConcurrentNavigableMap<byte[],RegionLocations>> |
MetaCache.cachedRegionLocations
Map of table to table
HRegionLocation s. |
private ConcurrentMap<TableName,ConcurrentNavigableMap<byte[],CatalogReplicaLoadBalanceSimpleSelector.StaleLocationCacheEntry>> |
CatalogReplicaLoadBalanceSimpleSelector.staleCache |
private List<TableName> |
NormalizeTableFilterParams.tableNames |
private List<TableName> |
NormalizeTableFilterParams.Builder.tableNames |
Modifier and Type | Method and Description |
---|---|
private TableName |
HBaseAdmin.checkTableExists(TableName tableName)
Check if table exists or not
|
private static TableName |
MutableRegionInfo.checkTableName(TableName tableName) |
TableName |
BufferedMutator.getName()
Gets the fully qualified table name instance of the table that this BufferedMutator writes to.
|
TableName |
AsyncBufferedMutatorImpl.getName() |
TableName |
HTable.getName() |
TableName |
RegionLocator.getName()
Gets the fully qualified table name instance of this table.
|
TableName |
HRegionLocator.getName() |
TableName |
AsyncTable.getName()
Gets the fully qualified table name instance of this table.
|
TableName |
Table.getName()
Gets the fully qualified table name instance of this table.
|
TableName |
AsyncTableRegionLocatorImpl.getName() |
TableName |
RawAsyncTableImpl.getName() |
TableName |
BufferedMutatorImpl.getName() |
TableName |
AsyncTableImpl.getName() |
TableName |
AsyncBufferedMutator.getName()
Gets the fully qualified table name instance of the table that this
AsyncBufferedMutator writes to. |
TableName |
AsyncTableRegionLocator.getName()
Gets the fully qualified table name instance of the table whose region we want to locate.
|
TableName |
MutableRegionInfo.getTable()
Get current table name of the region n
|
protected TableName |
ClientScanner.getTable() |
TableName |
RegionInfo.getTable()
Returns current table name of the region
|
static TableName |
RegionInfo.getTable(byte[] regionName)
Gets the table name from the specified region name.
|
TableName |
SnapshotDescription.getTableName() |
TableName |
TableState.getTableName()
Table name for state n
|
TableName |
AsyncProcessTask.getTableName() |
TableName |
TableDescriptorBuilder.ModifyableTableDescriptor.getTableName()
Get the name of the table n
|
TableName |
BufferedMutatorParams.getTableName() |
TableName |
RegionServerCallable.getTableName() |
protected TableName |
HBaseAdmin.TableFuture.getTableName()
Returns the table name
|
TableName |
TableDescriptor.getTableName()
Get the name of the table
|
private TableName |
HBaseAdmin.getTableNameBeforeRestoreSnapshot(String snapshotName)
Check whether the snapshot exists and contains disabled table
|
TableName[] |
Admin.listTableNames()
List all of the names of userspace tables.
|
TableName[] |
HBaseAdmin.listTableNames() |
default TableName[] |
Admin.listTableNames(Pattern pattern)
List all of the names of userspace tables.
|
TableName[] |
Admin.listTableNames(Pattern pattern,
boolean includeSysTables)
List all of the names of userspace tables.
|
TableName[] |
HBaseAdmin.listTableNames(Pattern pattern,
boolean includeSysTables) |
TableName[] |
Admin.listTableNames(String regex)
Deprecated.
since 2.0 version and will be removed in 3.0 version. Use
Admin.listTableNames(Pattern) instead. |
TableName[] |
HBaseAdmin.listTableNames(String regex) |
TableName[] |
Admin.listTableNames(String regex,
boolean includeSysTables)
Deprecated.
since 2.0 version and will be removed in 3.0 version. Use
Admin.listTableNames(Pattern, boolean) instead. |
TableName[] |
HBaseAdmin.listTableNames(String regex,
boolean includeSysTables) |
TableName[] |
Admin.listTableNamesByNamespace(String name)
Get list of table names by namespace.
|
TableName[] |
HBaseAdmin.listTableNamesByNamespace(String name) |
Modifier and Type | Method and Description |
---|---|
private CompletableFuture<TableName> |
RawAsyncHBaseAdmin.checkRegionsAndGetTableName(byte[][] encodedRegionNames) |
Map<TableName,? extends SpaceQuotaSnapshotView> |
Admin.getRegionServerSpaceQuotaSnapshots(ServerName serverName)
Fetches the observed
SpaceQuotaSnapshotView s observed by a RegionServer. |
CompletableFuture<? extends Map<TableName,? extends SpaceQuotaSnapshotView>> |
AsyncAdmin.getRegionServerSpaceQuotaSnapshots(ServerName serverName)
Fetches the observed
SpaceQuotaSnapshotView s observed by a RegionServer. |
CompletableFuture<Map<TableName,SpaceQuotaSnapshot>> |
RawAsyncHBaseAdmin.getRegionServerSpaceQuotaSnapshots(ServerName serverName) |
CompletableFuture<Map<TableName,SpaceQuotaSnapshot>> |
AsyncHBaseAdmin.getRegionServerSpaceQuotaSnapshots(ServerName serverName) |
Map<TableName,SpaceQuotaSnapshot> |
HBaseAdmin.getRegionServerSpaceQuotaSnapshots(ServerName serverName) |
Map<TableName,Long> |
Admin.getSpaceQuotaTableSizes()
Fetches the table sizes on the filesystem as tracked by the HBase Master.
|
CompletableFuture<Map<TableName,Long>> |
AsyncAdmin.getSpaceQuotaTableSizes()
Fetches the table sizes on the filesystem as tracked by the HBase Master.
|
CompletableFuture<Map<TableName,Long>> |
RawAsyncHBaseAdmin.getSpaceQuotaTableSizes() |
CompletableFuture<Map<TableName,Long>> |
AsyncHBaseAdmin.getSpaceQuotaTableSizes() |
Map<TableName,Long> |
HBaseAdmin.getSpaceQuotaTableSizes() |
protected Optional<TableName> |
AsyncRpcRetryingCaller.getTableName() |
protected Optional<TableName> |
AsyncSingleRequestRpcRetryingCaller.getTableName() |
List<TableName> |
NormalizeTableFilterParams.getTableNames() |
private CompletableFuture<List<TableName>> |
RawAsyncHBaseAdmin.getTableNames(org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.GetTableNamesRequest request) |
default CompletableFuture<List<TableName>> |
AsyncAdmin.listTableNames()
List all of the names of userspace tables.
|
CompletableFuture<List<TableName>> |
AsyncAdmin.listTableNames(boolean includeSysTables)
List all of the names of tables.
|
CompletableFuture<List<TableName>> |
RawAsyncHBaseAdmin.listTableNames(boolean includeSysTables) |
CompletableFuture<List<TableName>> |
AsyncHBaseAdmin.listTableNames(boolean includeSysTables) |
CompletableFuture<List<TableName>> |
AsyncAdmin.listTableNames(Pattern pattern,
boolean includeSysTables)
List all of the names of userspace tables.
|
CompletableFuture<List<TableName>> |
RawAsyncHBaseAdmin.listTableNames(Pattern pattern,
boolean includeSysTables) |
CompletableFuture<List<TableName>> |
AsyncHBaseAdmin.listTableNames(Pattern pattern,
boolean includeSysTables) |
CompletableFuture<List<TableName>> |
AsyncAdmin.listTableNamesByNamespace(String name)
Get list of table names by namespace.
|
CompletableFuture<List<TableName>> |
RawAsyncHBaseAdmin.listTableNamesByNamespace(String name) |
CompletableFuture<List<TableName>> |
AsyncHBaseAdmin.listTableNamesByNamespace(String name) |
Modifier and Type | Method and Description |
---|---|
default void |
Admin.addColumn(TableName tableName,
ColumnFamilyDescriptor columnFamily)
Deprecated.
As of release 2.0.0. This will be removed in HBase 3.0.0. Use
Admin.addColumnFamily(TableName, ColumnFamilyDescriptor) . |
default void |
Admin.addColumnFamily(TableName tableName,
ColumnFamilyDescriptor columnFamily)
Add a column family to an existing table.
|
CompletableFuture<Void> |
AsyncAdmin.addColumnFamily(TableName tableName,
ColumnFamilyDescriptor columnFamily)
Add a column family to an existing table.
|
CompletableFuture<Void> |
RawAsyncHBaseAdmin.addColumnFamily(TableName tableName,
ColumnFamilyDescriptor columnFamily) |
CompletableFuture<Void> |
AsyncHBaseAdmin.addColumnFamily(TableName tableName,
ColumnFamilyDescriptor columnFamily) |
Future<Void> |
Admin.addColumnFamilyAsync(TableName tableName,
ColumnFamilyDescriptor columnFamily)
Add a column family to an existing table.
|
Future<Void> |
HBaseAdmin.addColumnFamilyAsync(TableName tableName,
ColumnFamilyDescriptor columnFamily) |
void |
ClusterConnection.cacheLocation(TableName tableName,
RegionLocations location) |
void |
MetaCache.cacheLocation(TableName tableName,
RegionLocations locations)
Put a newly discovered HRegionLocation into the cache.
|
void |
ConnectionImplementation.cacheLocation(TableName tableName,
RegionLocations location)
Put a newly discovered HRegionLocation into the cache.
|
void |
MetaCache.cacheLocation(TableName tableName,
ServerName source,
HRegionLocation location)
Put a newly discovered HRegionLocation into the cache.
|
private void |
ConnectionImplementation.cacheLocation(TableName tableName,
ServerName source,
HRegionLocation location)
Put a newly discovered HRegionLocation into the cache.
|
(package private) static int |
ConnectionUtils.calcPriority(int priority,
TableName tableName)
Select the priority for the rpc call.
|
private void |
HBaseAdmin.checkAndSyncTableDescToPeers(TableName tableName,
byte[][] splits)
Connect to peer and check the table descriptor on peer:
Create the same table on peer when not exist.
Throw an exception if the table already has replication enabled on any of the column
families.
Throw an exception if the table exists on peer cluster but descriptors are not same.
|
private CompletableFuture<Void> |
RawAsyncHBaseAdmin.checkAndSyncTableToPeerClusters(TableName tableName,
byte[][] splits)
Connect to peer and check the table descriptor on peer:
Create the same table on peer when not exist.
Throw an exception if the table already has replication enabled on any of the column
families.
Throw an exception if the table exists on peer cluster but descriptors are not same.
|
private TableName |
HBaseAdmin.checkTableExists(TableName tableName)
Check if table exists or not
|
private static TableName |
MutableRegionInfo.checkTableName(TableName tableName) |
CacheEvictionStats |
Admin.clearBlockCache(TableName tableName)
Clear all the blocks corresponding to this table from BlockCache.
|
CompletableFuture<CacheEvictionStats> |
AsyncAdmin.clearBlockCache(TableName tableName)
Clear all the blocks corresponding to this table from BlockCache.
|
CompletableFuture<CacheEvictionStats> |
RawAsyncHBaseAdmin.clearBlockCache(TableName tableName) |
CompletableFuture<CacheEvictionStats> |
AsyncHBaseAdmin.clearBlockCache(TableName tableName) |
CacheEvictionStats |
HBaseAdmin.clearBlockCache(TableName tableName)
Clear all the blocks corresponding to this table from BlockCache.
|
void |
MetaCache.clearCache(TableName tableName)
Delete all cached entries of a table.
|
(package private) void |
AsyncNonMetaRegionLocator.clearCache(TableName tableName) |
(package private) void |
AsyncRegionLocator.clearCache(TableName tableName) |
void |
MetaCache.clearCache(TableName tableName,
byte[] row)
Delete a cached location, no matter what it is.
|
void |
MetaCache.clearCache(TableName tableName,
byte[] row,
int replicaId)
Delete a cached location with specific replicaId.
|
void |
MetaCache.clearCache(TableName tableName,
byte[] row,
ServerName serverName)
Delete a cached location for a table, row and server
|
void |
ClusterConnection.clearRegionCache(TableName tableName)
Allows flushing the region cache of all locations that pertain to
tableName |
void |
ConnectionImplementation.clearRegionCache(TableName tableName) |
void |
ConnectionImplementation.clearRegionCache(TableName tableName,
byte[] row) |
default void |
Admin.cloneSnapshot(byte[] snapshotName,
TableName tableName)
Deprecated.
since 2.3.0, will be removed in 3.0.0. Use
Admin.cloneSnapshot(String, TableName) instead. |
default void |
Admin.cloneSnapshot(String snapshotName,
TableName tableName)
Create a new table by cloning the snapshot content.
|
default CompletableFuture<Void> |
AsyncAdmin.cloneSnapshot(String snapshotName,
TableName tableName)
Create a new table by cloning the snapshot content.
|
default void |
Admin.cloneSnapshot(String snapshotName,
TableName tableName,
boolean restoreAcl)
Create a new table by cloning the snapshot content.
|
default CompletableFuture<Void> |
AsyncAdmin.cloneSnapshot(String snapshotName,
TableName tableName,
boolean restoreAcl)
Create a new table by cloning the snapshot content.
|
default void |
Admin.cloneSnapshot(String snapshotName,
TableName tableName,
boolean restoreAcl,
String customSFT)
Create a new table by cloning the snapshot content.
|
CompletableFuture<Void> |
AsyncAdmin.cloneSnapshot(String snapshotName,
TableName tableName,
boolean restoreAcl,
String customSFT)
Create a new table by cloning the snapshot content.
|
CompletableFuture<Void> |
RawAsyncHBaseAdmin.cloneSnapshot(String snapshotName,
TableName tableName,
boolean restoreAcl,
String customSFT) |
CompletableFuture<Void> |
AsyncHBaseAdmin.cloneSnapshot(String snapshotName,
TableName tableName,
boolean restoreAcl,
String customSFT) |
default Future<Void> |
Admin.cloneSnapshotAsync(String snapshotName,
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,
TableName tableName,
boolean restoreAcl)
Create a new table by cloning the snapshot content.
|
Future<Void> |
Admin.cloneSnapshotAsync(String snapshotName,
TableName tableName,
boolean restoreAcl,
String customSFT)
Create a new table by cloning the snapshot content.
|
Future<Void> |
HBaseAdmin.cloneSnapshotAsync(String snapshotName,
TableName tableName,
boolean restoreAcl,
String customSFT) |
void |
Admin.cloneTableSchema(TableName tableName,
TableName newTableName,
boolean preserveSplits)
Create a new table by cloning the existent table schema.
|
CompletableFuture<Void> |
AsyncAdmin.cloneTableSchema(TableName tableName,
TableName newTableName,
boolean preserveSplits)
Create a new table by cloning the existent table schema.
|
CompletableFuture<Void> |
RawAsyncHBaseAdmin.cloneTableSchema(TableName tableName,
TableName newTableName,
boolean preserveSplits) |
CompletableFuture<Void> |
AsyncHBaseAdmin.cloneTableSchema(TableName tableName,
TableName newTableName,
boolean preserveSplits) |
void |
HBaseAdmin.cloneTableSchema(TableName tableName,
TableName newTableName,
boolean preserveSplits) |
void |
Admin.compact(TableName tableName)
Compact a table.
|
default CompletableFuture<Void> |
AsyncAdmin.compact(TableName tableName)
Compact a table.
|
void |
HBaseAdmin.compact(TableName tableName)
Compact a table.
|
void |
Admin.compact(TableName tableName,
byte[] columnFamily)
Compact a column family within a table.
|
default CompletableFuture<Void> |
AsyncAdmin.compact(TableName tableName,
byte[] columnFamily)
Compact a column family within a table.
|
void |
HBaseAdmin.compact(TableName tableName,
byte[] columnFamily)
Compact a column family within a table.
|
private CompletableFuture<Void> |
RawAsyncHBaseAdmin.compact(TableName tableName,
byte[] columnFamily,
boolean major,
CompactType compactType)
Compact column family of a table, Asynchronous operation even if CompletableFuture.get()
|
private void |
HBaseAdmin.compact(TableName tableName,
byte[] columnFamily,
boolean major,
CompactType compactType)
Compact a table.
|
void |
Admin.compact(TableName tableName,
byte[] columnFamily,
CompactType compactType)
Compact a column family within a table.
|
CompletableFuture<Void> |
AsyncAdmin.compact(TableName tableName,
byte[] columnFamily,
CompactType compactType)
Compact a column family within a table.
|
CompletableFuture<Void> |
RawAsyncHBaseAdmin.compact(TableName tableName,
byte[] columnFamily,
CompactType compactType) |
CompletableFuture<Void> |
AsyncHBaseAdmin.compact(TableName tableName,
byte[] columnFamily,
CompactType compactType) |
void |
HBaseAdmin.compact(TableName tableName,
byte[] columnFamily,
CompactType compactType)
Compact a column family within a table.
|
void |
Admin.compact(TableName tableName,
CompactType compactType)
Compact a table.
|
CompletableFuture<Void> |
AsyncAdmin.compact(TableName tableName,
CompactType compactType)
Compact a table.
|
CompletableFuture<Void> |
RawAsyncHBaseAdmin.compact(TableName tableName,
CompactType compactType) |
CompletableFuture<Void> |
AsyncHBaseAdmin.compact(TableName tableName,
CompactType compactType) |
void |
HBaseAdmin.compact(TableName tableName,
CompactType compactType)
Compact a table.
|
private CompletableFuture<Void> |
RawAsyncHBaseAdmin.compareTableWithPeerCluster(TableName tableName,
TableDescriptor tableDesc,
ReplicationPeerDescription peer,
AsyncAdmin peerAdmin) |
private void |
AsyncNonMetaRegionLocator.complete(TableName tableName,
AsyncNonMetaRegionLocator.LocateRequest req,
RegionLocations locs,
Throwable error) |
private static CompletableFuture<Boolean> |
RawAsyncHBaseAdmin.completeCheckTableState(CompletableFuture<Boolean> future,
TableState tableState,
Throwable error,
TableState.State targetState,
TableName tableName)
Utility for completing passed TableState
CompletableFuture future using
passed parameters. |
static TableState |
TableState.convert(TableName tableName,
org.apache.hadoop.hbase.shaded.protobuf.generated.HBaseProtos.TableState tableState)
Covert from PB version of TableState
|
static TableDescriptor |
TableDescriptorBuilder.copy(TableName name,
TableDescriptor desc) |
private MultiServerCallable |
AsyncRequestFutureImpl.createCallable(ServerName server,
TableName tableName,
MultiAction multi)
Create a callable.
|
static RegionInfo |
RegionInfo.createMobRegionInfo(TableName tableName)
Creates a RegionInfo object for MOB data.
|
static byte[] |
RegionInfo.createRegionName(TableName tableName,
byte[] startKey,
byte[] id,
boolean newFormat)
Make a region name of passed parameters.
|
static byte[] |
RegionInfo.createRegionName(TableName tableName,
byte[] startKey,
byte[] id,
int replicaId,
boolean newFormat)
Make a region name of passed parameters.
|
static byte[] |
RegionInfo.createRegionName(TableName tableName,
byte[] startKey,
long regionid,
boolean newFormat)
Make a region name of passed parameters.
|
static byte[] |
RegionInfo.createRegionName(TableName tableName,
byte[] startKey,
long regionid,
int replicaId,
boolean newFormat)
Make a region name of passed parameters.
|
static byte[] |
RegionInfo.createRegionName(TableName tableName,
byte[] startKey,
String id,
boolean newFormat)
Make a region name of passed parameters.
|
static CatalogReplicaLoadBalanceSelector |
CatalogReplicaLoadBalanceSelectorFactory.createSelector(String replicaSelectorClass,
TableName tableName,
ChoreService choreService,
IntSupplier getReplicaCount)
Create a CatalogReplicaLoadBalanceReplicaSelector based on input config.
|
private CompletableFuture<Void> |
RawAsyncHBaseAdmin.createTable(TableName tableName,
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.CreateTableRequest request) |
void |
Admin.deleteColumn(TableName tableName,
byte[] columnFamily)
Deprecated.
As of release 2.0.0. This will be removed in HBase 3.0.0. Use
Admin.deleteColumnFamily(TableName, byte[]) }. |
void |
HBaseAdmin.deleteColumn(TableName tableName,
byte[] columnFamily)
Deprecated.
Since 2.0. Will be removed in 3.0. Use
Admin.deleteColumnFamily(TableName, byte[]) instead. |
default void |
Admin.deleteColumnFamily(TableName tableName,
byte[] columnFamily)
Delete a column family from a table.
|
CompletableFuture<Void> |
AsyncAdmin.deleteColumnFamily(TableName tableName,
byte[] columnFamily)
Delete a column family from a table.
|
CompletableFuture<Void> |
RawAsyncHBaseAdmin.deleteColumnFamily(TableName tableName,
byte[] columnFamily) |
CompletableFuture<Void> |
AsyncHBaseAdmin.deleteColumnFamily(TableName tableName,
byte[] columnFamily) |
Future<Void> |
Admin.deleteColumnFamilyAsync(TableName tableName,
byte[] columnFamily)
Delete a column family from a table.
|
Future<Void> |
HBaseAdmin.deleteColumnFamilyAsync(TableName tableName,
byte[] columnFamily) |
default void |
Admin.deleteTable(TableName tableName)
Deletes a table.
|
CompletableFuture<Void> |
AsyncAdmin.deleteTable(TableName tableName)
Deletes a table.
|
CompletableFuture<Void> |
RawAsyncHBaseAdmin.deleteTable(TableName tableName) |
CompletableFuture<Void> |
AsyncHBaseAdmin.deleteTable(TableName tableName) |
Future<Void> |
Admin.deleteTableAsync(TableName tableName)
Deletes the table but does not block and wait for it to be completely removed.
|
Future<Void> |
HBaseAdmin.deleteTableAsync(TableName tableName) |
default void |
Admin.disableTable(TableName tableName)
Disable table and wait on completion.
|
CompletableFuture<Void> |
AsyncAdmin.disableTable(TableName tableName)
Disable a table.
|
CompletableFuture<Void> |
RawAsyncHBaseAdmin.disableTable(TableName tableName) |
CompletableFuture<Void> |
AsyncHBaseAdmin.disableTable(TableName tableName) |
Future<Void> |
Admin.disableTableAsync(TableName tableName)
Disable the table but does not block and wait for it to be completely disabled.
|
Future<Void> |
HBaseAdmin.disableTableAsync(TableName tableName) |
void |
Admin.disableTableReplication(TableName tableName)
Disable a table's replication switch.
|
CompletableFuture<Void> |
AsyncAdmin.disableTableReplication(TableName tableName)
Disable a table's replication switch.
|
CompletableFuture<Void> |
RawAsyncHBaseAdmin.disableTableReplication(TableName tableName) |
CompletableFuture<Void> |
AsyncHBaseAdmin.disableTableReplication(TableName tableName) |
void |
HBaseAdmin.disableTableReplication(TableName tableName) |
static <R> void |
HTable.doBatchWithCallback(List<? extends Row> actions,
Object[] results,
Batch.Callback<R> callback,
ClusterConnection connection,
ExecutorService pool,
TableName tableName) |
default void |
Admin.enableTable(TableName tableName)
Enable a table.
|
CompletableFuture<Void> |
AsyncAdmin.enableTable(TableName tableName)
Enable a table.
|
CompletableFuture<Void> |
RawAsyncHBaseAdmin.enableTable(TableName tableName) |
CompletableFuture<Void> |
AsyncHBaseAdmin.enableTable(TableName tableName) |
Future<Void> |
Admin.enableTableAsync(TableName tableName)
Enable the table but does not block and wait for it to be completely enabled.
|
Future<Void> |
HBaseAdmin.enableTableAsync(TableName tableName) |
void |
Admin.enableTableReplication(TableName tableName)
Enable a table's replication switch.
|
CompletableFuture<Void> |
AsyncAdmin.enableTableReplication(TableName tableName)
Enable a table's replication switch.
|
CompletableFuture<Void> |
RawAsyncHBaseAdmin.enableTableReplication(TableName tableName) |
CompletableFuture<Void> |
AsyncHBaseAdmin.enableTableReplication(TableName tableName) |
void |
HBaseAdmin.enableTableReplication(TableName tableName) |
void |
Admin.flush(TableName tableName)
Flush a table.
|
CompletableFuture<Void> |
AsyncAdmin.flush(TableName tableName)
Flush a table.
|
CompletableFuture<Void> |
RawAsyncHBaseAdmin.flush(TableName tableName) |
CompletableFuture<Void> |
AsyncHBaseAdmin.flush(TableName tableName) |
void |
HBaseAdmin.flush(TableName tableName) |
void |
Admin.flush(TableName tableName,
byte[] columnFamily)
Flush the specified column family stores on all regions of the passed table.
|
CompletableFuture<Void> |
AsyncAdmin.flush(TableName tableName,
byte[] columnFamily)
Flush the specified column family stores on all regions of the passed table.
|
CompletableFuture<Void> |
RawAsyncHBaseAdmin.flush(TableName tableName,
byte[] columnFamily) |
CompletableFuture<Void> |
AsyncHBaseAdmin.flush(TableName tableName,
byte[] columnFamily) |
void |
HBaseAdmin.flush(TableName tableName,
byte[] columnFamily) |
private static int |
MutableRegionInfo.generateHashCode(TableName tableName,
byte[] startKey,
byte[] endKey,
long regionId,
int replicaId,
boolean offLine,
byte[] regionName) |
Pair<Integer,Integer> |
Admin.getAlterStatus(TableName tableName)
Deprecated.
Since 2.0.0. Will be removed in 3.0.0. No longer needed now you get a Future on an
operation.
|
Pair<Integer,Integer> |
HBaseAdmin.getAlterStatus(TableName tableName) |
BufferedMutator |
ConnectionImplementation.getBufferedMutator(TableName tableName) |
default AsyncBufferedMutator |
AsyncConnection.getBufferedMutator(TableName tableName)
Retrieve an
AsyncBufferedMutator for performing client-side buffering of writes. |
BufferedMutator |
Connection.getBufferedMutator(TableName tableName)
Retrieve a
BufferedMutator for performing client-side buffering of writes. |
default AsyncBufferedMutator |
AsyncConnection.getBufferedMutator(TableName tableName,
ExecutorService pool)
Retrieve an
AsyncBufferedMutator for performing client-side buffering of writes. |
AsyncBufferedMutatorBuilder |
AsyncConnectionImpl.getBufferedMutatorBuilder(TableName tableName) |
AsyncBufferedMutatorBuilder |
AsyncConnection.getBufferedMutatorBuilder(TableName tableName)
Returns an
AsyncBufferedMutatorBuilder for creating AsyncBufferedMutator . |
AsyncBufferedMutatorBuilder |
AsyncConnectionImpl.getBufferedMutatorBuilder(TableName tableName,
ExecutorService pool) |
AsyncBufferedMutatorBuilder |
AsyncConnection.getBufferedMutatorBuilder(TableName tableName,
ExecutorService pool)
Returns an
AsyncBufferedMutatorBuilder for creating AsyncBufferedMutator . |
RegionLocations |
MetaCache.getCachedLocation(TableName tableName,
byte[] row)
Search the cache for a location that fits our table and row key.
|
(package private) RegionLocations |
ConnectionImplementation.getCachedLocation(TableName tableName,
byte[] row)
Search the cache for a location that fits our table and row key.
|
CompactionState |
Admin.getCompactionState(TableName tableName)
Get the current compaction state of a table.
|
default CompletableFuture<CompactionState> |
AsyncAdmin.getCompactionState(TableName tableName)
Get the current compaction state of a table.
|
CompactionState |
HBaseAdmin.getCompactionState(TableName tableName) |
CompactionState |
Admin.getCompactionState(TableName tableName,
CompactType compactType)
Get the current compaction state of a table.
|
CompletableFuture<CompactionState> |
AsyncAdmin.getCompactionState(TableName tableName,
CompactType compactType)
Get the current compaction state of a table.
|
CompletableFuture<CompactionState> |
RawAsyncHBaseAdmin.getCompactionState(TableName tableName,
CompactType compactType) |
CompletableFuture<CompactionState> |
AsyncHBaseAdmin.getCompactionState(TableName tableName,
CompactType compactType) |
CompactionState |
HBaseAdmin.getCompactionState(TableName tableName,
CompactType compactType)
Get the current compaction state of a table.
|
SpaceQuotaSnapshotView |
Admin.getCurrentSpaceQuotaSnapshot(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 SpaceQuotaSnapshotView> |
AsyncAdmin.getCurrentSpaceQuotaSnapshot(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<SpaceQuotaSnapshot> |
RawAsyncHBaseAdmin.getCurrentSpaceQuotaSnapshot(TableName tableName) |
CompletableFuture<SpaceQuotaSnapshot> |
AsyncHBaseAdmin.getCurrentSpaceQuotaSnapshot(TableName tableName) |
SpaceQuotaSnapshot |
HBaseAdmin.getCurrentSpaceQuotaSnapshot(TableName tableName) |
TableDescriptor |
Admin.getDescriptor(TableName tableName)
Get a table descriptor.
|
CompletableFuture<TableDescriptor> |
AsyncAdmin.getDescriptor(TableName tableName)
Method for getting the tableDescriptor
|
CompletableFuture<TableDescriptor> |
RawAsyncHBaseAdmin.getDescriptor(TableName tableName) |
CompletableFuture<TableDescriptor> |
AsyncHBaseAdmin.getDescriptor(TableName tableName) |
TableDescriptor |
HBaseAdmin.getDescriptor(TableName tableName) |
(package private) static HTableDescriptor |
HBaseAdmin.getHTableDescriptor(TableName tableName,
Connection connection,
RpcRetryingCallerFactory rpcCallerFactory,
RpcControllerFactory rpcControllerFactory,
int operationTimeout,
int rpcTimeout)
Deprecated.
since 2.0 version and will be removed in 3.0 version. use
HBaseAdmin.getTableDescriptor(TableName, Connection, RpcRetryingCallerFactory,RpcControllerFactory,int,int) |
long |
Admin.getLastMajorCompactionTimestamp(TableName tableName)
Get the timestamp of the last major compaction for the passed table The timestamp of the oldest
HFile resulting from a major compaction of that table, or 0 if no such HFile could be found.
|
CompletableFuture<Optional<Long>> |
AsyncAdmin.getLastMajorCompactionTimestamp(TableName tableName)
Get the timestamp of the last major compaction for the passed table.
|
CompletableFuture<Optional<Long>> |
RawAsyncHBaseAdmin.getLastMajorCompactionTimestamp(TableName tableName) |
CompletableFuture<Optional<Long>> |
AsyncHBaseAdmin.getLastMajorCompactionTimestamp(TableName tableName) |
long |
HBaseAdmin.getLastMajorCompactionTimestamp(TableName tableName) |
private Consumer<Long> |
AsyncProcess.getLogger(TableName tableName,
long max) |
int |
MetaCache.getNumberOfCachedRegionLocations(TableName tableName)
Return the number of cached region for a table.
|
(package private) int |
ConnectionImplementation.getNumberOfCachedRegionLocations(TableName tableName) |
(package private) static int |
ConnectionUtils.getPriority(TableName tableName) |
HRegionLocation |
ClusterConnection.getRegionLocation(TableName tableName,
byte[] row,
boolean reload)
Find region location hosting passed row
|
HRegionLocation |
ConnectionImplementation.getRegionLocation(TableName tableName,
byte[] row,
boolean reload) |
(package private) CompletableFuture<HRegionLocation> |
AsyncRegionLocator.getRegionLocation(TableName tableName,
byte[] row,
int replicaId,
RegionLocateType type,
boolean reload,
long timeoutNs) |
(package private) CompletableFuture<HRegionLocation> |
AsyncRegionLocator.getRegionLocation(TableName tableName,
byte[] row,
int replicaId,
RegionLocateType type,
long timeoutNs) |
(package private) CompletableFuture<HRegionLocation> |
AsyncRegionLocator.getRegionLocation(TableName tableName,
byte[] row,
RegionLocateType type,
boolean reload,
long timeoutNs) |
(package private) CompletableFuture<HRegionLocation> |
AsyncRegionLocator.getRegionLocation(TableName tableName,
byte[] row,
RegionLocateType type,
long timeoutNs) |
(package private) RegionLocations |
AsyncNonMetaRegionLocator.getRegionLocationInCache(TableName tableName,
byte[] row) |
(package private) static RegionLocations |
RpcRetryingCallerWithReadReplicas.getRegionLocations(boolean useCache,
int replicaId,
ClusterConnection cConnection,
TableName tableName,
byte[] row) |
static RegionLocations |
RegionAdminServiceCallable.getRegionLocations(ClusterConnection connection,
TableName tableName,
byte[] row,
boolean useCache,
int replicaId) |
(package private) CompletableFuture<RegionLocations> |
AsyncNonMetaRegionLocator.getRegionLocations(TableName tableName,
byte[] row,
int replicaId,
RegionLocateType locateType,
boolean reload) |
(package private) CompletableFuture<RegionLocations> |
AsyncRegionLocator.getRegionLocations(TableName tableName,
byte[] row,
RegionLocateType type,
boolean reload,
long timeoutNs) |
private CompletableFuture<RegionLocations> |
AsyncNonMetaRegionLocator.getRegionLocationsInternal(TableName tableName,
byte[] row,
int replicaId,
RegionLocateType locateType,
boolean reload) |
RegionLocator |
ConnectionImplementation.getRegionLocator(TableName tableName) |
AsyncTableRegionLocator |
AsyncConnectionImpl.getRegionLocator(TableName tableName) |
AsyncTableRegionLocator |
AsyncConnection.getRegionLocator(TableName tableName)
Retrieve a AsyncRegionLocator implementation to inspect region information on a table.
|
RegionLocator |
Connection.getRegionLocator(TableName tableName)
Retrieve a RegionLocator implementation to inspect region information on a table.
|
List<RegionMetrics> |
Admin.getRegionMetrics(ServerName serverName,
TableName tableName)
Get
RegionMetrics of all regions hosted on a regionserver for a table. |
CompletableFuture<List<RegionMetrics>> |
AsyncAdmin.getRegionMetrics(ServerName serverName,
TableName tableName)
Get a list of
RegionMetrics of all regions hosted on a region server for a table. |
CompletableFuture<List<RegionMetrics>> |
RawAsyncHBaseAdmin.getRegionMetrics(ServerName serverName,
TableName tableName) |
CompletableFuture<List<RegionMetrics>> |
AsyncHBaseAdmin.getRegionMetrics(ServerName serverName,
TableName tableName) |
List<RegionMetrics> |
HBaseAdmin.getRegionMetrics(ServerName serverName,
TableName tableName) |
List<RegionInfo> |
Admin.getRegions(TableName tableName)
Get the regions of a given table.
|
CompletableFuture<List<RegionInfo>> |
AsyncAdmin.getRegions(TableName tableName)
Get the regions of a given table.
|
CompletableFuture<List<RegionInfo>> |
RawAsyncHBaseAdmin.getRegions(TableName tableName) |
CompletableFuture<List<RegionInfo>> |
AsyncHBaseAdmin.getRegions(TableName tableName) |
List<RegionInfo> |
HBaseAdmin.getRegions(TableName tableName) |
Table |
ConnectionImplementation.getTable(TableName tableName) |
default AsyncTable<AdvancedScanResultConsumer> |
AsyncConnection.getTable(TableName tableName)
Retrieve an
AsyncTable implementation for accessing a table. |
default Table |
Connection.getTable(TableName tableName)
Retrieve a Table implementation for accessing a table.
|
default AsyncTable<ScanResultConsumer> |
AsyncConnection.getTable(TableName tableName,
ExecutorService pool)
Retrieve an
AsyncTable implementation for accessing a table. |
default Table |
Connection.getTable(TableName tableName,
ExecutorService pool)
Retrieve a Table implementation for accessing a table.
|
AsyncTableBuilder<AdvancedScanResultConsumer> |
AsyncConnectionImpl.getTableBuilder(TableName tableName) |
AsyncTableBuilder<AdvancedScanResultConsumer> |
AsyncConnection.getTableBuilder(TableName tableName)
Returns an
AsyncTableBuilder for creating AsyncTable . |
TableBuilder |
ConnectionImplementation.getTableBuilder(TableName tableName,
ExecutorService pool) |
AsyncTableBuilder<ScanResultConsumer> |
AsyncConnectionImpl.getTableBuilder(TableName tableName,
ExecutorService pool) |
AsyncTableBuilder<ScanResultConsumer> |
AsyncConnection.getTableBuilder(TableName tableName,
ExecutorService pool)
Returns an
AsyncTableBuilder for creating AsyncTable . |
TableBuilder |
Connection.getTableBuilder(TableName tableName,
ExecutorService pool)
Returns an
TableBuilder for creating Table . |
private AsyncNonMetaRegionLocator.TableCache |
AsyncNonMetaRegionLocator.getTableCache(TableName tableName) |
HTableDescriptor |
Admin.getTableDescriptor(TableName tableName)
Deprecated.
since 2.0 version and will be removed in 3.0 version. Use
Admin.getDescriptor(TableName) . |
HTableDescriptor |
HBaseAdmin.getTableDescriptor(TableName tableName) |
(package private) static TableDescriptor |
HBaseAdmin.getTableDescriptor(TableName tableName,
Connection connection,
RpcRetryingCallerFactory rpcCallerFactory,
RpcControllerFactory rpcControllerFactory,
int operationTimeout,
int rpcTimeout) |
private CompletableFuture<List<HRegionLocation>> |
RawAsyncHBaseAdmin.getTableHRegionLocations(TableName tableName)
List all region locations for the specific table.
|
private ConcurrentNavigableMap<byte[],RegionLocations> |
MetaCache.getTableLocations(TableName tableName)
n * @return Map of cached locations for passed
tableName |
List<HRegionInfo> |
Admin.getTableRegions(TableName tableName)
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0
(HBASE-17980). Use
Admin.getRegions(TableName) . |
List<HRegionInfo> |
HBaseAdmin.getTableRegions(TableName tableName)
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use
HBaseAdmin.getRegions(TableName) . |
private CompletableFuture<byte[][]> |
RawAsyncHBaseAdmin.getTableSplits(TableName tableName) |
private byte[][] |
HBaseAdmin.getTableSplits(TableName tableName) |
TableState |
ClusterConnection.getTableState(TableName tableName)
Retrieve TableState, represent current table state.
|
TableState |
ConnectionImplementation.getTableState(TableName tableName) |
private CompletableFuture<Void> |
RawAsyncHBaseAdmin.internalRestoreSnapshot(String snapshotName,
TableName tableName,
boolean restoreAcl,
String customSFT) |
private Future<Void> |
HBaseAdmin.internalRestoreSnapshotAsync(String snapshotName,
TableName tableName,
boolean restoreAcl,
String customSFT)
Execute Restore/Clone snapshot and wait for the server to complete (blocking).
|
private boolean |
AsyncRegionLocator.isMeta(TableName tableName) |
boolean |
MetaCache.isRegionCached(TableName tableName,
byte[] row)
Check the region cache to see whether a region is cached yet or not.
|
boolean |
Admin.isTableAvailable(TableName tableName)
Check if a table is available.
|
CompletableFuture<Boolean> |
AsyncAdmin.isTableAvailable(TableName tableName)
Check if a table is available.
|
CompletableFuture<Boolean> |
RawAsyncHBaseAdmin.isTableAvailable(TableName tableName) |
CompletableFuture<Boolean> |
AsyncHBaseAdmin.isTableAvailable(TableName tableName) |
boolean |
HBaseAdmin.isTableAvailable(TableName tableName) |
boolean |
ClusterConnection.isTableAvailable(TableName tableName,
byte[][] splitKeys)
Use this api to check if the table has been created with the specified number of splitkeys
which was used while creating the given table.
|
boolean |
Admin.isTableAvailable(TableName tableName,
byte[][] splitKeys)
Deprecated.
Since 2.0.0. Will be removed in 3.0.0. Use
Admin.isTableAvailable(TableName) |
CompletableFuture<Boolean> |
AsyncAdmin.isTableAvailable(TableName tableName,
byte[][] splitKeys)
Deprecated.
Since 2.2.0. Will be removed in 3.0.0. Use
AsyncAdmin.isTableAvailable(TableName) |
boolean |
ConnectionImplementation.isTableAvailable(TableName tableName,
byte[][] splitKeys) |
CompletableFuture<Boolean> |
RawAsyncHBaseAdmin.isTableAvailable(TableName tableName,
byte[][] splitKeys) |
CompletableFuture<Boolean> |
AsyncHBaseAdmin.isTableAvailable(TableName tableName,
byte[][] splitKeys) |
boolean |
HBaseAdmin.isTableAvailable(TableName tableName,
byte[][] splitKeys) |
private CompletableFuture<Boolean> |
RawAsyncHBaseAdmin.isTableAvailable(TableName tableName,
Optional<byte[][]> splitKeys) |
boolean |
ClusterConnection.isTableDisabled(TableName tableName)
Check if a table is disabled.
|
boolean |
ConnectionUtils.MasterlessConnection.isTableDisabled(TableName tableName) |
boolean |
Admin.isTableDisabled(TableName tableName)
Check if a table is disabled.
|
CompletableFuture<Boolean> |
AsyncAdmin.isTableDisabled(TableName tableName)
Check if a table is disabled.
|
boolean |
ConnectionImplementation.isTableDisabled(TableName tableName) |
CompletableFuture<Boolean> |
RawAsyncHBaseAdmin.isTableDisabled(TableName tableName) |
CompletableFuture<Boolean> |
AsyncHBaseAdmin.isTableDisabled(TableName tableName) |
boolean |
HBaseAdmin.isTableDisabled(TableName tableName) |
boolean |
ClusterConnection.isTableEnabled(TableName tableName)
A table that isTableEnabled == false and isTableDisabled == false is possible.
|
boolean |
Admin.isTableEnabled(TableName tableName)
Check if a table is enabled.
|
CompletableFuture<Boolean> |
AsyncAdmin.isTableEnabled(TableName tableName)
Check if a table is enabled.
|
boolean |
ConnectionImplementation.isTableEnabled(TableName tableName) |
CompletableFuture<Boolean> |
RawAsyncHBaseAdmin.isTableEnabled(TableName tableName) |
CompletableFuture<Boolean> |
AsyncHBaseAdmin.isTableEnabled(TableName tableName) |
boolean |
HBaseAdmin.isTableEnabled(TableName tableName) |
private RegionLocations |
AsyncNonMetaRegionLocator.locateInCache(AsyncNonMetaRegionLocator.TableCache tableCache,
TableName tableName,
byte[] row,
int replicaId,
RegionLocateType locateType) |
private void |
AsyncNonMetaRegionLocator.locateInMeta(TableName tableName,
AsyncNonMetaRegionLocator.LocateRequest req) |
private RegionLocations |
ConnectionImplementation.locateMeta(TableName tableName,
boolean useCache,
int replicaId) |
HRegionLocation |
ClusterConnection.locateRegion(TableName tableName,
byte[] row)
Find the location of the region of tableName that row lives in.
|
HRegionLocation |
ConnectionImplementation.locateRegion(TableName tableName,
byte[] row) |
RegionLocations |
ClusterConnection.locateRegion(TableName tableName,
byte[] row,
boolean useCache,
boolean retry)
Gets the locations of the region in the specified table, tableName, for a given row.
|
RegionLocations |
ConnectionImplementation.locateRegion(TableName tableName,
byte[] row,
boolean useCache,
boolean retry) |
RegionLocations |
ClusterConnection.locateRegion(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.
|
RegionLocations |
ConnectionImplementation.locateRegion(TableName tableName,
byte[] row,
boolean useCache,
boolean retry,
int replicaId) |
private RegionLocations |
ConnectionImplementation.locateRegionInMeta(TableName tableName,
byte[] row,
boolean useCache,
boolean retry,
int replicaId)
Search the hbase:meta table for the HRegionLocation info that contains the table and row we're
seeking.
|
List<HRegionLocation> |
ClusterConnection.locateRegions(TableName tableName)
Gets the locations of all regions in the specified table, tableName.
|
List<HRegionLocation> |
ConnectionImplementation.locateRegions(TableName tableName) |
List<HRegionLocation> |
ClusterConnection.locateRegions(TableName tableName,
boolean useCache,
boolean offlined)
Gets the locations of all regions in the specified table, tableName.
|
List<HRegionLocation> |
ConnectionImplementation.locateRegions(TableName tableName,
boolean useCache,
boolean offlined) |
private RegionLocations |
AsyncNonMetaRegionLocator.locateRowBeforeInCache(AsyncNonMetaRegionLocator.TableCache tableCache,
TableName tableName,
byte[] row,
int replicaId) |
private RegionLocations |
AsyncNonMetaRegionLocator.locateRowInCache(AsyncNonMetaRegionLocator.TableCache tableCache,
TableName tableName,
byte[] row,
int replicaId) |
void |
Admin.majorCompact(TableName tableName)
Major compact a table.
|
default CompletableFuture<Void> |
AsyncAdmin.majorCompact(TableName tableName)
Major compact a table.
|
void |
HBaseAdmin.majorCompact(TableName tableName) |
void |
Admin.majorCompact(TableName tableName,
byte[] columnFamily)
Major compact a column family within a table.
|
default CompletableFuture<Void> |
AsyncAdmin.majorCompact(TableName tableName,
byte[] columnFamily)
Major compact a column family within a table.
|
void |
HBaseAdmin.majorCompact(TableName tableName,
byte[] columnFamily)
Major compact a column family within a table.
|
void |
Admin.majorCompact(TableName tableName,
byte[] columnFamily,
CompactType compactType)
Major compact a column family within a table.
|
CompletableFuture<Void> |
AsyncAdmin.majorCompact(TableName tableName,
byte[] columnFamily,
CompactType compactType)
Major compact a column family within a table.
|
CompletableFuture<Void> |
RawAsyncHBaseAdmin.majorCompact(TableName tableName,
byte[] columnFamily,
CompactType compactType) |
CompletableFuture<Void> |
AsyncHBaseAdmin.majorCompact(TableName tableName,
byte[] columnFamily,
CompactType compactType) |
void |
HBaseAdmin.majorCompact(TableName tableName,
byte[] columnFamily,
CompactType compactType)
Major compact a column family within a table.
|
void |
Admin.majorCompact(TableName tableName,
CompactType compactType)
Major compact a table.
|
CompletableFuture<Void> |
AsyncAdmin.majorCompact(TableName tableName,
CompactType compactType)
Major compact a table.
|
CompletableFuture<Void> |
RawAsyncHBaseAdmin.majorCompact(TableName tableName,
CompactType compactType) |
CompletableFuture<Void> |
AsyncHBaseAdmin.majorCompact(TableName tableName,
CompactType compactType) |
void |
HBaseAdmin.majorCompact(TableName tableName,
CompactType compactType)
Major compact a table.
|
default void |
Admin.modifyColumn(TableName tableName,
ColumnFamilyDescriptor columnFamily)
Deprecated.
As of release 2.0.0. This will be removed in HBase 3.0.0. Use
Admin.modifyColumnFamily(TableName, ColumnFamilyDescriptor) . |
default void |
Admin.modifyColumnFamily(TableName tableName,
ColumnFamilyDescriptor columnFamily)
Modify an existing column family on a table.
|
CompletableFuture<Void> |
AsyncAdmin.modifyColumnFamily(TableName tableName,
ColumnFamilyDescriptor columnFamily)
Modify an existing column family on a table.
|
CompletableFuture<Void> |
RawAsyncHBaseAdmin.modifyColumnFamily(TableName tableName,
ColumnFamilyDescriptor columnFamily) |
CompletableFuture<Void> |
AsyncHBaseAdmin.modifyColumnFamily(TableName tableName,
ColumnFamilyDescriptor columnFamily) |
Future<Void> |
Admin.modifyColumnFamilyAsync(TableName tableName,
ColumnFamilyDescriptor columnFamily)
Modify an existing column family on a table.
|
Future<Void> |
HBaseAdmin.modifyColumnFamilyAsync(TableName tableName,
ColumnFamilyDescriptor columnFamily) |
default void |
Admin.modifyColumnFamilyStoreFileTracker(TableName tableName,
byte[] family,
String dstSFT)
Change the store file tracker of the given table's given family.
|
CompletableFuture<Void> |
AsyncAdmin.modifyColumnFamilyStoreFileTracker(TableName tableName,
byte[] family,
String dstSFT)
Change the store file tracker of the given table's given family.
|
CompletableFuture<Void> |
RawAsyncHBaseAdmin.modifyColumnFamilyStoreFileTracker(TableName tableName,
byte[] family,
String dstSFT) |
CompletableFuture<Void> |
AsyncHBaseAdmin.modifyColumnFamilyStoreFileTracker(TableName tableName,
byte[] family,
String dstSFT) |
Future<Void> |
Admin.modifyColumnFamilyStoreFileTrackerAsync(TableName tableName,
byte[] family,
String dstSFT)
Change the store file tracker of the given table's given family.
|
Future<Void> |
HBaseAdmin.modifyColumnFamilyStoreFileTrackerAsync(TableName tableName,
byte[] family,
String dstSFT) |
default void |
Admin.modifyTable(TableName tableName,
TableDescriptor td)
Deprecated.
since 2.0 version and will be removed in 3.0 version. use
Admin.modifyTable(TableDescriptor) |
default Future<Void> |
Admin.modifyTableAsync(TableName tableName,
TableDescriptor td)
Deprecated.
since 2.0 version and will be removed in 3.0 version. use
Admin.modifyTableAsync(TableDescriptor) |
default void |
Admin.modifyTableStoreFileTracker(TableName tableName,
String dstSFT)
Change the store file tracker of the given table.
|
CompletableFuture<Void> |
AsyncAdmin.modifyTableStoreFileTracker(TableName tableName,
String dstSFT)
Change the store file tracker of the given table.
|
CompletableFuture<Void> |
RawAsyncHBaseAdmin.modifyTableStoreFileTracker(TableName tableName,
String dstSFT) |
CompletableFuture<Void> |
AsyncHBaseAdmin.modifyTableStoreFileTracker(TableName tableName,
String dstSFT) |
Future<Void> |
Admin.modifyTableStoreFileTrackerAsync(TableName tableName,
String dstSFT)
Change the store file tracker of the given table.
|
Future<Void> |
HBaseAdmin.modifyTableStoreFileTrackerAsync(TableName tableName,
String dstSFT) |
static RegionInfoBuilder |
RegionInfoBuilder.newBuilder(TableName tableName) |
static TableDescriptorBuilder |
TableDescriptorBuilder.newBuilder(TableName name) |
private boolean |
AsyncNonMetaRegionLocator.onScanNext(TableName tableName,
AsyncNonMetaRegionLocator.LocateRequest req,
Result result) |
static TableState |
TableState.parseFrom(TableName tableName,
byte[] bytes) |
AsyncRpcRetryingCallerFactory.MasterRequestCallerBuilder<T> |
AsyncRpcRetryingCallerFactory.MasterRequestCallerBuilder.priority(TableName tableName) |
private <PREQ,PRESP> |
RawAsyncHBaseAdmin.procedureCall(TableName tableName,
PREQ preq,
RawAsyncHBaseAdmin.MasterRpcCall<PRESP,PREQ> rpcCall,
RawAsyncHBaseAdmin.Converter<Long,PRESP> respConverter,
RawAsyncHBaseAdmin.ProcedureBiConsumer consumer) |
List<Put> |
HTableMultiplexer.put(TableName tableName,
List<Put> puts)
Deprecated.
The puts request will be buffered by their corresponding buffer queue.
|
boolean |
HTableMultiplexer.put(TableName tableName,
Put put)
Deprecated.
The put request will be buffered by its corresponding buffer queue.
|
boolean |
HTableMultiplexer.put(TableName tableName,
Put put,
int maxAttempts)
Deprecated.
The put request will be buffered by its corresponding buffer queue.
|
HRegionLocation |
ClusterConnection.relocateRegion(TableName tableName,
byte[] row)
Find the location of the region of tableName that row lives in, ignoring any
value that might be in the cache.
|
HRegionLocation |
ConnectionImplementation.relocateRegion(TableName tableName,
byte[] row) |
RegionLocations |
ClusterConnection.relocateRegion(TableName tableName,
byte[] row,
int replicaId)
Find the location of the region of tableName that row lives in, ignoring any
value that might be in the cache.
|
RegionLocations |
ConnectionImplementation.relocateRegion(TableName tableName,
byte[] row,
int replicaId) |
private CompletableFuture<Void> |
RawAsyncHBaseAdmin.restoreSnapshot(String snapshotName,
TableName tableName,
boolean takeFailSafeSnapshot,
boolean restoreAcl) |
int |
CatalogReplicaLoadBalanceSimpleSelector.select(TableName tableName,
byte[] row,
RegionLocateType locateType)
When it looks up a location, it will call this method to find a replica region to go.
|
int |
CatalogReplicaLoadBalanceSelector.select(TableName tablename,
byte[] row,
RegionLocateType locateType)
Select a catalog replica region where client go to loop up the input row key.
|
(package private) void |
MasterCallable.setPriority(TableName tableName) |
AsyncProcessTask.Builder<T> |
AsyncProcessTask.Builder.setTableName(TableName tableName) |
private void |
HBaseAdmin.setTableRep(TableName tableName,
boolean enableRep)
Set the table's replication switch if the table's replication switch is already not set.
|
private CompletableFuture<Void> |
RawAsyncHBaseAdmin.setTableReplication(TableName tableName,
boolean enableRep)
Set the table's replication switch if the table's replication switch is already not set.
|
default void |
Admin.snapshot(byte[] snapshotName,
TableName tableName)
Deprecated.
since 2.3.0, will be removed in 3.0.0. Use
Admin.snapshot(String, TableName)
instead. |
default void |
Admin.snapshot(String snapshotName,
TableName tableName)
Take a snapshot for the given table.
|
default CompletableFuture<Void> |
AsyncAdmin.snapshot(String snapshotName,
TableName tableName)
Take a snapshot for the given table.
|
default void |
Admin.snapshot(String snapshotName,
TableName tableName,
Map<String,Object> snapshotProps)
Create typed snapshot of the table.
|
default void |
Admin.snapshot(String snapshotName,
TableName tableName,
SnapshotType type)
Create typed snapshot of the table.
|
default CompletableFuture<Void> |
AsyncAdmin.snapshot(String snapshotName,
TableName tableName,
SnapshotType type)
Create typed snapshot of the table.
|
default void |
Admin.snapshot(String snapshotName,
TableName tableName,
SnapshotType type,
Map<String,Object> snapshotProps)
Create typed snapshot of the table.
|
void |
Admin.split(TableName tableName)
Split a table.
|
CompletableFuture<Void> |
AsyncAdmin.split(TableName tableName)
Split a table.
|
CompletableFuture<Void> |
RawAsyncHBaseAdmin.split(TableName tableName) |
CompletableFuture<Void> |
AsyncHBaseAdmin.split(TableName tableName) |
void |
HBaseAdmin.split(TableName tableName) |
void |
Admin.split(TableName tableName,
byte[] splitPoint)
Split a table.
|
CompletableFuture<Void> |
AsyncAdmin.split(TableName tableName,
byte[] splitPoint)
Split a table.
|
CompletableFuture<Void> |
RawAsyncHBaseAdmin.split(TableName tableName,
byte[] splitPoint) |
CompletableFuture<Void> |
AsyncHBaseAdmin.split(TableName tableName,
byte[] splitPoint) |
void |
HBaseAdmin.split(TableName tableName,
byte[] splitPoint) |
AsyncRpcRetryingCallerFactory.SingleRequestCallerBuilder<T> |
AsyncRpcRetryingCallerFactory.SingleRequestCallerBuilder.table(TableName tableName) |
AsyncRpcRetryingCallerFactory.BatchCallerBuilder |
AsyncRpcRetryingCallerFactory.BatchCallerBuilder.table(TableName tableName) |
boolean |
Admin.tableExists(TableName tableName)
Check if a table exists.
|
CompletableFuture<Boolean> |
AsyncAdmin.tableExists(TableName tableName)
Check if a table exists.
|
CompletableFuture<Boolean> |
RawAsyncHBaseAdmin.tableExists(TableName tableName) |
CompletableFuture<Boolean> |
AsyncHBaseAdmin.tableExists(TableName tableName) |
boolean |
HBaseAdmin.tableExists(TableName tableName) |
(package private) static <T> CompletableFuture<T> |
ConnectionUtils.timelineConsistentRead(AsyncRegionLocator locator,
TableName tableName,
Query query,
byte[] row,
RegionLocateType locateType,
Function<Integer,CompletableFuture<T>> requestReplica,
long rpcTimeoutNs,
long primaryCallTimeoutNs,
org.apache.hbase.thirdparty.io.netty.util.Timer retryTimer,
Optional<MetricsConnection> metrics) |
default void |
Admin.truncateTable(TableName tableName,
boolean preserveSplits)
Truncate a table.
|
CompletableFuture<Void> |
AsyncAdmin.truncateTable(TableName tableName,
boolean preserveSplits)
Truncate a table.
|
CompletableFuture<Void> |
RawAsyncHBaseAdmin.truncateTable(TableName tableName,
boolean preserveSplits) |
CompletableFuture<Void> |
AsyncHBaseAdmin.truncateTable(TableName tableName,
boolean preserveSplits) |
Future<Void> |
Admin.truncateTableAsync(TableName tableName,
boolean preserveSplits)
Truncate the table but does not block and wait for it to be completely enabled.
|
Future<Void> |
HBaseAdmin.truncateTableAsync(TableName tableName,
boolean preserveSplits) |
private CompletableFuture<Void> |
RawAsyncHBaseAdmin.trySyncTableToPeerCluster(TableName tableName,
byte[][] splits,
ReplicationPeerDescription peer) |
void |
ClusterConnection.updateCachedLocations(TableName tableName,
byte[] regionName,
byte[] rowkey,
Object exception,
ServerName source)
Update the location cache.
|
void |
ConnectionImplementation.updateCachedLocations(TableName tableName,
byte[] regionName,
byte[] rowkey,
Object exception,
ServerName source)
Update the location with the new value (if the exception is a RegionMovedException) or delete
it from the cache.
|
protected void |
AsyncProcess.waitForMaximumCurrentTasks(int max,
TableName tableName)
Wait until the async does not have more than max tasks in progress.
|
Constructor and Description |
---|
AddColumnFamilyFuture(HBaseAdmin admin,
TableName tableName,
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.AddColumnResponse response) |
AddColumnFamilyProcedureBiConsumer(TableName tableName) |
AsyncBatchRpcRetryingCaller(org.apache.hbase.thirdparty.io.netty.util.Timer retryTimer,
AsyncConnectionImpl conn,
TableName tableName,
List<? extends Row> actions,
long pauseNs,
long pauseNsForServerOverloaded,
int maxAttempts,
long operationTimeoutNs,
long rpcTimeoutNs,
int startLogErrorsCnt) |
AsyncClientScanner(Scan scan,
AdvancedScanResultConsumer consumer,
TableName tableName,
AsyncConnectionImpl conn,
org.apache.hbase.thirdparty.io.netty.util.Timer retryTimer,
long pauseNs,
long pauseNsForServerOverloaded,
int maxAttempts,
long scanTimeoutNs,
long rpcTimeoutNs,
int startLogErrorsCnt) |
AsyncProcessTask(ExecutorService pool,
TableName tableName,
RowAccess<? extends Row> rows,
AsyncProcessTask.SubmittedRows size,
Batch.Callback<T> callback,
CancellableRegionServerCallable callable,
boolean needResults,
int rpcTimeout,
int operationTimeout,
Object[] results) |
AsyncSingleRequestRpcRetryingCaller(org.apache.hbase.thirdparty.io.netty.util.Timer retryTimer,
AsyncConnectionImpl conn,
TableName tableName,
byte[] row,
int replicaId,
RegionLocateType locateType,
AsyncSingleRequestRpcRetryingCaller.Callable<T> callable,
int priority,
long pauseNs,
long pauseNsForServerOverloaded,
int maxAttempts,
long operationTimeoutNs,
long rpcTimeoutNs,
int startLogErrorsCnt) |
AsyncTableBuilderBase(TableName tableName,
AsyncConnectionConfiguration connConf) |
AsyncTableRegionLocatorImpl(TableName tableName,
AsyncConnectionImpl conn) |
AsyncTableResultScanner(TableName tableName,
Scan scan,
long maxCacheSize) |
BufferedMutatorParams(TableName tableName) |
CancellableRegionServerCallable(Connection connection,
TableName tableName,
byte[] row,
org.apache.hbase.thirdparty.com.google.protobuf.RpcController rpcController,
int rpcTimeout,
RetryingTimeTracker tracker,
int priority) |
CatalogReplicaLoadBalanceSimpleSelector(TableName tableName,
ChoreService choreService,
IntSupplier getNumOfReplicas) |
ClientAsyncPrefetchScanner(org.apache.hadoop.conf.Configuration configuration,
Scan scan,
TableName name,
ClusterConnection connection,
RpcRetryingCallerFactory rpcCallerFactory,
RpcControllerFactory rpcControllerFactory,
ExecutorService pool,
int scanReadRpcTimeout,
int scannerTimeout,
int replicaCallTimeoutMicroSecondScan) |
ClientScanner(org.apache.hadoop.conf.Configuration conf,
Scan scan,
TableName tableName,
ClusterConnection connection,
RpcRetryingCallerFactory rpcFactory,
RpcControllerFactory controllerFactory,
ExecutorService pool,
int scanReadRpcTimeout,
int scannerTimeout,
int primaryOperationTimeout)
Create a new ClientScanner for the specified table Note that the passed
Scan 's start
row maybe changed changed. |
ClientServiceCallable(Connection connection,
TableName tableName,
byte[] row,
org.apache.hbase.thirdparty.com.google.protobuf.RpcController rpcController,
int priority) |
ClientSimpleScanner(org.apache.hadoop.conf.Configuration configuration,
Scan scan,
TableName name,
ClusterConnection connection,
RpcRetryingCallerFactory rpcCallerFactory,
RpcControllerFactory rpcControllerFactory,
ExecutorService pool,
int scanReadRpcTimeout,
int scannerTimeout,
int replicaCallTimeoutMicroSecondScan) |
CreateTableProcedureBiConsumer(TableName tableName) |
DeleteColumnFamilyFuture(HBaseAdmin admin,
TableName tableName,
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.DeleteColumnResponse response) |
DeleteColumnFamilyProcedureBiConsumer(TableName tableName) |
DeleteTableFuture(HBaseAdmin admin,
TableName tableName,
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.DeleteTableResponse response) |
DeleteTableProcedureBiConsumer(TableName tableName) |
DisableTableFuture(HBaseAdmin admin,
TableName tableName,
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.DisableTableResponse response) |
DisableTableProcedureBiConsumer(TableName tableName) |
EnableTableFuture(HBaseAdmin admin,
TableName tableName,
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.EnableTableResponse response) |
EnableTableProcedureBiConsumer(TableName tableName) |
FlushRegionCallable(ClusterConnection connection,
RpcControllerFactory rpcControllerFactory,
TableName tableName,
byte[] regionName,
byte[] regionStartKey,
boolean writeFlushWalMarker) |
HRegionLocator(TableName tableName,
ConnectionImplementation connection) |
MergeTableRegionProcedureBiConsumer(TableName tableName) |
MergeTableRegionsFuture(HBaseAdmin admin,
TableName tableName,
Long procId) |
MergeTableRegionsFuture(HBaseAdmin admin,
TableName tableName,
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MergeTableRegionsResponse response) |
ModifyableTableDescriptor(TableName name)
Construct a table descriptor specifying a TableName object
|
ModifyableTableDescriptor(TableName name,
Collection<ColumnFamilyDescriptor> families,
Map<Bytes,Bytes> values) |
ModifyableTableDescriptor(TableName name,
TableDescriptor desc)
Deprecated.
|
ModifyColumnFamilyFuture(HBaseAdmin admin,
TableName tableName,
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.ModifyColumnResponse response) |
ModifyColumnFamilyProcedureBiConsumer(TableName tableName) |
ModifyColumnFamilyStoreFileTrackerFuture(HBaseAdmin admin,
TableName tableName,
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.ModifyColumnStoreFileTrackerResponse response) |
ModifyColumnFamilyStoreFileTrackerProcedureBiConsumer(TableName tableName) |
ModifyTableFuture(HBaseAdmin admin,
TableName tableName,
Long procId) |
ModifyTableFuture(HBaseAdmin admin,
TableName tableName,
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.ModifyTableResponse response) |
ModifyTableProcedureBiConsumer(AsyncAdmin admin,
TableName tableName) |
ModifyTablerStoreFileTrackerFuture(HBaseAdmin admin,
TableName tableName,
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.ModifyTableStoreFileTrackerResponse response) |
ModifyTableStoreFileTrackerProcedureBiConsumer(AsyncAdmin admin,
TableName tableName) |
MultiServerCallable(ClusterConnection connection,
TableName tableName,
ServerName location,
MultiAction multi,
org.apache.hbase.thirdparty.com.google.protobuf.RpcController rpcController,
int rpcTimeout,
RetryingTimeTracker tracker,
int priority) |
MutableRegionInfo(long regionId,
TableName tableName,
int replicaId)
Package private constructor used constructing MutableRegionInfo for the first meta regions
|
MutableRegionInfo(TableName tableName,
byte[] startKey,
byte[] endKey,
boolean split,
long regionId,
int replicaId,
boolean offLine) |
NoncedRegionServerCallable(Connection connection,
TableName tableName,
byte[] row,
HBaseRpcController rpcController,
int priority) |
RegionAdminServiceCallable(ClusterConnection connection,
RpcControllerFactory rpcControllerFactory,
HRegionLocation location,
TableName tableName,
byte[] row) |
RegionAdminServiceCallable(ClusterConnection connection,
RpcControllerFactory rpcControllerFactory,
HRegionLocation location,
TableName tableName,
byte[] row,
int replicaId) |
RegionAdminServiceCallable(ClusterConnection connection,
RpcControllerFactory rpcControllerFactory,
TableName tableName,
byte[] row) |
RegionCoprocessorRpcChannel(ClusterConnection conn,
TableName table,
byte[] row)
Constructor
|
RegionCoprocessorRpcChannelImpl(AsyncConnectionImpl conn,
TableName tableName,
RegionInfo region,
byte[] row,
long rpcTimeoutNs,
long operationTimeoutNs) |
RegionInfoBuilder(TableName tableName) |
RegionServerCallable(Connection connection,
TableName tableName,
byte[] row,
org.apache.hbase.thirdparty.com.google.protobuf.RpcController rpcController) |
RegionServerCallable(Connection connection,
TableName tableName,
byte[] row,
org.apache.hbase.thirdparty.com.google.protobuf.RpcController rpcController,
int priority) |
RestoreSnapshotFuture(HBaseAdmin admin,
org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotDescription snapshot,
TableName tableName,
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.RestoreSnapshotResponse response) |
RestoreSnapshotFuture(HBaseAdmin admin,
TableName tableName,
Long procId) |
ReversedClientScanner(org.apache.hadoop.conf.Configuration conf,
Scan scan,
TableName tableName,
ClusterConnection connection,
RpcRetryingCallerFactory rpcFactory,
RpcControllerFactory controllerFactory,
ExecutorService pool,
int scanReadRpcTimeout,
int scannerTimeout,
int primaryOperationTimeout)
Create a new ReversibleClientScanner for the specified table Note that the passed
Scan 's start row maybe changed. |
ReversedScannerCallable(ClusterConnection connection,
TableName tableName,
Scan scan,
ScanMetrics scanMetrics,
RpcControllerFactory rpcFactory,
int replicaId) |
RpcRetryingCallerWithReadReplicas(RpcControllerFactory rpcControllerFactory,
TableName tableName,
ClusterConnection cConnection,
Get get,
ExecutorService pool,
int retries,
int operationTimeout,
int rpcTimeout,
int timeBeforeReplicas) |
ScannerCallable(ClusterConnection connection,
TableName tableName,
Scan scan,
ScanMetrics scanMetrics,
RpcControllerFactory rpcControllerFactory,
int id) |
ScannerCallableWithReplicas(TableName tableName,
ClusterConnection cConnection,
ScannerCallable baseCallable,
ExecutorService pool,
int timeBeforeReplicas,
Scan scan,
int retries,
int readRpcTimeout,
int scannerTimeout,
int caching,
org.apache.hadoop.conf.Configuration conf,
RpcRetryingCaller<Result[]> caller) |
SnapshotDescription(String name,
TableName table) |
SnapshotDescription(String name,
TableName table,
SnapshotType type) |
SnapshotDescription(String snapshotName,
TableName tableName,
SnapshotType type,
Map<String,Object> snapshotProps)
SnapshotDescription Parameterized Constructor
|
SnapshotDescription(String name,
TableName table,
SnapshotType type,
String owner) |
SnapshotDescription(String name,
TableName table,
SnapshotType type,
String owner,
long creationTime,
int version)
Deprecated.
since 2.3.0 and will be removed in 4.0.0. Use
SnapshotDescription(String, TableName, SnapshotType, String, long, int, Map) |
SnapshotDescription(String name,
TableName table,
SnapshotType type,
String owner,
long creationTime,
int version,
Map<String,Object> snapshotProps)
SnapshotDescription Parameterized Constructor
|
SplitTableRegionFuture(HBaseAdmin admin,
TableName tableName,
Long procId) |
SplitTableRegionFuture(HBaseAdmin admin,
TableName tableName,
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.SplitTableRegionResponse response) |
SplitTableRegionProcedureBiConsumer(TableName tableName) |
TableBuilderBase(TableName tableName,
ConnectionConfiguration connConf) |
TableDescriptorBuilder(TableName name) |
TableFuture(HBaseAdmin admin,
TableName tableName,
Long procId) |
TableProcedureBiConsumer(TableName tableName) |
TableState(TableName tableName,
TableState.State state)
Create instance of TableState.
|
TruncateTableFuture(HBaseAdmin admin,
TableName tableName,
boolean preserveSplits,
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.TruncateTableResponse response) |
TruncateTableProcedureBiConsumer(TableName tableName) |
Constructor and Description |
---|
NormalizeTableFilterParams(List<TableName> tableNames,
String regex,
String namespace) |
Modifier and Type | Field and Description |
---|---|
private static TableName |
BufferedMutatorExample.TABLE |
private TableName |
MultiThreadedClientExample.WriteExampleCallable.tableName |
private TableName |
MultiThreadedClientExample.SingleWriteExampleCallable.tableName |
private TableName |
MultiThreadedClientExample.ReadExampleCallable.tableName |
Modifier and Type | Method and Description |
---|---|
void |
RefreshHFilesClient.refreshHFiles(TableName tableName) |
private void |
MultiThreadedClientExample.warmUpConnectionCache(Connection connection,
TableName tn) |
Constructor and Description |
---|
ReadExampleCallable(Connection connection,
TableName tableName) |
SingleWriteExampleCallable(Connection connection,
TableName tableName) |
WriteExampleCallable(Connection connection,
TableName tableName) |
Modifier and Type | Method and 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,
TableName tableName,
List<RegionInfo> regionInfos,
String description,
long nonceGroup,
long nonce) |
EntityLock |
LockServiceClient.tableLock(TableName tableName,
boolean exclusive,
String description,
Abortable abort)
Create a new EntityLock object to acquire an exclusive or shared lock on a table.
|
Modifier and Type | Field and Description |
---|---|
private TableName |
TableCFs.table |
Modifier and Type | Method and Description |
---|---|
TableName |
TableCFs.getTable() |
Modifier and Type | Method and Description |
---|---|
static Map<TableName,List<String>> |
ReplicationPeerConfigUtil.convert2Map(org.apache.hadoop.hbase.shaded.protobuf.generated.ReplicationProtos.TableCF[] tableCFs)
Convert tableCFs Object to Map.
|
private Map<TableName,List<String>> |
ReplicationAdmin.copyTableCFs(Map<TableName,? extends Collection<String>> tableCfs)
Deprecated.
|
private static Map<TableName,List<String>> |
ReplicationPeerConfigUtil.copyTableCFsMap(Map<TableName,List<String>> preTableCfs) |
private static Map<TableName,List<String>> |
ReplicationPeerConfigUtil.mergeTableCFs(Map<TableName,List<String>> preTableCfs,
Map<TableName,List<String>> tableCfs) |
static Map<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<TableName,List<String>> |
ReplicationPeerConfigUtil.parseTableCFsFromConfig(String tableCFsConfig)
Convert tableCFs string into Map.
|
Modifier and Type | Method and Description |
---|---|
void |
ReplicationAdmin.disableTableRep(TableName tableName)
Deprecated.
use
Admin.disableTableReplication(TableName)
instead |
void |
ReplicationAdmin.enableTableRep(TableName tableName)
Deprecated.
use
Admin.enableTableReplication(TableName)
instead |
Modifier and Type | Method and Description |
---|---|
void |
ReplicationAdmin.addPeer(String id,
ReplicationPeerConfig peerConfig,
Map<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 ReplicationPeerConfig |
ReplicationPeerConfigUtil.appendExcludeTableCFsToReplicationPeerConfig(Map<TableName,List<String>> excludeTableCfs,
ReplicationPeerConfig peerConfig) |
void |
ReplicationAdmin.appendPeerTableCFs(String id,
Map<TableName,? extends Collection<String>> tableCfs)
Deprecated.
|
static ReplicationPeerConfig |
ReplicationPeerConfigUtil.appendTableCFsToReplicationPeerConfig(Map<TableName,List<String>> tableCfs,
ReplicationPeerConfig peerConfig) |
static org.apache.hadoop.hbase.shaded.protobuf.generated.ReplicationProtos.TableCF[] |
ReplicationPeerConfigUtil.convert(Map<TableName,? extends Collection<String>> tableCfs)
convert map to TableCFs Object
|
static String |
ReplicationPeerConfigUtil.convertToString(Map<TableName,? extends Collection<String>> tableCfs) |
private Map<TableName,List<String>> |
ReplicationAdmin.copyTableCFs(Map<TableName,? extends Collection<String>> tableCfs)
Deprecated.
|
private static Map<TableName,List<String>> |
ReplicationPeerConfigUtil.copyTableCFsMap(Map<TableName,List<String>> preTableCfs) |
private static Map<TableName,List<String>> |
ReplicationPeerConfigUtil.mergeTableCFs(Map<TableName,List<String>> preTableCfs,
Map<TableName,List<String>> tableCfs) |
private static Map<TableName,List<String>> |
ReplicationPeerConfigUtil.mergeTableCFs(Map<TableName,List<String>> preTableCfs,
Map<TableName,List<String>> tableCfs) |
static ReplicationPeerConfig |
ReplicationPeerConfigUtil.removeExcludeTableCFsFromReplicationPeerConfig(Map<TableName,List<String>> excludeTableCfs,
ReplicationPeerConfig peerConfig,
String id) |
void |
ReplicationAdmin.removePeerTableCFs(String id,
Map<TableName,? extends Collection<String>> tableCfs)
Deprecated.
|
static ReplicationPeerConfig |
ReplicationPeerConfigUtil.removeTableCFsFromReplicationPeerConfig(Map<TableName,List<String>> tableCfs,
ReplicationPeerConfig peerConfig,
String id) |
void |
ReplicationAdmin.setPeerTableCFs(String id,
Map<TableName,? extends Collection<String>> tableCfs)
Deprecated.
|
Constructor and Description |
---|
TableCFs(TableName table,
Map<String,Integer> cfs) |
Modifier and Type | Field and Description |
---|---|
private TableName |
TableOperationSpanBuilder.tableName |
Modifier and Type | Method and Description |
---|---|
(package private) static void |
TableSpanBuilder.populateTableNameAttributes(Map<io.opentelemetry.api.common.AttributeKey<?>,Object> attributes,
TableName tableName)
Static utility method that performs the primary logic of this builder.
|
TableSpanBuilder |
TableSpanBuilder.setTableName(TableName tableName) |
TableOperationSpanBuilder |
TableOperationSpanBuilder.setTableName(TableName tableName) |
Modifier and Type | Method and Description |
---|---|
default void |
MasterObserver.postCompletedDeleteTableAction(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName)
Called after
HMaster deletes a table. |
default void |
MasterObserver.postCompletedDisableTableAction(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName)
Called after the disableTable operation has been requested.
|
default void |
MasterObserver.postCompletedEnableTableAction(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName)
Called after the enableTable operation has been requested.
|
default void |
MasterObserver.postCompletedModifyTableAction(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName,
TableDescriptor currentDescriptor)
Deprecated.
Since 2.1. Will be removed in 3.0.
|
default void |
MasterObserver.postCompletedModifyTableAction(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName,
TableDescriptor oldDescriptor,
TableDescriptor currentDescriptor)
Called after to modifying a table's properties.
|
default void |
MasterObserver.postCompletedTruncateTableAction(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName)
Called after
HMaster truncates a table. |
default void |
MasterObserver.postDeleteTable(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName)
Called after the deleteTable operation has been requested.
|
default void |
MasterObserver.postDisableTable(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName)
Called after the disableTable operation has been requested.
|
default void |
MasterObserver.postEnableTable(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName)
Called after the enableTable operation has been requested.
|
default void |
MasterObserver.postGetUserPermissions(ObserverContext<MasterCoprocessorEnvironment> ctx,
String userName,
String namespace,
TableName tableName,
byte[] family,
byte[] qualifier)
Called after getting user permissions.
|
default void |
MasterObserver.postModifyColumnFamilyStoreFileTracker(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName,
byte[] family,
String dstSFT)
Called after modifying a family store file tracker.
|
default void |
MasterObserver.postModifyTable(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName,
TableDescriptor currentDescriptor)
Deprecated.
Since 2.1. Will be removed in 3.0.
|
default void |
MasterObserver.postModifyTable(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName,
TableDescriptor oldDescriptor,
TableDescriptor currentDescriptor)
Called after the modifyTable operation has been requested.
|
default void |
MasterObserver.postModifyTableStoreFileTracker(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName,
String dstSFT)
Called after modifying a table's store file tracker.
|
default void |
MasterObserver.postRequestLock(ObserverContext<MasterCoprocessorEnvironment> ctx,
String namespace,
TableName tableName,
RegionInfo[] regionInfos,
String description)
Called after new LockProcedure is queued.
|
default void |
MasterObserver.postSetTableQuota(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName,
GlobalQuotaSettings quotas)
Called after the quota for the table is stored.
|
default void |
MasterObserver.postSetUserQuota(ObserverContext<MasterCoprocessorEnvironment> ctx,
String userName,
TableName tableName,
GlobalQuotaSettings quotas)
Called after the quota for the user on the specified table is stored.
|
default void |
MasterObserver.postTableFlush(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName)
Called after the table memstore is flushed to disk.
|
default void |
MasterObserver.postTruncateTable(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName)
Called after the truncateTable operation has been requested.
|
default void |
MasterObserver.preDeleteTable(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName)
Called before
HMaster deletes a table. |
default void |
MasterObserver.preDeleteTableAction(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName)
Called before
HMaster deletes a table. |
default void |
MasterObserver.preDisableTable(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName)
Called prior to disabling a table.
|
default void |
MasterObserver.preDisableTableAction(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName)
Called prior to disabling a table.
|
default void |
MasterObserver.preEnableTable(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName)
Called prior to enabling a table.
|
default void |
MasterObserver.preEnableTableAction(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName)
Called prior to enabling a table.
|
default void |
MasterObserver.preGetUserPermissions(ObserverContext<MasterCoprocessorEnvironment> ctx,
String userName,
String namespace,
TableName tableName,
byte[] family,
byte[] qualifier)
Called before getting user permissions.
|
default void |
MasterObserver.preLockHeartbeat(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tn,
String description)
Called before heartbeat to a lock.
|
default String |
MasterObserver.preModifyColumnFamilyStoreFileTracker(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName,
byte[] family,
String dstSFT)
Called prior to modifying a family's store file tracker.
|
default void |
MasterObserver.preModifyTable(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName,
TableDescriptor newDescriptor)
Deprecated.
Since 2.1. Will be removed in 3.0.
|
default TableDescriptor |
MasterObserver.preModifyTable(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName,
TableDescriptor currentDescriptor,
TableDescriptor newDescriptor)
Called prior to modifying a table's properties.
|
default void |
MasterObserver.preModifyTableAction(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName,
TableDescriptor newDescriptor)
Deprecated.
Since 2.1. Will be removed in 3.0.
|
default void |
MasterObserver.preModifyTableAction(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName,
TableDescriptor currentDescriptor,
TableDescriptor newDescriptor)
Called prior to modifying a table's properties.
|
default String |
MasterObserver.preModifyTableStoreFileTracker(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName,
String dstSFT)
Called prior to modifying a table's store file tracker.
|
default void |
MasterObserver.preRequestLock(ObserverContext<MasterCoprocessorEnvironment> ctx,
String namespace,
TableName tableName,
RegionInfo[] regionInfos,
String description)
Called before new LockProcedure is queued.
|
default void |
MasterObserver.preSetTableQuota(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName,
GlobalQuotaSettings quotas)
Called before the quota for the table is stored.
|
default void |
MasterObserver.preSetUserQuota(ObserverContext<MasterCoprocessorEnvironment> ctx,
String userName,
TableName tableName,
GlobalQuotaSettings quotas)
Called before the quota for the user on the specified table is stored.
|
default void |
MasterObserver.preSplitRegion(ObserverContext<MasterCoprocessorEnvironment> c,
TableName tableName,
byte[] splitRow)
Called before the split region procedure is called.
|
default void |
MasterObserver.preSplitRegionAction(ObserverContext<MasterCoprocessorEnvironment> c,
TableName tableName,
byte[] splitRow)
Called before the region is split.
|
default void |
MasterObserver.preTableFlush(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName)
Called before the table memstore is flushed to disk.
|
default void |
MasterObserver.preTruncateTable(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName)
Called before
HMaster truncates a table. |
default void |
MasterObserver.preTruncateTableAction(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName)
Called before
HMaster truncates a table. |
Modifier and Type | Method and Description |
---|---|
default void |
MasterObserver.postGetTableDescriptors(ObserverContext<MasterCoprocessorEnvironment> ctx,
List<TableName> tableNamesList,
List<TableDescriptor> descriptors,
String regex)
Called after a getTableDescriptors request has been processed.
|
default void |
MasterObserver.postMoveServersAndTables(ObserverContext<MasterCoprocessorEnvironment> ctx,
Set<Address> servers,
Set<TableName> tables,
String targetGroup)
Called after servers are moved to target region server group
|
default void |
MasterObserver.postMoveTables(ObserverContext<MasterCoprocessorEnvironment> ctx,
Set<TableName> tables,
String targetGroup)
Called after servers are moved to target region server group
|
default void |
MasterObserver.preGetTableDescriptors(ObserverContext<MasterCoprocessorEnvironment> ctx,
List<TableName> tableNamesList,
List<TableDescriptor> descriptors,
String regex)
Called before a getTableDescriptors request has been processed.
|
default void |
MasterObserver.preMoveServersAndTables(ObserverContext<MasterCoprocessorEnvironment> ctx,
Set<Address> servers,
Set<TableName> tables,
String targetGroup)
Called before servers are moved to target region server group
|
default void |
MasterObserver.preMoveTables(ObserverContext<MasterCoprocessorEnvironment> ctx,
Set<TableName> tables,
String targetGroup)
Called before tables are moved to target region server group
|
Modifier and Type | Method and Description |
---|---|
void |
ExampleMasterObserverWithMetrics.preDisableTable(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName) |
Modifier and Type | Method and Description |
---|---|
protected List<RegionPlan> |
FavoredNodeLoadBalancer.balanceTable(TableName tableName,
Map<ServerName,List<RegionInfo>> loadOfOneTable) |
Modifier and Type | Method and Description |
---|---|
static TableName |
HFileLink.getReferencedTableName(String fileName)
Get the Table name of the referenced link
|
Modifier and Type | Method and Description |
---|---|
static Pair<TableName,String> |
HFileLink.parseBackReferenceName(String name) |
Modifier and Type | Method and Description |
---|---|
static HFileLink |
HFileLink.build(org.apache.hadoop.conf.Configuration conf,
TableName table,
String region,
String family,
String hfile)
Create an HFileLink instance from table/region/family/hfile location
|
static 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,
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,
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,
TableName linkedTable,
String linkedRegion,
String hfileName,
boolean createBackRef)
Create a new HFileLink.
|
static String |
HFileLink.createHFileLinkName(TableName tableName,
String regionName,
String hfileName)
Create a new HFileLink name
|
static org.apache.hadoop.fs.Path |
HFileLink.createPath(TableName table,
String region,
String family,
String hfile)
Create an HFileLink relative path for the table/region/family/hfile location
|
Modifier and Type | Method and Description |
---|---|
private boolean |
HFilePrettyPrinter.mobFileExists(org.apache.hadoop.fs.FileSystem fs,
TableName tn,
String mobFileName,
String family,
Set<String> foundMobFiles,
Set<String> missingMobFiles)
Checks whether the referenced mob file exists.
|
Modifier and Type | Method and Description |
---|---|
void |
HBaseRpcControllerImpl.setPriority(TableName tn) |
void |
DelegatingHBaseRpcController.setPriority(TableName tn) |
void |
HBaseRpcController.setPriority(TableName tn)
Set the priority for this operation.
|
Modifier and Type | Field and Description |
---|---|
private TableName |
TableSplit.m_tableName |
Modifier and Type | Method and Description |
---|---|
TableName |
TableSplit.getTable()
Returns table name
|
Modifier and Type | Method and Description |
---|---|
private static int |
TableMapReduceUtil.getRegionCount(org.apache.hadoop.conf.Configuration conf,
TableName tableName) |
protected void |
TableInputFormatBase.initializeTable(Connection connection,
TableName tableName)
Allows subclasses to initialize the table information.
|
Constructor and Description |
---|
TableSplit(TableName tableName,
byte[] startRow,
byte[] endRow,
String location)
Constructor nnnn
|
Modifier and Type | Field and Description |
---|---|
private TableName |
TableSplit.tableName |
Modifier and Type | Field and Description |
---|---|
private Map<TableName,TableName> |
WALPlayer.WALMapper.tables |
private Map<TableName,TableName> |
WALPlayer.WALMapper.tables |
Modifier and Type | Method and Description |
---|---|
TableName |
TableSplit.getTable()
Returns the table name.
|
Modifier and Type | Method and Description |
---|---|
static Triple<TableName,Scan,org.apache.hadoop.fs.Path> |
ExportUtils.getArgumentsFromCommandLine(org.apache.hadoop.conf.Configuration conf,
String[] args) |
Modifier and Type | Method and Description |
---|---|
static void |
TableInputFormat.configureSplitTable(org.apache.hadoop.mapreduce.Job job,
TableName tableName)
Sets split table in map-reduce job.
|
private static void |
ImportTsv.createTable(Admin admin,
TableName tableName,
String[] columns) |
private static int |
TableMapReduceUtil.getRegionCount(org.apache.hadoop.conf.Configuration conf,
TableName tableName) |
protected void |
TableInputFormatBase.initializeTable(Connection connection,
TableName tableName)
Allows subclasses to initialize the table information.
|
static void |
TableMapReduceUtil.initTableMapperJob(TableName table,
Scan scan,
Class<? extends TableMapper> mapper,
Class<?> outputKeyClass,
Class<?> outputValueClass,
org.apache.hadoop.mapreduce.Job job)
Use this before submitting a TableMap job.
|
Map<LoadIncrementalHFiles.LoadQueueItem,ByteBuffer> |
LoadIncrementalHFiles.run(String dirPath,
Map<byte[],List<org.apache.hadoop.fs.Path>> map,
TableName tableName)
Deprecated.
|
Constructor and Description |
---|
TableSplit(TableName tableName,
byte[] startRow,
byte[] endRow,
String location)
Creates a new instance without a scanner.
|
TableSplit(TableName tableName,
byte[] startRow,
byte[] endRow,
String location,
long length)
Creates a new instance without a scanner.
|
TableSplit(TableName tableName,
Scan scan,
byte[] startRow,
byte[] endRow,
String location)
Creates a new instance while assigning all variables.
|
TableSplit(TableName tableName,
Scan scan,
byte[] startRow,
byte[] endRow,
String location,
long length)
Creates a new instance while assigning all variables.
|
TableSplit(TableName tableName,
Scan scan,
byte[] startRow,
byte[] endRow,
String location,
String encodedRegionName,
long length)
Creates a new instance while assigning all variables.
|
Modifier and Type | Field and Description |
---|---|
private TableName |
AssignmentVerificationReport.tableName |
Modifier and Type | Field and Description |
---|---|
private Set<TableName> |
SnapshotOfRegionAssignmentFromMeta.disabledTables |
private Map<TableName,AtomicInteger> |
HMaster.mobCompactionStates |
private ConcurrentMap<TableName,TableState.State> |
TableStateManager.tableName2State |
private Map<TableName,List<RegionInfo>> |
SnapshotOfRegionAssignmentFromMeta.tableToRegionMap
the table name to region map
|
private Set<TableName> |
RegionPlacementMaintainer.targetTableSet |
private IdReadWriteLock<TableName> |
TableStateManager.tnLock |
Modifier and Type | Method and Description |
---|---|
Map<TableName,Integer> |
RegionPlacementMaintainer.getRegionsMovement(FavoredNodesPlan newPlan)
Return how many regions will move per table since their primary RS will change
|
Set<TableName> |
SnapshotOfRegionAssignmentFromMeta.getTableSet()
Get the table set
|
(package private) Set<TableName> |
TableStateManager.getTablesInStates(TableState.State... states)
Return all tables in given states.
|
Map<TableName,List<RegionInfo>> |
SnapshotOfRegionAssignmentFromMeta.getTableToRegionMap()
Get regions for tables
|
private Map<TableName,List<byte[]>> |
RegionsRecoveryChore.getTableToRegionsByRefCount(Map<ServerName,ServerMetrics> serverMetricsMap) |
List<TableName> |
HMaster.listTableNames(String namespace,
String regex,
boolean includeSysTables)
Returns the list of table names that match the specified request
|
List<TableName> |
MasterServices.listTableNamesByNamespace(String name)
Get list of table names by namespace
|
List<TableName> |
HMaster.listTableNamesByNamespace(String name) |
Modifier and Type | Method and Description |
---|---|
long |
MasterServices.addColumn(TableName tableName,
ColumnFamilyDescriptor column,
long nonceGroup,
long nonce)
Add a new column to an existing table
|
long |
HMaster.addColumn(TableName tableName,
ColumnFamilyDescriptor column,
long nonceGroup,
long nonce) |
private void |
HMaster.checkTableExists(TableName tableName) |
void |
MasterServices.checkTableModifiable(TableName tableName)
Check table is modifiable; i.e.
|
void |
HMaster.checkTableModifiable(TableName tableName) |
long |
MasterServices.deleteColumn(TableName tableName,
byte[] columnName,
long nonceGroup,
long nonce)
Delete a column from an existing table
|
long |
HMaster.deleteColumn(TableName tableName,
byte[] columnName,
long nonceGroup,
long nonce) |
long |
MasterServices.deleteTable(TableName tableName,
long nonceGroup,
long nonce)
Delete a table
|
long |
HMaster.deleteTable(TableName tableName,
long nonceGroup,
long nonce) |
protected void |
TableStateManager.deleteZooKeeper(TableName tableName)
Deprecated.
Since 2.0.0. To be removed in hbase-3.0.0.
|
long |
MasterServices.disableTable(TableName tableName,
long nonceGroup,
long nonce)
Disable an existing table
|
long |
HMaster.disableTable(TableName tableName,
long nonceGroup,
long nonce) |
long |
MasterServices.enableTable(TableName tableName,
long nonceGroup,
long nonce)
Enable an existing table
|
long |
HMaster.enableTable(TableName tableName,
long nonceGroup,
long nonce) |
void |
AssignmentVerificationReport.fillUp(TableName tableName,
SnapshotOfRegionAssignmentFromMeta snapshot,
Map<String,Map<String,Float>> regionLocalityMap) |
void |
AssignmentVerificationReport.fillUpDispersion(TableName tableName,
SnapshotOfRegionAssignmentFromMeta snapshot,
FavoredNodesPlan newPlan)
Use this to project the dispersion scores nnn
|
private void |
RegionPlacementMaintainer.genAssignmentPlan(TableName tableName,
SnapshotOfRegionAssignmentFromMeta assignmentSnapshot,
Map<String,Map<String,Float>> regionLocalityMap,
FavoredNodesPlan plan,
boolean munkresForSecondaryAndTertiary)
Generate the assignment plan for the existing table nnnn * @param
munkresForSecondaryAndTertiary if set on true the assignment plan for the tertiary and
secondary will be generated with Munkres algorithm, otherwise will be generated using
placeSecondaryAndTertiaryRS n
|
CompactionState |
HMaster.getCompactionState(TableName tableName)
Get the compaction state of the table
|
long |
MasterServices.getLastMajorCompactionTimestamp(TableName table) |
long |
HMaster.getLastMajorCompactionTimestamp(TableName table) |
org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.GetRegionInfoResponse.CompactionState |
HMaster.getMobCompactionState(TableName tableName)
Gets the mob file compaction state for a specific table.
|
TableState |
TableStateManager.getTableState(TableName tableName) |
private static boolean |
HMaster.isCatalogTable(TableName tableName) |
boolean |
TableStateManager.isTablePresent(TableName tableName) |
boolean |
TableStateManager.isTableState(TableName tableName,
TableState.State... states) |
protected void |
MirroringTableStateManager.metaStateDeleted(TableName tableName)
Deprecated.
|
protected void |
TableStateManager.metaStateDeleted(TableName tableName) |
protected void |
MirroringTableStateManager.metaStateUpdated(TableName tableName,
TableState.State newState)
Deprecated.
|
protected void |
TableStateManager.metaStateUpdated(TableName tableName,
TableState.State newState) |
long |
MasterServices.modifyColumn(TableName tableName,
ColumnFamilyDescriptor descriptor,
long nonceGroup,
long nonce)
Modify the column descriptor of an existing column in an existing table
|
long |
HMaster.modifyColumn(TableName tableName,
ColumnFamilyDescriptor descriptor,
long nonceGroup,
long nonce) |
long |
MasterServices.modifyColumnStoreFileTracker(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.modifyColumnStoreFileTracker(TableName tableName,
byte[] family,
String dstSFT,
long nonceGroup,
long nonce) |
private long |
HMaster.modifyTable(TableName tableName,
HMaster.TableDescriptorGetter newDescriptorGetter,
long nonceGroup,
long nonce,
boolean shouldCheckDescriptor) |
long |
MasterServices.modifyTable(TableName tableName,
TableDescriptor descriptor,
long nonceGroup,
long nonce)
Modify the descriptor of an existing table
|
long |
HMaster.modifyTable(TableName tableName,
TableDescriptor newDescriptor,
long nonceGroup,
long nonce) |
long |
MasterServices.modifyTableStoreFileTracker(TableName tableName,
String dstSFT,
long nonceGroup,
long nonce)
Modify the store file tracker of an existing table
|
long |
HMaster.modifyTableStoreFileTracker(TableName tableName,
String dstSFT,
long nonceGroup,
long nonce) |
void |
MasterCoprocessorHost.postCompletedDeleteTableAction(TableName tableName,
User user) |
void |
MasterCoprocessorHost.postCompletedDisableTableAction(TableName tableName,
User user) |
void |
MasterCoprocessorHost.postCompletedEnableTableAction(TableName tableName,
User user) |
void |
MasterCoprocessorHost.postCompletedModifyTableAction(TableName tableName,
TableDescriptor oldDescriptor,
TableDescriptor currentDescriptor,
User user) |
void |
MasterCoprocessorHost.postCompletedTruncateTableAction(TableName tableName,
User user) |
void |
MasterCoprocessorHost.postDeleteTable(TableName tableName) |
void |
MasterCoprocessorHost.postDisableTable(TableName tableName) |
void |
MasterCoprocessorHost.postEnableTable(TableName tableName) |
void |
MasterCoprocessorHost.postGetUserPermissions(String userName,
String namespace,
TableName tableName,
byte[] family,
byte[] qualifier) |
void |
MasterCoprocessorHost.postModifyColumnFamilyStoreFileTracker(TableName tableName,
byte[] family,
String dstSFT) |
void |
MasterCoprocessorHost.postModifyTable(TableName tableName,
TableDescriptor oldDescriptor,
TableDescriptor currentDescriptor) |
void |
MasterCoprocessorHost.postModifyTableStoreFileTracker(TableName tableName,
String dstSFT) |
void |
MasterCoprocessorHost.postRequestLock(String namespace,
TableName tableName,
RegionInfo[] regionInfos,
LockType type,
String description) |
void |
MasterCoprocessorHost.postSetTableQuota(TableName table,
GlobalQuotaSettings quotas) |
void |
MasterCoprocessorHost.postSetUserQuota(String user,
TableName table,
GlobalQuotaSettings quotas) |
void |
MasterCoprocessorHost.postTableFlush(TableName tableName) |
void |
MasterCoprocessorHost.postTruncateTable(TableName tableName) |
void |
MasterCoprocessorHost.preDeleteTable(TableName tableName) |
void |
MasterCoprocessorHost.preDeleteTableAction(TableName tableName,
User user) |
void |
MasterCoprocessorHost.preDisableTable(TableName tableName) |
void |
MasterCoprocessorHost.preDisableTableAction(TableName tableName,
User user) |
void |
MasterCoprocessorHost.preEnableTable(TableName tableName) |
void |
MasterCoprocessorHost.preEnableTableAction(TableName tableName,
User user) |
void |
MasterCoprocessorHost.preGetUserPermissions(String userName,
String namespace,
TableName tableName,
byte[] family,
byte[] qualifier) |
String |
MasterCoprocessorHost.preModifyColumnFamilyStoreFileTracker(TableName tableName,
byte[] family,
String dstSFT) |
TableDescriptor |
MasterCoprocessorHost.preModifyTable(TableName tableName,
TableDescriptor currentDescriptor,
TableDescriptor newDescriptor) |
void |
MasterCoprocessorHost.preModifyTableAction(TableName tableName,
TableDescriptor currentDescriptor,
TableDescriptor newDescriptor,
User user) |
String |
MasterCoprocessorHost.preModifyTableStoreFileTracker(TableName tableName,
String dstSFT) |
void |
MasterCoprocessorHost.preRequestLock(String namespace,
TableName tableName,
RegionInfo[] regionInfos,
LockType type,
String description) |
void |
MasterCoprocessorHost.preSetTableQuota(TableName table,
GlobalQuotaSettings quotas) |
void |
MasterCoprocessorHost.preSetUserQuota(String user,
TableName table,
GlobalQuotaSettings quotas) |
void |
MasterCoprocessorHost.preSplitRegion(TableName tableName,
byte[] splitRow)
Invoked just before calling the split region procedure
|
void |
MasterCoprocessorHost.preSplitRegionAction(TableName tableName,
byte[] splitRow,
User user)
Invoked just before a split
|
void |
MasterCoprocessorHost.preTableFlush(TableName tableName) |
void |
MasterCoprocessorHost.preTruncateTable(TableName tableName) |
void |
MasterCoprocessorHost.preTruncateTableAction(TableName tableName,
User user) |
void |
RegionPlacementMaintainer.printDispersionScores(TableName table,
SnapshotOfRegionAssignmentFromMeta snapshot,
int numRegions,
FavoredNodesPlan newPlan,
boolean simplePrint) |
private TableState |
TableStateManager.readMetaState(TableName tableName) |
(package private) long |
HMaster.reopenRegions(TableName tableName,
List<byte[]> regionNames,
long nonceGroup,
long nonce)
Reopen regions provided in the argument
|
void |
HMaster.reportMobCompactionEnd(TableName tableName) |
void |
HMaster.reportMobCompactionStart(TableName tableName) |
void |
TableStateManager.setDeletedTable(TableName tableName) |
void |
TableStateManager.setTableState(TableName tableName,
TableState.State newState)
Set table state to provided.
|
long |
MasterServices.truncateTable(TableName tableName,
boolean preserveSplits,
long nonceGroup,
long nonce)
Truncate a table
|
long |
HMaster.truncateTable(TableName tableName,
boolean preserveSplits,
long nonceGroup,
long nonce) |
private void |
TableStateManager.updateMetaState(TableName tableName,
TableState.State newState) |
Modifier and Type | Method and Description |
---|---|
List<RegionPlan> |
LoadBalancer.balanceCluster(Map<TableName,Map<ServerName,List<RegionInfo>>> loadOfAllTable)
Perform the major balance operation for cluster.
|
void |
RegionPlacementMaintainer.checkDifferencesWithOldPlan(Map<TableName,Integer> movesPerTable,
Map<String,Map<String,Float>> regionLocalityMap,
FavoredNodesPlan newPlan)
Compares two plans and check whether the locality dropped or increased (prints the information
as a string) also prints the baseline locality
|
private List<TableDescriptor> |
HMaster.getTableDescriptors(List<TableDescriptor> htds,
String namespace,
String regex,
List<TableName> tableNameList,
boolean includeSysTables)
Return a list of table table descriptors after applying any provided filter parameters.
|
List<TableDescriptor> |
HMaster.listTableDescriptors(String namespace,
String regex,
List<TableName> tableNameList,
boolean includeSysTables)
Returns the list of table descriptors that match the specified request
|
void |
MasterCoprocessorHost.postGetTableDescriptors(List<TableName> tableNamesList,
List<TableDescriptor> descriptors,
String regex) |
void |
MasterCoprocessorHost.postMoveServersAndTables(Set<Address> servers,
Set<TableName> tables,
String targetGroup) |
void |
MasterCoprocessorHost.postMoveTables(Set<TableName> tables,
String targetGroup) |
void |
MasterCoprocessorHost.preGetTableDescriptors(List<TableName> tableNamesList,
List<TableDescriptor> descriptors,
String regex) |
void |
MasterCoprocessorHost.preMoveServersAndTables(Set<Address> servers,
Set<TableName> tables,
String targetGroup) |
void |
MasterCoprocessorHost.preMoveTables(Set<TableName> tables,
String targetGroup) |
private void |
RegionsRecoveryChore.prepareTableToReopenRegionsMap(Map<TableName,List<byte[]>> tableToReopenRegionsMap,
byte[] regionName,
int regionStoreRefCount) |
default void |
LoadBalancer.updateBalancerLoadInfo(Map<TableName,Map<ServerName,List<RegionInfo>>> loadOfAllTable)
In some scenarios, Balancer needs to update internal status or information according to the
current tables load
|
Constructor and Description |
---|
SnapshotOfRegionAssignmentFromMeta(Connection connection,
Set<TableName> disabledTables,
boolean excludeOfflinedSplitParents) |
Modifier and Type | Method and Description |
---|---|
TableName |
RegionStateNode.getTable() |
TableName |
GCMergedRegionsProcedure.getTableName()
Deprecated.
|
TableName |
MergeTableRegionsProcedure.getTableName() |
TableName |
GCMultipleMergedRegionsProcedure.getTableName() |
TableName |
RegionRemoteProcedureBase.getTableName() |
TableName |
MoveRegionProcedure.getTableName()
Deprecated.
|
TableName |
RegionTransitionProcedure.getTableName()
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
Map<TableName,Map<ServerName,List<RegionInfo>>> |
RegionStates.getAssignmentsForBalancer(TableStateManager tableStateManager,
List<ServerName> onlineServers)
This is an EXPENSIVE clone.
|
Modifier and Type | Method and Description |
---|---|
TransitRegionStateProcedure[] |
AssignmentManager.createUnassignProceduresForClosingExcessRegionReplicas(TableName tableName,
int newReplicaCount)
Called by ModifyTableProcedures to unassign all the excess region replicas for a table.
|
TransitRegionStateProcedure[] |
AssignmentManager.createUnassignProceduresForDisabling(TableName tableName)
Called by DisableTableProcedure to unassign all the regions for a table.
|
void |
AssignmentManager.deleteTable(TableName tableName)
Delete the region states.
|
Map<RegionState.State,List<RegionInfo>> |
RegionStates.getRegionByStateOfTable(TableName tableName) |
List<RegionInfo> |
RegionStates.getRegionsOfTable(TableName table)
Returns Return online regions of table; does not include OFFLINE or SPLITTING regions.
|
private List<RegionInfo> |
RegionStates.getRegionsOfTable(TableName table,
Predicate<RegionStateNode> filter)
Returns Return the regions of the table and filter them.
|
List<RegionInfo> |
RegionStates.getRegionsOfTableForDeleting(TableName table)
Get the regions for deleting a table.
|
List<RegionInfo> |
RegionStates.getRegionsOfTableForEnabling(TableName table)
Get the regions for enabling a table.
|
List<HRegionLocation> |
RegionStates.getRegionsOfTableForReopen(TableName tableName)
Get the regions to be reopened when modifying a table.
|
private Stream<RegionStateNode> |
AssignmentManager.getRegionStateNodes(TableName tableName,
boolean excludeOfflinedSplitParents) |
RegionStatesCount |
AssignmentManager.getRegionStatesCount(TableName tableName)
Provide regions state count for given table.
|
Pair<Integer,Integer> |
AssignmentManager.getReopenStatus(TableName tableName)
Used by the client (via master) to identify if all regions have the schema updates
|
private Scan |
RegionStateStore.getScanForUpdateRegionReplicas(TableName tableName) |
private TableDescriptor |
RegionStateStore.getTableDescriptor(TableName tableName) |
List<RegionInfo> |
AssignmentManager.getTableRegions(TableName tableName,
boolean excludeOfflinedSplitParents) |
List<Pair<RegionInfo,ServerName>> |
AssignmentManager.getTableRegionsAndLocations(TableName tableName,
boolean excludeOfflinedSplitParents) |
(package private) ArrayList<RegionInfo> |
RegionStates.getTableRegionsInfo(TableName tableName) |
(package private) List<RegionStateNode> |
RegionStates.getTableRegionStateNodes(TableName tableName) |
(package private) ArrayList<RegionState> |
RegionStates.getTableRegionStates(TableName tableName) |
private boolean |
RegionStateStore.hasGlobalReplicationScope(TableName tableName) |
boolean |
RegionStates.hasTableRegionStates(TableName tableName) |
private boolean |
AssignmentManager.isTableDisabled(TableName tableName) |
private boolean |
RegionStates.isTableDisabled(TableStateManager tableStateManager,
TableName tableName) |
private boolean |
AssignmentManager.isTableEnabled(TableName tableName) |
void |
RegionStateStore.removeRegionReplicas(TableName tableName,
int oldReplicaCount,
int newReplicaCount) |
Modifier and Type | Method and Description |
---|---|
protected List<RegionPlan> |
StochasticLoadBalancer.balanceTable(TableName tableName,
Map<ServerName,List<RegionInfo>> loadOfOneTable)
Given the cluster state this will try and approach an optimal balance.
|
protected abstract List<RegionPlan> |
BaseLoadBalancer.balanceTable(TableName tableName,
Map<ServerName,List<RegionInfo>> loadOfOneTable)
Perform the major balance operation for table, all sub classes should override this method.
|
protected List<RegionPlan> |
SimpleLoadBalancer.balanceTable(TableName tableName,
Map<ServerName,List<RegionInfo>> loadOfOneTable)
Generate a global load balancing plan according to the specified map of server information to
the most loaded regions of each server.
|
protected List<RegionPlan> |
FavoredStochasticBalancer.balanceTable(TableName tableName,
Map<ServerName,List<RegionInfo>> loadOfOneTable) |
protected TableDescriptor |
RegionLocationFinder.getTableDescriptor(TableName tableName)
return TableDescriptor for a given tableName
|
(package private) boolean |
StochasticLoadBalancer.needsBalance(TableName tableName,
BalancerClusterState cluster) |
private void |
StochasticLoadBalancer.updateBalancerTableLoadInfo(TableName tableName,
Map<ServerName,List<RegionInfo>> loadOfOneTable) |
private void |
StochasticLoadBalancer.updateStochasticCosts(TableName tableName,
double overall,
double[] subCosts)
update costs to JMX
|
Modifier and Type | Method and Description |
---|---|
List<RegionPlan> |
BaseLoadBalancer.balanceCluster(Map<TableName,Map<ServerName,List<RegionInfo>>> loadOfAllTable)
Perform the major balance operation for cluster, will invoke
BaseLoadBalancer.balanceTable(TableName, Map) to do actual balance. |
List<RegionPlan> |
MaintenanceLoadBalancer.balanceCluster(Map<TableName,Map<ServerName,List<RegionInfo>>> loadOfAllTable) |
protected void |
BaseLoadBalancer.preBalanceCluster(Map<TableName,Map<ServerName,List<RegionInfo>>> loadOfAllTable)
Called before actually executing balanceCluster.
|
protected void |
SimpleLoadBalancer.preBalanceCluster(Map<TableName,Map<ServerName,List<RegionInfo>>> loadOfAllTable) |
(package private) void |
SimpleLoadBalancer.setClusterLoad(Map<TableName,Map<ServerName,List<RegionInfo>>> clusterLoad)
Pass RegionStates and allow balancer to set the current cluster load.
|
protected Map<ServerName,List<RegionInfo>> |
BaseLoadBalancer.toEnsumbleTableLoad(Map<TableName,Map<ServerName,List<RegionInfo>>> LoadOfAllTable) |
void |
StochasticLoadBalancer.updateBalancerLoadInfo(Map<TableName,Map<ServerName,List<RegionInfo>>> loadOfAllTable) |
Modifier and Type | Field and Description |
---|---|
private TableName |
MetaBrowser.scanTable |
private TableName |
RegionVisualizer.RegionDetails.tableName |
Modifier and Type | Method and Description |
---|---|
TableName |
MetaBrowser.getScanTable() |
TableName |
RegionVisualizer.RegionDetails.getTableName() |
private static TableName |
MetaBrowser.resolveScanTable(javax.servlet.http.HttpServletRequest request) |
Modifier and Type | Method and Description |
---|---|
private static Filter |
MetaBrowser.buildTableFilter(TableName tableName) |
Constructor and Description |
---|
RegionDetails(ServerName serverName,
TableName tableName,
RegionMetrics regionMetrics) |
Modifier and Type | Method and Description |
---|---|
private static RegionInfo |
MetaFixer.buildRegionInfo(TableName tn,
byte[] start,
byte[] end) |
private TableDescriptor |
CatalogJanitor.getDescriptor(TableName tableName) |
Modifier and Type | Field and Description |
---|---|
private TableName |
LockManager.MasterLock.tableName |
private TableName |
LockProcedure.tableName |
Modifier and Type | Method and Description |
---|---|
TableName |
LockProcedure.getTableName() |
Modifier and Type | Method and Description |
---|---|
LockManager.MasterLock |
LockManager.createMasterLock(TableName tableName,
LockType type,
String description) |
long |
LockManager.RemoteLocks.requestTableLock(TableName tableName,
LockType type,
String description,
NonceKey nonceKey) |
Constructor and Description |
---|
LockProcedure(org.apache.hadoop.conf.Configuration conf,
TableName tableName,
LockType type,
String description,
CountDownLatch lockAcquireLatch)
Constructor for table lock.
|
MasterLock(TableName tableName,
LockType type,
String description) |
Modifier and Type | Field and Description |
---|---|
private TableName |
SimpleRegionNormalizer.NormalizeContext.tableName |
Modifier and Type | Field and Description |
---|---|
private RegionNormalizerWorkQueue<TableName> |
RegionNormalizerManager.workQueue |
private RegionNormalizerWorkQueue<TableName> |
RegionNormalizerWorker.workQueue |
Modifier and Type | Method and Description |
---|---|
TableName |
SimpleRegionNormalizer.NormalizeContext.getTableName() |
Modifier and Type | Method and Description |
---|---|
private List<NormalizationPlan> |
RegionNormalizerWorker.calculatePlans(TableName tableName) |
Modifier and Type | Method and Description |
---|---|
boolean |
RegionNormalizerManager.normalizeRegions(List<TableName> tables,
boolean isHighPriority)
Submit tables for normalization.
|
Constructor and Description |
---|
RegionNormalizerManager(RegionNormalizerTracker regionNormalizerTracker,
RegionNormalizerChore regionNormalizerChore,
RegionNormalizerWorkQueue<TableName> workQueue,
RegionNormalizerWorker worker) |
RegionNormalizerWorker(org.apache.hadoop.conf.Configuration configuration,
MasterServices masterServices,
RegionNormalizer regionNormalizer,
RegionNormalizerWorkQueue<TableName> workQueue) |
Modifier and Type | Field and Description |
---|---|
private TableName |
TruncateTableProcedure.tableName |
private TableName |
ModifyTableDescriptorProcedure.tableName |
private TableName |
DeleteTableProcedure.tableName |
private TableName |
EnableTableProcedure.tableName |
private TableName |
DisableTableProcedure.tableName |
private TableName |
ReopenTableRegionsProcedure.tableName |
Modifier and Type | Field and Description |
---|---|
private FairQueue<TableName> |
MasterProcedureScheduler.metaRunQueue |
private Map<TableName,LockAndQueue> |
SchemaLocking.tableLocks |
private FairQueue<TableName> |
MasterProcedureScheduler.tableRunQueue |
Modifier and Type | Method and Description |
---|---|
TableName |
TruncateTableProcedure.getTableName() |
TableName |
CreateTableProcedure.getTableName() |
TableName |
InitMetaProcedure.getTableName() |
TableName |
ModifyTableDescriptorProcedure.getTableName() |
TableName |
DeleteTableProcedure.getTableName() |
TableName |
CloneSnapshotProcedure.getTableName() |
TableName |
AbstractStateMachineNamespaceProcedure.getTableName() |
TableName |
AbstractStateMachineRegionProcedure.getTableName() |
TableName |
ModifyTableProcedure.getTableName() |
abstract TableName |
AbstractStateMachineTableProcedure.getTableName() |
TableName |
EnableTableProcedure.getTableName() |
TableName |
DisableTableProcedure.getTableName() |
TableName |
TableProcedureInterface.getTableName()
Returns the name of the table the procedure is operating on
|
TableName |
RestoreSnapshotProcedure.getTableName() |
TableName |
ReopenTableRegionsProcedure.getTableName() |
private static TableName |
MasterProcedureScheduler.getTableName(Procedure<?> proc) |
Modifier and Type | Method and Description |
---|---|
private static void |
DeleteTableProcedure.cleanRegionsInMeta(MasterProcedureEnv env,
TableName tableName)
There may be items for this table still up in hbase:meta in the case where the info:regioninfo
column was empty because of some write error.
|
List<RegionInfo> |
CreateTableProcedure.CreateHdfsRegions.createHdfsRegions(MasterProcedureEnv env,
org.apache.hadoop.fs.Path tableRootDir,
TableName tableName,
List<RegionInfo> newRegions) |
protected static void |
DeleteTableProcedure.deleteAssignmentState(MasterProcedureEnv env,
TableName tableName) |
static void |
MasterDDLOperationHelper.deleteColumnFamilyFromFileSystem(MasterProcedureEnv env,
TableName tableName,
List<RegionInfo> regionInfoList,
byte[] familyName,
boolean hasMob)
Remove the column family from the file system
|
protected static void |
DeleteTableProcedure.deleteFromFs(MasterProcedureEnv env,
TableName tableName,
List<RegionInfo> regions,
boolean archive) |
protected static void |
DeleteTableProcedure.deleteFromMeta(MasterProcedureEnv env,
TableName tableName,
List<RegionInfo> regions) |
protected static void |
DeleteTableProcedure.deleteTableDescriptorCache(MasterProcedureEnv env,
TableName tableName) |
protected static void |
DeleteTableProcedure.deleteTableStates(MasterProcedureEnv env,
TableName tableName) |
(package private) LockAndQueue |
SchemaLocking.getTableLock(TableName tableName) |
static int |
MasterProcedureUtil.getTablePriority(TableName tableName)
Return the priority for the given table.
|
private TableQueue |
MasterProcedureScheduler.getTableQueue(TableName tableName) |
(package private) boolean |
MasterProcedureScheduler.markTableAsDeleted(TableName table,
Procedure<?> procedure)
Tries to remove the queue and the table-lock of the specified table.
|
(package private) LockAndQueue |
SchemaLocking.removeTableLock(TableName tableName) |
private void |
MasterProcedureScheduler.removeTableQueue(TableName tableName) |
protected static void |
CreateTableProcedure.setEnabledState(MasterProcedureEnv env,
TableName tableName) |
protected static void |
CreateTableProcedure.setEnablingState(MasterProcedureEnv env,
TableName tableName) |
protected static void |
DisableTableProcedure.setTableStateToDisabled(MasterProcedureEnv env,
TableName tableName)
Mark table state to Disabled
|
private static void |
DisableTableProcedure.setTableStateToDisabling(MasterProcedureEnv env,
TableName tableName)
Mark table state to Disabling
|
protected static void |
EnableTableProcedure.setTableStateToEnabled(MasterProcedureEnv env,
TableName tableName)
Mark table state to Enabled
|
protected static void |
EnableTableProcedure.setTableStateToEnabling(MasterProcedureEnv env,
TableName tableName)
Mark table state to Enabling
|
boolean |
MasterProcedureScheduler.waitRegions(Procedure<?> procedure,
TableName table,
RegionInfo... regionInfos)
Suspend the procedure if the specified set of regions are already locked.
|
boolean |
MasterProcedureScheduler.waitTableExclusiveLock(Procedure<?> procedure,
TableName table)
Suspend the procedure if the specified table is already locked.
|
private TableQueue |
MasterProcedureScheduler.waitTableQueueSharedLock(Procedure<?> procedure,
TableName table) |
boolean |
MasterProcedureScheduler.waitTableSharedLock(Procedure<?> procedure,
TableName table)
Suspend the procedure if the specified table is already locked.
|
void |
MasterProcedureScheduler.wakeRegions(Procedure<?> procedure,
TableName table,
RegionInfo... regionInfos)
Wake the procedures waiting for the specified regions
|
void |
MasterProcedureScheduler.wakeTableExclusiveLock(Procedure<?> procedure,
TableName table)
Wake the procedures waiting for the specified table
|
void |
MasterProcedureScheduler.wakeTableSharedLock(Procedure<?> procedure,
TableName table)
Wake the procedures waiting for the specified table
|
Modifier and Type | Field and Description |
---|---|
static TableName |
MasterRegionFactory.TABLE_NAME |
Modifier and Type | Method and Description |
---|---|
List<String> |
ReplicationPeerManager.getSerialPeerIdsBelongsTo(TableName tableName) |
private boolean |
ModifyPeerProcedure.needReopen(TableStateManager tsm,
TableName tn) |
private boolean |
ModifyPeerProcedure.needSetLastPushedSequenceId(TableStateManager tsm,
TableName tn) |
protected void |
ModifyPeerProcedure.setLastPushedSequenceIdForTable(MasterProcedureEnv env,
TableName tableName,
Map<String,Long> lastSeqIds) |
Modifier and Type | Method and Description |
---|---|
private void |
ReplicationPeerManager.checkNamespacesAndTableCfsConfigConflict(Set<String> namespaces,
Map<TableName,? extends Collection<String>> tableCfs)
Set a namespace in the peer config means that all tables in this namespace will be replicated
to the peer cluster.
|
Modifier and Type | Field and Description |
---|---|
protected TableName |
TakeSnapshotHandler.snapshotTable |
private TableName |
MasterSnapshotVerifier.tableName |
Modifier and Type | Field and Description |
---|---|
private Map<TableName,Long> |
SnapshotManager.restoreTableToProcIdMap |
private Map<TableName,SnapshotSentinel> |
SnapshotManager.snapshotHandlers |
Modifier and Type | Method and Description |
---|---|
private long |
SnapshotManager.cloneSnapshot(org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotDescription reqSnapshot,
TableName tableName,
org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotDescription snapshot,
TableDescriptor snapshotTableDesc,
NonceKey nonceKey,
boolean restoreAcl,
String customSFT)
Clone the specified snapshot.
|
private boolean |
SnapshotManager.isRestoringTable(TableName tableName)
Verify if the restore of the specified table is in progress.
|
boolean |
SnapshotManager.isTakingSnapshot(TableName tableName)
Check to see if the specified table has a snapshot in progress.
|
private long |
SnapshotManager.restoreSnapshot(org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotDescription reqSnapshot,
TableName tableName,
org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotDescription snapshot,
TableDescriptor snapshotTableDesc,
NonceKey nonceKey,
boolean restoreAcl)
Restore the specified snapshot.
|
void |
SnapshotManager.setSnapshotHandlerForTesting(TableName tableName,
SnapshotSentinel handler)
Set the handler for the current snapshot
|
Modifier and Type | Method and Description |
---|---|
private void |
SnapshotManager.cleanupSentinels(Map<TableName,SnapshotSentinel> sentinels)
Remove the sentinels that are marked as finished and the completion time has exceeded the
removal timeout.
|
private SnapshotSentinel |
SnapshotManager.removeSentinelIfFinished(Map<TableName,SnapshotSentinel> sentinels,
org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotDescription snapshot)
Return the handler if it is currently live and has the same snapshot target name.
|
Modifier and Type | Field and Description |
---|---|
private static ConcurrentMap<TableName,String> |
ManualMobMaintHFileCleaner.MOB_REGIONS |
(package private) static ThreadLocal<org.apache.hbase.thirdparty.com.google.common.collect.SetMultimap<TableName,String>> |
DefaultMobStoreCompactor.mobRefSet |
Modifier and Type | Method and Description |
---|---|
static org.apache.hbase.thirdparty.com.google.common.collect.ImmutableSetMultimap.Builder<TableName,String> |
MobUtils.deserializeMobFileRefs(byte[] bytes)
Deserialize the set of referenced mob hfiles from store file metadata.
|
static Optional<TableName> |
MobUtils.getTableName(Cell cell)
Get the table name from when this cell was written into a mob hfile as a TableName.
|
Modifier and Type | Method and Description |
---|---|
void |
RSMobFileCleanerChore.archiveMobFiles(org.apache.hadoop.conf.Configuration conf,
TableName tableName,
byte[] family,
List<org.apache.hadoop.fs.Path> storeFiles)
Archives the mob files.
|
void |
MobFileCleanerChore.archiveMobFiles(org.apache.hadoop.conf.Configuration conf,
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,
TableName tableName,
ColumnFamilyDescriptor columnDescriptor,
CacheConfig cacheConfig,
long current)
Cleans the expired mob files.
|
void |
MobFileCleanerChore.cleanupObsoleteMobFiles(org.apache.hadoop.conf.Configuration conf,
TableName table)
Performs housekeeping file cleaning (called by MOB Cleaner chore)
|
static org.apache.hadoop.fs.Path |
MobUtils.getMobFamilyPath(org.apache.hadoop.conf.Configuration conf,
TableName tableName,
String familyName)
Gets the family dir of the mob files.
|
static RegionInfo |
MobUtils.getMobRegionInfo(TableName tableName)
Gets the RegionInfo of the mob files.
|
static org.apache.hadoop.fs.Path |
MobUtils.getMobRegionPath(org.apache.hadoop.conf.Configuration conf,
TableName tableName)
Gets the region dir of the mob files.
|
static org.apache.hadoop.fs.Path |
MobUtils.getMobRegionPath(org.apache.hadoop.fs.Path rootDir,
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,
TableName tableName)
Gets the table dir of the mob files under the qualified HBase root dir.
|
static boolean |
MobUtils.isMobRegionName(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,
TableName tableName,
org.apache.hadoop.fs.Path tableDir,
byte[] family,
Collection<HStoreFile> storeFiles)
Archives the mob files.
|
private void |
MobFileCompactionChore.startCompaction(Admin admin,
TableName table,
RegionInfo region,
byte[] cf) |
Modifier and Type | Method and Description |
---|---|
private void |
DefaultMobStoreCompactor.calculateMobLengthMap(org.apache.hbase.thirdparty.com.google.common.collect.SetMultimap<TableName,String> mobRefs) |
static byte[] |
MobUtils.serializeMobFileRefs(org.apache.hbase.thirdparty.com.google.common.collect.SetMultimap<TableName,String> mobRefSet)
Serialize a set of referenced mob hfiles
|
Modifier and Type | Field and Description |
---|---|
(package private) TableName |
MobRefReporter.MobRefReducer.table |
Modifier and Type | Field and Description |
---|---|
private Map<TableName,AtomicInteger> |
NamespaceTableAndRegionInfo.tableAndRegionInfo |
Modifier and Type | Method and Description |
---|---|
(package private) Set<TableName> |
NamespaceTableAndRegionInfo.getTables()
Gets the set of table names belonging to namespace.
|
Modifier and Type | Method and Description |
---|---|
private void |
NamespaceStateManager.addTable(TableName tableName,
int regionCount) |
(package private) void |
NamespaceTableAndRegionInfo.addTable(TableName tableName,
int regionCount) |
(package private) boolean |
NamespaceStateManager.checkAndUpdateNamespaceRegionCount(TableName name,
byte[] regionName,
int incr)
Check if adding a region violates namespace quota, if not update namespace cache.
|
(package private) void |
NamespaceStateManager.checkAndUpdateNamespaceRegionCount(TableName name,
int incr)
Check and update region count for an existing table.
|
(package private) void |
NamespaceStateManager.checkAndUpdateNamespaceTableCount(TableName table,
int numRegions) |
void |
NamespaceAuditor.checkQuotaToCreateTable(TableName tName,
int regions)
Check quota to create table.
|
void |
NamespaceAuditor.checkQuotaToUpdateRegion(TableName tName,
int regions)
Check and update region count quota for an existing table.
|
private void |
NamespaceAuditor.checkTableTypeAndThrowException(TableName name) |
(package private) boolean |
NamespaceTableAndRegionInfo.containsTable(TableName tableName) |
(package private) int |
NamespaceTableAndRegionInfo.decrementRegionCountForTable(TableName tableName,
int count) |
(package private) int |
NamespaceTableAndRegionInfo.getRegionCountOfTable(TableName tableName) |
int |
NamespaceAuditor.getRegionCountOfTable(TableName tName)
Get region count for table
|
(package private) int |
NamespaceTableAndRegionInfo.incRegionCountForTable(TableName tableName,
int count) |
void |
NamespaceAuditor.removeFromNamespaceUsage(TableName tableName) |
(package private) void |
NamespaceStateManager.removeTable(TableName tableName) |
(package private) void |
NamespaceTableAndRegionInfo.removeTable(TableName tableName) |
Modifier and Type | Field and Description |
---|---|
private Map<TableName,Procedure> |
MasterFlushTableProcedureManager.procMap |
Modifier and Type | Field and Description |
---|---|
static TableName |
QuotaTableUtil.QUOTA_TABLE_NAME
System table for quotas
|
private TableName |
QuotaSettings.tableName |
(package private) TableName |
FileArchiverNotifierFactoryImpl.CacheKey.tn |
private TableName |
FileArchiverNotifierImpl.tn |
Modifier and Type | Method and Description |
---|---|
protected static TableName |
QuotaTableUtil.getTableFromRowKey(byte[] key) |
TableName |
QuotaSettings.getTableName() |
Modifier and Type | Method and Description |
---|---|
(package private) Map<TableName,SpaceViolationPolicyEnforcement> |
RegionServerSpaceQuotaManager.copyActiveEnforcements()
Returns the collection of tables which have quota violation policies enforced on this
RegionServer.
|
Map<TableName,SpaceQuotaSnapshot> |
RegionServerSpaceQuotaManager.copyQuotaSnapshots()
Copies the last
SpaceQuotaSnapshot s that were recorded. |
Map<TableName,SpaceQuotaSnapshot> |
SpaceQuotaRefresherChore.fetchSnapshotsFromQuotaTable()
Reads all quota snapshots from the quota table.
|
static Map<TableName,QuotaState> |
QuotaUtil.fetchTableQuotas(Connection connection,
List<Get> gets,
Map<TableName,Double> tableMachineFactors) |
Set<TableName> |
QuotaObserverChore.TablesWithQuotas.filterInsufficientlyReportedTables(QuotaSnapshotStore<TableName> tableStore)
Filters out all tables for which the Master currently doesn't have enough region space
reports received from RegionServers yet.
|
Map<TableName,SpaceQuotaSnapshot> |
RegionServerSpaceQuotaManager.getActivePoliciesAsMap()
Converts a map of table to
SpaceViolationPolicyEnforcement s into
SpaceViolationPolicy s. |
(package private) Map<TableName,SpaceViolationPolicyEnforcement> |
ActivePolicyEnforcement.getLocallyCachedPolicies()
Returns an unmodifiable version of the policy enforcements that were cached because they are
not in violation of their quota.
|
Set<TableName> |
QuotaObserverChore.TablesWithQuotas.getNamespaceQuotaTables()
Returns an unmodifiable view of all tables in namespaces that have namespace quotas.
|
Map<TableName,SpaceViolationPolicyEnforcement> |
ActivePolicyEnforcement.getPolicies()
Returns an unmodifiable version of the active
SpaceViolationPolicyEnforcement s. |
static Map<TableName,SpaceQuotaSnapshot> |
QuotaTableUtil.getSnapshots(Connection conn)
Fetches all
SpaceQuotaSnapshot objects from the hbase:quota table. |
(package private) org.apache.hbase.thirdparty.com.google.common.collect.Multimap<TableName,String> |
SnapshotQuotaObserverChore.getSnapshotsFromTables(Admin admin,
Set<TableName> tablesToFetchSnapshotsFrom)
Computes a mapping of originating
TableName to snapshots, when the TableName
exists in the provided Set . |
(package private) org.apache.hbase.thirdparty.com.google.common.collect.Multimap<TableName,String> |
SnapshotQuotaObserverChore.getSnapshotsToComputeSize()
Fetches each table with a quota (table or namespace quota), and then fetch the name of each
snapshot which was created from that table.
|
(package private) Map<TableName,QuotaState> |
QuotaCache.getTableQuotaCache() |
Map<TableName,SpaceQuotaSnapshot> |
QuotaObserverChore.getTableQuotaSnapshots()
Returns an unmodifiable view over the current
SpaceQuotaSnapshot objects for each HBase
table with a quota defined. |
Set<TableName> |
QuotaObserverChore.TablesWithQuotas.getTableQuotaTables()
Returns an unmodifiable view of all tables with table quotas.
|
org.apache.hbase.thirdparty.com.google.common.collect.Multimap<String,TableName> |
QuotaObserverChore.TablesWithQuotas.getTablesByNamespace()
Returns a view of all tables that reside in a namespace with a namespace quota, grouped by
the namespace itself.
|
static org.apache.hbase.thirdparty.com.google.common.collect.Multimap<TableName,String> |
QuotaTableUtil.getTableSnapshots(Connection conn)
Returns a multimap for all existing table snapshot entries.
|
(package private) QuotaSnapshotStore<TableName> |
QuotaObserverChore.getTableSnapshotStore() |
Modifier and Type | Method and Description |
---|---|
void |
QuotaObserverChore.TablesWithQuotas.addNamespaceQuotaTable(TableName tn)
Adds a table with a namespace quota.
|
static void |
QuotaUtil.addTableQuota(Connection connection,
TableName table,
org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Quotas data) |
void |
QuotaObserverChore.TablesWithQuotas.addTableQuotaTable(TableName tn)
Adds a table with a table quota.
|
static void |
QuotaUtil.addUserQuota(Connection connection,
String user,
TableName table,
org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Quotas data) |
boolean |
RegionServerSpaceQuotaManager.areCompactionsDisabled(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(TableName tn,
Collection<Map.Entry<String,Long>> archivedFiles)
Builds the protobuf message to inform the Master of files being archived.
|
void |
MasterQuotaManager.checkAndUpdateNamespaceRegionQuota(TableName tName,
int regions) |
void |
MasterQuotaManager.checkNamespaceTableAndRegionQuota(TableName tName,
int regions) |
SpaceViolationPolicyEnforcement |
SpaceViolationPolicyEnforcementFactory.create(RegionServerServices rss,
TableName tableName,
SpaceQuotaSnapshot snapshot)
Constructs the appropriate
SpaceViolationPolicyEnforcement for tables that are in
violation of their space quota. |
(package private) static Put |
QuotaTableUtil.createPutForSnapshotSize(TableName tableName,
String snapshot,
long size)
|
(package private) static Put |
QuotaTableUtil.createPutForSpaceSnapshot(TableName tableName,
SpaceQuotaSnapshot snapshot)
|
(package private) static Scan |
QuotaTableUtil.createScanForSpaceSnapshotSizes(TableName table) |
SpaceViolationPolicyEnforcement |
SpaceViolationPolicyEnforcementFactory.createWithoutViolation(RegionServerServices rss,
TableName tableName,
SpaceQuotaSnapshot snapshot)
Creates the "default"
SpaceViolationPolicyEnforcement for a table that isn't in
violation. |
static void |
QuotaUtil.deleteTableQuota(Connection connection,
TableName table) |
static void |
QuotaUtil.deleteUserQuota(Connection connection,
String& |