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.thrift2.client |
Modifier and Type | Field and Description |
---|---|
private ScanMetrics |
AsyncScanSingleRegionRpcRetryingCaller.scanMetrics |
private ScanMetrics |
AsyncTableResultScanner.scanMetrics |
private ScanMetrics |
AsyncClientScanner.scanMetrics |
protected ScanMetrics |
AbstractClientScanner.scanMetrics |
protected ScanMetrics |
ScannerCallable.scanMetrics |
private ScanMetrics |
AsyncRpcRetryingCallerFactory.ScanSingleRegionCallerBuilder.scanMetrics |
Modifier and Type | Method and Description |
---|---|
ScanMetrics |
Scan.getScanMetrics()
Deprecated.
Use
ResultScanner.getScanMetrics() instead. And notice that, please do not
use this method and ResultScanner.getScanMetrics() together, the metrics
will be messed up. |
ScanMetrics |
ResultScanner.getScanMetrics() |
ScanMetrics |
AsyncTableResultScanner.getScanMetrics() |
ScanMetrics |
AbstractClientScanner.getScanMetrics()
Used internally accumulating metrics on scan.
|
Modifier and Type | Method and Description |
---|---|
(package private) static void |
ConnectionUtils.incRegionCountMetrics(ScanMetrics scanMetrics) |
(package private) static void |
ConnectionUtils.incRPCCallsMetrics(ScanMetrics scanMetrics,
boolean isRegionServerRemote) |
(package private) static void |
ConnectionUtils.incRPCRetriesMetrics(ScanMetrics scanMetrics,
boolean isRegionServerRemote) |
AsyncRpcRetryingCallerFactory.ScanSingleRegionCallerBuilder |
AsyncRpcRetryingCallerFactory.ScanSingleRegionCallerBuilder.metrics(ScanMetrics scanMetrics) |
void |
AsyncTableResultScanner.onScanMetricsCreated(ScanMetrics scanMetrics) |
default void |
ScanResultConsumerBase.onScanMetricsCreated(ScanMetrics scanMetrics)
If
scan.isScanMetricsEnabled() returns true, then this method will be called prior to
all other methods in this interface to give you the ScanMetrics instance for this scan
operation. |
(package private) static void |
ConnectionUtils.updateResultsMetrics(ScanMetrics scanMetrics,
Result[] rrs,
boolean isRegionServerRemote) |
(package private) static void |
ConnectionUtils.updateServerSideMetrics(ScanMetrics scanMetrics,
org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ScanResponse response)
Use the scan metrics returned by the server to add to the identically named counters in the
client side metrics.
|
Constructor and Description |
---|
AsyncScanSingleRegionRpcRetryingCaller(org.apache.hbase.thirdparty.io.netty.util.Timer retryTimer,
AsyncConnectionImpl conn,
Scan scan,
ScanMetrics scanMetrics,
long scannerId,
ScanResultCache resultCache,
AdvancedScanResultConsumer consumer,
org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ClientService.Interface stub,
HRegionLocation loc,
boolean isRegionServerRemote,
int priority,
long scannerLeaseTimeoutPeriodNs,
long pauseNs,
long pauseForCQTBENs,
int maxAttempts,
long scanTimeoutNs,
long rpcTimeoutNs,
int startLogErrorsCnt) |
ClientSideRegionScanner(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.fs.Path rootDir,
TableDescriptor htd,
RegionInfo hri,
Scan scan,
ScanMetrics scanMetrics) |
ReversedScannerCallable(ClusterConnection connection,
TableName tableName,
Scan scan,
ScanMetrics scanMetrics,
RpcControllerFactory rpcFactory) |
ReversedScannerCallable(ClusterConnection connection,
TableName tableName,
Scan scan,
ScanMetrics scanMetrics,
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 |
---|---|
ScanMetrics |
ThriftTable.Scanner.getScanMetrics() |
Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.