Modifier and Type | Field and Description |
---|---|
static TableName |
HConstants.ENSEMBLE_TABLE_NAME
The name of the ensemble table
|
static TableName |
TableName.META_TABLE_NAME
The hbase:meta table's name.
|
static TableName |
TableName.NAMESPACE_TABLE_NAME
The Namespace table's name.
|
static TableName |
TableName.OLD_META_TABLE_NAME
TableName for old .META.
|
static TableName |
TableName.OLD_ROOT_TABLE_NAME
TableName for old -ROOT- table.
|
private static TableName |
RSGroupTableAccessor.RSGROUP_TABLE_NAME |
private TableName |
HRegionInfo.tableName
Deprecated.
|
private TableName |
MetaTableAccessor.TableVisitorBase.tableName |
Modifier and Type | Field and Description |
---|---|
private static Set<TableName> |
TableName.tableCache
|
private Map<TableName,RegionStatesCount> |
ClusterMetricsBuilder.tableRegionStatesCount |
private Map<TableName,RegionStatesCount> |
ClusterMetricsBuilder.ClusterMetricsImpl.tableRegionStatesCount |
Modifier and Type | Method and Description |
---|---|
private static TableName |
TableName.createTableNameIfNecessary(ByteBuffer bns,
ByteBuffer qns)
Check that the object does not exist already.
|
private static TableName |
TableName.getADummyTableName(String qualifier)
It is used to create table names for old META, and ROOT table.
|
TableName |
HRegionInfo.getTable()
Deprecated.
Get current table name of the region
|
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 |
---|---|
Map<TableName,RegionStatesCount> |
ClusterMetricsBuilder.ClusterMetricsImpl.getTableRegionStatesCount() |
Map<TableName,RegionStatesCount> |
ClusterMetrics.getTableRegionStatesCount()
Provide region states count for given table.
|
Map<TableName,RegionStatesCount> |
ClusterStatus.getTableRegionStatesCount()
Deprecated.
|
static Map<TableName,TableState> |
MetaTableAccessor.getTableStates(Connection conn)
Fetch table states from META table
|
Modifier and Type | Method and Description |
---|---|
int |
TableName.compareTo(TableName tableName)
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) |
static CellComparator |
CellComparatorImpl.getCellComparator(TableName tableName)
Utility method that makes a guess at comparator to use based off passed tableName.
|
private static RegionInfo |
MetaTableAccessor.getClosestRegionInfo(Connection connection,
TableName tableName,
byte[] row) |
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 CompletableFuture<List<HRegionLocation>> |
AsyncMetaTableAccessor.getTableHRegionLocations(AsyncTable<AdvancedScanResultConsumer> metaTable,
TableName tableName)
Used to get all region locations for the specific table.
|
static List<RegionInfo> |
MetaTableAccessor.getTableRegions(Connection connection,
TableName tableName)
Gets all of the regions of the specified table.
|
static List<RegionInfo> |
MetaTableAccessor.getTableRegions(Connection connection,
TableName tableName,
boolean excludeOfflinedSplitParents)
Gets all of the regions of the specified table.
|
private static CompletableFuture<List<Pair<RegionInfo,ServerName>>> |
AsyncMetaTableAccessor.getTableRegionsAndLocations(AsyncTable<AdvancedScanResultConsumer> metaTable,
TableName tableName,
boolean excludeOfflinedSplitParents)
Used to get table regions' info and server.
|
static List<Pair<RegionInfo,ServerName>> |
MetaTableAccessor.getTableRegionsAndLocations(Connection connection,
TableName tableName)
Do not use this method to get meta table regions, use methods in MetaTableLocator instead.
|
static List<Pair<RegionInfo,ServerName>> |
MetaTableAccessor.getTableRegionsAndLocations(Connection connection,
TableName tableName,
boolean excludeOfflinedSplitParents)
Do not use this method to get meta table regions, use methods in MetaTableLocator instead.
|
static byte[] |
MetaTableAccessor.getTableStartRowForMeta(TableName tableName,
MetaTableAccessor.QueryType type) |
private static byte[] |
AsyncMetaTableAccessor.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) |
private static byte[] |
AsyncMetaTableAccessor.getTableStopRowForMeta(TableName tableName,
MetaTableAccessor.QueryType type) |
static boolean |
TableName.isMetaTableName(TableName tn) |
TableDescriptor |
TableDescriptors.remove(TableName tablename) |
private static CompletableFuture<Void> |
AsyncMetaTableAccessor.scanMeta(AsyncTable<AdvancedScanResultConsumer> metaTable,
TableName tableName,
MetaTableAccessor.QueryType type,
MetaTableAccessor.Visitor visitor)
Performs a scan of META table for given table.
|
static void |
MetaTableAccessor.scanMeta(Connection connection,
MetaTableAccessor.Visitor visitor,
TableName tableName,
byte[] row,
int rowLimit)
Performs a scan of META table for given table starting from given row.
|
private static void |
MetaTableAccessor.scanMeta(Connection connection,
TableName table,
MetaTableAccessor.QueryType type,
int maxRows,
MetaTableAccessor.Visitor visitor) |
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
Do not use.
|
Modifier and Type | Method and Description |
---|---|
ClusterMetricsBuilder |
ClusterMetricsBuilder.setTableRegionStatesCount(Map<TableName,RegionStatesCount> tableRegionStatesCount) |
Constructor and Description |
---|
ConcurrentTableModificationException(TableName tableName) |
HRegionInfo(long regionId,
TableName tableName)
Deprecated.
Private constructor used constructing HRegionInfo for the
first meta regions
|
HRegionInfo(long regionId,
TableName tableName,
int replicaId)
Deprecated.
|
HRegionInfo(TableName tableName)
Deprecated.
|
HRegionInfo(TableName tableName,
byte[] startKey,
byte[] endKey)
Deprecated.
Construct HRegionInfo with explicit parameters
|
HRegionInfo(TableName tableName,
byte[] startKey,
byte[] endKey,
boolean split)
Deprecated.
Construct HRegionInfo with explicit parameters
|
HRegionInfo(TableName tableName,
byte[] startKey,
byte[] endKey,
boolean split,
long regionid)
Deprecated.
Construct HRegionInfo with explicit parameters
|
HRegionInfo(TableName tableName,
byte[] startKey,
byte[] endKey,
boolean split,
long regionid,
int replicaId)
Deprecated.
Construct HRegionInfo with explicit parameters
|
HTableDescriptor(TableName name)
Deprecated.
Construct a table descriptor specifying a TableName object
|
HTableDescriptor(TableName name,
HTableDescriptor desc)
Deprecated.
Construct a table descriptor by cloning the descriptor passed as a parameter
but using a different table name.
|
TableExistsException(TableName tableName) |
TableNotDisabledException(TableName tableName) |
TableNotEnabledException(TableName tableName) |
TableNotFoundException(TableName tableName) |
TableVisitorBase(TableName tableName) |
Constructor and Description |
---|
ClusterMetricsImpl(String hbaseVersion,
List<ServerName> deadServerNames,
Map<ServerName,ServerMetrics> liveServerMetrics,
ServerName masterName,
List<ServerName> backupMasterNames,
List<RegionState> regionsInTransition,
String clusterId,
List<String> masterCoprocessorNames,
Boolean balancerOn,
int masterInfoPort,
List<ServerName> serversName,
Map<TableName,RegionStatesCount> tableRegionStatesCount) |
Modifier and Type | Field and Description |
---|---|
private TableName |
TableDescriptorBuilder.ModifyableTableDescriptor.name |
private TableName |
SnapshotDescription.table |
private TableName |
RegionCoprocessorRpcChannel.table |
private TableName |
HBaseAdmin.TableFuture.tableName |
protected TableName |
RpcRetryingCallerWithReadReplicas.tableName |
private TableName |
BufferedMutatorImpl.tableName |
private TableName |
AsyncClientScanner.tableName |
private TableName |
AsyncTableRegionLocatorImpl.tableName |
protected TableName |
RawAsyncHBaseAdmin.TableProcedureBiConsumer.tableName |
private TableName |
TableState.tableName |
private TableName |
RegionServerCallable.tableName |
private TableName |
AsyncSingleRequestRpcRetryingCaller.tableName |
private TableName |
AsyncProcessTask.tableName |
private TableName |
AsyncProcessTask.Builder.tableName |
protected TableName |
TableBuilderBase.tableName |
private TableName |
AsyncRequestFutureImpl.tableName |
private TableName |
HRegionLocator.tableName |
private TableName |
ScannerCallableWithReplicas.tableName |
protected TableName |
AsyncTableBuilderBase.tableName |
private TableName |
AsyncBatchRpcRetryingCaller.tableName |
protected TableName |
ClientScanner.tableName |
private TableName |
RegionCoprocessorRpcChannelImpl.tableName |
private TableName |
BufferedMutatorParams.tableName |
private TableName |
RawAsyncTableImpl.tableName |
private TableName |
AsyncRpcRetryingCallerFactory.SingleRequestCallerBuilder.tableName |
private TableName |
AsyncRpcRetryingCallerFactory.BatchCallerBuilder.tableName |
private TableName |
RegionInfoBuilder.tableName |
private TableName |
RegionInfoBuilder.MutableRegionInfo.tableName |
protected TableName |
RegionAdminServiceCallable.tableName |
private TableName |
HTable.tableName |
Modifier and Type | Field and Description |
---|---|
private ConcurrentMap<TableName,AsyncNonMetaRegionLocator.TableCache> |
AsyncNonMetaRegionLocator.cache |
private ConcurrentMap<TableName,ConcurrentNavigableMap<byte[],RegionLocations>> |
MetaCache.cachedRegionLocations
Map of table to table
HRegionLocation s. |
Modifier and Type | Method and Description |
---|---|
private TableName |
HBaseAdmin.checkTableExists(TableName tableName)
Check if table exists or not
|
private static TableName |
RegionInfoBuilder.MutableRegionInfo.checkTableName(TableName tableName) |
TableName |
BufferedMutatorImpl.getName() |
TableName |
AsyncBufferedMutatorImpl.getName() |
TableName |
AsyncTableRegionLocatorImpl.getName() |
TableName |
AsyncBufferedMutator.getName()
Gets the fully qualified table name instance of the table that this
AsyncBufferedMutator writes to. |
TableName |
RegionLocator.getName()
Gets the fully qualified table name instance of this table.
|
TableName |
HRegionLocator.getName() |
TableName |
AsyncTable.getName()
Gets the fully qualified table name instance of this table.
|
TableName |
Table.getName()
Gets the fully qualified table name instance of this table.
|
TableName |
AsyncTableRegionLocator.getName()
Gets the fully qualified table name instance of the table whose region we want to locate.
|
TableName |
BufferedMutator.getName()
Gets the fully qualified table name instance of the table that this BufferedMutator writes to.
|
TableName |
RawAsyncTableImpl.getName() |
TableName |
AsyncTableImpl.getName() |
TableName |
HTable.getName() |
TableName |
RegionInfo.getTable() |
protected TableName |
ClientScanner.getTable() |
TableName |
RegionInfoBuilder.MutableRegionInfo.getTable()
Get current table name of the region
|
static TableName |
RegionInfo.getTable(byte[] regionName)
Gets the table name from the specified region name.
|
TableName |
TableDescriptorBuilder.ModifyableTableDescriptor.getTableName()
Get the name of the table
|
protected TableName |
HBaseAdmin.TableFuture.getTableName() |
TableName |
SnapshotDescription.getTableName() |
TableName |
TableState.getTableName()
Table name for state
|
TableName |
RegionServerCallable.getTableName() |
TableName |
AsyncProcessTask.getTableName() |
TableName |
TableDescriptor.getTableName()
Get the name of the table
|
TableName |
BufferedMutatorParams.getTableName() |
private TableName |
HBaseAdmin.getTableNameBeforeRestoreSnapshot(String snapshotName)
Check whether the snapshot exists and contains disabled table
|
TableName[] |
HBaseAdmin.listTableNames() |
TableName[] |
Admin.listTableNames()
List all of the names of userspace tables.
|
default 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 |
---|---|
private CompletableFuture<TableName> |
RawAsyncHBaseAdmin.checkRegionsAndGetTableName(byte[][] encodedRegionNames) |
Map<TableName,SpaceQuotaSnapshot> |
HBaseAdmin.getRegionServerSpaceQuotaSnapshots(ServerName serverName) |
Map<TableName,? extends SpaceQuotaSnapshotView> |
Admin.getRegionServerSpaceQuotaSnapshots(ServerName serverName)
Fetches the observed
SpaceQuotaSnapshotView s observed by a RegionServer. |
CompletableFuture<? extends Map<TableName,? extends SpaceQuotaSnapshotView>> |
AsyncAdmin.getRegionServerSpaceQuotaSnapshots(ServerName serverName)
Fetches the observed
SpaceQuotaSnapshotView s observed by a RegionServer. |
CompletableFuture<Map<TableName,SpaceQuotaSnapshot>> |
RawAsyncHBaseAdmin.getRegionServerSpaceQuotaSnapshots(ServerName serverName) |
CompletableFuture<Map<TableName,SpaceQuotaSnapshot>> |
AsyncHBaseAdmin.getRegionServerSpaceQuotaSnapshots(ServerName serverName) |
Map<TableName,Long> |
HBaseAdmin.getSpaceQuotaTableSizes() |
Map<TableName,Long> |
Admin.getSpaceQuotaTableSizes()
Fetches the table sizes on the filesystem as tracked by the HBase Master.
|
CompletableFuture<Map<TableName,Long>> |
AsyncAdmin.getSpaceQuotaTableSizes()
Fetches the table sizes on the filesystem as tracked by the HBase Master.
|
CompletableFuture<Map<TableName,Long>> |
RawAsyncHBaseAdmin.getSpaceQuotaTableSizes() |
CompletableFuture<Map<TableName,Long>> |
AsyncHBaseAdmin.getSpaceQuotaTableSizes() |
protected Optional<TableName> |
AsyncSingleRequestRpcRetryingCaller.getTableName() |
protected Optional<TableName> |
AsyncRpcRetryingCaller.getTableName() |
private CompletableFuture<List<TableName>> |
RawAsyncHBaseAdmin.getTableNames(org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.GetTableNamesRequest request) |
default CompletableFuture<List<TableName>> |
AsyncAdmin.listTableNames()
List all of the names of userspace tables.
|
CompletableFuture<List<TableName>> |
AsyncAdmin.listTableNames(boolean includeSysTables)
List all of the names of tables.
|
CompletableFuture<List<TableName>> |
RawAsyncHBaseAdmin.listTableNames(boolean includeSysTables) |
CompletableFuture<List<TableName>> |
AsyncHBaseAdmin.listTableNames(boolean includeSysTables) |
CompletableFuture<List<TableName>> |
AsyncAdmin.listTableNames(Pattern pattern,
boolean includeSysTables)
List all of the names of userspace tables.
|
CompletableFuture<List<TableName>> |
RawAsyncHBaseAdmin.listTableNames(Pattern pattern,
boolean includeSysTables) |
CompletableFuture<List<TableName>> |
AsyncHBaseAdmin.listTableNames(Pattern pattern,
boolean includeSysTables) |
CompletableFuture<List<TableName>> |
AsyncAdmin.listTableNamesByNamespace(String name)
Get list of table names by namespace.
|
CompletableFuture<List<TableName>> |
RawAsyncHBaseAdmin.listTableNamesByNamespace(String name) |
CompletableFuture<List<TableName>> |
AsyncHBaseAdmin.listTableNamesByNamespace(String name) |
Modifier and Type | Method and Description |
---|---|
default void |
Admin.addColumn(TableName tableName,
ColumnFamilyDescriptor columnFamily)
Deprecated.
As of release 2.0.0.
This will be removed in HBase 3.0.0.
Use
Admin.addColumnFamily(TableName, ColumnFamilyDescriptor) . |
default void |
Admin.addColumnFamily(TableName tableName,
ColumnFamilyDescriptor columnFamily)
Add a column family to an existing table.
|
CompletableFuture<Void> |
AsyncAdmin.addColumnFamily(TableName tableName,
ColumnFamilyDescriptor columnFamily)
Add a column family to an existing table.
|
CompletableFuture<Void> |
RawAsyncHBaseAdmin.addColumnFamily(TableName tableName,
ColumnFamilyDescriptor columnFamily) |
CompletableFuture<Void> |
AsyncHBaseAdmin.addColumnFamily(TableName tableName,
ColumnFamilyDescriptor columnFamily) |
Future<Void> |
HBaseAdmin.addColumnFamilyAsync(TableName tableName,
ColumnFamilyDescriptor columnFamily) |
Future<Void> |
Admin.addColumnFamilyAsync(TableName tableName,
ColumnFamilyDescriptor columnFamily)
Add a column family to an existing table.
|
void |
ClusterConnection.cacheLocation(TableName tableName,
RegionLocations location) |
void |
ConnectionImplementation.cacheLocation(TableName tableName,
RegionLocations location)
Put a newly discovered HRegionLocation into the cache.
|
void |
MetaCache.cacheLocation(TableName tableName,
RegionLocations locations)
Put a newly discovered HRegionLocation into the cache.
|
private void |
ConnectionImplementation.cacheLocation(TableName tableName,
ServerName source,
HRegionLocation location)
Put a newly discovered HRegionLocation into the cache.
|
void |
MetaCache.cacheLocation(TableName tableName,
ServerName source,
HRegionLocation location)
Put a newly discovered HRegionLocation into the cache.
|
(package private) static int |
ConnectionUtils.calcPriority(int priority,
TableName tableName)
Select the priority for the rpc call.
|
private void |
HBaseAdmin.checkAndSyncTableDescToPeers(TableName tableName,
byte[][] splits)
Connect to peer and check the table descriptor on peer:
Create the same table on peer when not exist.
Throw an exception if the table already has replication enabled on any of the column
families.
Throw an exception if the table exists on peer cluster but descriptors are not same.
|
private CompletableFuture<Void> |
RawAsyncHBaseAdmin.checkAndSyncTableToPeerClusters(TableName tableName,
byte[][] splits)
Connect to peer and check the table descriptor on peer:
Create the same table on peer when not exist.
Throw an exception if the table already has replication enabled on any of the column
families.
Throw an exception if the table exists on peer cluster but descriptors are not same.
|
private TableName |
HBaseAdmin.checkTableExists(TableName tableName)
Check if table exists or not
|
private static TableName |
RegionInfoBuilder.MutableRegionInfo.checkTableName(TableName tableName) |
CacheEvictionStats |
HBaseAdmin.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.
|
CompletableFuture<CacheEvictionStats> |
AsyncAdmin.clearBlockCache(TableName tableName)
Clear all the blocks corresponding to this table from BlockCache.
|
CompletableFuture<CacheEvictionStats> |
RawAsyncHBaseAdmin.clearBlockCache(TableName tableName) |
CompletableFuture<CacheEvictionStats> |
AsyncHBaseAdmin.clearBlockCache(TableName tableName) |
(package private) void |
AsyncRegionLocator.clearCache(TableName tableName) |
(package private) void |
AsyncNonMetaRegionLocator.clearCache(TableName tableName) |
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 |
ConnectionImplementation.clearRegionCache(TableName tableName) |
void |
ConnectionImplementation.clearRegionCache(TableName tableName,
byte[] row) |
default void |
Admin.cloneSnapshot(byte[] snapshotName,
TableName tableName)
Deprecated.
since 2.3.0, will be removed in 3.0.0. Use
Admin.cloneSnapshot(String, TableName) instead. |
default void |
Admin.cloneSnapshot(String snapshotName,
TableName tableName)
Create a new table by cloning the snapshot content.
|
default CompletableFuture<Void> |
AsyncAdmin.cloneSnapshot(String snapshotName,
TableName tableName)
Create a new table by cloning the snapshot content.
|
default void |
Admin.cloneSnapshot(String snapshotName,
TableName tableName,
boolean restoreAcl)
Create a new table by cloning the snapshot content.
|
CompletableFuture<Void> |
AsyncAdmin.cloneSnapshot(String snapshotName,
TableName tableName,
boolean restoreAcl)
Create a new table by cloning the snapshot content.
|
CompletableFuture<Void> |
RawAsyncHBaseAdmin.cloneSnapshot(String snapshotName,
TableName tableName,
boolean restoreAcl) |
CompletableFuture<Void> |
AsyncHBaseAdmin.cloneSnapshot(String snapshotName,
TableName tableName,
boolean restoreAcl) |
default Future<Void> |
Admin.cloneSnapshotAsync(String snapshotName,
TableName tableName)
Create a new table by cloning the snapshot content, but does not block and wait for it to be
completely cloned.
|
Future<Void> |
HBaseAdmin.cloneSnapshotAsync(String snapshotName,
TableName tableName,
boolean restoreAcl) |
Future<Void> |
Admin.cloneSnapshotAsync(String snapshotName,
TableName tableName,
boolean restoreAcl)
Create a new table by cloning the snapshot content.
|
void |
HBaseAdmin.cloneTableSchema(TableName tableName,
TableName newTableName,
boolean preserveSplits) |
void |
Admin.cloneTableSchema(TableName tableName,
TableName newTableName,
boolean preserveSplits)
Create a new table by cloning the existent table schema.
|
CompletableFuture<Void> |
AsyncAdmin.cloneTableSchema(TableName tableName,
TableName newTableName,
boolean preserveSplits)
Create a new table by cloning the existent table schema.
|
CompletableFuture<Void> |
RawAsyncHBaseAdmin.cloneTableSchema(TableName tableName,
TableName newTableName,
boolean preserveSplits) |
CompletableFuture<Void> |
AsyncHBaseAdmin.cloneTableSchema(TableName tableName,
TableName newTableName,
boolean preserveSplits) |
void |
HBaseAdmin.compact(TableName tableName)
Compact a table.
|
void |
Admin.compact(TableName tableName)
Compact a table.
|
default CompletableFuture<Void> |
AsyncAdmin.compact(TableName tableName)
Compact a table.
|
void |
HBaseAdmin.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.
|
default CompletableFuture<Void> |
AsyncAdmin.compact(TableName tableName,
byte[] columnFamily)
Compact a column family within a table.
|
private void |
HBaseAdmin.compact(TableName tableName,
byte[] columnFamily,
boolean major,
CompactType compactType)
Compact a table.
|
private CompletableFuture<Void> |
RawAsyncHBaseAdmin.compact(TableName tableName,
byte[] columnFamily,
boolean major,
CompactType compactType)
Compact column family of a table, Asynchronous operation even if CompletableFuture.get()
|
void |
HBaseAdmin.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.
|
CompletableFuture<Void> |
AsyncAdmin.compact(TableName tableName,
byte[] columnFamily,
CompactType compactType)
Compact a column family within a table.
|
CompletableFuture<Void> |
RawAsyncHBaseAdmin.compact(TableName tableName,
byte[] columnFamily,
CompactType compactType) |
CompletableFuture<Void> |
AsyncHBaseAdmin.compact(TableName tableName,
byte[] columnFamily,
CompactType compactType) |
void |
HBaseAdmin.compact(TableName tableName,
CompactType compactType)
Compact a table.
|
void |
Admin.compact(TableName tableName,
CompactType compactType)
Compact a table.
|
CompletableFuture<Void> |
AsyncAdmin.compact(TableName tableName,
CompactType compactType)
Compact a table.
|
CompletableFuture<Void> |
RawAsyncHBaseAdmin.compact(TableName tableName,
CompactType compactType) |
CompletableFuture<Void> |
AsyncHBaseAdmin.compact(TableName tableName,
CompactType compactType) |
private CompletableFuture<Void> |
RawAsyncHBaseAdmin.compareTableWithPeerCluster(TableName tableName,
TableDescriptor tableDesc,
ReplicationPeerDescription peer,
AsyncAdmin peerAdmin) |
private void |
AsyncNonMetaRegionLocator.complete(TableName tableName,
AsyncNonMetaRegionLocator.LocateRequest req,
RegionLocations locs,
Throwable error) |
private static CompletableFuture<Boolean> |
RawAsyncHBaseAdmin.completeCheckTableState(CompletableFuture<Boolean> future,
TableState tableState,
Throwable error,
TableState.State targetState,
TableName tableName)
Utility for completing passed TableState
CompletableFuture future
using passed parameters. |
static TableState |
TableState.convert(TableName tableName,
org.apache.hadoop.hbase.shaded.protobuf.generated.HBaseProtos.TableState tableState)
Covert from PB version of TableState
|
static TableDescriptor |
TableDescriptorBuilder.copy(TableName name,
TableDescriptor desc) |
private MultiServerCallable |
AsyncRequestFutureImpl.createCallable(ServerName server,
TableName tableName,
MultiAction multi)
Create a callable.
|
static RegionInfo |
RegionInfo.createMobRegionInfo(TableName tableName)
Creates a RegionInfo object for MOB data.
|
static byte[] |
RegionInfo.createRegionName(TableName tableName,
byte[] startKey,
byte[] id,
boolean newFormat)
Make a region name of passed parameters.
|
static byte[] |
RegionInfo.createRegionName(TableName tableName,
byte[] startKey,
byte[] id,
int replicaId,
boolean newFormat)
Make a region name of passed parameters.
|
static byte[] |
RegionInfo.createRegionName(TableName tableName,
byte[] startKey,
long regionid,
boolean newFormat)
Make a region name of passed parameters.
|
static byte[] |
RegionInfo.createRegionName(TableName tableName,
byte[] startKey,
long regionid,
int replicaId,
boolean newFormat)
Make a region name of passed parameters.
|
static byte[] |
RegionInfo.createRegionName(TableName tableName,
byte[] startKey,
String id,
boolean newFormat)
Make a region name of passed parameters.
|
private CompletableFuture<Void> |
RawAsyncHBaseAdmin.createTable(TableName tableName,
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.CreateTableRequest request) |
void |
HBaseAdmin.deleteColumn(TableName tableName,
byte[] columnFamily)
Deprecated.
Since 2.0. Will be removed in 3.0. Use
Admin.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[]) }. |
default void |
Admin.deleteColumnFamily(TableName tableName,
byte[] columnFamily)
Delete a column family from a table.
|
CompletableFuture<Void> |
AsyncAdmin.deleteColumnFamily(TableName tableName,
byte[] columnFamily)
Delete a column family from a table.
|
CompletableFuture<Void> |
RawAsyncHBaseAdmin.deleteColumnFamily(TableName tableName,
byte[] columnFamily) |
CompletableFuture<Void> |
AsyncHBaseAdmin.deleteColumnFamily(TableName tableName,
byte[] columnFamily) |
Future<Void> |
HBaseAdmin.deleteColumnFamilyAsync(TableName tableName,
byte[] columnFamily) |
Future<Void> |
Admin.deleteColumnFamilyAsync(TableName tableName,
byte[] columnFamily)
Delete a column family from a table.
|
default void |
Admin.deleteTable(TableName tableName)
Deletes a table.
|
CompletableFuture<Void> |
AsyncAdmin.deleteTable(TableName tableName)
Deletes a table.
|
CompletableFuture<Void> |
RawAsyncHBaseAdmin.deleteTable(TableName tableName) |
CompletableFuture<Void> |
AsyncHBaseAdmin.deleteTable(TableName tableName) |
Future<Void> |
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.
|
default void |
Admin.disableTable(TableName tableName)
Disable table and wait on completion.
|
CompletableFuture<Void> |
AsyncAdmin.disableTable(TableName tableName)
Disable a table.
|
CompletableFuture<Void> |
RawAsyncHBaseAdmin.disableTable(TableName tableName) |
CompletableFuture<Void> |
AsyncHBaseAdmin.disableTable(TableName tableName) |
Future<Void> |
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) |
void |
Admin.disableTableReplication(TableName tableName)
Disable a table's replication switch.
|
CompletableFuture<Void> |
AsyncAdmin.disableTableReplication(TableName tableName)
Disable a table's replication switch.
|
CompletableFuture<Void> |
RawAsyncHBaseAdmin.disableTableReplication(TableName tableName) |
CompletableFuture<Void> |
AsyncHBaseAdmin.disableTableReplication(TableName tableName) |
static <R> void |
HTable.doBatchWithCallback(List<? extends Row> actions,
Object[] results,
Batch.Callback<R> callback,
ClusterConnection connection,
ExecutorService pool,
TableName tableName) |
default void |
Admin.enableTable(TableName tableName)
Enable a table.
|
CompletableFuture<Void> |
AsyncAdmin.enableTable(TableName tableName)
Enable a table.
|
CompletableFuture<Void> |
RawAsyncHBaseAdmin.enableTable(TableName tableName) |
CompletableFuture<Void> |
AsyncHBaseAdmin.enableTable(TableName tableName) |
Future<Void> |
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) |
void |
Admin.enableTableReplication(TableName tableName)
Enable a table's replication switch.
|
CompletableFuture<Void> |
AsyncAdmin.enableTableReplication(TableName tableName)
Enable a table's replication switch.
|
CompletableFuture<Void> |
RawAsyncHBaseAdmin.enableTableReplication(TableName tableName) |
CompletableFuture<Void> |
AsyncHBaseAdmin.enableTableReplication(TableName tableName) |
void |
HBaseAdmin.flush(TableName tableName) |
void |
Admin.flush(TableName tableName)
Flush a table.
|
CompletableFuture<Void> |
AsyncAdmin.flush(TableName tableName)
Flush a table.
|
CompletableFuture<Void> |
RawAsyncHBaseAdmin.flush(TableName tableName) |
CompletableFuture<Void> |
AsyncHBaseAdmin.flush(TableName tableName) |
private static int |
RegionInfoBuilder.MutableRegionInfo.generateHashCode(TableName tableName,
byte[] startKey,
byte[] endKey,
long regionId,
int replicaId,
boolean offLine,
byte[] regionName) |
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 |
ConnectionImplementation.getBufferedMutator(TableName tableName) |
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 |
AsyncConnectionImpl.getBufferedMutatorBuilder(TableName tableName) |
AsyncBufferedMutatorBuilder |
AsyncConnection.getBufferedMutatorBuilder(TableName tableName,
ExecutorService pool)
Returns an
AsyncBufferedMutatorBuilder for creating AsyncBufferedMutator . |
AsyncBufferedMutatorBuilder |
AsyncConnectionImpl.getBufferedMutatorBuilder(TableName tableName,
ExecutorService pool) |
(package private) RegionLocations |
ConnectionImplementation.getCachedLocation(TableName tableName,
byte[] row)
Search the cache for a location that fits our table and row key.
|
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) |
CompactionState |
Admin.getCompactionState(TableName tableName)
Get the current compaction state of a table.
|
default CompletableFuture<CompactionState> |
AsyncAdmin.getCompactionState(TableName tableName)
Get the current compaction state of a table.
|
CompactionState |
HBaseAdmin.getCompactionState(TableName tableName,
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.
|
CompletableFuture<CompactionState> |
AsyncAdmin.getCompactionState(TableName tableName,
CompactType compactType)
Get the current compaction state of a table.
|
CompletableFuture<CompactionState> |
RawAsyncHBaseAdmin.getCompactionState(TableName tableName,
CompactType compactType) |
CompletableFuture<CompactionState> |
AsyncHBaseAdmin.getCompactionState(TableName tableName,
CompactType compactType) |
SpaceQuotaSnapshot |
HBaseAdmin.getCurrentSpaceQuotaSnapshot(TableName tableName) |
SpaceQuotaSnapshotView |
Admin.getCurrentSpaceQuotaSnapshot(TableName tableName)
Returns the Master's view of a quota on the given
tableName or null if the Master has
no quota information on that table. |
CompletableFuture<? extends SpaceQuotaSnapshotView> |
AsyncAdmin.getCurrentSpaceQuotaSnapshot(TableName tableName)
Returns the Master's view of a quota on the given
tableName or null if the Master has
no quota information on that table. |
CompletableFuture<SpaceQuotaSnapshot> |
RawAsyncHBaseAdmin.getCurrentSpaceQuotaSnapshot(TableName tableName) |
CompletableFuture<SpaceQuotaSnapshot> |
AsyncHBaseAdmin.getCurrentSpaceQuotaSnapshot(TableName tableName) |
TableDescriptor |
HBaseAdmin.getDescriptor(TableName tableName) |
TableDescriptor |
Admin.getDescriptor(TableName tableName)
Get a table descriptor.
|
CompletableFuture<TableDescriptor> |
AsyncAdmin.getDescriptor(TableName tableName)
Method for getting the tableDescriptor
|
CompletableFuture<TableDescriptor> |
RawAsyncHBaseAdmin.getDescriptor(TableName tableName) |
CompletableFuture<TableDescriptor> |
AsyncHBaseAdmin.getDescriptor(TableName tableName) |
(package private) static HTableDescriptor |
HBaseAdmin.getHTableDescriptor(TableName tableName,
Connection connection,
RpcRetryingCallerFactory rpcCallerFactory,
RpcControllerFactory rpcControllerFactory,
int operationTimeout,
int rpcTimeout)
Deprecated.
since 2.0 version and will be removed in 3.0 version.
use
HBaseAdmin.getTableDescriptor(TableName,
Connection, RpcRetryingCallerFactory,RpcControllerFactory,int,int) |
long |
HBaseAdmin.getLastMajorCompactionTimestamp(TableName tableName) |
long |
Admin.getLastMajorCompactionTimestamp(TableName tableName)
Get the timestamp of the last major compaction for the passed table
The timestamp of the oldest HFile resulting from a major compaction of that table,
or 0 if no such HFile could be found.
|
CompletableFuture<Optional<Long>> |
AsyncAdmin.getLastMajorCompactionTimestamp(TableName tableName)
Get the timestamp of the last major compaction for the passed table.
|
CompletableFuture<Optional<Long>> |
RawAsyncHBaseAdmin.getLastMajorCompactionTimestamp(TableName tableName) |
CompletableFuture<Optional<Long>> |
AsyncHBaseAdmin.getLastMajorCompactionTimestamp(TableName tableName) |
private Consumer<Long> |
AsyncProcess.getLogger(TableName tableName,
long max) |
(package private) int |
ConnectionImplementation.getNumberOfCachedRegionLocations(TableName tableName) |
int |
MetaCache.getNumberOfCachedRegionLocations(TableName tableName)
Return the number of cached region for a table.
|
(package private) static int |
ConnectionUtils.getPriority(TableName tableName) |
HRegionLocation |
ClusterConnection.getRegionLocation(TableName tableName,
byte[] row,
boolean reload)
Find region location hosting passed row
|
HRegionLocation |
ConnectionImplementation.getRegionLocation(TableName tableName,
byte[] row,
boolean reload) |
(package private) CompletableFuture<HRegionLocation> |
AsyncRegionLocator.getRegionLocation(TableName tableName,
byte[] row,
int replicaId,
RegionLocateType type,
boolean reload,
long timeoutNs) |
(package private) CompletableFuture<HRegionLocation> |
AsyncRegionLocator.getRegionLocation(TableName tableName,
byte[] row,
int replicaId,
RegionLocateType type,
long timeoutNs) |
(package private) CompletableFuture<HRegionLocation> |
AsyncRegionLocator.getRegionLocation(TableName tableName,
byte[] row,
RegionLocateType type,
boolean reload,
long timeoutNs) |
(package private) CompletableFuture<HRegionLocation> |
AsyncRegionLocator.getRegionLocation(TableName tableName,
byte[] row,
RegionLocateType type,
long timeoutNs) |
(package private) RegionLocations |
AsyncNonMetaRegionLocator.getRegionLocationInCache(TableName tableName,
byte[] row) |
(package private) static RegionLocations |
RpcRetryingCallerWithReadReplicas.getRegionLocations(boolean useCache,
int replicaId,
ClusterConnection cConnection,
TableName tableName,
byte[] row) |
static RegionLocations |
RegionAdminServiceCallable.getRegionLocations(ClusterConnection connection,
TableName tableName,
byte[] row,
boolean useCache,
int replicaId) |
(package private) CompletableFuture<RegionLocations> |
AsyncNonMetaRegionLocator.getRegionLocations(TableName tableName,
byte[] row,
int replicaId,
RegionLocateType locateType,
boolean reload) |
(package private) CompletableFuture<RegionLocations> |
AsyncRegionLocator.getRegionLocations(TableName tableName,
byte[] row,
RegionLocateType type,
boolean reload,
long timeoutNs) |
private CompletableFuture<RegionLocations> |
AsyncNonMetaRegionLocator.getRegionLocationsInternal(TableName tableName,
byte[] row,
int replicaId,
RegionLocateType locateType,
boolean reload) |
AsyncTableRegionLocator |
AsyncConnection.getRegionLocator(TableName tableName)
Retrieve a AsyncRegionLocator implementation to inspect region information on a table.
|
RegionLocator |
ConnectionImplementation.getRegionLocator(TableName tableName) |
RegionLocator |
Connection.getRegionLocator(TableName tableName)
Retrieve a RegionLocator implementation to inspect region information on a table.
|
AsyncTableRegionLocator |
AsyncConnectionImpl.getRegionLocator(TableName tableName) |
List<RegionMetrics> |
HBaseAdmin.getRegionMetrics(ServerName serverName,
TableName tableName) |
List<RegionMetrics> |
Admin.getRegionMetrics(ServerName serverName,
TableName tableName)
Get
RegionMetrics of all regions hosted on a regionserver for a table. |
CompletableFuture<List<RegionMetrics>> |
AsyncAdmin.getRegionMetrics(ServerName serverName,
TableName tableName)
Get a list of
RegionMetrics of all regions hosted on a region seerver for a table. |
CompletableFuture<List<RegionMetrics>> |
RawAsyncHBaseAdmin.getRegionMetrics(ServerName serverName,
TableName tableName) |
CompletableFuture<List<RegionMetrics>> |
AsyncHBaseAdmin.getRegionMetrics(ServerName serverName,
TableName tableName) |
List<RegionInfo> |
HBaseAdmin.getRegions(TableName tableName) |
List<RegionInfo> |
Admin.getRegions(TableName tableName)
Get the regions of a given table.
|
CompletableFuture<List<RegionInfo>> |
AsyncAdmin.getRegions(TableName tableName)
Get the regions of a given table.
|
CompletableFuture<List<RegionInfo>> |
RawAsyncHBaseAdmin.getRegions(TableName tableName) |
CompletableFuture<List<RegionInfo>> |
AsyncHBaseAdmin.getRegions(TableName tableName) |
default AsyncTable<AdvancedScanResultConsumer> |
AsyncConnection.getTable(TableName tableName)
Retrieve an
AsyncTable implementation for accessing a table. |
Table |
ConnectionImplementation.getTable(TableName tableName) |
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<AdvancedScanResultConsumer> |
AsyncConnectionImpl.getTableBuilder(TableName tableName) |
AsyncTableBuilder<ScanResultConsumer> |
AsyncConnection.getTableBuilder(TableName tableName,
ExecutorService pool)
Returns an
AsyncTableBuilder for creating AsyncTable . |
TableBuilder |
ConnectionImplementation.getTableBuilder(TableName tableName,
ExecutorService pool) |
TableBuilder |
Connection.getTableBuilder(TableName tableName,
ExecutorService pool)
Returns an
TableBuilder for creating Table . |
AsyncTableBuilder<ScanResultConsumer> |
AsyncConnectionImpl.getTableBuilder(TableName tableName,
ExecutorService pool) |
private AsyncNonMetaRegionLocator.TableCache |
AsyncNonMetaRegionLocator.getTableCache(TableName tableName) |
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) . |
(package private) static TableDescriptor |
HBaseAdmin.getTableDescriptor(TableName tableName,
Connection connection,
RpcRetryingCallerFactory rpcCallerFactory,
RpcControllerFactory rpcControllerFactory,
int operationTimeout,
int rpcTimeout) |
private CompletableFuture<List<HRegionLocation>> |
RawAsyncHBaseAdmin.getTableHRegionLocations(TableName tableName)
List all region locations for the specific table.
|
private ConcurrentNavigableMap<byte[],RegionLocations> |
MetaCache.getTableLocations(TableName tableName) |
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) . |
private byte[][] |
HBaseAdmin.getTableSplits(TableName tableName) |
private CompletableFuture<byte[][]> |
RawAsyncHBaseAdmin.getTableSplits(TableName tableName) |
TableState |
ClusterConnection.getTableState(TableName tableName)
Retrieve TableState, represent current table state.
|
TableState |
ConnectionImplementation.getTableState(TableName tableName) |
private CompletableFuture<Void> |
RawAsyncHBaseAdmin.internalRestoreSnapshot(String snapshotName,
TableName tableName,
boolean restoreAcl) |
private Future<Void> |
HBaseAdmin.internalRestoreSnapshotAsync(String snapshotName,
TableName tableName,
boolean restoreAcl)
Execute Restore/Clone snapshot and wait for the server to complete (blocking).
|
private boolean |
AsyncRegionLocator.isMeta(TableName tableName) |
boolean |
MetaCache.isRegionCached(TableName tableName,
byte[] row)
Check the region cache to see whether a region is cached yet or not.
|
boolean |
HBaseAdmin.isTableAvailable(TableName tableName) |
boolean |
Admin.isTableAvailable(TableName tableName) |
CompletableFuture<Boolean> |
AsyncAdmin.isTableAvailable(TableName tableName) |
CompletableFuture<Boolean> |
RawAsyncHBaseAdmin.isTableAvailable(TableName tableName) |
CompletableFuture<Boolean> |
AsyncHBaseAdmin.isTableAvailable(TableName tableName) |
boolean |
ClusterConnection.isTableAvailable(TableName tableName,
byte[][] splitKeys)
Use this api to check if the table has been created with the specified number of
splitkeys which was used while creating the given table.
|
boolean |
ConnectionImplementation.isTableAvailable(TableName tableName,
byte[][] splitKeys) |
boolean |
HBaseAdmin.isTableAvailable(TableName tableName,
byte[][] splitKeys) |
boolean |
Admin.isTableAvailable(TableName tableName,
byte[][] splitKeys)
Deprecated.
Since 2.0.0. Will be removed in 3.0.0. Use
Admin.isTableAvailable(TableName) |
CompletableFuture<Boolean> |
AsyncAdmin.isTableAvailable(TableName tableName,
byte[][] splitKeys)
Deprecated.
Since 2.2.0. Will be removed in 3.0.0. Use
AsyncAdmin.isTableAvailable(TableName) |
CompletableFuture<Boolean> |
RawAsyncHBaseAdmin.isTableAvailable(TableName tableName,
byte[][] splitKeys) |
CompletableFuture<Boolean> |
AsyncHBaseAdmin.isTableAvailable(TableName tableName,
byte[][] splitKeys) |
private CompletableFuture<Boolean> |
RawAsyncHBaseAdmin.isTableAvailable(TableName tableName,
Optional<byte[][]> splitKeys) |
boolean |
ClusterConnection.isTableDisabled(TableName tableName) |
boolean |
ConnectionImplementation.isTableDisabled(TableName tableName) |
boolean |
HBaseAdmin.isTableDisabled(TableName tableName) |
boolean |
Admin.isTableDisabled(TableName tableName) |
CompletableFuture<Boolean> |
AsyncAdmin.isTableDisabled(TableName tableName) |
CompletableFuture<Boolean> |
RawAsyncHBaseAdmin.isTableDisabled(TableName tableName) |
CompletableFuture<Boolean> |
AsyncHBaseAdmin.isTableDisabled(TableName tableName) |
boolean |
ConnectionUtils.MasterlessConnection.isTableDisabled(TableName tableName) |
boolean |
ClusterConnection.isTableEnabled(TableName tableName)
A table that isTableEnabled == false and isTableDisabled == false
is possible.
|
boolean |
ConnectionImplementation.isTableEnabled(TableName tableName) |
boolean |
HBaseAdmin.isTableEnabled(TableName tableName) |
boolean |
Admin.isTableEnabled(TableName tableName) |
CompletableFuture<Boolean> |
AsyncAdmin.isTableEnabled(TableName tableName) |
CompletableFuture<Boolean> |
RawAsyncHBaseAdmin.isTableEnabled(TableName tableName) |
CompletableFuture<Boolean> |
AsyncHBaseAdmin.isTableEnabled(TableName tableName) |
private RegionLocations |
AsyncNonMetaRegionLocator.locateInCache(AsyncNonMetaRegionLocator.TableCache tableCache,
TableName tableName,
byte[] row,
int replicaId,
RegionLocateType locateType) |
private void |
AsyncNonMetaRegionLocator.locateInMeta(TableName tableName,
AsyncNonMetaRegionLocator.LocateRequest req) |
private RegionLocations |
ConnectionImplementation.locateMeta(TableName tableName,
boolean useCache,
int replicaId) |
HRegionLocation |
ClusterConnection.locateRegion(TableName tableName,
byte[] row)
Find the location of the region of tableName that row
lives in.
|
HRegionLocation |
ConnectionImplementation.locateRegion(TableName tableName,
byte[] row) |
RegionLocations |
ClusterConnection.locateRegion(TableName tableName,
byte[] row,
boolean useCache,
boolean retry) |
RegionLocations |
ConnectionImplementation.locateRegion(TableName tableName,
byte[] row,
boolean useCache,
boolean retry) |
RegionLocations |
ClusterConnection.locateRegion(TableName tableName,
byte[] row,
boolean useCache,
boolean retry,
int replicaId) |
RegionLocations |
ConnectionImplementation.locateRegion(TableName tableName,
byte[] row,
boolean useCache,
boolean retry,
int replicaId) |
private RegionLocations |
ConnectionImplementation.locateRegionInMeta(TableName tableName,
byte[] row,
boolean useCache,
boolean retry,
int replicaId)
Search the hbase:meta table for the HRegionLocation info that contains the table and row we're
seeking.
|
List<HRegionLocation> |
ClusterConnection.locateRegions(TableName tableName)
Gets the locations of all regions in the specified table, tableName.
|
List<HRegionLocation> |
ConnectionImplementation.locateRegions(TableName tableName) |
List<HRegionLocation> |
ClusterConnection.locateRegions(TableName tableName,
boolean useCache,
boolean offlined)
Gets the locations of all regions in the specified table, tableName.
|
List<HRegionLocation> |
ConnectionImplementation.locateRegions(TableName tableName,
boolean useCache,
boolean offlined) |
private RegionLocations |
AsyncNonMetaRegionLocator.locateRowBeforeInCache(AsyncNonMetaRegionLocator.TableCache tableCache,
TableName tableName,
byte[] row,
int replicaId) |
private RegionLocations |
AsyncNonMetaRegionLocator.locateRowInCache(AsyncNonMetaRegionLocator.TableCache tableCache,
TableName tableName,
byte[] row,
int replicaId) |
void |
HBaseAdmin.majorCompact(TableName tableName) |
void |
Admin.majorCompact(TableName tableName)
Major compact a table.
|
default CompletableFuture<Void> |
AsyncAdmin.majorCompact(TableName tableName)
Major compact a table.
|
void |
HBaseAdmin.majorCompact(TableName tableName,
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.
|
default CompletableFuture<Void> |
AsyncAdmin.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.
|
void |
Admin.majorCompact(TableName tableName,
byte[] columnFamily,
CompactType compactType)
Major compact a column family within a table.
|
CompletableFuture<Void> |
AsyncAdmin.majorCompact(TableName tableName,
byte[] columnFamily,
CompactType compactType)
Major compact a column family within a table.
|
CompletableFuture<Void> |
RawAsyncHBaseAdmin.majorCompact(TableName tableName,
byte[] columnFamily,
CompactType compactType) |
CompletableFuture<Void> |
AsyncHBaseAdmin.majorCompact(TableName tableName,
byte[] columnFamily,
CompactType compactType) |
void |
HBaseAdmin.majorCompact(TableName tableName,
CompactType compactType)
Major compact a table.
|
void |
Admin.majorCompact(TableName tableName,
CompactType compactType)
Major compact a table.
|
CompletableFuture<Void> |
AsyncAdmin.majorCompact(TableName tableName,
CompactType compactType)
Major compact a table.
|
CompletableFuture<Void> |
RawAsyncHBaseAdmin.majorCompact(TableName tableName,
CompactType compactType) |
CompletableFuture<Void> |
AsyncHBaseAdmin.majorCompact(TableName tableName,
CompactType compactType) |
default void |
Admin.modifyColumn(TableName tableName,
ColumnFamilyDescriptor columnFamily)
Deprecated.
As of release 2.0.0.
This will be removed in HBase 3.0.0.
Use
Admin.modifyColumnFamily(TableName, ColumnFamilyDescriptor) . |
default void |
Admin.modifyColumnFamily(TableName tableName,
ColumnFamilyDescriptor columnFamily)
Modify an existing column family on a table.
|
CompletableFuture<Void> |
AsyncAdmin.modifyColumnFamily(TableName tableName,
ColumnFamilyDescriptor columnFamily)
Modify an existing column family on a table.
|
CompletableFuture<Void> |
RawAsyncHBaseAdmin.modifyColumnFamily(TableName tableName,
ColumnFamilyDescriptor columnFamily) |
CompletableFuture<Void> |
AsyncHBaseAdmin.modifyColumnFamily(TableName tableName,
ColumnFamilyDescriptor columnFamily) |
Future<Void> |
HBaseAdmin.modifyColumnFamilyAsync(TableName tableName,
ColumnFamilyDescriptor columnFamily) |
Future<Void> |
Admin.modifyColumnFamilyAsync(TableName tableName,
ColumnFamilyDescriptor columnFamily)
Modify an existing column family on a table.
|
default void |
Admin.modifyTable(TableName tableName,
TableDescriptor td)
Deprecated.
since 2.0 version and will be removed in 3.0 version. use
Admin.modifyTable(TableDescriptor) |
default Future<Void> |
Admin.modifyTableAsync(TableName tableName,
TableDescriptor td)
Deprecated.
since 2.0 version and will be removed in 3.0 version.
use
Admin.modifyTableAsync(TableDescriptor) |
static TableDescriptorBuilder |
TableDescriptorBuilder.newBuilder(TableName name) |
static RegionInfoBuilder |
RegionInfoBuilder.newBuilder(TableName tableName) |
private boolean |
AsyncNonMetaRegionLocator.onScanNext(TableName tableName,
AsyncNonMetaRegionLocator.LocateRequest req,
Result result) |
CompletableFuture<Void> |
RawAsyncHBaseAdmin.TableOperator.operate(TableName table) |
static TableState |
TableState.parseFrom(TableName tableName,
byte[] bytes) |
AsyncRpcRetryingCallerFactory.MasterRequestCallerBuilder<T> |
AsyncRpcRetryingCallerFactory.MasterRequestCallerBuilder.priority(TableName tableName) |
private <PREQ,PRESP> |
RawAsyncHBaseAdmin.procedureCall(TableName tableName,
PREQ preq,
RawAsyncHBaseAdmin.MasterRpcCall<PRESP,PREQ> rpcCall,
RawAsyncHBaseAdmin.Converter<Long,PRESP> respConverter,
RawAsyncHBaseAdmin.ProcedureBiConsumer consumer) |
List<Put> |
HTableMultiplexer.put(TableName tableName,
List<Put> puts)
Deprecated.
The puts request will be buffered by their corresponding buffer queue.
|
boolean |
HTableMultiplexer.put(TableName tableName,
Put put)
Deprecated.
The put request will be buffered by its corresponding buffer queue.
|
boolean |
HTableMultiplexer.put(TableName tableName,
Put put,
int maxAttempts)
Deprecated.
The put request will be buffered by its corresponding buffer queue.
|
HRegionLocation |
ClusterConnection.relocateRegion(TableName tableName,
byte[] row)
Find the location of the region of tableName that row
lives in, ignoring any value that might be in the cache.
|
HRegionLocation |
ConnectionImplementation.relocateRegion(TableName tableName,
byte[] row) |
RegionLocations |
ClusterConnection.relocateRegion(TableName tableName,
byte[] row,
int replicaId)
Find the location of the region of tableName that row
lives in, ignoring any value that might be in the cache.
|
RegionLocations |
ConnectionImplementation.relocateRegion(TableName tableName,
byte[] row,
int replicaId) |
private CompletableFuture<Void> |
RawAsyncHBaseAdmin.restoreSnapshot(String snapshotName,
TableName tableName,
boolean takeFailSafeSnapshot,
boolean restoreAcl) |
(package private) void |
MasterCallable.setPriority(TableName tableName) |
AsyncProcessTask.Builder<T> |
AsyncProcessTask.Builder.setTableName(TableName tableName) |
private void |
HBaseAdmin.setTableRep(TableName tableName,
boolean enableRep)
Set the table's replication switch if the table's replication switch is already not set.
|
private CompletableFuture<Void> |
RawAsyncHBaseAdmin.setTableReplication(TableName tableName,
boolean enableRep)
Set the table's replication switch if the table's replication switch is already not set.
|
default void |
Admin.snapshot(byte[] snapshotName,
TableName tableName)
Deprecated.
since 2.3.0, will be removed in 3.0.0. Use
Admin.snapshot(String, TableName)
instead. |
default void |
Admin.snapshot(String snapshotName,
TableName tableName)
Take a snapshot for the given table.
|
default CompletableFuture<Void> |
AsyncAdmin.snapshot(String snapshotName,
TableName tableName)
Take a snapshot for the given table.
|
default void |
Admin.snapshot(String snapshotName,
TableName tableName,
Map<String,Object> snapshotProps)
Create typed snapshot of the table.
|
default void |
Admin.snapshot(String snapshotName,
TableName tableName,
SnapshotType type)
Create typed snapshot of the table.
|
default CompletableFuture<Void> |
AsyncAdmin.snapshot(String snapshotName,
TableName tableName,
SnapshotType type)
Create typed snapshot of the table.
|
default void |
Admin.snapshot(String snapshotName,
TableName tableName,
SnapshotType type,
Map<String,Object> snapshotProps)
Create typed snapshot of the table.
|
void |
HBaseAdmin.split(TableName tableName) |
void |
Admin.split(TableName tableName)
Split a table.
|
CompletableFuture<Void> |
AsyncAdmin.split(TableName tableName)
Split a table.
|
CompletableFuture<Void> |
RawAsyncHBaseAdmin.split(TableName tableName) |
CompletableFuture<Void> |
AsyncHBaseAdmin.split(TableName tableName) |
void |
HBaseAdmin.split(TableName tableName,
byte[] splitPoint) |
void |
Admin.split(TableName tableName,
byte[] splitPoint)
Split a table.
|
CompletableFuture<Void> |
AsyncAdmin.split(TableName tableName,
byte[] splitPoint)
Split a table.
|
CompletableFuture<Void> |
RawAsyncHBaseAdmin.split(TableName tableName,
byte[] splitPoint) |
CompletableFuture<Void> |
AsyncHBaseAdmin.split(TableName tableName,
byte[] splitPoint) |
AsyncRpcRetryingCallerFactory.SingleRequestCallerBuilder<T> |
AsyncRpcRetryingCallerFactory.SingleRequestCallerBuilder.table(TableName tableName) |
AsyncRpcRetryingCallerFactory.BatchCallerBuilder |
AsyncRpcRetryingCallerFactory.BatchCallerBuilder.table(TableName tableName) |
boolean |
HBaseAdmin.tableExists(TableName tableName) |
boolean |
Admin.tableExists(TableName tableName) |
CompletableFuture<Boolean> |
AsyncAdmin.tableExists(TableName tableName) |
CompletableFuture<Boolean> |
RawAsyncHBaseAdmin.tableExists(TableName tableName) |
CompletableFuture<Boolean> |
AsyncHBaseAdmin.tableExists(TableName tableName) |
(package private) static <T> CompletableFuture<T> |
ConnectionUtils.timelineConsistentRead(AsyncRegionLocator locator,
TableName tableName,
Query query,
byte[] row,
RegionLocateType locateType,
Function<Integer,CompletableFuture<T>> requestReplica,
long rpcTimeoutNs,
long primaryCallTimeoutNs,
org.apache.hbase.thirdparty.io.netty.util.Timer retryTimer,
Optional<MetricsConnection> metrics) |
default void |
Admin.truncateTable(TableName tableName,
boolean preserveSplits)
Truncate a table.
|
CompletableFuture<Void> |
AsyncAdmin.truncateTable(TableName tableName,
boolean preserveSplits)
Truncate a table.
|
CompletableFuture<Void> |
RawAsyncHBaseAdmin.truncateTable(TableName tableName,
boolean preserveSplits) |
CompletableFuture<Void> |
AsyncHBaseAdmin.truncateTable(TableName tableName,
boolean preserveSplits) |
Future<Void> |
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.
|
private CompletableFuture<Void> |
RawAsyncHBaseAdmin.trySyncTableToPeerCluster(TableName tableName,
byte[][] splits,
ReplicationPeerDescription peer) |
void |
ClusterConnection.updateCachedLocations(TableName tableName,
byte[] regionName,
byte[] rowkey,
Object exception,
ServerName source)
Update the location cache.
|
void |
ConnectionImplementation.updateCachedLocations(TableName tableName,
byte[] regionName,
byte[] rowkey,
Object exception,
ServerName source)
Update the location with the new value (if the exception is a RegionMovedException)
or delete it from the cache.
|
protected void |
AsyncProcess.waitForMaximumCurrentTasks(int max,
TableName tableName)
Wait until the async does not have more than max tasks in progress.
|
Constructor and Description |
---|
AddColumnFamilyFuture(HBaseAdmin admin,
TableName tableName,
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.AddColumnResponse response) |
AddColumnFamilyProcedureBiConsumer(TableName tableName) |
AsyncBatchRpcRetryingCaller(org.apache.hbase.thirdparty.io.netty.util.Timer retryTimer,
AsyncConnectionImpl conn,
TableName tableName,
List<? extends Row> actions,
long pauseNs,
long pauseForCQTBENs,
int maxAttempts,
long operationTimeoutNs,
long rpcTimeoutNs,
int startLogErrorsCnt) |
AsyncClientScanner(Scan scan,
AdvancedScanResultConsumer consumer,
TableName tableName,
AsyncConnectionImpl conn,
org.apache.hbase.thirdparty.io.netty.util.Timer retryTimer,
long pauseNs,
long pauseForCQTBENs,
int maxAttempts,
long scanTimeoutNs,
long rpcTimeoutNs,
int startLogErrorsCnt) |
AsyncProcessTask(ExecutorService pool,
TableName tableName,
RowAccess<? extends Row> rows,
AsyncProcessTask.SubmittedRows size,
Batch.Callback<T> callback,
CancellableRegionServerCallable callable,
boolean needResults,
int rpcTimeout,
int operationTimeout,
Object[] results) |
AsyncSingleRequestRpcRetryingCaller(org.apache.hbase.thirdparty.io.netty.util.Timer retryTimer,
AsyncConnectionImpl conn,
TableName tableName,
byte[] row,
int replicaId,
RegionLocateType locateType,
AsyncSingleRequestRpcRetryingCaller.Callable<T> callable,
int priority,
long pauseNs,
long pauseForCQTBENs,
int maxAttempts,
long operationTimeoutNs,
long rpcTimeoutNs,
int startLogErrorsCnt) |
AsyncTableBuilderBase(TableName tableName,
AsyncConnectionConfiguration connConf) |
AsyncTableRegionLocatorImpl(TableName tableName,
AsyncConnectionImpl conn) |
BufferedMutatorParams(TableName tableName) |
CancellableRegionServerCallable(Connection connection,
TableName tableName,
byte[] row,
org.apache.hbase.thirdparty.com.google.protobuf.RpcController rpcController,
int rpcTimeout,
RetryingTimeTracker tracker,
int priority) |
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) |
CreateTableProcedureBiConsumer(TableName tableName) |
DeleteColumnFamilyFuture(HBaseAdmin admin,
TableName tableName,
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.DeleteColumnResponse response) |
DeleteColumnFamilyProcedureBiConsumer(TableName tableName) |
DeleteTableFuture(HBaseAdmin admin,
TableName tableName,
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.DeleteTableResponse response) |
DeleteTableProcedureBiConsumer(TableName tableName) |
DisableTableFuture(HBaseAdmin admin,
TableName tableName,
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.DisableTableResponse response) |
DisableTableProcedureBiConsumer(TableName tableName) |
EnableTableFuture(HBaseAdmin admin,
TableName tableName,
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.EnableTableResponse response) |
EnableTableProcedureBiConsumer(TableName tableName) |
FlushRegionCallable(ClusterConnection connection,
RpcControllerFactory rpcControllerFactory,
TableName tableName,
byte[] regionName,
byte[] regionStartKey,
boolean writeFlushWalMarker) |
HRegionLocator(TableName tableName,
ConnectionImplementation connection) |
MergeTableRegionProcedureBiConsumer(TableName tableName) |
MergeTableRegionsFuture(HBaseAdmin admin,
TableName tableName,
Long procId) |
MergeTableRegionsFuture(HBaseAdmin admin,
TableName tableName,
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MergeTableRegionsResponse response) |
ModifyableTableDescriptor(TableName name)
Construct a table descriptor specifying a TableName object
|
ModifyableTableDescriptor(TableName name,
Collection<ColumnFamilyDescriptor> families,
Map<Bytes,Bytes> values) |
ModifyableTableDescriptor(TableName name,
TableDescriptor desc)
Deprecated.
|
ModifyColumnFamilyFuture(HBaseAdmin admin,
TableName tableName,
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.ModifyColumnResponse response) |
ModifyColumnFamilyProcedureBiConsumer(TableName tableName) |
ModifyTableFuture(HBaseAdmin admin,
TableName tableName,
Long procId) |
ModifyTableFuture(HBaseAdmin admin,
TableName tableName,
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.ModifyTableResponse response) |
ModifyTableProcedureBiConsumer(AsyncAdmin admin,
TableName tableName) |
MultiServerCallable(ClusterConnection connection,
TableName tableName,
ServerName location,
MultiAction multi,
org.apache.hbase.thirdparty.com.google.protobuf.RpcController rpcController,
int rpcTimeout,
RetryingTimeTracker tracker,
int priority) |
MutableRegionInfo(long regionId,
TableName tableName,
int replicaId)
Private constructor used constructing MutableRegionInfo for the
first meta regions
|
MutableRegionInfo(TableName tableName,
byte[] startKey,
byte[] endKey,
boolean split,
long regionId,
int replicaId,
boolean offLine) |
NoncedRegionServerCallable(Connection connection,
TableName tableName,
byte[] row,
HBaseRpcController rpcController,
int priority) |
RegionAdminServiceCallable(ClusterConnection connection,
RpcControllerFactory rpcControllerFactory,
HRegionLocation location,
TableName tableName,
byte[] row) |
RegionAdminServiceCallable(ClusterConnection connection,
RpcControllerFactory rpcControllerFactory,
HRegionLocation location,
TableName tableName,
byte[] row,
int replicaId) |
RegionAdminServiceCallable(ClusterConnection connection,
RpcControllerFactory rpcControllerFactory,
TableName tableName,
byte[] row) |
RegionCoprocessorRpcChannel(ClusterConnection conn,
TableName table,
byte[] row)
Constructor
|
RegionCoprocessorRpcChannelImpl(AsyncConnectionImpl conn,
TableName tableName,
RegionInfo region,
byte[] row,
long rpcTimeoutNs,
long operationTimeoutNs) |
RegionInfoBuilder(TableName tableName) |
RegionServerCallable(Connection connection,
TableName tableName,
byte[] row,
org.apache.hbase.thirdparty.com.google.protobuf.RpcController rpcController) |
RegionServerCallable(Connection connection,
TableName tableName,
byte[] row,
org.apache.hbase.thirdparty.com.google.protobuf.RpcController rpcController,
int priority) |
RestoreSnapshotFuture(HBaseAdmin admin,
org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotDescription snapshot,
TableName tableName,
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.RestoreSnapshotResponse response) |
RestoreSnapshotFuture(HBaseAdmin admin,
TableName tableName,
Long procId) |
ReversedClientScanner(org.apache.hadoop.conf.Configuration conf,
Scan scan,
TableName tableName,
ClusterConnection connection,
RpcRetryingCallerFactory rpcFactory,
RpcControllerFactory controllerFactory,
ExecutorService pool,
int 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) |
ScannerCallableWithReplicas(TableName tableName,
ClusterConnection cConnection,
ScannerCallable baseCallable,
ExecutorService pool,
int timeBeforeReplicas,
Scan scan,
int retries,
int scannerTimeout,
int caching,
org.apache.hadoop.conf.Configuration conf,
RpcRetryingCaller<Result[]> caller) |
SnapshotDescription(String name,
TableName table) |
SnapshotDescription(String name,
TableName table,
SnapshotType type) |
SnapshotDescription(String snapshotName,
TableName tableName,
SnapshotType type,
Map<String,Object> snapshotProps)
SnapshotDescription Parameterized Constructor
|
SnapshotDescription(String name,
TableName table,
SnapshotType type,
String owner) |
SnapshotDescription(String name,
TableName table,
SnapshotType type,
String owner,
long creationTime,
int version)
Deprecated.
since 2.3.0 and will be removed in 4.0.0. Use
SnapshotDescription.SnapshotDescription(String, TableName, SnapshotType, String, long, int, Map) |
SnapshotDescription(String name,
TableName table,
SnapshotType type,
String owner,
long creationTime,
int version,
Map<String,Object> snapshotProps)
SnapshotDescription Parameterized Constructor
|
SplitTableRegionFuture(HBaseAdmin admin,
TableName tableName,
Long procId) |
SplitTableRegionFuture(HBaseAdmin admin,
TableName tableName,
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.SplitTableRegionResponse response) |
SplitTableRegionProcedureBiConsumer(TableName tableName) |
TableBuilderBase(TableName tableName,
ConnectionConfiguration connConf) |
TableDescriptorBuilder(TableName name) |
TableFuture(HBaseAdmin admin,
TableName tableName,
Long procId) |
TableProcedureBiConsumer(TableName tableName) |
TableState(TableName tableName,
TableState.State state)
Create instance of TableState.
|
TruncateTableFuture(HBaseAdmin admin,
TableName tableName,
boolean preserveSplits,
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.TruncateTableResponse response) |
TruncateTableProcedureBiConsumer(TableName tableName) |
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.
|
private <R,S,P extends com.google.protobuf.Message,Q extends com.google.protobuf.Message,T extends com.google.protobuf.Message> |
AggregationClient.getAvgArgs(TableName tableName,
ColumnInterpreter<R,S,P,Q,T> ci,
Scan scan)
It computes average while fetching sum and row count from all the
corresponding regions.
|
<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 | Field and Description |
---|---|
private static TableName |
BufferedMutatorExample.TABLE |
private TableName |
MultiThreadedClientExample.WriteExampleCallable.tableName |
private TableName |
MultiThreadedClientExample.SingleWriteExampleCallable.tableName |
private TableName |
MultiThreadedClientExample.ReadExampleCallable.tableName |
Modifier and Type | Method and Description |
---|---|
void |
RefreshHFilesClient.refreshHFiles(TableName tableName) |
private void |
MultiThreadedClientExample.warmUpConnectionCache(Connection connection,
TableName tn) |
Constructor and Description |
---|
ReadExampleCallable(Connection connection,
TableName tableName) |
SingleWriteExampleCallable(Connection connection,
TableName tableName) |
WriteExampleCallable(Connection connection,
TableName tableName) |
Modifier and Type | Method and Description |
---|---|
static org.apache.hadoop.hbase.shaded.protobuf.generated.LockServiceProtos.LockRequest |
LockServiceClient.buildLockRequest(org.apache.hadoop.hbase.shaded.protobuf.generated.LockServiceProtos.LockType type,
String namespace,
TableName tableName,
List<RegionInfo> regionInfos,
String description,
long nonceGroup,
long nonce) |
EntityLock |
LockServiceClient.tableLock(TableName tableName,
boolean exclusive,
String description,
Abortable abort)
Create a new EntityLock object to acquire an exclusive or shared lock on a table.
|
Modifier and Type | Field and Description |
---|---|
private TableName |
TableCFs.table |
Modifier and Type | Method and Description |
---|---|
TableName |
TableCFs.getTable() |
Modifier and Type | Method and Description |
---|---|
static Map<TableName,List<String>> |
ReplicationPeerConfigUtil.convert2Map(org.apache.hadoop.hbase.shaded.protobuf.generated.ReplicationProtos.TableCF[] tableCFs)
Convert tableCFs Object to Map.
|
private Map<TableName,List<String>> |
ReplicationAdmin.copyTableCFs(Map<TableName,? extends Collection<String>> tableCfs)
Deprecated.
|
private static Map<TableName,List<String>> |
ReplicationPeerConfigUtil.copyTableCFsMap(Map<TableName,List<String>> preTableCfs) |
private static Map<TableName,List<String>> |
ReplicationPeerConfigUtil.mergeTableCFs(Map<TableName,List<String>> preTableCfs,
Map<TableName,List<String>> tableCfs) |
static Map<TableName,List<String>> |
ReplicationPeerConfigUtil.parseTableCFsFromConfig(String tableCFsConfig)
Convert tableCFs string into 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
|
Modifier and Type | Method and Description |
---|---|
void |
ReplicationAdmin.disableTableRep(TableName tableName)
Deprecated.
use
Admin.disableTableReplication(TableName)
instead |
void |
ReplicationAdmin.enableTableRep(TableName tableName)
Deprecated.
use
Admin.enableTableReplication(TableName)
instead |
Modifier and Type | Method and Description |
---|---|
void |
ReplicationAdmin.addPeer(String id,
ReplicationPeerConfig peerConfig,
Map<TableName,? extends Collection<String>> tableCfs)
Deprecated.
as release of 2.0.0, and it will be removed in 3.0.0,
use
ReplicationAdmin.addPeer(String, ReplicationPeerConfig) instead. |
static ReplicationPeerConfig |
ReplicationPeerConfigUtil.appendExcludeTableCFsToReplicationPeerConfig(Map<TableName,List<String>> excludeTableCfs,
ReplicationPeerConfig peerConfig) |
void |
ReplicationAdmin.appendPeerTableCFs(String id,
Map<TableName,? extends Collection<String>> tableCfs)
Deprecated.
|
static ReplicationPeerConfig |
ReplicationPeerConfigUtil.appendTableCFsToReplicationPeerConfig(Map<TableName,List<String>> tableCfs,
ReplicationPeerConfig peerConfig) |
static org.apache.hadoop.hbase.shaded.protobuf.generated.ReplicationProtos.TableCF[] |
ReplicationPeerConfigUtil.convert(Map<TableName,? extends Collection<String>> tableCfs)
convert map to TableCFs Object
|
static String |
ReplicationPeerConfigUtil.convertToString(Map<TableName,? extends Collection<String>> tableCfs) |
private Map<TableName,List<String>> |
ReplicationAdmin.copyTableCFs(Map<TableName,? extends Collection<String>> tableCfs)
Deprecated.
|
private static Map<TableName,List<String>> |
ReplicationPeerConfigUtil.copyTableCFsMap(Map<TableName,List<String>> preTableCfs) |
private static Map<TableName,List<String>> |
ReplicationPeerConfigUtil.mergeTableCFs(Map<TableName,List<String>> preTableCfs,
Map<TableName,List<String>> tableCfs) |
private static Map<TableName,List<String>> |
ReplicationPeerConfigUtil.mergeTableCFs(Map<TableName,List<String>> preTableCfs,
Map<TableName,List<String>> tableCfs) |
static ReplicationPeerConfig |
ReplicationPeerConfigUtil.removeExcludeTableCFsFromReplicationPeerConfig(Map<TableName,List<String>> excludeTableCfs,
ReplicationPeerConfig peerConfig,
String id) |
void |
ReplicationAdmin.removePeerTableCFs(String id,
Map<TableName,? extends Collection<String>> tableCfs)
Deprecated.
|
static ReplicationPeerConfig |
ReplicationPeerConfigUtil.removeTableCFsFromReplicationPeerConfig(Map<TableName,List<String>> tableCfs,
ReplicationPeerConfig peerConfig,
String id) |
void |
ReplicationAdmin.setPeerTableCFs(String id,
Map<TableName,? extends Collection<String>> tableCfs)
Deprecated.
|
Constructor and Description |
---|
TableCFs(TableName table,
Map<String,Integer> cfs) |
Modifier and Type | Method and Description |
---|---|
default void |
MasterObserver.postCompletedDeleteTableAction(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName)
Called after
HMaster deletes a
table. |
default void |
MasterObserver.postCompletedDisableTableAction(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName)
Called after the disableTable operation has been requested.
|
default void |
MasterObserver.postCompletedEnableTableAction(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName)
Called after the enableTable operation has been requested.
|
default void |
MasterObserver.postCompletedModifyTableAction(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName,
TableDescriptor currentDescriptor)
Deprecated.
Since 2.1. Will be removed in 3.0.
|
default void |
MasterObserver.postCompletedModifyTableAction(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName,
TableDescriptor oldDescriptor,
TableDescriptor currentDescriptor)
Called after to modifying a table's properties.
|
default void |
MasterObserver.postCompletedTruncateTableAction(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName)
Called after
HMaster truncates a
table. |
default void |
MasterObserver.postDeleteTable(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName)
Called after the deleteTable operation has been requested.
|
default void |
MasterObserver.postDisableTable(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName)
Called after the disableTable operation has been requested.
|
default void |
MasterObserver.postEnableTable(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName)
Called after the enableTable operation has been requested.
|
default void |
MasterObserver.postGetUserPermissions(ObserverContext<MasterCoprocessorEnvironment> ctx,
String userName,
String namespace,
TableName tableName,
byte[] family,
byte[] qualifier)
Called after getting user permissions.
|
default void |
MasterObserver.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.preGetUserPermissions(ObserverContext<MasterCoprocessorEnvironment> ctx,
String userName,
String namespace,
TableName tableName,
byte[] family,
byte[] qualifier)
Called before getting user permissions.
|
default void |
MasterObserver.preLockHeartbeat(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tn,
String description)
Called before heartbeat to a lock.
|
default void |
MasterObserver.preModifyTable(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName,
TableDescriptor newDescriptor)
Deprecated.
Since 2.1. Will be removed in 3.0.
|
default TableDescriptor |
MasterObserver.preModifyTable(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName,
TableDescriptor currentDescriptor,
TableDescriptor newDescriptor)
Called prior to modifying a table's properties.
|
default void |
MasterObserver.preModifyTableAction(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName,
TableDescriptor newDescriptor)
Deprecated.
Since 2.1. Will be removed in 3.0.
|
default void |
MasterObserver.preModifyTableAction(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName,
TableDescriptor currentDescriptor,
TableDescriptor newDescriptor)
Called prior to modifying a table's properties.
|
default void |
MasterObserver.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.balanceTable(TableName tableName,
Map<ServerName,List<RegionInfo>> loadOfOneTable) |
Modifier and Type | Method and Description |
---|---|
static TableName |
HFileLink.getReferencedTableName(String fileName)
Get the Table name of the referenced link
|
Modifier and Type | Method and Description |
---|---|
static Pair<TableName,String> |
HFileLink.parseBackReferenceName(String name) |
Modifier and Type | Method and Description |
---|---|
static HFileLink |
HFileLink.build(org.apache.hadoop.conf.Configuration conf,
TableName table,
String region,
String family,
String hfile)
Create an HFileLink instance from table/region/family/hfile location
|
static 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 |
---|---|
private boolean |
HFilePrettyPrinter.mobFileExists(org.apache.hadoop.fs.FileSystem fs,
TableName tn,
String mobFileName,
String family,
Set<String> foundMobFiles,
Set<String> missingMobFiles)
Checks whether the referenced mob file exists.
|
Modifier and Type | Method and Description |
---|---|
void |
DelegatingHBaseRpcController.setPriority(TableName tn) |
void |
HBaseRpcController.setPriority(TableName tn) |
void |
HBaseRpcControllerImpl.setPriority(TableName tn) |
Modifier and Type | Field and Description |
---|---|
private TableName |
TableSplit.m_tableName |
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 | Field and Description |
---|---|
private TableName |
TableSplit.tableName |
Modifier and Type | Field and Description |
---|---|
private Map<TableName,TableName> |
WALPlayer.WALMapper.tables |
private Map<TableName,TableName> |
WALPlayer.WALMapper.tables |
Modifier and Type | Method and Description |
---|---|
TableName |
TableSplit.getTable()
Returns the table name.
|
Modifier and Type | Method and Description |
---|---|
static Triple<TableName,Scan,org.apache.hadoop.fs.Path> |
ExportUtils.getArgumentsFromCommandLine(org.apache.hadoop.conf.Configuration conf,
String[] args) |
Modifier and Type | Method and Description |
---|---|
static void |
TableInputFormat.configureSplitTable(org.apache.hadoop.mapreduce.Job job,
TableName tableName)
Sets split table in map-reduce job.
|
private static void |
ImportTsv.createTable(Admin admin,
TableName tableName,
String[] columns) |
protected void |
TableInputFormatBase.initializeTable(Connection connection,
TableName tableName)
Allows subclasses to initialize the table information.
|
static void |
TableMapReduceUtil.initTableMapperJob(TableName table,
Scan scan,
Class<? extends TableMapper> mapper,
Class<?> outputKeyClass,
Class<?> outputValueClass,
org.apache.hadoop.mapreduce.Job job)
Use this before submitting a TableMap job.
|
Map<LoadIncrementalHFiles.LoadQueueItem,ByteBuffer> |
LoadIncrementalHFiles.run(String dirPath,
Map<byte[],List<org.apache.hadoop.fs.Path>> map,
TableName tableName)
Deprecated.
|
Constructor and Description |
---|
TableSplit(TableName tableName,
byte[] startRow,
byte[] endRow,
String location)
Creates a new instance without a scanner.
|
TableSplit(TableName tableName,
byte[] startRow,
byte[] endRow,
String location,
long length)
Creates a new instance without a scanner.
|
TableSplit(TableName tableName,
Scan scan,
byte[] startRow,
byte[] endRow,
String location)
Creates a new instance while assigning all variables.
|
TableSplit(TableName tableName,
Scan scan,
byte[] startRow,
byte[] endRow,
String location,
long length)
Creates a new instance while assigning all variables.
|
TableSplit(TableName tableName,
Scan scan,
byte[] startRow,
byte[] endRow,
String location,
String encodedRegionName,
long length)
Creates a new instance while assigning all variables.
|
Modifier and Type | Field and Description |
---|---|
private TableName |
AssignmentVerificationReport.tableName |
private TableName |
MasterMobCompactionThread.CompactionRunner.tableName |
Modifier and Type | Field and Description |
---|---|
private Set<TableName> |
SnapshotOfRegionAssignmentFromMeta.disabledTables |
private Map<TableName,AtomicInteger> |
HMaster.mobCompactionStates |
private ConcurrentMap<TableName,TableState.State> |
TableStateManager.tableName2State |
private Map<TableName,List<RegionInfo>> |
SnapshotOfRegionAssignmentFromMeta.tableToRegionMap
the table name to region map
|
private Set<TableName> |
RegionPlacementMaintainer.targetTableSet |
private IdReadWriteLock<TableName> |
TableStateManager.tnLock |
Modifier and Type | Method and Description |
---|---|
Map<TableName,Integer> |
RegionPlacementMaintainer.getRegionsMovement(FavoredNodesPlan newPlan)
Return how many regions will move per table since their primary RS will
change
|
Set<TableName> |
SnapshotOfRegionAssignmentFromMeta.getTableSet()
Get the table set
|
(package private) Set<TableName> |
TableStateManager.getTablesInStates(TableState.State... states)
Return all tables in given states.
|
Map<TableName,List<RegionInfo>> |
SnapshotOfRegionAssignmentFromMeta.getTableToRegionMap()
Get regions for tables
|
private Map<TableName,List<byte[]>> |
RegionsRecoveryChore.getTableToRegionsByRefCount(Map<ServerName,ServerMetrics> serverMetricsMap) |
List<TableName> |
HMaster.listTableNames(String namespace,
String regex,
boolean includeSysTables)
Returns the list of table names that match the specified request
|
List<TableName> |
HMaster.listTableNamesByNamespace(String name) |
List<TableName> |
MasterServices.listTableNamesByNamespace(String name)
Get list of table names by namespace
|
Modifier and Type | Method and Description |
---|---|
long |
HMaster.addColumn(TableName tableName,
ColumnFamilyDescriptor column,
long nonceGroup,
long nonce) |
long |
MasterServices.addColumn(TableName tableName,
ColumnFamilyDescriptor column,
long nonceGroup,
long nonce)
Add a new column to an existing table
|
List<RegionPlan> |
LoadBalancer.balanceTable(TableName tableName,
Map<ServerName,List<RegionInfo>> loadOfOneTable)
Perform the major balance operation for table, all class implement of
LoadBalancer
should override this method |
private static RegionInfo |
MetaFixer.buildRegionInfo(TableName tn,
byte[] start,
byte[] end) |
private void |
HMaster.checkTableExists(TableName tableName) |
void |
HMaster.checkTableModifiable(TableName tableName) |
void |
MasterServices.checkTableModifiable(TableName tableName)
Check table is modifiable; i.e.
|
private org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.CompactRegionResponse |
MasterRpcServices.compactMob(org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.CompactRegionRequest request,
TableName tableName)
Compacts the mob files in the current table.
|
long |
HMaster.deleteColumn(TableName tableName,
byte[] columnName,
long nonceGroup,
long nonce) |
long |
MasterServices.deleteColumn(TableName tableName,
byte[] columnName,
long nonceGroup,
long nonce)
Delete a column from an existing table
|
long |
HMaster.deleteTable(TableName tableName,
long nonceGroup,
long nonce) |
long |
MasterServices.deleteTable(TableName tableName,
long nonceGroup,
long nonce)
Delete a table
|
protected void |
TableStateManager.deleteZooKeeper(TableName tableName)
Deprecated.
Since 2.0.0. To be removed in hbase-3.0.0.
|
long |
HMaster.disableTable(TableName tableName,
long nonceGroup,
long nonce) |
long |
MasterServices.disableTable(TableName tableName,
long nonceGroup,
long nonce)
Disable an existing table
|
long |
HMaster.enableTable(TableName tableName,
long nonceGroup,
long nonce) |
long |
MasterServices.enableTable(TableName tableName,
long nonceGroup,
long nonce)
Enable an existing table
|
void |
AssignmentVerificationReport.fillUp(TableName tableName,
SnapshotOfRegionAssignmentFromMeta snapshot,
Map<String,Map<String,Float>> regionLocalityMap) |
void |
AssignmentVerificationReport.fillUpDispersion(TableName tableName,
SnapshotOfRegionAssignmentFromMeta snapshot,
FavoredNodesPlan newPlan)
Use this to project the dispersion scores
|
private void |
RegionPlacementMaintainer.genAssignmentPlan(TableName tableName,
SnapshotOfRegionAssignmentFromMeta assignmentSnapshot,
Map<String,Map<String,Float>> regionLocalityMap,
FavoredNodesPlan plan,
boolean munkresForSecondaryAndTertiary)
Generate the assignment plan for the existing table
|
private TableDescriptor |
CatalogJanitor.getDescriptor(TableName tableName) |
long |
HMaster.getLastMajorCompactionTimestamp(TableName table) |
long |
MasterServices.getLastMajorCompactionTimestamp(TableName table) |
org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.GetRegionInfoResponse.CompactionState |
HMaster.getMobCompactionState(TableName tableName)
Gets the mob file compaction state for a specific table.
|
TableState |
TableStateManager.getTableState(TableName tableName) |
private static boolean |
HMaster.isCatalogTable(TableName tableName) |
boolean |
TableStateManager.isTablePresent(TableName tableName) |
boolean |
TableStateManager.isTableState(TableName tableName,
TableState.State... states) |
protected void |
MirroringTableStateManager.metaStateDeleted(TableName tableName)
Deprecated.
|
protected void |
TableStateManager.metaStateDeleted(TableName tableName) |
protected void |
MirroringTableStateManager.metaStateUpdated(TableName tableName,
TableState.State newState)
Deprecated.
|
protected void |
TableStateManager.metaStateUpdated(TableName tableName,
TableState.State newState) |
long |
HMaster.modifyColumn(TableName tableName,
ColumnFamilyDescriptor descriptor,
long nonceGroup,
long nonce) |
long |
MasterServices.modifyColumn(TableName tableName,
ColumnFamilyDescriptor descriptor,
long nonceGroup,
long nonce)
Modify the column descriptor of an existing column in an existing table
|
private long |
HMaster.modifyTable(TableName tableName,
HMaster.TableDescriptorGetter newDescriptorGetter,
long nonceGroup,
long nonce,
boolean shouldCheckDescriptor) |
long |
HMaster.modifyTable(TableName tableName,
TableDescriptor newDescriptor,
long nonceGroup,
long nonce) |
long |
MasterServices.modifyTable(TableName tableName,
TableDescriptor descriptor,
long nonceGroup,
long nonce)
Modify the descriptor of an existing table
|
void |
MasterCoprocessorHost.postCompletedDeleteTableAction(TableName tableName,
User user) |
void |
MasterCoprocessorHost.postCompletedDisableTableAction(TableName tableName,
User user) |
void |
MasterCoprocessorHost.postCompletedEnableTableAction(TableName tableName,
User user) |
void |
MasterCoprocessorHost.postCompletedModifyTableAction(TableName tableName,
TableDescriptor oldDescriptor,
TableDescriptor currentDescriptor,
User user) |
void |
MasterCoprocessorHost.postCompletedTruncateTableAction(TableName tableName,
User user) |
void |
MasterCoprocessorHost.postDeleteTable(TableName tableName) |
void |
MasterCoprocessorHost.postDisableTable(TableName tableName) |
void |
MasterCoprocessorHost.postEnableTable(TableName tableName) |
void |
MasterCoprocessorHost.postGetUserPermissions(String userName,
String namespace,
TableName tableName,
byte[] family,
byte[] qualifier) |
void |
MasterCoprocessorHost.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.preGetUserPermissions(String userName,
String namespace,
TableName tableName,
byte[] family,
byte[] qualifier) |
TableDescriptor |
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) |
private TableState |
TableStateManager.readMetaState(TableName tableName) |
(package private) long |
HMaster.reopenRegions(TableName tableName,
List<byte[]> regionNames,
long nonceGroup,
long nonce)
Reopen regions provided in the argument
|
void |
HMaster.reportMobCompactionEnd(TableName tableName) |
void |
HMaster.reportMobCompactionStart(TableName tableName) |
void |
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.
|
long |
HMaster.truncateTable(TableName tableName,
boolean preserveSplits,
long nonceGroup,
long nonce) |
long |
MasterServices.truncateTable(TableName tableName,
boolean preserveSplits,
long nonceGroup,
long nonce)
Truncate a table
|
private void |
TableStateManager.updateMetaState(TableName tableName,
TableState.State newState) |
Modifier and Type | Method and Description |
---|---|
List<RegionPlan> |
LoadBalancer.balanceCluster(Map<TableName,Map<ServerName,List<RegionInfo>>> loadOfAllTable)
Perform the major balance operation for cluster, will invoke
LoadBalancer.balanceTable(org.apache.hadoop.hbase.TableName, java.util.Map<org.apache.hadoop.hbase.ServerName, java.util.List<org.apache.hadoop.hbase.client.RegionInfo>>) to do
actual balance. |
void |
RegionPlacementMaintainer.checkDifferencesWithOldPlan(Map<TableName,Integer> movesPerTable,
Map<String,Map<String,Float>> regionLocalityMap,
FavoredNodesPlan newPlan)
Compares two plans and check whether the locality dropped or increased
(prints the information as a string) also prints the baseline locality
|
private List<TableDescriptor> |
HMaster.getTableDescriptors(List<TableDescriptor> htds,
String namespace,
String regex,
List<TableName> tableNameList,
boolean includeSysTables) |
List<TableDescriptor> |
HMaster.listTableDescriptors(String namespace,
String regex,
List<TableName> tableNameList,
boolean includeSysTables)
Returns the list of table descriptors that match the specified request
|
void |
MasterCoprocessorHost.postGetTableDescriptors(List<TableName> tableNamesList,
List<TableDescriptor> descriptors,
String regex) |
void |
MasterCoprocessorHost.postMoveServersAndTables(Set<Address> servers,
Set<TableName> tables,
String targetGroup) |
void |
MasterCoprocessorHost.postMoveTables(Set<TableName> tables,
String targetGroup) |
void |
MasterCoprocessorHost.preGetTableDescriptors(List<TableName> tableNamesList,
List<TableDescriptor> descriptors,
String regex) |
void |
MasterCoprocessorHost.preMoveServersAndTables(Set<Address> servers,
Set<TableName> tables,
String targetGroup) |
void |
MasterCoprocessorHost.preMoveTables(Set<TableName> tables,
String targetGroup) |
private void |
RegionsRecoveryChore.prepareTableToReopenRegionsMap(Map<TableName,List<byte[]>> tableToReopenRegionsMap,
byte[] regionName,
int regionStoreRefCount) |
Constructor and Description |
---|
CompactionRunner(org.apache.hadoop.fs.FileSystem fs,
TableName tableName,
List<ColumnFamilyDescriptor> hcds,
boolean allFiles,
ExecutorService pool) |
Constructor and Description |
---|
SnapshotOfRegionAssignmentFromMeta(Connection connection,
Set<TableName> disabledTables,
boolean excludeOfflinedSplitParents) |
Modifier and Type | Method and Description |
---|---|
TableName |
RegionStateNode.getTable() |
TableName |
GCMultipleMergedRegionsProcedure.getTableName() |
TableName |
RegionTransitionProcedure.getTableName()
Deprecated.
|
TableName |
MoveRegionProcedure.getTableName()
Deprecated.
|
TableName |
GCMergedRegionsProcedure.getTableName()
Deprecated.
|
TableName |
MergeTableRegionsProcedure.getTableName() |
TableName |
RegionRemoteProcedureBase.getTableName() |
Modifier and Type | Method and Description |
---|---|
Map<TableName,Map<ServerName,List<RegionInfo>>> |
RegionStates.getAssignmentsForBalancer(TableStateManager tableStateManager,
List<ServerName> onlineServers)
This is an EXPENSIVE clone.
|
Modifier and Type | Method and Description |
---|---|
TransitRegionStateProcedure[] |
AssignmentManager.createUnassignProceduresForDisabling(TableName tableName)
Called by DisableTableProcedure to unassign all the regions for a table.
|
void |
AssignmentManager.deleteTable(TableName tableName)
Delete the region states.
|
Map<RegionState.State,List<RegionInfo>> |
RegionStates.getRegionByStateOfTable(TableName tableName) |
List<RegionInfo> |
RegionStates.getRegionsOfTable(TableName table) |
List<RegionInfo> |
RegionStates.getRegionsOfTable(TableName table,
boolean offline) |
private List<RegionInfo> |
RegionStates.getRegionsOfTable(TableName table,
Predicate<RegionStateNode> filter) |
List<HRegionLocation> |
RegionStates.getRegionsOfTableForReopen(TableName tableName)
Get the regions to be reopened when modifying a table.
|
RegionStatesCount |
AssignmentManager.getRegionStatesCount(TableName tableName)
Provide regions state count for given table.
|
Pair<Integer,Integer> |
AssignmentManager.getReopenStatus(TableName tableName)
Used by the client (via master) to identify if all regions have the schema updates
|
private TableDescriptor |
RegionStateStore.getTableDescriptor(TableName tableName) |
(package private) ArrayList<RegionInfo> |
RegionStates.getTableRegionsInfo(TableName tableName) |
(package private) ArrayList<RegionStateNode> |
RegionStates.getTableRegionStateNodes(TableName tableName) |
(package private) ArrayList<RegionState> |
RegionStates.getTableRegionStates(TableName tableName) |
private boolean |
RegionStateStore.hasGlobalReplicationScope(TableName tableName) |
boolean |
RegionStates.hasTableRegionStates(TableName tableName) |
boolean |
AssignmentManager.isTableDisabled(TableName tableName) |
private boolean |
RegionStates.isTableDisabled(TableStateManager tableStateManager,
TableName tableName) |
boolean |
AssignmentManager.isTableEnabled(TableName tableName) |
Modifier and Type | Method and Description |
---|---|
List<RegionPlan> |
StochasticLoadBalancer.balanceTable(TableName tableName,
Map<ServerName,List<RegionInfo>> loadOfOneTable)
Given the cluster state this will try and approach an optimal balance.
|
List<RegionPlan> |
SimpleLoadBalancer.balanceTable(TableName tableName,
Map<ServerName,List<RegionInfo>> loadOfOneTable)
Generate a global load balancing plan according to the specified map of
server information to the most loaded regions of each server.
|
List<RegionPlan> |
FavoredStochasticBalancer.balanceTable(TableName tableName,
Map<ServerName,List<RegionInfo>> loadOfOneTable) |
abstract List<RegionPlan> |
BaseLoadBalancer.balanceTable(TableName tableName,
Map<ServerName,List<RegionInfo>> loadOfOneTable) |
protected TableDescriptor |
RegionLocationFinder.getTableDescriptor(TableName tableName)
return TableDescriptor for a given tableName
|
protected boolean |
StochasticLoadBalancer.needsBalance(TableName tableName,
BaseLoadBalancer.Cluster cluster) |
protected boolean |
BaseLoadBalancer.needsBalance(TableName tableName,
BaseLoadBalancer.Cluster c) |
private void |
StochasticLoadBalancer.updateStochasticCosts(TableName tableName,
Double overall,
Double[] subCosts)
update costs to JMX
|
Modifier and Type | Field and Description |
---|---|
private TableName |
LockManager.MasterLock.tableName |
private TableName |
LockProcedure.tableName |
Modifier and Type | Method and Description |
---|---|
TableName |
LockProcedure.getTableName() |
Modifier and Type | Method and Description |
---|---|
LockManager.MasterLock |
LockManager.createMasterLock(TableName tableName,
LockType type,
String description) |
long |
LockManager.RemoteLocks.requestTableLock(TableName tableName,
LockType type,
String description,
NonceKey nonceKey) |
Constructor and Description |
---|
LockProcedure(org.apache.hadoop.conf.Configuration conf,
TableName tableName,
LockType type,
String description,
CountDownLatch lockAcquireLatch)
Constructor for table lock.
|
MasterLock(TableName tableName,
LockType type,
String description) |
Modifier and Type | Field and Description |
---|---|
private TableName |
SimpleRegionNormalizer.NormalizeContext.tableName |
Modifier and Type | Method and Description |
---|---|
TableName |
SimpleRegionNormalizer.NormalizeContext.getTableName() |
Modifier and Type | Method and Description |
---|---|
List<NormalizationPlan> |
SimpleRegionNormalizer.computePlansForTable(TableName table) |
List<NormalizationPlan> |
RegionNormalizer.computePlansForTable(TableName table)
Computes a list of normalizer actions to perform on the target table.
|
Constructor and Description |
---|
NormalizeContext(TableName tableName) |
Modifier and Type | Field and Description |
---|---|
private TableName |
DeleteTableProcedure.tableName |
private TableName |
EnableTableProcedure.tableName |
private TableName |
TruncateTableProcedure.tableName |
private TableName |
DisableTableProcedure.tableName |
private TableName |
ReopenTableRegionsProcedure.tableName |
Modifier and Type | Field and Description |
---|---|
private FairQueue<TableName> |
MasterProcedureScheduler.metaRunQueue |
private Map<TableName,LockAndQueue> |
SchemaLocking.tableLocks |
private FairQueue<TableName> |
MasterProcedureScheduler.tableRunQueue |
Modifier and Type | Method and Description |
---|---|
TableName |
DeleteTableProcedure.getTableName() |
TableName |
AbstractStateMachineRegionProcedure.getTableName() |
TableName |
EnableTableProcedure.getTableName() |
TableName |
CreateTableProcedure.getTableName() |
TableName |
TruncateTableProcedure.getTableName() |
TableName |
RestoreSnapshotProcedure.getTableName() |
TableName |
ModifyTableProcedure.getTableName() |
TableName |
InitMetaProcedure.getTableName() |
abstract TableName |
AbstractStateMachineTableProcedure.getTableName() |
TableName |
DisableTableProcedure.getTableName() |
TableName |
TableProcedureInterface.getTableName() |
TableName |
ReopenTableRegionsProcedure.getTableName() |
TableName |
AbstractStateMachineNamespaceProcedure.getTableName() |
TableName |
CloneSnapshotProcedure.getTableName() |
private static TableName |
MasterProcedureScheduler.getTableName(Procedure<?> proc) |
Modifier and Type | Method and Description |
---|---|
private static void |
DeleteTableProcedure.cleanRegionsInMeta(MasterProcedureEnv env,
TableName tableName)
There may be items for this table still up in hbase:meta in the case where the info:regioninfo
column was empty because of some write error.
|
List<RegionInfo> |
CreateTableProcedure.CreateHdfsRegions.createHdfsRegions(MasterProcedureEnv env,
org.apache.hadoop.fs.Path tableRootDir,
TableName tableName,
List<RegionInfo> newRegions) |
protected static void |
DeleteTableProcedure.deleteAssignmentState(MasterProcedureEnv env,
TableName tableName) |
static void |
MasterDDLOperationHelper.deleteColumnFamilyFromFileSystem(MasterProcedureEnv env,
TableName tableName,
List<RegionInfo> regionInfoList,
byte[] familyName,
boolean hasMob)
Remove the column family from the file system
|
protected static void |
DeleteTableProcedure.deleteFromFs(MasterProcedureEnv env,
TableName tableName,
List<RegionInfo> regions,
boolean archive) |
protected static void |
DeleteTableProcedure.deleteFromMeta(MasterProcedureEnv env,
TableName tableName,
List<RegionInfo> regions) |
protected static void |
DeleteTableProcedure.deleteTableDescriptorCache(MasterProcedureEnv env,
TableName tableName) |
protected static void |
DeleteTableProcedure.deleteTableStates(MasterProcedureEnv env,
TableName tableName) |
(package private) LockAndQueue |
SchemaLocking.getTableLock(TableName tableName) |
static int |
MasterProcedureUtil.getTablePriority(TableName tableName)
Return the priority for the given table.
|
private TableQueue |
MasterProcedureScheduler.getTableQueue(TableName tableName) |
(package private) boolean |
MasterProcedureScheduler.markTableAsDeleted(TableName table,
Procedure<?> procedure)
Tries to remove the queue and the table-lock of the specified table.
|
(package private) LockAndQueue |
SchemaLocking.removeTableLock(TableName tableName) |
private void |
MasterProcedureScheduler.removeTableQueue(TableName tableName) |
protected static void |
CreateTableProcedure.setEnabledState(MasterProcedureEnv env,
TableName tableName) |
protected static void |
CreateTableProcedure.setEnablingState(MasterProcedureEnv env,
TableName tableName) |
protected static void |
DisableTableProcedure.setTableStateToDisabled(MasterProcedureEnv env,
TableName tableName)
Mark table state to Disabled
|
private static void |
DisableTableProcedure.setTableStateToDisabling(MasterProcedureEnv env,
TableName tableName)
Mark table state to Disabling
|
protected static void |
EnableTableProcedure.setTableStateToEnabled(MasterProcedureEnv env,
TableName tableName)
Mark table state to Enabled
|
protected static void |
EnableTableProcedure.setTableStateToEnabling(MasterProcedureEnv env,
TableName tableName)
Mark table state to Enabling
|
protected static void |
CreateTableProcedure.updateTableDescCache(MasterProcedureEnv env,
TableName tableName) |
boolean |
MasterProcedureScheduler.waitRegions(Procedure<?> procedure,
TableName table,
RegionInfo... regionInfos)
Suspend the procedure if the specified set of regions are already locked.
|
boolean |
MasterProcedureScheduler.waitTableExclusiveLock(Procedure<?> procedure,
TableName table)
Suspend the procedure if the specified table is already locked.
|
private TableQueue |
MasterProcedureScheduler.waitTableQueueSharedLock(Procedure<?> procedure,
TableName table) |
boolean |
MasterProcedureScheduler.waitTableSharedLock(Procedure<?> procedure,
TableName table)
Suspend the procedure if the specified table is already locked.
|
void |
MasterProcedureScheduler.wakeRegions(Procedure<?> procedure,
TableName table,
RegionInfo... regionInfos)
Wake the procedures waiting for the specified regions
|
void |
MasterProcedureScheduler.wakeTableExclusiveLock(Procedure<?> procedure,
TableName table)
Wake the procedures waiting for the specified table
|
void |
MasterProcedureScheduler.wakeTableSharedLock(Procedure<?> procedure,
TableName table)
Wake the procedures waiting for the specified table
|
Modifier and Type | Field and Description |
---|---|
static TableName |
MasterRegionFactory.TABLE_NAME |
Modifier and Type | Method and Description |
---|---|
List<String> |
ReplicationPeerManager.getSerialPeerIdsBelongsTo(TableName tableName) |
private boolean |
ModifyPeerProcedure.needReopen(TableStateManager tsm,
TableName tn) |
private boolean |
ModifyPeerProcedure.needSetLastPushedSequenceId(TableStateManager tsm,
TableName tn) |
protected void |
ModifyPeerProcedure.setLastPushedSequenceIdForTable(MasterProcedureEnv env,
TableName tableName,
Map<String,Long> lastSeqIds) |
Modifier and Type | Method and Description |
---|---|
private void |
ReplicationPeerManager.checkNamespacesAndTableCfsConfigConflict(Set<String> namespaces,
Map<TableName,? extends Collection<String>> tableCfs)
Set a namespace in the peer config means that all tables in this namespace will be replicated
to the peer cluster.
|
Modifier and Type | Field and Description |
---|---|
protected TableName |
TakeSnapshotHandler.snapshotTable |
private TableName |
MasterSnapshotVerifier.tableName |
Modifier and Type | Field and Description |
---|---|
private Map<TableName,Long> |
SnapshotManager.restoreTableToProcIdMap |
private Map<TableName,SnapshotSentinel> |
SnapshotManager.snapshotHandlers |
Modifier and Type | Method and Description |
---|---|
private long |
SnapshotManager.cloneSnapshot(org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotDescription reqSnapshot,
TableName tableName,
org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotDescription snapshot,
TableDescriptor snapshotTableDesc,
NonceKey nonceKey,
boolean restoreAcl)
Clone the specified snapshot.
|
private boolean |
SnapshotManager.isRestoringTable(TableName tableName)
Verify if the restore of the specified table is in progress.
|
boolean |
SnapshotManager.isTakingSnapshot(TableName tableName)
Check to see if the specified table has a snapshot in progress.
|
private long |
SnapshotManager.restoreSnapshot(org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotDescription reqSnapshot,
TableName tableName,
org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotDescription snapshot,
TableDescriptor snapshotTableDesc,
NonceKey nonceKey,
boolean restoreAcl)
Restore the specified snapshot.
|
void |
SnapshotManager.setSnapshotHandlerForTesting(TableName tableName,
SnapshotSentinel handler)
Set the handler for the current snapshot
|
Modifier and Type | Method and Description |
---|---|
private void |
SnapshotManager.cleanupSentinels(Map<TableName,SnapshotSentinel> sentinels)
Remove the sentinels that are marked as finished and the completion time
has exceeded the removal timeout.
|
private SnapshotSentinel |
SnapshotManager.removeSentinelIfFinished(Map<TableName,SnapshotSentinel> sentinels,
org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotDescription snapshot)
Return the handler if it is currently live and has the same snapshot target name.
|
Modifier and Type | Field and Description |
---|---|
private TableName |
MetaBrowser.scanTable |
Modifier and Type | Method and Description |
---|---|
TableName |
MetaBrowser.getScanTable() |
private static TableName |
MetaBrowser.resolveScanTable(javax.servlet.http.HttpServletRequest request) |
Modifier and Type | Method and Description |
---|---|
private static Filter |
MetaBrowser.buildTableFilter(TableName tableName) |
Modifier and Type | Field and Description |
---|---|
private static ConcurrentMap<TableName,String> |
ManualMobMaintHFileCleaner.MOB_REGIONS |
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 | Field and Description |
---|---|
(package private) TableName |
MobRefReporter.MobRefReducer.table |
Modifier and Type | Field and Description |
---|---|
private Map<TableName,AtomicInteger> |
NamespaceTableAndRegionInfo.tableAndRegionInfo |
Modifier and Type | Method and Description |
---|---|
(package private) Set<TableName> |
NamespaceTableAndRegionInfo.getTables()
Gets the set of table names belonging to namespace.
|
Modifier and Type | Method and Description |
---|---|
private void |
NamespaceStateManager.addTable(TableName tableName,
int regionCount) |
(package private) void |
NamespaceTableAndRegionInfo.addTable(TableName tableName,
int regionCount) |
(package private) boolean |
NamespaceStateManager.checkAndUpdateNamespaceRegionCount(TableName name,
byte[] regionName,
int incr)
Check if adding a region violates namespace quota, if not update namespace cache.
|
(package private) void |
NamespaceStateManager.checkAndUpdateNamespaceRegionCount(TableName name,
int incr)
Check and update region count for an existing table.
|
(package private) void |
NamespaceStateManager.checkAndUpdateNamespaceTableCount(TableName table,
int numRegions) |
void |
NamespaceAuditor.checkQuotaToCreateTable(TableName tName,
int regions)
Check quota to create table.
|
void |
NamespaceAuditor.checkQuotaToUpdateRegion(TableName tName,
int regions)
Check and update region count quota for an existing table.
|
private void |
NamespaceAuditor.checkTableTypeAndThrowException(TableName name) |
(package private) boolean |
NamespaceTableAndRegionInfo.containsTable(TableName tableName) |
(package private) int |
NamespaceTableAndRegionInfo.decrementRegionCountForTable(TableName tableName,
int count) |
(package private) int |
NamespaceTableAndRegionInfo.getRegionCountOfTable(TableName tableName) |
int |
NamespaceAuditor.getRegionCountOfTable(TableName tName)
Get region count for table
|
(package private) int |
NamespaceTableAndRegionInfo.incRegionCountForTable(TableName tableName,
int count) |
void |
NamespaceAuditor.removeFromNamespaceUsage(TableName tableName) |
(package private) void |
NamespaceStateManager.removeTable(TableName tableName) |
(package private) void |
NamespaceTableAndRegionInfo.removeTable(TableName tableName) |
Modifier and Type | Field and Description |
---|---|
private Map<TableName,Procedure> |
MasterFlushTableProcedureManager.procMap |
Modifier and Type | Field and Description |
---|---|
static TableName |
QuotaTableUtil.QUOTA_TABLE_NAME
System table for quotas
|
private TableName |
QuotaSettings.tableName |
(package private) TableName |
FileArchiverNotifierFactoryImpl.CacheKey.tn |
private TableName |
FileArchiverNotifierImpl.tn |
Modifier and Type | Method and Description |
---|---|
protected static TableName |
QuotaTableUtil.getTableFromRowKey(byte[] key) |
TableName |
QuotaSettings.getTableName() |
Modifier and Type | Method and Description |
---|---|
(package private) Map<TableName,SpaceViolationPolicyEnforcement> |
RegionServerSpaceQuotaManager.copyActiveEnforcements()
Returns the collection of tables which have quota violation policies enforced on
this RegionServer.
|
Map<TableName,SpaceQuotaSnapshot> |
RegionServerSpaceQuotaManager.copyQuotaSnapshots()
Copies the last
SpaceQuotaSnapshot s that were recorded. |
Map<TableName,SpaceQuotaSnapshot> |
SpaceQuotaRefresherChore.fetchSnapshotsFromQuotaTable()
Reads all quota snapshots from the quota table.
|
static Map<TableName,QuotaState> |
QuotaUtil.fetchTableQuotas(Connection connection,
List<Get> gets,
Map<TableName,Double> tableMachineFactors) |
Set<TableName> |
QuotaObserverChore.TablesWithQuotas.filterInsufficientlyReportedTables(QuotaSnapshotStore<TableName> tableStore)
Filters out all tables for which the Master currently doesn't have enough region space
reports received from RegionServers yet.
|
Map<TableName,SpaceQuotaSnapshot> |
RegionServerSpaceQuotaManager.getActivePoliciesAsMap()
Converts a map of table to
SpaceViolationPolicyEnforcement s into
SpaceViolationPolicy s. |
(package private) Map<TableName,SpaceViolationPolicyEnforcement> |
ActivePolicyEnforcement.getLocallyCachedPolicies()
Returns an unmodifiable version of the policy enforcements that were cached because they are
not in violation of their quota.
|
Set<TableName> |
QuotaObserverChore.TablesWithQuotas.getNamespaceQuotaTables()
Returns an unmodifiable view of all tables in namespaces that have
namespace quotas.
|
Map<TableName,SpaceViolationPolicyEnforcement> |
ActivePolicyEnforcement.getPolicies()
Returns an unmodifiable version of the active
SpaceViolationPolicyEnforcement s. |
static Map<TableName,SpaceQuotaSnapshot> |
QuotaTableUtil.getSnapshots(Connection conn)
Fetches all
SpaceQuotaSnapshot objects from the hbase:quota table. |
(package private) org.apache.hbase.thirdparty.com.google.common.collect.Multimap<TableName,String> |
SnapshotQuotaObserverChore.getSnapshotsFromTables(Admin admin,
Set<TableName> tablesToFetchSnapshotsFrom)
Computes a mapping of originating
TableName to snapshots, when the TableName
exists in the provided Set . |
(package private) org.apache.hbase.thirdparty.com.google.common.collect.Multimap<TableName,String> |
SnapshotQuotaObserverChore.getSnapshotsToComputeSize()
Fetches each table with a quota (table or namespace quota), and then fetch the name of each
snapshot which was created from that table.
|
(package private) Map<TableName,QuotaState> |
QuotaCache.getTableQuotaCache() |
Map<TableName,SpaceQuotaSnapshot> |
QuotaObserverChore.getTableQuotaSnapshots()
Returns an unmodifiable view over the current
SpaceQuotaSnapshot objects
for each HBase table with a quota defined. |
Set<TableName> |
QuotaObserverChore.TablesWithQuotas.getTableQuotaTables()
Returns an unmodifiable view of all tables with table quotas.
|
org.apache.hbase.thirdparty.com.google.common.collect.Multimap<String,TableName> |
QuotaObserverChore.TablesWithQuotas.getTablesByNamespace()
Returns a view of all tables that reside in a namespace with a namespace
quota, grouped by the namespace itself.
|
static org.apache.hbase.thirdparty.com.google.common.collect.Multimap<TableName,String> |
QuotaTableUtil.getTableSnapshots(Connection conn)
Returns a multimap for all existing table snapshot entries.
|
(package private) QuotaSnapshotStore<TableName> |
QuotaObserverChore.getTableSnapshotStore() |
Modifier and Type | Method and Description |
---|---|
void |
QuotaObserverChore.TablesWithQuotas.addNamespaceQuotaTable(TableName tn)
Adds a table with a namespace quota.
|
static void |
QuotaUtil.addTableQuota(Connection connection,
TableName table,
org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Quotas data) |
void |
QuotaObserverChore.TablesWithQuotas.addTableQuotaTable(TableName tn)
Adds a table with a table quota.
|
static void |
QuotaUtil.addUserQuota(Connection connection,
String user,
TableName table,
org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Quotas data) |
boolean |
RegionServerSpaceQuotaManager.areCompactionsDisabled(TableName tableName)
Returns whether or not compactions should be disabled for the given
tableName per
a space quota violation policy. |
org.apache.hadoop.hbase.shaded.protobuf.generated.RegionServerStatusProtos.FileArchiveNotificationRequest |
RegionServerSpaceQuotaManager.buildFileArchiveRequest(TableName tn,
Collection<Map.Entry<String,Long>> archivedFiles)
Builds the protobuf message to inform the Master of files being archived.
|
void |
MasterQuotaManager.checkAndUpdateNamespaceRegionQuota(TableName tName,
int regions) |
void |
MasterQuotaManager.checkNamespaceTableAndRegionQuota(TableName tName,
int regions) |
SpaceViolationPolicyEnforcement |
SpaceViolationPolicyEnforcementFactory.create(RegionServerServices rss,
TableName tableName,
SpaceQuotaSnapshot snapshot)
Constructs the appropriate
SpaceViolationPolicyEnforcement for tables that are
in violation of their space quota. |
(package private) static Put |
QuotaTableUtil.createPutForSnapshotSize(TableName tableName,
String snapshot,
long size)
|
(package private) static Put |
QuotaTableUtil.createPutForSpaceSnapshot(TableName tableName,
SpaceQuotaSnapshot snapshot)
|
(package private) static Scan |
QuotaTableUtil.createScanForSpaceSnapshotSizes(TableName table) |
SpaceViolationPolicyEnforcement |
SpaceViolationPolicyEnforcementFactory.createWithoutViolation(RegionServerServices rss,
TableName tableName,
SpaceQuotaSnapshot snapshot)
Creates the "default"
SpaceViolationPolicyEnforcement for a table that isn't in
violation. |
static void |
QuotaUtil.deleteTableQuota(Connection connection,
TableName table) |
static void |
QuotaUtil.deleteUserQuota(Connection connection,
String 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) |
private static List<QuotaSettings> |
QuotaSettingsFactory.fromQuotas(String userName,
TableName tableName,
String namespace,
String regionServer,
org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Quotas quotas) |
(package private) static QuotaSettings |
QuotaSettingsFactory.fromSpace(TableName table,
String namespace,
org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.SpaceQuota protoQuota) |
(package private) static SpaceLimitSettings |
SpaceLimitSettings.fromSpaceQuota(TableName tableName,
org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.SpaceQuota proto)
Constructs a
SpaceLimitSettings from the provided protobuf message and tablename. |
(package private) static List<QuotaSettings> |
QuotaSettingsFactory.fromTableQuotas(TableName tableName,
org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Quotas quotas) |
static List<ThrottleSettings> |
QuotaSettingsFactory.fromTableThrottles(TableName tableName,
org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Throttle throttle) |
protected static List<ThrottleSettings> |
QuotaSettingsFactory.fromThrottle(String userName,
TableName tableName,
String namespace,
String regionServer,
org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Throttle throttle) |
(package private) static ThrottleSettings |
ThrottleSettings.fromTimedQuota(String userName,
TableName tableName,
String namespace,
String regionServer,
ThrottleType type,
org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.TimedQuota timedQuota) |
(package private) static List<QuotaSettings> |
QuotaSettingsFactory.fromUserQuotas(String userName,
TableName tableName,
org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Quotas quotas) |
FileArchiverNotifier |
FileArchiverNotifierFactory.get(Connection conn,
org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
TableName tn)
Creates or obtains a
FileArchiverNotifier instance for the given args. |
FileArchiverNotifier |
FileArchiverNotifierFactoryImpl.get(Connection conn,
org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
TableName tn)
Returns the
FileArchiverNotifier instance for the given TableName . |
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) |
(package private) FileArchiverNotifier |
SnapshotQuotaObserverChore.getNotifierForTable(TableName tn)
Returns the correct instance of
FileArchiverNotifier for the given table name. |
(package private) int |
QuotaObserverChore.TablesWithQuotas.getNumRegions(TableName table)
Computes the total number of regions in a table.
|
(package private) int |
QuotaObserverChore.TablesWithQuotas.getNumReportedRegions(TableName table,
QuotaSnapshotStore<TableName> tableStore)
Computes the number of regions reported for a 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.
|
(package private) org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Quotas |
TableQuotaSnapshotStore.getQuotaForTable(TableName table)
Fetches the table quota.
|
int |
MasterQuotaManager.getRegionCountOfTable(TableName tName) |
protected static byte[] |
QuotaTableUtil.getSettingsQualifierForUserTable(TableName tableName) |
(package private) long |
FileArchiverNotifierImpl.getSizeOfStoreFile(TableName tn,
FileArchiverNotifierImpl.StoreFileReference storeFileName)
Computes the size of the store files for a single region.
|
(package private) long |
FileArchiverNotifierImpl.getSizeOfStoreFile(TableName tn,
String regionName,
String family,
String storeFile)
Computes the size of the store file given its name, region and family name in
the archive directory.
|
(package private) long |
FileArchiverNotifierImpl.getSizeOfStoreFiles(TableName tn,
Set<FileArchiverNotifierImpl.StoreFileReference> storeFileNames)
Computes the size of each store file in
storeFileNames |
(package private) long |
TableQuotaSnapshotStore.getSnapshotSizesForTable(TableName tn)
Fetches any serialized snapshot sizes from the quota table for the
tn provided. |
org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.SpaceQuota |
TableQuotaSnapshotStore.getSpaceQuota(TableName subject) |
QuotaLimiter |
QuotaCache.getTableLimiter(TableName table)
Returns the limiter associated to the specified table.
|
QuotaLimiter |
UserQuotaState.getTableLimiter(TableName table)
Return the limiter for the specified table associated with this quota.
|
static org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Quotas |
QuotaTableUtil.getTableQuota(Connection connection,
TableName table) |
(package private) SpaceQuotaSnapshot |
QuotaObserverChore.getTableQuotaSnapshot(TableName table)
Fetches the
SpaceQuotaSnapshot for the given table. |
protected static byte[] |
QuotaTableUtil.getTableRowKey(TableName table) |
SpaceQuotaSnapshot |
TableQuotaSnapshotStore.getTargetState(TableName table,
org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.SpaceQuota spaceQuota) |
QuotaLimiter |
QuotaCache.getUserLimiter(org.apache.hadoop.security.UserGroupInformation ugi,
TableName table)
Returns the limiter associated to the specified user/table.
|
static org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Quotas |
QuotaTableUtil.getUserQuota(Connection connection,
String user,
TableName table) |
boolean |
QuotaObserverChore.TablesWithQuotas.hasNamespaceQuota(TableName tn)
Returns true if the table exists in a namespace with a namespace quota.
|
boolean |
QuotaObserverChore.TablesWithQuotas.hasTableQuota(TableName tn)
Returns true if the given table has a table quota.
|
void |
SpaceViolationPolicyEnforcement.initialize(RegionServerServices rss,
TableName tableName,
SpaceQuotaSnapshot snapshot)
Initializes this policy instance.
|
private boolean |
MasterQuotaManager.isInViolationAndPolicyDisable(TableName tableName,
QuotaObserverChore quotaObserverChore)
Method to check if a table is in violation and policy set on table is DISABLE.
|
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. |
(package private) static Get |
QuotaTableUtil.makeGetForSnapshotSize(TableName tn,
String snapshot)
Creates a
Get for the HBase snapshot's size against the given table. |
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.removeRegionSizesForTable(TableName tableName)
Removes each region size entry where the RegionInfo references the provided 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,
org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Quotas quotas)
Add the quota information of the specified table.
|
void |
MasterQuotaManager.setTableQuota(TableName table,
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.SetQuotaRequest req) |
(package private) void |
QuotaObserverChore.setTableQuotaSnapshot(TableName table,
SpaceQuotaSnapshot snapshot)
Stores the quota state for the given table.
|
void |
MasterQuotaManager.setUserQuota(String userName,
TableName table,
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.SetQuotaRequest req) |
private static QuotaSettings |
QuotaSettingsFactory.throttle(String userName,
TableName tableName,
String namespace,
String regionServer,
ThrottleType type,
long limit,
TimeUnit timeUnit,
QuotaScope scope) |
static QuotaSettings |
QuotaSettingsFactory.throttleTable(TableName tableName,
ThrottleType type,
long limit,
TimeUnit timeUnit)
Throttle the specified table.
|
static QuotaSettings |
QuotaSettingsFactory.throttleTable(TableName tableName,
ThrottleType type,
long limit,
TimeUnit timeUnit,
QuotaScope scope)
Throttle the specified table.
|
static QuotaSettings |
QuotaSettingsFactory.throttleUser(String userName,
TableName tableName,
ThrottleType type,
long limit,
TimeUnit timeUnit)
Throttle the specified user on the specified table.
|
static QuotaSettings |
QuotaSettingsFactory.throttleUser(String userName,
TableName tableName,
ThrottleType type,
long limit,
TimeUnit timeUnit,
QuotaScope scope)
Throttle the specified user on the specified table.
|
void |
SpaceQuotaSnapshotNotifier.transitionTable(TableName tableName,
SpaceQuotaSnapshot snapshot)
Informs the cluster of the current state of a space quota for a table.
|
void |
TableSpaceQuotaSnapshotNotifier.transitionTable(TableName tableName,
SpaceQuotaSnapshot snapshot) |
static QuotaSettings |
QuotaSettingsFactory.unthrottleTable(TableName tableName)
Remove the throttling for the specified table.
|
static QuotaSettings |
QuotaSettingsFactory.unthrottleTableByThrottleType(TableName tableName,
ThrottleType type)
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.
|
static QuotaSettings |
QuotaSettingsFactory.unthrottleUserByThrottleType(String userName,
TableName tableName,
ThrottleType type)
Remove the throttling for the specified user on the specified table.
|
(package private) void |
QuotaObserverChore.updateTableQuota(TableName table,
SpaceQuotaSnapshot currentSnapshot,
SpaceQuotaSnapshot targetSnapshot)
Updates the hbase:quota table with the new quota policy for this
table
if necessary. |
void |
QuotaTableUtil.TableQuotasVisitor.visitTableQuotas(TableName tableName,
org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Quotas quotas) |
void |
QuotaTableUtil.UserQuotasVisitor.visitUserQuotas(String userName,
TableName table,
org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Quotas quotas) |
Modifier and Type | Method and Description |
---|---|
(package private) Map<String,Long> |
SnapshotQuotaObserverChore.computeSnapshotSizes(org.apache.hbase.thirdparty.com.google.common.collect.Multimap<TableName,String> snapshotsToComputeSize)
Computes the size of each snapshot provided given the current files referenced by the table.
|
(package private) static List<Delete> |
QuotaTableUtil.createDeletesForExistingTableSnapshotSizes(org.apache.hbase.thirdparty.com.google.common.collect.Multimap<TableName,String> snapshotEntriesToRemove)
Returns a list of
Delete to remove given table snapshot
entries to remove from quota table |
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 . |
(package private) void |
SpaceQuotaRefresherChore.extractQuotaSnapshot(Result result,
Map<TableName,SpaceQuotaSnapshot> snapshots)
Wrapper around
QuotaTableUtil.extractQuotaSnapshot(Result, Map) for testing. |
static Map<TableName,QuotaState> |
QuotaUtil.fetchTableQuotas(Connection connection,
List<Get> gets,
Map<TableName,Double> tableMachineFactors) |
static Map<String,UserQuotaState> |
QuotaUtil.fetchUserQuotas(Connection connection,
List<Get> gets,
Map<TableName,Double> tableMachineQuotaFactors,
double factor) |
Set<TableName> |
QuotaObserverChore.TablesWithQuotas.filterInsufficientlyReportedTables(QuotaSnapshotStore<TableName> tableStore)
Filters out all tables for which the Master currently doesn't have enough region space
reports received from RegionServers yet.
|
(package private) int |
QuotaObserverChore.TablesWithQuotas.getNumReportedRegions(TableName table,
QuotaSnapshotStore<TableName> tableStore)
Computes the number of regions reported for a table.
|
(package private) org.apache.hbase.thirdparty.com.google.common.collect.Multimap<TableName,String> |
SnapshotQuotaObserverChore.getSnapshotsFromTables(Admin admin,
Set<TableName> tablesToFetchSnapshotsFrom)
Computes a mapping of originating
TableName to snapshots, when the TableName
exists in the provided Set . |
static Get |
QuotaTableUtil.makeGetForUserQuotas(String user,
Iterable<TableName> tables,
Iterable<String> namespaces) |
(package private) void |
QuotaObserverChore.processNamespacesWithQuotas(Set<String> namespacesWithQuotas,
org.apache.hbase.thirdparty.com.google.common.collect.Multimap<String,TableName> tablesByNamespace)
Processes each namespace which has a quota defined and moves all of the tables contained
in that namespace into or out of violation of the quota.
|
(package private) void |
QuotaObserverChore.processTablesWithQuotas(Set<TableName> tablesWithTableQuotas)
Processes each
TableName which has a quota defined and moves it in or out of
violation based on the space use. |
(package private) void |
SnapshotQuotaObserverChore.pruneNamespaceSnapshots(org.apache.hbase.thirdparty.com.google.common.collect.Multimap<TableName,String> snapshotsToComputeSize)
Removes the snapshot entries that are present in Quota table but not in snapshotsToComputeSize
|
(package private) void |
SnapshotQuotaObserverChore.pruneTableSnapshots(org.apache.hbase.thirdparty.com.google.common.collect.Multimap<TableName,String> snapshotsToComputeSize)
Removes the snapshot entries that are present in Quota table but not in snapshotsToComputeSize
|
(package private) void |
SnapshotQuotaObserverChore.removeExistingTableSnapshotSizes(org.apache.hbase.thirdparty.com.google.common.collect.Multimap<TableName,String> snapshotEntriesToRemove) |
(package private) void |
QuotaObserverChore.updateNamespaceQuota(String namespace,
SpaceQuotaSnapshot currentSnapshot,
SpaceQuotaSnapshot targetSnapshot,
org.apache.hbase.thirdparty.com.google.common.collect.Multimap<String,TableName> tablesByNamespace)
Updates the hbase:quota table with the target quota policy for this
namespace
if necessary. |
void |
RegionServerSpaceQuotaManager.updateQuotaSnapshot(Map<TableName,SpaceQuotaSnapshot> newSnapshots)
Updates the current
SpaceQuotaSnapshot s for the RegionServer. |
Constructor and Description |
---|
CacheKey(Connection conn,
org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
TableName tn) |
FileArchiverNotifierImpl(Connection conn,
org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
TableName tn) |
GlobalQuotaSettings(String userName,
TableName tableName,
String namespace,
String regionServer) |
GlobalQuotaSettingsImpl(String username,
TableName tableName,
String namespace,
String regionServer,
org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Quotas quotas) |
GlobalQuotaSettingsImpl(String userName,
TableName tableName,
String namespace,
String regionServer,
org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Throttle throttleProto,
Boolean bypassGlobals,
org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.SpaceQuota spaceProto) |
QuotaGlobalsSettingsBypass(String userName,
TableName tableName,
String namespace,
String regionServer,
boolean bypassGlobals) |
QuotaSettings(String userName,
TableName tableName,
String namespace,
String regionServer) |
SpaceLimitSettings(TableName tableName)
Constructs a
SpaceLimitSettings to remove a space quota on the given tableName . |
SpaceLimitSettings(TableName tableName,
long sizeLimit,
SpaceViolationPolicy violationPolicy) |
SpaceLimitSettings(TableName tableName,
String namespace,
org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.SpaceLimitRequest req) |
ThrottleSettings(String userName,
TableName tableName,
String namespace,
String regionServer,
org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.ThrottleRequest proto) |
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 | Field and Description |
---|---|
(package private) TableName |
AbstractViolationPolicyEnforcement.tableName |
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 | Field and Description |
---|---|
private TableName |
MetricsTableSourceImpl.tableName |
Modifier and Type | Field and Description |
---|---|
private HashMap<TableName,MetricsTableLatenciesImpl.TableHistograms> |
MetricsTableLatenciesImpl.histogramsByTable |
private Map<TableName,MetricsTableQueryMeterImpl.TableMeters> |
MetricsTableQueryMeterImpl.metersByTable |
private ConcurrentHashMap<TableName,MetricsTableWrapperAggregateImpl.MetricsTableValues> |
MetricsTableWrapperAggregateImpl.metricsTableMap |
Modifier and Type | Method and Description |
---|---|
TableName |
HStore.getTableName() |
TableName |
Store.getTableName() |
Modifier and Type | Method and Description |
---|---|
Set<TableName> |
HRegionServer.getOnlineTables()
Gets the online tables in this RS.
|
Modifier and Type | Method and Description |
---|---|
private org.apache.hadoop.fs.Path |
SecureBulkLoadManager.createStagingDir(org.apache.hadoop.fs.Path baseDir,
User user,
TableName tableName) |
private MetricsTableQueryMeterImpl.TableMeters |
MetricsTableQueryMeterImpl.getOrCreateTableMeter(TableName tableName) |
List<HRegion> |
HRegionServer.getRegions(TableName tableName)
Gets the online regions of the specified table.
|
List<? extends Region> |
OnlineRegions.getRegions(TableName tableName)
Get all online regions of a table in this RS.
|
private static String |
MetricsTableQueryMeterImpl.qualifyMetricsName(TableName tableName,
String metric) |
static String |
MetricsTableLatenciesImpl.qualifyMetricsName(TableName tableName,
String metric) |
boolean |
HRegionServer.reportFileArchivalForQuotas(TableName tableName,
Collection<Map.Entry<String,Long>> archivedFiles) |
boolean |
RegionServerServices.reportFileArchivalForQuotas(TableName tableName,
Collection<Map.Entry<String,Long>> archivedFiles)
Reports a collection of files, and their sizes, that belonged to the given
table were
just moved to the archive directory. |
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 |
MetricsRegionServer.updateReadQueryMeter(TableName tn) |
void |
MetricsRegionServer.updateReadQueryMeter(TableName tn,
long count) |
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) |
void |
MetricsTableQueryMeter.updateTableReadQueryMeter(TableName tableName)
Update table read QPS
|
void |
MetricsTableQueryMeterImpl.updateTableReadQueryMeter(TableName tableName) |
void |
RegionServerTableMetrics.updateTableReadQueryMeter(TableName table) |
void |
MetricsTableQueryMeter.updateTableReadQueryMeter(TableName tableName,
long count)
Update table read QPS
|
void |
MetricsTableQueryMeterImpl.updateTableReadQueryMeter(TableName tableName,
long count) |
void |
RegionServerTableMetrics.updateTableReadQueryMeter(TableName table,
long count) |
void |
MetricsTableQueryMeter.updateTableWriteQueryMeter(TableName tableName)
Update table write QPS
|
void |
MetricsTableQueryMeterImpl.updateTableWriteQueryMeter(TableName tableName) |
void |
RegionServerTableMetrics.updateTableWriteQueryMeter(TableName table) |
void |
MetricsTableQueryMeter.updateTableWriteQueryMeter(TableName tableName,
long count)
Update table write QPS
|
void |
MetricsTableQueryMeterImpl.updateTableWriteQueryMeter(TableName tableName,
long count) |
void |
RegionServerTableMetrics.updateTableWriteQueryMeter(TableName table,
long count) |
void |
MetricsRegionServer.updateWriteQueryMeter(TableName tn) |
void |
MetricsRegionServer.updateWriteQueryMeter(TableName tn,
long count) |
Modifier and Type | Method and Description |
---|---|
private void |
RSRpcServices.executeOpenRegionProcedures(org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.OpenRegionRequest request,
Map<TableName,TableDescriptor> tdCache) |
Constructor and Description |
---|
TableHistograms(DynamicMetricsRegistry registry,
TableName tn) |
TableMeters(MetricRegistry metricRegistry,
TableName tableName) |
Modifier and Type | Field and Description |
---|---|
private Map<TableName,? extends Collection<String>> |
ReplicationPeerConfig.excludeTableCFsMap |
private Map<TableName,List<String>> |
ReplicationPeerConfig.ReplicationPeerConfigBuilderImpl.excludeTableCFsMap |
private Map<TableName,? extends Collection<String>> |
ReplicationPeerConfig.tableCFsMap |
private Map<TableName,List<String>> |
ReplicationPeerConfig.ReplicationPeerConfigBuilderImpl.tableCFsMap |
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() |
private Map<TableName,List<String>> |
ReplicationPeerConfig.unmodifiableTableCFsMap(Map<TableName,List<String>> tableCFsMap) |
Modifier and Type | Method and Description |
---|---|
static boolean |
ReplicationUtils.contains(ReplicationPeerConfig peerConfig,
TableName tableName)
Deprecated.
Will be removed in HBase 3.
Use
ReplicationPeerConfig.needToReplicate(TableName) instead. |
private boolean |
NamespaceTableCfWALEntryFilter.filterByExcludeTableCfs(TableName tableName,
String family,
Map<TableName,List<String>> excludeTableCfs) |
private boolean |
NamespaceTableCfWALEntryFilter.filterByTableCfs(TableName tableName,
String family,
Map<TableName,List<String>> tableCfs) |
boolean |
ReplicationPeerConfig.needToReplicate(TableName table)
Decide whether the table need replicate to the peer cluster
|
Modifier and Type | Method and Description |
---|---|
private boolean |
NamespaceTableCfWALEntryFilter.filterByExcludeTableCfs(TableName tableName,
String family,
Map<TableName,List<String>> excludeTableCfs) |
private boolean |
NamespaceTableCfWALEntryFilter.filterByTableCfs(TableName tableName,
String family,
Map<TableName,List<String>> tableCfs) |
private static boolean |
ReplicationUtils.isTableCFsEqual(Map<TableName,List<String>> tableCFs1,
Map<TableName,List<String>> tableCFs2) |
private static boolean |
ReplicationUtils.isTableCFsEqual(Map<TableName,List<String>> tableCFs1,
Map<TableName,List<String>> tableCFs2) |
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.
|
ReplicationPeerConfigBuilder |
ReplicationPeerConfig.ReplicationPeerConfigBuilderImpl.setExcludeTableCFsMap(Map<TableName,List<String>> excludeTableCFsMap) |
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.
|
ReplicationPeerConfigBuilder |
ReplicationPeerConfig.ReplicationPeerConfigBuilderImpl.setTableCFsMap(Map<TableName,List<String>> tableCFsMap) |
private Map<TableName,List<String>> |
ReplicationPeerConfig.unmodifiableTableCFsMap(Map<TableName,List<String>> tableCFsMap) |
Modifier and Type | Field and Description |
---|---|
(package private) org.apache.hbase.thirdparty.com.google.common.cache.Cache<TableName,Boolean> |
RegionReplicaReplicationEndpoint.RegionReplicaSinkWriter.disabledAndDroppedTables |
private org.apache.hbase.thirdparty.com.google.common.cache.Cache<TableName,Boolean> |
RegionReplicaReplicationEndpoint.RegionReplicaOutputSink.memstoreReplicationEnabled |
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) |
(package private) void |
Replication.addHFileRefsToQueue(TableName tableName,
byte[] family,
List<Pair<org.apache.hadoop.fs.Path,org.apache.hadoop.fs.Path>> pairs) |
void |
RegionReplicaReplicationEndpoint.RegionReplicaSinkWriter.append(TableName tableName,
byte[] encodedRegionName,
byte[] row,
List<WAL.Entry> entries) |
protected void |
ReplicationSink.batch(TableName tableName,
Collection<List<Row>> allRows)
Do the changes and handle the pool
|
private void |
ReplicationSink.buildBulkLoadHFileMap(Map<String,List<Pair<byte[],List<String>>>> bulkLoadHFileMap,
TableName table,
org.apache.hadoop.hbase.shaded.protobuf.generated.WALProtos.BulkLoadDescriptor bld) |
private org.apache.hadoop.fs.Path |
HFileReplicator.createStagingDir(org.apache.hadoop.fs.Path baseDir,
User user,
TableName tableName) |
boolean |
WALEntrySinkFilter.filter(TableName table,
long writeTime) |
private String |
ReplicationSink.getHFilePath(TableName table,
org.apache.hadoop.hbase.shaded.protobuf.generated.WALProtos.BulkLoadDescriptor bld,
String storeFile,
byte[] family) |
private boolean |
RegionReplicaReplicationEndpoint.RegionReplicaOutputSink.requiresReplication(TableName tableName,
List<WAL.Entry> entries)
returns true if the specified entry must be replicated.
|
Constructor and Description |
---|
RegionReplicaReplayCallable(ClusterConnection connection,
RpcControllerFactory rpcControllerFactory,
TableName tableName,
HRegionLocation location,
RegionInfo regionInfo,
byte[] row,
List<WAL.Entry> entries,
AtomicLong skippedEntries) |
Modifier and Type | Method and Description |
---|---|
private javax.ws.rs.core.Response |
SchemaResource.replace(TableName name,
TableSchemaModel model,
javax.ws.rs.core.UriInfo uriInfo,
Admin admin) |
private javax.ws.rs.core.Response |
SchemaResource.update(TableName name,
TableSchemaModel model,
javax.ws.rs.core.UriInfo uriInfo,
Admin admin) |
Modifier and Type | Field and Description |
---|---|
static TableName |
RSGroupInfoManager.RSGROUP_TABLE_NAME |
Modifier and Type | Field and Description |
---|---|
private Map<TableName,String> |
RSGroupInfoManagerImpl.tableMap |
private SortedSet<TableName> |
RSGroupInfo.tables |
Modifier and Type | Method and Description |
---|---|
private Pair<Map<TableName,Map<ServerName,List<RegionInfo>>>,List<RegionPlan>> |
RSGroupBasedLoadBalancer.correctAssignments(Map<TableName,Map<ServerName,List<RegionInfo>>> existingAssignments) |
private Map<TableName,String> |
RSGroupInfoManagerImpl.flushConfigTable(Map<String,RSGroupInfo> groupMap) |
private Map<TableName,Map<ServerName,List<RegionInfo>>> |
RSGroupAdminServer.getRSGroupAssignmentsByTable(String groupName) |
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.balanceTable(TableName tableName,
Map<ServerName,List<RegionInfo>> loadOfOneTable)
can achieve table balanced rather than overall balanced
|
boolean |
RSGroupInfo.containsTable(TableName table) |
RSGroupInfo |
RSGroupInfoManager.determineRSGroupInfoForTable(TableName tableName)
Determine
RSGroupInfo for the given table. |
RSGroupInfo |
RSGroupInfoManagerImpl.determineRSGroupInfoForTable(TableName tableName)
Will try to get the rsgroup from
tableMap first
then try to get the rsgroup from script
try to get the rsgroup from the NamespaceDescriptor lastly. |
RSGroupInfo |
RSGroupAdmin.getRSGroupInfoOfTable(TableName tableName)
Gets
RSGroupInfo for the given table's group. |
RSGroupInfo |
RSGroupAdminServer.getRSGroupInfoOfTable(TableName tableName) |
RSGroupInfo |
RSGroupAdminClient.getRSGroupInfoOfTable(TableName tableName) |
String |
RSGroupInfoManager.getRSGroupOfTable(TableName tableName)
Get the group membership of a table
|
String |
RSGroupInfoManagerImpl.getRSGroupOfTable(TableName tableName) |
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) |
List<RegionPlan> |
RSGroupBasedLoadBalancer.balanceCluster(Map<TableName,Map<ServerName,List<RegionInfo>>> loadOfAllTable)
Override to balance by RSGroup
not invoke
RSGroupBasedLoadBalancer.balanceTable(TableName, Map) |
private void |
RSGroupAdminServer.checkServersAndTables(Set<Address> servers,
Set<TableName> tables,
String targetGroupName)
Check servers and tables.
|
private Pair<Map<TableName,Map<ServerName,List<RegionInfo>>>,List<RegionPlan>> |
RSGroupBasedLoadBalancer.correctAssignments(Map<TableName,Map<ServerName,List<RegionInfo>>> existingAssignments) |
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 |
RSGroupAdminClient.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 |
RSGroupInfoManagerImpl.moveServersAndTables(Set<Address> servers,
Set<TableName> tables,
String srcGroup,
String dstGroup) |
private void |
RSGroupAdminServer.moveTableRegionsToGroup(Set<TableName> tables,
String targetGroupName)
Moves regions of tables which are not on target group servers.
|
void |
RSGroupAdmin.moveTables(Set<TableName> tables,
String targetGroup)
Move given set of tables to the specified target RegionServer group.
|
void |
RSGroupInfoManager.moveTables(Set<TableName> tableNames,
String groupName)
Set the group membership of a set of tables
|
void |
RSGroupAdminServer.moveTables(Set<TableName> tables,
String targetGroup) |
void |
RSGroupInfoManagerImpl.moveTables(Set<TableName> tableNames,
String groupName) |
void |
RSGroupAdminClient.moveTables(Set<TableName> tables,
String targetGroup) |
private void |
RSGroupInfoManagerImpl.resetRSGroupAndTableMaps(Map<String,RSGroupInfo> newRSGroupMap,
Map<TableName,String> newTableMap)
Make changes visible.
|
Constructor and Description |
---|
RSGroupInfo(String name,
SortedSet<Address> servers,
SortedSet<TableName> tables) |
Modifier and Type | Field and Description |
---|---|
static TableName |
AccessControlClient.ACL_TABLE_NAME |
static TableName |
PermissionStorage.ACL_TABLE_NAME
Internal storage table for access control lists
|
private TableName |
TablePermission.table |
private TableName |
AccessControlFilter.table |
private TableName |
AuthResult.table |
private TableName |
Permission.Builder.tableName |
private TableName |
GetUserPermissionsRequest.tableName |
private TableName |
GetUserPermissionsRequest.Builder.tableName |
private TableName |
AuthResult.Params.tableName |
Modifier and Type | Field and Description |
---|---|
private Map<TableName,List<UserPermission>> |
AccessController.tableAcls |
private ConcurrentHashMap<TableName,AuthManager.PermissionCache<TablePermission>> |
AuthManager.tableCache
Cache for table permission.
|
Modifier and Type | Method and Description |
---|---|
TableName |
TablePermission.getTableName() |
TableName |
GetUserPermissionsRequest.getTableName() |
TableName |
AuthResult.getTableName() |
private TableName |
AccessController.getTableName(Region region) |
private TableName |
AccessController.getTableName(RegionCoprocessorEnvironment e) |
static TableName |
ShadedAccessControlUtil.toTableName(org.apache.hadoop.hbase.shaded.protobuf.generated.HBaseProtos.TableName tableNamePB) |
Modifier and Type | Method and Description |
---|---|
(package private) static Pair<Set<String>,Set<TableName>> |
SnapshotScannerHDFSAclController.SnapshotScannerHDFSAclStorage.getUserNamespaceAndTable(Table aclTable,
String userName) |
Modifier and Type | Method and Description |
---|---|
boolean |
AuthManager.accessUserTable(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.
|
boolean |
SnapshotScannerHDFSAclHelper.addTableAcl(TableName tableName,
Set<String> users,
String operation)
Add table user acls
|
(package private) static void |
SnapshotScannerHDFSAclController.SnapshotScannerHDFSAclStorage.addUserTableHdfsAcl(Connection connection,
Set<String> users,
TableName tableName) |
(package private) static void |
SnapshotScannerHDFSAclController.SnapshotScannerHDFSAclStorage.addUserTableHdfsAcl(Connection connection,
String user,
TableName tableName) |
(package private) static void |
SnapshotScannerHDFSAclController.SnapshotScannerHDFSAclStorage.addUserTableHdfsAcl(Table aclTable,
String user,
TableName tableName) |
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 |
AuthManager.authorizeCell(User user,
TableName table,
Cell cell,
Permission.Action action)
Check if user has given action privilige in cell scope.
|
private boolean |
AuthManager.authorizeFamily(Set<TablePermission> permissions,
TableName table,
byte[] family,
Permission.Action action) |
private boolean |
AuthManager.authorizeTable(Set<TablePermission> permissions,
TableName table,
byte[] family,
byte[] qualifier,
Permission.Action action) |
boolean |
AuthManager.authorizeUserFamily(User user,
TableName table,
byte[] family,
Permission.Action action)
Check if user has given action privilige in table:family scope.
|
boolean |
AuthManager.authorizeUserTable(User user,
TableName table,
byte[] family,
byte[] qualifier,
Permission.Action action)
Check if user has given action privilige in table:family:qualifier scope.
|
boolean |
AuthManager.authorizeUserTable(User user,
TableName table,
byte[] family,
Permission.Action action)
Check if user has given action privilige in table:family scope.
|
boolean |
AuthManager.authorizeUserTable(User user,
TableName table,
Permission.Action action)
Check if user has given action privilige in table scope.
|
static org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantRequest |
AccessControlUtil.buildGrantRequest(String username,
TableName tableName,
byte[] family,
byte[] qualifier,
boolean mergeExistingPermissions,
org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission.Action... actions)
Create a request to grant user table permissions.
|
static org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeRequest |
AccessControlUtil.buildRevokeRequest(String username,
TableName tableName,
byte[] family,
byte[] qualifier,
org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission.Action... actions)
Create a request to revoke user table permissions.
|
void |
AccessController.checkLockPermissions(ObserverContext<?> ctx,
String namespace,
TableName tableName,
RegionInfo[] regionInfos,
String reason) |
void |
NoopAccessChecker.checkLockPermissions(User user,
String namespace,
TableName tableName,
RegionInfo[] regionInfos,
String reason) |
void |
AccessChecker.checkLockPermissions(User user,
String namespace,
TableName tableName,
RegionInfo[] regionInfos,
String reason) |
(package private) void |
SnapshotScannerHDFSAclHelper.createTableDirectories(TableName tableName) |
void |
ZKPermissionWatcher.deleteTableACLNode(TableName tableName)
Delete the acl notify node of table
|
(package private) static void |
SnapshotScannerHDFSAclController.SnapshotScannerHDFSAclStorage.deleteTableHdfsAcl(Table aclTable,
TableName tableName) |
(package private) static void |
SnapshotScannerHDFSAclController.SnapshotScannerHDFSAclStorage.deleteUserTableHdfsAcl(Connection connection,
Set<String> users,
TableName tableName) |
(package private) static void |
SnapshotScannerHDFSAclController.SnapshotScannerHDFSAclStorage.deleteUserTableHdfsAcl(Table aclTable,
String user,
TableName tableName) |
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) |
private boolean |
TablePermission.failCheckTable(TableName table) |
private Set<String> |
SnapshotScannerHDFSAclController.filterUsersToRemoveNsAccessAcl(Table aclTable,
TableName tableName,
Set<String> tablesUsers)
Remove table user access HDFS acl from namespace directory if the user has no permissions of
global, ns of the table or other tables of the ns, eg: Bob has 'ns1:t1' read permission, when
delete 'ns1:t1', if Bob has global read permission, '@ns1' read permission or
'ns1:other_tables' read permission, then skip remove Bob access acl in ns1Dirs, otherwise,
remove Bob access acl.
|
(package private) org.apache.hadoop.fs.Path |
SnapshotScannerHDFSAclHelper.PathHelper.getArchiveTableDir(TableName tableName) |
(package private) org.apache.hadoop.fs.Path |
SnapshotScannerHDFSAclHelper.PathHelper.getDataTableDir(TableName tableName) |
(package private) org.apache.hadoop.fs.Path |
SnapshotScannerHDFSAclHelper.PathHelper.getMobTableDir(TableName tableName) |
static org.apache.hbase.thirdparty.com.google.common.collect.ListMultimap<String,UserPermission> |
PermissionStorage.getTablePermissions(org.apache.hadoop.conf.Configuration conf,
TableName tableName) |
(package private) List<org.apache.hadoop.fs.Path> |
SnapshotScannerHDFSAclHelper.getTableRootPaths(TableName tableName,
boolean includeSnapshotPath)
return paths that user will table permission will visit
|
private List<org.apache.hadoop.fs.Path> |
SnapshotScannerHDFSAclHelper.getTableSnapshotPaths(TableName tableName) |
(package private) static Set<String> |
SnapshotScannerHDFSAclController.SnapshotScannerHDFSAclStorage.getTableUsers(Table aclTable,
TableName tableName) |
(package private) org.apache.hadoop.fs.Path |
SnapshotScannerHDFSAclHelper.PathHelper.getTmpTableDir(TableName tableName) |
static List<UserPermission> |
AccessControlUtil.getUserPermissions(com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.AccessControlService.BlockingInterface protocol,
TableName t)
Deprecated.
Use
Admin.getUserPermissions(GetUserPermissionsRequest) instead. |
static List<UserPermission> |
AccessControlUtil.getUserPermissions(com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.AccessControlService.BlockingInterface protocol,
TableName t,
byte[] columnFamily,
byte[] columnQualifier,
String userName)
Deprecated.
Use
Admin.getUserPermissions(GetUserPermissionsRequest) instead. |
(package private) Set<String> |
SnapshotScannerHDFSAclHelper.getUsersWithTableReadAction(TableName tableName,
boolean includeNamespace,
boolean includeGlobal)
Return users with table read permission
|
private UserPermission |
SnapshotScannerHDFSAclController.getUserTablePermission(org.apache.hadoop.conf.Configuration conf,
String userName,
TableName tableName) |
static List<UserPermission> |
PermissionStorage.getUserTablePermissions(org.apache.hadoop.conf.Configuration conf,
TableName tableName,
byte[] cf,
byte[] cq,
String userName,
boolean hasFilterUser)
Returns the currently granted permissions for a given table as the specified user plus
associated permissions.
|
private static void |
AccessControlClient.grant(Connection connection,
TableName tableName,
String userName,
byte[] family,
byte[] qual,
boolean mergeExistingPermissions,
Permission.Action... actions)
Grants permission on the specified table for the specified user
|
static void |
AccessControlClient.grant(Connection connection,
TableName tableName,
String userName,
byte[] family,
byte[] qual,
Permission.Action... actions)
Grants permission on the specified table for the specified user.
|
static void |
AccessControlUtil.grant(com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.AccessControlService.BlockingInterface protocol,
String userShortName,
TableName tableName,
byte[] f,
byte[] q,
boolean mergeExistingPermissions,
Permission.Action... actions)
Deprecated.
Use
Admin.grant(UserPermission, boolean) instead. |
static boolean |
AccessControlUtil.hasPermission(com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.AccessControlService.BlockingInterface protocol,
TableName tableName,
byte[] columnFamily,
byte[] columnQualifier,
String userName,
Permission.Action[] actions)
Deprecated.
Use
Admin.hasUserPermissions(String, List) instead. |
(package private) static boolean |
SnapshotScannerHDFSAclController.SnapshotScannerHDFSAclStorage.hasUserTableHdfsAcl(Table aclTable,
String user,
TableName tableName) |
boolean |
TablePermission.implies(TableName table,
byte[] family,
byte[] qualifier,
Permission.Action action)
Check if given action can performs on given table:family:qualifier.
|
boolean |
TablePermission.implies(TableName table,
byte[] family,
Permission.Action action)
Check if given action can performs on given table:family.
|
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.
|
private boolean |
SnapshotScannerHDFSAclController.isHdfsAclSet(Table aclTable,
String userName,
String namespace,
TableName tableName)
Check if user global/namespace/table HDFS acls is already set
|
private boolean |
SnapshotScannerHDFSAclController.isHdfsAclSet(Table aclTable,
String userName,
TableName tableName) |
private boolean |
SnapshotScannerHDFSAclController.needHandleTableHdfsAcl(TableName tableName,
String operation) |
static Permission.Builder |
Permission.newBuilder(TableName tableName)
Build a table permission
|
static GetUserPermissionsRequest.Builder |
GetUserPermissionsRequest.newBuilder(TableName tableName)
Build a get table permission request
|
private AuthResult |
AccessChecker.permissionGranted(String request,
User user,
Permission.Action permRequest,
TableName tableName,
byte[] family,
byte[] qualifier) |
AuthResult |
NoopAccessChecker.permissionGranted(String request,
User user,
Permission.Action permRequest,
TableName tableName,
Map<byte[],? extends Collection<?>> families) |
AuthResult |
AccessChecker.permissionGranted(String request,
User user,
Permission.Action permRequest,
TableName tableName,
Map<byte[],? extends Collection<?>> families)
Check the current user for authorization to perform a specific action against the given set of
row data.
|
void |
SnapshotScannerHDFSAclController.postCompletedDeleteTableAction(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName) |
void |
SnapshotScannerHDFSAclController.postCompletedTruncateTableAction(ObserverContext<MasterCoprocessorEnvironment> c,
TableName tableName) |
void |
AccessController.postDeleteTable(ObserverContext<MasterCoprocessorEnvironment> c,
TableName tableName) |
void |
AccessController.postModifyTable(ObserverContext<MasterCoprocessorEnvironment> c,
TableName tableName,
TableDescriptor htd) |
void |
SnapshotScannerHDFSAclController.postModifyTable(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName,
TableDescriptor oldDescriptor,
TableDescriptor currentDescriptor) |
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.preGetUserPermissions(ObserverContext<MasterCoprocessorEnvironment> ctx,
String userName,
String namespace,
TableName tableName,
byte[] family,
byte[] qualifier) |
private void |
AccessController.preGetUserPermissions(User caller,
String userName,
String namespace,
TableName tableName,
byte[] family,
byte[] qualifier) |
void |
AccessController.preLockHeartbeat(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName,
String description) |
TableDescriptor |
AccessController.preModifyTable(ObserverContext<MasterCoprocessorEnvironment> c,
TableName tableName,
TableDescriptor currentDesc,
TableDescriptor newDesc) |
TableDescriptor |
CoprocessorWhitelistMasterObserver.preModifyTable(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName,
TableDescriptor currentDesc,
TableDescriptor newDesc) |
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 |
AuthManager.refreshTableCacheFromWritable(TableName table,
byte[] data)
Update acl info for table.
|
boolean |
SnapshotScannerHDFSAclHelper.removeNamespaceAccessAcl(TableName tableName,
Set<String> removeUsers,
String operation)
Remove table access acl from namespace dir when delete table
|
void |
AuthManager.removeTable(TableName table)
Remove given table from AuthManager's table cache.
|
boolean |
SnapshotScannerHDFSAclHelper.removeTableAcl(TableName tableName,
Set<String> users)
Remove table acls when modify table
|
boolean |
SnapshotScannerHDFSAclHelper.removeTableDefaultAcl(TableName tableName,
Set<String> removeUsers)
Remove default acl from table archive dir when delete table
|
(package private) static void |
PermissionStorage.removeTablePermissions(org.apache.hadoop.conf.Configuration conf,
TableName tableName,
byte[] column,
Table t)
Remove specified table column from the acl table.
|
(package private) static void |
PermissionStorage.removeTablePermissions(org.apache.hadoop.conf.Configuration conf,
TableName tableName,
Table t)
Remove specified table from the _acl_ table.
|
private static void |
PermissionStorage.removeTablePermissions(TableName tableName,
byte[] column,
Table table,
boolean closeTable) |
private void |
SnapshotScannerHDFSAclController.removeUserTableHdfsAcl(Table aclTable,
String userName,
TableName tableName,
UserPermission userPermission) |
void |
AccessController.requireAccess(ObserverContext<?> ctx,
String request,
TableName tableName,
Permission.Action... permissions) |
void |
NoopAccessChecker.requireAccess(User user,
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 |
NoopAccessChecker.requireGlobalPermission(User user,
String request,
Permission.Action perm,
TableName tableName,
Map<byte[],? extends Collection<byte[]>> familyMap,
String filterUser) |
void |
AccessChecker.requireGlobalPermission(User user,
String request,
Permission.Action perm,
TableName tableName,
Map<byte[],? extends Collection<byte[]>> familyMap,
String filterUser)
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 |
NoopAccessChecker.requireNamespacePermission(User user,
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 |
NoopAccessChecker.requirePermission(User user,
String request,
TableName tableName,
byte[] family,
byte[] qualifier,
String filterUser,
Permission.Action... permissions) |
void |
AccessChecker.requirePermission(User user,
String request,
TableName tableName,
byte[] family,
byte[] qualifier,
String filterUser,
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 |
NoopAccessChecker.requireTablePermission(User user,
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,
org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.AccessControlService.BlockingInterface protocol,
String userShortName,
TableName tableName,
byte[] f,
byte[] q,
Permission.Action... actions)
Deprecated.
Use
Admin.revoke(UserPermission) instead. |
AuthResult.Params |
AuthResult.Params.setTableName(TableName table) |
private boolean |
SnapshotScannerHDFSAclCleaner.tableExists(TableName tableName) |
static org.apache.hadoop.hbase.shaded.protobuf.generated.HBaseProtos.TableName |
ShadedAccessControlUtil.toProtoTableName(TableName tableName) |
private void |
AuthManager.updateTableCache(TableName table,
org.apache.hbase.thirdparty.com.google.common.collect.ListMultimap<String,Permission> tablePerms)
Updates the internal table permissions cache for specified table.
|
Modifier and Type | Method and Description |
---|---|
boolean |
SnapshotScannerHDFSAclHelper.grantAcl(UserPermission userPermission,
Set<String> skipNamespaces,
Set<TableName> skipTables)
Set acl when grant user permission
|
private void |
SnapshotScannerHDFSAclHelper.handleGlobalAcl(Set<String> users,
Set<String> skipNamespaces,
Set<TableName> skipTables,
SnapshotScannerHDFSAclHelper.HDFSAclOperation.OperationType operationType) |
private void |
SnapshotScannerHDFSAclHelper.handleGrantOrRevokeAcl(UserPermission userPermission,
SnapshotScannerHDFSAclHelper.HDFSAclOperation.OperationType operationType,
Set<String> skipNamespaces,
Set<TableName> skipTables) |
private void |
SnapshotScannerHDFSAclHelper.handleNamespaceAcl(Set<String> namespaces,
Set<String> users,
Set<String> skipNamespaces,
Set<TableName> skipTables,
SnapshotScannerHDFSAclHelper.HDFSAclOperation.OperationType operationType) |
private void |
SnapshotScannerHDFSAclHelper.handleTableAcl(Set<TableName> tableNames,
Set<String> users,
Set<String> skipNamespaces,
Set<TableName> skipTables,
SnapshotScannerHDFSAclHelper.HDFSAclOperation.OperationType operationType) |
private void |
SnapshotScannerHDFSAclHelper.handleTableAcl(Set<TableName> tableNames,
Set<String> users,
Set<String> skipNamespaces,
Set<TableName> skipTables,
SnapshotScannerHDFSAclHelper.HDFSAclOperation.OperationType operationType) |
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) |
boolean |
SnapshotScannerHDFSAclHelper.revokeAcl(UserPermission userPermission,
Set<String> skipNamespaces,
Set<TableName> skipTables)
Remove acl when grant or revoke user permission
|
Constructor and Description |
---|
AccessControlFilter(AuthManager mgr,
User ugi,
TableName tableName,
AccessControlFilter.Strategy strategy,
Map<ByteRange,Integer> cfVsMaxVersions) |
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) |
Builder(TableName tableName) |
Builder(TableName tableName) |
GetUserPermissionsRequest(String userName,
String namespace,
TableName tableName,
byte[] family,
byte[] qualifier) |
TablePermission(TableName table,
byte[] family,
byte[] qualifier,
Permission.Action... assigned)
Construct a table:family:qualifier permission.
|
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) |
TableDescriptor |
VisibilityController.preModifyTable(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName,
TableDescriptor currentDescriptor,
TableDescriptor newDescriptor) |
Modifier and Type | Field and Description |
---|---|
static TableName |
SlowLogTableAccessor.SLOW_LOG_TABLE_NAME
hbase:slowlog table name - can be enabled
with config - hbase.regionserver.slowlog.systable.enabled
|
Modifier and Type | Field and Description |
---|---|
private TableName |
RestoreSnapshotHelper.snapshotTable |
private TableName |
SnapshotInfo.SnapshotStats.snapshotTable |
private TableName |
CreateSnapshot.tableName |
Modifier and Type | Method and Description |
---|---|
static RegionInfo |
RestoreSnapshotHelper.cloneRegionInfo(TableName tableName,
RegionInfo snapshotRegionInfo) |
static void |
RestoreSnapshotHelper.restoreSnapshotAcl(org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotDescription snapshot,
TableName newTableName,
org.apache.hadoop.conf.Configuration conf) |
Constructor and Description |
---|
TablePartiallyOpenException(TableName tableName) |
Modifier and Type | Method and Description |
---|---|
private static TableName |
ThriftHBaseServiceHandler.getTableName(ByteBuffer buffer) |
Modifier and Type | Method and Description |
---|---|
static TableName |
ThriftUtilities.tableNameFromThrift(org.apache.hadoop.hbase.thrift2.generated.TTableName tableName) |
static TableName[] |
ThriftUtilities.tableNamesArrayFromThrift(List<org.apache.hadoop.hbase.thrift2.generated.TTableName> tableNames) |
Modifier and Type | Method and Description |
---|---|
static List<TableName> |
ThriftUtilities.tableNamesFromThrift(List<org.apache.hadoop.hbase.thrift2.generated.TTableName> tableNames) |
Modifier and Type | Method and Description |
---|---|
static org.apache.hadoop.hbase.thrift2.generated.TTableName |
ThriftUtilities.tableNameFromHBase(TableName table) |
static List<org.apache.hadoop.hbase.thrift2.generated.TTableName> |
ThriftUtilities.tableNamesFromHBase(TableName[] in) |
Modifier and Type | Method and Description |
---|---|
static List<org.apache.hadoop.hbase.thrift2.generated.TTableName> |
ThriftUtilities.tableNamesFromHBase(List<TableName> in) |
Modifier and Type | Field and Description |
---|---|
private TableName |
ThriftTable.tableName |
Modifier and Type | Method and Description |
---|---|
TableName |
ThriftTable.getName() |
TableName[] |
ThriftAdmin.listTableNames() |
TableName[] |
ThriftAdmin.listTableNames(Pattern pattern) |
TableName[] |
ThriftAdmin.listTableNames(Pattern pattern,
boolean includeSysTables) |
TableName[] |
ThriftAdmin.listTableNames(String regex) |
TableName[] |
ThriftAdmin.listTableNames(String regex,
boolean includeSysTables) |
TableName[] |
ThriftAdmin.listTableNamesByNamespace(String name) |
Modifier and Type | Method and Description |
---|---|
Map<TableName,SpaceQuotaSnapshot> |
ThriftAdmin.getRegionServerSpaceQuotaSnapshots(ServerName serverName) |
Map<TableName,Long> |
ThriftAdmin.getSpaceQuotaTableSizes() |
Modifier and Type | Method and Description |
---|---|
void |
ThriftAdmin.addColumnFamily(TableName tableName,
ColumnFamilyDescriptor columnFamily) |
Future<Void> |
ThriftAdmin.addColumnFamilyAsync(TableName tableName,
ColumnFamilyDescriptor columnFamily) |
CacheEvictionStats |
ThriftAdmin.clearBlockCache(TableName tableName) |
Future<Void> |
ThriftAdmin.cloneSnapshotAsync(String snapshotName,
TableName tableName,
boolean cloneAcl) |
void |
ThriftAdmin.cloneTableSchema(TableName tableName,
TableName newTableName,
boolean preserveSplits) |
void |
ThriftAdmin.compact(TableName tableName) |
void |
ThriftAdmin.compact(TableName tableName,
byte[] columnFamily) |
void |
ThriftAdmin.compact(TableName tableName,
byte[] columnFamily,
CompactType compactType) |
void |
ThriftAdmin.compact(TableName tableName,
CompactType compactType) |
void |
ThriftAdmin.deleteColumn(TableName tableName,
byte[] columnFamily) |
void |
ThriftAdmin.deleteColumnFamily(TableName tableName,
byte[] columnFamily) |
Future<Void> |
ThriftAdmin.deleteColumnFamilyAsync(TableName tableName,
byte[] columnFamily) |
void |
ThriftAdmin.deleteTable(TableName tableName) |
Future<Void> |
ThriftAdmin.deleteTableAsync(TableName tableName) |
void |
ThriftAdmin.disableTable(TableName tableName) |
Future<Void> |
ThriftAdmin.disableTableAsync(TableName tableName) |
void |
ThriftAdmin.disableTableReplication(TableName tableName) |
void |
ThriftAdmin.enableTable(TableName tableName) |
Future<Void> |
ThriftAdmin.enableTableAsync(TableName tableName) |
void |
ThriftAdmin.enableTableReplication(TableName tableName) |
void |
ThriftAdmin.flush(TableName tableName) |
Pair<Integer,Integer> |
ThriftAdmin.getAlterStatus(TableName tableName) |
BufferedMutator |
ThriftConnection.getBufferedMutator(TableName tableName) |
CompactionState |
ThriftAdmin.getCompactionState(TableName tableName) |
CompactionState |
ThriftAdmin.getCompactionState(TableName tableName,
CompactType compactType) |
SpaceQuotaSnapshot |
ThriftAdmin.getCurrentSpaceQuotaSnapshot(TableName tableName) |
TableDescriptor |
ThriftAdmin.getDescriptor(TableName tableName) |
long |
ThriftAdmin.getLastMajorCompactionTimestamp(TableName tableName) |
RegionLocator |
ThriftConnection.getRegionLocator(TableName tableName) |
List<RegionMetrics> |
ThriftAdmin.getRegionMetrics(ServerName serverName,
TableName tableName) |
List<RegionInfo> |
ThriftAdmin.getRegions(TableName tableName) |
TableBuilder |
ThriftConnection.getTableBuilder(TableName tableName,
ExecutorService pool)
Get a TableBuider to build ThriftTable, ThriftTable is NOT thread safe
|
HTableDescriptor |
ThriftAdmin.getTableDescriptor(TableName tableName) |
List<HRegionInfo> |
ThriftAdmin.getTableRegions(TableName tableName) |
boolean |
ThriftAdmin.isTableAvailable(TableName tableName) |
boolean |
ThriftAdmin.isTableAvailable(TableName tableName,
byte[][] splitKeys) |
boolean |
ThriftAdmin.isTableDisabled(TableName tableName) |
boolean |
ThriftAdmin.isTableEnabled(TableName tableName) |
void |
ThriftAdmin.majorCompact(TableName tableName) |
void |
ThriftAdmin.majorCompact(TableName tableName,
byte[] columnFamily) |
void |
ThriftAdmin.majorCompact(TableName tableName,
byte[] columnFamily,
CompactType compactType) |
void |
ThriftAdmin.majorCompact(TableName tableName,
CompactType compactType) |
void |
ThriftAdmin.modifyColumnFamily(TableName tableName,
ColumnFamilyDescriptor columnFamily) |
Future<Void> |
ThriftAdmin.modifyColumnFamilyAsync(TableName tableName,
ColumnFamilyDescriptor columnFamily) |
void |
ThriftAdmin.modifyTable(TableName tableName,
TableDescriptor td) |
Future<Void> |
ThriftAdmin.modifyTableAsync(TableName tableName,
TableDescriptor td) |
void |
ThriftAdmin.snapshot(byte[] snapshotName,
TableName tableName) |
void |
ThriftAdmin.snapshot(String snapshotName,
TableName tableName) |
void |
ThriftAdmin.snapshot(String snapshotName,
TableName tableName,
SnapshotType type) |
void |
ThriftAdmin.split(TableName tableName) |
void |
ThriftAdmin.split(TableName tableName,
byte[] splitPoint) |
boolean |
ThriftAdmin.tableExists(TableName tableName) |
void |
ThriftAdmin.truncateTable(TableName tableName,
boolean preserveSplits) |
Future<Void> |
ThriftAdmin.truncateTableAsync(TableName tableName,
boolean preserveSplits) |
Modifier and Type | Method and Description |
---|---|
HTableDescriptor[] |
ThriftAdmin.getTableDescriptorsByTableName(List<TableName> tableNames) |
List<TableDescriptor> |
ThriftAdmin.listTableDescriptors(List<TableName> tableNames) |
Constructor and Description |
---|
ThriftTable(TableName tableName,
org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client client,
org.apache.thrift.transport.TTransport tTransport,
org.apache.hadoop.conf.Configuration conf) |
Modifier and Type | Field and Description |
---|---|
static TableName |
CanaryTool.DEFAULT_WRITE_TABLE_NAME |
private TableName |
CanaryTool.RegionTaskResult.tableName |
private TableName |
CanaryTool.RegionMonitor.writeTableName |
Modifier and Type | Method and Description |
---|---|
TableName |
CanaryTool.RegionTaskResult.getTableName() |
Modifier and Type | Method and Description |
---|---|
protected ClientServiceCallable<byte[]> |
LoadIncrementalHFiles.buildClientServiceCallable(Connection conn,
TableName tableName,
byte[] first,
Collection<LoadIncrementalHFiles.LoadQueueItem> lqis,
boolean copyFile)
Deprecated.
|
Map<BulkLoadHFiles.LoadQueueItem,ByteBuffer> |
BulkLoadHFilesTool.bulkLoad(TableName tableName,
Map<byte[],List<org.apache.hadoop.fs.Path>> family2Files) |
Map<BulkLoadHFiles.LoadQueueItem,ByteBuffer> |
BulkLoadHFiles.bulkLoad(TableName tableName,
Map<byte[],List<org.apache.hadoop.fs.Path>> family2Files)
Perform a bulk load of the given directory into the given pre-existing table.
|
Map<BulkLoadHFiles.LoadQueueItem,ByteBuffer> |
BulkLoadHFilesTool.bulkLoad(TableName tableName,
org.apache.hadoop.fs.Path dir) |
Map<BulkLoadHFiles.LoadQueueItem,ByteBuffer> |
BulkLoadHFiles.bulkLoad(TableName tableName,
org.apache.hadoop.fs.Path dir)
Perform a bulk load of the given directory into the given pre-existing table.
|
private void |
LoadIncrementalHFiles.createTable(TableName tableName,
org.apache.hadoop.fs.Path hfofDir,
Admin admin)
Deprecated.
If the table is created for the first time, then "completebulkload" reads the files twice.
|
Map<LoadIncrementalHFiles.LoadQueueItem,ByteBuffer> |
LoadIncrementalHFiles.run(Map<byte[],List<org.apache.hadoop.fs.Path>> family2Files,
TableName tableName)
Deprecated.
Perform bulk load on the given table.
|
protected Map<LoadIncrementalHFiles.LoadQueueItem,ByteBuffer> |
LoadIncrementalHFiles.run(org.apache.hadoop.fs.Path hfofDir,
TableName tableName)
Deprecated.
|
Map<LoadIncrementalHFiles.LoadQueueItem,ByteBuffer> |
LoadIncrementalHFiles.run(String hfofDir,
TableName tableName)
Deprecated.
Perform bulk load on the given table.
|
protected List<LoadIncrementalHFiles.LoadQueueItem> |
LoadIncrementalHFiles.tryAtomicRegionLoad(ClientServiceCallable<byte[]> serviceCallable,
TableName tableName,
byte[] first,
Collection<LoadIncrementalHFiles.LoadQueueItem> lqis)
Deprecated.
as of release 2.3.0. Use
BulkLoadHFiles instead. |
protected List<LoadIncrementalHFiles.LoadQueueItem> |
LoadIncrementalHFiles.tryAtomicRegionLoad(Connection conn,
TableName tableName,
byte[] first,
Collection<LoadIncrementalHFiles.LoadQueueItem> lqis,
boolean copyFile)
Deprecated.
as of release 2.3.0. Use
BulkLoadHFiles instead. |
Constructor and Description |
---|
RegionMonitor(Connection connection,
String[] monitorTargets,
boolean useRegExp,
CanaryTool.Sink sink,
ExecutorService executor,
boolean writeSniffing,
TableName writeTableName,
boolean treatFailureAsError,
HashMap<String,Long> configuredReadTableTimeouts,
long configuredWriteTableTimeout,
long allowedFailures) |
RegionTaskResult(RegionInfo region,
TableName tableName,
ServerName serverName,
ColumnFamilyDescriptor column) |
Modifier and Type | Field and Description |
---|---|
private TableName |
HBaseFsck.cleanReplicationBarrierTable
Deprecated.
|
(package private) TableName |
HbckTableInfo.tableName |
Modifier and Type | Field and Description |
---|---|
private Map<TableName,TableDescriptor> |
FSTableDescriptors.cache |
private Map<TableName,Set<String>> |
HBaseFsck.orphanTableDirs
Deprecated.
|
private Map<TableName,Set<String>> |
HBaseFsck.skippedRegions
Deprecated.
|
private Set<TableName> |
HBaseFsck.tablesIncluded
Deprecated.
|
private SortedMap<TableName,HbckTableInfo> |
HBaseFsck.tablesInfo
Deprecated.
This map from Tablename -> TableInfo contains the structures necessary to
detect table consistency problems (holes, dupes, overlaps).
|
private Map<TableName,TableState> |
HBaseFsck.tableStates
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
TableName |
HbckTableInfo.getName() |
TableName |
HbckRegionInfo.getTableName() |
static TableName |
CommonFSUtils.getTableName(org.apache.hadoop.fs.Path tablePath)
Returns the
TableName object representing
the table directory under
path rootdir |
static TableName |
HFileArchiveUtil.getTableName(org.apache.hadoop.fs.Path archivePath) |
Modifier and Type | Method and Description |
---|---|
private SortedMap<TableName,HbckTableInfo> |
HBaseFsck.checkHdfsIntegrity(boolean fixHoles,
boolean fixOverlaps)
Deprecated.
|
(package private) SortedMap<TableName,HbckTableInfo> |
HBaseFsck.checkIntegrity()
Deprecated.
Checks tables integrity.
|
(package private) Set<TableName> |
HBaseFsck.getIncludedTables()
Deprecated.
|
private SortedMap<TableName,HbckTableInfo> |
HBaseFsck.loadHdfsRegionInfos()
Deprecated.
Populate hbi's from regionInfos loaded from file system.
|
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 |
---|---|
(package private) static void |
RegionSplitter.createPresplitTable(TableName tableName,
RegionSplitter.SplitAlgorithm splitAlgo,
String[] columnFamilies,
org.apache.hadoop.conf.Configuration conf) |
private boolean |
HBaseFsck.fabricateTableInfo(FSTableDescriptors fstd,
TableName tableName,
Set<String> columns)
Deprecated.
To fabricate a .tableinfo file with following contents
1. |
TableDescriptor |
FSTableDescriptors.get(TableName tablename)
Get the current table descriptor for the given table, or null if none exists.
|
static org.apache.hadoop.fs.Path |
HFileArchiveUtil.getRegionArchiveDir(org.apache.hadoop.fs.Path rootDir,
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 |
CommonFSUtils.getRegionDir(org.apache.hadoop.fs.Path rootdir,
TableName tableName,
String regionName)
Returns the
Path object representing the region directory under
path rootdir |
(package private) static LinkedList<Pair<byte[],byte[]>> |
RegionSplitter.getSplits(Connection connection,
TableName tableName,
RegionSplitter.SplitAlgorithm splitAlgo) |
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 |
(package private) org.apache.hadoop.fs.Path |
FSTableDescriptors.getTableDir(TableName tableName)
Return the table directory in HDFS
|
private static Pair<org.apache.hadoop.fs.Path,org.apache.hadoop.fs.Path> |
RegionSplitter.getTableDirAndSplitFile(org.apache.hadoop.conf.Configuration conf,
TableName tableName) |
private static org.apache.hadoop.hbase.shaded.protobuf.generated.ZooKeeperProtos.DeprecatedTableState.State |
ZKDataMigrator.getTableState(ZKWatcher zkw,
TableName tableName)
Deprecated.
Since 2.0.0. To be removed in hbase-3.0.0.
|
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,
FSUtils.ProgressReporter progressReporter)
Runs through the HBase rootdir/tablename and creates a reverse lookup map for
table StoreFile names to the full Path.
|
static Map<String,org.apache.hadoop.fs.Path> |
FSUtils.getTableStoreFilePathMap(Map<String,org.apache.hadoop.fs.Path> resultMap,
org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.fs.Path hbaseRootDir,
TableName tableName,
org.apache.hadoop.fs.PathFilter sfFilter,
ExecutorService executor,
HbckErrorReporter progressReporter)
Deprecated.
Since 2.3.0. For removal in hbase4. Use ProgressReporter override instead.
|
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)
Deprecated.
|
(package private) boolean |
HBaseFsck.isTableDisabled(TableName tableName)
Deprecated.
Check if the specified region's table is disabled.
|
(package private) boolean |
HBaseFsck.isTableIncluded(TableName table)
Deprecated.
Only check/fix tables specified by the list,
Empty list means all tables are included.
|
<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.
|
(package private) static void |
RegionSplitter.rollingSplit(TableName tableName,
RegionSplitter.SplitAlgorithm splitAlgo,
org.apache.hadoop.conf.Configuration conf) |
(package private) static LinkedList<Pair<byte[],byte[]>> |
RegionSplitter.splitScan(LinkedList<Pair<byte[],byte[]>> regionList,
Connection connection,
TableName tableName,
RegionSplitter.SplitAlgorithm splitAlgo) |
Modifier and Type | Method and Description |
---|---|
(package private) TableDescriptor[] |
HBaseFsck.getTableDescriptors(List<TableName> tableNames)
Deprecated.
|
private void |
HBaseFsck.printTableSummary(SortedMap<TableName,HbckTableInfo> tablesInfo)
Deprecated.
Prints summary of all tables found on the system.
|
Constructor and Description |
---|
HbckTableInfo(TableName name,
HBaseFsck hbck) |
Modifier and Type | Field and Description |
---|---|
protected TableName |
MajorCompactor.tableName |
Constructor and Description |
---|
MajorCompactor(org.apache.hadoop.conf.Configuration conf,
TableName tableName,
Set<String> storesToCompact,
int concurrency,
long timestamp,
long sleepForMs) |
Modifier and Type | Field and Description |
---|---|
private TableName |
WALKeyImpl.tablename |
(package private) TableName |
EntryBuffers.RegionEntryBuffer.tableName |
Modifier and Type | Method and Description |
---|---|
TableName |
WALKeyImpl.getTableName() |
TableName |
WALKey.getTableName() |
TableName |
EntryBuffers.RegionEntryBuffer.getTableName() |
Modifier and Type | Method and Description |
---|---|
protected AbstractRecoveredEditsOutputSink.RecoveredEditsWriter |
AbstractRecoveredEditsOutputSink.createRecoveredEditsWriter(TableName tableName,
byte[] region,
long seqId) |
private StoreFileWriter |
BoundedRecoveredHFilesOutputSink.createRecoveredHFileWriter(TableName tableName,
String regionName,
long seqId,
String familyName,
boolean isMetaTable) |
private AbstractRecoveredEditsOutputSink.RecoveredEditsWriter |
RecoveredEditsOutputSink.getRecoveredEditsWriter(TableName tableName,
byte[] region,
long seqId)
Get a writer and path for a log starting at the given entry.
|
(package private) static org.apache.hadoop.fs.Path |
WALSplitUtil.getRegionSplitEditsPath(TableName tableName,
byte[] encodedRegionName,
long seqId,
String fileNameBeingSplit,
String tmpDirName,
org.apache.hadoop.conf.Configuration conf)
Path to a file under RECOVERED_EDITS_DIR directory of the region found in
logEntry
named for the sequenceid in the passed logEntry : e.g. |
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,
Map<String,byte[]> extendedAttributes) |
(package private) void |
WALKeyImpl.internTableName(TableName tablename)
Drop this instance's tablename byte array and instead
hold a reference to the provided tablename.
|
private boolean |
WALSplitter.isRegionDirPresentUnderRoot(TableName tableName,
String regionName) |
(package private) static org.apache.hadoop.fs.Path |
WALSplitUtil.tryCreateRecoveredHFilesDir(org.apache.hadoop.fs.FileSystem rootFS,
org.apache.hadoop.conf.Configuration conf,
TableName tableName,
String encodedRegionName,
String familyName)
Return path to recovered.hfiles directory of the region's column family: e.g.
|
Constructor and Description |
---|
RegionEntryBuffer(TableName tableName,
byte[] region) |
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 now,
List<UUID> clusterIds,
long nonceGroup,
long nonce,
MultiVersionConcurrencyControl mvcc,
NavigableMap<byte[],Integer> replicationScope,
Map<String,byte[]> extendedAttributes) |
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,
MultiVersionConcurrencyControl mvcc,
NavigableMap<byte[],Integer> replicationScope,
Map<String,byte[]> extendedAttributes) |
WALKeyImpl(byte[] encodedRegionName,
TableName tablename,
long now,
NavigableMap<byte[],Integer> replicationScope) |
Modifier and Type | Field and Description |
---|---|
(package private) static TableName |
HelloHBase.MY_TABLE_NAME |
Modifier and Type | Field and Description |
---|---|
(package private) static TableName |
HelloHBase.MY_TABLE_NAME |
Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.