Skip to content

Conversation

@renovate
Copy link
Contributor

@renovate renovate bot commented Dec 15, 2025

This PR contains the following updates:

Package Change Age Confidence
github.com/open-telemetry/opentelemetry-collector-contrib/extension/k8sleaderelector v0.141.0v0.143.0 age confidence
github.com/open-telemetry/opentelemetry-collector-contrib/pkg/golden v0.141.0v0.143.0 age confidence
github.com/open-telemetry/opentelemetry-collector-contrib/pkg/pdatatest v0.141.0v0.143.0 age confidence
go.opentelemetry.io/collector/cmd/builder v0.141.0v0.143.0 age confidence
go.opentelemetry.io/collector/cmd/mdatagen v0.141.0v0.143.0 age confidence
go.opentelemetry.io/collector/component v1.47.0v1.49.0 age confidence
go.opentelemetry.io/collector/component/componenttest v0.141.0v0.143.0 age confidence
go.opentelemetry.io/collector/confmap v1.47.0v1.49.0 age confidence
go.opentelemetry.io/collector/confmap/xconfmap v0.141.0v0.143.0 age confidence
go.opentelemetry.io/collector/consumer v1.47.0v1.49.0 age confidence
go.opentelemetry.io/collector/consumer/consumertest v0.141.0v0.143.0 age confidence
go.opentelemetry.io/collector/exporter v1.47.0v1.49.0 age confidence
go.opentelemetry.io/collector/exporter/debugexporter v0.141.0v0.143.0 age confidence
go.opentelemetry.io/collector/filter v0.141.0v0.143.0 age confidence
go.opentelemetry.io/collector/otelcol v0.141.0v0.143.0 age confidence
go.opentelemetry.io/collector/pdata v1.47.0v1.49.0 age confidence
go.opentelemetry.io/collector/pipeline v1.47.0v1.49.0 age confidence
go.opentelemetry.io/collector/processor v1.47.0v1.49.0 age confidence
go.opentelemetry.io/collector/processor/batchprocessor v0.141.0v0.143.0 age confidence
go.opentelemetry.io/collector/processor/processorhelper v0.141.0v0.143.0 age confidence
go.opentelemetry.io/collector/processor/processortest v0.141.0v0.143.0 age confidence
go.opentelemetry.io/collector/receiver v1.47.0v1.49.0 age confidence
go.opentelemetry.io/collector/receiver/receivertest v0.141.0v0.143.0 age confidence
go.opentelemetry.io/collector/scraper v0.141.0v0.143.0 age confidence
go.opentelemetry.io/collector/scraper/scraperhelper v0.141.0v0.143.0 age confidence

Release Notes

open-telemetry/opentelemetry-collector-contrib (github.com/open-telemetry/opentelemetry-collector-contrib/extension/k8sleaderelector)

v0.143.0

Compare Source

