Modifier and Type | Field and Description |
---|---|
static TableName |
HTestConst.DEFAULT_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.
|
protected static TableName |
IntegrationTestManyRegions.TABLE_NAME |
static TableName |
TestAcidGuarantees.TABLE_NAME |
Modifier and Type | Method and Description |
---|---|
TableName |
HRegionInfo.getTable()
Get current table name of the region
|
static TableName |
HRegionInfo.getTable(byte[] regionName)
Gets the table name from the specified region name.
|
TableName |
IntegrationTestAcidGuarantees.getTablename() |
abstract TableName |
IntegrationTestBase.getTablename() |
TableName |
IntegrationTestDDLMasterFailover.getTablename() |
TableName |
IntegrationTestIngest.getTablename() |
TableName |
IntegrationTestRegionReplicaPerf.getTablename() |
TableName |
HTableDescriptor.getTableName()
Get the name of the table
|
static TableName |
TableName.valueOf(byte[] fullName) |
static TableName |
TableName.valueOf(byte[] namespace,
byte[] qualifier) |
static TableName |
TableName.valueOf(ByteBuffer namespace,
ByteBuffer qualifier) |
static TableName |
TableName.valueOf(String name) |
static TableName |
TableName.valueOf(String namespaceAsString,
String qualifierAsString) |
Modifier and Type | Method and Description |
---|---|
Set<TableName> |
MockRegionServerServices.getOnlineTables() |
Set<TableName> |
TableStateManager.getTablesInStates(ZooKeeperProtos.Table.State... states) |
Modifier and Type | Method and Description |
---|---|
void |
TableStateManager.checkAndRemoveTableState(TableName tableName,
ZooKeeperProtos.Table.State states,
boolean deletePermanentState)
If the table is found in the given state the in-memory state is removed.
|
void |
HBaseTestingUtility.compact(TableName tableName,
boolean major)
Compact all of a table's reagion in the mini hbase cluster
|
void |
MiniHBaseCluster.compact(TableName tableName,
boolean major)
Call flushCache on all regions of the specified table.
|
int |
TableName.compareTo(TableName tableName)
For performance reasons, the ordering is not lexicographic.
|
int |
HBaseTestingUtility.countRows(TableName tableName)
Return the number of rows in the given table.
|
int |
TestMetaMigrationConvertingToPB.createMultiRegionsWithWritableSerialization(Configuration c,
TableName tableName,
byte[][] startKeys)
Deprecated.
Inserts multiple regions into hbase:meta using Writable serialization instead of PB
|
HTable |
HBaseTestingUtility.createMultiRegionTable(TableName tableName,
byte[] family)
Create a table with multiple regions.
|
HTable |
HBaseTestingUtility.createMultiRegionTable(TableName tableName,
byte[][] families)
Create a table with multiple regions.
|
HTable |
HBaseTestingUtility.createMultiRegionTable(TableName tableName,
byte[][] families,
int numVersions)
Create a table with multiple regions.
|
HTable |
HBaseTestingUtility.createMultiRegionTable(TableName tableName,
byte[] family,
int numRegions)
Create a table with multiple regions.
|
static int |
HBaseTestingUtility.createPreSplitLoadTestTable(Configuration conf,
TableName tableName,
byte[][] columnFamilies,
Compression.Algorithm compression,
DataBlockEncoding dataBlockEncoding,
int numRegionsPerServer,
int regionReplication,
Durability durability)
Creates a pre-split table for load testing.
|
static int |
HBaseTestingUtility.createPreSplitLoadTestTable(Configuration conf,
TableName tableName,
byte[] columnFamily,
Compression.Algorithm compression,
DataBlockEncoding dataBlockEncoding)
Creates a pre-split table for load testing.
|
static int |
HBaseTestingUtility.createPreSplitLoadTestTable(Configuration conf,
TableName tableName,
byte[] columnFamily,
Compression.Algorithm compression,
DataBlockEncoding dataBlockEncoding,
int numRegionsPerServer,
int regionReplication,
Durability durability)
Creates a pre-split table for load testing.
|
static byte[] |
HRegionInfo.createRegionName(TableName tableName,
byte[] startKey,
byte[] id,
boolean newFormat)
Make a region name of passed parameters.
|
static byte[] |
HRegionInfo.createRegionName(TableName tableName,
byte[] startKey,
byte[] id,
int replicaId,
boolean newFormat)
Make a region name of passed parameters.
|
static byte[] |
HRegionInfo.createRegionName(TableName tableName,
byte[] startKey,
long regionid,
boolean newFormat)
Make a region name of passed parameters.
|
static byte[] |
HRegionInfo.createRegionName(TableName tableName,
byte[] startKey,
long regionid,
int replicaId,
boolean newFormat)
Make a region name of passed parameters.
|
static byte[] |
HRegionInfo.createRegionName(TableName tableName,
byte[] startKey,
String id,
boolean newFormat)
Make a region name of passed parameters.
|
HTable |
HBaseTestingUtility.createTable(TableName tableName,
byte[] family)
Create a table.
|
HTable |
HBaseTestingUtility.createTable(TableName tableName,
byte[][] families)
Create a table.
|
HTable |
HBaseTestingUtility.createTable(TableName tableName,
byte[][] families,
byte[][] splitKeys)
Create a table.
|
HTable |
HBaseTestingUtility.createTable(TableName tableName,
byte[][] families,
byte[][] splitKeys,
Configuration c)
Create a table.
|
HTable |
HBaseTestingUtility.createTable(TableName tableName,
byte[][] families,
Configuration c)
Create a table.
|
HTable |
HBaseTestingUtility.createTable(TableName tableName,
byte[][] families,
Configuration c,
int numVersions)
Create a table.
|
HTable |
HBaseTestingUtility.createTable(TableName tableName,
byte[][] families,
int numVersions,
byte[][] splitKeys)
Create a table.
|
HTable |
HBaseTestingUtility.createTable(TableName tableName,
byte[][] families,
int numVersions,
byte[] startKey,
byte[] endKey,
int numRegions) |
HTable |
HBaseTestingUtility.createTable(TableName tableName,
byte[] family,
byte[][] splitRows)
Create a table.
|
HTable |
HBaseTestingUtility.createTable(TableName tableName,
byte[] family,
int numVersions)
Create a table.
|
Table |
HBaseTestingUtility.createTable(TableName tableName,
String family)
Create a table.
|
Table |
HBaseTestingUtility.createTable(TableName tableName,
String[] families)
Create a table.
|
void |
HBaseTestingUtility.deleteTable(TableName tableName)
Drop an existing table
|
HTable |
HBaseTestingUtility.deleteTableData(TableName tableName)
Provide an existing table name to truncate.
|
void |
HBaseTestingUtility.deleteTableIfAny(TableName tableName)
Drop an existing table
|
String |
HBaseTestingUtility.explainTableAvailability(TableName tableName) |
String |
HBaseTestingUtility.explainTableState(TableName tableName) |
List<HRegion> |
MiniHBaseCluster.findRegionsForTable(TableName tableName) |
void |
HBaseTestingUtility.flush(TableName tableName)
Flushes all caches in the mini hbase cluster
|
void |
MiniHBaseCluster.flushcache(TableName tableName)
Call flushCache on all regions of the specified table.
|
HTableDescriptor |
TableDescriptors.get(TableName tableName) |
long |
ClusterStatus.getLastMajorCompactionTsForTable(TableName table) |
List<byte[]> |
HBaseTestingUtility.getMetaTableRows(TableName tableName)
Returns all rows from the hbase:meta table for a given user table
|
List<Region> |
MockRegionServerServices.getOnlineRegions(TableName tableName) |
static int |
MetaTableAccessor.getRegionCount(Configuration c,
TableName tableName)
Count regions in
hbase:meta for passed table. |
List<HRegion> |
MiniHBaseCluster.getRegions(TableName tableName) |
HRegionServer |
HBaseTestingUtility.getRSForFirstRegionInTable(TableName tableName)
Tool to get the reference to the region server object that holds the
region of the specified user table.
|
static Scan |
MetaTableAccessor.getScanForTableName(TableName tableName)
This method creates a Scan object that will only scan catalog rows that
belong to the specified table.
|
ServerName |
DistributedHBaseCluster.getServerHoldingRegion(TableName tn,
byte[] regionName) |
abstract ServerName |
HBaseCluster.getServerHoldingRegion(TableName tn,
byte[] regionName)
Get the ServerName of region server serving the specified region
|
ServerName |
MiniHBaseCluster.getServerHoldingRegion(TableName tn,
byte[] regionName) |
HRegion |
HBaseTestingUtility.getSplittableRegion(TableName tableName,
int maxAttempts) |
HTableInterface |
CoprocessorEnvironment.getTable(TableName tableName) |
HTableInterface |
CoprocessorEnvironment.getTable(TableName tableName,
ExecutorService service) |
static List<HRegionInfo> |
MetaTableAccessor.getTableRegions(ZooKeeperWatcher zkw,
Connection connection,
TableName tableName)
Gets all of the regions of the specified table.
|
static List<HRegionInfo> |
MetaTableAccessor.getTableRegions(ZooKeeperWatcher zkw,
Connection connection,
TableName tableName,
boolean excludeOfflinedSplitParents)
Gets all of the regions of the specified table.
|
static List<Pair<HRegionInfo,ServerName>> |
MetaTableAccessor.getTableRegionsAndLocations(ZooKeeperWatcher zkw,
Connection connection,
TableName tableName) |
static List<Pair<HRegionInfo,ServerName>> |
MetaTableAccessor.getTableRegionsAndLocations(ZooKeeperWatcher zkw,
Connection connection,
TableName tableName,
boolean excludeOfflinedSplitParents) |
boolean |
TableStateManager.isTablePresent(TableName tableName)
Checks if table is present.
|
boolean |
TableStateManager.isTableState(TableName tableName,
boolean checkSource,
ZooKeeperProtos.Table.State... states) |
boolean |
TableStateManager.isTableState(TableName tableName,
ZooKeeperProtos.Table.State... states) |
Waiter.Predicate<IOException> |
HBaseTestingUtility.predicateTableAvailable(TableName tableName)
Returns a
Waiter.Predicate for checking that table is enabled |
Waiter.Predicate<IOException> |
HBaseTestingUtility.predicateTableDisabled(TableName tableName)
Returns a
Waiter.Predicate for checking that table is enabled |
Waiter.Predicate<IOException> |
HBaseTestingUtility.predicateTableEnabled(TableName tableName)
Returns a
Waiter.Predicate for checking that table is enabled |
HTableDescriptor |
TableDescriptors.remove(TableName tablename) |
void |
TableStateManager.setDeletedTable(TableName tableName)
Mark table as deleted.
|
HTableDescriptor |
HTableDescriptor.setName(TableName name)
Deprecated.
|
static void |
HBaseTestingUtility.setReplicas(Admin admin,
TableName table,
int replicaCount)
Set the number of Region replicas.
|
void |
TableStateManager.setTableState(TableName tableName,
ZooKeeperProtos.Table.State state)
Sets the table into desired state.
|
boolean |
TableStateManager.setTableStateIfInStates(TableName tableName,
ZooKeeperProtos.Table.State newState,
ZooKeeperProtos.Table.State... states)
Sets the specified table into the newState, but only if the table is already in
one of the possibleCurrentStates (otherwise no operation is performed).
|
boolean |
TableStateManager.setTableStateIfNotInStates(TableName tableName,
ZooKeeperProtos.Table.State newState,
ZooKeeperProtos.Table.State... states)
Sets the specified table into the newState, but only if the table is NOT in
one of the possibleCurrentStates (otherwise no operation is performed).
|
static boolean |
MetaTableAccessor.tableExists(Connection connection,
TableName tableName)
Checks if the specified table exists.
|
HTable |
HBaseTestingUtility.truncateTable(TableName tableName)
Truncate a table using the admin command.
|
HTable |
HBaseTestingUtility.truncateTable(TableName tableName,
boolean preserveRegions)
Truncate a table using the admin command.
|
void |
HBaseTestingUtility.waitTableAvailable(TableName table)
Wait until all regions in a table have been assigned.
|
void |
HBaseTestingUtility.waitTableAvailable(TableName table,
long timeoutMillis) |
void |
HBaseTestingUtility.waitTableEnabled(TableName table)
Waits for a table to be 'enabled'.
|
void |
HBaseTestingUtility.waitTableEnabled(TableName table,
long timeoutMillis) |
void |
HBaseTestingUtility.waitUntilAllRegionsAssigned(TableName tableName)
Wait until all regions for a table in hbase:meta have a non-empty
info:server, up to 60 seconds.
|
void |
HBaseTestingUtility.waitUntilAllRegionsAssigned(TableName tableName,
long timeout)
Wait until all regions for a table in hbase:meta have a non-empty
info:server, or until timeout.
|
Constructor and Description |
---|
DelayingMultiThreadedUpdater(LoadTestDataGenerator dataGen,
Configuration conf,
TableName tableName,
double updatePercent) |
DelayingMultiThreadedWriter(LoadTestDataGenerator dataGen,
Configuration conf,
TableName tableName) |
HRegionInfo(long regionId,
TableName tableName,
int replicaId) |
HRegionInfo(TableName tableName) |
HRegionInfo(TableName tableName,
byte[] startKey,
byte[] endKey)
Construct HRegionInfo with explicit parameters
|
HRegionInfo(TableName tableName,
byte[] startKey,
byte[] endKey,
boolean split)
Construct HRegionInfo with explicit parameters
|
HRegionInfo(TableName tableName,
byte[] startKey,
byte[] endKey,
boolean split,
long regionid)
Construct HRegionInfo with explicit parameters
|
HRegionInfo(TableName tableName,
byte[] startKey,
byte[] endKey,
boolean split,
long regionid,
int replicaId)
Construct HRegionInfo with explicit parameters
|
HTableDescriptor(TableName name)
Construct a table descriptor specifying a TableName object
|
HTableDescriptor(TableName name,
HColumnDescriptor[] families)
INTERNAL Private constructor used internally creating table descriptors for
catalog tables,
hbase:meta and -ROOT- . |
HTableDescriptor(TableName name,
HColumnDescriptor[] families,
Map<ImmutableBytesWritable,ImmutableBytesWritable> values)
INTERNAL Private constructor used internally creating table descriptors for
catalog tables,
hbase:meta and -ROOT- . |
TableExistsException(TableName t) |
TableNotDisabledException(TableName tableName) |
TableNotEnabledException(TableName tableName) |
TableNotFoundException(TableName tableName) |
Modifier and Type | Field and Description |
---|---|
protected TableName |
MonkeyFactory.tableName |
Modifier and Type | Method and Description |
---|---|
MonkeyFactory |
MonkeyFactory.setTableName(TableName tableName) |
Modifier and Type | Method and Description |
---|---|
TableName |
ChaosMonkeyRunner.getTablename() |
Modifier and Type | Field and Description |
---|---|
protected static TableName |
TestSnapshotFromClient.TABLE_NAME |
protected TableName |
RegionAdminServiceCallable.tableName |
protected TableName |
RegionServerCallable.tableName |
protected TableName |
RpcRetryingCallerWithReadReplicas.tableName |
Modifier and Type | Method and Description |
---|---|
TableName |
BufferedMutator.getName()
Gets the fully qualified table name instance of the table that this BufferedMutator writes to.
|
TableName |
BufferedMutatorImpl.getName() |
TableName |
HRegionLocator.getName() |
TableName |
HTable.getName() |
TableName |
RegionLocator.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 |
HTableWrapper.getName() |
protected TableName |
ClientScanner.getTable() |
TableName |
BufferedMutatorParams.getTableName() |
TableName |
RegionServerCallable.getTableName() |
TableName[] |
Admin.listTableNames()
List all of the names of userspace tables.
|
TableName[] |
HBaseAdmin.listTableNames() |
TableName[] |
HConnection.listTableNames()
Deprecated.
Use
Admin.listTables() instead. |
TableName[] |
Admin.listTableNames(Pattern pattern)
List all of the names of userspace tables.
|
TableName[] |
HBaseAdmin.listTableNames(Pattern pattern) |
TableName[] |
Admin.listTableNames(Pattern pattern,
boolean includeSysTables)
List all of the names of userspace tables.
|
TableName[] |
HBaseAdmin.listTableNames(Pattern pattern,
boolean includeSysTables) |
TableName[] |
Admin.listTableNames(String regex)
List all of the names of userspace tables.
|
TableName[] |
HBaseAdmin.listTableNames(String regex) |
TableName[] |
Admin.listTableNames(String regex,
boolean includeSysTables)
List all of the names of userspace tables.
|
TableName[] |
HBaseAdmin.listTableNames(String regex,
boolean includeSysTables) |
TableName[] |
Admin.listTableNamesByNamespace(String name)
Get list of table names by namespace
|
TableName[] |
HBaseAdmin.listTableNamesByNamespace(String name)
Get list of table names by namespace
|
Modifier and Type | Method and Description |
---|---|
void |
Admin.addColumn(TableName tableName,
HColumnDescriptor column)
Add a column to an existing table.
|
void |
HBaseAdmin.addColumn(TableName tableName,
HColumnDescriptor column)
Add a column to an existing table.
|
static NavigableMap<HRegionInfo,ServerName> |
MetaScanner.allTableRegions(Configuration conf,
Connection connection,
TableName tableName,
boolean offlined)
Deprecated.
|
static NavigableMap<HRegionInfo,ServerName> |
MetaScanner.allTableRegions(Connection connection,
TableName tableName)
Lists all of the table regions currently in META.
|
void |
MetaCache.cacheLocation(TableName tableName,
RegionLocations locations)
Put a newly discovered HRegionLocation into the cache.
|
void |
MetaCache.cacheLocation(TableName tableName,
ServerName source,
HRegionLocation location)
Put a newly discovered HRegionLocation into the cache.
|
void |
MetaCache.clearCache(TableName tableName)
Delete all cached entries of a table.
|
void |
MetaCache.clearCache(TableName tableName,
byte[] row)
Delete a cached location, no matter what it is.
|
void |
MetaCache.clearCache(TableName tableName,
byte[] row,
int replicaId)
Delete a cached location, no matter what it is.
|
void |
MetaCache.clearCache(TableName tableName,
byte[] row,
ServerName serverName)
Delete a cached location for a table, row and server
|
void |
ClusterConnection.clearRegionCache(TableName tableName)
Allows flushing the region cache of all locations that pertain to
tableName |
void |
HConnection.clearRegionCache(TableName tableName)
Deprecated.
internal method, do not use thru HConnection
|
void |
Admin.cloneSnapshot(byte[] snapshotName,
TableName tableName)
Create a new table by cloning the snapshot content.
|
void |
HBaseAdmin.cloneSnapshot(byte[] snapshotName,
TableName tableName)
Create a new table by cloning the snapshot content.
|
void |
Admin.cloneSnapshot(String snapshotName,
TableName tableName)
Create a new table by cloning the snapshot content.
|
void |
HBaseAdmin.cloneSnapshot(String snapshotName,
TableName tableName)
Create a new table by cloning the snapshot content.
|
void |
Admin.compact(TableName tableName)
Compact a table.
|
void |
HBaseAdmin.compact(TableName tableName)
Compact a table.
|
void |
Admin.compact(TableName tableName,
byte[] columnFamily)
Compact a column family within a table.
|
void |
HBaseAdmin.compact(TableName tableName,
byte[] columnFamily)
Compact a column family within a table.
|
static void |
TestTableSnapshotScanner.createTableAndSnapshot(HBaseTestingUtility util,
TableName tableName,
String snapshotName,
int numRegions) |
static HTableInterface |
HTableWrapper.createWrapper(List<HTableInterface> openTables,
TableName tableName,
CoprocessorHost.Environment env,
ExecutorService pool) |
void |
Admin.deleteColumn(TableName tableName,
byte[] columnName)
Delete a column from a table.
|
void |
HBaseAdmin.deleteColumn(TableName tableName,
byte[] columnName)
Delete a column from a table.
|
void |
Admin.deleteTable(TableName tableName)
Deletes a table.
|
void |
HBaseAdmin.deleteTable(TableName tableName)
Deletes a table.
|
void |
Admin.disableTable(TableName tableName)
Disable table and wait on completion.
|
void |
HBaseAdmin.disableTable(TableName tableName)
Disable table and wait on completion.
|
void |
Admin.disableTableAsync(TableName tableName)
Starts the disable of a table.
|
void |
HBaseAdmin.disableTableAsync(TableName tableName)
Starts the disable of a table.
|
void |
Admin.enableTable(TableName tableName)
Enable a table.
|
void |
HBaseAdmin.enableTable(TableName tableName)
Enable a table.
|
void |
Admin.enableTableAsync(TableName tableName)
Brings a table on-line (enables it).
|
void |
HBaseAdmin.enableTableAsync(TableName tableName)
Brings a table on-line (enables it).
|
void |
Admin.flush(TableName tableName)
Flush a table.
|
void |
HBaseAdmin.flush(TableName tableName)
Flush a table.
|
Pair<Integer,Integer> |
Admin.getAlterStatus(TableName tableName)
Get the status of alter command - indicates how many regions have received the updated schema
Asynchronous operation.
|
Pair<Integer,Integer> |
HBaseAdmin.getAlterStatus(TableName tableName)
Get the status of alter command - indicates how many regions have received
the updated schema Asynchronous operation.
|
BufferedMutator |
Connection.getBufferedMutator(TableName tableName)
Retrieve a
BufferedMutator for performing client-side buffering of writes. |
RegionLocations |
MetaCache.getCachedLocation(TableName tableName,
byte[] row)
Search the cache for a location that fits our table and row key.
|
org.apache.hadoop.hbase.client.ScannerCallableWithReplicas |
ClientSmallScanner.SmallScannerCallableFactory.getCallable(ClusterConnection connection,
TableName table,
Scan scan,
ScanMetrics scanMetrics,
byte[] localStartKey,
int cacheNum,
RpcControllerFactory controllerFactory,
ExecutorService pool,
int primaryOperationTimeout,
int retries,
int scannerTimeout,
Configuration conf,
RpcRetryingCaller<Result[]> caller) |
AdminProtos.GetRegionInfoResponse.CompactionState |
Admin.getCompactionState(TableName tableName)
Get the current compaction state of a table.
|
AdminProtos.GetRegionInfoResponse.CompactionState |
HBaseAdmin.getCompactionState(TableName tableName)
Get the current compaction state of a table.
|
HTableDescriptor |
HConnection.getHTableDescriptor(TableName tableName)
Deprecated.
|
long |
Admin.getLastMajorCompactionTimestamp(TableName tableName)
Get the timestamp of the last major compaction for the passed table
The timestamp of the oldest HFile resulting from a major compaction of that table,
or 0 if no such HFile could be found.
|
long |
HBaseAdmin.getLastMajorCompactionTimestamp(TableName tableName) |
int |
MetaCache.getNumberOfCachedRegionLocations(TableName tableName)
Return the number of cached region for a table.
|
static boolean |
HTable.getRegionCachePrefetch(Configuration conf,
TableName tableName)
Deprecated.
always return false since 0.99
|
boolean |
HConnection.getRegionCachePrefetch(TableName tableName)
Deprecated.
always return false since 0.99
|
static boolean |
HTable.getRegionCachePrefetch(TableName tableName)
Deprecated.
always return false since 0.99
|
HRegionLocation |
ClusterConnection.getRegionLocation(TableName tableName,
byte[] row,
boolean reload)
Find region location hosting passed row
|
HRegionLocation |
HConnection.getRegionLocation(TableName tableName,
byte[] row,
boolean reload)
Deprecated.
internal method, do not use thru HConnection
|
static RegionLocations |
RegionAdminServiceCallable.getRegionLocations(ClusterConnection connection,
TableName tableName,
byte[] row,
boolean useCache,
int replicaId) |
RegionLocator |
Connection.getRegionLocator(TableName tableName)
Retrieve a RegionLocator implementation to inspect region information on a table.
|
RegionLocator |
HConnection.getRegionLocator(TableName tableName)
Deprecated.
Retrieve a RegionLocator implementation to inspect region information on a table.
|
Table |
Connection.getTable(TableName tableName)
Retrieve a Table implementation for accessing a table.
|
HTableInterface |
HConnection.getTable(TableName tableName)
Deprecated.
Retrieve an HTableInterface implementation for access to a table.
|
Table |
Connection.getTable(TableName tableName,
ExecutorService pool)
Retrieve a Table implementation for accessing a table.
|
HTableInterface |
HConnection.getTable(TableName tableName,
ExecutorService pool)
Deprecated.
Retrieve an HTableInterface implementation for access to a table.
|
HTableDescriptor |
Admin.getTableDescriptor(TableName tableName)
Method for getting the tableDescriptor
|
HTableDescriptor |
HBaseAdmin.getTableDescriptor(TableName tableName)
Method for getting the tableDescriptor
|
List<HRegionInfo> |
Admin.getTableRegions(TableName tableName)
Get the regions of a given table.
|
List<HRegionInfo> |
HBaseAdmin.getTableRegions(TableName tableName)
get the regions of a given table.
|
boolean |
MetaCache.isRegionCached(TableName tableName,
byte[] row)
Check the region cache to see whether a region is cached yet or not.
|
boolean |
Admin.isTableAvailable(TableName tableName) |
boolean |
HBaseAdmin.isTableAvailable(TableName tableName) |
boolean |
HConnection.isTableAvailable(TableName tableName)
Deprecated.
|
boolean |
Admin.isTableAvailable(TableName tableName,
byte[][] splitKeys)
Use this api to check if the table has been created with the specified number of splitkeys
which was used while creating the given table.
|
boolean |
ClusterConnection.isTableAvailable(TableName tableName,
byte[][] splitKeys)
Use this api to check if the table has been created with the specified number of
splitkeys which was used while creating the given table.
|
boolean |
HBaseAdmin.isTableAvailable(TableName tableName,
byte[][] splitKeys)
Use this api to check if the table has been created with the specified number of
splitkeys which was used while creating the given table.
|
boolean |
HConnection.isTableAvailable(TableName tableName,
byte[][] splitKeys)
Deprecated.
internal method, do not use thru HConnection
|
boolean |
Admin.isTableDisabled(TableName tableName) |
boolean |
HBaseAdmin.isTableDisabled(TableName tableName) |
boolean |
HConnection.isTableDisabled(TableName tableName)
Deprecated.
|
static boolean |
HTable.isTableEnabled(Configuration conf,
TableName tableName)
|
boolean |
Admin.isTableEnabled(TableName tableName) |
boolean |
HBaseAdmin.isTableEnabled(TableName tableName) |
boolean |
HConnection.isTableEnabled(TableName tableName)
Deprecated.
A table that isTableEnabled == false and isTableDisabled == false
is possible.
|
static boolean |
HTable.isTableEnabled(TableName tableName)
Deprecated.
|
static List<RegionLocations> |
MetaScanner.listTableRegionLocations(Configuration conf,
Connection connection,
TableName tableName)
Lists table regions and locations grouped by region range from META.
|
HRegionLocation |
ClusterConnection.locateRegion(TableName tableName,
byte[] row)
Find the location of the region of tableName that row
lives in.
|
HRegionLocation |
HConnection.locateRegion(TableName tableName,
byte[] row)
Deprecated.
internal method, do not use thru HConnection
|
RegionLocations |
ClusterConnection.locateRegion(TableName tableName,
byte[] row,
boolean useCache,
boolean retry) |
RegionLocations |
ClusterConnection.locateRegion(TableName tableName,
byte[] row,
boolean useCache,
boolean retry,
int replicaId) |
List<HRegionLocation> |
ClusterConnection.locateRegions(TableName tableName)
Gets the locations of all regions in the specified table, tableName.
|
List<HRegionLocation> |
HConnection.locateRegions(TableName tableName)
Deprecated.
internal method, do not use thru HConnection
|
List<HRegionLocation> |
ClusterConnection.locateRegions(TableName tableName,
boolean useCache,
boolean offlined)
Gets the locations of all regions in the specified table, tableName.
|
List<HRegionLocation> |
HConnection.locateRegions(TableName tableName,
boolean useCache,
boolean offlined)
Deprecated.
internal method, do not use thru HConnection
|
void |
Admin.majorCompact(TableName tableName)
Major compact a table.
|
void |
HBaseAdmin.majorCompact(TableName tableName)
Major compact a table.
|
void |
Admin.majorCompact(TableName tableName,
byte[] columnFamily)
Major compact a column family within a table.
|
void |
HBaseAdmin.majorCompact(TableName tableName,
byte[] columnFamily)
Major compact a column family within a table.
|
static void |
MetaScanner.metaScan(Connection connection,
MetaScanner.MetaScannerVisitor visitor,
TableName userTableName)
Scans the meta table and calls a visitor on each RowResult.
|
static void |
MetaScanner.metaScan(Connection connection,
MetaScanner.MetaScannerVisitor visitor,
TableName userTableName,
byte[] row,
int rowLimit)
Scans the meta table and calls a visitor on each RowResult.
|
void |
Admin.modifyColumn(TableName tableName,
HColumnDescriptor descriptor)
Modify an existing column family on a table.
|
void |
HBaseAdmin.modifyColumn(TableName tableName,
HColumnDescriptor descriptor)
Modify an existing column family on a table.
|
void |
Admin.modifyTable(TableName tableName,
HTableDescriptor htd)
Modify an existing table, more IRB friendly version.
|
void |
HBaseAdmin.modifyTable(TableName tableName,
HTableDescriptor htd)
Modify an existing table, more IRB friendly version.
|
void |
HConnection.processBatch(List<? extends Row> actions,
TableName tableName,
ExecutorService pool,
Object[] results)
Deprecated.
since 0.96 - Use
Table.batch(java.util.List<? extends org.apache.hadoop.hbase.client.Row>, java.lang.Object[]) instead |
<R> void |
HConnection.processBatchCallback(List<? extends Row> list,
TableName tableName,
ExecutorService pool,
Object[] results,
Batch.Callback<R> callback)
|
List<Put> |
HTableMultiplexer.put(TableName tableName,
List<Put> puts)
The puts request will be buffered by their corresponding buffer queue.
|
boolean |
HTableMultiplexer.put(TableName tableName,
Put put)
The put request will be buffered by its corresponding buffer queue.
|
boolean |
HTableMultiplexer.put(TableName tableName,
Put put,
int retry)
The put request will be buffered by its corresponding buffer queue.
|
HRegionLocation |
ClusterConnection.relocateRegion(TableName tableName,
byte[] row)
Find the location of the region of tableName that row
lives in, ignoring any value that might be in the cache.
|
HRegionLocation |
HConnection.relocateRegion(TableName tableName,
byte[] row)
Deprecated.
internal method, do not use thru HConnection
|
RegionLocations |
ClusterConnection.relocateRegion(TableName tableName,
byte[] row,
int replicaId)
Find the location of the region of tableName that row
lives in, ignoring any value that might be in the cache.
|
void |
TestRpcControllerFactory.CountingRpcController.setPriority(TableName tn) |
static void |
HTable.setRegionCachePrefetch(Configuration conf,
TableName tableName,
boolean enable)
Deprecated.
does nothing since 0.99
|
void |
HConnection.setRegionCachePrefetch(TableName tableName,
boolean enable)
Deprecated.
does nothing since since 0.99
|
static void |
HTable.setRegionCachePrefetch(TableName tableName,
boolean enable)
Deprecated.
does nothing since 0.99
|
void |
Admin.snapshot(byte[] snapshotName,
TableName tableName)
public void snapshot(final String snapshotName, Create a timestamp consistent snapshot for the
given table.
|
void |
HBaseAdmin.snapshot(byte[] snapshotName,
TableName tableName)
public void snapshot(final String snapshotName,
Create a timestamp consistent snapshot for the given table.
|
void |
Admin.snapshot(String snapshotName,
TableName tableName)
Take a snapshot for the given table.
|
void |
HBaseAdmin.snapshot(String snapshotName,
TableName tableName)
Take a snapshot for the given table.
|
void |
Admin.snapshot(String snapshotName,
TableName tableName,
HBaseProtos.SnapshotDescription.Type type)
Create typed snapshot of the table.
|
void |
HBaseAdmin.snapshot(String snapshotName,
TableName tableName,
HBaseProtos.SnapshotDescription.Type type)
Create typed snapshot of the table.
|
void |
Admin.split(TableName tableName)
Split a table.
|
void |
HBaseAdmin.split(TableName tableName)
Split a table.
|
void |
Admin.split(TableName tableName,
byte[] splitPoint)
Split a table.
|
void |
HBaseAdmin.split(TableName tableName,
byte[] splitPoint)
Split a table.
|
boolean |
Admin.tableExists(TableName tableName) |
boolean |
HBaseAdmin.tableExists(TableName tableName) |
void |
Admin.truncateTable(TableName tableName,
boolean preserveSplits)
Truncate a table.
|
void |
HBaseAdmin.truncateTable(TableName tableName,
boolean preserveSplits)
Truncate a table.
|
void |
ClusterConnection.updateCachedLocations(TableName tableName,
byte[] regionName,
byte[] rowkey,
Object exception,
ServerName source)
Update the location cache.
|
void |
HConnection.updateCachedLocations(TableName tableName,
byte[] regionName,
byte[] rowkey,
Object exception,
ServerName source)
Deprecated.
internal method, do not use thru HConnection
|
void |
HConnection.updateCachedLocations(TableName tableName,
byte[] rowkey,
Object exception,
HRegionLocation source)
Deprecated.
|
protected void |
TestCloneSnapshotFromClient.verifyReplicasCameOnline(TableName tableName) |
Modifier and Type | Method and Description |
---|---|
HTableDescriptor[] |
HConnection.getHTableDescriptorsByTableName(List<TableName> tableNames)
Deprecated.
Use
Admin.getTableDescriptor(TableName) instead. |
HTableDescriptor[] |
Admin.getTableDescriptorsByTableName(List<TableName> tableNames)
Get tableDescriptors
|
HTableDescriptor[] |
HBaseAdmin.getTableDescriptorsByTableName(List<TableName> tableNames)
Get tableDescriptors
|
Constructor and Description |
---|
BufferedMutatorParams(TableName tableName) |
ClientScanner(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. |
ClientSmallReversedScanner(Configuration conf,
Scan scan,
TableName tableName,
ClusterConnection connection,
RpcRetryingCallerFactory rpcFactory,
RpcControllerFactory controllerFactory,
ExecutorService pool,
int primaryOperationTimeout)
Create a new ReversibleClientScanner for the specified table.
|
ClientSmallScanner(Configuration conf,
Scan scan,
TableName tableName,
ClusterConnection connection,
RpcRetryingCallerFactory rpcFactory,
RpcControllerFactory controllerFactory,
ExecutorService pool,
int primaryOperationTimeout)
Create a new ShortClientScanner for the specified table.
|
FlushRegionCallable(ClusterConnection connection,
RpcControllerFactory rpcControllerFactory,
TableName tableName,
byte[] regionName,
byte[] regionStartKey,
boolean writeFlushWalMarker) |
HRegionLocator(TableName tableName,
ClusterConnection connection) |
HTable(Configuration conf,
TableName tableName)
Deprecated.
Constructing HTable objects manually has been deprecated. Please use
Connection to instantiate a Table instead. |
HTable(Configuration conf,
TableName tableName,
ExecutorService pool)
Deprecated.
Constructing HTable objects manually has been deprecated. Please use
Connection to instantiate a Table instead. |
HTable(TableName tableName,
ClusterConnection connection,
TableConfiguration tableConfig,
RpcRetryingCallerFactory rpcCallerFactory,
RpcControllerFactory rpcControllerFactory,
ExecutorService pool)
Creates an object to access a HBase table.
|
HTable(TableName tableName,
Connection connection)
Deprecated.
Do not use.
|
HTable(TableName tableName,
Connection connection,
ExecutorService pool)
Deprecated.
Do not use, internal ctor.
|
RegionAdminServiceCallable(ClusterConnection connection,
RpcControllerFactory rpcControllerFactory,
HRegionLocation location,
TableName tableName,
byte[] row) |
RegionAdminServiceCallable(ClusterConnection connection,
RpcControllerFactory rpcControllerFactory,
HRegionLocation location,
TableName tableName,
byte[] row,
int replicaId) |
RegionAdminServiceCallable(ClusterConnection connection,
RpcControllerFactory rpcControllerFactory,
TableName tableName,
byte[] row) |
RegionServerCallable(Connection connection,
TableName tableName,
byte[] row) |
ReversedClientScanner(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,
byte[] locateStartRow)
|
ReversedScannerCallable(ClusterConnection connection,
TableName tableName,
Scan scan,
ScanMetrics scanMetrics,
byte[] locateStartRow,
RpcControllerFactory rpcFactory) |
ReversedScannerCallable(ClusterConnection connection,
TableName tableName,
Scan scan,
ScanMetrics scanMetrics,
byte[] locateStartRow,
RpcControllerFactory rpcFactory,
int replicaId) |
RpcRetryingCallerWithReadReplicas(RpcControllerFactory rpcControllerFactory,
TableName tableName,
ClusterConnection cConnection,
Get get,
ExecutorService pool,
int retries,
int callTimeout,
int timeBeforeReplicas) |
ScannerCallable(ClusterConnection connection,
TableName tableName,
Scan scan,
ScanMetrics scanMetrics,
RpcControllerFactory rpcControllerFactory) |
ScannerCallable(ClusterConnection connection,
TableName tableName,
Scan scan,
ScanMetrics scanMetrics,
RpcControllerFactory rpcControllerFactory,
int id) |
TableMetaScannerVisitor(TableName tableName) |
Modifier and Type | Method and Description |
---|---|
<R,S,P extends Message,Q extends Message,T extends Message> |
AggregationClient.avg(TableName tableName,
ColumnInterpreter<R,S,P,Q,T> ci,
Scan scan)
This is the client side interface/handle for calling the average method for
a given cf-cq combination.
|
<R,S,P extends Message,Q extends Message,T extends 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 Message,Q extends Message,T extends 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 Message,Q extends Message,T extends Message> |
AggregationClient.min(TableName tableName,
ColumnInterpreter<R,S,P,Q,T> ci,
Scan scan)
It gives the minimum value of a column for a given column family for the
given range.
|
String |
SecureBulkLoadClient.prepareBulkLoad(TableName tableName) |
<R,S,P extends Message,Q extends Message,T extends 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 Message,Q extends Message,T extends 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 Message,Q extends Message,T extends Message> |
AggregationClient.sum(TableName tableName,
ColumnInterpreter<R,S,P,Q,T> ci,
Scan scan)
It sums up the value returned from various regions.
|
Modifier and Type | Method and Description |
---|---|
static Map<TableName,List<String>> |
ReplicationAdmin.parseTableCFsFromConfig(String tableCFsConfig) |
Modifier and Type | Method and Description |
---|---|
void |
ReplicationAdmin.disableTableRep(TableName tableName)
Disable a table's replication switch.
|
void |
ReplicationAdmin.enableTableRep(TableName tableName)
Enable a table's replication switch.
|
Modifier and Type | Method and Description |
---|---|
void |
ReplicationAdmin.addPeer(String id,
ReplicationPeerConfig peerConfig,
Map<TableName,? extends Collection<String>> tableCfs)
Add a new remote slave cluster for replication.
|
void |
ReplicationAdmin.appendPeerTableCFs(String id,
Map<TableName,? extends Collection<String>> tableCfs)
Append the replicable table-cf config of the specified peer
|
void |
ReplicationAdmin.removePeerTableCFs(String id,
Map<TableName,? extends Collection<String>> tableCfs)
Remove some table-cfs from config of the specified peer
|
void |
ReplicationAdmin.setPeerTableCFs(String id,
Map<TableName,? extends Collection<String>> tableCfs)
Set the replicable table-cf config of the specified peer
|
Modifier and Type | Field and Description |
---|---|
static TableName |
TestRegionObserverInterface.TEST_TABLE |
Modifier and Type | Method and Description |
---|---|
static TableName |
HFileLink.getReferencedTableName(String fileName)
Get the Table name of the referenced link
|
Modifier and Type | Method and Description |
---|---|
static HFileLink |
HFileLink.build(Configuration conf,
TableName table,
String region,
String family,
String hfile)
Create an HFileLink instance from table/region/family/hfile location
|
static boolean |
HFileLink.create(Configuration conf,
FileSystem fs,
Path dstFamilyPath,
TableName linkedTable,
String linkedRegion,
String hfileName)
Create a new HFileLink
|
static boolean |
HFileLink.create(Configuration conf,
FileSystem 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 Path |
HFileLink.createPath(TableName table,
String region,
String family,
String hfile)
Create an HFileLink relative path for the table/region/family/hfile location
|
Modifier and Type | Method and Description |
---|---|
void |
DelegatingPayloadCarryingRpcController.setPriority(TableName tn) |
void |
PayloadCarryingRpcController.setPriority(TableName tn) |
Constructor and Description |
---|
RegionCoprocessorRpcChannel(HConnection conn,
TableName table,
byte[] row) |
Modifier and Type | Method and Description |
---|---|
TableName |
TableSplit.getTable() |
Modifier and Type | Method and Description |
---|---|
static Table |
TestTableMapReduceUtil.createAndFillTable(TableName tableName) |
static void |
TestTableSnapshotInputFormat.doTestWithMapReduce(HBaseTestingUtility util,
TableName tableName,
String snapshotName,
byte[] startRow,
byte[] endRow,
Path tableDir,
int numRegions,
int expectedNumSplits,
boolean shutdownCluster) |
protected void |
TableInputFormatBase.initializeTable(Connection connection,
TableName tableName)
Allows subclasses to initialize the table information.
|
void |
TestTableSnapshotInputFormat.testRestoreSnapshotDoesNotCreateBackRefLinksInit(TableName tableName,
String snapshotName,
Path tmpTableDir) |
protected void |
TestTableSnapshotInputFormat.testWithMapReduceImpl(HBaseTestingUtility util,
TableName tableName,
String snapshotName,
Path tableDir,
int numRegions,
int expectedNumSplits,
boolean shutdownCluster) |
Constructor and Description |
---|
TableSplit(TableName tableName,
byte[] startRow,
byte[] endRow,
String location)
Constructor
|
Modifier and Type | Field and Description |
---|---|
protected static TableName |
TestTableMapReduceBase.MULTI_REGION_TABLE_NAME |
Modifier and Type | Method and Description |
---|---|
TableName |
TableSplit.getTable()
Returns the table name.
|
TableName |
IntegrationTestBulkLoad.getTablename() |
TableName |
IntegrationTestTableSnapshotInputFormat.getTablename() |
static TableName |
IntegrationTestBulkLoad.getTableName(Configuration conf) |
Modifier and Type | Method and Description |
---|---|
static void |
TableInputFormat.configureSplitTable(Job job,
TableName tableName)
Sets split table in map-reduce job.
|
protected static void |
TableSnapshotInputFormatTestBase.createTableAndSnapshot(HBaseTestingUtility util,
TableName tableName,
String snapshotName,
byte[] startRow,
byte[] endRow,
int numRegions) |
protected void |
IntegrationTestImportTsv.doLoadIncrementalHFiles(Path hfiles,
TableName tableName)
Verify the data described by
simple_tsv matches
simple_expected . |
static void |
TestTableSnapshotInputFormat.doTestWithMapReduce(HBaseTestingUtility util,
TableName tableName,
String snapshotName,
byte[] startRow,
byte[] endRow,
Path tableDir,
int numRegions,
int expectedNumSplits,
boolean shutdownCluster) |
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,
Job job)
Use this before submitting a TableMap job.
|
abstract void |
TableSnapshotInputFormatTestBase.testRestoreSnapshotDoesNotCreateBackRefLinksInit(TableName tableName,
String snapshotName,
Path tmpTableDir) |
void |
TestTableSnapshotInputFormat.testRestoreSnapshotDoesNotCreateBackRefLinksInit(TableName tableName,
String snapshotName,
Path tmpTableDir) |
protected abstract void |
TableSnapshotInputFormatTestBase.testWithMapReduceImpl(HBaseTestingUtility util,
TableName tableName,
String snapshotName,
Path tableDir,
int numRegions,
int expectedNumSplits,
boolean shutdownCluster) |
protected void |
TestTableSnapshotInputFormat.testWithMapReduceImpl(HBaseTestingUtility util,
TableName tableName,
String snapshotName,
Path tableDir,
int numRegions,
int expectedNumSplits,
boolean shutdownCluster) |
protected List<org.apache.hadoop.hbase.mapreduce.LoadIncrementalHFiles.LoadQueueItem> |
LoadIncrementalHFiles.tryAtomicRegionLoad(Connection conn,
TableName tableName,
byte[] first,
Collection<org.apache.hadoop.hbase.mapreduce.LoadIncrementalHFiles.LoadQueueItem> lqis)
Attempts to do an atomic load of many hfiles into a region.
|
protected void |
TestTableMapReduceBase.verify(TableName tableName) |
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.
|
Modifier and Type | Field and Description |
---|---|
protected TableName |
TestWarmupRegion.TABLENAME |
Modifier and Type | Method and Description |
---|---|
protected Map<TableName,Map<ServerName,List<HRegionInfo>>> |
RegionStates.getAssignmentsByTable()
This is an EXPENSIVE clone.
|
Map<TableName,Integer> |
RegionPlacementMaintainer.getRegionsMovement(FavoredNodesPlan newPlan)
Return how many regions will move per table since their primary RS will
change
|
Set<TableName> |
SnapshotOfRegionAssignmentFromMeta.getTableSet()
Get the table set
|
Map<TableName,List<HRegionInfo>> |
SnapshotOfRegionAssignmentFromMeta.getTableToRegionMap()
Get regions for tables
|
List<TableName> |
HMaster.listTableNames(String namespace,
String regex,
boolean includeSysTables)
Returns the list of table names that match the specified request
|
List<TableName> |
HMaster.listTableNamesByNamespace(String name) |
List<TableName> |
MasterServices.listTableNamesByNamespace(String name)
Get list of table names by namespace
|
Modifier and Type | Method and Description |
---|---|
void |
HMaster.addColumn(TableName tableName,
HColumnDescriptor columnDescriptor) |
HTableDescriptor |
MasterFileSystem.addColumn(TableName tableName,
HColumnDescriptor hcd)
Add column to a table
|
void |
MasterServices.addColumn(TableName tableName,
HColumnDescriptor column)
Add a new column to an existing table
|
void |
HMaster.checkTableModifiable(TableName tableName) |
void |
MasterServices.checkTableModifiable(TableName tableName)
Check table is modifiable; i.e.
|
void |
HMaster.deleteColumn(TableName tableName,
byte[] columnName) |
HTableDescriptor |
MasterFileSystem.deleteColumn(TableName tableName,
byte[] familyName)
Delete column of a table
|
void |
MasterServices.deleteColumn(TableName tableName,
byte[] columnName)
Delete a column from an existing table
|
long |
HMaster.deleteTable(TableName tableName) |
void |
MasterFileSystem.deleteTable(TableName tableName) |
long |
MasterServices.deleteTable(TableName tableName)
Delete a table
|
long |
HMaster.disableTable(TableName tableName) |
long |
MasterServices.disableTable(TableName tableName)
Disable an existing table
|
long |
HMaster.enableTable(TableName tableName) |
long |
MasterServices.enableTable(TableName tableName)
Enable an existing table
|
void |
AssignmentVerificationReport.fillUp(TableName tableName,
SnapshotOfRegionAssignmentFromMeta snapshot,
Map<String,Map<String,Float>> regionLocalityMap) |
void |
AssignmentVerificationReport.fillUpDispersion(TableName tableName,
SnapshotOfRegionAssignmentFromMeta snapshot,
FavoredNodesPlan newPlan)
Use this to project the dispersion scores
|
long |
HMaster.getLastMajorCompactionTimestamp(TableName table) |
long |
MasterServices.getLastMajorCompactionTimestamp(TableName table) |
Map<RegionState.State,List<HRegionInfo>> |
RegionStates.getRegionByStateOfTable(TableName tableName)
Gets current state of all regions of the table.
|
List<HRegionInfo> |
RegionStates.getRegionsOfTable(TableName tableName)
Gets the online regions of the specified table.
|
Pair<Integer,Integer> |
AssignmentManager.getReopenStatus(TableName tableName)
Used by the client to identify if all regions have the schema updates
|
void |
HMaster.modifyColumn(TableName tableName,
HColumnDescriptor descriptor) |
HTableDescriptor |
MasterFileSystem.modifyColumn(TableName tableName,
HColumnDescriptor hcd)
Modify Column of a table
|
void |
MasterServices.modifyColumn(TableName tableName,
HColumnDescriptor descriptor)
Modify the column descriptor of an existing column in an existing table
|
void |
HMaster.modifyTable(TableName tableName,
HTableDescriptor descriptor) |
void |
MasterServices.modifyTable(TableName tableName,
HTableDescriptor descriptor)
Modify the descriptor of an existing table
|
Path |
MasterFileSystem.moveTableToTemp(TableName tableName)
Move the specified table to the hbase temp directory
|
void |
MasterCoprocessorHost.postAddColumn(TableName tableName,
HColumnDescriptor column) |
void |
TestTableLockManager.TestAlterAndDisableMasterObserver.postAddColumnHandler(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName,
HColumnDescriptor column) |
void |
MasterCoprocessorHost.postAddColumnHandler(TableName tableName,
HColumnDescriptor column) |
void |
MasterCoprocessorHost.postDeleteColumn(TableName tableName,
byte[] c) |
void |
TestTableLockManager.TestLockTimeoutExceptionMasterObserver.postDeleteColumnHandler(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName,
byte[] c) |
void |
MasterCoprocessorHost.postDeleteColumnHandler(TableName tableName,
byte[] c) |
void |
MasterCoprocessorHost.postDeleteTable(TableName tableName) |
void |
MasterCoprocessorHost.postDeleteTableHandler(TableName tableName) |
void |
MasterCoprocessorHost.postDisableTable(TableName tableName) |
void |
TestTableLockManager.TestAlterAndDisableMasterObserver.postDisableTableHandler(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName) |
void |
MasterCoprocessorHost.postDisableTableHandler(TableName tableName) |
void |
MasterCoprocessorHost.postEnableTable(TableName tableName) |
void |
MasterCoprocessorHost.postEnableTableHandler(TableName tableName) |
void |
MasterCoprocessorHost.postModifyColumn(TableName tableName,
HColumnDescriptor descriptor) |
void |
MasterCoprocessorHost.postModifyColumnHandler(TableName tableName,
HColumnDescriptor descriptor) |
void |
MasterCoprocessorHost.postModifyTable(TableName tableName,
HTableDescriptor htd) |
void |
MasterCoprocessorHost.postModifyTableHandler(TableName tableName,
HTableDescriptor htd) |
void |
MasterCoprocessorHost.postSetTableQuota(TableName table,
QuotaProtos.Quotas quotas) |
void |
MasterCoprocessorHost.postSetUserQuota(String user,
TableName table,
QuotaProtos.Quotas quotas) |
void |
MasterCoprocessorHost.postTableFlush(TableName tableName) |
void |
MasterCoprocessorHost.postTruncateTable(TableName tableName) |
void |
MasterCoprocessorHost.postTruncateTableHandler(TableName tableName) |
boolean |
MasterCoprocessorHost.preAddColumn(TableName tableName,
HColumnDescriptor column) |
void |
TestTableLockManager.TestLockTimeoutExceptionMasterObserver.preAddColumnHandler(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName,
HColumnDescriptor column) |
void |
TestTableLockManager.TestAlterAndDisableMasterObserver.preAddColumnHandler(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName,
HColumnDescriptor column) |
boolean |
MasterCoprocessorHost.preAddColumnHandler(TableName tableName,
HColumnDescriptor column) |
boolean |
MasterCoprocessorHost.preDeleteColumn(TableName tableName,
byte[] c) |
void |
TestTableLockManager.TestLockTimeoutExceptionMasterObserver.preDeleteColumnHandler(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName,
byte[] c) |
boolean |
MasterCoprocessorHost.preDeleteColumnHandler(TableName tableName,
byte[] c) |
void |
MasterCoprocessorHost.preDeleteTable(TableName tableName) |
void |
MasterCoprocessorHost.preDeleteTableHandler(TableName tableName) |
void |
TestTableLockManager.TestAlterAndDisableMasterObserver.preDisableTable(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName) |
void |
MasterCoprocessorHost.preDisableTable(TableName tableName) |
void |
MasterCoprocessorHost.preDisableTableHandler(TableName tableName) |
void |
MasterCoprocessorHost.preEnableTable(TableName tableName) |
void |
MasterCoprocessorHost.preEnableTableHandler(TableName tableName) |
boolean |
MasterCoprocessorHost.preModifyColumn(TableName tableName,
HColumnDescriptor descriptor) |
boolean |
MasterCoprocessorHost.preModifyColumnHandler(TableName tableName,
HColumnDescriptor descriptor) |
void |
MasterCoprocessorHost.preModifyTable(TableName tableName,
HTableDescriptor htd) |
void |
MasterCoprocessorHost.preModifyTableHandler(TableName tableName,
HTableDescriptor htd) |
void |
MasterCoprocessorHost.preSetTableQuota(TableName table,
QuotaProtos.Quotas quotas) |
void |
MasterCoprocessorHost.preSetUserQuota(String user,
TableName table,
QuotaProtos.Quotas quotas) |
void |
MasterCoprocessorHost.preTableFlush(TableName tableName) |
void |
MasterCoprocessorHost.preTruncateTable(TableName tableName) |
void |
MasterCoprocessorHost.preTruncateTableHandler(TableName tableName) |
void |
RegionPlacementMaintainer.printDispersionScores(TableName table,
SnapshotOfRegionAssignmentFromMeta snapshot,
int numRegions,
FavoredNodesPlan newPlan,
boolean simplePrint) |
abstract TableLockManager.TableLock |
TableLockManager.readLock(TableName tableName,
String purpose)
Returns a TableLock for locking the table for shared access among read-lock holders
|
TableLockManager.TableLock |
TableLockManager.NullTableLockManager.readLock(TableName tableName,
String purpose) |
protected void |
AssignmentManager.setEnabledTable(TableName tableName) |
void |
RegionStates.tableDeleted(TableName tableName)
A table is deleted.
|
abstract void |
TableLockManager.tableDeleted(TableName tableName)
Called after a table has been deleted, and after the table lock is released.
|
void |
TableLockManager.NullTableLockManager.tableDeleted(TableName tableName) |
void |
HMaster.truncateTable(TableName tableName,
boolean preserveSplits) |
void |
MasterServices.truncateTable(TableName tableName,
boolean preserveSplits)
Truncate a table
|
abstract TableLockManager.TableLock |
TableLockManager.writeLock(TableName tableName,
String purpose)
Returns a TableLock for locking the table for exclusive access
|
TableLockManager.TableLock |
TableLockManager.NullTableLockManager.writeLock(TableName tableName,
String purpose) |
Modifier and Type | Method and Description |
---|---|
void |
RegionPlacementMaintainer.checkDifferencesWithOldPlan(Map<TableName,Integer> movesPerTable,
Map<String,Map<String,Float>> regionLocalityMap,
FavoredNodesPlan newPlan)
Compares two plans and check whether the locality dropped or increased
(prints the information as a string) also prints the baseline locality
|
List<HTableDescriptor> |
HMaster.listTableDescriptors(String namespace,
String regex,
List<TableName> tableNameList,
boolean includeSysTables)
Returns the list of table descriptors that match the specified request
|
void |
MasterCoprocessorHost.postGetTableDescriptors(List<TableName> tableNamesList,
List<HTableDescriptor> descriptors,
String regex) |
boolean |
MasterCoprocessorHost.preGetTableDescriptors(List<TableName> tableNamesList,
List<HTableDescriptor> descriptors)
Deprecated.
|
boolean |
MasterCoprocessorHost.preGetTableDescriptors(List<TableName> tableNamesList,
List<HTableDescriptor> descriptors,
String regex) |
Constructor and Description |
---|
SnapshotOfRegionAssignmentFromMeta(Connection connection,
Set<TableName> disabledTables,
boolean excludeOfflinedSplitParents) |
Modifier and Type | Field and Description |
---|---|
protected TableName |
TableEventHandler.tableName |
Modifier and Type | Method and Description |
---|---|
static void |
TestEnableTableHandler.deleteTable(HBaseTestingUtility testUtil,
HBaseAdmin admin,
TableName tableName) |
static void |
TestEnableTableHandler.deleteTable(HBaseTestingUtility testUtil,
TableName tableName) |
protected List<HRegionInfo> |
CreateTableHandler.handleCreateHdfsRegions(Path tableRootDir,
TableName tableName)
Create the on-disk structure for the table, and returns the regions info.
|
void |
TestEnableTableHandler.MasterSyncObserver.postDeleteTableHandler(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName) |
Constructor and Description |
---|
DeleteTableHandler(TableName tableName,
Server server,
MasterServices masterServices) |
DisableTableHandler(Server server,
TableName tableName,
AssignmentManager assignmentManager,
TableLockManager tableLockManager,
boolean skipTableStateCheck) |
EnableTableHandler(MasterServices services,
TableName tableName,
AssignmentManager assignmentManager,
TableLockManager tableLockManager,
boolean skipTableStateCheck) |
EnableTableHandler(Server server,
TableName tableName,
AssignmentManager assignmentManager,
TableLockManager tableLockManager,
boolean skipTableStateCheck) |
ModifyTableHandler(TableName tableName,
HTableDescriptor htd,
Server server,
MasterServices masterServices) |
TableAddFamilyHandler(TableName tableName,
HColumnDescriptor familyDesc,
Server server,
MasterServices masterServices) |
TableDeleteFamilyHandler(TableName tableName,
byte[] familyName,
Server server,
MasterServices masterServices) |
TableEventHandler(EventType eventType,
TableName tableName,
Server server,
MasterServices masterServices) |
TableModifyFamilyHandler(TableName tableName,
HColumnDescriptor familyDesc,
Server server,
MasterServices masterServices) |
TruncateTableHandler(TableName tableName,
Server server,
MasterServices masterServices,
boolean preserveSplits) |
Modifier and Type | Method and Description |
---|---|
NormalizationPlan |
RegionNormalizer.computePlanForTable(TableName table)
Computes next optimal normalization plan.
|
NormalizationPlan |
SimpleRegionNormalizer.computePlanForTable(TableName table)
Computes next most "urgent" normalization action on the table.
|
Modifier and Type | Method and Description |
---|---|
TableName |
AddColumnFamilyProcedure.getTableName() |
TableName |
CreateTableProcedure.getTableName() |
TableName |
DeleteColumnFamilyProcedure.getTableName() |
TableName |
DeleteTableProcedure.getTableName() |
TableName |
DisableTableProcedure.getTableName() |
TableName |
EnableTableProcedure.getTableName() |
TableName |
ModifyColumnFamilyProcedure.getTableName() |
TableName |
ModifyTableProcedure.getTableName() |
TableName |
TableProcedureInterface.getTableName() |
TableName |
TruncateTableProcedure.getTableName() |
TableName |
TestMasterProcedureQueue.TestTableProcedure.getTableName() |
Modifier and Type | Method and Description |
---|---|
protected static void |
CreateTableProcedure.assignRegions(MasterProcedureEnv env,
TableName tableName,
List<HRegionInfo> regions) |
static void |
MasterDDLOperationHelper.checkTableModifiable(MasterProcedureEnv env,
TableName tableName)
Check whether a table is modifiable - exists and either offline or online with config set
|
List<HRegionInfo> |
CreateTableProcedure.CreateHdfsRegions.createHdfsRegions(MasterProcedureEnv env,
Path tableRootDir,
TableName tableName,
List<HRegionInfo> newRegions) |
static HTableDescriptor |
MasterProcedureTestingUtility.createHTD(TableName tableName,
String... family) |
static HRegionInfo[] |
MasterProcedureTestingUtility.createTable(ProcedureExecutor<MasterProcedureEnv> procExec,
TableName tableName,
byte[][] splitKeys,
String... family) |
protected static void |
DeleteTableProcedure.deleteAssignmentState(MasterProcedureEnv env,
TableName tableName) |
static void |
MasterDDLOperationHelper.deleteColumnFamilyFromFileSystem(MasterProcedureEnv env,
TableName tableName,
List<HRegionInfo> regionInfoList,
byte[] familyName)
Remove the column family from the file system
|
protected static void |
DeleteTableProcedure.deleteFromFs(MasterProcedureEnv env,
TableName tableName,
List<HRegionInfo> regions,
boolean archive) |
protected static void |
DeleteTableProcedure.deleteFromMeta(MasterProcedureEnv env,
TableName tableName,
List<HRegionInfo> regions) |
protected static void |
DeleteTableProcedure.deleteTableDescriptorCache(MasterProcedureEnv env,
TableName tableName) |
protected static void |
DeleteTableProcedure.deleteTableStates(MasterProcedureEnv env,
TableName tableName) |
protected static List<HRegionInfo> |
ProcedureSyncWait.getRegionsFromMeta(MasterProcedureEnv env,
TableName tableName) |
static void |
MasterProcedureTestingUtility.loadData(Connection connection,
TableName tableName,
int rows,
byte[][] splitKeys,
String... sfamilies) |
protected static org.apache.hadoop.hbase.master.procedure.DisableTableProcedure.MarkRegionOfflineOpResult |
DisableTableProcedure.markRegionsOffline(MasterProcedureEnv env,
TableName tableName,
Boolean retryRequired)
Mark regions of the table offline with retries
|
protected static void |
EnableTableProcedure.markRegionsOnline(MasterProcedureEnv env,
TableName tableName,
Boolean retryRequired)
Mark offline regions of the table online with retry
|
protected boolean |
MasterProcedureQueue.markTableAsDeleted(TableName table)
Tries to remove the queue and the table-lock of the specified table.
|
void |
MasterProcedureQueue.releaseTableRead(TableName table)
Release the read lock taken with tryAcquireTableRead()
|
void |
MasterProcedureQueue.releaseTableWrite(TableName table)
Release the write lock taken with tryAcquireTableWrite()
|
static boolean |
MasterDDLOperationHelper.reOpenAllRegions(MasterProcedureEnv env,
TableName tableName,
List<HRegionInfo> regionInfoList)
Reopen all regions from a table after a schema change operation.
|
protected static void |
DisableTableProcedure.setTableStateToDisabled(MasterProcedureEnv env,
TableName tableName)
Mark table state to Disabled
|
protected static void |
DisableTableProcedure.setTableStateToDisabling(MasterProcedureEnv env,
TableName tableName)
Mark table state to Disabling
|
protected static void |
EnableTableProcedure.setTableStateToEnabled(MasterProcedureEnv env,
TableName tableName)
Mark table state to Enabled
|
protected static void |
EnableTableProcedure.setTableStateToEnabling(MasterProcedureEnv env,
TableName tableName)
Mark table state to Enabling
|
boolean |
MasterProcedureQueue.tryAcquireTableRead(TableName table,
String purpose)
Try to acquire the read lock on the specified table.
|
boolean |
MasterProcedureQueue.tryAcquireTableWrite(TableName table,
String purpose)
Try to acquire the write lock on the specified table.
|
protected static void |
CreateTableProcedure.updateTableDescCache(MasterProcedureEnv env,
TableName tableName) |
static void |
MasterProcedureTestingUtility.validateColumnFamilyAddition(HMaster master,
TableName tableName,
String family) |
static void |
MasterProcedureTestingUtility.validateColumnFamilyDeletion(HMaster master,
TableName tableName,
String family) |
static void |
MasterProcedureTestingUtility.validateColumnFamilyModification(HMaster master,
TableName tableName,
String family,
HColumnDescriptor columnDescriptor) |
static void |
MasterProcedureTestingUtility.validateTableCreation(HMaster master,
TableName tableName,
HRegionInfo[] regions,
boolean hasFamilyDirs,
String... family) |
static void |
MasterProcedureTestingUtility.validateTableCreation(HMaster master,
TableName tableName,
HRegionInfo[] regions,
String... family) |
static void |
MasterProcedureTestingUtility.validateTableDeletion(HMaster master,
TableName tableName,
HRegionInfo[] regions,
String... family) |
static void |
MasterProcedureTestingUtility.validateTableIsDisabled(HMaster master,
TableName tableName) |
static void |
MasterProcedureTestingUtility.validateTableIsEnabled(HMaster master,
TableName tableName) |
Modifier and Type | Field and Description |
---|---|
protected TableName |
TakeSnapshotHandler.snapshotTable |
Modifier and Type | Method and Description |
---|---|
protected List<HRegionInfo> |
CloneSnapshotHandler.handleCreateHdfsRegions(Path tableRootDir,
TableName tableName)
Create the on-disk regions, using the tableRootDir provided by the CreateTableHandler.
|
void |
SnapshotManager.setSnapshotHandlerForTesting(TableName tableName,
SnapshotSentinel handler)
Set the handler for the current snapshot
|
Modifier and Type | Method and Description |
---|---|
void |
NamespaceAuditor.checkQuotaToCreateTable(TableName tName,
int regions)
Check quota to create table.
|
void |
NamespaceAuditor.checkQuotaToUpdateRegion(TableName tName,
int regions)
Check and update region count quota for an existing table.
|
void |
TestNamespaceAuditor.MasterSyncObserver.postDeleteTableHandler(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName) |
void |
TestNamespaceAuditor.MasterSyncObserver.preDeleteTable(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName) |
void |
NamespaceAuditor.removeFromNamespaceUsage(TableName tableName) |
Modifier and Type | Method and Description |
---|---|
static TableName[] |
ProtobufUtil.getTableNameArray(List<HBaseProtos.TableName> tableNamesList) |
static TableName |
ProtobufUtil.toTableName(HBaseProtos.TableName tableNamePB) |
Modifier and Type | Method and Description |
---|---|
static MasterProtos.AddColumnRequest |
RequestConverter.buildAddColumnRequest(TableName tableName,
HColumnDescriptor column)
Create a protocol buffer AddColumnRequest
|
static MasterProtos.DeleteColumnRequest |
RequestConverter.buildDeleteColumnRequest(TableName tableName,
byte[] columnName)
Create a protocol buffer DeleteColumnRequest
|
static MasterProtos.DeleteTableRequest |
RequestConverter.buildDeleteTableRequest(TableName tableName)
Creates a protocol buffer DeleteTableRequest
|
static MasterProtos.DisableTableRequest |
RequestConverter.buildDisableTableRequest(TableName tableName)
Creates a protocol buffer DisableTableRequest
|
static MasterProtos.EnableTableRequest |
RequestConverter.buildEnableTableRequest(TableName tableName)
Creates a protocol buffer EnableTableRequest
|
static MasterProtos.GetSchemaAlterStatusRequest |
RequestConverter.buildGetSchemaAlterStatusRequest(TableName tableName)
Creates a protocol buffer GetSchemaAlterStatusRequest
|
static MasterProtos.GetTableDescriptorsRequest |
RequestConverter.buildGetTableDescriptorsRequest(TableName tableName)
Creates a protocol buffer GetTableDescriptorsRequest for a single table
|
static AccessControlProtos.GrantRequest |
RequestConverter.buildGrantRequest(String username,
TableName tableName,
byte[] family,
byte[] qualifier,
AccessControlProtos.Permission.Action... actions)
Create a request to grant user permissions.
|
static MasterProtos.ModifyColumnRequest |
RequestConverter.buildModifyColumnRequest(TableName tableName,
HColumnDescriptor column)
Create a protocol buffer ModifyColumnRequest
|
static MasterProtos.ModifyTableRequest |
RequestConverter.buildModifyTableRequest(TableName tableName,
HTableDescriptor hTableDesc)
Creates a protocol buffer ModifyTableRequest
|
static AccessControlProtos.RevokeRequest |
RequestConverter.buildRevokeRequest(String username,
TableName tableName,
byte[] family,
byte[] qualifier,
AccessControlProtos.Permission.Action... actions)
Create a request to revoke user permissions.
|
static MasterProtos.TruncateTableRequest |
RequestConverter.buildTruncateTableRequest(TableName tableName,
boolean preserveSplits)
Creates a protocol buffer TruncateTableRequest
|
static List<UserPermission> |
ProtobufUtil.getUserPermissions(AccessControlProtos.AccessControlService.BlockingInterface protocol,
TableName t)
A utility used to get user table permissions.
|
static void |
ProtobufUtil.grant(AccessControlProtos.AccessControlService.BlockingInterface protocol,
String userShortName,
TableName tableName,
byte[] f,
byte[] q,
Permission.Action... actions)
A utility used to grant a user table permissions.
|
static void |
ProtobufUtil.revoke(AccessControlProtos.AccessControlService.BlockingInterface protocol,
String userShortName,
TableName tableName,
byte[] f,
byte[] q,
Permission.Action... actions)
A utility used to revoke a user's table permissions.
|
static WALProtos.BulkLoadDescriptor |
ProtobufUtil.toBulkLoadDescriptor(TableName tableName,
ByteString encodedRegionName,
Map<byte[],List<Path>> storeFiles,
long bulkloadSeqId)
Generates a marker for the WAL so that we propagate the notion of a bulk region load
throughout the WAL.
|
static HBaseProtos.TableName |
ProtobufUtil.toProtoTableName(TableName tableName) |
Modifier and Type | Method and Description |
---|---|
static MasterProtos.GetTableDescriptorsRequest |
RequestConverter.buildGetTableDescriptorsRequest(List<TableName> tableNames)
Creates a protocol buffer GetTableDescriptorsRequest
|
Modifier and Type | Field and Description |
---|---|
static TableName |
QuotaTableUtil.QUOTA_TABLE_NAME
System table for quotas
|
Modifier and Type | Method and Description |
---|---|
protected static TableName |
QuotaTableUtil.getTableFromRowKey(byte[] key) |
TableName |
QuotaSettings.getTableName() |
Modifier and Type | Method and Description |
---|---|
static Map<TableName,QuotaState> |
QuotaUtil.fetchTableQuotas(Connection connection,
List<Get> gets) |
Modifier and Type | Method and Description |
---|---|
static void |
QuotaUtil.addTableQuota(Connection connection,
TableName table,
QuotaProtos.Quotas data) |
static void |
QuotaUtil.addUserQuota(Connection connection,
String user,
TableName table,
QuotaProtos.Quotas data) |
void |
MasterQuotaManager.checkAndUpdateNamespaceRegionQuota(TableName tName,
int regions) |
void |
MasterQuotaManager.checkNamespaceTableAndRegionQuota(TableName tName,
int regions) |
static void |
QuotaUtil.deleteTableQuota(Connection connection,
TableName table) |
static void |
QuotaUtil.deleteUserQuota(Connection connection,
String user,
TableName table) |
OperationQuota |
RegionServerQuotaManager.getQuota(UserGroupInformation ugi,
TableName table)
Returns the quota for an operation.
|
protected static byte[] |
QuotaTableUtil.getSettingsQualifierForUserTable(TableName tableName) |
QuotaLimiter |
QuotaCache.getTableLimiter(TableName table)
Returns the limiter associated to the specified table.
|
QuotaLimiter |
UserQuotaState.getTableLimiter(TableName table)
Return the limiter for the specified table associated with this quota.
|
static QuotaProtos.Quotas |
QuotaTableUtil.getTableQuota(Connection connection,
TableName table) |
protected static byte[] |
QuotaTableUtil.getTableRowKey(TableName table) |
QuotaLimiter |
QuotaCache.getUserLimiter(UserGroupInformation ugi,
TableName table)
Returns the limiter associated to the specified user/table.
|
static QuotaProtos.Quotas |
QuotaTableUtil.getUserQuota(Connection connection,
String user,
TableName table) |
static Get |
QuotaTableUtil.makeGetForTableQuotas(TableName table) |
protected static void |
QuotaTableUtil.parseTableResult(TableName table,
Result result,
QuotaTableUtil.TableQuotasVisitor visitor) |
void |
MasterQuotaManager.removeTableFromNamespaceQuota(TableName tName)
Remove table from namespace quota.
|
void |
UserQuotaState.setQuotas(TableName table,
QuotaProtos.Quotas quotas)
Add the quota information of the specified table.
|
void |
MasterQuotaManager.setTableQuota(TableName table,
MasterProtos.SetQuotaRequest req) |
void |
MasterQuotaManager.setUserQuota(String userName,
TableName table,
MasterProtos.SetQuotaRequest req) |
static QuotaSettings |
QuotaSettingsFactory.throttleTable(TableName tableName,
ThrottleType type,
long limit,
TimeUnit timeUnit)
Throttle the specified table.
|
static QuotaSettings |
QuotaSettingsFactory.throttleUser(String userName,
TableName tableName,
ThrottleType type,
long limit,
TimeUnit timeUnit)
Throttle the specified user on the specified table.
|
static QuotaSettings |
QuotaSettingsFactory.unthrottleTable(TableName tableName)
Remove the throttling for the specified table.
|
static QuotaSettings |
QuotaSettingsFactory.unthrottleUser(String userName,
TableName tableName)
Remove the throttling for the specified user on the specified table.
|
void |
QuotaTableUtil.TableQuotasVisitor.visitTableQuotas(TableName tableName,
QuotaProtos.Quotas quotas) |
void |
QuotaTableUtil.UserQuotasVisitor.visitUserQuotas(String userName,
TableName table,
QuotaProtos.Quotas quotas) |
Modifier and Type | Method and Description |
---|---|
static Get |
QuotaTableUtil.makeGetForUserQuotas(String user,
Iterable<TableName> tables,
Iterable<String> namespaces) |
Constructor and Description |
---|
QuotaSettings(String userName,
TableName tableName,
String namespace) |
Modifier and Type | Field and Description |
---|---|
protected TableName |
TestFailedAppendAndSync.tableName |
protected TableName |
TestWALLockup.tableName |
static TableName |
TestPerColumnFamilyFlush.TABLENAME |
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.
|
Set<TableName> |
RegionServerServices.getOnlineTables() |
Modifier and Type | Method and Description |
---|---|
List<Region> |
HRegionServer.getOnlineRegions(TableName tableName)
Gets the online regions of the specified table.
|
List<Region> |
OnlineRegions.getOnlineRegions(TableName tableName)
Get all online regions of a table in this RS.
|
HRegion |
TestFailedAppendAndSync.initHRegion(TableName tableName,
byte[] startKey,
byte[] stopKey,
WAL wal) |
HRegion |
TestWALLockup.initHRegion(TableName tableName,
byte[] startKey,
byte[] stopKey,
WAL wal) |
static HRegion |
TestHRegion.initHRegion(TableName tableName,
String callingMethod,
Configuration conf,
byte[]... families) |
Constructor and Description |
---|
AtomicHFileLoader(TableName tableName,
MultithreadedTestUtil.TestContext ctx,
byte[][] targetFamilies) |
AtomicScanReader(TableName TABLE_NAME,
MultithreadedTestUtil.TestContext ctx,
byte[][] targetFamilies) |
Modifier and Type | Method and Description |
---|---|
protected WALKey |
FSHLog.makeKey(byte[] encodedRegionName,
TableName tableName,
long seqnum,
long now,
List<UUID> clusterIds,
long nonceGroup,
long nonce) |
Constructor and Description |
---|
HLogKey(byte[] encodedRegionName,
TableName tablename)
Deprecated.
|
HLogKey(byte[] encodedRegionName,
TableName tablename,
long now)
Deprecated.
|
HLogKey(byte[] encodedRegionName,
TableName tablename,
long now,
List<UUID> clusterIds,
long nonceGroup,
long nonce)
Deprecated.
Create the log key for writing to somewhere.
|
HLogKey(byte[] encodedRegionName,
TableName tablename,
long logSeqNum,
long now,
List<UUID> clusterIds,
long nonceGroup,
long nonce)
Deprecated.
Create the log key for writing to somewhere.
|
HLogKey(byte[] encodedRegionName,
TableName tablename,
long logSeqNum,
long nonceGroup,
long nonce)
Deprecated.
Create the log key for writing to somewhere.
|
HLogKey(byte[] encodedRegionName,
TableName tablename,
long logSeqNum,
long now,
UUID clusterId)
Deprecated.
|
ReplayHLogKey(byte[] encodedRegionName,
TableName tablename,
long now,
List<UUID> clusterIds,
long nonceGroup,
long nonce) |
ReplayHLogKey(byte[] encodedRegionName,
TableName tablename,
long logSeqNum,
long now,
List<UUID> clusterIds,
long nonceGroup,
long nonce) |
WALEditsReplaySink(Configuration conf,
TableName tableName,
HConnection conn)
Create a sink for WAL log entries replay
|
Modifier and Type | Field and Description |
---|---|
protected static TableName |
TestReplicationBase.tableName |
Modifier and Type | Method and Description |
---|---|
Map<TableName,List<String>> |
ReplicationPeer.getTableCFs()
Get replicable (table, cf-list) map of this peer
|
Map<TableName,List<String>> |
ReplicationPeerZKImpl.getTableCFs()
Get replicable (table, cf-list) map of this peer
|
Map<TableName,List<String>> |
ReplicationPeers.getTableCFs(String peerId)
Get the table and column-family-list map of the peer.
|
Map<TableName,List<String>> |
ReplicationPeersZKImpl.getTableCFs(String id) |
Modifier and Type | Method and Description |
---|---|
protected void |
ReplicationSink.batch(TableName tableName,
Collection<List<Row>> allRows)
Do the changes and handle the pool
|
Modifier and Type | Field and Description |
---|---|
static TableName |
PerformanceEvaluation.TABLE_NAME |
Modifier and Type | Method and Description |
---|---|
TableName |
PerformanceEvaluation.PeInputSplit.getTableName() |
Constructor and Description |
---|
PeInputSplit(TableName tableName,
int startRow,
int rows,
int totalRows,
int clients,
boolean flushCommits,
boolean writeToWAL,
boolean useTags,
int noOfTags) |
Modifier and Type | Method and Description |
---|---|
TableName |
RemoteHTable.getName() |
Modifier and Type | Field and Description |
---|---|
static TableName |
AccessControlClient.ACL_TABLE_NAME |
static TableName |
AccessControlLists.ACL_TABLE_NAME
Internal storage table for access control lists
|
Modifier and Type | Method and Description |
---|---|
TableName |
TablePermission.getTableName() |
TableName |
AuthResult.getTableName() |
TableName |
TestAccessController.TestTableDDLProcedure.getTableName() |
Modifier and Type | Method and Description |
---|---|
static AuthResult |
AuthResult.allow(String request,
String reason,
User user,
Permission.Action action,
TableName table,
byte[] family,
byte[] qualifier) |
static AuthResult |
AuthResult.allow(String request,
String reason,
User user,
Permission.Action action,
TableName table,
Map<byte[],? extends Collection<?>> families) |
boolean |
TableAuthManager.authorize(User user,
TableName table,
byte[] family,
byte[] qualifier,
Permission.Action action) |
boolean |
TableAuthManager.authorize(User user,
TableName table,
byte[] family,
Permission.Action action) |
boolean |
TableAuthManager.authorize(User user,
TableName table,
Cell cell,
Permission.Action action)
Authorize a user for a given KV.
|
boolean |
TableAuthManager.authorizeGroup(String groupName,
TableName table,
byte[] family,
byte[] qualifier,
Permission.Action action)
Checks authorization to a given table, column family and column for a group, based
on the stored permissions.
|
boolean |
TableAuthManager.authorizeUser(User user,
TableName table,
byte[] family,
byte[] qualifier,
Permission.Action action) |
boolean |
TableAuthManager.authorizeUser(User user,
TableName table,
byte[] family,
Permission.Action action)
Checks authorization to a given table and column family for a user, based on the
stored user permissions.
|
static void |
SecureTestUtil.checkTablePerms(Configuration conf,
TableName table,
byte[] family,
byte[] column,
Permission.Action... actions) |
static void |
SecureTestUtil.checkTablePerms(Configuration conf,
TableName table,
Permission... perms) |
static Table |
SecureTestUtil.createTable(HBaseTestingUtility testUtil,
TableName tableName,
byte[][] families) |
static void |
SecureTestUtil.deleteTable(HBaseTestingUtility testUtil,
Admin admin,
TableName tableName) |
static void |
SecureTestUtil.deleteTable(HBaseTestingUtility testUtil,
TableName tableName) |
void |
ZKPermissionWatcher.deleteTableACLNode(TableName tableName)
Delete the acl notify node of table
|
static AuthResult |
AuthResult.deny(String request,
String reason,
User user,
Permission.Action action,
TableName table,
byte[] family,
byte[] qualifier) |
static AuthResult |
AuthResult.deny(String request,
String reason,
User user,
Permission.Action action,
TableName table,
Map<byte[],? extends Collection<?>> families) |
static void |
AccessControlClient.grant(Configuration conf,
TableName tableName,
String userName,
byte[] family,
byte[] qual,
Permission.Action... actions)
Deprecated.
|
static void |
AccessControlClient.grant(Connection connection,
TableName tableName,
String userName,
byte[] family,
byte[] qual,
Permission.Action... actions)
Grants permission on the specified table for the specified user
|
static void |
SecureTestUtil.grantOnTable(HBaseTestingUtility util,
String user,
TableName table,
byte[] family,
byte[] qualifier,
Permission.Action... actions)
Grant permissions on a table to the given user.
|
static void |
SecureTestUtil.grantOnTableUsingAccessControlClient(HBaseTestingUtility util,
Connection connection,
String user,
TableName table,
byte[] family,
byte[] qualifier,
Permission.Action... actions)
Grant permissions on a table to the given user using AccessControlClient.
|
boolean |
TableAuthManager.groupHasAccess(String groupName,
TableName table,
Permission.Action action)
Checks if the user has access to the full table or at least a family/qualifier
for the specified action.
|
boolean |
TableAuthManager.hasAccess(User user,
TableName table,
Permission.Action action) |
boolean |
TablePermission.implies(TableName table,
byte[] family,
byte[] qualifier,
Permission.Action action)
Checks that a given table operation is authorized by this permission
instance.
|
boolean |
TablePermission.implies(TableName table,
KeyValue kv,
Permission.Action action)
Checks if this permission grants access to perform the given action on
the given table and key value.
|
boolean |
TablePermission.matchesFamily(TableName table,
byte[] family,
Permission.Action action)
Returns
true if this permission matches the given column
family at least. |
boolean |
TablePermission.matchesFamilyQualifier(TableName table,
byte[] family,
byte[] qualifier,
Permission.Action action)
Returns if the given permission matches the given qualifier.
|
boolean |
TableAuthManager.matchPermission(User user,
TableName table,
byte[] family,
byte[] qualifier,
Permission.Action action) |
boolean |
TableAuthManager.matchPermission(User user,
TableName table,
byte[] family,
Permission.Action action)
Returns true if the given user has a
TablePermission matching up
to the column family portion of a permission. |
void |
AccessController.postDeleteColumn(ObserverContext<MasterCoprocessorEnvironment> c,
TableName tableName,
byte[] col) |
void |
AccessController.postDeleteTable(ObserverContext<MasterCoprocessorEnvironment> c,
TableName tableName) |
void |
SecureTestUtil.MasterSyncObserver.postDeleteTableHandler(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName) |
void |
AccessController.postModifyTable(ObserverContext<MasterCoprocessorEnvironment> c,
TableName tableName,
HTableDescriptor htd) |
void |
AccessController.postTruncateTable(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName) |
void |
AccessController.preAddColumn(ObserverContext<MasterCoprocessorEnvironment> c,
TableName tableName,
HColumnDescriptor column) |
void |
AccessController.preDeleteColumn(ObserverContext<MasterCoprocessorEnvironment> c,
TableName tableName,
byte[] col) |
void |
AccessController.preDeleteTable(ObserverContext<MasterCoprocessorEnvironment> c,
TableName tableName) |
void |
AccessController.preDisableTable(ObserverContext<MasterCoprocessorEnvironment> c,
TableName tableName) |
void |
AccessController.preEnableTable(ObserverContext<MasterCoprocessorEnvironment> c,
TableName tableName) |
void |
AccessController.preModifyColumn(ObserverContext<MasterCoprocessorEnvironment> c,
TableName tableName,
HColumnDescriptor descriptor) |
void |
AccessController.preModifyTable(ObserverContext<MasterCoprocessorEnvironment> c,
TableName tableName,
HTableDescriptor htd) |
void |
AccessController.preSetTableQuota(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName,
QuotaProtos.Quotas quotas) |
void |
AccessController.preSetUserQuota(ObserverContext<MasterCoprocessorEnvironment> ctx,
String userName,
TableName tableName,
QuotaProtos.Quotas quotas) |
void |
AccessController.preTableFlush(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName) |
void |
AccessController.preTruncateTable(ObserverContext<MasterCoprocessorEnvironment> c,
TableName tableName) |
void |
TableAuthManager.refreshTableCacheFromWritable(TableName table,
byte[] data) |
void |
TableAuthManager.removeTable(TableName table) |
void |
AccessController.requireNamespacePermission(String request,
String namespace,
TableName tableName,
Map<byte[],? extends Collection<byte[]>> familyMap,
Permission.Action... permissions)
Checks that the user has the given global or namespace permission.
|
static void |
AccessControlClient.revoke(Configuration conf,
TableName tableName,
String username,
byte[] family,
byte[] qualifier,
Permission.Action... actions)
Deprecated.
|
static void |
AccessControlClient.revoke(Connection connection,
TableName tableName,
String username,
byte[] family,
byte[] qualifier,
Permission.Action... actions)
Revokes the permission on the table
|
static void |
SecureTestUtil.revokeFromTable(HBaseTestingUtility util,
String user,
TableName table,
byte[] family,
byte[] qualifier,
Permission.Action... actions)
Revoke permissions on a table from the given user.
|
static void |
SecureTestUtil.revokeFromTableUsingAccessControlClient(HBaseTestingUtility util,
Connection connection,
String user,
TableName table,
byte[] family,
byte[] qualifier,
Permission.Action... actions)
Revoke permissions on a table from the given user using AccessControlClient.
|
void |
TableAuthManager.setTableGroupPermissions(String group,
TableName table,
List<TablePermission> perms)
Overwrites the existing permission set for a group and triggers an update
for zookeeper synchronization.
|
AuthResult.Params |
AuthResult.Params.setTableName(TableName table) |
void |
TableAuthManager.setTableUserPermissions(String username,
TableName table,
List<TablePermission> perms)
Overwrites the existing permission set for a given user for a table, and
triggers an update for zookeeper synchronization.
|
boolean |
TableAuthManager.userHasAccess(User user,
TableName table,
Permission.Action action)
Checks if the user has access to the full table or at least a family/qualifier
for the specified action.
|
void |
TableAuthManager.writeTableToZooKeeper(TableName table,
org.apache.hadoop.hbase.security.access.TableAuthManager.PermissionCache<TablePermission> tablePerms) |
Modifier and Type | Method and Description |
---|---|
void |
AccessController.postGetTableDescriptors(ObserverContext<MasterCoprocessorEnvironment> ctx,
List<TableName> tableNamesList,
List<HTableDescriptor> descriptors,
String regex) |
void |
AccessController.preGetTableDescriptors(ObserverContext<MasterCoprocessorEnvironment> ctx,
List<TableName> tableNamesList,
List<HTableDescriptor> descriptors,
String regex) |
Constructor and Description |
---|
AuthResult(boolean allowed,
String request,
String reason,
User user,
Permission.Action action,
TableName table,
byte[] family,
byte[] qualifier) |
AuthResult(boolean allowed,
String request,
String reason,
User user,
Permission.Action action,
TableName table,
Map<byte[],? extends Collection<?>> families) |
TablePermission(String namespace,
TableName table,
byte[] family,
byte[] qualifier,
byte[] actionCodes)
Creates a new permission for the given namespace or table, family and column qualifier,
allowing the actions matching the provided byte codes to be performed.
|
TablePermission(String namespace,
TableName table,
byte[] family,
byte[] qualifier,
Permission.Action... assigned)
Creates a new permission for the given namespace or table, restricted to the given
column family and qualifier, allowing the assigned actions to be performed.
|
TablePermission(TableName table,
byte[] family,
byte[] qualifier,
byte[] actionCodes)
Creates a new permission for the given table, family and column qualifier,
allowing the actions matching the provided byte codes to be performed.
|
TablePermission(TableName table,
byte[] family,
byte[] qualifier,
Permission.Action... assigned)
Creates a new permission for the given table, restricted to the given
column family and qualifier, allowing the assigned actions to be performed.
|
TablePermission(TableName table,
byte[] family,
Permission.Action... assigned)
Create a new permission for the given table and (optionally) column family,
allowing the given actions.
|
TestTableDDLProcedure(MasterProcedureEnv env,
TableName tableName) |
UserPermission(byte[] user,
TableName table,
byte[] family,
byte[] qualifier,
byte[] actionCodes)
Creates a new instance for the given user, table, column family and
qualifier, matching the actions with the given codes.
|
UserPermission(byte[] user,
TableName table,
byte[] family,
byte[] qualifier,
Permission.Action... assigned)
Creates a new permission for the given user, table, column family and
column qualifier.
|
UserPermission(byte[] user,
TableName table,
byte[] family,
Permission.Action... assigned)
Creates a new instance for the given user, table and column family.
|
Modifier and Type | Field and Description |
---|---|
static TableName |
VisibilityConstants.LABELS_TABLE_NAME
Internal storage table for visibility labels
|
Modifier and Type | Method and Description |
---|---|
static List<HBaseProtos.SnapshotDescription> |
SnapshotTestingUtils.assertExistsMatchingSnapshot(Admin admin,
String snapshotName,
TableName tableName)
Make sure that there is only one snapshot returned from the master and its
name and table match the passed in parameters.
|
static List<HBaseProtos.SnapshotDescription> |
SnapshotTestingUtils.assertOneSnapshotThatMatches(Admin admin,
byte[] snapshot,
TableName tableName)
Make sure that there is only one snapshot returned from the master and its
name and table match the passed in parameters.
|
static List<HBaseProtos.SnapshotDescription> |
SnapshotTestingUtils.assertOneSnapshotThatMatches(Admin admin,
String snapshotName,
TableName tableName)
Make sure that there is only one snapshot returned from the master and its
name and table match the passed in parameters.
|
void |
TestSnapshotClientRetries.cloneAndAssertOneRetry(String snapshotName,
TableName tableName) |
static HTableDescriptor |
RestoreSnapshotHelper.cloneTableSchema(HTableDescriptor snapshotTableDescriptor,
TableName tableName)
Create a new table descriptor cloning the snapshot table schema.
|
static void |
SnapshotTestingUtils.confirmEmptySnapshotValid(HBaseProtos.SnapshotDescription snapshotDescriptor,
TableName tableName,
byte[] testFamily,
Path rootDir,
Admin admin,
FileSystem fs)
Confirm that the snapshot has no references files but only metadata.
|
static void |
SnapshotTestingUtils.confirmSnapshotValid(HBaseProtos.SnapshotDescription snapshotDescriptor,
TableName tableName,
byte[] testFamily,
Path rootDir,
Admin admin,
FileSystem fs)
Confirm that the snapshot contains references to all the files that should
be in the snapshot.
|
static void |
SnapshotTestingUtils.confirmSnapshotValid(HBaseProtos.SnapshotDescription snapshotDescriptor,
TableName tableName,
List<byte[]> nonEmptyTestFamilies,
List<byte[]> emptyTestFamilies,
Path rootDir,
Admin admin,
FileSystem fs)
Confirm that the snapshot contains references to all the files that should
be in the snapshot.
|
static void |
SnapshotTestingUtils.createSnapshotAndValidate(Admin admin,
TableName tableName,
List<byte[]> nonEmptyFamilyNames,
List<byte[]> emptyFamilyNames,
String snapshotNameString,
Path rootDir,
FileSystem fs,
boolean onlineSnapshot)
Take a snapshot of the specified table and verify the given families.
|
static void |
SnapshotTestingUtils.createSnapshotAndValidate(Admin admin,
TableName tableName,
String familyName,
String snapshotNameString,
Path rootDir,
FileSystem fs,
boolean onlineSnapshot)
Take a snapshot of the specified table and verify that the given family is
not empty.
|
static void |
SnapshotTestingUtils.createTable(HBaseTestingUtility util,
TableName tableName,
byte[]... families) |
static void |
SnapshotTestingUtils.createTable(HBaseTestingUtility util,
TableName tableName,
int regionReplication,
byte[]... families) |
static void |
SnapshotTestingUtils.loadData(HBaseTestingUtility util,
TableName tableName,
int rows,
byte[]... families) |
void |
TestSnapshotClientRetries.snapshotAndAssertOneRetry(String snapshotName,
TableName tableName) |
static void |
SnapshotTestingUtils.verifyReplicasCameOnline(TableName tableName,
Admin admin,
int regionReplication) |
static void |
SnapshotTestingUtils.verifyRowCount(HBaseTestingUtility util,
TableName tableName,
long expectedRows) |
static void |
SnapshotTestingUtils.waitForTableToBeOnline(HBaseTestingUtility util,
TableName tableName) |
Constructor and Description |
---|
TablePartiallyOpenException(TableName tableName) |
Modifier and Type | Method and Description |
---|---|
TableName |
IntegrationTestBigLinkedList.getTablename() |
TableName |
IntegrationTestLoadAndVerify.getTablename() |
Constructor and Description |
---|
TimeBoundedMultiThreadedReader(LoadTestDataGenerator dataGen,
Configuration conf,
TableName tableName,
double verifyPercent) |
Modifier and Type | Method and Description |
---|---|
static void |
Canary.sniff(Admin admin,
TableName tableName)
Canary entry point for specified table.
|
Modifier and Type | Field and Description |
---|---|
protected static TableName |
TestMiniClusterLoadSequential.TABLE |
protected TableName |
MultiThreadedAction.tableName |
Modifier and Type | Method and Description |
---|---|
TableName |
HBaseFsck.TableInfo.getName() |
TableName |
HBaseFsck.HbckInfo.getTableName() |
TableName |
TestTableName.getTableName() |
static TableName |
FSUtils.getTableName(Path tablePath)
Returns the
TableName object representing
the table directory under
path rootdir |
Modifier and Type | Method and Description |
---|---|
protected void |
LoadTestTool.applyColumnFamilyOptions(TableName tableName,
byte[][] columnFamilies)
Apply column family options such as Bloom filters, compression, and data
block encoding.
|
static void |
TestHBaseFsck.deleteTable(HBaseTestingUtility testUtil,
TableName tableName) |
void |
FSTableDescriptors.deleteTableDescriptorIfExists(TableName tableName)
Deletes all the table descriptor files from the file system.
|
void |
TestHBaseFsck.deleteTableDir(TableName table) |
HTableDescriptor |
FSTableDescriptors.get(TableName tablename)
Get the current table descriptor for the given table, or null if none exists.
|
<any> |
HBaseFsck.getOverlapGroups(TableName table) |
static Path |
HFileArchiveUtil.getRegionArchiveDir(Path rootDir,
TableName tableName,
Path regiondir)
Get the archive directory for a given region under the specified table
|
static Path |
HFileArchiveUtil.getRegionArchiveDir(Path rootDir,
TableName tableName,
String encodedRegionName)
Get the archive directory for a given region under the specified table
|
static Path |
HFileArchiveUtil.getStoreArchivePath(Configuration conf,
TableName tableName,
String regionName,
String familyName)
Get the directory to archive a store directory
|
static Path |
HFileArchiveUtil.getTableArchivePath(Configuration conf,
TableName tableName)
Get the path to the table archive directory based on the configured archive directory.
|
static Path |
HFileArchiveUtil.getTableArchivePath(Path rootdir,
TableName tableName)
Get the path to the table archive directory based on the configured archive directory.
|
static HTableDescriptor |
FSTableDescriptors.getTableDescriptorFromFs(FileSystem fs,
Path hbaseRootDir,
TableName tableName)
Returns the latest table descriptor for the given table directly from the file system
if it exists, bypassing the local cache.
|
static HTableDescriptor |
FSTableDescriptors.getTableDescriptorFromFs(FileSystem fs,
Path hbaseRootDir,
TableName tableName,
boolean rewritePb)
Returns the latest table descriptor for the table located at the given directory
directly from the file system if it exists.
|
static Path |
FSUtils.getTableDir(Path rootdir,
TableName tableName)
Returns the
org.apache.hadoop.fs.Path object representing the table directory under
path rootdir |
static Map<String,Path> |
FSUtils.getTableStoreFilePathMap(Map<String,Path> map,
FileSystem 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,Path> |
FSUtils.getTableStoreFilePathMap(Map<String,Path> map,
FileSystem fs,
Path hbaseRootDir,
TableName tableName,
HBaseFsck.ErrorReporter errors)
Runs through the HBase rootdir/tablename and creates a reverse lookup map for
table StoreFile names to the full Path.
|
void |
HBaseFsck.includeTable(TableName table) |
boolean |
FSTableDescriptors.isTableInfoExists(TableName tableName)
Checks if a current table info file exists for the given table
|
void |
TestHBaseFsck.MasterSyncObserver.postDeleteTableHandler(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName) |
protected MultiThreadedReader |
TestMiniClusterLoadSequential.prepareReaderThreads(LoadTestDataGenerator dataGen,
Configuration conf,
TableName tableName,
double verifyPercent) |
protected MultiThreadedWriter |
TestMiniClusterLoadSequential.prepareWriterThreads(LoadTestDataGenerator dataGen,
Configuration conf,
TableName tableName) |
<R> void |
MultiHConnection.processBatchCallback(List<? extends Row> actions,
TableName tableName,
Object[] results,
Batch.Callback<R> callback)
Randomly pick a connection and process the batch of actions for a given table
|
HTableDescriptor |
FSTableDescriptors.remove(TableName tablename)
Removes the table descriptor from the local cache and returns it.
|
Constructor and Description |
---|
MultiThreadedAction(LoadTestDataGenerator dataGen,
Configuration conf,
TableName tableName,
String actionLetter) |
MultiThreadedReader(LoadTestDataGenerator dataGen,
Configuration conf,
TableName tableName,
double verifyPercent) |
MultiThreadedReaderWithACL(LoadTestDataGenerator dataGen,
Configuration conf,
TableName tableName,
double verifyPercent,
String userNames) |
MultiThreadedUpdater(LoadTestDataGenerator dataGen,
Configuration conf,
TableName tableName,
double updatePercent) |
MultiThreadedUpdaterWithACL(LoadTestDataGenerator dataGen,
Configuration conf,
TableName tableName,
double updatePercent,
User userOwner,
String userNames) |
MultiThreadedWriter(LoadTestDataGenerator dataGen,
Configuration conf,
TableName tableName) |
MultiThreadedWriterBase(LoadTestDataGenerator dataGen,
Configuration conf,
TableName tableName,
String actionLetter) |
MultiThreadedWriterWithACL(LoadTestDataGenerator dataGen,
Configuration conf,
TableName tableName,
User userOwner) |
Modifier and Type | Field and Description |
---|---|
protected TableName |
OfflineMetaRebuildTestCore.table |
Modifier and Type | Method and Description |
---|---|
static HBaseFsck |
HbckTestingUtil.doFsck(Configuration conf,
boolean fixAssignments,
boolean fixMeta,
boolean fixHdfsHoles,
boolean fixHdfsOverlaps,
boolean fixHdfsOrphans,
boolean fixTableOrphans,
boolean fixVersionFile,
boolean fixReferenceFiles,
boolean fixEmptyMetaRegionInfo,
boolean fixTableLocks,
boolean fixTableZnodes,
TableName table) |
static HBaseFsck |
HbckTestingUtil.doFsck(Configuration conf,
boolean fix,
TableName table) |
static HBaseFsck |
HbckTestingUtil.doHFileQuarantine(Configuration conf,
TableName table)
Runs hbck with the -sidelineCorruptHFiles option
|
protected int |
OfflineMetaRebuildTestCore.tableRowCount(Configuration conf,
TableName table)
Returns the number of rows in a given table.
|
Modifier and Type | Field and Description |
---|---|
protected TableName |
WALKey.tablename |
Modifier and Type | Method and Description |
---|---|
TableName |
WALKey.getTablename() |
TableName |
WALSplitter.RegionEntryBuffer.getTableName() |
Modifier and Type | Method and Description |
---|---|
static long |
TestWALSplit.appendEntry(WALProvider.Writer writer,
TableName table,
byte[] region,
byte[] row,
byte[] family,
byte[] qualifier,
byte[] value,
long seq) |
protected void |
WALKey.init(byte[] encodedRegionName,
TableName tablename,
long logSeqNum,
long now,
List<UUID> clusterIds,
long nonceGroup,
long nonce) |
Constructor and Description |
---|
WALKey(byte[] encodedRegionName,
TableName tablename) |
WALKey(byte[] encodedRegionName,
TableName tablename,
long now) |
WALKey(byte[] encodedRegionName,
TableName tablename,
long now,
List<UUID> clusterIds,
long nonceGroup,
long nonce)
Create the log key for writing to somewhere.
|
WALKey(byte[] encodedRegionName,
TableName tablename,
long logSeqNum,
long now,
List<UUID> clusterIds,
long nonceGroup,
long nonce)
Create the log key for writing to somewhere.
|
WALKey(byte[] encodedRegionName,
TableName tablename,
long logSeqNum,
long nonceGroup,
long nonce)
Create the log key for writing to somewhere.
|
WALKey(byte[] encodedRegionName,
TableName tablename,
long logSeqNum,
long now,
UUID clusterId) |
Modifier and Type | Method and Description |
---|---|
static Set<TableName> |
ZKTableStateClientSideReader.getDisabledOrDisablingTables(ZooKeeperWatcher zkw)
Gets a list of all the tables set as disabled in zookeeper.
|
static Set<TableName> |
ZKTableStateClientSideReader.getDisabledTables(ZooKeeperWatcher zkw)
Gets a list of all the tables set as disabled in zookeeper.
|
static Set<TableName> |
ZKTableStateClientSideReader.getEnablingTables(ZooKeeperWatcher zkw)
Gets a list of all the tables set as enabling in zookeeper.
|
Set<TableName> |
ZKTableStateManager.getTablesInStates(ZooKeeperProtos.Table.State... states)
Gets a list of all the tables set as disabling in zookeeper.
|
Modifier and Type | Method and Description |
---|---|
void |
ZKTableStateManager.checkAndRemoveTableState(TableName tableName,
ZooKeeperProtos.Table.State states,
boolean deletePermanentState)
If the table is found in the given state the in-memory state is removed.
|
static boolean |
ZKTableStateClientSideReader.isDisabledTable(ZooKeeperWatcher zkw,
TableName tableName)
Go to zookeeper and see if state of table is
ZooKeeperProtos.Table.State#DISABLED . |
static boolean |
ZKTableStateClientSideReader.isDisablingOrDisabledTable(ZooKeeperWatcher zkw,
TableName tableName)
Go to zookeeper and see if state of table is
ZooKeeperProtos.Table.State#DISABLING
of ZooKeeperProtos.Table.State#DISABLED . |
static boolean |
ZKTableStateClientSideReader.isEnabledTable(ZooKeeperWatcher zkw,
TableName tableName)
Go to zookeeper and see if state of table is
ZooKeeperProtos.Table.State#ENABLED . |
boolean |
ZKTableStateManager.isTablePresent(TableName tableName)
check if table is present.
|
boolean |
ZKTableStateManager.isTableState(TableName tableName,
boolean checkSource,
ZooKeeperProtos.Table.State... states)
Checks if table is marked in specified state in ZK.
|
boolean |
ZKTableStateManager.isTableState(TableName tableName,
ZooKeeperProtos.Table.State... states)
Checks if table is marked in specified state in ZK (using cache only).
|
void |
ZKTableStateManager.setDeletedTable(TableName tableName)
Deletes the table in zookeeper.
|
void |
ZKTableStateManager.setTableState(TableName tableName,
ZooKeeperProtos.Table.State state)
Sets table state in ZK.
|
boolean |
ZKTableStateManager.setTableStateIfInStates(TableName tableName,
ZooKeeperProtos.Table.State newState,
ZooKeeperProtos.Table.State... states)
Checks and sets table state in ZK.
|
boolean |
ZKTableStateManager.setTableStateIfNotInStates(TableName tableName,
ZooKeeperProtos.Table.State newState,
ZooKeeperProtos.Table.State... states)
Checks and sets table state in ZK.
|