Package | Description |
---|---|
org.apache.hadoop.hbase.client |
Provides HBase Client
|
org.apache.hadoop.hbase.mapreduce |
Provides HBase MapReduce
Input/OutputFormats, a table indexing MapReduce job, and utility methods.
|
org.apache.hadoop.hbase.protobuf |
Holds classes generated from protobuf
src/main/protobuf definition files. |
Modifier and Type | Field and Description |
---|---|
protected ScanMetrics |
ScannerCallable.scanMetrics |
protected ScanMetrics |
AbstractClientScanner.scanMetrics |
Modifier and Type | Method and Description |
---|---|
ScanMetrics |
Scan.getScanMetrics() |
ScanMetrics |
AbstractClientScanner.getScanMetrics()
Used internally accumulating metrics on scan.
|
Modifier and Type | Method and Description |
---|---|
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,
org.apache.hadoop.conf.Configuration conf,
RpcRetryingCaller<Result[]> caller) |
Constructor and Description |
---|
ClientSideRegionScanner(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.fs.Path rootDir,
HTableDescriptor htd,
HRegionInfo hri,
Scan scan,
ScanMetrics scanMetrics) |
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) |
ScannerCallable(ClusterConnection connection,
TableName tableName,
Scan scan,
ScanMetrics scanMetrics,
RpcControllerFactory rpcControllerFactory) |
ScannerCallable(ClusterConnection connection,
TableName tableName,
Scan scan,
ScanMetrics scanMetrics,
RpcControllerFactory rpcControllerFactory,
int id) |
Modifier and Type | Method and Description |
---|---|
protected static void |
TableRecordReaderImpl.updateCounters(ScanMetrics scanMetrics,
long numScannerRestarts,
Method getCounter,
org.apache.hadoop.mapreduce.TaskAttemptContext context,
long numStale) |
Modifier and Type | Method and Description |
---|---|
static ScanMetrics |
ProtobufUtil.toScanMetrics(byte[] bytes) |
Modifier and Type | Method and Description |
---|---|
static MapReduceProtos.ScanMetrics |
ProtobufUtil.toScanMetrics(ScanMetrics scanMetrics) |
Copyright © 2007-2016 The Apache Software Foundation. All Rights Reserved.