Package | Description |
---|---|
org.apache.hadoop.hbase | |
org.apache.hadoop.hbase.client |
Provides HBase Client
|
org.apache.hadoop.hbase.client.coprocessor |
Provides client classes for invoking Coprocessor RPC protocols
Overview
Example Usage
|
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.mapreduce.replication | |
org.apache.hadoop.hbase.master | |
org.apache.hadoop.hbase.quotas | |
org.apache.hadoop.hbase.rest |
HBase REST
|
org.apache.hadoop.hbase.rest.client | |
org.apache.hadoop.hbase.security.access | |
org.apache.hadoop.hbase.thrift |
Provides an HBase Thrift
service.
|
org.apache.hadoop.hbase.thrift2 |
Provides an HBase Thrift
service.
|
org.apache.hadoop.hbase.tool | |
org.apache.hadoop.hbase.util |
Modifier and Type | Method and Description |
---|---|
(package private) static Table |
MetaTableAccessor.getMetaHTable(Connection connection)
Callers should call close on the returned
Table instance. |
Modifier and Type | Method and Description |
---|---|
static void |
MetaTableAccessor.addRegionToMeta(Table meta,
HRegionInfo regionInfo)
Adds a hbase:meta row for the specified new region to the given catalog table.
|
static void |
MetaTableAccessor.addRegionToMeta(Table meta,
HRegionInfo regionInfo,
HRegionInfo splitA,
HRegionInfo splitB)
Adds a (single) hbase:meta row for the specified new region and its daughters.
|
private static Result |
MetaTableAccessor.get(Table t,
Get g) |
private static void |
MetaTableAccessor.multiMutate(Table table,
byte[] row,
Mutation... mutations)
Performs an atomic multi-Mutate operation against the given table.
|
private static void |
MetaTableAccessor.put(Table t,
Put p) |
Modifier and Type | Interface and Description |
---|---|
interface |
HTableInterface
Deprecated.
use
Table instead |
Modifier and Type | Class and Description |
---|---|
class |
HTable
An implementation of
Table . |
(package private) class |
HTablePool.PooledHTable
Deprecated.
A proxy class that implements HTableInterface.close method to return the
wrapped table back to the table pool
|
class |
HTableWrapper
A wrapper for HTable.
|
Modifier and Type | Method and Description |
---|---|
Table |
Connection.getTable(TableName tableName)
Retrieve a Table implementation for accessing a table.
|
Table |
Connection.getTable(TableName tableName,
ExecutorService pool)
Retrieve a Table implementation for accessing a table.
|
Modifier and Type | Method and Description |
---|---|
private static Result |
MetaScanner.getClosestRowOrBefore(Table metaTable,
TableName userTableName,
byte[] row,
boolean useMetaReplicas) |
Modifier and Type | Field and Description |
---|---|
private Table |
SecureBulkLoadClient.table |
Modifier and Type | Method and Description |
---|---|
<R,S,P extends com.google.protobuf.Message,Q extends com.google.protobuf.Message,T extends com.google.protobuf.Message> |
AggregationClient.avg(Table table,
ColumnInterpreter<R,S,P,Q,T> ci,
Scan scan)
This is the client side interface/handle for calling the average method for
a given cf-cq combination.
|
private <R,S,P extends com.google.protobuf.Message,Q extends com.google.protobuf.Message,T extends com.google.protobuf.Message> |
AggregationClient.getAvgArgs(Table table,
ColumnInterpreter<R,S,P,Q,T> ci,
Scan scan)
It computes average while fetching sum and row count from all the
corresponding regions.
|
private <R,S,P extends com.google.protobuf.Message,Q extends com.google.protobuf.Message,T extends com.google.protobuf.Message> |
AggregationClient.getMedianArgs(Table table,
ColumnInterpreter<R,S,P,Q,T> ci,
Scan scan)
It helps locate the region with median for a given column whose weight
is specified in an optional column.
|
private <R,S,P extends com.google.protobuf.Message,Q extends com.google.protobuf.Message,T extends com.google.protobuf.Message> |
AggregationClient.getStdArgs(Table table,
ColumnInterpreter<R,S,P,Q,T> ci,
Scan scan)
It computes a global standard deviation for a given column and its value.
|
<R,S,P extends com.google.protobuf.Message,Q extends com.google.protobuf.Message,T extends com.google.protobuf.Message> |
AggregationClient.max(Table table,
ColumnInterpreter<R,S,P,Q,T> ci,
Scan scan)
It gives the maximum value of a column for a given column family for the
given range.
|
<R,S,P extends com.google.protobuf.Message,Q extends com.google.protobuf.Message,T extends com.google.protobuf.Message> |
AggregationClient.median(Table table,
ColumnInterpreter<R,S,P,Q,T> ci,
Scan scan)
This is the client side interface/handler for calling the median method for a
given cf-cq combination.
|
<R,S,P extends com.google.protobuf.Message,Q extends com.google.protobuf.Message,T extends com.google.protobuf.Message> |
AggregationClient.min(Table table,
ColumnInterpreter<R,S,P,Q,T> ci,
Scan scan)
It gives the minimum value of a column for a given column family for the
given range.
|
<R,S,P extends com.google.protobuf.Message,Q extends com.google.protobuf.Message,T extends com.google.protobuf.Message> |
AggregationClient.rowCount(Table table,
ColumnInterpreter<R,S,P,Q,T> ci,
Scan scan)
It gives the row count, by summing up the individual results obtained from
regions.
|
<R,S,P extends com.google.protobuf.Message,Q extends com.google.protobuf.Message,T extends com.google.protobuf.Message> |
AggregationClient.std(Table table,
ColumnInterpreter<R,S,P,Q,T> ci,
Scan scan)
This is the client side interface/handle for calling the std method for a
given cf-cq combination.
|
<R,S,P extends com.google.protobuf.Message,Q extends com.google.protobuf.Message,T extends com.google.protobuf.Message> |
AggregationClient.sum(Table table,
ColumnInterpreter<R,S,P,Q,T> ci,
Scan scan)
It sums up the value returned from various regions.
|
Constructor and Description |
---|
SecureBulkLoadClient(Table table) |
Modifier and Type | Field and Description |
---|---|
private Table |
TableRecordReaderImpl.htable |
Modifier and Type | Method and Description |
---|---|
protected Table |
TableInputFormatBase.getTable()
Allows subclasses to get the
Table . |
Modifier and Type | Method and Description |
---|---|
void |
TableRecordReader.setHTable(Table htable) |
void |
TableRecordReaderImpl.setHTable(Table htable) |
Modifier and Type | Field and Description |
---|---|
private Table |
TableRecordReaderImpl.htable |
(package private) Table |
SyncTable.SyncMapper.sourceTable |
private Table |
TableInputFormatBase.table
The
Table to scan. |
(package private) Table |
SyncTable.SyncMapper.targetTable |
Modifier and Type | Method and Description |
---|---|
protected Table |
TableInputFormatBase.getTable()
Allows subclasses to get the
Table . |
private static Table |
SyncTable.SyncMapper.openTable(Connection connection,
org.apache.hadoop.conf.Configuration conf,
String tableNameConfKey) |
Modifier and Type | Method and Description |
---|---|
protected void |
LoadIncrementalHFiles.bulkLoadPhase(Table table,
Connection conn,
ExecutorService pool,
Deque<LoadIncrementalHFiles.LoadQueueItem> queue,
com.google.common.collect.Multimap<ByteBuffer,LoadIncrementalHFiles.LoadQueueItem> regionGroups)
This takes the LQI's grouped by likely regions and attempts to bulk load
them.
|
(package private) static void |
HFileOutputFormat.configureBlockSize(Table table,
org.apache.hadoop.conf.Configuration conf)
Deprecated.
Serialize column family to block size map to configuration.
|
(package private) static void |
HFileOutputFormat.configureBloomType(Table table,
org.apache.hadoop.conf.Configuration conf)
Deprecated.
Serialize column family to bloom type map to configuration.
|
(package private) static void |
HFileOutputFormat.configureCompression(Table table,
org.apache.hadoop.conf.Configuration conf)
Deprecated.
|
(package private) static void |
HFileOutputFormat.configureDataBlockEncoding(Table table,
org.apache.hadoop.conf.Configuration conf)
Deprecated.
Serialize column family to data block encoding map to configuration.
|
static void |
HFileOutputFormat2.configureIncrementalLoad(org.apache.hadoop.mapreduce.Job job,
Table table,
RegionLocator regionLocator)
Configure a MapReduce Job to perform an incremental load into the given
table.
|
static void |
HFileOutputFormat2.configureIncrementalLoadMap(org.apache.hadoop.mapreduce.Job job,
Table table) |
void |
LoadIncrementalHFiles.doBulkLoad(org.apache.hadoop.fs.Path hfofDir,
Admin admin,
Table table,
RegionLocator regionLocator)
Perform a bulk load of the given directory into the given
pre-existing table.
|
protected List<LoadIncrementalHFiles.LoadQueueItem> |
LoadIncrementalHFiles.groupOrSplit(com.google.common.collect.Multimap<ByteBuffer,LoadIncrementalHFiles.LoadQueueItem> regionGroups,
LoadIncrementalHFiles.LoadQueueItem item,
Table table,
Pair<byte[][],byte[][]> startEndKeys)
Attempt to assign the given load queue item into its target region group.
|
private com.google.common.collect.Multimap<ByteBuffer,LoadIncrementalHFiles.LoadQueueItem> |
LoadIncrementalHFiles.groupOrSplitPhase(Table table,
ExecutorService pool,
Deque<LoadIncrementalHFiles.LoadQueueItem> queue,
Pair<byte[][],byte[][]> startEndKeys) |
void |
TableRecordReader.setHTable(Table htable)
Deprecated.
Use setTable() instead.
|
void |
TableRecordReaderImpl.setHTable(Table htable)
Sets the HBase table.
|
void |
TableRecordReader.setTable(Table table) |
protected List<LoadIncrementalHFiles.LoadQueueItem> |
LoadIncrementalHFiles.splitStoreFile(LoadIncrementalHFiles.LoadQueueItem item,
Table table,
byte[] startKey,
byte[] splitKey) |
Modifier and Type | Field and Description |
---|---|
private Table |
VerifyReplication.Verifier.replicatedTable |
Modifier and Type | Field and Description |
---|---|
private Table |
TableNamespaceManager.nsTable |
Modifier and Type | Method and Description |
---|---|
private Table |
TableNamespaceManager.getNamespaceTable() |
Modifier and Type | Method and Description |
---|---|
private void |
TableNamespaceManager.create(Table table,
NamespaceDescriptor ns) |
private NamespaceDescriptor |
TableNamespaceManager.get(Table table,
String name) |
private void |
TableNamespaceManager.upsert(Table table,
NamespaceDescriptor ns) |
Modifier and Type | Field and Description |
---|---|
private Table |
QuotaRetriever.table |
Modifier and Type | Method and Description |
---|---|
(package private) Table |
RESTServlet.getTable(String tableName)
Caller closes the table afterwards.
|
Modifier and Type | Class and Description |
---|---|
class |
RemoteHTable
HTable interface to remote tables accessed via REST gateway
|
Modifier and Type | Method and Description |
---|---|
private static org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.AccessControlService.BlockingInterface |
AccessControlClient.getAccessControlServiceStub(Table ht) |
Modifier and Type | Method and Description |
---|---|
Table |
ThriftServerRunner.HBaseHandler.getTable(byte[] tableName)
Creates and returns a Table instance from a given table name.
|
Table |
ThriftServerRunner.HBaseHandler.getTable(ByteBuffer tableName) |
Modifier and Type | Method and Description |
---|---|
private void |
ThriftServerRunner.HBaseHandler.closeTable(Table table) |
(package private) byte[][] |
ThriftServerRunner.HBaseHandler.getAllColumns(Table table)
Returns a list of all the column families for a given Table.
|
Modifier and Type | Method and Description |
---|---|
private Table |
ThriftHBaseServiceHandler.getTable(ByteBuffer tableName) |
Modifier and Type | Method and Description |
---|---|
private void |
ThriftHBaseServiceHandler.closeTable(Table table) |
Modifier and Type | Method and Description |
---|---|
private static void |
Canary.sniffRegion(Admin admin,
Canary.Sink sink,
HRegionInfo region,
Table table) |
Modifier and Type | Field and Description |
---|---|
private Table |
HBaseFsck.meta |
private Table |
HMerge.OnlineMerger.table |
Modifier and Type | Method and Description |
---|---|
Table |
ConnectionCache.getTable(String tableName)
Caller closes the table afterwards.
|
Copyright © 2007–2019 The Apache Software Foundation. All rights reserved.