Package | Description |
---|---|
org.apache.hadoop.hbase | |
org.apache.hadoop.hbase.client |
Provides HBase Client
|
org.apache.hadoop.hbase.client.replication | |
org.apache.hadoop.hbase.mapred |
Provides HBase MapReduce
Input/OutputFormats, a table indexing MapReduce job, and utility methods.
|
org.apache.hadoop.hbase.mapreduce |
Provides HBase MapReduce
Input/OutputFormats, a table indexing MapReduce job, and utility methods.
|
org.apache.hadoop.hbase.quotas | |
org.apache.hadoop.hbase.replication |
Multi Cluster Replication
|
org.apache.hadoop.hbase.rest.client | |
org.apache.hadoop.hbase.rsgroup | |
org.apache.hadoop.hbase.snapshot |
Modifier and Type | Field and Description |
---|---|
static TableName |
HConstants.ENSEMBLE_TABLE_NAME
The name of the ensemble table
|
static TableName |
TableName.META_TABLE_NAME
The hbase:meta table's name.
|
static TableName |
TableName.NAMESPACE_TABLE_NAME
The Namespace table's name.
|
static TableName |
TableName.OLD_META_TABLE_NAME
TableName for old .META.
|
static TableName |
TableName.OLD_ROOT_TABLE_NAME
TableName for old -ROOT- table.
|
Modifier and Type | Method and Description |
---|---|
TableName |
HRegionInfo.getTable()
Deprecated.
Get current table name of the region
|
static TableName |
HRegionInfo.getTable(byte[] regionName)
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0
Use
RegionInfo.getTable(byte[]) . |
TableName |
HTableDescriptor.getTableName()
Deprecated.
Get the name of the table
|
static TableName |
TableName.valueOf(byte[] fullName) |
static TableName |
TableName.valueOf(byte[] namespace,
byte[] qualifier) |
static TableName |
TableName.valueOf(ByteBuffer namespace,
ByteBuffer qualifier) |
static TableName |
TableName.valueOf(String name) |
static TableName |
TableName.valueOf(String namespaceAsString,
String qualifierAsString) |
Modifier and Type | Method and Description |
---|---|
int |
TableName.compareTo(TableName tableName)
For performance reasons, the ordering is not lexicographic.
|
static byte[] |
HRegionInfo.createRegionName(TableName tableName,
byte[] startKey,
byte[] id,
boolean newFormat)
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0
Use
RegionInfo.createRegionName(TableName, byte[], byte[], boolean) . |
static byte[] |
HRegionInfo.createRegionName(TableName tableName,
byte[] startKey,
byte[] id,
int replicaId,
boolean newFormat)
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0
Use
RegionInfo.createRegionName(TableName, byte[], byte[], int, boolean) . |
static byte[] |
HRegionInfo.createRegionName(TableName tableName,
byte[] startKey,
long regionid,
boolean newFormat)
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0
Use
RegionInfo.createRegionName(TableName, byte[], long, boolean) . |
static byte[] |
HRegionInfo.createRegionName(TableName tableName,
byte[] startKey,
long regionid,
int replicaId,
boolean newFormat)
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0
Use
RegionInfo.createRegionName(TableName, byte[], long, int, boolean) . |
static byte[] |
HRegionInfo.createRegionName(TableName tableName,
byte[] startKey,
String id,
boolean newFormat)
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0
Use
RegionInfo.createRegionName(TableName, byte[], String, boolean) . |
default long |
ClusterMetrics.getLastMajorCompactionTimestamp(TableName table) |
long |
ClusterStatus.getLastMajorCompactionTsForTable(TableName table)
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0
Use
ClusterMetrics.getLastMajorCompactionTimestamp(TableName) instead. |
static boolean |
TableName.isMetaTableName(TableName tn) |
Constructor and Description |
---|
HRegionInfo(long regionId,
TableName tableName,
int replicaId)
Deprecated.
|
HRegionInfo(TableName tableName)
Deprecated.
|
HRegionInfo(TableName tableName,
byte[] startKey,
byte[] endKey)
Deprecated.
Construct HRegionInfo with explicit parameters
|
HRegionInfo(TableName tableName,
byte[] startKey,
byte[] endKey,
boolean split)
Deprecated.
Construct HRegionInfo with explicit parameters
|
HRegionInfo(TableName tableName,
byte[] startKey,
byte[] endKey,
boolean split,
long regionid)
Deprecated.
Construct HRegionInfo with explicit parameters
|
HRegionInfo(TableName tableName,
byte[] startKey,
byte[] endKey,
boolean split,
long regionid,
int replicaId)
Deprecated.
Construct HRegionInfo with explicit parameters
|
HTableDescriptor(TableName name)
Deprecated.
Construct a table descriptor specifying a TableName object
|
HTableDescriptor(TableName name,
HTableDescriptor desc)
Deprecated.
Construct a table descriptor by cloning the descriptor passed as a parameter
but using a different table name.
|
TableExistsException(TableName tableName) |
TableNotDisabledException(TableName tableName) |
TableNotEnabledException(TableName tableName) |
TableNotFoundException(TableName tableName) |
Modifier and Type | Method and Description |
---|---|
TableName |
AsyncTable.getName()
Gets the fully qualified table name instance of this table.
|
TableName |
BufferedMutator.getName()
Gets the fully qualified table name instance of the table that this BufferedMutator writes to.
|
TableName |
Table.getName()
Gets the fully qualified table name instance of this table.
|
TableName |
RegionLocator.getName()
Gets the fully qualified table name instance of this table.
|
TableName |
AsyncTableRegionLocator.getName()
Gets the fully qualified table name instance of the table whose region we want to locate.
|
TableName |
AsyncBufferedMutator.getName()
Gets the fully qualified table name instance of the table that this
AsyncBufferedMutator writes to. |
TableName |
RegionInfo.getTable() |
static TableName |
RegionInfo.getTable(byte[] regionName)
Gets the table name from the specified region name.
|
TableName |
BufferedMutatorParams.getTableName() |
TableName |
TableDescriptor.getTableName()
Get the name of the table
|
TableName |
SnapshotDescription.getTableName() |
TableName[] |
Admin.listTableNames()
List all of the names of userspace tables.
|
TableName[] |
Admin.listTableNames(Pattern pattern)
List all of the names of userspace tables.
|
TableName[] |
Admin.listTableNames(Pattern pattern,
boolean includeSysTables)
List all of the names of userspace tables.
|
TableName[] |
Admin.listTableNames(String regex)
Deprecated.
since 2.0 version and will be removed in 3.0 version. Use
Admin.listTableNames(Pattern) instead. |
TableName[] |
Admin.listTableNames(String regex,
boolean includeSysTables)
Deprecated.
since 2.0 version and will be removed in 3.0 version. Use
Admin.listTableNames(Pattern, boolean) instead. |
TableName[] |
Admin.listTableNamesByNamespace(String name)
Get list of table names by namespace.
|
Modifier and Type | Method and Description |
---|---|
default CompletableFuture<List<TableName>> |
AsyncAdmin.listTableNames()
List all of the names of userspace tables.
|
CompletableFuture<List<TableName>> |
AsyncAdmin.listTableNames(boolean includeSysTables)
List all of the names of tables.
|
CompletableFuture<List<TableName>> |
AsyncAdmin.listTableNames(Pattern pattern,
boolean includeSysTables)
List all of the names of userspace tables.
|
CompletableFuture<List<TableName>> |
AsyncAdmin.listTableNamesByNamespace(String name)
Get list of table names by namespace.
|
Modifier and Type | Method and Description |
---|---|
default void |
Admin.addColumn(TableName tableName,
ColumnFamilyDescriptor columnFamily)
Deprecated.
As of release 2.0.0.
This will be removed in HBase 3.0.0.
Use
Admin.addColumnFamily(TableName, ColumnFamilyDescriptor) . |
CompletableFuture<Void> |
AsyncAdmin.addColumnFamily(TableName tableName,
ColumnFamilyDescriptor columnFamily)
Add a column family to an existing table.
|
void |
Admin.addColumnFamily(TableName tableName,
ColumnFamilyDescriptor columnFamily)
Add a column family to an existing table.
|
Future<Void> |
Admin.addColumnFamilyAsync(TableName tableName,
ColumnFamilyDescriptor columnFamily)
Add a column family to an existing table.
|
CompletableFuture<CacheEvictionStats> |
AsyncAdmin.clearBlockCache(TableName tableName)
Clear all the blocks corresponding to this table from BlockCache.
|
CacheEvictionStats |
Admin.clearBlockCache(TableName tableName)
Clear all the blocks corresponding to this table from BlockCache.
|
void |
Admin.cloneSnapshot(byte[] snapshotName,
TableName tableName)
Create a new table by cloning the snapshot content.
|
CompletableFuture<Void> |
AsyncAdmin.cloneSnapshot(String snapshotName,
TableName tableName)
Create a new table by cloning the snapshot content.
|
void |
Admin.cloneSnapshot(String snapshotName,
TableName tableName)
Create a new table by cloning the snapshot content.
|
void |
Admin.cloneSnapshot(String snapshotName,
TableName tableName,
boolean restoreAcl)
Create a new table by cloning the snapshot content.
|
Future<Void> |
Admin.cloneSnapshotAsync(String snapshotName,
TableName tableName)
Create a new table by cloning the snapshot content, but does not block
and wait for it to be completely cloned.
|
default CompletableFuture<Void> |
AsyncAdmin.compact(TableName tableName)
Compact a table.
|
void |
Admin.compact(TableName tableName)
Compact a table.
|
default CompletableFuture<Void> |
AsyncAdmin.compact(TableName tableName,
byte[] columnFamily)
Compact a column family within a table.
|
void |
Admin.compact(TableName tableName,
byte[] columnFamily)
Compact a column family within a table.
|
CompletableFuture<Void> |
AsyncAdmin.compact(TableName tableName,
byte[] columnFamily,
CompactType compactType)
Compact a column family within a table.
|
void |
Admin.compact(TableName tableName,
byte[] columnFamily,
CompactType compactType)
Compact a column family within a table.
|
CompletableFuture<Void> |
AsyncAdmin.compact(TableName tableName,
CompactType compactType)
Compact a table.
|
void |
Admin.compact(TableName tableName,
CompactType compactType)
Compact a table.
|
static TableDescriptor |
TableDescriptorBuilder.copy(TableName name,
TableDescriptor desc) |
static RegionInfo |
RegionInfo.createMobRegionInfo(TableName tableName)
Creates a RegionInfo object for MOB data.
|
static byte[] |
RegionInfo.createRegionName(TableName tableName,
byte[] startKey,
byte[] id,
boolean newFormat)
Make a region name of passed parameters.
|
static byte[] |
RegionInfo.createRegionName(TableName tableName,
byte[] startKey,
byte[] id,
int replicaId,
boolean newFormat)
Make a region name of passed parameters.
|
static byte[] |
RegionInfo.createRegionName(TableName tableName,
byte[] startKey,
long regionid,
boolean newFormat)
Make a region name of passed parameters.
|
static byte[] |
RegionInfo.createRegionName(TableName tableName,
byte[] startKey,
long regionid,
int replicaId,
boolean newFormat)
Make a region name of passed parameters.
|
static byte[] |
RegionInfo.createRegionName(TableName tableName,
byte[] startKey,
String id,
boolean newFormat)
Make a region name of passed parameters.
|
void |
Admin.deleteColumn(TableName tableName,
byte[] columnFamily)
Deprecated.
As of release 2.0.0.
This will be removed in HBase 3.0.0.
Use
Admin.deleteColumnFamily(TableName, byte[]) }. |
CompletableFuture<Void> |
AsyncAdmin.deleteColumnFamily(TableName tableName,
byte[] columnFamily)
Delete a column family from a table.
|
void |
Admin.deleteColumnFamily(TableName tableName,
byte[] columnFamily)
Delete a column family from a table.
|
Future<Void> |
Admin.deleteColumnFamilyAsync(TableName tableName,
byte[] columnFamily)
Delete a column family from a table.
|
CompletableFuture<Void> |
AsyncAdmin.deleteTable(TableName tableName)
Deletes a table.
|
void |
Admin.deleteTable(TableName tableName)
Deletes a table.
|
Future<Void> |
Admin.deleteTableAsync(TableName tableName)
Deletes the table but does not block and wait for it to be completely removed.
|
CompletableFuture<Void> |
AsyncAdmin.disableTable(TableName tableName)
Disable a table.
|
void |
Admin.disableTable(TableName tableName)
Disable table and wait on completion.
|
Future<Void> |
Admin.disableTableAsync(TableName tableName)
Disable the table but does not block and wait for it to be completely disabled.
|
CompletableFuture<Void> |
AsyncAdmin.disableTableReplication(TableName tableName)
Disable a table's replication switch.
|
void |
Admin.disableTableReplication(TableName tableName)
Disable a table's replication switch.
|
CompletableFuture<Void> |
AsyncAdmin.enableTable(TableName tableName)
Enable a table.
|
void |
Admin.enableTable(TableName tableName)
Enable a table.
|
Future<Void> |
Admin.enableTableAsync(TableName tableName)
Enable the table but does not block and wait for it to be completely enabled.
|
CompletableFuture<Void> |
AsyncAdmin.enableTableReplication(TableName tableName)
Enable a table's replication switch.
|
void |
Admin.enableTableReplication(TableName tableName)
Enable a table's replication switch.
|
CompletableFuture<Void> |
AsyncAdmin.flush(TableName tableName)
Flush a table.
|
void |
Admin.flush(TableName tableName)
Flush a table.
|
Pair<Integer,Integer> |
Admin.getAlterStatus(TableName tableName)
Deprecated.
Since 2.0.0. Will be removed in 3.0.0. No longer needed now you get a Future
on an operation.
|
BufferedMutator |
Connection.getBufferedMutator(TableName tableName)
Retrieve a
BufferedMutator for performing client-side buffering of writes. |
default AsyncBufferedMutator |
AsyncConnection.getBufferedMutator(TableName tableName)
Retrieve an
AsyncBufferedMutator for performing client-side buffering of writes. |
default AsyncBufferedMutator |
AsyncConnection.getBufferedMutator(TableName tableName,
ExecutorService pool)
Retrieve an
AsyncBufferedMutator for performing client-side buffering of writes. |
AsyncBufferedMutatorBuilder |
AsyncConnection.getBufferedMutatorBuilder(TableName tableName)
Returns an
AsyncBufferedMutatorBuilder for creating AsyncBufferedMutator . |
AsyncBufferedMutatorBuilder |
AsyncConnection.getBufferedMutatorBuilder(TableName tableName,
ExecutorService pool)
Returns an
AsyncBufferedMutatorBuilder for creating AsyncBufferedMutator . |
default CompletableFuture<CompactionState> |
AsyncAdmin.getCompactionState(TableName tableName)
Get the current compaction state of a table.
|
CompactionState |
Admin.getCompactionState(TableName tableName)
Get the current compaction state of a table.
|
CompletableFuture<CompactionState> |
AsyncAdmin.getCompactionState(TableName tableName,
CompactType compactType)
Get the current compaction state of a table.
|
CompactionState |
Admin.getCompactionState(TableName tableName,
CompactType compactType)
Get the current compaction state of a table.
|
CompletableFuture<TableDescriptor> |
AsyncAdmin.getDescriptor(TableName tableName)
Method for getting the tableDescriptor
|
TableDescriptor |
Admin.getDescriptor(TableName tableName)
Get a table descriptor.
|
CompletableFuture<Optional<Long>> |
AsyncAdmin.getLastMajorCompactionTimestamp(TableName tableName)
Get the timestamp of the last major compaction for the passed table.
|
long |
Admin.getLastMajorCompactionTimestamp(TableName tableName)
Get the timestamp of the last major compaction for the passed table
The timestamp of the oldest HFile resulting from a major compaction of that table,
or 0 if no such HFile could be found.
|
RegionLocator |
Connection.getRegionLocator(TableName tableName)
Retrieve a RegionLocator implementation to inspect region information on a table.
|
AsyncTableRegionLocator |
AsyncConnection.getRegionLocator(TableName tableName)
Retrieve a AsyncRegionLocator implementation to inspect region information on a table.
|
CompletableFuture<List<RegionMetrics>> |
AsyncAdmin.getRegionMetrics(ServerName serverName,
TableName tableName)
Get a list of
RegionMetrics of all regions hosted on a region seerver for a table. |
List<RegionMetrics> |
Admin.getRegionMetrics(ServerName serverName,
TableName tableName)
Get
RegionMetrics of all regions hosted on a regionserver for a table. |
CompletableFuture<List<RegionInfo>> |
AsyncAdmin.getRegions(TableName tableName)
Get the regions of a given table.
|
List<RegionInfo> |
Admin.getRegions(TableName tableName)
Get the regions of a given table.
|
default Table |
Connection.getTable(TableName tableName)
Retrieve a Table implementation for accessing a table.
|
default AsyncTable<AdvancedScanResultConsumer> |
AsyncConnection.getTable(TableName tableName)
Retrieve an
AsyncTable implementation for accessing a table. |
default Table |
Connection.getTable(TableName tableName,
ExecutorService pool)
Retrieve a Table implementation for accessing a table.
|
default AsyncTable<ScanResultConsumer> |
AsyncConnection.getTable(TableName tableName,
ExecutorService pool)
Retrieve an
AsyncTable implementation for accessing a table. |
AsyncTableBuilder<AdvancedScanResultConsumer> |
AsyncConnection.getTableBuilder(TableName tableName)
Returns an
AsyncTableBuilder for creating AsyncTable . |
TableBuilder |
Connection.getTableBuilder(TableName tableName,
ExecutorService pool)
Returns an
TableBuilder for creating Table . |
AsyncTableBuilder<ScanResultConsumer> |
AsyncConnection.getTableBuilder(TableName tableName,
ExecutorService pool)
Returns an
AsyncTableBuilder for creating AsyncTable . |
HTableDescriptor |
Admin.getTableDescriptor(TableName tableName)
Deprecated.
since 2.0 version and will be removed in 3.0 version.
Use
Admin.getDescriptor(TableName) . |
List<HRegionInfo> |
Admin.getTableRegions(TableName tableName)
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0
(HBASE-17980).
Use
Admin.getRegions(TableName) . |
CompletableFuture<Boolean> |
AsyncAdmin.isTableAvailable(TableName tableName) |
boolean |
Admin.isTableAvailable(TableName tableName) |
CompletableFuture<Boolean> |
AsyncAdmin.isTableAvailable(TableName tableName,
byte[][] splitKeys)
Use this api to check if the table has been created with the specified number of splitkeys
which was used while creating the given table.
|
boolean |
Admin.isTableAvailable(TableName tableName,
byte[][] splitKeys)
Deprecated.
Since 2.0.0. Will be removed in 3.0.0. Use
Admin.isTableAvailable(TableName) |
CompletableFuture<Boolean> |
AsyncAdmin.isTableDisabled(TableName tableName) |
boolean |
Admin.isTableDisabled(TableName tableName) |
CompletableFuture<Boolean> |
AsyncAdmin.isTableEnabled(TableName tableName) |
boolean |
Admin.isTableEnabled(TableName tableName) |
default CompletableFuture<Void> |
AsyncAdmin.majorCompact(TableName tableName)
Major compact a table.
|
void |
Admin.majorCompact(TableName tableName)
Major compact a table.
|
default CompletableFuture<Void> |
AsyncAdmin.majorCompact(TableName tableName,
byte[] columnFamily)
Major compact a column family within a table.
|
void |
Admin.majorCompact(TableName tableName,
byte[] columnFamily)
Major compact a column family within a table.
|
CompletableFuture<Void> |
AsyncAdmin.majorCompact(TableName tableName,
byte[] columnFamily,
CompactType compactType)
Major compact a column family within a table.
|
void |
Admin.majorCompact(TableName tableName,
byte[] columnFamily,
CompactType compactType)
Major compact a column family within a table.
|
CompletableFuture<Void> |
AsyncAdmin.majorCompact(TableName tableName,
CompactType compactType)
Major compact a table.
|
void |
Admin.majorCompact(TableName tableName,
CompactType compactType)
Major compact a table.
|
default void |
Admin.modifyColumn(TableName tableName,
ColumnFamilyDescriptor columnFamily)
Deprecated.
As of release 2.0.0.
This will be removed in HBase 3.0.0.
Use
Admin.modifyColumnFamily(TableName, ColumnFamilyDescriptor) . |
CompletableFuture<Void> |
AsyncAdmin.modifyColumnFamily(TableName tableName,
ColumnFamilyDescriptor columnFamily)
Modify an existing column family on a table.
|
void |
Admin.modifyColumnFamily(TableName tableName,
ColumnFamilyDescriptor columnFamily)
Modify an existing column family on a table.
|
Future<Void> |
Admin.modifyColumnFamilyAsync(TableName tableName,
ColumnFamilyDescriptor columnFamily)
Modify an existing column family on a table.
|
void |
Admin.modifyTable(TableName tableName,
TableDescriptor td)
Deprecated.
since 2.0 version and will be removed in 3.0 version.
use
Admin.modifyTable(TableDescriptor) |
Future<Void> |
Admin.modifyTableAsync(TableName tableName,
TableDescriptor td)
Deprecated.
since 2.0 version and will be removed in 3.0 version.
use
Admin.modifyTableAsync(TableDescriptor) |
static TableDescriptorBuilder |
TableDescriptorBuilder.newBuilder(TableName name) |
List<Put> |
HTableMultiplexer.put(TableName tableName,
List<Put> puts)
The puts request will be buffered by their corresponding buffer queue.
|
boolean |
HTableMultiplexer.put(TableName tableName,
Put put)
The put request will be buffered by its corresponding buffer queue.
|
boolean |
HTableMultiplexer.put(TableName tableName,
Put put,
int maxAttempts)
The put request will be buffered by its corresponding buffer queue.
|
void |
Admin.snapshot(byte[] snapshotName,
TableName tableName)
Create a timestamp consistent snapshot for the given table.
|
default CompletableFuture<Void> |
AsyncAdmin.snapshot(String snapshotName,
TableName tableName)
Take a snapshot for the given table.
|
void |
Admin.snapshot(String snapshotName,
TableName tableName)
Take a snapshot for the given table.
|
default CompletableFuture<Void> |
AsyncAdmin.snapshot(String snapshotName,
TableName tableName,
SnapshotType type)
Create typed snapshot of the table.
|
void |
Admin.snapshot(String snapshotName,
TableName tableName,
SnapshotType type)
Create typed snapshot of the table.
|
CompletableFuture<Void> |
AsyncAdmin.split(TableName tableName)
Split a table.
|
void |
Admin.split(TableName tableName)
+ Split a table.
|
CompletableFuture<Void> |
AsyncAdmin.split(TableName tableName,
byte[] splitPoint)
Split a table.
|
void |
Admin.split(TableName tableName,
byte[] splitPoint)
Split a table.
|
CompletableFuture<Boolean> |
AsyncAdmin.tableExists(TableName tableName) |
boolean |
Admin.tableExists(TableName tableName) |
CompletableFuture<Void> |
AsyncAdmin.truncateTable(TableName tableName,
boolean preserveSplits)
Truncate a table.
|
void |
Admin.truncateTable(TableName tableName,
boolean preserveSplits)
Truncate a table.
|
Future<Void> |
Admin.truncateTableAsync(TableName tableName,
boolean preserveSplits)
Truncate the table but does not block and wait for it to be completely enabled.
|
Modifier and Type | Method and Description |
---|---|
CompletableFuture<Void> |
AsyncAdmin.appendReplicationPeerTableCFs(String peerId,
Map<TableName,List<String>> tableCfs)
Append the replicable table-cf config of the specified peer
|
void |
Admin.appendReplicationPeerTableCFs(String id,
Map<TableName,List<String>> tableCfs)
Append the replicable table column family config from the specified peer.
|
HTableDescriptor[] |
Admin.getTableDescriptorsByTableName(List<TableName> tableNames)
Deprecated.
since 2.0 version and will be removed in 3.0 version.
use
Admin.listTableDescriptors(List) |
List<TableDescriptor> |
Admin.listTableDescriptors(List<TableName> tableNames)
Get tableDescriptors.
|
CompletableFuture<Void> |
AsyncAdmin.removeReplicationPeerTableCFs(String peerId,
Map<TableName,List<String>> tableCfs)
Remove some table-cfs from config of the specified peer
|
void |
Admin.removeReplicationPeerTableCFs(String id,
Map<TableName,List<String>> tableCfs)
Remove some table-cfs from config of the specified peer.
|
Constructor and Description |
---|
BufferedMutatorParams(TableName tableName) |
SnapshotDescription(String name,
TableName table) |
SnapshotDescription(String name,
TableName table,
SnapshotType type) |
SnapshotDescription(String name,
TableName table,
SnapshotType type,
String owner) |
SnapshotDescription(String name,
TableName table,
SnapshotType type,
String owner,
long creationTime,
int version) |
Modifier and Type | Method and Description |
---|---|
TableName |
TableCFs.getTable() |
Modifier and Type | Method and Description |
---|---|
static Map<TableName,List<String>> |
ReplicationAdmin.parseTableCFsFromConfig(String tableCFsConfig)
Deprecated.
as release of 2.0.0, and it will be removed in 3.0.0
|
Modifier and Type | Method and Description |
---|---|
void |
ReplicationAdmin.disableTableRep(TableName tableName)
Deprecated.
use
Admin.disableTableReplication(TableName)
instead |
void |
ReplicationAdmin.enableTableRep(TableName tableName)
Deprecated.
use
Admin.enableTableReplication(TableName)
instead |
Modifier and Type | Method and Description |
---|---|
void |
ReplicationAdmin.addPeer(String id,
ReplicationPeerConfig peerConfig,
Map<TableName,? extends Collection<String>> tableCfs)
Deprecated.
as release of 2.0.0, and it will be removed in 3.0.0,
use
ReplicationAdmin.addPeer(String, ReplicationPeerConfig) instead. |
void |
ReplicationAdmin.appendPeerTableCFs(String id,
Map<TableName,? extends Collection<String>> tableCfs)
Deprecated.
|
void |
ReplicationAdmin.removePeerTableCFs(String id,
Map<TableName,? extends Collection<String>> tableCfs)
Deprecated.
|
void |
ReplicationAdmin.setPeerTableCFs(String id,
Map<TableName,? extends Collection<String>> tableCfs)
Deprecated.
|
Constructor and Description |
---|
TableCFs(TableName table,
Map<String,Integer> cfs) |
Modifier and Type | Method and Description |
---|---|
TableName |
TableSplit.getTable() |
Modifier and Type | Method and Description |
---|---|
protected void |
TableInputFormatBase.initializeTable(Connection connection,
TableName tableName)
Allows subclasses to initialize the table information.
|
Constructor and Description |
---|
TableSplit(TableName tableName,
byte[] startRow,
byte[] endRow,
String location)
Constructor
|
Modifier and Type | Method and Description |
---|---|
TableName |
TableSplit.getTable()
Returns the table name.
|
Modifier and Type | Method and Description |
---|---|
static void |
TableInputFormat.configureSplitTable(org.apache.hadoop.mapreduce.Job job,
TableName tableName)
Sets split table in map-reduce job.
|
protected void |
TableInputFormatBase.initializeTable(Connection connection,
TableName tableName)
Allows subclasses to initialize the table information.
|
static void |
TableMapReduceUtil.initTableMapperJob(TableName table,
Scan scan,
Class<? extends TableMapper> mapper,
Class<?> outputKeyClass,
Class<?> outputValueClass,
org.apache.hadoop.mapreduce.Job job)
Use this before submitting a TableMap job.
|
Map<LoadIncrementalHFiles.LoadQueueItem,ByteBuffer> |
LoadIncrementalHFiles.run(String dirPath,
Map<byte[],List<org.apache.hadoop.fs.Path>> map,
TableName tableName)
Deprecated.
|
Constructor and Description |
---|
TableSplit(TableName tableName,
byte[] startRow,
byte[] endRow,
String location)
Creates a new instance without a scanner.
|
TableSplit(TableName tableName,
byte[] startRow,
byte[] endRow,
String location,
long length)
Creates a new instance without a scanner.
|
TableSplit(TableName tableName,
Scan scan,
byte[] startRow,
byte[] endRow,
String location)
Creates a new instance while assigning all variables.
|
TableSplit(TableName tableName,
Scan scan,
byte[] startRow,
byte[] endRow,
String location,
long length)
Creates a new instance while assigning all variables.
|
TableSplit(TableName tableName,
Scan scan,
byte[] startRow,
byte[] endRow,
String location,
String encodedRegionName,
long length)
Creates a new instance while assigning all variables.
|
Modifier and Type | Method and Description |
---|---|
TableName |
QuotaSettings.getTableName() |
Modifier and Type | Method and Description |
---|---|
protected static List<QuotaSettings> |
QuotaSettingsFactory.fromThrottle(String userName,
TableName tableName,
String namespace,
org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Throttle throttle) |
static QuotaSettings |
QuotaSettingsFactory.limitTableSpace(TableName tableName,
long sizeLimit,
SpaceViolationPolicy violationPolicy)
Creates a
QuotaSettings object to limit the FileSystem space usage for the given table
to the given size in bytes. |
static QuotaSettings |
QuotaSettingsFactory.removeTableSpaceLimit(TableName tableName)
Creates a
QuotaSettings object to remove the FileSystem space quota for the given
table. |
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.
|
Constructor and Description |
---|
QuotaSettings(String userName,
TableName tableName,
String namespace) |
Modifier and Type | Method and Description |
---|---|
Map<TableName,List<String>> |
ReplicationPeerConfig.getExcludeTableCFsMap() |
Map<TableName,List<String>> |
ReplicationPeerConfig.getTableCFsMap() |
Modifier and Type | Method and Description |
---|---|
boolean |
ReplicationPeerConfig.needToReplicate(TableName table)
Decide whether the table need replicate to the peer cluster
|
Modifier and Type | Method and Description |
---|---|
ReplicationPeerConfig |
ReplicationPeerConfig.setExcludeTableCFsMap(Map<TableName,? extends Collection<String>> tableCFsMap)
Deprecated.
as release of 2.0.0, and it will be removed in 3.0.0. Use
ReplicationPeerConfigBuilder.setExcludeTableCFsMap(Map) instead. |
ReplicationPeerConfigBuilder |
ReplicationPeerConfigBuilder.setExcludeTableCFsMap(Map<TableName,List<String>> tableCFsMap)
Sets the mapping of table name to column families which should not be replicated.
|
ReplicationPeerConfig |
ReplicationPeerConfig.setTableCFsMap(Map<TableName,? extends Collection<String>> tableCFsMap)
Deprecated.
as release of 2.0.0, and it will be removed in 3.0.0. Use
ReplicationPeerConfigBuilder.setTableCFsMap(Map) instead. |
ReplicationPeerConfigBuilder |
ReplicationPeerConfigBuilder.setTableCFsMap(Map<TableName,List<String>> tableCFsMap)
Sets an explicit map of tables and column families in those tables that should be replicated
to the given peer.
|
Modifier and Type | Method and Description |
---|---|
TableName |
RemoteHTable.getName() |
Modifier and Type | Method and Description |
---|---|
SortedSet<TableName> |
RSGroupInfo.getTables()
Get set of tables that are members of the group.
|
Modifier and Type | Method and Description |
---|---|
void |
RSGroupInfo.addTable(TableName table) |
boolean |
RSGroupInfo.containsTable(TableName table) |
boolean |
RSGroupInfo.removeTable(TableName table) |
Modifier and Type | Method and Description |
---|---|
void |
RSGroupInfo.addAllTables(Collection<TableName> arg) |
Constructor and Description |
---|
TablePartiallyOpenException(TableName tableName) |
Copyright © 2007–2019 The Apache Software Foundation. All rights reserved.