Uses of Class
org.apache.hadoop.metrics2.lib.MutableFastCounter
Package
Description
Tools to help define network clients and servers.
Metrics API for HBase.
HBase REST
Provides an HBase Thrift
service.
-
Uses of MutableFastCounter in org.apache.hadoop.hbase.io
Modifier and TypeFieldDescriptionprivate final MutableFastCounter
MetricsIOSourceImpl.fsSlowReads
-
Uses of MutableFastCounter in org.apache.hadoop.hbase.ipc
Modifier and TypeFieldDescriptionprivate final MutableFastCounter
MetricsHBaseServerSourceImpl.authenticationFailures
private final MutableFastCounter
MetricsHBaseServerSourceImpl.authenticationFallbacks
private final MutableFastCounter
MetricsHBaseServerSourceImpl.authenticationSuccesses
private final MutableFastCounter
MetricsHBaseServerSourceImpl.authorizationFailures
private final MutableFastCounter
MetricsHBaseServerSourceImpl.authorizationSuccesses
private final MutableFastCounter
MetricsHBaseServerSourceImpl.maxOutboundBytesExceeded
private final MutableFastCounter
MetricsHBaseServerSourceImpl.receivedBytes
private final MutableFastCounter
MetricsHBaseServerSourceImpl.sentBytes
-
Uses of MutableFastCounter in org.apache.hadoop.hbase.master
Modifier and TypeFieldDescriptionprivate MutableFastCounter
MetricsMasterSourceImpl.clusterReadRequestsCounter
private MutableFastCounter
MetricsMasterSourceImpl.clusterRequestsCounter
private MutableFastCounter
MetricsMasterSourceImpl.clusterWriteRequestsCounter
private MutableFastCounter
MetricsAssignmentManagerSourceImpl.operationCounter
-
Uses of MutableFastCounter in org.apache.hadoop.hbase.master.balancer
-
Uses of MutableFastCounter in org.apache.hadoop.hbase.metrics
Modifier and TypeFieldDescriptionprotected MutableFastCounter
ExceptionTrackingSourceImpl.exceptionRequestTooBig
protected MutableFastCounter
ExceptionTrackingSourceImpl.exceptions
protected MutableFastCounter
ExceptionTrackingSourceImpl.exceptionsBusy
protected MutableFastCounter
ExceptionTrackingSourceImpl.exceptionsCallDropped
protected MutableFastCounter
ExceptionTrackingSourceImpl.exceptionsCallQueueTooBig
protected MutableFastCounter
ExceptionTrackingSourceImpl.exceptionsCallTimedOut
protected MutableFastCounter
ExceptionTrackingSourceImpl.exceptionsMoved
protected MutableFastCounter
ExceptionTrackingSourceImpl.exceptionsMultiTooLarge
protected MutableFastCounter
ExceptionTrackingSourceImpl.exceptionsNSRE
protected MutableFastCounter
ExceptionTrackingSourceImpl.exceptionsOOO
protected MutableFastCounter
ExceptionTrackingSourceImpl.exceptionsQuotaExceeded
protected MutableFastCounter
ExceptionTrackingSourceImpl.exceptionsRpcThrottling
protected MutableFastCounter
ExceptionTrackingSourceImpl.exceptionsSanity
protected MutableFastCounter
ExceptionTrackingSourceImpl.exceptionsScannerReset
protected MutableFastCounter
ExceptionTrackingSourceImpl.exceptionsUnknown
protected MutableFastCounter
ExceptionTrackingSourceImpl.otherExceptions
-
Uses of MutableFastCounter in org.apache.hadoop.hbase.namequeues
Modifier and TypeFieldDescriptionprivate final MutableFastCounter
MetricsWALEventTrackerSourceImpl.numFailedPutsCount
private final MutableFastCounter
MetricsWALEventTrackerSourceImpl.numRecordsFailedPutsCount
-
Uses of MutableFastCounter in org.apache.hadoop.hbase.regionserver
Modifier and TypeFieldDescriptionprivate final MutableFastCounter
MetricsHeapMemoryManagerSourceImpl.aboveHeapOccupancyLowWatermarkCounter
private final MutableFastCounter
MetricsRegionServerSourceImpl.blockBytesScannedCount
private MutableFastCounter
MetricsUserSourceImpl.blockBytesScannedCount
private final MutableFastCounter
MetricsRegionServerSourceImpl.compactedInputBytes
private MutableFastCounter
MetricsTableSourceImpl.compactedInputBytes
private final MutableFastCounter
MetricsRegionServerSourceImpl.compactedOutputBytes
private MutableFastCounter
MetricsTableSourceImpl.compactedOutputBytes
private final MutableFastCounter
MetricsHeapMemoryManagerSourceImpl.doNothingCounter
private final MutableFastCounter
MetricsRegionServerSourceImpl.flushedMemstoreBytes
private MutableFastCounter
MetricsTableSourceImpl.flushedMemstoreBytes
private final MutableFastCounter
MetricsRegionServerSourceImpl.flushedOutputBytes
private MutableFastCounter
MetricsTableSourceImpl.flushedOutputBytes
private final MutableFastCounter
MetricsRegionServerSourceImpl.infoPauseThresholdExceeded
private final MutableFastCounter
MetricsRegionServerSourceImpl.majorCompactedInputBytes
private MutableFastCounter
MetricsTableSourceImpl.majorCompactedInputBytes
private final MutableFastCounter
MetricsRegionServerSourceImpl.majorCompactedOutputBytes
private MutableFastCounter
MetricsTableSourceImpl.majorCompactedOutputBytes
private final MutableFastCounter
MetricsRegionSourceImpl.regionAppend
private final MutableFastCounter
MetricsRegionSourceImpl.regionDelete
private final MutableFastCounter
MetricsRegionSourceImpl.regionGet
private final MutableFastCounter
MetricsRegionSourceImpl.regionIncrement
private final MutableFastCounter
MetricsRegionSourceImpl.regionPut
private final MutableFastCounter
MetricsRegionSourceImpl.regionScan
private final MutableFastCounter
MetricsRegionServerSourceImpl.scannerLeaseExpiredCount
private final MutableFastCounter
MetricsRegionServerSourceImpl.slowAppend
private final MutableFastCounter
MetricsRegionServerSourceImpl.slowDelete
private final MutableFastCounter
MetricsRegionServerSourceImpl.slowGet
private final MutableFastCounter
MetricsRegionServerSourceImpl.slowIncrement
private final MutableFastCounter
MetricsRegionServerSourceImpl.slowPut
private final MutableFastCounter
MetricsRegionServerSourceImpl.splitRequest
private MutableFastCounter
MetricsTableSourceImpl.splitRequest
private final MutableFastCounter
MetricsRegionServerSourceImpl.splitSuccess
private MutableFastCounter
MetricsTableSourceImpl.splitSuccess
private final MutableFastCounter
MetricsRegionServerSourceImpl.warnPauseThresholdExceeded
-
Uses of MutableFastCounter in org.apache.hadoop.hbase.regionserver.wal
Modifier and TypeFieldDescriptionprivate final MutableFastCounter
MetricsWALSourceImpl.appendCount
private final MutableFastCounter
MetricsWALSourceImpl.errorRollRequested
private final MutableFastCounter
MetricsWALSourceImpl.logRollRequested
private final MutableFastCounter
MetricsWALSourceImpl.lowReplicationRollRequested
private final MutableFastCounter
MetricsWALSourceImpl.sizeRollRequested
private final MutableFastCounter
MetricsWALSourceImpl.slowAppendCount
private final MutableFastCounter
MetricsWALSourceImpl.slowSyncRollRequested
private final MutableFastCounter
MetricsWALSourceImpl.successfulLogRolls
private final MutableFastCounter
MetricsWALSourceImpl.writtenBytes
Modifier and TypeFieldDescriptionprivate final ConcurrentMap<TableName,
MutableFastCounter> MetricsWALSourceImpl.perTableAppendCount
private final ConcurrentMap<TableName,
MutableFastCounter> MetricsWALSourceImpl.perTableAppendSize
-
Uses of MutableFastCounter in org.apache.hadoop.hbase.replication.regionserver
Modifier and TypeFieldDescriptionprivate final MutableFastCounter
MetricsReplicationSinkSourceImpl.batchesCounter
private final MutableFastCounter
MetricsReplicationGlobalSourceSourceImpl.completedRecoveryQueue
private final MutableFastCounter
MetricsReplicationSourceSourceImpl.completedRecoveryQueue
private final MutableFastCounter
MetricsReplicationGlobalSourceSourceImpl.completedWAL
private final MutableFastCounter
MetricsReplicationSourceSourceImpl.completedWAL
private final MutableFastCounter
MetricsReplicationGlobalSourceSourceImpl.failedBatchesCounter
private final MutableFastCounter
MetricsReplicationSinkSourceImpl.failedBatchesCounter
private final MutableFastCounter
MetricsReplicationSourceSourceImpl.failedBatchesCounter
private final MutableFastCounter
MetricsReplicationGlobalSourceSourceImpl.failedRecoveryQueue
private final MutableFastCounter
MetricsReplicationSinkSourceImpl.hfilesCounter
private final MutableFastCounter
MetricsReplicationGlobalSourceSourceImpl.logReadInBytesCounter
private final MutableFastCounter
MetricsReplicationSourceSourceImpl.logReadInBytesCounter
private final MutableFastCounter
MetricsReplicationGlobalSourceSourceImpl.logReadInEditsCounter
private final MutableFastCounter
MetricsReplicationSourceSourceImpl.logReadInEditsCounter
private final MutableFastCounter
MetricsReplicationSinkSourceImpl.opsCounter
private final MutableFastCounter
MetricsReplicationGlobalSourceSourceImpl.repeatedFileBytes
private final MutableFastCounter
MetricsReplicationSourceSourceImpl.repeatedFileBytes
private final MutableFastCounter
MetricsReplicationGlobalSourceSourceImpl.restartWALReading
private final MutableFastCounter
MetricsReplicationSourceSourceImpl.restartWALReading
private final MutableFastCounter
MetricsReplicationGlobalSourceSourceImpl.shippedBatchesCounter
private final MutableFastCounter
MetricsReplicationSourceSourceImpl.shippedBatchesCounter
private final MutableFastCounter
MetricsReplicationGlobalSourceSourceImpl.shippedBytesCounter
private final MutableFastCounter
MetricsReplicationSourceSourceImpl.shippedBytesCounter
private final MutableFastCounter
MetricsReplicationTableSourceImpl.shippedBytesCounter
private final MutableFastCounter
MetricsReplicationGlobalSourceSourceImpl.shippedHFilesCounter
private final MutableFastCounter
MetricsReplicationSourceSourceImpl.shippedHFilesCounter
private final MutableFastCounter
MetricsReplicationGlobalSourceSourceImpl.shippedOpsCounter
private final MutableFastCounter
MetricsReplicationSourceSourceImpl.shippedOpsCounter
private final MutableFastCounter
MetricsReplicationGlobalSourceSourceImpl.uncleanlyClosedSkippedBytes
private final MutableFastCounter
MetricsReplicationSourceSourceImpl.uncleanlyClosedSkippedBytes
private final MutableFastCounter
MetricsReplicationGlobalSourceSourceImpl.uncleanlyClosedWAL
private final MutableFastCounter
MetricsReplicationSourceSourceImpl.uncleanlyClosedWAL
private final MutableFastCounter
MetricsReplicationGlobalSourceSourceImpl.unknownFileLengthForClosedWAL
private final MutableFastCounter
MetricsReplicationSourceSourceImpl.unknownFileLengthForClosedWAL
private final MutableFastCounter
MetricsReplicationGlobalSourceSourceImpl.walEditsFilteredCounter
private final MutableFastCounter
MetricsReplicationSourceSourceImpl.walEditsFilteredCounter
-
Uses of MutableFastCounter in org.apache.hadoop.hbase.rest
Modifier and TypeFieldDescriptionprivate MutableFastCounter
MetricsRESTSourceImpl.fAppend
private MutableFastCounter
MetricsRESTSourceImpl.fDel
private MutableFastCounter
MetricsRESTSourceImpl.fGet
private MutableFastCounter
MetricsRESTSourceImpl.fIncrement
private MutableFastCounter
MetricsRESTSourceImpl.fPut
private MutableFastCounter
MetricsRESTSourceImpl.fScan
private final MutableFastCounter
MetricsRESTSourceImpl.infoPauseThresholdExceeded
private MutableFastCounter
MetricsRESTSourceImpl.request
private MutableFastCounter
MetricsRESTSourceImpl.sucAppend
private MutableFastCounter
MetricsRESTSourceImpl.sucDel
private MutableFastCounter
MetricsRESTSourceImpl.sucGet
private MutableFastCounter
MetricsRESTSourceImpl.sucIncrement
private MutableFastCounter
MetricsRESTSourceImpl.sucPut
private MutableFastCounter
MetricsRESTSourceImpl.sucScan
private final MutableFastCounter
MetricsRESTSourceImpl.warnPauseThresholdExceeded
-
Uses of MutableFastCounter in org.apache.hadoop.hbase.thrift
Modifier and TypeFieldDescriptionprivate final MutableFastCounter
MetricsThriftServerSourceImpl.infoPauseThresholdExceeded
private final MutableFastCounter
MetricsThriftServerSourceImpl.warnPauseThresholdExceeded
-
Uses of MutableFastCounter in org.apache.hadoop.metrics2.lib
Modifier and TypeMethodDescriptionDynamicMetricsRegistry.getCounter
(String counterName, long potentialStartingValue) Get a MetricMutableCounterLong from the storage.DynamicMetricsRegistry.newCounter
(String name, String desc, long iVal) Create a mutable long integer counterDynamicMetricsRegistry.newCounter
(org.apache.hadoop.metrics2.MetricsInfo info, long iVal) Create a mutable long integer counter