🛑 Breaking changes 🛑
  • connector/servicegraph: remove deprecated warning log about metrics exporter logical (#​45177)

  • extension/googlecloudlogentry_encoding: Parse Cloud DNS Query logs into log record attributes instead of placing it in the body as is. (#​44561)

  • processor/tail_sampling: Add support for caching the policy name involved in a sampling decision. (#​45040)
    This change allows the tailsampling.policy attribute to be set on the spans in a trace when a sampling decision is cached.

  • receiver/prometheus: Remove deprecated use_start_time_metric and start_time_metric_regex configuration options. (#​44180)
    The use_start_time_metric and start_time_metric_regex configuration options have been removed after being deprecated in v0.142.0.
    Users who have these options set in their configuration will experience collector startup failures after upgrading.
    To migrate, remove these configuration options and use the metricstarttime processor instead for equivalent functionality.

  • receiver/systemd: Rename systemd.unit.cpu.time metric to systemd.service.cpu.time (#​44916)

🚀 New components 🚀
  • cmd/schemagen: Introduce script that generates configuration schemas for collector components based on go structs. (#​42214)
    The schemagen tool generates schemas for OpenTelemetry Collector components configuration
    by analyzing Go struct definitions. This is preliminary work to support automatic generation
    of documentation and validation for component configurations.
💡 Enhancements 💡
  • exporter/azureblob: Add time_parser_ranges option to allow selective time parsing of blob name substrings (#​44650)
    The new time_parser_ranges configuration allows specifying index ranges (e.g., ["0-10", "15-25"]) to control which parts of the blob name are time-formatted.

  • exporter/coralogix: Exposed a new field to set grpc-accept-encoding. gzip will be used by default. (#​45191)

  • exporter/coralogix: Improve log messages when a partial success happens for traces. (#​44926)
    The exporter now provides additional context based on the type of partial success | returned by the backend. When the backend indicates issues with the sent data, the error | message is analyzed to identify and display examples of the problematic data.

  • exporter/elasticsearch: Add support for extra query parameters to the outgoing bulk request (#​44480)

  • exporter/kafka: Make max_message_bytes and flush_max_messages unconditional in franz-go producer. Changed flush_max_messages default from 0 to 10000 to match franz-go default. (#​44840)

  • extension/awslogs_encoding: Enhance VPC flow logs encoding extension with CloudWatch logs support (#​44710)

  • extension/azure_encoding: Add processing for AppService, CDN, FrontDoor and Recommendation logs records (#​41725)

  • extension/googlecloudlogentry_encoding: Add support for Passthrough External and Internal Network Load Balancer logs (#​44524)
    Add support for Passthrough External and Internal Network Load Balancer logs to the Google Cloud log entry encoding extension.
    This includes adding support for the new gcp.load_balancing.passthrough_nlb attributes including connection details,
    bytes/packets sent and received, and RTT measurements.

  • pkg/ottl: Add Bool function for converting values to boolean (#​44770)

  • processor/geoip: Bump oschwald/geoip2 to v2 (#​44687)

  • receiver/awscloudwatch: Add support for filtering log groups by account ID. (#​38391)

  • receiver/awscontainerinsightreceiver: Component type name renamed from awscontainerinsightreceiver to awscontainerinsight, controlled by feature gate receiver.awscontainerinsightreceiver.useNewTypeName. (#​44052)
    When the feature gate is enabled, the receiver uses the new type name awscontainerinsight instead of awscontainerinsightreceiver.
    To enable the new type name, use: --feature-gates=+receiver.awscontainerinsightreceiver.useNewTypeName.

  • receiver/awslambda: Add support for AWS Lambda receiver to trigger by CloudWatch logs subscription filters for Lambda (#​43504)

  • receiver/awslambda: Add S3 failure replay support to AWS Lambda receiver (#​43504)

  • receiver/filelog: gzip files are auto detected based on their header (#​39682)

  • receiver/github: Add merged_pr_lookback_days configuration to limit historical PR queries and reduce API usage (#​43388)
    The merged_pr_lookback_days configuration option limits the timeframe for
    which merged pull requests are queried. Set to 0 to fetch all merged PRs.
    Open PRs are always fetched regardless of this setting.

  • receiver/oracledb: Add stored procedure information to logs for top queries and query samples. (#​44764)
    The db.server.top_query event now includes oracledb.procedure_id, oracledb.procedure_name, and oracledb.procedure_type attributes.
    The db.server.query_sample event now includes oracledb.procedure_id, oracledb.procedure_name, and oracledb.procedure_type attributes.

  • receiver/postgresql: Added service.instance.id resource attribute for metrics and logs (#​43907)
    service.instance.id is enabled by default.

  • receiver/postgresql: Add trace propagation support (#​44868)
    When postgresql.application_name contains a valid W3C traceparent, emitted db.server.query_sample logs include trace_id and span_id for correlation.

  • receiver/prometheus: Add receiver.prometheusreceiver.RemoveReportExtraScrapeMetricsConfig feature gate to disable the report_extra_scrape_metrics config option. (#​44181)
    When enabled, the report_extra_scrape_metrics configuration option is ignored, and extra scrape metrics are
    controlled solely by the receiver.prometheusreceiver.EnableReportExtraScrapeMetrics feature gate.
    This mimics Prometheus behavior where extra scrape metrics are controlled by a feature flag.

  • receiver/systemd: Add metric for number of times a service has restarted. (#​45071)

  • receiver/windowseventlog: Improved performance of the Windows Event Log Receiver (#​43195)
    Previously, the Windows Event Log Receiver could only process events up to 100 messages per second with default settings.
    This was because the receiver would read at most max_reads messages within each configured poll_interval, even if
    additional events were already available.

    This restriction has been removed. The poll_interval parameter behaves as described in the documentation:
    The poll_interval parameter now only takes effect after all current events have been read.

    For users who prefer the previous behavior, a new configuration option, max_events_per_poll, has been introduced.

  • receiver/windowseventlog: Add parsing for Version and Correlation event fields. (#​45018)

🧰 Bug fixes 🧰
  • connector/count: Basic config should emit default metrics (#​41769)

  • exporter/elasticsearch: Deduplicate attribute keys from non-compliant SDKs in otel mapping mode (#​39304)
    The serializer in otel mapping mode now explicitly deduplicates attribute keys when writing to Elasticsearch,
    keeping only the first occurrence. This prevents invalid JSON from being produced when
    non-compliant SDKs send duplicate keys.

  • exporter/kafka: Wrap non-retriable errors from franzgo with consumererror::permanent (#​44918)

  • exporter/loadbalancing: Fix k8s resolver parsing so loadbalancing exporter works with service FQDNs (#​44472)

  • pkg/translator/azurelogs: Fix missing data when ingesting Azure logs without properties field. (#​44222)

  • receiver/awss3: Fix data loss when SQS messages contain multiple S3 object notifications and some fail to process (#​45153)
    The SQS notification reader was unconditionally deleting messages after processing,
    even when some S3 object retrievals or callback processing failed. This caused data
    loss when a message contained multiple S3 notification records and any of them failed.
    Messages are now only deleted when all records are successfully processed, allowing
    failed records to be retried after the visibility timeout.

  • receiver/azureeventhub: Make storage of new azeventhub library backward compatible and fix checkpoint starting at earliest when storage is enabled (#​44461)

  • receiver/fluentforward: Ensure all established connections are properly closed on shutdown in the fluentforward receiver. The shutdown process now reliably closes all active connections. (#​44433)

    • Fixes shutdown behavior so that all existing connections are closed cleanly.
    • Adds tests to verify proper connection closure.
  • receiver/kafka: Fix deprecated field migration logic for metrics, traces, and profiles topic configuration (#​45215)
    Fixed bug where deprecated topic and exclude_topic fields for metrics, traces, and profiles
    were incorrectly checking logs configuration instead of their respective signal type's configuration.
    This prevented proper migration from deprecated fields unless logs.topics was empty.
    Also fixed validation error message typo for traces.exclude_topic and corrected profiles validation
    to check ExcludeTopic fields instead of Topic fields.

  • receiver/sqlserver: Collect query metrics for long running queries (#​44984)

  • receiver/tcpcheck: Fix the unit of the tcpcheck.error metric from error to errors (#​45092)

v0.142.0

Compare Source

🛑 Breaking changes 🛑
  • all: It's recommended to change the field type in your component configuration to be configoptional.Optional[exporterhelper.QueueBatchConfig] to keep the enabled subfield. Use configoptional.Some(exporterhelper.NewDefaultQueueConfig()) to enable by default. Use configoptional.Default(exporterhelper.NewDefaultQueueConfig()) to disable by default. (#​44320)

  • exporter/datadog: Update the Datadog exporter to support the Orchestrator Explorer by accepting receiver/k8sobjects logs and sending Kubernetes data to the Datadog endpoint. (#​44523)
    The Cluster name field in Orchestrator Explorer Configuration has been removed. Use the k8s.cluster.name attribute instead.

  • exporter/prometheusremotewrite: Updated to Remote Write 2.0 spec rc.4, requiring Prometheus 3.8.0 or later as the receiving endpoint. (#​44861)
    The upstream Prometheus library updated the Remote Write 2.0 protocol from rc.3 to rc.4 in
    prometheus/prometheus#17411. This renamed CreatedTimestamp to StartTimestamp and moved it
    from the TimeSeries message to individual Sample and Histogram messages. This is a
    wire-protocol incompatibility, so if you are exporting to a Prometheus server, you must upgrade
    it to version 3.8.0 or later to receive data from this exporter.

  • extension/googlecloudlogentry_encoding: Parse External Application Load Balancer logs into log record attributes instead of placing it in the body as is. (#​44438)

  • pkg/stanza: Allow max_batch_size of 0 for unlimited batching in recombine operator (#​43982)
    The recombine operator now supports setting max_batch_size: 0 to disable batch size limits.
    This allows unlimited batching, letting entries be combined based only on max_log_size and matching conditions.
    If you have max_batch_size: 0 in your config and want to keep the behavior unchanged, change the configuration to max_batch_size: 1.

  • processor/cumulativetodelta: Change default max_staleness from 0 (infinite) to 1 hour (#​44427)
    The processor now defaults to a max_staleness of 1 hour instead of 0 (infinite retention).
    This prevents unbounded memory growth in long-running collector instances, especially when tracking metrics with high cardinality or frequently changing attribute values.
    To restore the previous behavior of infinite retention, explicitly set max_staleness: 0 in your configuration.

  • processor/resourcedetection: Promote processor.resourcedetection.propagateerrors feature gate to beta (#​44609)

  • processor/resourcedetection: Remove deprecated attributes configuration option (#​44610)

  • receiver/awss3: Remove the s3_partition config option in favor of s3_partition_format and s3_partition_timezone options. This aligns the S3 receiver more closely with the S3 Exporter. Also add the ability to include or exclude the telemetry type from the file prefix using the file_prefix_include_telemetry_type option. (#​43720)

  • receiver/docker_stats: Upgrades default Docker API version to 1.44 to be compatible with recent Docker Engine versions. (#​44279)
    Users requiring an older Docker API version can set the api_version in the docker stats receiver config. The minimum supported API level is not changed, only default.

  • receiver/filelog: Move filelog.decompressFingerprint to stable stage (#​44570)

  • receiver/prometheus: Promote the receiver.prometheusreceiver.RemoveStartTimeAdjustment feature gate to stable and remove in-receiver metric start time adjustment in favor of the metricstarttime processor, including disabling the created-metric feature gate. (#​44180)
    Previously, users could disable the RemoveStartTimeAdjustment feature gate to temporarily keep the legacy start time adjustment behavior in the Prometheus receiver.
    With this promotion to stable and bounded registration, that gate can no longer be disabled; the receiver will no longer set StartTime on metrics based on process_start_time_seconds, and users should migrate to the metricstarttime processor for equivalent functionality.
    This change also disables the receiver.prometheusreceiver.UseCreatedMetric feature gate, which previously used the <metric>_created series to derive start timestamps for counters, summaries, and histograms when scraping non OpenMetrics protocols.
    However, this does not mean that the _created series is always ignored: when using the OpenMetrics 1.0 protocol, Prometheus itself continues to interpret the _created series as the start timestamp, so only the receiver-side handling for other scrape protocols has been removed.

  • receiver/prometheus: Native histogram scraping and ingestion is now controlled by the scrape configuration option scrape_native_histograms. (#​44861)
    The feature gate receiver.prometheusreceiver.EnableNativeHistograms is now stable and enabled by default.
    Native histograms scraped from Prometheus will automatically be converted to OpenTelemetry exponential histograms.

    To enable scraping of native histograms, you must configure scrape_native_histograms: true in your Prometheus
    scrape configuration (either globally or per-job). Additionally, the protobuf scrape protocol must be enabled
    by setting scrape_protocols to include PrometheusProto.

  • receiver/prometheusremotewrite: Updated to Remote Write 2.0 spec rc.4, requiring Prometheus 3.8.0 or later (#​44861)
    The upstream Prometheus library updated the Remote Write 2.0 protocol from rc.3 to rc.4 in
    prometheus/prometheus#17411. This renamed CreatedTimestamp to StartTimestamp and moved it
    from the TimeSeries message to individual Sample and Histogram messages. This is a
    wire-protocol incompatibility, so Prometheus versions 3.7.x and earlier will no longer work
    correctly with this receiver. Please upgrade to Prometheus 3.8.0 or later.

🚩 Deprecations 🚩
  • processor/k8sattributes: Removes stable k8sattr.fieldExtractConfigRegex.disallow feature gate (#​44694)

  • receiver/kafka: Deprecate default_fetch_size parameter for franz-go client (#​43104)
    The default_fetch_size parameter is now deprecated for the franz-go Kafka client and will only be used with the legacy Sarama client.
    Users should configure max_fetch_size instead when using franz-go.
    This deprecation is marked as of v0.142.0.

  • receiver/kafka: Support configuring a list of topics and exclude_topics; deprecate topic and exclude_topic (#​44477)

  • receiver/prometheus: Deprecate use_start_time_metric and start_time_metric_regex config in favor of the processor metricstarttime (#​44180)

🚀 New components 🚀
  • receiver/yanggrpc: Implement the YANG/gRPC receiver (#​43840)
💡 Enhancements 💡
  • exporter/elasticsearch: add dynamic data stream routing for connectors (#​44525)

  • exporter/kafka: Adds server.address attribute to all Kafka exporter metrics. (#​44649)

  • exporter/prometheusremotewrite: Add option to remove service.name, service.instance.id, service.namespace ResourceAttribute from exported metrics (#​44567)

  • exporter/signalfx: Support setting default properties for dimension updates to be set lazily as part of configuration (#​44891)

  • extension/azure_encoding: Implement general Azure Resource Log parsing functionality (#​41725)

  • extension/datadog: Datadog Extension users may view and manage OTel Collectors in Fleet Automation. (#​44666)
    Interested users should read the post on the Datadog Monitor blog and fill out the preview intake form listed there.

  • extension/datadog: Adds deployment_type configuration option to the Datadog Extension. (#​44430)
    Users may specify the deployment type of the collector in Datadog Extension configuration to view in Datadog app.
    If the collector is deployed as a gateway (i.e. receiving pipeline telemetry from multiple hosts/sources),
    user should specify "gateway" as the deployment type.
    If the collector is deployed as a daemonset/agent, user should specify "daemonset" as the deployment type.
    The default setting is "unknown" if not set.

  • extension/datadog: Adds standard (non-billed) liveness metric otel.datadog_extension.running to ensure host data is shown in Datadog app. (#​44285)

  • extension/googlecloudlogentry_encoding: Add support for GCP VPC Flow Log fields for MIG (Managed Instance Group) and Google Service logs. (#​44220)
    Adds support for the following GCP VPC Flow Log fields:

    • Add support for gcp.vpc.flow.{source,destination}.google_service.{type,name,connectivity}
    • Add support for gcp.vpc.flow.{source,destination}.instance.managed_instance_group.{name,region,zone}
  • extension/health_check: Added extension.healthcheck.useComponentStatus feature gate to enable v2 component status reporting in healthcheckextension while maintaining backward compatibility by default. (#​42256)

  • pkg/ottl: Accept string trace/span/profile IDs for TraceID(), SpanID(), and ProfileID() in OTTL. (#​43429)
    This change allows for a more straightforward use of string values to set trace, span, and profile IDs in OTTL.

  • pkg/stanza: New featuregate filelog.windows.caseInsensitive introduced. It will make glob matching is case-insensitive on Windows. (#​40685)
    Previously, any include pattern that included some manner of wildcard (* or **) would
    be case-sensitive on Windows, but Windows filepaths are by default case-insensitive. This meant
    that in a directory with the files a.log and b.LOG, the pattern *.log would previously only
    match a.log. With the filelog.windows.caseInsensitive featuregate enabled, it will match both a.log
    and b.LOG when on Windows. The behaviour is the same as always on other operating systems, as all other
    currently supported platforms for the Collector have case-sensitive filesystems.

  • pkg/translator/azurelogs: Added support for Activity Logs Recommendation category (#​43220)

  • processor/k8sattributes: Updates semconv version to v1.37.0 (#​44696)

  • processor/resourcedetection: Add support for dynamic refresh resource attributes with refresh_interval parameter (#​42663)

  • processor/resourcedetection: Update semconv dependency to 1.37.0 which updates the schema url in the data, but no other impact is expected. (#​44726)

  • processor/transform: New Transform Processor function set_semconv_span_name() to overwrite the span name with the semantic conventions for HTTP, RPC, messaging, and database spans. (#​43124)
    In other cases, the original span.name is unchanged.
    The primary use of set_semconv_span_name() is alongside the
    Span Metrics Connector
    to address high-cardinality issues in span metrics when span.name does not comply with the OTel requirement
    that span names be low cardinality.

  • receiver/azuremonitor: Scrape storage account sub types (#​37220)

  • receiver/datadog: Improve the compliance with OTel Semantic Conventions for RPC spans in the Datadog receiver. (#​44671)
    Compliance improvements on spans received via the Datadog receiver when applicable:

    • Set span name according to RPC conventions.
    • Set rpc.method and rpc.service attributes.
  • receiver/datadog: Bump OTel Semantic Conventions from v1.30.0 to v1.37.0 in the Datadog receiver. (#​44671)
    Changes in OTel Semantic Conventions v1.37.0 affecting the Datadog receiver:

    • The Datadog tag runtime is now mapped to the OTel attribute container.runtime.name instead of container.runtime.
  • receiver/datadog: Improve the compliance with OTel Semantic Conventions for AWS SDK spans in the Datadog receiver. (#​44723)
    Compliance improvements on spans received via the Datadog receiver when applicable:

    • Set span name according to AWS SDK conventions.
    • Set rpc.system, rpc.method and rpc.service attributes.
  • receiver/datadog: Add receiver.datadogreceiver.EnableMultiTagParsing feature gate (#​44747)
    The feature flag changes the logic that converts Datadog tags to OpenTelemetry attributes.
    When the flag is enabled, data points that have multiple tags starting with the same key: prefix
    will be turned into an attribute slice (instead of a string) containing all the suffix values.

  • receiver/datadog: Improve the compliance with OTel Semantic Conventions for HTTP spans in the Datadog receiver. (#​44722)
    Compliance improvements on spans received via the Datadog receiver when applicable:
    Set span name according to HTTP conventions for web.request and http.request spans.

  • receiver/github: Add concurrency limiting to reduce likelihood of hitting secondary rate limits (#​43388)
    Adds concurrency_limit configuration parameter (default: 50) to limit
    concurrent repository processing goroutines. This reduces the likelihood of
    getting 502/504 errors when scraping organizations with >100 repositories.

  • receiver/googlecloudpubsub: Exponential backoff streaming restarts (#​44741)

  • receiver/kafka: Make session_timeout, heartbeat_interval, max_partition_fetch_size, and max_fetch_wait unconditional in franz-go consumer (#​44839)

  • receiver/kafka: Validate that exclude_topics entries in kafkareceiver config are non-empty. (#​44920)

  • receiver/oracledb: Added independent collection interval config for Oracle top query metrics collection (#​44607)

  • receiver/prometheusremotewrite: Map.PutStr causes excessive memory allocations due to repeated slice expansions (#​44612)

  • receiver/splunk_hec: Support parsing JSON array payloads in Splunk HEC receiver (#​43941)

  • receiver/sshcheck: Promote sshcheck receiver to beta stability (#​41573)

  • receiver/yanggrpc: Promote to alpha stability (#​44783)

🧰 Bug fixes 🧰
  • exporter/elasticsearch: Fix hostname mapping in Elasticsearch exporter (#​44874)

    • The exporter now supports to map an otel field to an ecs field only if the ecs field is not already present. This is applied to host.hostname mapping.
  • processor/cumulativetodelta: Check whether bucket bounds are the same when verifying whether histograms are comparable (#​44793)

  • processor/cumulativetodelta: Fix logic handling ZeroThreshold increases for exponential histograms (#​44793)

  • processor/filter: Fix context initialization for metric/datapoint context (#​44813)

  • processor/k8sattributes: Fix k8sattr.labelsAnnotationsSingular.allow feature gate to affect config default tag names in addition to runtime extraction (#​39774)

  • processor/tail_sampling: Fix a memory leak introduced in 0.141.0 of the tail sampling processor when not blocking on overflow. (#​44884)

  • receiver/datadog: The db.instance tag of Datadog database client spans should be mapped to the OTel attribute db.namespace, not to db.collection.name. (#​44702)
    Compliance improvements on spans received via the Datadog receiver when applicable:

    • The db.instance tag is now mapped to the OTel attribute db.namespace instead of db.collection.name.
    • The db.sql.table tag is mapped to the OTel attribute db.collection.name.
    • The db.statement tag is mapped to the OTel attribute db.query.text.
  • receiver/datadog: Fix Datadog trace span counting so otelcol_receiver_accepted_spans is not under-reported (#​44865)
    Previously only the last payload's spans were counted, so the otelcol_receiver_accepted_spans metric could be lower than otelcol_exporter_sent_spans in pipelines where they should match.

  • receiver/github: Adds corrections to span kind for GitHub events when they are tasks. (#​44667)

  • receiver/googlecloudpubsub: Acknowledge messages at restart (#​44706)
    Rewrote the control flow loop so the acknowledgment of messages is more reliable. At stream restart, the messages
    ackIds are resent immediately without an explicit acknowledgment. Outstanding ackIds are only cleared when the
    acknowledgment is sent successfully.

  • receiver/googlecloudspanner: Fixed goroutine leaks in ttlcache lifecycle management and applied modernize linter fixes across multiple receivers. (#​44779)

    • Simplified cache lifecycle management by removing unnecessary WaitGroup complexity
    • Added goleak ignores for ttlcache goroutines that don't stop immediately after Stop()
  • receiver/kafka: Use max_fetch_size instead of default_fetch_size in franz-go client (#​43104)
    The franz-go Kafka consumer was incorrectly using default_fetch_size (a Sarama-specific setting) instead of max_fetch_size when configuring kgo.FetchMaxBytes.
    This fix ensures the correct parameter is used and adds validation to prevent max_fetch_size from being less than min_fetch_size.
    The default value for max_fetch_size has been changed from 0 (unlimited) to 1048576 (1 MiB) to maintain backward compatibility with the previous (incorrect) behavior.

  • receiver/prometheus: Fix HTTP response body leak in target allocator when fetching scrape configs fails (#​44921)
    The getScrapeConfigsResponse function did not close resp.Body on error paths.
    If io.ReadAll or yaml.Unmarshal failed, the response body would leak,
    potentially causing HTTP connection exhaustion.

  • receiver/prometheus: Fixes yaml marshaling of prometheus/common/config.Secret types (#​44445)

open-telemetry/opentelemetry-collector (go.opentelemetry.io/collector/cmd/builder)

v0.143.0

Compare Source

💡 Enhancements 💡
  • all: Update semconv import to 1.38.0 (#​14305)
  • exporter/nop: Add profiles support to nop exporter (#​14331)
  • pkg/pdata: Optimize the size and pointer bytes for pdata structs (#​14339)
  • pkg/pdata: Avoid using interfaces/oneof like style for optional fields (#​14333)

v0.142.0

Compare Source

💡 Enhancements 💡
  • exporter/debug: Add logging of dropped attributes, events, and links counts in detailed verbosity (#​14202)

  • extension/memory_limiter: The memorylimiter extension can be used as an HTTP/GRPC middleware. (#​14081)

  • pkg/config/configgrpc: Statically validate gRPC endpoint (#​10451)
    This validation was already done in the OTLP exporter. It will now be applied to any gRPC client.

  • pkg/service: Add support to disabling adding resource attributes as zap fields in internal logging (#​13869)
    Note that this does not affect logs exported through OTLP.


Configuration

📅 Schedule: Branch creation - At any time (no schedule defined), Automerge - At any time (no schedule defined).

🚦 Automerge: Enabled.

Rebasing: Whenever PR is behind base branch, or you tick the rebase/retry checkbox.

👻 Immortal: This PR will be recreated if closed unmerged. Get config help if that's undesired.


  • If you want to rebase/retry this PR, check this box

This PR was generated by Mend Renovate. View the repository job log.

@renovate renovate bot added area/dependency Dependency changes kind/chore Categorizes issue or PR as related to a chore. labels Dec 15, 2025
@renovate renovate bot requested a review from a team as a code owner December 15, 2025 21:40
@renovate renovate bot enabled auto-merge (squash) December 15, 2025 21:40
@renovate
Copy link
Contributor Author

renovate bot commented Dec 15, 2025

ℹ️ Artifact update notice

File name: go.mod

In order to perform the update(s) described in the table above, Renovate ran the go get command, which resulted in the following additional change(s):

  • 55 additional dependencies were updated

Details:

Package Change
github.com/ebitengine/purego v0.9.0 -> v0.9.1
github.com/hashicorp/go-version v1.7.0 -> v1.8.0
github.com/shirou/gopsutil/v4 v4.25.10 -> v4.25.11
github.com/spf13/cobra v1.10.1 -> v1.10.2
github.com/tklauser/go-sysconf v0.3.15 -> v0.3.16
github.com/tklauser/numcpus v0.10.0 -> v0.11.0
go.opentelemetry.io/collector/client v1.47.0 -> v1.48.0
go.opentelemetry.io/collector/component v1.47.0 -> v1.48.0
go.opentelemetry.io/collector/component/componentstatus v0.141.0 -> v0.142.0
go.opentelemetry.io/collector/component/componenttest v0.141.0 -> v0.142.0
go.opentelemetry.io/collector/config/configoptional v1.47.0 -> v1.48.0
go.opentelemetry.io/collector/config/configretry v1.47.0 -> v1.48.0
go.opentelemetry.io/collector/config/configtelemetry v0.141.0 -> v0.142.0
go.opentelemetry.io/collector/confmap v1.47.0 -> v1.48.0
go.opentelemetry.io/collector/confmap/xconfmap v0.141.0 -> v0.142.0
go.opentelemetry.io/collector/connector v0.141.0 -> v0.142.0
go.opentelemetry.io/collector/connector/connectortest v0.141.0 -> v0.142.0
go.opentelemetry.io/collector/connector/xconnector v0.141.0 -> v0.142.0
go.opentelemetry.io/collector/consumer v1.47.0 -> v1.48.0
go.opentelemetry.io/collector/consumer/consumererror v0.141.0 -> v0.142.0
go.opentelemetry.io/collector/consumer/consumererror/xconsumererror v0.141.0 -> v0.142.0
go.opentelemetry.io/collector/consumer/consumertest v0.141.0 -> v0.142.0
go.opentelemetry.io/collector/consumer/xconsumer v0.141.0 -> v0.142.0
go.opentelemetry.io/collector/exporter/exporterhelper v0.141.0 -> v0.142.0
go.opentelemetry.io/collector/exporter/exporterhelper/xexporterhelper v0.141.0 -> v0.142.0
go.opentelemetry.io/collector/exporter/exportertest v0.141.0 -> v0.142.0
go.opentelemetry.io/collector/exporter/xexporter v0.141.0 -> v0.142.0
go.opentelemetry.io/collector/extension v1.47.0 -> v1.48.0
go.opentelemetry.io/collector/extension/extensioncapabilities v0.141.0 -> v0.142.0
go.opentelemetry.io/collector/extension/extensiontest v0.141.0 -> v0.142.0
go.opentelemetry.io/collector/extension/xextension v0.141.0 -> v0.142.0
go.opentelemetry.io/collector/featuregate v1.47.0 -> v1.48.0
go.opentelemetry.io/collector/internal/fanoutconsumer v0.141.0 -> v0.142.0
go.opentelemetry.io/collector/internal/telemetry v0.141.0 -> v0.142.0
go.opentelemetry.io/collector/pdata v1.47.0 -> v1.48.0
go.opentelemetry.io/collector/pdata/pprofile v0.141.0 -> v0.142.0
go.opentelemetry.io/collector/pdata/testdata v0.141.0 -> v0.142.0
go.opentelemetry.io/collector/pdata/xpdata v0.141.0 -> v0.142.0
go.opentelemetry.io/collector/pipeline v1.47.0 -> v1.48.0
go.opentelemetry.io/collector/pipeline/xpipeline v0.141.0 -> v0.142.0
go.opentelemetry.io/collector/processor/processortest v0.141.0 -> v0.142.0
go.opentelemetry.io/collector/processor/xprocessor v0.141.0 -> v0.142.0
go.opentelemetry.io/collector/receiver/receivertest v0.141.0 -> v0.142.0
go.opentelemetry.io/collector/receiver/xreceiver v0.141.0 -> v0.142.0
go.opentelemetry.io/collector/service v0.141.0 -> v0.142.0
go.opentelemetry.io/collector/service/hostcapabilities v0.141.0 -> v0.142.0
go.opentelemetry.io/otel v1.38.0 -> v1.39.0
go.opentelemetry.io/otel/log v0.14.0 -> v0.15.0
go.opentelemetry.io/otel/metric v1.38.0 -> v1.39.0
go.opentelemetry.io/otel/sdk v1.38.0 -> v1.39.0
go.opentelemetry.io/otel/sdk/metric v1.38.0 -> v1.39.0
go.opentelemetry.io/otel/trace v1.38.0 -> v1.39.0
golang.org/x/net v0.47.0 -> v0.48.0
golang.org/x/sys v0.38.0 -> v0.39.0
golang.org/x/text v0.31.0 -> v0.32.0
File name: internal/tools/go.mod

In order to perform the update(s) described in the table above, Renovate ran the go get command, which resulted in the following additional change(s):

  • 10 additional dependencies were updated

Details:

Package Change
go.opentelemetry.io/collector/component v1.47.0 -> v1.48.0
go.opentelemetry.io/collector/confmap v1.47.0 -> v1.48.0
go.opentelemetry.io/collector/confmap/provider/fileprovider v1.47.0 -> v1.48.0
go.opentelemetry.io/collector/featuregate v1.47.0 -> v1.48.0
go.opentelemetry.io/collector/filter v0.141.0 -> v0.142.0
go.opentelemetry.io/collector/pdata v1.47.0 -> v1.48.0
go.opentelemetry.io/otel v1.38.0 -> v1.39.0
go.opentelemetry.io/otel/metric v1.38.0 -> v1.39.0
go.opentelemetry.io/otel/trace v1.38.0 -> v1.39.0
golang.org/x/text v0.31.0 -> v0.32.0
File name: processor/istioenrichmentprocessor/go.mod

In order to perform the update(s) described in the table above, Renovate ran the go get command, which resulted in the following additional change(s):

  • 15 additional dependencies were updated

Details:

Package Change
github.com/hashicorp/go-version v1.7.0 -> v1.8.0
go.opentelemetry.io/auto/sdk v1.1.0 -> v1.2.1
go.opentelemetry.io/collector/component/componentstatus v0.141.0 -> v0.142.0
go.opentelemetry.io/collector/consumer/xconsumer v0.141.0 -> v0.142.0
go.opentelemetry.io/collector/featuregate v1.47.0 -> v1.48.0
go.opentelemetry.io/collector/pdata/pprofile v0.141.0 -> v0.142.0
go.opentelemetry.io/collector/pdata/testdata v0.141.0 -> v0.142.0
go.opentelemetry.io/collector/pipeline v1.47.0 -> v1.48.0
go.opentelemetry.io/collector/processor/xprocessor v0.141.0 -> v0.142.0
go.opentelemetry.io/otel v1.38.0 -> v1.39.0
go.opentelemetry.io/otel/metric v1.38.0 -> v1.39.0
go.opentelemetry.io/otel/sdk v1.38.0 -> v1.39.0
go.opentelemetry.io/otel/sdk/metric v1.38.0 -> v1.39.0
go.opentelemetry.io/otel/trace v1.38.0 -> v1.39.0
golang.org/x/sys v0.37.0 -> v0.39.0
File name: processor/istionoisefilter/go.mod

In order to perform the update(s) described in the table above, Renovate ran the go get command, which resulted in the following additional change(s):

  • 15 additional dependencies were updated

Details:

Package Change
github.com/hashicorp/go-version v1.7.0 -> v1.8.0
go.opentelemetry.io/auto/sdk v1.1.0 -> v1.2.1
go.opentelemetry.io/collector/component/componentstatus v0.141.0 -> v0.142.0
go.opentelemetry.io/collector/consumer/xconsumer v0.141.0 -> v0.142.0
go.opentelemetry.io/collector/featuregate v1.47.0 -> v1.48.0
go.opentelemetry.io/collector/pdata/pprofile v0.141.0 -> v0.142.0
go.opentelemetry.io/collector/pdata/testdata v0.141.0 -> v0.142.0
go.opentelemetry.io/collector/pipeline v1.47.0 -> v1.48.0
go.opentelemetry.io/collector/processor/xprocessor v0.141.0 -> v0.142.0
go.opentelemetry.io/otel v1.38.0 -> v1.39.0
go.opentelemetry.io/otel/metric v1.38.0 -> v1.39.0
go.opentelemetry.io/otel/sdk v1.38.0 -> v1.39.0
go.opentelemetry.io/otel/sdk/metric v1.38.0 -> v1.39.0
go.opentelemetry.io/otel/trace v1.38.0 -> v1.39.0
golang.org/x/sys v0.37.0 -> v0.39.0
File name: processor/serviceenrichmentprocessor/go.mod

In order to perform the update(s) described in the table above, Renovate ran the go get command, which resulted in the following additional change(s):

  • 15 additional dependencies were updated

Details:

Package Change
github.com/hashicorp/go-version v1.7.0 -> v1.8.0
go.opentelemetry.io/auto/sdk v1.1.0 -> v1.2.1
go.opentelemetry.io/collector/component/componentstatus v0.141.0 -> v0.142.0
go.opentelemetry.io/collector/consumer/xconsumer v0.141.0 -> v0.142.0
go.opentelemetry.io/collector/featuregate v1.47.0 -> v1.48.0
go.opentelemetry.io/collector/pdata/pprofile v0.141.0 -> v0.142.0
go.opentelemetry.io/collector/pdata/testdata v0.141.0 -> v0.142.0
go.opentelemetry.io/collector/pipeline v1.47.0 -> v1.48.0
go.opentelemetry.io/collector/processor/xprocessor v0.141.0 -> v0.142.0
go.opentelemetry.io/otel v1.38.0 -> v1.39.0
go.opentelemetry.io/otel/metric v1.38.0 -> v1.39.0
go.opentelemetry.io/otel/sdk v1.38.0 -> v1.39.0
go.opentelemetry.io/otel/sdk/metric v1.38.0 -> v1.39.0
go.opentelemetry.io/otel/trace v1.38.0 -> v1.39.0
golang.org/x/sys v0.37.0 -> v0.39.0
File name: receiver/dummyreceiver/go.mod

In order to perform the update(s) described in the table above, Renovate ran the go get command, which resulted in the following additional change(s):

  • 13 additional dependencies were updated

Details:

Package Change
github.com/hashicorp/go-version v1.7.0 -> v1.8.0
go.opentelemetry.io/collector/consumer/consumererror v0.141.0 -> v0.142.0
go.opentelemetry.io/collector/consumer/xconsumer v0.141.0 -> v0.142.0
go.opentelemetry.io/collector/featuregate v1.47.0 -> v1.48.0
go.opentelemetry.io/collector/pdata/pprofile v0.141.0 -> v0.142.0
go.opentelemetry.io/collector/pipeline v1.47.0 -> v1.48.0
go.opentelemetry.io/collector/receiver/xreceiver v0.141.0 -> v0.142.0
go.opentelemetry.io/otel v1.38.0 -> v1.39.0
go.opentelemetry.io/otel/metric v1.38.0 -> v1.39.0
go.opentelemetry.io/otel/sdk v1.38.0 -> v1.39.0
go.opentelemetry.io/otel/sdk/metric v1.38.0 -> v1.39.0
go.opentelemetry.io/otel/trace v1.38.0 -> v1.39.0
golang.org/x/sys v0.37.0 -> v0.39.0
File name: receiver/kymastatsreceiver/go.mod

In order to perform the update(s) described in the table above, Renovate ran the go get command, which resulted in the following additional change(s):

  • 13 additional dependencies were updated

Details:

Package Change
github.com/hashicorp/go-version v1.7.0 -> v1.8.0
go.opentelemetry.io/collector/consumer/consumererror v0.141.0 -> v0.142.0
go.opentelemetry.io/collector/consumer/xconsumer v0.141.0 -> v0.142.0
go.opentelemetry.io/collector/featuregate v1.47.0 -> v1.48.0
go.opentelemetry.io/collector/pdata/pprofile v0.141.0 -> v0.142.0
go.opentelemetry.io/collector/receiver/receiverhelper v0.141.0 -> v0.142.0
go.opentelemetry.io/collector/receiver/xreceiver v0.141.0 -> v0.142.0
go.opentelemetry.io/otel v1.38.0 -> v1.39.0
go.opentelemetry.io/otel/metric v1.38.0 -> v1.39.0
go.opentelemetry.io/otel/sdk v1.38.0 -> v1.39.0
go.opentelemetry.io/otel/sdk/metric v1.38.0 -> v1.39.0
go.opentelemetry.io/otel/trace v1.38.0 -> v1.39.0
golang.org/x/sys v0.38.0 -> v0.39.0

@renovate renovate bot force-pushed the renovate/opentelemetry branch from 028b9e5 to 2710f72 Compare December 16, 2025 03:09
@renovate
Copy link
Contributor Author

renovate bot commented Dec 16, 2025

⚠️ Artifact update problem

Renovate failed to update an artifact related to this branch. You probably do not want to merge this PR as-is.

♻ Renovate will retry this branch, including artifacts, only when one of the following happens:

  • any of the package files in this branch needs updating, or
  • the branch becomes conflicted, or
  • you click the rebase/retry checkbox if found above, or
  • you rename this PR's title to start with "rebase!" to trigger it manually

The artifact failure details are included below:

File name: receiver/kymastatsreceiver/go.sum
Command failed: go get -t ./...
go: downloading github.com/open-telemetry/opentelemetry-collector-contrib/extension/k8sleaderelector v0.143.0
go: downloading go.opentelemetry.io/collector/scraper v0.143.0
go: downloading go.opentelemetry.io/collector/scraper/scraperhelper v0.143.0
go: downloading k8s.io/apimachinery v0.35.0
go: downloading k8s.io/client-go v0.35.0
go: downloading github.com/open-telemetry/opentelemetry-collector-contrib/pkg/golden v0.143.0
go: downloading github.com/open-telemetry/opentelemetry-collector-contrib/pkg/pdatatest v0.143.0
go: downloading github.com/open-telemetry/opentelemetry-collector-contrib/internal/k8sconfig v0.143.0
go: downloading go.opentelemetry.io/collector/receiver/receiverhelper v0.143.0
go: downloading k8s.io/utils v0.0.0-20251002143259-bc988d571ff4
go: downloading sigs.k8s.io/randfill v1.0.0
go: downloading k8s.io/klog/v2 v2.130.1
go: downloading github.com/open-telemetry/opentelemetry-collector-contrib/pkg/pdatautil v0.143.0
go: downloading k8s.io/kube-openapi v0.0.0-20250910181357-589584f1c912
go: downloading sigs.k8s.io/structured-merge-diff/v6 v6.3.0
go: downloading gopkg.in/evanphx/json-patch.v4 v4.13.0
go: downloading sigs.k8s.io/yaml v1.6.0
go: downloading golang.org/x/term v0.37.0
go: downloading github.com/openshift/client-go v0.0.0-20251015124057-db0dee36e235
go: downloading k8s.io/api v0.35.0
go: downloading gopkg.in/inf.v0 v0.9.1
go: downloading sigs.k8s.io/json v0.0.0-20250730193827-2d320260d730
go: downloading github.com/fxamacker/cbor/v2 v2.9.0
go: downloading github.com/google/gnostic-models v0.7.0
go: downloading golang.org/x/time v0.11.0
go: downloading golang.org/x/oauth2 v0.32.0
go: downloading github.com/x448/float16 v0.8.4
go: downloading github.com/go-openapi/jsonreference v0.21.0
go: downloading github.com/go-openapi/swag v0.23.1
go: downloading github.com/openshift/api v3.9.0+incompatible
go: downloading github.com/go-openapi/jsonpointer v0.21.1
go: downloading github.com/mailru/easyjson v0.9.0
go: downloading github.com/gogo/protobuf v1.3.2
go: downloading github.com/josharian/intern v1.0.0
go: downloading github.com/emicklei/go-restful/v3 v3.12.2
go: downloading github.com/open-telemetry/opentelemetry-collector-contrib v0.143.0
go: github.com/kyma-project/opentelemetry-collector-components/receiver/kymastatsreceiver tested by
	github.com/kyma-project/opentelemetry-collector-components/receiver/kymastatsreceiver.test imports
	github.com/open-telemetry/opentelemetry-collector-contrib/extension/k8sleaderelector/k8sleaderelectortest: cannot find module providing package github.com/open-telemetry/opentelemetry-collector-contrib/extension/k8sleaderelector/k8sleaderelectortest
go: warning: github.com/openshift/[email protected]+incompatible: retracted by module author: v3.9.0 is the only tag in openshift/api and it was created before go.mod was
go: to switch to the latest unretracted version, run:
	go get github.com/openshift/api@latest

@renovate renovate bot force-pushed the renovate/opentelemetry branch 6 times, most recently from c5a1212 to 2f28da3 Compare December 19, 2025 21:39
@renovate renovate bot force-pushed the renovate/opentelemetry branch 7 times, most recently from 6bb7dee to 2dd8ac1 Compare January 12, 2026 20:36
@renovate renovate bot force-pushed the renovate/opentelemetry branch from 2dd8ac1 to 4f5399b Compare January 13, 2026 09:30
@renovate renovate bot force-pushed the renovate/opentelemetry branch from 4f5399b to 8f6c9d8 Compare January 13, 2026 16:05
@renovate
Copy link
Contributor Author

renovate bot commented Jan 14, 2026

Edited/Blocked Notification

Renovate will not automatically rebase this PR, because it does not recognize the last commit author and assumes somebody else may have edited the PR.

You can manually request rebase by checking the rebase/retry box above.

⚠️ Warning: custom changes will be lost.

@TeodorSAP TeodorSAP added this to the 1.56.0 milestone Jan 14, 2026
Signed-off-by: Teodor-Adrian Mihaescu <[email protected]>
@renovate renovate bot merged commit 9ba1621 into main Jan 16, 2026
17 checks passed
@renovate renovate bot deleted the renovate/opentelemetry branch January 16, 2026 10:11
Sign up for free to join this conversation on GitHub. Already have an account? Sign in to comment

Labels

area/dependency Dependency changes kind/chore Categorizes issue or PR as related to a chore.

Projects

None yet

Development

Successfully merging this pull request may close these issues.

2 participants