Redpanda

Supported OS Linux Mac OS Windows

Intégration1.1.0

Présentation

Redpanda est une plateforme de diffusion compatible avec l’API Kafka permettant de gérer des workloads essentiels.

Associez Datadog à Redpanda pour consulter vos métriques clés et ajouter des groupes de métriques supplémentaires basés sur des besoins spécifiques des utilisateurs.

Configuration

Installation

  1. Téléchargez et lancez l’Agent Datadog.
  2. Installez manuellement l’intégration Redpanda. Consultez la section Utiliser les intégrations de la communauté pour découvrir plus de détails en fonction de votre environnement.

Host

Pour configurer ce check pour un Agent en cours d’exécution sur un host, exécutez la commande datadog-agent integration install -t datadog-redpanda==<VERSION_INTÉGRATION>.

Environnement conteneurisé

Pour utiliser au mieux cette intégration avec l’Agent Docker dans des environnements conteneurisés, générez une image de l’Agent avec l’intégration Redpanda installée.

Pour générer une image à jour de l’Agent, procédez comme suit :

  1. Utilisez le Dockerfile suivant :
FROM gcr.io/datadoghq/agent:latest

ARG INTEGRATION_VERSION=1.0.0

RUN agent integration install -r -t datadog-redpanda==${INTEGRATION_VERSION}
  1. Créez l’image et envoyez-la vers votre registre Docker privé.

  2. Mettez à niveau l’image du conteneur de l’Agent Datadog. Si vous utilisez un chart Helm, modifiez la section agents.image du fichier values.yaml afin de remplacer l’image de l’Agent par défaut :

agents:
  enabled: true
  image:
    tag: <NOUVEAU_TAG>
    repository: <VOTRE_RÉFÉRENTIEL_PRIVÉ>/<NOM_AGENT>
  1. Utilisez le nouveau fichier values.yaml pour mettre à niveau l’Agent :
helm upgrade -f values.yaml <NOM_VERSION> datadog/datadog

Configuration

Host

Collecte de métriques

Pour commencer à recueillir vos données de performance Redpanda, procédez comme suit :

  1. Modifiez le fichier redpanda.d/conf.yaml dans le dossier conf.d/ à la racine du répertoire de configuration de votre Agent. Consultez le fichier d’exemple redpanda.d/conf.yaml.example pour découvrir toutes les options de configuration disponibles.

  2. Redémarrez l’Agent.

Collecte de logs

Par défaut, la collecte de logs est désactivée dans l’Agent Datadog. Elle est disponible à partir de la version 6.0 de l’Agent.

  1. Pour activer les logs, ajoutez ce qui suit à votre fichier datadog.yaml :

    logs_enabled: true
    
  2. Ajoutez les lignes suivantes à votre fichier redpanda.d/conf.yaml pour commencer à recueillir vos logs Redpanda :

     logs:
     - type: journald
       source: redpanda
    

Environnement conteneurisé

Collecte de métriques

Dans les environnements conteneurisés, Autodiscovery est configuré par défaut après l’intégration du check Redpanda à l’image de l’Agent Datadog.

Les métriques sont automatiquement recueillies sur le serveur de Datadog. Pour en savoir plus, consultez la section relative aux modèles d’intégration Autodiscovery.

Collecte de logs

Par défaut, la collecte de logs est désactivée dans l’Agent Datadog. Elle est disponible à partir de la version 6.0 de l’Agent.

Pour activer les logs, consultez la section relative à la collecte de logs Kubernetes.

ParamètreValeur
<CONFIG_LOG>{"source": "redpanda", "service": "redpanda_cluster"}

Validation

Lancez la sous-commande status de l’Agent et cherchez redpanda dans la section Checks.

Données collectées

Métriques

