Class ChangeStreamMetrics

java.lang.Object
org.apache.beam.sdk.io.gcp.bigtable.changestreams.ChangeStreamMetrics
All Implemented Interfaces:
Serializable

@Internal public class ChangeStreamMetrics extends Object implements Serializable
Class to aggregate metrics related functionality.
See Also:
  • Field Details

    • LIST_PARTITIONS_COUNT

      public static final Counter LIST_PARTITIONS_COUNT
      Counter for the total number of partitions identified during the execution of the Connector.
    • PARTITION_SPLIT_COUNT

      public static final Counter PARTITION_SPLIT_COUNT
      Counter for the total number of partition splits / moves identified during the execution of the Connector.
    • PARTITION_MERGE_COUNT

      public static final Counter PARTITION_MERGE_COUNT
      Counter for the total number of partition merges identified during the execution of the Connector.
    • PARTITION_RECONCILED_WITH_TOKEN_COUNT

      public static final Counter PARTITION_RECONCILED_WITH_TOKEN_COUNT
      Counter for the total number of partitions reconciled with continuation tokens.
    • PARTITION_RECONCILED_WITHOUT_TOKEN_COUNT

      public static final Counter PARTITION_RECONCILED_WITHOUT_TOKEN_COUNT
      Counter for the total number of partitions reconciled without continuation tokens.
    • ORPHANED_NEW_PARTITION_CLEANED_COUNT

      public static final Counter ORPHANED_NEW_PARTITION_CLEANED_COUNT
      Counter for the total number of orphaned new partitions cleaned up.
    • HEARTBEAT_COUNT

      public static final Counter HEARTBEAT_COUNT
      Counter for the total number of heartbeats identified during the execution of the Connector.
    • CLOSESTREAM_COUNT

      public static final Counter CLOSESTREAM_COUNT
      Counter for the total number of heartbeats identified during the execution of the Connector.
    • CHANGE_STREAM_MUTATION_USER_COUNT

      public static final Counter CHANGE_STREAM_MUTATION_USER_COUNT
      Counter for the total number of ChangeStreamMutations that are initiated by users (not garbage collection) identified during the execution of the Connector.
    • CHANGE_STREAM_MUTATION_GC_COUNT

      public static final Counter CHANGE_STREAM_MUTATION_GC_COUNT
      Counter for the total number of ChangeStreamMutations that are initiated by garbage collection (not user initiated) identified during the execution of the Connector.
    • PROCESSING_DELAY_FROM_COMMIT_TIMESTAMP

      public static final Distribution PROCESSING_DELAY_FROM_COMMIT_TIMESTAMP
      Distribution for measuring processing delay from commit timestamp.
    • PARTITION_STREAM_COUNT

      public static final Counter PARTITION_STREAM_COUNT
      Counter for the total number of active partitions being streamed.
  • Constructor Details

    • ChangeStreamMetrics

      public ChangeStreamMetrics()
  • Method Details

    • incListPartitionsCount

      public void incListPartitionsCount()
      Increments the LIST_PARTITIONS_COUNT by 1 if the metric is enabled.
    • incPartitionSplitCount

      public void incPartitionSplitCount()
      Increments the PARTITION_SPLIT_COUNT by 1 if the metric is enabled.
    • incPartitionMergeCount

      public void incPartitionMergeCount()
      Increments the PARTITION_MERGE_COUNT by 1 if the metric is enabled.
    • incPartitionReconciledWithTokenCount

      public void incPartitionReconciledWithTokenCount()
    • incPartitionReconciledWithoutTokenCount

      public void incPartitionReconciledWithoutTokenCount()
    • incOrphanedNewPartitionCleanedCount

      public void incOrphanedNewPartitionCleanedCount()
    • incHeartbeatCount

      public void incHeartbeatCount()
      Increments the HEARTBEAT_COUNT by 1 if the metric is enabled.
    • incClosestreamCount

      public void incClosestreamCount()
      Increments the CLOSESTREAM_COUNT by 1 if the metric is enabled.
    • incChangeStreamMutationUserCounter

      public void incChangeStreamMutationUserCounter()
      Increments the CHANGE_STREAM_MUTATION_USER_COUNT by 1 if the metric is enabled.
    • incChangeStreamMutationGcCounter

      public void incChangeStreamMutationGcCounter()
      Increments the CHANGE_STREAM_MUTATION_GC_COUNT by 1 if the metric is enabled.
    • incPartitionStreamCount

      public void incPartitionStreamCount()
      Increments the PARTITION_STREAM_COUNT by 1.
    • decPartitionStreamCount

      public void decPartitionStreamCount()
      Decrements the PARTITION_STREAM_COUNT by 1.
    • updateProcessingDelayFromCommitTimestamp

      public void updateProcessingDelayFromCommitTimestamp(long durationInMilli)
      Adds measurement of an instance for the PROCESSING_DELAY_FROM_COMMIT_TIMESTAMP.