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.
|
Modifier and Type | Method and Description |
---|---|
TableName |
HRegionInfo.getTable()
Deprecated.
Get current table name of the region
|
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
|
static TableName |
TableName.valueOf(byte[] fullName) |
static TableName |
TableName.valueOf(byte[] namespace,
byte[] qualifier) |
static TableName |
TableName.valueOf(ByteBuffer namespace,
ByteBuffer qualifier) |
static TableName |
TableName.valueOf(String name) |
static TableName |
TableName.valueOf(String namespaceAsString,
String qualifierAsString) |
Modifier and Type | Method and Description |
---|---|
static Map<TableName,TableState> |
MetaTableAccessor.getTableStates(Connection conn)
Fetch table states from META table
|
Modifier and Type | Method and Description |
---|---|
static NavigableMap<RegionInfo,ServerName> |
MetaTableAccessor.allTableRegions(Connection connection,
TableName tableName)
Deprecated.
use
MetaTableAccessor.getTableRegionsAndLocations(org.apache.hadoop.hbase.client.Connection, org.apache.hadoop.hbase.TableName) , region can have multiple locations |
int |
TableName.compareTo(TableName tableName)
For performance reasons, the ordering is not lexicographic.
|
static byte[] |
HRegionInfo.createRegionName(TableName tableName,
byte[] startKey,
byte[] id,
boolean newFormat)
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
|
TableDescriptor |
TableDescriptors.get(TableName tableName) |
BufferedMutator |
SharedConnection.getBufferedMutator(TableName tableName) |
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. |
static int |
MetaTableAccessor.getRegionCount(org.apache.hadoop.conf.Configuration c,
TableName tableName)
Count regions in
hbase:meta for passed table. |
static int |
MetaTableAccessor.getRegionCount(Connection connection,
TableName tableName)
Count regions in
hbase:meta for passed table. |
RegionLocator |
SharedConnection.getRegionLocator(TableName tableName) |
static MetaTableAccessor.ReplicationBarrierResult |
MetaTableAccessor.getReplicationBarrierResult(Connection conn,
TableName tableName,
byte[] row,
byte[] encodedRegionName) |
static Scan |
MetaTableAccessor.getScanForTableName(Connection connection,
TableName tableName)
Deprecated.
|
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 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.
|
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.
|
static byte[] |
MetaTableAccessor.getTableStartRowForMeta(TableName tableName,
MetaTableAccessor.QueryType 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
|
static byte[] |
MetaTableAccessor.getTableStopRowForMeta(TableName tableName,
MetaTableAccessor.QueryType type) |
static boolean |
TableName.isMetaTableName(TableName tn) |
TableDescriptor |
TableDescriptors.remove(TableName tablename) |
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.
|
static void |
MetaTableAccessor.scanMeta(Connection connection,
TableName table,
MetaTableAccessor.QueryType type,
int maxRows,
MetaTableAccessor.Visitor visitor) |
static void |
MetaTableAccessor.scanMetaForTableRegions(Connection connection,
MetaTableAccessor.Visitor visitor,
TableName tableName) |
static CompletableFuture<Boolean> |
AsyncMetaTableAccessor.tableExists(AsyncTable<?> metaTable,
TableName tableName) |
static boolean |
MetaTableAccessor.tableExists(Connection connection,
TableName tableName)
Checks if the specified table exists.
|
static void |
MetaTableAccessor.updateTableState(Connection conn,
TableName tableName,
TableState.State actual)
Updates state in META
|
Modifier and Type | Method and Description |
---|---|
static CompletableFuture<List<HRegionLocation>> |
AsyncMetaTableAccessor.getTableHRegionLocations(AsyncTable<AdvancedScanResultConsumer> metaTable,
Optional<TableName> tableName)
Used to get all region locations for the specific table.
|
Constructor and Description |
---|
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 t) |
TableNotDisabledException(TableName tableName) |
TableNotEnabledException(TableName tableName) |
TableNotFoundException(TableName tableName) |
TableVisitorBase(TableName tableName) |
Modifier and Type | Field and Description |
---|---|
protected TableName |
RpcRetryingCallerWithReadReplicas.tableName |
protected TableName |
ClientScanner.tableName |
protected TableName |
RegionAdminServiceCallable.tableName |
Modifier and Type | Method and Description |
---|---|
TableName |
BufferedMutatorImpl.getName() |
TableName |
HRegionLocator.getName() |
TableName |
HTable.getName() |
TableName |
AsyncBufferedMutator.getName()
Gets the fully qualified table name instance of the table that this
AsyncBufferedMutator writes to. |
TableName |
AsyncTable.getName()
Gets the fully qualified table name instance of this table.
|
TableName |
AsyncTableRegionLocator.getName()
Gets the fully qualified table name instance of the table whose region we want to locate.
|
TableName |
RegionLocator.getName()
Gets the fully qualified table name instance of this table.
|
TableName |
BufferedMutator.getName()
Gets the fully qualified table name instance of the table that this BufferedMutator writes to.
|
TableName |
Table.getName()
Gets the fully qualified table name instance of this table.
|
protected TableName |
ClientScanner.getTable() |
TableName |
RegionInfo.getTable() |
static TableName |
RegionInfo.getTable(byte[] regionName)
Gets the table name from the specified region name.
|
protected TableName |
HBaseAdmin.TableFuture.getTableName() |
TableName |
RegionServerCallable.getTableName() |
TableName |
TableState.getTableName()
Table name for state
|
TableName |
AsyncProcessTask.getTableName() |
TableName |
SnapshotDescription.getTableName() |
TableName |
TableDescriptor.getTableName()
Get the name of the table
|
TableName |
TableDescriptorBuilder.ModifyableTableDescriptor.getTableName()
Get the name of the table
|
TableName |
BufferedMutatorParams.getTableName() |
TableName[] |
HBaseAdmin.listTableNames() |
TableName[] |
Admin.listTableNames()
List all of the names of userspace tables.
|
TableName[] |
HBaseAdmin.listTableNames(Pattern pattern) |
TableName[] |
Admin.listTableNames(Pattern pattern)
List all of the names of userspace tables.
|
TableName[] |
HBaseAdmin.listTableNames(Pattern pattern,
boolean includeSysTables) |
TableName[] |
Admin.listTableNames(Pattern pattern,
boolean includeSysTables)
List all of the names of userspace tables.
|
TableName[] |
HBaseAdmin.listTableNames(String regex) |
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,
boolean includeSysTables) |
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.listTableNamesByNamespace(String name) |
TableName[] |
Admin.listTableNamesByNamespace(String name)
Get list of table names by namespace.
|
Modifier and Type | Method and Description |
---|---|
protected Optional<TableName> |
AsyncRpcRetryingCaller.getTableName() |
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>> |
AsyncAdmin.listTableNames(Pattern pattern,
boolean includeSysTables)
List all of the names of userspace tables.
|
CompletableFuture<List<TableName>> |
AsyncAdmin.listTableNamesByNamespace(String name)
Get list of table names by namespace.
|
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) . |
void |
HBaseAdmin.addColumnFamily(TableName tableName,
ColumnFamilyDescriptor columnFamily) |
CompletableFuture<Void> |
AsyncAdmin.addColumnFamily(TableName tableName,
ColumnFamilyDescriptor columnFamily)
Add a column family to an existing table.
|
void |
Admin.addColumnFamily(TableName tableName,
ColumnFamilyDescriptor columnFamily)
Add a column family to an existing table.
|
Future<Void> |
HBaseAdmin.addColumnFamilyAsync(TableName tableName,
ColumnFamilyDescriptor columnFamily) |
Future<Void> |
Admin.addColumnFamilyAsync(TableName tableName,
ColumnFamilyDescriptor columnFamily)
Add a column family to an existing table.
|
void |
MetaCache.cacheLocation(TableName tableName,
RegionLocations locations)
Put a newly discovered HRegionLocation into the cache.
|
void |
ClusterConnection.cacheLocation(TableName tableName,
RegionLocations location) |
void |
MetaCache.cacheLocation(TableName tableName,
ServerName source,
HRegionLocation location)
Put a newly discovered HRegionLocation into the cache.
|
CacheEvictionStats |
HBaseAdmin.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.
|
CacheEvictionStats |
Admin.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.
|
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 |
HBaseAdmin.cloneSnapshot(byte[] snapshotName,
TableName tableName) |
void |
Admin.cloneSnapshot(byte[] snapshotName,
TableName tableName)
Create a new table by cloning the snapshot content.
|
void |
HBaseAdmin.cloneSnapshot(String snapshotName,
TableName tableName) |
CompletableFuture<Void> |
AsyncAdmin.cloneSnapshot(String snapshotName,
TableName tableName)
Create a new table by cloning the snapshot content.
|
void |
Admin.cloneSnapshot(String snapshotName,
TableName tableName)
Create a new table by cloning the snapshot content.
|
void |
HBaseAdmin.cloneSnapshot(String snapshotName,
TableName tableName,
boolean restoreAcl) |
void |
Admin.cloneSnapshot(String snapshotName,
TableName tableName,
boolean restoreAcl)
Create a new table by cloning the snapshot content.
|
Future<Void> |
HBaseAdmin.cloneSnapshotAsync(String snapshotName,
TableName tableName) |
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.
|
void |
HBaseAdmin.cloneTableSchema(TableName tableName,
TableName newTableName,
boolean preserveSplits) |
CompletableFuture<Void> |
AsyncAdmin.cloneTableSchema(TableName tableName,
TableName newTableName,
boolean preserveSplits)
Create a new table by cloning the existent table schema.
|
void |
Admin.cloneTableSchema(TableName tableName,
TableName newTableName,
boolean preserveSplits)
Create a new table by cloning the existent table schema.
|
void |
HBaseAdmin.compact(TableName tableName)
Compact a table.
|
default CompletableFuture<Void> |
AsyncAdmin.compact(TableName tableName)
Compact a table.
|
void |
Admin.compact(TableName tableName)
Compact a table.
|
void |
HBaseAdmin.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 |
Admin.compact(TableName tableName,
byte[] columnFamily)
Compact a column family within a table.
|
void |
HBaseAdmin.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.
|
void |
Admin.compact(TableName tableName,
byte[] columnFamily,
CompactType compactType)
Compact a column family within a table.
|
void |
HBaseAdmin.compact(TableName tableName,
CompactType compactType)
Compact a table.
|
CompletableFuture<Void> |
AsyncAdmin.compact(TableName tableName,
CompactType compactType)
Compact a table.
|
void |
Admin.compact(TableName tableName,
CompactType compactType)
Compact a table.
|
static TableState |
TableState.convert(TableName tableName,
HBaseProtos.TableState tableState)
Covert from PB version of TableState
|
static TableDescriptor |
TableDescriptorBuilder.copy(TableName name,
TableDescriptor desc) |
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.
|
void |
HBaseAdmin.deleteColumn(TableName tableName,
byte[] columnFamily)
Deprecated.
Since 2.0. Will be removed in 3.0. Use
HBaseAdmin.deleteColumnFamily(TableName, byte[]) instead. |
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.deleteColumnFamily(TableName tableName,
byte[] columnFamily) |
CompletableFuture<Void> |
AsyncAdmin.deleteColumnFamily(TableName tableName,
byte[] columnFamily)
Delete a column family from a table.
|
void |
Admin.deleteColumnFamily(TableName tableName,
byte[] columnFamily)
Delete a column family from a table.
|
Future<Void> |
HBaseAdmin.deleteColumnFamilyAsync(TableName tableName,
byte[] columnFamily) |
Future<Void> |
Admin.deleteColumnFamilyAsync(TableName tableName,
byte[] columnFamily)
Delete a column family from a table.
|
void |
HBaseAdmin.deleteTable(TableName tableName) |
CompletableFuture<Void> |
AsyncAdmin.deleteTable(TableName tableName)
Deletes a table.
|
void |
Admin.deleteTable(TableName tableName)
Deletes a table.
|
Future<Void> |
HBaseAdmin.deleteTableAsync(TableName tableName) |
Future<Void> |
Admin.deleteTableAsync(TableName tableName)
Deletes the table but does not block and wait for it to be completely removed.
|
void |
HBaseAdmin.disableTable(TableName tableName) |
CompletableFuture<Void> |
AsyncAdmin.disableTable(TableName tableName)
Disable a table.
|
void |
Admin.disableTable(TableName tableName)
Disable table and wait on completion.
|
Future<Void> |
HBaseAdmin.disableTableAsync(TableName tableName) |
Future<Void> |
Admin.disableTableAsync(TableName tableName)
Disable the table but does not block and wait for it to be completely disabled.
|
void |
HBaseAdmin.disableTableReplication(TableName tableName) |
CompletableFuture<Void> |
AsyncAdmin.disableTableReplication(TableName tableName)
Disable a table's replication switch.
|
void |
Admin.disableTableReplication(TableName tableName)
Disable a table's replication switch.
|
static <R> void |
HTable.doBatchWithCallback(List<? extends Row> actions,
Object[] results,
Batch.Callback<R> callback,
ClusterConnection connection,
ExecutorService pool,
TableName tableName) |
void |
HBaseAdmin.enableTable(TableName tableName) |
CompletableFuture<Void> |
AsyncAdmin.enableTable(TableName tableName)
Enable a table.
|
void |
Admin.enableTable(TableName tableName)
Enable a table.
|
Future<Void> |
HBaseAdmin.enableTableAsync(TableName tableName) |
Future<Void> |
Admin.enableTableAsync(TableName tableName)
Enable the table but does not block and wait for it to be completely enabled.
|
void |
HBaseAdmin.enableTableReplication(TableName tableName) |
CompletableFuture<Void> |
AsyncAdmin.enableTableReplication(TableName tableName)
Enable a table's replication switch.
|
void |
Admin.enableTableReplication(TableName tableName)
Enable a table's replication switch.
|
void |
HBaseAdmin.flush(TableName tableName) |
CompletableFuture<Void> |
AsyncAdmin.flush(TableName tableName)
Flush a table.
|
void |
Admin.flush(TableName tableName)
Flush a table.
|
Pair<Integer,Integer> |
HBaseAdmin.getAlterStatus(TableName tableName) |
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.
|
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 |
AsyncConnection.getBufferedMutatorBuilder(TableName tableName)
Returns an
AsyncBufferedMutatorBuilder for creating AsyncBufferedMutator . |
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.
|
CompactionState |
HBaseAdmin.getCompactionState(TableName tableName) |
default CompletableFuture<CompactionState> |
AsyncAdmin.getCompactionState(TableName tableName)
Get the current compaction state of a table.
|
CompactionState |
Admin.getCompactionState(TableName tableName)
Get the current compaction state of a table.
|
CompactionState |
HBaseAdmin.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.
|
CompactionState |
Admin.getCompactionState(TableName tableName,
CompactType compactType)
Get the current compaction state of a table.
|
TableDescriptor |
HBaseAdmin.getDescriptor(TableName tableName) |
CompletableFuture<TableDescriptor> |
AsyncAdmin.getDescriptor(TableName tableName)
Method for getting the tableDescriptor
|
TableDescriptor |
Admin.getDescriptor(TableName tableName)
Get a table descriptor.
|
long |
HBaseAdmin.getLastMajorCompactionTimestamp(TableName tableName) |
CompletableFuture<Optional<Long>> |
AsyncAdmin.getLastMajorCompactionTimestamp(TableName tableName)
Get the timestamp of the last major compaction for the passed table.
|
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.
|
int |
MetaCache.getNumberOfCachedRegionLocations(TableName tableName)
Return the number of cached region for a table.
|
HRegionLocation |
ClusterConnection.getRegionLocation(TableName tableName,
byte[] row,
boolean reload)
Find region location hosting passed row
|
static RegionLocations |
RegionAdminServiceCallable.getRegionLocations(ClusterConnection connection,
TableName tableName,
byte[] row,
boolean useCache,
int replicaId) |
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> |
HBaseAdmin.getRegionMetrics(ServerName serverName,
TableName tableName) |
CompletableFuture<List<RegionMetrics>> |
AsyncAdmin.getRegionMetrics(ServerName serverName,
TableName tableName)
Get a list of
RegionMetrics of all regions hosted on a region seerver for a table. |
List<RegionMetrics> |
Admin.getRegionMetrics(ServerName serverName,
TableName tableName)
Get
RegionMetrics of all regions hosted on a regionserver for a table. |
List<RegionInfo> |
HBaseAdmin.getRegions(TableName tableName) |
CompletableFuture<List<RegionInfo>> |
AsyncAdmin.getRegions(TableName tableName)
Get the regions of a given table.
|
List<RegionInfo> |
Admin.getRegions(TableName tableName)
Get the regions of a given table.
|
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> |
AsyncConnection.getTableBuilder(TableName tableName)
Returns an
AsyncTableBuilder for creating AsyncTable . |
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 . |
HTableDescriptor |
HBaseAdmin.getTableDescriptor(TableName tableName) |
HTableDescriptor |
Admin.getTableDescriptor(TableName tableName)
Deprecated.
since 2.0 version and will be removed in 3.0 version.
Use
Admin.getDescriptor(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) . |
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) . |
TableState |
ClusterConnection.getTableState(TableName tableName)
Retrieve TableState, represent current table state.
|
boolean |
MetaCache.isRegionCached(TableName tableName,
byte[] row)
Check the region cache to see whether a region is cached yet or not.
|
boolean |
HBaseAdmin.isTableAvailable(TableName tableName) |
CompletableFuture<Boolean> |
AsyncAdmin.isTableAvailable(TableName tableName) |
boolean |
Admin.isTableAvailable(TableName tableName) |
boolean |
HBaseAdmin.isTableAvailable(TableName tableName,
byte[][] splitKeys) |
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.
|
CompletableFuture<Boolean> |
AsyncAdmin.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) |
boolean |
HBaseAdmin.isTableDisabled(TableName tableName) |
boolean |
ClusterConnection.isTableDisabled(TableName tableName) |
CompletableFuture<Boolean> |
AsyncAdmin.isTableDisabled(TableName tableName) |
boolean |
Admin.isTableDisabled(TableName tableName) |
boolean |
HBaseAdmin.isTableEnabled(TableName tableName) |
boolean |
ClusterConnection.isTableEnabled(TableName tableName)
A table that isTableEnabled == false and isTableDisabled == false
is possible.
|
CompletableFuture<Boolean> |
AsyncAdmin.isTableEnabled(TableName tableName) |
boolean |
Admin.isTableEnabled(TableName tableName) |
HRegionLocation |
ClusterConnection.locateRegion(TableName tableName,
byte[] row)
Find the location of the region of tableName that row
lives in.
|
RegionLocations |
ClusterConnection.locateRegion(TableName tableName,
byte[] row,
boolean useCache,
boolean retry) |
RegionLocations |
ClusterConnection.locateRegion(TableName tableName,
byte[] row,
boolean useCache,
boolean retry,
int replicaId) |
List<HRegionLocation> |
ClusterConnection.locateRegions(TableName tableName)
Gets the locations of all regions in the specified table, tableName.
|
List<HRegionLocation> |
ClusterConnection.locateRegions(TableName tableName,
boolean useCache,
boolean offlined)
Gets the locations of all regions in the specified table, tableName.
|
void |
HBaseAdmin.majorCompact(TableName tableName) |
default CompletableFuture<Void> |
AsyncAdmin.majorCompact(TableName tableName)
Major compact a table.
|
void |
Admin.majorCompact(TableName tableName)
Major compact a table.
|
void |
HBaseAdmin.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 |
Admin.majorCompact(TableName tableName,
byte[] columnFamily)
Major compact a column family within a table.
|
void |
HBaseAdmin.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.
|
void |
Admin.majorCompact(TableName tableName,
byte[] columnFamily,
CompactType compactType)
Major compact a column family within a table.
|
void |
HBaseAdmin.majorCompact(TableName tableName,
CompactType compactType)
Major compact a table.
|
CompletableFuture<Void> |
AsyncAdmin.majorCompact(TableName tableName,
CompactType compactType)
Major compact a table.
|
void |
Admin.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) . |
void |
HBaseAdmin.modifyColumnFamily(TableName tableName,
ColumnFamilyDescriptor columnFamily) |
CompletableFuture<Void> |
AsyncAdmin.modifyColumnFamily(TableName tableName,
ColumnFamilyDescriptor columnFamily)
Modify an existing column family on a table.
|
void |
Admin.modifyColumnFamily(TableName tableName,
ColumnFamilyDescriptor columnFamily)
Modify an existing column family on a table.
|
Future<Void> |
HBaseAdmin.modifyColumnFamilyAsync(TableName tableName,
ColumnFamilyDescriptor columnFamily) |
Future<Void> |
Admin.modifyColumnFamilyAsync(TableName tableName,
ColumnFamilyDescriptor columnFamily)
Modify an existing column family on a table.
|
void |
HBaseAdmin.modifyTable(TableName tableName,
TableDescriptor td) |
void |
Admin.modifyTable(TableName tableName,
TableDescriptor td)
Deprecated.
since 2.0 version and will be removed in 3.0 version.
use
Admin.modifyTable(TableDescriptor) |
Future<Void> |
HBaseAdmin.modifyTableAsync(TableName tableName,
TableDescriptor td) |
Future<Void> |
Admin.modifyTableAsync(TableName tableName,
TableDescriptor td)
Deprecated.
since 2.0 version and will be removed in 3.0 version.
use
Admin.modifyTableAsync(TableDescriptor) |
static RegionInfoBuilder |
RegionInfoBuilder.newBuilder(TableName tableName) |
static TableDescriptorBuilder |
TableDescriptorBuilder.newBuilder(TableName name) |
static TableState |
TableState.parseFrom(TableName tableName,
byte[] bytes) |
List<Put> |
HTableMultiplexer.put(TableName tableName,
List<Put> puts)
The puts request will be buffered by their corresponding buffer queue.
|
boolean |
HTableMultiplexer.put(TableName tableName,
Put put)
The put request will be buffered by its corresponding buffer queue.
|
boolean |
HTableMultiplexer.put(TableName tableName,
Put put,
int maxAttempts)
The put request will be buffered by its corresponding buffer queue.
|
HRegionLocation |
ClusterConnection.relocateRegion(TableName tableName,
byte[] row)
Find the location of the region of tableName that row
lives in, ignoring any value that might be in the cache.
|
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.
|
AsyncProcessTask.Builder<T> |
AsyncProcessTask.Builder.setTableName(TableName tableName) |
void |
HBaseAdmin.snapshot(byte[] snapshotName,
TableName tableName) |
void |
Admin.snapshot(byte[] snapshotName,
TableName tableName)
Create a timestamp consistent snapshot for the given table.
|
void |
HBaseAdmin.snapshot(String snapshotName,
TableName tableName) |
default CompletableFuture<Void> |
AsyncAdmin.snapshot(String snapshotName,
TableName tableName)
Take a snapshot for the given table.
|
void |
Admin.snapshot(String snapshotName,
TableName tableName)
Take a snapshot for the given table.
|
void |
HBaseAdmin.snapshot(String snapshotName,
TableName tableName,
SnapshotType type) |
default CompletableFuture<Void> |
AsyncAdmin.snapshot(String snapshotName,
TableName tableName,
SnapshotType type)
Create typed snapshot of the table.
|
void |
Admin.snapshot(String snapshotName,
TableName tableName,
SnapshotType type)
Create typed snapshot of the table.
|
void |
HBaseAdmin.split(TableName tableName) |
CompletableFuture<Void> |
AsyncAdmin.split(TableName tableName)
Split a table.
|
void |
Admin.split(TableName tableName)
+ Split a table.
|
void |
HBaseAdmin.split(TableName tableName,
byte[] splitPoint) |
CompletableFuture<Void> |
AsyncAdmin.split(TableName tableName,
byte[] splitPoint)
Split a table.
|
void |
Admin.split(TableName tableName,
byte[] splitPoint)
Split a table.
|
boolean |
HBaseAdmin.tableExists(TableName tableName) |
CompletableFuture<Boolean> |
AsyncAdmin.tableExists(TableName tableName) |
boolean |
Admin.tableExists(TableName tableName) |
void |
HBaseAdmin.truncateTable(TableName tableName,
boolean preserveSplits) |
CompletableFuture<Void> |
AsyncAdmin.truncateTable(TableName tableName,
boolean preserveSplits)
Truncate a table.
|
void |
Admin.truncateTable(TableName tableName,
boolean preserveSplits)
Truncate a table.
|
Future<Void> |
HBaseAdmin.truncateTableAsync(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.
|
void |
ClusterConnection.updateCachedLocations(TableName tableName,
byte[] regionName,
byte[] rowkey,
Object exception,
ServerName source)
Update the location cache.
|
Modifier and Type | Method and Description |
---|---|
void |
HBaseAdmin.appendReplicationPeerTableCFs(String id,
Map<TableName,List<String>> tableCfs) |
CompletableFuture<Void> |
AsyncAdmin.appendReplicationPeerTableCFs(String peerId,
Map<TableName,List<String>> tableCfs)
Append the replicable table-cf config of the specified peer
|
void |
Admin.appendReplicationPeerTableCFs(String id,
Map<TableName,List<String>> tableCfs)
Append the replicable table column family config from the specified peer.
|
HTableDescriptor[] |
HBaseAdmin.getTableDescriptorsByTableName(List<TableName> tableNames) |
HTableDescriptor[] |
Admin.getTableDescriptorsByTableName(List<TableName> tableNames)
Deprecated.
since 2.0 version and will be removed in 3.0 version.
use
Admin.listTableDescriptors(List) |
List<TableDescriptor> |
HBaseAdmin.listTableDescriptors(List<TableName> tableNames) |
List<TableDescriptor> |
Admin.listTableDescriptors(List<TableName> tableNames)
Get tableDescriptors.
|
void |
HBaseAdmin.removeReplicationPeerTableCFs(String id,
Map<TableName,List<String>> tableCfs) |
CompletableFuture<Void> |
AsyncAdmin.removeReplicationPeerTableCFs(String peerId,
Map<TableName,List<String>> tableCfs)
Remove some table-cfs from config of the specified peer
|
void |
Admin.removeReplicationPeerTableCFs(String id,
Map<TableName,List<String>> tableCfs)
Remove some table-cfs from config of the specified peer.
|
Constructor and Description |
---|
BufferedMutatorParams(TableName tableName) |
ClientAsyncPrefetchScanner(org.apache.hadoop.conf.Configuration configuration,
Scan scan,
TableName name,
ClusterConnection connection,
RpcRetryingCallerFactory rpcCallerFactory,
RpcControllerFactory rpcControllerFactory,
ExecutorService pool,
int replicaCallTimeoutMicroSecondScan) |
ClientScanner(org.apache.hadoop.conf.Configuration conf,
Scan scan,
TableName tableName,
ClusterConnection connection,
RpcRetryingCallerFactory rpcFactory,
RpcControllerFactory controllerFactory,
ExecutorService pool,
int primaryOperationTimeout)
Create a new ClientScanner for the specified table Note that the passed
Scan 's start
row maybe changed changed. |
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 replicaCallTimeoutMicroSecondScan) |
FlushRegionCallable(ClusterConnection connection,
RpcControllerFactory rpcControllerFactory,
TableName tableName,
byte[] regionName,
byte[] regionStartKey,
boolean writeFlushWalMarker) |
HRegionLocator(TableName tableName,
ClusterConnection connection) |
ModifyableTableDescriptor(TableName name)
Construct a table descriptor specifying a TableName object
|
ModifyableTableDescriptor(TableName name,
TableDescriptor desc)
Deprecated.
|
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) |
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) |
ReversedClientScanner(org.apache.hadoop.conf.Configuration conf,
Scan scan,
TableName tableName,
ClusterConnection connection,
RpcRetryingCallerFactory rpcFactory,
RpcControllerFactory controllerFactory,
ExecutorService pool,
int primaryOperationTimeout)
Create a new ReversibleClientScanner for the specified table Note that the passed
Scan 's start row maybe changed. |
ReversedScannerCallable(ClusterConnection connection,
TableName tableName,
Scan scan,
ScanMetrics scanMetrics,
RpcControllerFactory rpcFactory) |
ReversedScannerCallable(ClusterConnection connection,
TableName tableName,
Scan scan,
ScanMetrics scanMetrics,
RpcControllerFactory rpcFactory,
int replicaId) |
RpcRetryingCallerWithReadReplicas(RpcControllerFactory rpcControllerFactory,
TableName tableName,
ClusterConnection cConnection,
Get get,
ExecutorService pool,
int retries,
int operationTimeout,
int rpcTimeout,
int timeBeforeReplicas) |
ScannerCallable(ClusterConnection connection,
TableName tableName,
Scan scan,
ScanMetrics scanMetrics,
RpcControllerFactory rpcControllerFactory) |
ScannerCallable(ClusterConnection connection,
TableName tableName,
Scan scan,
ScanMetrics scanMetrics,
RpcControllerFactory rpcControllerFactory,
int id) |
SnapshotDescription(String name,
TableName table) |
SnapshotDescription(String name,
TableName table,
SnapshotType type) |
SnapshotDescription(String name,
TableName table,
SnapshotType type,
String owner) |
SnapshotDescription(String name,
TableName table,
SnapshotType type,
String owner,
long creationTime,
int version) |
TableFuture(HBaseAdmin admin,
TableName tableName,
Long procId) |
TableState(TableName tableName,
TableState.State state)
Create instance of TableState.
|
Modifier and Type | Method and Description |
---|---|
<R,S,P extends com.google.protobuf.Message,Q extends com.google.protobuf.Message,T extends com.google.protobuf.Message> |
AggregationClient.avg(TableName tableName,
ColumnInterpreter<R,S,P,Q,T> ci,
Scan scan)
This is the client side interface/handle for calling the average method for
a given cf-cq combination.
|
<R,S,P extends com.google.protobuf.Message,Q extends com.google.protobuf.Message,T extends com.google.protobuf.Message> |
AggregationClient.max(TableName tableName,
ColumnInterpreter<R,S,P,Q,T> ci,
Scan scan)
It gives the maximum value of a column for a given column family for the
given range.
|
<R,S,P extends com.google.protobuf.Message,Q extends com.google.protobuf.Message,T extends com.google.protobuf.Message> |
AggregationClient.median(TableName tableName,
ColumnInterpreter<R,S,P,Q,T> ci,
Scan scan)
This is the client side interface/handler for calling the median method for a
given cf-cq combination.
|
<R,S,P extends com.google.protobuf.Message,Q extends com.google.protobuf.Message,T extends com.google.protobuf.Message> |
AggregationClient.min(TableName tableName,
ColumnInterpreter<R,S,P,Q,T> ci,
Scan scan)
It gives the minimum value of a column for a given column family for the
given range.
|
<R,S,P extends com.google.protobuf.Message,Q extends com.google.protobuf.Message,T extends com.google.protobuf.Message> |
AggregationClient.rowCount(TableName tableName,
ColumnInterpreter<R,S,P,Q,T> ci,
Scan scan)
It gives the row count, by summing up the individual results obtained from
regions.
|
<R,S,P extends com.google.protobuf.Message,Q extends com.google.protobuf.Message,T extends com.google.protobuf.Message> |
AggregationClient.std(TableName tableName,
ColumnInterpreter<R,S,P,Q,T> ci,
Scan scan)
This is the client side interface/handle for calling the std method for a
given cf-cq combination.
|
<R,S,P extends com.google.protobuf.Message,Q extends com.google.protobuf.Message,T extends com.google.protobuf.Message> |
AggregationClient.sum(TableName tableName,
ColumnInterpreter<R,S,P,Q,T> ci,
Scan scan)
It sums up the value returned from various regions.
|
Modifier and Type | Method and Description |
---|---|
void |
RefreshHFilesClient.refreshHFiles(TableName tableName) |
Constructor and Description |
---|
ReadExampleCallable(Connection connection,
TableName tableName) |
SingleWriteExampleCallable(Connection connection,
TableName tableName) |
WriteExampleCallable(Connection connection,
TableName tableName) |
Modifier and Type | Method and Description |
---|---|
static LockServiceProtos.LockRequest |
LockServiceClient.buildLockRequest(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 | Method and Description |
---|---|
TableName |
TableCFs.getTable() |
Modifier and Type | Method and Description |
---|---|
static Map<TableName,List<String>> |
ReplicationPeerConfigUtil.convert2Map(ReplicationProtos.TableCF[] tableCFs)
Convert tableCFs Object to Map.
|
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 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) |
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 | 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.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.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.preLockHeartbeat(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tn,
String description)
Called before heartbeat to a lock.
|
default void |
MasterObserver.preModifyTable(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName,
TableDescriptor newDescriptor)
Deprecated.
Since 2.1. Will be removed in 3.0.
|
default void |
MasterObserver.preModifyTable(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName,
TableDescriptor currentDescriptor,
TableDescriptor newDescriptor)
Called prior to modifying a table's properties.
|
default void |
MasterObserver.preModifyTableAction(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName,
TableDescriptor newDescriptor)
Deprecated.
Since 2.1. Will be removed in 3.0.
|
default void |
MasterObserver.preModifyTableAction(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName,
TableDescriptor currentDescriptor,
TableDescriptor newDescriptor)
Called prior to modifying a table's properties.
|
default void |
MasterObserver.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. |
static Map<byte[],Export.Response> |
Export.run(org.apache.hadoop.conf.Configuration conf,
TableName tableName,
Scan scan,
org.apache.hadoop.fs.Path dir) |
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 |
---|---|
List<RegionPlan> |
FavoredNodeLoadBalancer.balanceCluster(TableName tableName,
Map<ServerName,List<RegionInfo>> clusterState) |
Modifier and Type | Method and Description |
---|---|
static TableName |
HFileLink.getReferencedTableName(String fileName)
Get the Table name of the referenced link
|
Modifier and Type | Method and Description |
---|---|
static HFileLink |
HFileLink.build(org.apache.hadoop.conf.Configuration conf,
TableName table,
String region,
String family,
String hfile)
Create an HFileLink instance from table/region/family/hfile location
|
static boolean |
HFileLink.create(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.fs.Path dstFamilyPath,
TableName linkedTable,
String linkedRegion,
String hfileName)
Create a new HFileLink
|
static boolean |
HFileLink.create(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.fs.Path dstFamilyPath,
TableName linkedTable,
String linkedRegion,
String hfileName,
boolean createBackRef)
Create a new HFileLink
|
static String |
HFileLink.createHFileLinkName(TableName tableName,
String regionName,
String hfileName)
Create a new HFileLink name
|
static org.apache.hadoop.fs.Path |
HFileLink.createPath(TableName table,
String region,
String family,
String hfile)
Create an HFileLink relative path for the table/region/family/hfile location
|
Modifier and Type | Method and Description |
---|---|
void |
HBaseRpcControllerImpl.setPriority(TableName tn) |
void |
HBaseRpcController.setPriority(TableName tn) |
void |
DelegatingHBaseRpcController.setPriority(TableName tn) |
Modifier and Type | Method and Description |
---|---|
TableName |
TableSplit.getTable() |
Modifier and Type | Method and Description |
---|---|
protected void |
TableInputFormatBase.initializeTable(Connection connection,
TableName tableName)
Allows subclasses to initialize the table information.
|
Constructor and Description |
---|
TableSplit(TableName tableName,
byte[] startRow,
byte[] endRow,
String location)
Constructor
|
Modifier and Type | Method and Description |
---|---|
TableName |
TableSplit.getTable()
Returns the table name.
|
Modifier and Type | Method and Description |
---|---|
static 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.
|
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 | 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
|
Set<TableName> |
TableStateManager.getTablesInStates(TableState.State... states)
Return all tables in given states.
|
Map<TableName,List<RegionInfo>> |
SnapshotOfRegionAssignmentFromMeta.getTableToRegionMap()
Get regions for tables
|
List<TableName> |
HMaster.listTableNames(String namespace,
String regex,
boolean includeSysTables)
Returns the list of table names that match the specified request
|
List<TableName> |
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) |
List<RegionPlan> |
LoadBalancer.balanceCluster(TableName tableName,
Map<ServerName,List<RegionInfo>> clusterState)
Perform the major balance operation
|
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
|
long |
MasterServices.getLastMajorCompactionTimestamp(TableName table) |
long |
HMaster.getLastMajorCompactionTimestamp(TableName table) |
AdminProtos.GetRegionInfoResponse.CompactionState |
HMaster.getMobCompactionState(TableName tableName)
Gets the mob file compaction state for a specific table.
|
TableState |
TableStateManager.getTableState(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.modifyTable(TableName tableName,
TableDescriptor descriptor,
long nonceGroup,
long nonce)
Modify the descriptor of an existing table
|
long |
HMaster.modifyTable(TableName tableName,
TableDescriptor newDescriptor,
long nonceGroup,
long nonce) |
void |
MasterCoprocessorHost.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.postModifyTable(TableName tableName,
TableDescriptor oldDescriptor,
TableDescriptor currentDescriptor) |
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.preModifyTable(TableName tableName,
TableDescriptor currentDescriptor,
TableDescriptor newDescriptor) |
void |
MasterCoprocessorHost.preModifyTableAction(TableName tableName,
TableDescriptor currentDescriptor,
TableDescriptor newDescriptor,
User user) |
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) |
void |
HMaster.reportMobCompactionEnd(TableName tableName) |
void |
HMaster.reportMobCompactionStart(TableName tableName) |
void |
MasterMobCompactionThread.requestMobCompaction(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
TableName tableName,
List<ColumnFamilyDescriptor> columns,
boolean allFiles)
Requests mob compaction
|
void |
HMaster.requestMobCompaction(TableName tableName,
List<ColumnFamilyDescriptor> columns,
boolean allFiles)
Requests mob compaction.
|
void |
TableStateManager.setDeletedTable(TableName tableName) |
void |
TableStateManager.setTableState(TableName tableName,
TableState.State newState)
Set table state to provided.
|
TableState |
TableStateManager.setTableStateIfInStates(TableName tableName,
TableState.State newState,
TableState.State... states)
Set table state to provided but only if table in specified states Caller should lock table on
write.
|
boolean |
TableStateManager.setTableStateIfNotInStates(TableName tableName,
TableState.State newState,
TableState.State... states)
Set table state to provided but only if table not in specified states Caller should lock table
on write.
|
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) |
Modifier and Type | Method and Description |
---|---|
void |
RegionPlacementMaintainer.checkDifferencesWithOldPlan(Map<TableName,Integer> movesPerTable,
Map<String,Map<String,Float>> regionLocalityMap,
FavoredNodesPlan newPlan)
Compares two plans and check whether the locality dropped or increased
(prints the information as a string) also prints the baseline locality
|
List<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) |
void |
LoadBalancer.setClusterLoad(Map<TableName,Map<ServerName,List<RegionInfo>>> ClusterLoad)
Pass RegionStates and allow balancer to set the current cluster load.
|
Constructor and Description |
---|
SnapshotOfRegionAssignmentFromMeta(Connection connection,
Set<TableName> disabledTables,
boolean excludeOfflinedSplitParents) |
Modifier and Type | Method and Description |
---|---|
TableName |
RegionStates.RegionStateNode.getTable() |
TableName |
GCMergedRegionsProcedure.getTableName() |
TableName |
MergeTableRegionsProcedure.getTableName() |
TableName |
MoveRegionProcedure.getTableName() |
TableName |
RegionTransitionProcedure.getTableName() |
Modifier and Type | Method and Description |
---|---|
Map<TableName,Map<ServerName,List<RegionInfo>>> |
RegionStates.getAssignmentsByTable() |
Map<TableName,Map<ServerName,List<RegionInfo>>> |
RegionStates.getAssignmentsByTable(boolean forceByCluster)
This is an EXPENSIVE clone.
|
Modifier and Type | Method and Description |
---|---|
UnassignProcedure[] |
AssignmentManager.createUnassignProcedures(TableName tableName) |
void |
AssignmentManager.deleteTable(TableName tableName)
Delete the region states.
|
Map<RegionState.State,List<RegionInfo>> |
RegionStates.getRegionByStateOfTable(TableName tableName) |
List<RegionInfo> |
RegionStates.getRegionsOfTable(TableName table) |
List<RegionInfo> |
RegionStates.getRegionsOfTable(TableName table,
boolean offline) |
List<HRegionLocation> |
RegionStates.getRegionsOfTableForReopen(TableName tableName)
Get the regions to be reopened when modifying a table.
|
Pair<Integer,Integer> |
AssignmentManager.getReopenStatus(TableName tableName)
Used by the client (via master) to identify if all regions have the schema updates
|
boolean |
RegionStates.hasTableRegionStates(TableName tableName) |
boolean |
AssignmentManager.isTableDisabled(TableName tableName) |
boolean |
AssignmentManager.isTableEnabled(TableName tableName) |
Modifier and Type | Method and Description |
---|---|
List<RegionPlan> |
SimpleLoadBalancer.balanceCluster(TableName tableName,
Map<ServerName,List<RegionInfo>> clusterState) |
List<RegionPlan> |
StochasticLoadBalancer.balanceCluster(TableName tableName,
Map<ServerName,List<RegionInfo>> clusterState) |
Modifier and Type | Method and Description |
---|---|
void |
SimpleLoadBalancer.setClusterLoad(Map<TableName,Map<ServerName,List<RegionInfo>>> clusterLoad) |
void |
BaseLoadBalancer.setClusterLoad(Map<TableName,Map<ServerName,List<RegionInfo>>> clusterLoad) |
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 | Method and Description |
---|---|
List<NormalizationPlan> |
SimpleRegionNormalizer.computePlanForTable(TableName table)
Computes next most "urgent" normalization action on the table.
|
List<NormalizationPlan> |
RegionNormalizer.computePlanForTable(TableName table)
Computes next optimal normalization plan.
|
Modifier and Type | Method and Description |
---|---|
TableName |
CloneSnapshotProcedure.getTableName() |
TableName |
TruncateTableProcedure.getTableName() |
TableName |
ModifyTableProcedure.getTableName() |
TableName |
DisableTableProcedure.getTableName() |
TableName |
ReopenTableRegionsProcedure.getTableName() |
TableName |
DeleteTableProcedure.getTableName() |
TableName |
AbstractStateMachineNamespaceProcedure.getTableName() |
TableName |
InitMetaProcedure.getTableName() |
TableName |
CreateTableProcedure.getTableName() |
TableName |
RestoreSnapshotProcedure.getTableName() |
TableName |
EnableTableProcedure.getTableName() |
abstract TableName |
AbstractStateMachineTableProcedure.getTableName() |
TableName |
AbstractStateMachineRegionProcedure.getTableName() |
TableName |
TableProcedureInterface.getTableName() |
Modifier and Type | Method and Description |
---|---|
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) |
static int |
MasterProcedureUtil.getTablePriority(TableName tableName)
Return the priority for the given table.
|
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
|
protected static void |
DisableTableProcedure.setTableStateToDisabling(MasterProcedureEnv env,
TableName tableName)
Mark table state to Disabling
|
protected static void |
EnableTableProcedure.setTableStateToEnabled(MasterProcedureEnv env,
TableName tableName)
Mark table state to Enabled
|
protected static void |
EnableTableProcedure.setTableStateToEnabling(MasterProcedureEnv env,
TableName tableName)
Mark table state to Enabling
|
protected static void |
CreateTableProcedure.updateTableDescCache(MasterProcedureEnv env,
TableName tableName) |
boolean |
MasterProcedureScheduler.waitRegions(Procedure<?> procedure,
TableName table,
RegionInfo... regionInfo)
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.
|
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... regionInfo)
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 | Method and Description |
---|---|
List<String> |
ReplicationPeerManager.getSerialPeerIdsBelongsTo(TableName tableName) |
protected void |
ModifyPeerProcedure.setLastPushedSequenceIdForTable(MasterProcedureEnv env,
TableName tableName,
Map<String,Long> lastSeqIds) |
Modifier and Type | Field and Description |
---|---|
protected TableName |
TakeSnapshotHandler.snapshotTable |
Modifier and Type | Method and Description |
---|---|
boolean |
SnapshotManager.isTakingSnapshot(TableName tableName)
Check to see if the specified table has a snapshot in progress.
|
void |
SnapshotManager.setSnapshotHandlerForTesting(TableName tableName,
SnapshotSentinel handler)
Set the handler for the current snapshot
|
Modifier and Type | Method and Description |
---|---|
static TableName |
MobUtils.getTableLockName(TableName tn)
Gets the table name used in the table lock.
|
Modifier and Type | Method and Description |
---|---|
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.
|
static void |
MobUtils.doMobCompaction(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
TableName tableName,
ColumnFamilyDescriptor hcd,
ExecutorService pool,
boolean allFiles,
LockManager.MasterLock lock)
Performs the mob compaction.
|
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 TableName |
MobUtils.getTableLockName(TableName tn)
Gets the table name used in the table lock.
|
static boolean |
MobUtils.isMobRegionName(TableName tableName,
byte[] regionName)
Gets whether the current region name follows the pattern of a mob region name.
|
static void |
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.
|
Modifier and Type | Field and Description |
---|---|
protected TableName |
MobCompactor.tableName |
Constructor and Description |
---|
MobCompactor(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
TableName tableName,
ColumnFamilyDescriptor column,
ExecutorService pool) |
PartitionedMobCompactor(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
TableName tableName,
ColumnFamilyDescriptor column,
ExecutorService pool) |
Modifier and Type | Method and Description |
---|---|
void |
NamespaceAuditor.checkQuotaToCreateTable(TableName tName,
int regions)
Check quota to create table.
|
void |
NamespaceAuditor.checkQuotaToUpdateRegion(TableName tName,
int regions)
Check and update region count quota for an existing table.
|
int |
NamespaceAuditor.getRegionCountOfTable(TableName tName)
Get region count for table
|
void |
NamespaceAuditor.removeFromNamespaceUsage(TableName tableName) |
Modifier and Type | Method and Description |
---|---|
static TableName |
ProtobufUtil.toTableName(TableProtos.TableName tableNamePB) |
Modifier and Type | Method and Description |
---|---|
static TableProtos.TableName |
ProtobufUtil.toProtoTableName(TableName tableName) |
Modifier and Type | Field and Description |
---|---|
static TableName |
QuotaTableUtil.QUOTA_TABLE_NAME
System table for quotas
|
Modifier and Type | Method and Description |
---|---|
protected static TableName |
QuotaTableUtil.getTableFromRowKey(byte[] key) |
TableName |
QuotaSettings.getTableName() |
Modifier and Type | Method and Description |
---|---|
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,SpaceQuotaSnapshot> |
RegionServerSpaceQuotaManager.getActivePoliciesAsMap()
Converts a map of table to
SpaceViolationPolicyEnforcement s into
SpaceViolationPolicy s. |
static Map<TableName,Long> |
QuotaTableUtil.getMasterReportedTableSizes(Connection conn)
Fetches the table sizes on the filesystem as tracked by the HBase Master.
|
Map<TableName,SpaceViolationPolicyEnforcement> |
ActivePolicyEnforcement.getPolicies()
Returns an unmodifiable version of the active
SpaceViolationPolicyEnforcement s. |
static Map<TableName,SpaceQuotaSnapshot> |
QuotaTableUtil.getRegionServerQuotaSnapshots(Connection conn,
ServerName regionServer)
Fetches the observed
SpaceQuotaSnapshot s observed by a RegionServer. |
static Map<TableName,SpaceQuotaSnapshot> |
QuotaTableUtil.getSnapshots(Connection conn)
Fetches all
SpaceQuotaSnapshot objects from the hbase:quota table. |
Map<TableName,SpaceQuotaSnapshot> |
QuotaObserverChore.getTableQuotaSnapshots()
Returns an unmodifiable view over the current
SpaceQuotaSnapshot objects
for each HBase table with a quota defined. |
static org.apache.hbase.thirdparty.com.google.common.collect.Multimap<TableName,String> |
QuotaTableUtil.getTableSnapshots(Connection conn)
Returns a multimap for all existing table snapshot entries.
|
Modifier and Type | Method and Description |
---|---|
static void |
QuotaUtil.addTableQuota(Connection connection,
TableName table,
QuotaProtos.Quotas data) |
static void |
QuotaUtil.addUserQuota(Connection connection,
String user,
TableName table,
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. |
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. |
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 user,
TableName table) |
static void |
QuotaUtil.disableTableIfNotDisabled(Connection conn,
TableName tableName)
Method to disable a table, if not already disabled.
|
void |
RegionServerSpaceQuotaManager.disableViolationPolicyEnforcement(TableName tableName)
Disables enforcement on any violation policy on the given
tableName . |
static void |
QuotaUtil.enableTableIfNotEnabled(Connection conn,
TableName tableName)
Method to enable a table, if not already enabled.
|
void |
RegionServerSpaceQuotaManager.enforceViolationPolicy(TableName tableName,
SpaceQuotaSnapshot snapshot)
Enforces the given violationPolicy on the given table in this RegionServer.
|
Iterable<Map.Entry<RegionInfo,Long>> |
TableQuotaSnapshotStore.filterBySubject(TableName table) |
protected static List<QuotaSettings> |
QuotaSettingsFactory.fromThrottle(String userName,
TableName tableName,
String namespace,
QuotaProtos.Throttle throttle) |
static SpaceQuotaSnapshot |
QuotaTableUtil.getCurrentSnapshot(Connection conn,
TableName tn)
Returns the Master's view of a quota on the given
tableName or null if the
Master has no quota information on that table. |
static SpaceQuotaSnapshot |
QuotaTableUtil.getCurrentSnapshotFromQuotaTable(Connection conn,
TableName tableName)
Returns the current space quota snapshot of the given
tableName from
QuotaTableUtil.QUOTA_TABLE_NAME or null if the no quota information is available for
that tableName. |
SpaceQuotaSnapshot |
TableQuotaSnapshotStore.getCurrentState(TableName table) |
SpaceViolationPolicyEnforcement |
ActivePolicyEnforcement.getPolicyEnforcement(TableName tableName)
Returns the proper
SpaceViolationPolicyEnforcement implementation for the given table. |
OperationQuota |
RegionServerRpcQuotaManager.getQuota(org.apache.hadoop.security.UserGroupInformation ugi,
TableName table)
Returns the quota for an operation.
|
int |
MasterQuotaManager.getRegionCountOfTable(TableName tName) |
protected static byte[] |
QuotaTableUtil.getSettingsQualifierForUserTable(TableName tableName) |
QuotaProtos.SpaceQuota |
TableQuotaSnapshotStore.getSpaceQuota(TableName subject) |
QuotaLimiter |
UserQuotaState.getTableLimiter(TableName table)
Return the limiter for the specified table associated with this quota.
|
QuotaLimiter |
QuotaCache.getTableLimiter(TableName table)
Returns the limiter associated to the specified table.
|
static QuotaProtos.Quotas |
QuotaTableUtil.getTableQuota(Connection connection,
TableName table) |
protected static byte[] |
QuotaTableUtil.getTableRowKey(TableName table) |
SpaceQuotaSnapshot |
TableQuotaSnapshotStore.getTargetState(TableName table,
QuotaProtos.SpaceQuota spaceQuota) |
QuotaLimiter |
QuotaCache.getUserLimiter(org.apache.hadoop.security.UserGroupInformation ugi,
TableName table)
Returns the limiter associated to the specified user/table.
|
static QuotaProtos.Quotas |
QuotaTableUtil.getUserQuota(Connection connection,
String user,
TableName table) |
void |
SpaceViolationPolicyEnforcement.initialize(RegionServerServices rss,
TableName tableName,
SpaceQuotaSnapshot snapshot)
Initializes this policy instance.
|
static QuotaSettings |
QuotaSettingsFactory.limitTableSpace(TableName tableName,
long sizeLimit,
SpaceViolationPolicy violationPolicy)
Creates a
QuotaSettings object to limit the FileSystem space usage for the given table
to the given size in bytes. |
static Get |
QuotaTableUtil.makeGetForTableQuotas(TableName table) |
static Get |
QuotaTableUtil.makeQuotaSnapshotGetForTable(TableName tn)
Creates a
Get which returns only SpaceQuotaSnapshot from the quota table for a
specific table. |
static Scan |
QuotaTableUtil.makeQuotaSnapshotScanForTable(TableName tn)
Creates a
Scan which returns only SpaceQuotaSnapshot from the quota table for a
specific table. |
protected static void |
QuotaTableUtil.parseTableResult(TableName table,
Result result,
QuotaTableUtil.TableQuotasVisitor visitor) |
void |
MasterQuotasObserver.postDeleteTable(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName) |
void |
MasterQuotaManager.removeTableFromNamespaceQuota(TableName tName)
Remove table from namespace quota.
|
static QuotaSettings |
QuotaSettingsFactory.removeTableSpaceLimit(TableName tableName)
Creates a
QuotaSettings object to remove the FileSystem space quota for the given
table. |
void |
TableQuotaSnapshotStore.setCurrentState(TableName table,
SpaceQuotaSnapshot snapshot) |
void |
UserQuotaState.setQuotas(TableName table,
QuotaProtos.Quotas quotas)
Add the quota information of the specified table.
|
void |
MasterQuotaManager.setTableQuota(TableName table,
MasterProtos.SetQuotaRequest req) |
void |
MasterQuotaManager.setUserQuota(String userName,
TableName table,
MasterProtos.SetQuotaRequest req) |
static QuotaSettings |
QuotaSettingsFactory.throttleTable(TableName tableName,
ThrottleType type,
long limit,
TimeUnit timeUnit)
Throttle the specified table.
|
static QuotaSettings |
QuotaSettingsFactory.throttleUser(String userName,
TableName tableName,
ThrottleType type,
long limit,
TimeUnit timeUnit)
Throttle the specified user on the specified table.
|
void |
TableSpaceQuotaSnapshotNotifier.transitionTable(TableName tableName,
SpaceQuotaSnapshot snapshot) |
void |
SpaceQuotaSnapshotNotifier.transitionTable(TableName tableName,
SpaceQuotaSnapshot snapshot)
Informs the cluster of the current state of a space quota for a table.
|
static QuotaSettings |
QuotaSettingsFactory.unthrottleTable(TableName tableName)
Remove the throttling for the specified table.
|
static QuotaSettings |
QuotaSettingsFactory.unthrottleUser(String userName,
TableName tableName)
Remove the throttling for the specified user on the specified table.
|
void |
QuotaTableUtil.TableQuotasVisitor.visitTableQuotas(TableName tableName,
QuotaProtos.Quotas quotas) |
void |
QuotaTableUtil.UserQuotasVisitor.visitUserQuotas(String userName,
TableName table,
QuotaProtos.Quotas quotas) |
Modifier and Type | Method and Description |
---|---|
static void |
QuotaTableUtil.extractQuotaSnapshot(Result result,
Map<TableName,SpaceQuotaSnapshot> snapshots)
Extracts the
SpaceViolationPolicy and TableName from the provided
Result and adds them to the given Map . |
static Get |
QuotaTableUtil.makeGetForUserQuotas(String user,
Iterable<TableName> tables,
Iterable<String> namespaces) |
void |
RegionServerSpaceQuotaManager.updateQuotaSnapshot(Map<TableName,SpaceQuotaSnapshot> newSnapshots)
Updates the current
SpaceQuotaSnapshot s for the RegionServer. |
Constructor and Description |
---|
GlobalQuotaSettings(String userName,
TableName tableName,
String namespace) |
GlobalQuotaSettingsImpl(String username,
TableName tableName,
String namespace,
QuotaProtos.Quotas quotas) |
GlobalQuotaSettingsImpl(String userName,
TableName tableName,
String namespace,
QuotaProtos.Throttle throttleProto,
Boolean bypassGlobals,
QuotaProtos.SpaceQuota spaceProto) |
QuotaSettings(String userName,
TableName tableName,
String namespace) |
Constructor and Description |
---|
ActivePolicyEnforcement(Map<TableName,SpaceViolationPolicyEnforcement> activePolicies,
Map<TableName,SpaceQuotaSnapshot> snapshots,
RegionServerServices rss) |
ActivePolicyEnforcement(Map<TableName,SpaceViolationPolicyEnforcement> activePolicies,
Map<TableName,SpaceQuotaSnapshot> snapshots,
RegionServerServices rss) |
ActivePolicyEnforcement(Map<TableName,SpaceViolationPolicyEnforcement> activePolicies,
Map<TableName,SpaceQuotaSnapshot> snapshots,
RegionServerServices rss,
SpaceViolationPolicyEnforcementFactory factory) |
ActivePolicyEnforcement(Map<TableName,SpaceViolationPolicyEnforcement> activePolicies,
Map<TableName,SpaceQuotaSnapshot> snapshots,
RegionServerServices rss,
SpaceViolationPolicyEnforcementFactory factory) |
Modifier and Type | Method and Description |
---|---|
TableName |
AbstractViolationPolicyEnforcement.getTableName() |
Modifier and Type | Method and Description |
---|---|
void |
AbstractViolationPolicyEnforcement.initialize(RegionServerServices rss,
TableName tableName,
SpaceQuotaSnapshot snapshot) |
void |
AbstractViolationPolicyEnforcement.setTableName(TableName tableName) |
Modifier and Type | Method and Description |
---|---|
TableName |
Store.getTableName() |
TableName |
HStore.getTableName() |
Modifier and Type | Method and Description |
---|---|
Set<TableName> |
HRegionServer.getOnlineTables()
Gets the online tables in this RS.
|
Modifier and Type | Method and Description |
---|---|
List<? extends Region> |
OnlineRegions.getRegions(TableName tableName)
Get all online regions of a table in this RS.
|
List<HRegion> |
HRegionServer.getRegions(TableName tableName)
Gets the online regions of the specified table.
|
static String |
MetricsTableLatenciesImpl.qualifyMetricsName(TableName tableName,
String metric) |
void |
RegionServerTableMetrics.updateAppend(TableName table,
long time) |
void |
MetricsRegionServer.updateAppend(TableName tn,
long t) |
void |
RegionServerTableMetrics.updateDelete(TableName table,
long time) |
void |
MetricsRegionServer.updateDelete(TableName tn,
long t) |
void |
RegionServerTableMetrics.updateDeleteBatch(TableName table,
long time) |
void |
MetricsRegionServer.updateDeleteBatch(TableName tn,
long t) |
void |
RegionServerTableMetrics.updateGet(TableName table,
long time) |
void |
MetricsRegionServer.updateGet(TableName tn,
long t) |
void |
RegionServerTableMetrics.updateIncrement(TableName table,
long time) |
void |
MetricsRegionServer.updateIncrement(TableName tn,
long t) |
void |
RegionServerTableMetrics.updatePut(TableName table,
long time) |
void |
MetricsRegionServer.updatePut(TableName tn,
long t) |
void |
RegionServerTableMetrics.updatePutBatch(TableName table,
long time) |
void |
MetricsRegionServer.updatePutBatch(TableName tn,
long t) |
void |
RegionServerTableMetrics.updateScanSize(TableName table,
long size) |
void |
MetricsRegionServer.updateScanSize(TableName tn,
long scanSize) |
void |
RegionServerTableMetrics.updateScanTime(TableName table,
long time) |
void |
MetricsRegionServer.updateScanTime(TableName tn,
long t) |
Modifier and Type | Method and Description |
---|---|
Map<TableName,List<String>> |
ReplicationPeerConfig.getExcludeTableCFsMap() |
Map<TableName,List<String>> |
ReplicationPeerImpl.getTableCFs()
Get replicable (table, cf-list) map of this peer
|
Map<TableName,List<String>> |
ReplicationPeer.getTableCFs()
Get replicable (table, cf-list) map of this peer
|
Map<TableName,List<String>> |
ReplicationPeerConfig.getTableCFsMap() |
Modifier and Type | Method and Description |
---|---|
static boolean |
ReplicationUtils.contains(ReplicationPeerConfig peerConfig,
TableName tableName)
Returns whether we should replicate the given table.
|
boolean |
ReplicationPeerConfig.needToReplicate(TableName table)
Decide whether the table need replicate to the peer cluster
|
Modifier and Type | Method and Description |
---|---|
ReplicationPeerConfig |
ReplicationPeerConfig.setExcludeTableCFsMap(Map<TableName,? extends Collection<String>> tableCFsMap)
Deprecated.
as release of 2.0.0, and it will be removed in 3.0.0. Use
ReplicationPeerConfigBuilder.setExcludeTableCFsMap(Map) instead. |
ReplicationPeerConfigBuilder |
ReplicationPeerConfigBuilder.setExcludeTableCFsMap(Map<TableName,List<String>> tableCFsMap)
Sets the mapping of table name to column families which should not be replicated.
|
ReplicationPeerConfig |
ReplicationPeerConfig.setTableCFsMap(Map<TableName,? extends Collection<String>> tableCFsMap)
Deprecated.
as release of 2.0.0, and it will be removed in 3.0.0. Use
ReplicationPeerConfigBuilder.setTableCFsMap(Map) instead. |
ReplicationPeerConfigBuilder |
ReplicationPeerConfigBuilder.setTableCFsMap(Map<TableName,List<String>> tableCFsMap)
Sets an explicit map of tables and column families in those tables that should be replicated
to the given peer.
|
Modifier and Type | Method and Description |
---|---|
void |
ReplicationSource.addHFileRefs(TableName tableName,
byte[] family,
List<Pair<org.apache.hadoop.fs.Path,org.apache.hadoop.fs.Path>> pairs) |
void |
ReplicationSourceInterface.addHFileRefs(TableName tableName,
byte[] family,
List<Pair<org.apache.hadoop.fs.Path,org.apache.hadoop.fs.Path>> pairs)
Add hfile names to the queue to be replicated.
|
void |
ReplicationSourceManager.addHFileRefs(TableName tableName,
byte[] family,
List<Pair<org.apache.hadoop.fs.Path,org.apache.hadoop.fs.Path>> pairs) |
protected void |
ReplicationSink.batch(TableName tableName,
Collection<List<Row>> allRows)
Do the changes and handle the pool
|
boolean |
WALEntrySinkFilter.filter(TableName table,
long writeTime) |
Modifier and Type | Method and Description |
---|---|
TableName |
RemoteHTable.getName() |
Modifier and Type | Field and Description |
---|---|
static TableName |
RSGroupInfoManager.RSGROUP_TABLE_NAME |
Modifier and Type | Method and Description |
---|---|
SortedSet<TableName> |
RSGroupInfo.getTables()
Get set of tables that are members of the group.
|
Modifier and Type | Method and Description |
---|---|
void |
RSGroupInfo.addTable(TableName table) |
List<RegionPlan> |
RSGroupBasedLoadBalancer.balanceCluster(TableName tableName,
Map<ServerName,List<RegionInfo>> clusterState) |
boolean |
RSGroupInfo.containsTable(TableName table) |
RSGroupInfo |
RSGroupAdminClient.getRSGroupInfoOfTable(TableName tableName) |
RSGroupInfo |
RSGroupAdmin.getRSGroupInfoOfTable(TableName tableName)
Gets
RSGroupInfo for the given table's group. |
RSGroupInfo |
RSGroupAdminServer.getRSGroupInfoOfTable(TableName tableName) |
String |
RSGroupInfoManager.getRSGroupOfTable(TableName tableName)
Get the group membership of a table
|
void |
RSGroupAdminEndpoint.postDeleteTable(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName) |
boolean |
RSGroupInfo.removeTable(TableName table) |
Modifier and Type | Method and Description |
---|---|
void |
RSGroupInfo.addAllTables(Collection<TableName> arg) |
void |
RSGroupAdminClient.moveServersAndTables(Set<Address> servers,
Set<TableName> tables,
String targetGroup) |
void |
RSGroupAdmin.moveServersAndTables(Set<Address> servers,
Set<TableName> tables,
String targetGroup)
Move given set of servers and tables to the specified target RegionServer group.
|
void |
RSGroupAdminServer.moveServersAndTables(Set<Address> servers,
Set<TableName> tables,
String targetGroup) |
void |
RSGroupInfoManager.moveServersAndTables(Set<Address> servers,
Set<TableName> tables,
String srcGroup,
String dstGroup)
Move servers and tables to a new group.
|
void |
RSGroupAdminClient.moveTables(Set<TableName> tables,
String targetGroup) |
void |
RSGroupAdmin.moveTables(Set<TableName> tables,
String targetGroup)
Move given set of tables to the specified target RegionServer group.
|
void |
RSGroupAdminServer.moveTables(Set<TableName> tables,
String targetGroup) |
void |
RSGroupInfoManager.moveTables(Set<TableName> tableNames,
String groupName)
Set the group membership of a set of tables
|
void |
RSGroupBasedLoadBalancer.setClusterLoad(Map<TableName,Map<ServerName,List<RegionInfo>>> clusterLoad) |
Modifier and Type | Field and Description |
---|---|
static TableName |
AccessControlLists.ACL_TABLE_NAME
Internal storage table for access control lists
|
static TableName |
AccessControlClient.ACL_TABLE_NAME |
Modifier and Type | Method and Description |
---|---|
TableName |
AuthResult.getTableName() |
TableName |
TablePermission.getTableName() |
static TableName |
ShadedAccessControlUtil.toTableName(HBaseProtos.TableName tableNamePB) |
Modifier and Type | Method and Description |
---|---|
static AuthResult |
AuthResult.allow(String request,
String reason,
User user,
Permission.Action action,
TableName table,
byte[] family,
byte[] qualifier) |
static AuthResult |
AuthResult.allow(String request,
String reason,
User user,
Permission.Action action,
TableName table,
Map<byte[],? extends Collection<?>> families) |
boolean |
TableAuthManager.authorize(User user,
TableName table,
byte[] family,
byte[] qualifier,
Permission.Action action) |
boolean |
TableAuthManager.authorize(User user,
TableName table,
byte[] family,
Permission.Action action) |
boolean |
TableAuthManager.authorize(User user,
TableName table,
Cell cell,
Permission.Action action)
Authorize a user for a given KV.
|
boolean |
TableAuthManager.authorizeGroup(String groupName,
TableName table,
byte[] family,
byte[] qualifier,
Permission.Action action)
Checks authorization to a given table, column family and column for a group, based
on the stored permissions.
|
boolean |
TableAuthManager.authorizeUser(User user,
TableName table,
byte[] family,
byte[] qualifier,
Permission.Action action) |
boolean |
TableAuthManager.authorizeUser(User user,
TableName table,
byte[] family,
Permission.Action action)
Checks authorization to a given table and column family for a user, based on the
stored user permissions.
|
static AccessControlProtos.GrantRequest |
AccessControlUtil.buildGrantRequest(String username,
TableName tableName,
byte[] family,
byte[] qualifier,
boolean mergeExistingPermissions,
AccessControlProtos.Permission.Action... actions)
Create a request to grant user permissions.
|
static AccessControlProtos.RevokeRequest |
AccessControlUtil.buildRevokeRequest(String username,
TableName tableName,
byte[] family,
byte[] qualifier,
AccessControlProtos.Permission.Action... actions)
Create a request to revoke user permissions.
|
void |
AccessController.checkLockPermissions(ObserverContext<?> ctx,
String namespace,
TableName tableName,
RegionInfo[] regionInfos,
String reason) |
void |
AccessChecker.checkLockPermissions(User user,
String namespace,
TableName tableName,
RegionInfo[] regionInfos,
String reason) |
void |
ZKPermissionWatcher.deleteTableACLNode(TableName tableName)
Delete the acl notify node of table
|
static AuthResult |
AuthResult.deny(String request,
String reason,
User user,
Permission.Action action,
TableName table,
byte[] family,
byte[] qualifier) |
static AuthResult |
AuthResult.deny(String request,
String reason,
User user,
Permission.Action action,
TableName table,
Map<byte[],? extends Collection<?>> families) |
static org.apache.hbase.thirdparty.com.google.common.collect.ListMultimap<String,TablePermission> |
AccessControlLists.getTablePermissions(org.apache.hadoop.conf.Configuration conf,
TableName tableName) |
static List<UserPermission> |
AccessControlUtil.getUserPermissions(com.google.protobuf.RpcController controller,
AccessControlProtos.AccessControlService.BlockingInterface protocol,
TableName t)
A utility used to get user table permissions.
|
static void |
AccessControlClient.grant(Connection connection,
TableName tableName,
String userName,
byte[] family,
byte[] qual,
Permission.Action... actions)
Grants permission on the specified table for the specified user.
|
static void |
AccessControlUtil.grant(com.google.protobuf.RpcController controller,
AccessControlProtos.AccessControlService.BlockingInterface protocol,
String userShortName,
TableName tableName,
byte[] f,
byte[] q,
boolean mergeExistingPermissions,
Permission.Action... actions)
A utility used to grant a user table permissions.
|
boolean |
TableAuthManager.groupHasAccess(String groupName,
TableName table,
Permission.Action action)
Checks if the user has access to the full table or at least a family/qualifier
for the specified action.
|
boolean |
TableAuthManager.hasAccess(User user,
TableName table,
Permission.Action action) |
boolean |
TablePermission.implies(TableName table,
byte[] family,
byte[] qualifier,
Permission.Action action)
Checks that a given table operation is authorized by this permission
instance.
|
boolean |
TablePermission.implies(TableName table,
KeyValue kv,
Permission.Action action)
Checks if this permission grants access to perform the given action on
the given table and key value.
|
boolean |
TablePermission.matchesFamily(TableName table,
byte[] family,
Permission.Action action)
Returns
true if this permission matches the given column
family at least. |
boolean |
TablePermission.matchesFamilyQualifier(TableName table,
byte[] family,
byte[] qualifier,
Permission.Action action)
Returns if the given permission matches the given qualifier.
|
boolean |
TableAuthManager.matchPermission(User user,
TableName table,
byte[] family,
byte[] qualifier,
Permission.Action action) |
boolean |
TableAuthManager.matchPermission(User user,
TableName table,
byte[] family,
Permission.Action action)
Returns true if the given user has a
TablePermission matching up
to the column family portion of a permission. |
void |
AccessController.postDeleteTable(ObserverContext<MasterCoprocessorEnvironment> c,
TableName tableName) |
void |
AccessController.postModifyTable(ObserverContext<MasterCoprocessorEnvironment> c,
TableName tableName,
TableDescriptor htd) |
void |
AccessController.postTruncateTable(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName) |
void |
AccessController.preDeleteTable(ObserverContext<MasterCoprocessorEnvironment> c,
TableName tableName) |
void |
AccessController.preDisableTable(ObserverContext<MasterCoprocessorEnvironment> c,
TableName tableName) |
void |
AccessController.preEnableTable(ObserverContext<MasterCoprocessorEnvironment> c,
TableName tableName) |
void |
AccessController.preLockHeartbeat(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName,
String description) |
void |
CoprocessorWhitelistMasterObserver.preModifyTable(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName,
TableDescriptor htd) |
void |
AccessController.preModifyTable(ObserverContext<MasterCoprocessorEnvironment> c,
TableName tableName,
TableDescriptor htd) |
void |
AccessController.preRequestLock(ObserverContext<MasterCoprocessorEnvironment> ctx,
String namespace,
TableName tableName,
RegionInfo[] regionInfos,
String description) |
void |
AccessController.preSetTableQuota(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName,
GlobalQuotaSettings quotas) |
void |
AccessController.preSetUserQuota(ObserverContext<MasterCoprocessorEnvironment> ctx,
String userName,
TableName tableName,
GlobalQuotaSettings quotas) |
void |
AccessController.preSplitRegion(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName,
byte[] splitRow) |
void |
AccessController.preTableFlush(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName) |
void |
AccessController.preTruncateTable(ObserverContext<MasterCoprocessorEnvironment> c,
TableName tableName) |
void |
TableAuthManager.refreshTableCacheFromWritable(TableName table,
byte[] data) |
void |
TableAuthManager.removeTable(TableName table) |
void |
AccessController.requireAccess(ObserverContext<?> ctx,
String request,
TableName tableName,
Permission.Action... permissions) |
void |
AccessChecker.requireAccess(User user,
String request,
TableName tableName,
Permission.Action... permissions)
Authorizes that the current user has any of the given permissions to access the table.
|
void |
AccessController.requireGlobalPermission(ObserverContext<?> ctx,
String request,
Permission.Action perm,
TableName tableName,
Map<byte[],? extends Collection<byte[]>> familyMap) |
void |
AccessChecker.requireGlobalPermission(User user,
String request,
Permission.Action perm,
TableName tableName,
Map<byte[],? extends Collection<byte[]>> familyMap)
Checks that the user has the given global permission.
|
void |
AccessController.requireNamespacePermission(ObserverContext<?> ctx,
String request,
String namespace,
TableName tableName,
Map<byte[],? extends Collection<byte[]>> familyMap,
Permission.Action... permissions) |
void |
AccessChecker.requireNamespacePermission(User user,
String request,
String namespace,
TableName tableName,
Map<byte[],? extends Collection<byte[]>> familyMap,
Permission.Action... permissions)
Checks that the user has the given global or namespace permission.
|
void |
AccessController.requirePermission(ObserverContext<?> ctx,
String request,
TableName tableName,
byte[] family,
byte[] qualifier,
Permission.Action... permissions) |
void |
AccessChecker.requirePermission(User user,
String request,
TableName tableName,
byte[] family,
byte[] qualifier,
Permission.Action... permissions)
Authorizes that the current user has any of the given permissions for the
given table, column family and column qualifier.
|
void |
AccessController.requireTablePermission(ObserverContext<?> ctx,
String request,
TableName tableName,
byte[] family,
byte[] qualifier,
Permission.Action... permissions) |
void |
AccessChecker.requireTablePermission(User user,
String request,
TableName tableName,
byte[] family,
byte[] qualifier,
Permission.Action... permissions)
Authorizes that the current user has any of the given permissions for the
given table, column family and column qualifier.
|
static void |
AccessControlClient.revoke(Connection connection,
TableName tableName,
String username,
byte[] family,
byte[] qualifier,
Permission.Action... actions)
Revokes the permission on the table
|
static void |
AccessControlUtil.revoke(com.google.protobuf.RpcController controller,
AccessControlProtos.AccessControlService.BlockingInterface protocol,
String userShortName,
TableName tableName,
byte[] f,
byte[] q,
Permission.Action... actions)
A utility used to revoke a user's table permissions.
|
void |
TableAuthManager.setTableGroupPermissions(String group,
TableName table,
List<TablePermission> perms)
Overwrites the existing permission set for a group and triggers an update
for zookeeper synchronization.
|
AuthResult.Params |
AuthResult.Params.setTableName(TableName table) |
void |
TablePermission.setTableName(TableName table) |
void |
TableAuthManager.setTableUserPermissions(String username,
TableName table,
List<TablePermission> perms)
Overwrites the existing permission set for a given user for a table, and
triggers an update for zookeeper synchronization.
|
static HBaseProtos.TableName |
ShadedAccessControlUtil.toProtoTableName(TableName tableName) |
boolean |
TableAuthManager.userHasAccess(User user,
TableName table,
Permission.Action action)
Checks if the user has access to the full table or at least a family/qualifier
for the specified action.
|
void |
TableAuthManager.writeTableToZooKeeper(TableName table,
org.apache.hadoop.hbase.security.access.TableAuthManager.PermissionCache<TablePermission> tablePerms) |
Modifier and Type | Method and Description |
---|---|
void |
AccessController.postGetTableDescriptors(ObserverContext<MasterCoprocessorEnvironment> ctx,
List<TableName> tableNamesList,
List<TableDescriptor> descriptors,
String regex) |
void |
AccessController.preGetTableDescriptors(ObserverContext<MasterCoprocessorEnvironment> ctx,
List<TableName> tableNamesList,
List<TableDescriptor> descriptors,
String regex) |
Constructor and Description |
---|
AuthResult(boolean allowed,
String request,
String reason,
User user,
Permission.Action action,
TableName table,
byte[] family,
byte[] qualifier) |
AuthResult(boolean allowed,
String request,
String reason,
User user,
Permission.Action action,
TableName table,
Map<byte[],? extends Collection<?>> families) |
TablePermission(String namespace,
TableName table,
byte[] family,
byte[] qualifier,
byte[] actionCodes)
Creates a new permission for the given namespace or table, family and column qualifier,
allowing the actions matching the provided byte codes to be performed.
|
TablePermission(String namespace,
TableName table,
byte[] family,
byte[] qualifier,
Permission.Action... assigned)
Creates a new permission for the given namespace or table, restricted to the given
column family and qualifier, allowing the assigned actions to be performed.
|
TablePermission(TableName table,
byte[] family,
byte[] qualifier,
byte[] actionCodes)
Creates a new permission for the given table, family and column qualifier,
allowing the actions matching the provided byte codes to be performed.
|
TablePermission(TableName table,
byte[] family,
byte[] qualifier,
Permission.Action... assigned)
Creates a new permission for the given table, restricted to the given
column family and qualifier, allowing the assigned actions to be performed.
|
TablePermission(TableName table,
byte[] family,
Permission.Action... assigned)
Create a new permission for the given table and (optionally) column family,
allowing the given actions.
|
UserPermission(byte[] user,
TableName table,
byte[] family,
byte[] qualifier,
byte[] actionCodes)
Creates a new instance for the given user, table, column family and
qualifier, matching the actions with the given codes.
|
UserPermission(byte[] user,
TableName table,
byte[] family,
byte[] qualifier,
Permission.Action... assigned)
Creates a new permission for the given user, table, column family and
column qualifier.
|
UserPermission(byte[] user,
TableName table,
byte[] family,
Permission.Action... assigned)
Creates a new instance for the given user, table and column family.
|
Modifier and Type | Field and Description |
---|---|
static TableName |
VisibilityConstants.LABELS_TABLE_NAME
Internal storage table for visibility labels
|
Modifier and Type | Method and Description |
---|---|
void |
VisibilityController.preDisableTable(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName) |
void |
VisibilityController.preModifyTable(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName,
TableDescriptor htd) |
Modifier and Type | Method and Description |
---|---|
static TableName[] |
ProtobufUtil.getTableNameArray(List<HBaseProtos.TableName> tableNamesList) |
static TableName |
ProtobufUtil.toTableName(HBaseProtos.TableName tableNamePB) |
Modifier and Type | Method and Description |
---|---|
static List<TableName> |
ProtobufUtil.toTableNameList(List<HBaseProtos.TableName> tableNamesList) |
Modifier and Type | Method and Description |
---|---|
static MasterProtos.AddColumnRequest |
RequestConverter.buildAddColumnRequest(TableName tableName,
ColumnFamilyDescriptor column,
long nonceGroup,
long nonce)
Create a protocol buffer AddColumnRequest
|
static MasterProtos.DeleteColumnRequest |
RequestConverter.buildDeleteColumnRequest(TableName tableName,
byte[] columnName,
long nonceGroup,
long nonce)
Create a protocol buffer DeleteColumnRequest
|
static MasterProtos.DeleteTableRequest |
RequestConverter.buildDeleteTableRequest(TableName tableName,
long nonceGroup,
long nonce)
Creates a protocol buffer DeleteTableRequest
|
static MasterProtos.DisableTableRequest |
RequestConverter.buildDisableTableRequest(TableName tableName,
long nonceGroup,
long nonce)
Creates a protocol buffer DisableTableRequest
|
static MasterProtos.EnableTableRequest |
RequestConverter.buildEnableTableRequest(TableName tableName,
long nonceGroup,
long nonce)
Creates a protocol buffer EnableTableRequest
|
static AdminProtos.GetRegionLoadRequest |
RequestConverter.buildGetRegionLoadRequest(TableName tableName)
Create a protocol buffer GetRegionLoadRequest for all regions/regions of a table.
|
static MasterProtos.GetSchemaAlterStatusRequest |
RequestConverter.buildGetSchemaAlterStatusRequest(TableName tableName)
Creates a protocol buffer GetSchemaAlterStatusRequest
|
static MasterProtos.GetTableDescriptorsRequest |
RequestConverter.buildGetTableDescriptorsRequest(TableName tableName)
Creates a protocol buffer GetTableDescriptorsRequest for a single table
|
static MasterProtos.GetTableStateRequest |
RequestConverter.buildGetTableStateRequest(TableName tableName)
Creates a protocol buffer GetTableStateRequest
|
static MasterProtos.ModifyColumnRequest |
RequestConverter.buildModifyColumnRequest(TableName tableName,
ColumnFamilyDescriptor column,
long nonceGroup,
long nonce)
Create a protocol buffer ModifyColumnRequest
|
static MasterProtos.ModifyTableRequest |
RequestConverter.buildModifyTableRequest(TableName tableName,
TableDescriptor tableDesc,
long nonceGroup,
long nonce)
Creates a protocol buffer ModifyTableRequest
|
static MasterProtos.TruncateTableRequest |
RequestConverter.buildTruncateTableRequest(TableName tableName,
boolean preserveSplits,
long nonceGroup,
long nonce)
Creates a protocol buffer TruncateTableRequest
|
static WALProtos.BulkLoadDescriptor |
ProtobufUtil.toBulkLoadDescriptor(TableName tableName,
org.apache.hbase.thirdparty.com.google.protobuf.ByteString encodedRegionName,
Map<byte[],List<org.apache.hadoop.fs.Path>> storeFiles,
Map<String,Long> storeFilesSize,
long bulkloadSeqId)
Generates a marker for the WAL so that we propagate the notion of a bulk region load
throughout the WAL.
|
static HBaseProtos.TableName |
ProtobufUtil.toProtoTableName(TableName tableName) |
Modifier and Type | Method and Description |
---|---|
static MasterProtos.GetTableDescriptorsRequest |
RequestConverter.buildGetTableDescriptorsRequest(List<TableName> tableNames)
Creates a protocol buffer GetTableDescriptorsRequest
|
Modifier and Type | Method and Description |
---|---|
static RegionInfo |
RestoreSnapshotHelper.cloneRegionInfo(TableName tableName,
RegionInfo snapshotRegionInfo) |
static void |
RestoreSnapshotHelper.restoreSnapshotAcl(SnapshotProtos.SnapshotDescription snapshot,
TableName newTableName,
org.apache.hadoop.conf.Configuration conf) |
Constructor and Description |
---|
TablePartiallyOpenException(TableName tableName) |
Modifier and Type | Field and Description |
---|---|
static TableName |
Canary.DEFAULT_WRITE_TABLE_NAME |
Modifier and Type | Method and Description |
---|---|
protected ClientServiceCallable<byte[]> |
LoadIncrementalHFiles.buildClientServiceCallable(Connection conn,
TableName tableName,
byte[] first,
Collection<LoadIncrementalHFiles.LoadQueueItem> lqis,
boolean copyFile) |
Map<LoadIncrementalHFiles.LoadQueueItem,ByteBuffer> |
LoadIncrementalHFiles.run(Map<byte[],List<org.apache.hadoop.fs.Path>> family2Files,
TableName tableName)
Perform bulk load on the given table.
|
Map<LoadIncrementalHFiles.LoadQueueItem,ByteBuffer> |
LoadIncrementalHFiles.run(String hfofDir,
TableName tableName)
Perform bulk load on the given table.
|
protected List<LoadIncrementalHFiles.LoadQueueItem> |
LoadIncrementalHFiles.tryAtomicRegionLoad(ClientServiceCallable<byte[]> serviceCallable,
TableName tableName,
byte[] first,
Collection<LoadIncrementalHFiles.LoadQueueItem> lqis)
Attempts to do an atomic load of many hfiles into a region.
|
Modifier and Type | Method and Description |
---|---|
TableName |
HBaseFsck.TableInfo.getName() |
TableName |
HBaseFsck.HbckInfo.getTableName() |
static TableName |
HFileArchiveUtil.getTableName(org.apache.hadoop.fs.Path archivePath) |
static TableName |
CommonFSUtils.getTableName(org.apache.hadoop.fs.Path tablePath)
Returns the
TableName object representing
the table directory under
path rootdir |
Modifier and Type | Method and Description |
---|---|
static Map<TableName,TableState.State> |
ZKDataMigrator.queryForTableStates(ZKWatcher zkw)
Deprecated.
Since 2.0.0. To be removed in hbase-3.0.0.
|
Modifier and Type | Method and Description |
---|---|
void |
FSTableDescriptors.deleteTableDescriptorIfExists(TableName tableName)
Deletes all the table descriptor files from the file system.
|
TableDescriptor |
FSTableDescriptors.get(TableName tablename)
Get the current table descriptor for the given table, or null if none exists.
|
org.apache.hbase.thirdparty.com.google.common.collect.Multimap<byte[],HBaseFsck.HbckInfo> |
HBaseFsck.getOverlapGroups(TableName table) |
static org.apache.hadoop.fs.Path |
HFileArchiveUtil.getRegionArchiveDir(org.apache.hadoop.fs.Path rootDir,
TableName tableName,
org.apache.hadoop.fs.Path regiondir)
Get the archive directory for a given region under the specified table
|
static org.apache.hadoop.fs.Path |
HFileArchiveUtil.getRegionArchiveDir(org.apache.hadoop.fs.Path rootDir,
TableName tableName,
String encodedRegionName)
Get the archive directory for a given region under the specified table
|
static org.apache.hadoop.fs.Path |
HFileArchiveUtil.getStoreArchivePath(org.apache.hadoop.conf.Configuration conf,
TableName tableName,
String regionName,
String familyName)
Get the directory to archive a store directory
|
static org.apache.hadoop.fs.Path |
HFileArchiveUtil.getTableArchivePath(org.apache.hadoop.conf.Configuration conf,
TableName tableName)
Get the path to the table archive directory based on the configured archive directory.
|
static org.apache.hadoop.fs.Path |
HFileArchiveUtil.getTableArchivePath(org.apache.hadoop.fs.Path rootdir,
TableName tableName)
Get the path to the table archive directory based on the configured archive directory.
|
static TableDescriptor |
FSTableDescriptors.getTableDescriptorFromFs(org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.fs.Path hbaseRootDir,
TableName tableName)
Returns the latest table descriptor for the given table directly from the file system
if it exists, bypassing the local cache.
|
static org.apache.hadoop.fs.Path |
CommonFSUtils.getTableDir(org.apache.hadoop.fs.Path rootdir,
TableName tableName)
Returns the
Path object representing the table directory under
path rootdir |
static Map<String,org.apache.hadoop.fs.Path> |
FSUtils.getTableStoreFilePathMap(Map<String,org.apache.hadoop.fs.Path> map,
org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.fs.Path hbaseRootDir,
TableName tableName)
Runs through the HBase rootdir/tablename and creates a reverse lookup map for
table StoreFile names to the full Path.
|
static Map<String,org.apache.hadoop.fs.Path> |
FSUtils.getTableStoreFilePathMap(Map<String,org.apache.hadoop.fs.Path> resultMap,
org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.fs.Path hbaseRootDir,
TableName tableName,
org.apache.hadoop.fs.PathFilter sfFilter,
ExecutorService executor,
HBaseFsck.ErrorReporter errors)
Runs through the HBase rootdir/tablename and creates a reverse lookup map for
table StoreFile names to the full Path.
|
static org.apache.hadoop.fs.Path |
CommonFSUtils.getWALRegionDir(org.apache.hadoop.conf.Configuration conf,
TableName tableName,
String encodedRegionName)
Returns the WAL region directory based on the given table name and region name
|
static org.apache.hadoop.fs.Path |
CommonFSUtils.getWALTableDir(org.apache.hadoop.conf.Configuration conf,
TableName tableName)
Returns the Table directory under the WALRootDir for the specified table name
|
static org.apache.hadoop.fs.Path |
CommonFSUtils.getWrongWALRegionDir(org.apache.hadoop.conf.Configuration conf,
TableName tableName,
String encodedRegionName)
Deprecated.
For compatibility, will be removed in 4.0.0.
|
void |
HBaseFsck.includeTable(TableName table) |
boolean |
FSTableDescriptors.isTableInfoExists(TableName tableName)
Checks if a current table info file exists for the given table
|
<R> void |
MultiHConnection.processBatchCallback(List<? extends Row> actions,
TableName tableName,
Object[] results,
Batch.Callback<R> callback)
Randomly pick a connection and process the batch of actions for a given table
|
TableDescriptor |
FSTableDescriptors.remove(TableName tablename)
Removes the table descriptor from the local cache and returns it.
|
Constructor and Description |
---|
MajorCompactor(org.apache.hadoop.conf.Configuration conf,
TableName tableName,
Set<String> storesToCompact,
int concurrency,
long timestamp,
long sleepForMs) |
Modifier and Type | Method and Description |
---|---|
default TableName |
WALKey.getTablename()
Deprecated.
Use
WALKey.getTableName() instead |
TableName |
WALKeyImpl.getTableName() |
TableName |
WALKey.getTableName() |
TableName |
WALSplitter.RegionEntryBuffer.getTableName() |
Modifier and Type | Method and Description |
---|---|
protected void |
WALKeyImpl.init(byte[] encodedRegionName,
TableName tablename,
long logSeqNum,
long now,
List<UUID> clusterIds,
long nonceGroup,
long nonce,
MultiVersionConcurrencyControl mvcc,
NavigableMap<byte[],Integer> replicationScope) |
Constructor and Description |
---|
WALKeyImpl(byte[] encodedRegionName,
TableName tablename,
long now) |
WALKeyImpl(byte[] encodedRegionName,
TableName tablename,
long now,
List<UUID> clusterIds,
long nonceGroup,
long nonce,
MultiVersionConcurrencyControl mvcc)
Create the log key for writing to somewhere.
|
WALKeyImpl(byte[] encodedRegionName,
TableName tablename,
long now,
List<UUID> clusterIds,
long nonceGroup,
long nonce,
MultiVersionConcurrencyControl mvcc,
NavigableMap<byte[],Integer> replicationScope)
Create the log key for writing to somewhere.
|
WALKeyImpl(byte[] encodedRegionName,
TableName tablename,
long logSeqNum,
long now,
List<UUID> clusterIds,
long nonceGroup,
long nonce,
MultiVersionConcurrencyControl mvcc)
Create the log key for writing to somewhere.
|
WALKeyImpl(byte[] encodedRegionName,
TableName tablename,
long logSeqNum,
long now,
List<UUID> clusterIds,
long nonceGroup,
long nonce,
MultiVersionConcurrencyControl mvcc,
NavigableMap<byte[],Integer> replicationScope)
Create the log key for writing to somewhere.
|
WALKeyImpl(byte[] encodedRegionName,
TableName tablename,
long logSeqNum,
long nonceGroup,
long nonce,
MultiVersionConcurrencyControl mvcc)
Create the log key for writing to somewhere.
|
WALKeyImpl(byte[] encodedRegionName,
TableName tablename,
long logSeqNum,
long now,
UUID clusterId) |
WALKeyImpl(byte[] encodedRegionName,
TableName tablename,
long now,
MultiVersionConcurrencyControl mvcc) |
WALKeyImpl(byte[] encodedRegionName,
TableName tablename,
long now,
MultiVersionConcurrencyControl mvcc,
NavigableMap<byte[],Integer> replicationScope) |
WALKeyImpl(byte[] encodedRegionName,
TableName tablename,
long now,
NavigableMap<byte[],Integer> replicationScope) |
Copyright © 2007–2019 Cloudera. All rights reserved.