redpanda.application.build
(gauge)
Build information for Redpanda, including the revision and version details
redpanda.application.fips_mode
(gauge)
Indicates whether Redpanda is running in FIPS mode. Possible values: 0 = disabled, 1 = permissive, 2 = enabled
redpanda.application.uptime
(gauge)
Redpanda uptime in seconds
Shown as second
redpanda.authorization.result
(count)
Cumulative count of authorization results, categorized by result type.
redpanda.cloud.client_backoff
(count)
Total number of requests that backed off
Shown as operation
redpanda.cloud.client_pool_utilization
(gauge)
Current utilization of the object storage client pool, as a percentage
redpanda.cloud.client_download_backoff
(count)
Total number of download requests that backed off
Shown as operation
redpanda.cloud.client_downloads
(count)
Total number of requests that downloaded an object from cloud storage
redpanda.cloud.client_lease_duration
(gauge)
Lease duration histogram.
redpanda.cloud.client_not_found
(count)
Total number of requests for which the object was not found
redpanda.cloud.client_num_borrows
(count)
Count of instances where a shard borrowed an object storage client from another shard.
redpanda.cloud.client_upload_backoff
(count)
Total number of upload requests that backed off
redpanda.cloud.client_uploads
(count)
Total number of requests that uploaded an object to cloud storage
redpanda.cloud.storage.active_segments
(gauge)
Number of remote log segments that are currently hydrated and available for read operations
redpanda.cloud.storage.cache_op_hit
(count)
Number of get requests for objects that are already in cache.
redpanda.cloud.storage.op_in_progress_files
(gauge)
Number of files currently being written to the cache.
redpanda.cloud.storage.cache_op_miss
(count)
Number of get requests that are not satisfied from the cache.
redpanda.cloud.storage.op_put
(count)
Number of objects written into cache.
Shown as operation
redpanda.cloud.storage.cache_space_files
(gauge)
Current number of objects stored in the cache.
redpanda.cloud.storage.cache_space_hwm_files
(gauge)
High watermark for the number of objects stored in the cache.
redpanda.cloud.storage.cache_space_hwm_size_bytes
(gauge)
High watermark for the total size (in bytes) of cached objects.
redpanda.cloud.storage.cache_space_size_bytes
(gauge)
Sum of size of cached objects.
Shown as byte
redpanda.cloud.storage.cache_space_tracker_size
(gauge)
Current count of entries in the cache access tracker.
redpanda.cloud.storage.cache_space_tracker_syncs
(count)
Number of times the cache access tracker was synchronized with disk data.
Shown as operation
redpanda.cloud.storage_cache_trim_carryover_trims
(count)
Count of times the cache trim operation was invoked using a carryover strategy.
redpanda.cloud.storage_cache_trim_exhaustive_trims
(count)
Count of instances where a fast cache trim was insufficient and an exhaustive trim was required.
redpanda.cloud.storage_cache_trim_failed_trims
(count)
Count of cache trim operations that failed to free the expected amount of space, possibly indicating a bug or misconfiguration.
redpanda.cloud.storage_cache_trim_fast_trims
(count)
Count of successful fast cache trim operations.
redpanda.cloud.storage_cache_trim_in_mem_trims
(count)
Count of cache trim operations performed using the in-memory access tracker.
redpanda.cloud.storage_cloud_log_size
(gauge)
Total size (in bytes) of user-visible log data stored in Tiered Storage. This value increases with every segment offload and decreases when segments are deleted due to retention or compaction.
redpanda.cloud.storage.deleted_segments
(count)
Number of segments that have been deleted from S3 for the topic. This may grow due to retention or non compacted segments being replaced with their compacted equivalent.
redpanda.cloud.storage.errors
(count)
Cumulative count of errors encountered during object storage operations, segmented by direction.
Shown as error
redpanda.cloud.storage.housekeeping.drains
(gauge)
Number of times the object storage upload housekeeping queue was fully drained.
redpanda.cloud.storage.housekeeping.jobs_completed
(count)
Number of executed housekeeping jobs
redpanda.cloud.storage.housekeeping.jobs_failed
(count)
Number of failed housekeeping jobs
Shown as error
redpanda.cloud.storage.housekeeping.jobs_skipped
(count)
Number of object storage housekeeping jobs that were skipped during execution.
redpanda.cloud.storage.housekeeping.pauses
(gauge)
Number of times object storage upload housekeeping was paused.
redpanda.cloud.storage_housekeeping_requests_throttled_average_rate
(gauge)
Average rate (per shard) of requests that were throttled during object storage operations.
redpanda.cloud.storage.housekeeping.resumes
(gauge)
Number of times when object storage upload housekeeping resumed after a pause.
redpanda.cloud.storage.housekeeping.rounds
(count)
Number of upload housekeeping rounds
redpanda.cloud.storage.jobs.cloud_segment_reuploads
(gauge)
Number of segment reuploads from cloud storage sources (cloud storage cache or direct download from cloud storage)
redpanda.cloud.storage.jobs.local_segment_reuploads
(gauge)
Number of segment reuploads from local data directory
redpanda.cloud.storage.jobs.manifest_reuploads
(gauge)
Number of manifest reuploads performed by all housekeeping jobs
redpanda.cloud.storage.jobs.metadata_syncs
(gauge)
Number of archival configuration updates performed by all housekeeping jobs
redpanda.cloud.storage.jobs.segment_deletions
(gauge)
Number of segments deleted by all housekeeping jobs
redpanda.cloud.storage_limits_downloads_throttled_sum
(count)
Total cumulative time (in milliseconds) during which downloads were throttled.
redpanda.cloud.storage_partition_manifest_uploads
(count)
Total number of successful partition manifest uploads to object storage.
redpanda.cloud.storage_partition_readers
(gauge)
Number of active partition reader instances (fetch/timequery operations) reading from Tiered Storage.
redpanda.cloud.storage_partition_readers_delayed
(count)
Count of partition read operations delayed due to reaching the reader limit, suggesting potential saturation of Tiered Storage reads.
redpanda.cloud.storage_paused_archivers
(gauge)
Number of paused archivers.
redpanda.cloud.storage.readers
(gauge)
Total number of segments pending deletion from the cloud for the topic
redpanda.cloud.storage_segment_index_uploads
(count)
Total number of successful segment index uploads to object storage.
redpanda.cloud.storage_segment_materializations_delayed
(count)
Count of segment materialization operations that were delayed because of reader limit constraints.
redpanda.cloud.storage_segment_readers_delayed
(count)
Count of segment reader operations delayed due to reaching the reader limit. This indicates a cluster is saturated with Tiered Storage reads.
redpanda.cloud.storage_segment_uploads
(count)
Total number of successful data segment uploads to object storage.
redpanda.cloud.storage.segments
(gauge)
Total number of uploaded bytes for the topic
redpanda.cloud.storage.segments_pending_deletion
(gauge)
Number of read cursors for hydrated remote log segments
redpanda.cloud.storage_spillover_manifest_uploads
(count)
Total number of successful spillover manifest uploads to object storage.
redpanda.cloud.storage_spillover_manifests_materialized_bytes
(gauge)
Total bytes of memory used by spilled manifests that are currently cached in memory.
redpanda.cloud.storage_spillover_manifests_materialized_count
(gauge)
Count of spilled manifests currently held in memory cache.
redpanda.cloud.storage.uploaded_bytes
(count)
Total number of accounted segments in the cloud for the topic
Shown as byte
redpanda.cluster.brokers
(gauge)
Number of configured brokers in the cluster
redpanda.cluster.controller_log_limit_requests_dropped
(count)
REMOVED: use redpanda.controller.log_limit_requests_dropped instead
Shown as request
redpanda.controller.log_limit_requests_available
(gauge)
Controller log rate limiting. Available rps for group
Shown as request
redpanda.controller.log_limit_requests_dropped
(count)
Controller log rate limiting. Amount of requests that are dropped due to exceeding limit in group
Shown as request
redpanda.cluster.features_enterprise_license_expiry_sec
(gauge)
Number of seconds remaining until the Enterprise Edition license expires.
redpanda.cluster.latest_cluster_metadata_manifest_age
(gauge)
The amount of time in seconds since the last time Redpanda uploaded metadata files to Tiered Storage for your cluster. A value of 0 indicates metadata has not yet been uploaded.
redpanda.cluster.members_backend_queued_node_operations
(gauge)
Number of queued node operations.
redpanda.cluster.non_homogenous_fips_mode
(gauge)
Count of brokers whose FIPS mode configuration differs from the rest of the cluster.
redpanda.cluster.partitions
(gauge)
Total number of logical partitions managed by the cluster. This includes partitions for the controller topic but excludes replicas.
redpanda.partitions.moving_from_node
(gauge)
Number of partition replicas that are in the process of being removed from a broker.
redpanda.partitions.moving_to_node
(gauge)
Number of partition replicas in the cluster currently being added or moved to a broker.
redpanda.partitions.node_cancelling_movements
(gauge)
During a partition movement cancellation operation, the number of partition replicas that were being moved that now need to be canceled.
redpanda.cluster.partition_num_with_broken_rack_constraint
(gauge)
Number of partitions that don’t satisfy the rack awareness constraint
redpanda.cluster.partition_schema_id_validation_records_failed
(count)
Count of records that failed schema ID validation during ingestion.
redpanda.cluster.replicas
(gauge)
REMOVED: Use either redpanda.cluster.brokers for the number of brokers or redpanda.kafka.replicas for the number of replicas per topic
redpanda.cluster.topics
(gauge)
Number of topics in the cluster
redpanda.cluster.unavailable_partitions
(gauge)
Number of partitions that are unavailable due to a lack of quorum among their replica set.
redpanda.reactor.cpu_busy_seconds
(gauge)
Total CPU busy time in seconds
Shown as second
redpanda.debug_bundle.failed_generation_count
(count)
Running count of debug bundle generation failures, reported per shard.
redpanda.debug_bundle.last_failed_bundle_timestamp_seconds
(gauge)
Unix epoch timestamp of the last failed debug bundle generation, per shard.
redpanda.debug_bundle.last_successful_bundle_timestamp_seconds
(gauge)
Unix epoch timestamp of the last successfully generated debug bundle, per shard.
redpanda.debug_bundle.successful_generation_count
(count)
Running count of successfully generated debug bundles, reported per shard.
redpanda.iceberg.rest_client_active_gets
(gauge)
Number of active GET requests.
redpanda.iceberg.rest_client_active_puts
(gauge)
Number of active PUT requests.
redpanda.iceberg.rest_client_active_requests
(gauge)
Number of active HTTP requests (includes PUT and GET).
redpanda.iceberg.rest_client_num_commit_table_update_requests
(count)
Number of requests sent to the commit_table_update endpoint.
redpanda.iceberg.rest_client_num_commit_table_update_requests_failed
(count)
Number of requests sent to the commit_table_update endpoint that failed.
redpanda.iceberg.rest_client_num_create_namespace_requests
(count)
Number of requests sent to the create_namespace endpoint.
redpanda.iceberg.rest_client_num_create_namespace_requests_failed
(count)
Number of requests sent to the create_namespace endpoint that failed.
redpanda.iceberg.rest_client_num_create_table_requests
(count)
Number of requests sent to the create_table endpoint.
redpanda.iceberg.rest_client_num_create_table_requests_failed
(count)
Number of requests sent to the create_table endpoint that failed.
redpanda.iceberg.rest_client_num_drop_table_requests
(count)
Number of requests sent to the drop_table endpoint.
redpanda.iceberg.rest_client_num_drop_table_requests_failed
(count)
Number of requests sent to the drop_table endpoint that failed.
redpanda.iceberg.rest_client_num_get_config_requests
(count)
Number of requests sent to the config endpoint.
redpanda.iceberg.rest_client_num_get_config_requests_failed
(count)
Number of requests sent to the config endpoint that failed.
redpanda.iceberg.rest_client_num_load_table_requests
(count)
Number of requests sent to the load_table endpoint.
redpanda.iceberg.rest_client_num_load_table_requests_failed
(count)
Number of requests sent to the load_table endpoint that failed.
redpanda.iceberg.rest_client_num_oauth_token_requests
(count)
Number of requests sent to the oauth_token endpoint.
redpanda.iceberg.rest_client_num_oauth_token_requests_failed
(count)
Number of requests sent to the oauth_token endpoint that failed.
redpanda.iceberg.rest_client_num_request_timeouts
(count)
Total number of catalog requests that could no longer be retried because they timed out. This may occur if the catalog is not responding.
redpanda.iceberg.rest_client_num_transport_errors
(count)
Total number of transport errors (TCP and TLS).
redpanda.iceberg.rest_client_total_gets
(count)
Number of completed GET requests.
redpanda.iceberg.rest_client_total_inbound_bytes
(count)
Total number of bytes received from the Iceberg REST catalog.
redpanda.iceberg.rest_client_total_outbound_bytes
(count)
Total number of bytes sent to the Iceberg REST catalog.
redpanda.iceberg.rest_client_total_puts
(count)
Number of completed PUT requests.
redpanda.iceberg.rest_client_total_requests
(count)
Number of completed HTTP requests (includes PUT and GET).
redpanda.iceberg.translation_decompressed_bytes_processed
(count)
Number of bytes consumed post-decompression for processing that may or may not succeed in being processed. For example, if Redpanda fails to communicate with the coordinator preventing processing of a batch, this metric still increases.
redpanda.iceberg.translation_dlq_files_created
(count)
Number of created Parquet files for the dead letter queue (DLQ) table.
redpanda.iceberg.translation_files_created
(count)
Number of created Parquet files (not counting the DLQ table).
redpanda.iceberg.translation_invalid_records
(count)
Number of invalid records handled by translation.
redpanda.iceberg.translation_parquet_bytes_added
(count)
Number of bytes in created Parquet files (not counting the DLQ table).
redpanda.iceberg.translation_parquet_rows_added
(count)
Number of rows in created Parquet files (not counting the DLQ table).
redpanda.iceberg.translation_raw_bytes_processed
(count)
Number of raw, potentially compressed bytes, consumed for processing that may or may not succeed in being processed. For example, if Redpanda fails to communicate with the coordinator preventing processing of a batch, this metric still increases.
redpanda.iceberg.translation_translations_finished
(count)
Number of finished translator executions.
redpanda.io_queue.total_read_ops
(count)
Cumulative count of read operations processed by the I/O queue.
Shown as operation
redpanda.io_queue.total_write_ops
(count)
Cumulative count of write operations processed by the I/O queue.
Shown as operation
redpanda.kafka.group_offset
(gauge)
Consumer group committed offset
redpanda.kafka.group_count
(gauge)
Number of consumers in a group
redpanda.kafka.group_lag_max
(gauge)
Maximum lag for any partition in the group
redpanda.kafka.group_lag_sum
(gauge)
Sum of lag for all partitions in the group
redpanda.kafka.group_topic_count
(gauge)
Number of topics in a group
redpanda.kafka.handler_latency_seconds
(gauge)
Histogram capturing the latency for processing Kafka requests at the broker level.
redpanda.kafka.partition_committed_offset
(gauge)
Latest committed offset for the partition (i.e. the offset of the last message safely persisted on most replicas).
redpanda.kafka.partitions
(gauge)
Configured number of partitions for the topic
redpanda.kafka.quotas_client_quota_throttle_time
(gauge)
Histogram of client quota throttling delays (in seconds) per quota rule and type.
redpanda.kafka.quotas_client_quota_throughput
(gauge)
Histogram of client quota throughput per quota rule and type.
redpanda.kafka.records_fetched
(count)
Total number of records fetched from a topic
redpanda.kafka.records_produced
(count)
Total number of records produced to a topic
redpanda.kafka.replicas
(gauge)
Configured number of replicas for the topic
redpanda.kafka.request_bytes
(count)
Total number of bytes produced per topic
Shown as byte
redpanda.kafka.request_latency_seconds
(gauge)
Internal latency of kafka produce requests
Shown as second
redpanda.kafka.rpc_sasl_session_expiration
(count)
Total number of SASL session expirations observed.
redpanda.kafka.rpc_sasl_session_reauth_attempts
(count)
Total number of SASL reauthentication attempts made by clients.
redpanda.kafka.rpc_sasl_session_revoked
(count)
Total number of SASL sessions that have been revoked.
redpanda.kafka.under_replicated_replicas
(gauge)
Number of under replicated replicas (i.e. replicas that are live, but not at the latest offest)
redpanda.memory.allocated_memory
(gauge)
Allocated memory size in bytes
Shown as byte
redpanda.memory.available_memory
(gauge)
Total shard memory potentially available in bytes (free_memory plus reclaimable)
Shown as byte
redpanda.memory.available_memory_low_water_mark
(gauge)
The low-water mark for available_memory from process start
Shown as byte
redpanda.memory.free_memory
(gauge)
Free memory size in bytes
Shown as byte
redpanda.node_status.rpcs_received
(gauge)
Number of node status RPCs received by this node
Shown as request
redpanda.node_status.rpcs_sent
(gauge)
Number of node status RPCs sent by this node
Shown as request
redpanda.node_status.rpcs_timed_out
(gauge)
Number of timed out node status RPCs from this node
Shown as request
redpanda.raft.leadership_changes
(count)
Number of leadership changes across all partitions of a given topic
redpanda.raft.learners_gap_bytes
(gauge)
Total number of bytes that must be delivered to learner replicas to bring them up to date.
redpanda.raft.recovery_offsets_pending
(gauge)
Sum of offsets across partitions on a broker that still need to be recovered.
redpanda.raft.recovery_bandwidth
(gauge)
Available network bandwidth (in bytes per second) for partition movement operations.
Shown as byte
redpanda.raft.recovery_consumed_bandwidth
(gauge)
Network bandwidth (in bytes per second) currently being consumed for partition movement.
redpanda.raft.recovery_partitions_active
(gauge)
Number of partition replicas currently undergoing recovery on a broker.
redpanda.raft.recovery_partitions_to_recover
(gauge)
Total count of partition replicas that are pending recovery on a broker.
redpanda.pandaproxy.inflight_requests_memory_usage_ratio
(gauge)
Memory usage ratio of in-flight requests in the rest_proxy.
redpanda.pandaproxy.inflight_requests_usage_ratio
(gauge)
Usage ratio of in-flight requests in the rest_proxy.
redpanda.pandaproxy.queued_requests_memory_blocked
(gauge)
Number of requests queued in rest_proxy, due to memory limitations.
redpanda.pandaproxy.request_errors
(count)
Total number of rest_proxy server errors
Shown as error
redpanda.pandaproxy.request_latency
(gauge)
Internal latency of request for rest_proxy
Shown as millisecond
redpanda.rpc.active_connections
(gauge)
Current number of active RPC client connections on a shard.
Shown as connection
redpanda.rpc.received_bytes
(count)
Number of bytes received from the clients in valid requests.
redpanda.rpc.request_errors
(count)
Number of rpc errors
Shown as error
redpanda.rpc.request_latency_seconds
(gauge)
Histogram capturing the latency (in seconds) for RPC requests.
Shown as second
redpanda.rpc.sent_bytes
(count)
Number of bytes sent to clients.
redpanda.scheduler.runtime_seconds
(count)
Accumulated runtime of task queue associated with this scheduling group
Shown as second
redpanda.schema_registry.cache_schema_count
(gauge)
Total number of schemas currently stored in the Schema Registry cache.
redpanda.schema_registry.cache_schema_memory_bytes
(gauge)
Memory usage (in bytes) by schemas stored in the Schema Registry cache.
redpanda.schema_registry.cache_subject_count
(gauge)
Count of subjects stored in the Schema Registry cache.
redpanda.schema_registry.cache_subject_version_count
(gauge)
Count of versions available for each subject in the Schema Registry cache.
redpanda.schema_registry.inflight_requests_memory_usage_ratio
(gauge)
Ratio of memory used by in-flight requests in the Schema Registry, reported per shard.
redpanda.schema_registry.inflight_requests_usage_ratio
(gauge)
Usage ratio for in-flight Schema Registry requests, reported per shard.
redpanda.schema_registry.queued_requests_memory_blocked
(gauge)
Count of Schema Registry requests queued due to memory constraints, reported per shard.
redpanda.schema_registry.errors
(count)
Total number of schema_registry server errors
Shown as error
redpanda.schema_registry_latency_seconds
(gauge)
Histogram capturing the latency (in seconds) for Schema Registry requests. [supported in v2.1.0 and below]
Shown as second
redpanda.schema_registry.latency_seconds
(gauge)
Histogram capturing the latency (in seconds) for Schema Registry requests. [supported in v2.2.0+]
Shown as second
redpanda.security.audit_errors
(count)
Cumulative count of errors encountered when creating or publishing audit event log entries.
redpanda.security.audit_last_event_timestamp_seconds
(count)
Unix epoch timestamp of the last successful audit log event publication.
redpanda.storage.cache_disk_free_bytes
(gauge)
Amount of free disk space (in bytes) available on the cache storage.
redpanda.storage.cache_disk_free_space_alert
(gauge)
Alert indicator for cache storage free space, where: 0 = OK, 1 = Low space, 2 = Degraded
redpanda.storage.cache_disk_total_bytes
(gauge)
Amount of total disk space (in bytes) available on the cache storage.
redpanda.storage.disk_free_bytes
(gauge)
Amount of free disk space (in bytes) available on attached storage.
Shown as byte
redpanda.storage.disk_free_space_alert
(gauge)
Alert indicator for overall disk storage free space, where: 0 = OK, 1 = Low space, 2 = Degraded
redpanda.storage.disk_total_bytes
(gauge)
Total size of attached storage, in bytes.
Shown as byte
redpanda.tls.certificate_expires_at_timestamp_seconds
(gauge)
Unix epoch timestamp for the expiration of the shortest-lived installed TLS certificate.
redpanda.tls.certificate_serial
(gauge)
The least significant 4 bytes of the serial number for the certificate that will expire next.
redpanda.tls.certificate_valid
(gauge)
Indicator of whether a resource has at least one valid TLS certificate installed. Returns 1 if a valid certificate is present and 0 if not.
redpanda.tls.loaded_at_timestamp_seconds
(gauge)
Unix epoch timestamp marking the last time a TLS certificate was loaded for a resource.
redpanda.tls.truststore_expires_at_timestamp_seconds
(gauge)
Unix epoch timestamp representing the expiration time of the shortest-lived certificate authority (CA) in the installed truststore.
redpanda.transform.execution_errors
(count)
Counter for the number of errors encountered during the invocation of data transforms.
redpanda.transform.execution_latency_sec
(gauge)
Histogram tracking the execution latency (in seconds) for processing a single record via data transforms.
redpanda.transform.failures
(count)
Counter for each failure encountered by a data transform processor.
redpanda.transform.processor_lag
(count)
Number of records pending processing in the input topic for a data transform.
redpanda.transform.read_bytes
(count)
Cumulative count of bytes read as input to data transforms.
redpanda.transform.state
(gauge)
Current count of transform processors in a specific state (running, inactive, or errored).
redpanda.transform.write_bytes
(count)
Cumulative count of bytes output from data transforms.
redpanda.wasm.binary_executable_memory_usage
(gauge)
Amount of memory (in bytes) used by executable WebAssembly binaries.
redpanda.wasm.engine_cpu_seconds
(count)
Total CPU time (in seconds) consumed by WebAssembly functions.
redpanda.wasm.engine_max_memory
(gauge)
Maximum allowed memory (in bytes) allocated for a WebAssembly function.
redpanda.wasm.engine_memory_usage
(gauge)
Current memory usage (in bytes) by a WebAssembly function.

Événements

L’intégration Redpanda n’inclut aucun événement.

Checks de service

redpanda.openmetrics.health

Returns CRITICAL if the check cannot access the metrics endpoint. Returns OK otherwise.

Statuses: ok, critical

Dépannage

Besoin d’aide ? Contactez l’assistance Datadog.