Package org.apache.cassandra.metrics
-
Class Summary Class Description BatchMetrics BufferPoolMetrics CacheMetrics Metrics forICache
.CASClientRequestMetrics CASClientWriteRequestMetrics Metrics for tracking information about CAS write requests.CassandraMetricsRegistry Makes integrating 3.0 metrics API with 2.0.CassandraMetricsRegistry.MetricName A value class encapsulating a metric's owning class and name.ChunkCacheMetrics Metrics forICache
.CIDRAuthorizerMetrics Captures metrics of CIDR authorizerClearableHistogram Adds ability to reset a histogramClientMessageSizeMetrics Metrics to track the size of incoming and outgoing bytes at Cassandra server.ClientMetrics ClientRangeRequestMetrics Metrics for tracking information about range requests.ClientRequestMetrics ClientRequestSizeMetrics ClientRequestsMetricsHolder ClientWriteRequestMetrics Metrics for tracking information about write requests.CommitLogMetrics Metrics for commit logCompactionMetrics Metrics for compaction.CQLMetrics DecayingEstimatedHistogramReservoir A decaying histogram reservoir where values collected during each minute will be twice as significant as the values collected in the previous minute.DefaultNameFactory MetricNameFactory that generates default MetricName of metrics.DenylistMetrics DroppedMessageMetrics Metrics for dropped messages by verb.FrequencySampler<T> Find the most frequent sample.HintedHandoffMetrics Metrics forHintsService
.HintedHandoffMetrics.DifferencingCounter HintsServiceMetrics Metrics forHintsService
.InternodeInboundMetrics Metrics for internode connections.InternodeOutboundMetrics Metrics for internode connections.KeyspaceMetrics Metrics forColumnFamilyStore
.LatencyMetrics Metrics about latenciesMaxSampler<T> Note:Sampler.samplerExecutor
is single threaded but we still need to synchronize as we have access from both internal and the external JMX context that can cause races.MessagingMetrics Metrics for messagesMessagingMetrics.DCLatencyRecorder MinMaxAvgMetric PaxosMetrics ReadRepairMetrics Metrics related to Read Repair.RepairMetrics RestorableMeter A meter metric which measures mean throughput as well as fifteen-minute and two-hour exponentially-weighted moving average throughputs.Sampler<T> Sampler.Sample<S> Represents the ranked items collected during a sample periodSamplingManager SamplingManager.ResultBuilder ScalingReservoir A reservoir that scales the values before updating.SnapshottingTimer StorageMetrics Metrics related to Storage.StreamingMetrics Metrics for streaming.TableMetrics Metrics forColumnFamilyStore
.TableMetrics.TableHistogram TableMetrics.TableMeter TableMetrics.TableTimer TableMetrics.TableTimer.Context ThreadPoolMetrics Metrics forThreadPoolExecutor
.TopPartitionTracker Tracks top partitions, currently by size and by tombstone count Collects during full and preview (-vd) repair since then we read the full partition Note that since we can run sub range repair there might be windows where the top partitions are not correct - for example, assume we track the top 2 partitions for this node: tokens with size: (a, 100); (b, 40); (c, 10); (d, 100); (e, 50); (f, 10) - top2: a, d now a is deleted and we run a repair for keys [a, c] - top2: b, d and when we repair [d, f] - top2: d, eTopPartitionTracker.Collector TopPartitionTracker.StoredTopPartitions TopPartitionTracker.TombstoneCounter TopPartitionTracker.TopHolder TopPartitionTracker.TopPartition TrieMemtableMetricsView ViewWriteMetrics -
Enum Summary Enum Description Sampler.SamplerType