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.rest.client | |
org.apache.hadoop.hbase.snapshot |
Modifier and Type | Field and Description |
---|---|
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()
Get current table name of the region
|
static TableName |
HRegionInfo.getTable(byte[] regionName)
Gets the table name from the specified region name.
|
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 |
---|---|
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)
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.
|
long |
ClusterStatus.getLastMajorCompactionTsForTable(TableName table) |
HTableDescriptor |
HTableDescriptor.setName(TableName name)
Deprecated.
|
Constructor and Description |
---|
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 | Method and Description |
---|---|
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 |
BufferedMutator.getName()
Gets the fully qualified table name instance of the table that this BufferedMutator writes to.
|
TableName |
BufferedMutatorParams.getTableName() |
TableName[] |
HConnection.listTableNames()
Deprecated.
Use
Admin.listTables() instead. |
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)
List all of the names of userspace tables.
|
TableName[] |
Admin.listTableNames(String regex,
boolean includeSysTables)
List all of the names of userspace tables.
|
TableName[] |
Admin.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 |
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 |
Admin.cloneSnapshot(String snapshotName,
TableName tableName)
Create a new table by cloning the snapshot content.
|
void |
Admin.compact(TableName tableName)
Compact a table.
|
void |
Admin.compact(TableName tableName,
byte[] columnFamily)
Compact a column family within a table.
|
void |
Admin.deleteColumn(TableName tableName,
byte[] columnName)
Delete a column from a table.
|
void |
Admin.deleteTable(TableName tableName)
Deletes a table.
|
void |
Admin.disableTable(TableName tableName)
Disable table and wait on completion.
|
void |
Admin.disableTableAsync(TableName tableName)
Starts the disable of a table.
|
void |
Admin.enableTable(TableName tableName)
Enable a table.
|
void |
Admin.enableTableAsync(TableName tableName)
Brings a table on-line (enables it).
|
void |
Admin.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.
|
BufferedMutator |
Connection.getBufferedMutator(TableName tableName)
Retrieve a
BufferedMutator for performing client-side buffering of writes. |
org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse.CompactionState |
Admin.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.
|
boolean |
HConnection.getRegionCachePrefetch(TableName tableName)
Deprecated.
always return false since 0.99
|
HRegionLocation |
HConnection.getRegionLocation(TableName tableName,
byte[] row,
boolean reload)
Deprecated.
internal method, do not use thru HConnection
|
RegionLocator |
HConnection.getRegionLocator(TableName tableName)
Deprecated.
Retrieve a RegionLocator implementation to inspect region information on a table.
|
RegionLocator |
Connection.getRegionLocator(TableName tableName)
Retrieve a RegionLocator implementation to inspect region information on a table.
|
org.apache.hadoop.hbase.client.HTableInterface |
HConnection.getTable(TableName tableName)
Deprecated.
Retrieve an HTableInterface implementation for access to a table.
|
Table |
Connection.getTable(TableName tableName)
Retrieve a Table implementation for accessing a table.
|
org.apache.hadoop.hbase.client.HTableInterface |
HConnection.getTable(TableName tableName,
ExecutorService pool)
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.
|
HTableDescriptor |
Admin.getTableDescriptor(TableName tableName)
Method for getting the tableDescriptor
|
List<HRegionInfo> |
Admin.getTableRegions(TableName tableName)
Get the regions of a given table.
|
boolean |
HConnection.isTableAvailable(TableName tableName)
Deprecated.
|
boolean |
Admin.isTableAvailable(TableName tableName) |
boolean |
HConnection.isTableAvailable(TableName tableName,
byte[][] splitKeys)
Deprecated.
internal method, do not use thru HConnection
|
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 |
HConnection.isTableDisabled(TableName tableName)
Deprecated.
|
boolean |
Admin.isTableDisabled(TableName tableName) |
boolean |
HConnection.isTableEnabled(TableName tableName)
Deprecated.
A table that isTableEnabled == false and isTableDisabled == false
is possible.
|
boolean |
Admin.isTableEnabled(TableName tableName) |
HRegionLocation |
HConnection.locateRegion(TableName tableName,
byte[] row)
Deprecated.
internal method, do not use thru HConnection
|
List<HRegionLocation> |
HConnection.locateRegions(TableName tableName)
Deprecated.
internal method, do not use thru HConnection
|
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 |
Admin.majorCompact(TableName tableName,
byte[] columnFamily)
Major compact a column family within a table.
|
void |
Admin.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 |
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,
org.apache.hadoop.hbase.client.coprocessor.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 |
HConnection.relocateRegion(TableName tableName,
byte[] row)
Deprecated.
internal method, do not use thru HConnection
|
void |
HConnection.setRegionCachePrefetch(TableName tableName,
boolean enable)
Deprecated.
does nothing since 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 |
Admin.snapshot(String snapshotName,
TableName tableName)
Take a snapshot for the given table.
|
void |
Admin.snapshot(String snapshotName,
TableName tableName,
org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Type type)
Create typed snapshot of the table.
|
void |
Admin.split(TableName tableName)
Split a table.
|
void |
Admin.split(TableName tableName,
byte[] splitPoint)
Split a table.
|
boolean |
Admin.tableExists(TableName tableName) |
void |
Admin.truncateTable(TableName tableName,
boolean preserveSplits)
Truncate a table.
|
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.
|
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
|
Constructor and Description |
---|
BufferedMutatorParams(TableName tableName) |
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 | 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.
|
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.
|
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 | Method and Description |
---|---|
TableName |
QuotaSettings.getTableName() |
Modifier and Type | Method and Description |
---|---|
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 |
---|---|
TableName |
RemoteHTable.getName() |
Constructor and Description |
---|
TablePartiallyOpenException(TableName tableName) |
Copyright © 2007–2016 The Apache Software Foundation. All rights reserved.