Uses of Class
org.apache.hadoop.hbase.client.metrics.ScanMetrics
Packages that use ScanMetrics
Package
Description
Provides HBase Client
Provides HBase MapReduce
Input/OutputFormats, a table indexing MapReduce job, and utility methods.
-
Uses of ScanMetrics in org.apache.hadoop.hbase.client
Fields in org.apache.hadoop.hbase.client declared as ScanMetricsModifier and TypeFieldDescriptionprotected ScanMetricsAbstractClientScanner.scanMetricsprivate final ScanMetricsAsyncClientScanner.scanMetricsprivate ScanMetricsAsyncRpcRetryingCallerFactory.ScanSingleRegionCallerBuilder.scanMetricsprivate final ScanMetricsAsyncScanSingleRegionRpcRetryingCaller.scanMetricsprivate ScanMetricsAsyncTableResultScanner.scanMetricsprotected ScanMetricsScannerCallable.scanMetricsMethods in org.apache.hadoop.hbase.client that return ScanMetricsModifier and TypeMethodDescriptionAbstractClientScanner.getScanMetrics()Used internally accumulating metrics on scan.AsyncTableResultScanner.getScanMetrics()ResultScanner.getScanMetrics()Returns the scan metrics, ornullif we do not enable metrics.Scan.getScanMetrics()Deprecated.Methods in org.apache.hadoop.hbase.client with parameters of type ScanMetricsModifier and TypeMethodDescription(package private) static voidConnectionUtils.incRegionCountMetrics(ScanMetrics scanMetrics) (package private) static voidConnectionUtils.incRPCCallsMetrics(ScanMetrics scanMetrics, boolean isRegionServerRemote) (package private) static voidConnectionUtils.incRPCRetriesMetrics(ScanMetrics scanMetrics, boolean isRegionServerRemote) AsyncRpcRetryingCallerFactory.ScanSingleRegionCallerBuilder.metrics(ScanMetrics scanMetrics) voidAsyncTableResultScanner.onScanMetricsCreated(ScanMetrics scanMetrics) default voidScanResultConsumerBase.onScanMetricsCreated(ScanMetrics scanMetrics) Ifscan.isScanMetricsEnabled()returns true, then this method will be called prior to all other methods in this interface to give you theScanMetricsinstance for this scan operation.(package private) static voidConnectionUtils.updateResultsMetrics(ScanMetrics scanMetrics, Result[] rrs, boolean isRegionServerRemote) (package private) static voidConnectionUtils.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.Constructors in org.apache.hadoop.hbase.client with parameters of type ScanMetricsModifierConstructorDescriptionAsyncScanSingleRegionRpcRetryingCaller(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 pauseNsForServerOverloaded, int maxAttempts, long scanTimeoutNs, long rpcTimeoutNs, int startLogErrorsCnt, Map<String, byte[]> requestAttributes) 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, int replicaId, Map<String, byte[]> requestAttributes) ScannerCallable(ClusterConnection connection, TableName tableName, Scan scan, ScanMetrics scanMetrics, RpcControllerFactory rpcControllerFactory, int id, Map<String, byte[]> requestAttributes) -
Uses of ScanMetrics in org.apache.hadoop.hbase.mapreduce
Methods in org.apache.hadoop.hbase.mapreduce with parameters of type ScanMetricsModifier and TypeMethodDescriptionprotected static voidTableRecordReaderImpl.updateCounters(ScanMetrics scanMetrics, long numScannerRestarts, Method getCounter, org.apache.hadoop.mapreduce.TaskAttemptContext context, long numStale) Deprecated.since 2.4.0 and 2.3.2, will be removed in 4.0.0 UseTableRecordReaderImpl.updateCounters(ScanMetrics, long, TaskAttemptContext, long)instead.protected static voidTableRecordReaderImpl.updateCounters(ScanMetrics scanMetrics, long numScannerRestarts, org.apache.hadoop.mapreduce.TaskAttemptContext context, long numStale) -
Uses of ScanMetrics in org.apache.hadoop.hbase.master.region
Methods in org.apache.hadoop.hbase.master.region that return ScanMetrics -
Uses of ScanMetrics in org.apache.hadoop.hbase.thrift2.client
Methods in org.apache.hadoop.hbase.thrift2.client that return ScanMetrics
ResultScanner.getScanMetrics()instead.