File opentelemetry-collector-contrib.changes of Package opentelemetry-collector-contrib

-------------------------------------------------------------------
Wed Jan 21 06:28:25 UTC 2026 - Johannes Kastl <opensuse_buildservice@ojkastl.de>

- update to 0.144.0:
  The full changelog for this release can be found here:
  https://github.com/open-telemetry/opentelemetry-collector-contrib/releases/tag/v0.144.0
  The changelog for the core distribution, which is also included
  in the opentelemetry-collector-contrib distribution, can be found
  here:
  https://github.com/open-telemetry/opentelemetry-collector/releases/tag/v0.144.0
  * Breaking changes
    - exporter/elasticsearch: Remove ecs mode span enrichment for
      span.action, span.message.queue.name, and
      transaction.message.queue.name (#45014)
      The removed span enrichments have been moved to the
      github.com/elastic/opentelemetry-collector-components/processor/elasticapmprocessor.
      It is recommended to use the
      github.com/elastic/opentelemetry-collector-components/processor/elasticapmprocessor
      when using mapping mode ecs to ensure index documents contain
      all required Elastic fields to power the Kibana UI.
    - exporter/kafka: Remove Sarama producer implementation
      (#44565)
      The Sarama-based Kafka producer has been removed from
      kafkaexporter.
      Feature gate exporter.kafkaexporter.UseFranzGo has also been
      removed since Franz-go is now the only supported Kafka
      client.
    - processor/tail_sampling: The deprecated invert decisions are
      disabled by default. (#44132)
      Drop policies should be used instead of invert decisions for
      explicitly not sampling a trace.
      If the deprecated behavior is required while migrating to
      drop policies, disable the
      processor.tailsamplingprocessor.disableinvertdecisions
      feature gate.
    - receiver/kafka: Remove Sarama consumer implementation and
      default_fetch_size configuration option (#44564)
      The Sarama-based Kafka consumer has been removed from
      kafkareceiver.
      The default_fetch_size configuration option has also been
      removed as it was only used by the Sarama consumer.
      Feature gate receiver.kafkareceiver.UseFranzGo has also been
      removed since Franz-go is now the only supported Kafka
      client.
  * Deprecations
    - exporter/elasticsearch: Deprecate mapping::mode config option
      (#45246)
      The mapping::mode config option is now deprecated and will
      soon be ignored. Instead, use the X-Elastic-Mapping-Mode
      client metadata key (via headers_setter extension) or the
      elastic.mapping.mode scope attribute to control the mapping
      mode per-request. See the README for migration instructions.
  * New components
    - processor/lookup: Add skeleton for external lookup enrichment
      processor (#41816)
      Adds the initial skeleton for a lookup processor that
      performs external lookups to enrich telemetry signals.
      Also includes source abstraction with factory pattern, noop
      source for testing, and cache wrapper utility.
  * Enhancements
    - cmd/schemagen: Extend schemagen script with ability to handle
      external refs. (#42214)
      The schemagen tool has been enhanced to support external
      references when generating configuration schemas for
      OpenTelemetry Collector components. This improvement allows
      the tool to accurately reference and include schema
      definitions from external packages, facilitating better
      modularity and reuse of configuration schemas across
      different components.
    - cmd/schemagen: Fixes for schemagen to handle common issues
      with receiver components schemas. (#42214)
      Fix common issues discovered while using schemagen with
      receiver components:
      - Missing config.go file (e.g. namedpipereceiver)
      - Parsing obsolete types (e.g. nsxtreceiver)
      - Unable to embed fields with squash tag and not exported
        internal type (e.g. huaweicloudcesreceiver)
    - cmd/telemetrygen: Add batching capability to metrics and
      traces (#42322)
      - Changed traces batching to have configurable batch size and
        match batch flag.
      - Added batching to metrics.
      - Added batching to logs.
    - exporter/azureblob: Add timezone option for formatting blob
      names in azureblob exporter. (#43752)
    - exporter/elasticsearch: Remove go-elasticsearch dependency to
      reduce binary size (#45104)
      This leads to a 19MB size reduction in contrib distribution
    - exporter/googlecloudstorage: Add support for time
      partitioning (#44889)
    - exporter/opensearch: Add support for multiple variables to
      build index names (#42585)
    - exporter/sumologic: Add decompose_otlp_summaries
      configuration option to decompose OTLP Summary metrics into
      individual gauges and counters (#44737)
    - extension/awslogs_encoding: Optimize CloudTrail logs
      unmarshaling for memory usage (#45180)
    - processor/k8sattributes: Bumnp version of semconv to v1.39.0
      (#45447)
    - processor/redaction: Add sanitize_span_name option to URL and
      DB sanitization configs. (#44228)
    - processor/redaction: Add ignored_key_patterns configuration
      option to allow ignoring keys by regex pattern (#44657)
    - processor/resourcedetection: Add optional docker attributes
      (#44898)
      Add container.image.name and container.name optional resource
      attributes with the docker detector.
    - processor/tail_sampling: Provide an option,
      decision_wait_after_root_received, to make quicker decisions
      after a root span is received. (#43876)
    - receiver/azureeventhub: Add support for azure auth when
      feature gate receiver.azureeventhubreceiver.UseAzeventhubs is
      enabled. (#40711)
    - receiver/prometheus: receiver/prometheus now associates
      scraped '_created' text lines as the created timestamp of its
      metric family rather than its own metric series, as defined
      by the OpenMetricsText spec (#45291)
    - receiver/prometheus: Add comprehensive troubleshooting and
      best practices guide to Prometheus receiver README (#44925)
      The guide includes common issues and solutions, performance
      optimization strategies, production deployment best
      practices, monitoring recommendations, and debugging tips.
    - receiver/prometheusremotewrite: Replace labels.Map()
      iteration with direct label traversal to eliminate
      intermediate map allocations. (#45166)
  * Bug fixes
    - exporter/kafka: franz-go: Exclude non-produce metrics from
      kafka_exporter_write_latency and kafka_exporter_latency
      (#45258)
    - exporter/opensearch: Fix dynamic log index feature putting
      logs in wrong index (#43183)
    - exporter/prometheusremotewrite: Prevent duplicate samples by
      allowing the WAL to be empty (#41785)
      Since the WAL is being truncated after every send it's likely
      the reader and writer are in sync. Since WAL was not allowed
      to be empty, the reader would always re-read previously
      delivered samples causing duplicate data to be sent
      continuously.
    - extension/datadog: Datadog extension no longer throws an
      error for missing extensions when getting a list of active
      components, and now populates active components even when
      missing go mod/version info. (#45358, #45460)
    - extension/file_storage: Handle filename too long error in
      file storage extension by using the sha256 of the attempted
      filename instead. (#44039)
    - extension/text_encoding: Avoid spurious marshalling
      separators at end of lines (#42797)
      Previously, text_encoding would append the marshalling
      separator to the end of each log record, potentially
      resulting in double-newlines between blocks of records.
    - extension/text_encoding: Fix an issue where
      marshalling/unmarshalling separators were ignored (#42797)
    - pkg/kafka/configkafka: Fix consumer group rebalance strategy
      validation (#45268)
    - pkg/ottl: Fix numeric parsing to correctly handle signed
      numbers in math expressions. (#45222)
      The OTTL math expression parser did not correctly handle
      unary signs for plus and minus. Expressions like 3-5 would
      not parse correctly without inserting spaces to make it
      "3 - 5". This change moves the sign handling out of the lexer
      and into the parser.
    - pkg/ottl: Handle floating constants with decimal point but no
      fraction. (#45222)
      Floating point constants that had a decimal point but no
      fractional digits (e.g., "3.") were not handled properly and
      could crash the parser. These are now parsed as valid
      floating point numbers.
    - pkg/stanza: Fix Windows UNC network path handling in filelog
      receiver (#44401)
      The filelog receiver now correctly handles Windows UNC
      network paths (e.g., \server\share\logs*.log).  Previously,
      the receiver could list files from network shares but failed
      to open them due to path corruption during normalization.
      This fix converts UNC paths to Windows extended-length format
      (\?\UNC\server\share\path) which is more reliable and not
      affected by filepath.Clean() issues.
    - pkg/stanza: Ensure container parser respects the if condition
      and on_error settings when format detection fails (#41508)
    - processor/resourcedetection: Prevent the resource detection
      processor from panicking when detectors return a zero-valued
      pdata resource. (#41934)
    - processor/resourcedetection: Fix nil pointer panic when HTTP
      client creation fails in Start method (#45220)
    - receiver/awslambda: Fix S3 key usage in AWS Lambda Receiver
      (#45364)
    - receiver/datadog: Fix service check endpoint to handle both
      array and single object payloads (#44986)
      The /api/v1/check_run endpoint now uses defensive parsing to
      handle both array [{...}] and single object {...} payloads.
      This fixes intermittent unmarshal errors when Datadog agent
      sends connectivity health checks.
    - receiver/jmx: Enable initial_delay and collection_interval
      settings via scraper helper (#44492)
    - receiver/libhoney: Improve msgpack decoding to handle ints or
      uints (#45273)
    - receiver/postgresql: Fix query plan EXPLAIN to use raw query
      with $N placeholders instead of obfuscated query with ?
      placeholders (#45190)
      Previously, the EXPLAIN query was using obfuscated queries
      with ? placeholders, which PostgreSQL does not recognize.
      Now uses the raw query with $1, $2 placeholders that
      PostgreSQL expects.
    - receiver/prometheusremotewrite: Fix silent data loss when
      consumer fails by returning appropriate HTTP error codes
      instead of 204 No Content. (#45151)
      The receiver was sending HTTP 204 No Content before calling
      ConsumeMetrics(), causing clients to believe data was
      successfully delivered even when the consumer failed.  Now
      returns 400 Bad Request for permanent errors and 500 Internal
      Server Error for retryable errors, as per the Prometheus
      Remote Write 2.0 specification.
    - receiver/sqlserver: Accuracy improvements for top-query
      metrics (#45228)
      SQLServer metrics reporting is improved by reducing the
      warm-up delay and providing accurate insights sooner.

-------------------------------------------------------------------
Wed Jan 14 10:15:19 UTC 2026 - Johannes Kastl <opensuse_buildservice@ojkastl.de>

- update to 0.143.0:
  The full changelog for this release can be found here:
  https://github.com/open-telemetry/opentelemetry-collector-contrib/releases/tag/v0.143.0
  The changelog for the core distribution, which is also included
  in the opentelemetry-collector-contrib distribution, can be found
  here:
  https://github.com/open-telemetry/opentelemetry-collector/releases/tag/v0.143.0
  * 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)

-------------------------------------------------------------------
Tue Dec 16 09:24:10 UTC 2025 - Johannes Kastl <opensuse_buildservice@ojkastl.de>

- update to 0.142.0:
  The full changelog for this release can be found here:
  https://github.com/open-telemetry/opentelemetry-collector-contrib/releases/tag/v0.142.0
  The changelog for the core distribution, which is also included
  in the opentelemetry-collector-contrib distribution, can be found
  here:
  https://github.com/open-telemetry/opentelemetry-collector/releases/tag/v0.142.0
  * 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)

-------------------------------------------------------------------
Fri Dec 12 12:32:26 UTC 2025 - Johannes Kastl <opensuse_buildservice@ojkastl.de>

- update to 0.141.0:
  The full changelog for this release can be found here:
  https://github.com/open-telemetry/opentelemetry-collector-contrib/releases/tag/v0.141.0
  The changelog for the core distribution, which is also included
  in the opentelemetry-collector-contrib distribution, can be found
  here:
  https://github.com/open-telemetry/opentelemetry-collector/releases/tag/v0.141.0
  * Breaking changes
    - all: fix pprofile DurationNano to be a TypeUint64 (#44397)
    - cmd/otelcontribcol: Removing unmaintained component
      exporter/carbon (#38913)
    - connector/spanmetrics: Add a feature gate to use the latest
      semantic conventions for the status code attribute on
      generated metrics. | This feature gate will replace the
      status.code attribute on the generated RED metrics with
      otel.status_code. | It will also replace the values
      STATUS_CODE_ERROR and STATUS_CODE_OK with ERROR and OK to
      align with the latest conventions. (#42103)
    - This change is made to align with the latest semantic
      conventions. | The feature gate is disabled by default, but
      can be enabled with --feature-gates
      spanmetrics.statusCodeConvention.useOtelPrefix | or
      explicitly disabled with --feature-gates
      -spanmetrics.statusCodeConvention.useOtelPrefix.
    - exporter/clickhouse: Add EventName column to logs table
      (#42584)
    - This column is optional for existing deployments. See project
      README for notes on how to upgrade your logs table.
    - exporter/clickhouse: Add columns for tracking JSON paths in
      logs + traces (#43109)
    - The JSON columns now include a helper column for keeping
      track of what keys are inside of the JSON object.
    - This change also introduces schema detection logic to reduce
      breaking changes whenever a column is added.
    - Existing users can enable these features by manually adding
      all the new columns to their table.
    - exporter/kafka: exporter.kafkaexporter.UseFranzGo feature
      gate moved to Stable and is now always enabled (#44565)
    - The franz-go client is now the default and only Kafka client
      library for the Kafka exporter.
    - The feature gate exporter.kafkaexporter.UseFranzGo has been
      promoted to Stable status and cannot be disabled.
    - Users can no longer opt out of using the franz-go client in
      favor of the legacy Sarama client.
    - The Sarama client and the feature gate will be removed
      completely after v0.143.0.
    - extension/docker_observer: Upgrading Docker API version
      default from 1.24 to 1.44 (#44279)
    - pkg/ottl: Type of field profile.duration changes from
      time.Time to int64. (#44397)
    - receiver/azureeventhub: Promote Feature Gate
      receiver.azureeventhubreceiver.UseAzeventhubs to Beta
      (#44335)
    - receiver/k8slog: Update k8slogreceiver code-owners status and
      mark as unmaintained (#44078)
    - receiver/kafka: Remove deprecated topic and encoding (#44568)
    - receiver/kafka: receiver.kafkareceiver.UseFranzGo feature
      gate moved to Stable and is now always enabled (#44564)
    - The franz-go client is now the default and only Kafka client
      library for the Kafka receiver.
    - The feature gate receiver.kafkareceiver.UseFranzGo has been
      promoted to Stable status and cannot be disabled.
    - Users can no longer opt out of using the franz-go client in
      favor of the legacy Sarama client.
    - The Sarama code and the feature gate will be removed
      completely after v0.143.0.
  * Deprecations
    - receiver/prometheus: Add feature gate for extra scrape
      metrics in Prometheus receiver (#44181)
    - deprecation of extra scrape metrics in Prometheus receiver
      will be removed eventually.
  * New components
    - connector/metricsaslogs: Add connector to convert metrics to
      logs (#40938)
    - extension/azure_encoding: [extension/azure_encoding]
      Introduce new component (#41725)
    - This change includes only overall structure, readme and
      configuration for a new component
    - receiver/awslambda: Implementation of the AWS Lambda
      Receiver. (#43504)
    - receiver/macosunifiedlogging: Add a new receiver for macOS
      Unified Logging. (#44089)
    - receiver/macosunifiedlogging: Implementation of the macOS
      Unified Logging Receiver. (#44089)
  * Enhancements
    - connector/count: Support all attribute types in the count
      connector (#43768)
    - connector/routing: Avoid extra copy of all data during
      routing (#44387)
    - exporter/awss3: Support compression with ZSTD (#44542)
    - exporter/azuremonitor: Add additional mapping of standard
      OTel properties to builtin Application Insights properties
      (#40598)
    - exporter/cassandra: cassandraexporter: Upgrade cassandra
      library version (#43691)
    - Upgrade cassandra library version.
    - exporter/elasticsearch: Updates the ecs mode span encode to
      include the span.kind attribute (#44139)
    - exporter/elasticsearch: add missing fields to struct so that
      they are populated in the respective elasticsearch index
      (#44234)
    - exporter/file: Add create_directory and directory_permissions
      options; exporter can automatically create parent directories
      (also honored by group_by) with configurable permissions.
      (#44280)
      - New config: create_directory (bool) and
        directory_permissions (octal string, e.g. "0755").
      - When enabled, the exporter creates the parent directory of
        path on start.
      - group_by uses the configured permissions when creating
        per-attribute directories.
    - exporter/googlecloudpubsub: Update to
      cloud.google.com/go/pubsub/v2. (#44465)
    - exporter/googlecloudpubsub: Add encoding extension support
      (#42270, #41834) Add encoding extension support for the
      payload on Pub/Sub. As having custom extensions means the
      Pub/Sub attributes cannot be auto discovered additional
      functionality has been added to set the message attributes.
    - exporter/prometheus: Add without_scope_info to omit otel
      scope info from prometheus exporter metrics (#43613)
    - exporter/prometheus: Add support to exponential histograms
      (#33703)
    - exporter/signalfx: Makes sending tags from SignalFx Exporter
      configurable (#43799) New optional configuration flag
      drop_tags has been added to SignalFx Exporter to allow users
      to disable tag metadata sending.  This feature has been
      introduced due to a common issue among Splunk Observability
      customers when they're receiving more tags than allowed
      limit.
    - extension/awslogs_encoding: Add more fields to AWS NLB logs
      at ELB extension (#43757)
    - extension/googlecloudlogentry_encoding: Add support for Proxy
      Network Load Balancer logs (#44099) Add support for Proxy
      Network Load Balancer logs to the Google Cloud log entry
      encoding extension.  This includes adding support for the new
      gcp.load_balancing.proxy_nlb attributes.  See the README for
      more details.
    - extension/headers_setter: Add support for chaining with other
      auth extensions via additional_auth configuration parameter.
      This allows combining multiple authentication methods, such
      as OAuth2 for bearer token authentication and custom headers
      for additional metadata. (#43797)
      The additional_auth parameter enables the headers_setter
      extension to work in conjunction with other authentication
      extensions like oauth2client. The additional auth extension
      is called first to apply its authentication, then
      headers_setter adds its configured headers on top.
    - extension/observer: Add container name, container ID, and
      container image to port endpoint (#41309)
    - pkg/ottl: Add ParseSeverity function to define mappings for
      log severity levels. (#35778)
    - pkg/ottl: Introduce CommunityID function to generate network
      hash (20-byte SHA1 digest) flow from the given source and
      destination {IP, port}, optionally protocol and seed values.
      (#34062)
    - pkg/ottl: Expand usage of literal into typed getters and
      avoid unnecessary work (#44201)
    - pkg/ottl: SliceToMap: add support to convert slices with
      non-map elements to maps (#43099)
    - processor/cumulativetodelta: Add support for exponential
      histograms (#44106)
    - processor/resourcedetection: Use osProfile.computerName for
      setting host.name in Azure resource detection processor
      (#43959)
    - processor/resourcedetectionprocessor/oraclecloud: Oracle
      Cloud (OCI) resource detection processor now differentiates
      between running off-platform (expected not to work), and
      encountering an error when running on-platform (expected to
      work) (#42794)
      - Collectors not running on Oracle Cloud return an empty
        resource and no error, since we don't expect this case to
        work.
      - If the Oracle Cloud platform is detected but metadata fetch
        fails, the error is now logged and signaled to the
        processor, since we do expect this case to work.
    - processor/tail_sampling: Add bytes_limiting policy type,
      sample based on the rate of bytes per second using a token
      bucket algorithm. (#42509)
    - processor/tail_sampling: Adaptive expected_new_traces_per_sec
      to improve performance lower bound (#43561)
    - receiver/googlecloudpubsub: Update to
      cloud.google.com/go/pubsub/v2. (#44466)
    - receiver/googlecloudpubsub: Adjusts the subscription regex to
      accommodate new project naming used for Google Trusted
      Partner Clouds. (#43988)
    - receiver/googlecloudpubsubpush: Add telemetry metrics to the
      component. (#44422)
    - receiver/googlecloudpubsubpush: Add implementation to
      googlecloudpubsubpush receiver. (#44101)
    - receiver/k8s_events: Allow more event types like Error and
      Critical which are typically used by applications when
      creating events. (#43401)
    - k8seventsreceiver allows event types Error and Critical in
      addition to the current Normal and Warning event types.
    - receiver/kafka: Add support for exclude topics when consuming
      topics with a regex pattern (#43782)
    - receiver/prometheus: Support JWT Profile for Authorization
      Grant (RFC 7523 3.1) (#44381)
    - receiver/redis: Add support for redis.mode and
      redis.sentinel.* metrics (#42365)
    - receiver/systemd: Promote systemd receiver to alpha (#33532)
    - receiver/systemd: Scrape unit CPU time (#44646)
  * Bug fixes
    - cmd/opampsupervisor: Fix supervisor passthrough logs overflow
      by using bufio.Reader instead of bufio.Scanner (#44127)
    - cmd/opampsupervisor: Fix data race in remoteConfig field by
      using atomic pointer for thread-safe concurrent access
      (#44173)
    - connector/routing: Fix routing to default route when error
      occurs (#44386) Before we used to send everything (even
      records match without error) to the default pipeline, | after
      this change only entries that return error will be "ignored"
      and if no other rule in the | table picks them will be sent
      to the default rule.
    - exporter/clickhouse: Fix TLS configuration being ignored when
      only ca_file is provided and no cert/key files are set.
      (#43911) This change ensures server-side TLS validation works
      correctly even without client certificates.
    - exporter/elasticsearch: Fix CloudID parsing to correctly
      handle Elastic Cloud IDs when sent with multiple dollar sign
      separators (#44306) The CloudID decoder was incorrectly using
      strings.Cut() which only splits on the first delimiter,
      causing malformed URLs when the decoded CloudID contained
      multiple $ separators. Changed to use strings.Split() to
      match the reference implementation from go-elasticsearch
      library.
    - extension/awslogs_encoding: address the SIGSEGV occurring
      when processing control_message messages. (#44231)
    - extension/awslogs_encoding: Fix ALB log request_line parsing
      for valid formats and avoid errors (#44233)
    - pkg/ottl: Fixed OTTL grammar to treat the string literal
      "nil" as ordinary text instead of a nil value. (#44374)
    - pkg/ottl: Return errors when OTTL context setters receive
      values of the wrong type (#40198) Introduces
      ctxutil.ExpectType and updates log, metric, and scope setters
      to surface type assertion failures.
    - pkg/ottl: Fix TrimPrefix/TrimSuffix function name. (#44630)
      This change also adds a featuregate "ottl.PanicDuplicateName"
      to control the behavior of panicing when duplicate names are
      registered for the same function.
    - processor/k8sattributes: k8sattributesprocessor now respects
      semantic convention resolution order for service.namespace
      (#43919) Previously, when service.namespace was included in
      the extract metadata configuration, the processor would
      incorrectly allow k8s.namespace.name to override explicitly
      configured service namespace values from OpenTelemetry
      annotations (e.g.,
      resource.opentelemetry.io/service.namespace). Now the
      processor correctly follows the semantic convention
      resolution order, where annotation values take precedence
      over inferred Kubernetes namespace names.
    - processor/k8sattributes: Fix incorrect pod metadata
      assignment when host.name contains a non-IP hostname (#43938)
      The processor now correctly validates that host.name contains
      an IP address before using it for pod association.
      Previously, textual hostnames were incorrectly used for pod
      lookups, causing spans and metrics from one workload to
      receive metadata from unrelated pods that shared the same
      hostname.
    - receiver/awsxray: Fix incorrect span kind when translating
      X-Ray segment to trace span with parent ID (#44404)
    - receiver/azuremonitor: Collect only supported aggregations
      for each metric (501 not implemented issue) (#43648) Some
      metrics were not collected because we requested all available
      aggregation types. This led to 501 errors, as the Azure API
      returned responses indicating that certain aggregations were
      not implemented.  We now use the supported aggregations field
      from each metric definition to filter and request only the
      aggregations that are actually supported.  The user can
      expect less 501 errors in the logs and more metrics in the
      results.
    - receiver/datadog: Utilizes thread safe LRU packages (#42644)
    - receiver/github: Adds corrections to span times when GitHub
      sends incorrect start and end times. (#43180)
    - receiver/libhoney: Allow single events and uncompressed
      requests (#44026, #44010) The receiver required events to be
      wrapped in an array before. The single-event format was
      allowed by Honeycomb's API so we have added it here.  This
      fix also allows uncompressed requests again
    - receiver/sqlquery: Fix a bug in the sqlqueryreceiver where an
      error is returned if the query returned a null value. This is
      now logged as a warning and logs with null values are
      ignored. (#43984)
    - receiver/systemd: This allows systemd receiver to be used in
      collector config (#44420)

-------------------------------------------------------------------
Thu Nov 20 09:43:36 UTC 2025 - Johannes Kastl <opensuse_buildservice@ojkastl.de>

- update to 0.140.0:
  The full changelog for this release can be found here:
  https://github.com/open-telemetry/opentelemetry-collector-contrib/releases/tag/v0.140.0
  The changelog for the core distribution, which is also included
  in the opentelemetry-collector-contrib distribution, can be found
  here:
  https://github.com/open-telemetry/opentelemetry-collector/releases/tag/v0.140.0
  * Breaking changes
    - all: Latest supported k8s version is moved from 1.17 to 1.21.
      (#43891)
    - cmd/otelcontribcol: Removing unmaintained component
      extension/ecstaskobserver (#43818)
    - exporter/elasticsearch: Upgrade profiles proto to 1.9.0
      (#44031)
    - extension/googlecloudlogentry_encoding: Parse cloud armor
      logs into log record attributes instead of placing it in the
      body as is. (#43389)
    - pkg/ottl: Upgrade profiles proto to 1.9.0 (#44031)
    - processor/filter: Upgrade profiles proto to 1.9.0 (#44031)
    - processor/tail_sampling: Replace policy latency metric with
      total time spent executing specific sampling policy. (#42620)
    - The existing latency metric was misleading and expensive to
      compute. The new cpu time metric can be used to find
      expensive policies instead.
    - receiver/pprof: Upgrade profiles proto to 1.9.0 (#44031)
    - receiver/prometheus: The prometheus receiver no longer
      adjusts the start time of metrics by default. (#43656)
    - Disable the
      receiver.prometheusreceiver.RemoveStartTimeAdjustment |
      feature gate to temporarily re-enable this functionality.
      Users that need | this functionality should migrate to the
      metricstarttime processor, | and use the true_reset strategy
      for equivalent behavior.
  * New components
    - pkg/translator/pprof: move code from receiver/pprofreceiver
      to pkg/translator/pprof (#43975)
    - pprof is an established format. For a better integration with
      OTel move code to a dedicated component.
    - receiver/awslambda: Add scaffolding for the new awslambda
      receiver, for event-triggered receiving of data from S3 and
      CloudWatch. (#43504)
    - receiver/googlecloudpubsubpush: Add skeleton to the google
      pub sub push receiver. (#43503)
    - receiver/systemd: Report active state of systemd units.
      (#33532)
    - receiver/yanggrpc: New component YANG gRPC (#43840)
  * Enhancements
    - exporter/azureblob: Added serial_num_enabled and
      time_parser_enabled options to blob_name_format in Azure Blob
      Exporter to control random serial number appending and time
      parsing behavior. (#43603)
    - exporter/elasticsearch: Add support for latest OTEL SemConv
      version and fix Elasticsearch exporter ECS mapping for
      message.destination.name which is different for Elastic spans
      or transactions (#43805, #43806)
    - exporter/elasticsearch: Add helpful error hint for
      illegal_argument_exception when using OTel mapping mode with
      Elasticsearch < 8.12 (#39282)
    - When using OTel mapping mode (default from v0.122.0) with
      Elasticsearch versions < 8.12,
    - the exporter now provides a more descriptive error message
      explaining that OTel mapping mode
    - requires Elasticsearch 8.12+ and suggests either upgrading
      Elasticsearch or using a different
    - mapping mode. This helps users who encounter the generic
      illegal_argument_exception error
    - understand the root cause and resolution steps.
    - exporter/googlecloudstorage: Add googlecloudstorageexporter
      to the contrib distribution (#44063)
    - exporter/kafka: Adds a new configuration option to the Kafka
      exporter to control the linger time for the producer.
      (#44075)
    - Since franz-go now defaults to 10ms, it's best to allow users
      to configure this option to suit their needs.
    - extension/datadog: Adds collector resource attributes to
      collector metadata payload (#43979)
    - The Collector's resource attributes can be set under
      service::telemetry::resource.
    - extension/encoding: Add most of the AWS ELB fields to the
      AWSLogsEncoding. (#43757)
    - receiver/datadog: Adding log telemetry functionality to the
      existing datadog receiver component. (#43841)
    - receiver/github: Add include_span_events for GitHub Workflow
      Runs and Jobs for enhanced troubleshooting (#43180)
    - receiver/journald: Add root_path and journalctl_path config
      for running journald in a chroot (#43731)
    - receiver/prometheusremotewrite: Skip emitting empty metrics.
      (#44149)
    - receiver/prometheusremotewrite: prometheusremotewrite
      receiver now accepts metric type unspcified histograms.
      (#41840)
    - receiver/redis: Add redis metrics that are present in
      telegraf: cluster_enabled, tracking_total_keys,
      used_memory_overhead, used_memory_startup (#39859)
    - receiver/splunkenterprise: added pagination for search cases
      which may return more than the default 100 results (#43608)
    - receiver/webhookevent: Allow configuring larger webhook body
      size (#43544)
    - The receiver allows configuration a larger body buffer if
      needed.
    - It also returns an error if the body exceeds the configured
      limit.
  * Bug fixes
    - cmd/opampsupervisor: Redacts HTTP headers in debug message
      (#43781)
    - connector/datadog: Datadog connector no longer stalls after a
      downstream component errors (#43980)
    - exporter/awsxray: Fix conversion of the inProgress attribute
      into a Segment field instead of metadata (#44001)
    - exporter/datadog: Fix a panic from a race condition between
      exporter shutdown and trace export (#44068)
    - exporter/elasticsearch: Handle empty histogram buckets to not
      result in an invalid datapoint error. (#44022)
    - exporter/elasticsearch: Update the ecs mode span encode to
      correctly encode span.links ids as trace.id and span.id
      (#44186)
    - exporter/elasticsearch: Improve error message when an invalid
      Number data point is received. (#39063)
    - exporter/loadbalancing: Ensure loadbalancing child exporters
      use the OTLP type so backend creation succeeds (#43950)
    - exporter/stef: Fix STEF connection creation bug (#44048)
    - On some rare occasions due to a bug STEF exporter was
      incorrectly disconnecting just | created STEF connection
      causing connection error messages in the log. This fixes the
      bug.
    - extension/bearertokenauth: Remove error messages fsnotify:
      can't remove non-existent watch when watching kubernetes SA
      tokens. (#44104)
    - processor/k8sattributes: The fix is on k8sattributes
      processor to only set k8s.pod.ip attribute when it is
      requested in the extract.metadata configuration. (#43862)
    - Previously, the k8s.pod.ip attribute was always populated,
      even if it was not included in the extract.metadata list.
    - This fix ensures that k8s.pod.ip is set only when explicitly
      requested, aligning the processor behavior with configuration
      expectations.
    - receiver/ciscoos: Rename receiver component name from
      ciscoosreceiver to ciscoos to follow naming conventions.
      (#42647)
    - Users must update their collector configuration from
      ciscoosreceiver/device to ciscoos/device.
    - This is acceptable as the component is in alpha stability.
    - receiver/sqlserver: Resolved inaccurate data sampling in
      query metrics collection. (#44303)
    - receiver/sqlserver: Fix incorrect logic in query metrics
      window calculation. (#44162)
    - receiver/sqlserver: Fixed a bug in effective value
      calculation of lookback time in top query collection.
      (#43943)
    - receiver/windowsservice: Fixed an error where incorrect
      permissions and bad error handling were causing the receiver
      to stop reporting metrics (#44087)

-------------------------------------------------------------------
Sat Nov  8 19:51:24 UTC 2025 - Johannes Kastl <opensuse_buildservice@ojkastl.de>

- update to 0.139.0:
  The full changelog for this release can be found here:
  https://github.com/open-telemetry/opentelemetry-collector-contrib/releases/tag/v0.139.0
  The changelog for the core distribution, which is also included
  in the opentelemetry-collector-contrib distribution, can be found
  here:
  https://github.com/open-telemetry/opentelemetry-collector/releases/tag/v0.139.0
  * Breaking changes
    - receiver/sqlserver: Standardizing the unit interpretation of
      lookback_time in config for top query collection (#43573)
    - Like other interval related config values, lookback_time also
      should suffix 's' to represent time in seconds.
  * Enhancements
    - connector/count: Support for setting attributes from scope
      and resource levels. Precedence order: Span (or Log Record,
      etc.) > Scope attributes > Resource attributes. (#41859)
    - connector/spanmetrics: Add add_resource_attributes opt-in
      config option to keep resource attributes in generated
      metrics (#43394)
    - This configuration option allows users to override the
      connector.spanmetrics.excludeResourceMetrics feature gate
    - and restore the old behavior of including resource attributes
      in metrics. This is needed for customers whose
    - existing dashboards depend on resource attributes being
      present in the generated metrics.
    - exporter/azuremonitor: Add authenticator extension support to
      the Azure Monitor exporter. (#41004)
    - exporter/azuremonitor: Updated azure monitor exporter to use
      OTEL semantic conventions 1.34.0 (#41289)
    - exporter/datadog: Disabled "Successfully posted payload" log
      that was emitted every 500 metric exports (#43594, #43879)
    - exporter/datadog: Set sending queue batch default values to
      match exporter helper default: flush timeout 200ms, min size
      8192, no max size. (#43848)
    - The default values now match exactly the default in batch
      processor.
    - exporter/elasticsearch: Update Elasticsearch exporter ECS
      mapping mode encoder semantic convention mappings (#43805)
    - exporter/googlecloudstorage: Implement skeleton of
      googlecloudstorage exporter. (#43123)
    - exporter/influxdb: Fix InfluxDB Exporter precision
      configuration to allow choice of precision instead of
      hardcoding 'ns'. (#43645)
    - extension/awslogs_encoding: Enhance CloudTrail log parsing by
      adding support for digest files (#43403)
    - extension/awslogs_encoding: Add support for AWS Network
      Firewall logs. (#43616)
    - The AWS Logs Encoding Extension now supports unmarshaling AWS
      Network Firewall logs into OpenTelemetry logs format.
    - extension/awslogs_encoding: Enhance CloudTrail log parsing by
      adding extra fields (#43403)
    - extension/googlecloudlogentry_encoding: Add encoding.format
      attribute to GCP encoding extension to identify the source
      format. (#43320)
    - internal/aws: Upgrade k8s libraries from v0.32.x to v0.34.x
      (#43890)
    - pkg/ottl: Support taking match patterns from runtime data in
      the replace_all_patterns and replace_pattern functions.
      (#43555)
    - pkg/ottl: Add TrimPrefix and TrimSuffix to OTTL (#43883)
    - This is a much optimal way to remove prefix/suffix compare
      with replace_pattern(name, "^prefixed", "")
    - pkg/ottl: Added support for dynamic delimiter in Split()
      function in OTTL. (#43555)
    - pkg/ottl: Added support for dynamic delimiter in Concat()
      function in OTTL. (#43555)
    - pkg/ottl: Added support for dynamic prefix/suffix in
      HasPrefix and HasSuffix functions in OTTL. (#43555)
    - pkg/ottl: Remove unnecessary regexp compilation every
      execution (#43915)
    - pkg/ottl: Add unit and type subpaths for profile.sample_type
      and profile.period_type. (#43723)
    - pkg/ottl: Support taking match patterns from runtime data in
      the replace_all_matches and replace_match functions. (#43555)
    - pkg/ottl: Support taking match patterns from runtime data in
      the IsMatch function. (#43555)
    - pkg/ottl: Remove unnecessary full copy of maps/slices when
      setting value on sub-map (#43949)
    - pkg/ottl: Add XXH128 Converter function to converts a value
      to a XXH128 hash/digest (#42792)
    - pkg/ottl: Support dynamic keys in the delete_key and
      delete_matching_keys functions, allowing the key to be
      specified at runtime. (#43081)
    - pkg/ottl: Support paths and expressions as keys in keep_keys
      and keep_matching_keys (#43555)
    - pkg/ottl: Support dynamic pattern keys in ExtractPatterns and
      ExtractGrokPatterns functions, allowing the keys to be
      specified at runtime. (#43555)
    - pkg/ottl: Added support for dynamic encoding in Decode()
      function in OTTL. (#43555)
    - processor/filter: Allow setting OTTL conditions to filter out
      whole resources (#43968)
    - If any conditions set under the resource key for any signals
      match, the resource is dropped.
    - processor/k8sattributes: Support extracting deployment name
      purely from the owner reference (#42530)
    - processor/metricstarttime: Graduate the
      metricstarttimeprocessor to beta. (#43656)
    - processor/redaction: Extend database query obfuscation to
      span names. Previously, database query obfuscation (SQL,
      Redis, MongoDB) was only applied to span attributes and log
      bodies. Now it also redacts sensitive data in span names.
      (#43778)
    - processor/resourcedetection: Add the dt.smartscape.host
      resource attribute to data enriched with the Dynatrace
      detector (#43650)
    - receiver/azureeventhub: Adds support for receiving Azure app
      metrics from Azure Event Hubs in the azureeventhubreceiver
      (#41343, #41367)
    - The azureeventhubreceiver now supports receiving custom
      metrics emitted by applications to Azure Insights and
      forwarded using Diagnostic Settings to Azure Event Hub.
    - There's also on optional setting to aggregate received
      metrics into a single metric to keep the original name,
      instead of multiply the metrics by added suffixes '_total',
      '_sum', '_max' etc.
    - receiver/ciscoosreceiver: ciscoosreceiver: Add new receiver
      for collecting metrics from Cisco network devices via SSH
      (#42647)
    - Supports Cisco IOS, IOS-XE, and NX-OS devices with SSH-based
      metric collection.
    - Initial implementation includes system scraper for device
      availability and connection metrics.
    - receiver/gitlab: Promote GitLab receiver to Alpha stability
      (#41592)
    - receiver/jmx: Add JMX metrics gatherer version 1.51.0-alpha
      (#43666)
    - receiver/jmx: Add JMX scraper version 1.51.0-alpha (#43667)
    - receiver/pprof: convert google/pprof to OTel profiles
      (#42843)
    - receiver/redfish: this branch provides the first concrete
      implementation of the new component (#33724)
  * Bug fixes
    - exporter/clickhouse: Fix a bug in the exporter factory
      resulting in a nil dereference panic when the clickhouse.json
      feature gate is enabled (#43733)
    - exporter/kafka: franz-go: Fix underreported
      kafka_exporter_write_latency metric (#43803)
    - exporter/loadbalancing: Fix high cardinality issue in
      loadbalancing exporter by moving endpoint from exporter ID to
      attributes (#43719)
    - Previously, the exporter created unique IDs for each backend
      endpoint by appending the endpoint
    - to the exporter ID (e.g., loadbalancing_10.11.68.62:4317).
      This caused high cardinality in metrics,
    - especially in dynamic environments. Now the endpoint is added
      as an attribute instead.
    - exporter/pulsar: Fix the oauth2 flow for pulsar exporter by
      adding additional configuration fields (#43596)
    - Fixes the oauth2 authentication flow in pulsar exporter by
      exposing additional configuration like private_key and scope.
    - processor/metricstarttime: Do not set start timestamp if it
      is already set. (#43739)
    - processor/tail_sampling: Fix panic when invalid regex was
      sent to string_attribute sampler (#43735)
    - receiver/awss3: Fix S3 prefix trimming logic in awss3reader
      to correctly handle empty, single slash '/', and double slash
      '//' prefixes. (#43587)
    - This fix ensures the S3 object prefix is generated
      consistently for all prefix formats (e.g., "", /, //, /logs/,
      //raw//),
    - preventing malformed S3 paths when reading from buckets with
      non-standard prefixes.
    - receiver/hostmetrics: Allow process metrics to be recorded if
      the host does not have cgroup functionality (#43640)
    - receiver/kafka: Corrected the documentation for the Kafka
      receiver to accurately the supported/default group balancer
      strategies. (#43892)
    - receiver/postgresql: Change the unit of the metric
      postgresql.table.vacuum.count to be vacuum instead of vacuums
      (#43272)
    - receiver/prometheus: Fix missing staleness tracking leading
      to missing no recorded value data points. (#43893)
    - receiver/prometheusremotewrite: Fixed a concurrency bug in
      the Prometheus remote write receiver where concurrent
      requests with identical job/instance labels would return
      empty responses after the first successful request. (#42159)
    - receiver/pulsar: Fix the oauth2 flow for pulsar exporter by
      adding additional configuration fields (#435960)
    - Fixes the oauth2 authentication flow in pulsar receiver by
      exposing additional configuration like private_key and scope.
    - receiver/receiver_creator: Fix annotation-discovery config
      unmarshaling for nested configs (#43730)
- update to 0.138.0:
  The full changelog for this release can be found here:
  https://github.com/open-telemetry/opentelemetry-collector-contrib/releases/tag/v0.138.0
  The changelog for the core distribution, which is also included
  in the opentelemetry-collector-contrib distribution, can be found
  here:
  https://github.com/open-telemetry/opentelemetry-collector/releases/tag/v0.138.0
  * Breaking changes
    - connector/datadog: Mark NativeIngest as stable. (#104622)
    - connector/signaltometrics: Drop
      signaltometrics.service.{name, namespace} resource attribute
      from produced metrics. (#43148)
    - exporter/datadog: Remove logs::dump_payloads config option
      from datadogexporter config. (#43427)
    - Please remove the previously deprecated logs::dump_payloads
      config option from your datadogexporter config.
    - exporter/elasticsearch: Remove batcher and related config in
      favor of sending queue (#42718)
    - Previously deprecated batcher configuration is removed.
      num_consumers and flush are now deprecated as they conflict
      with sending_queue configurations.
    - extension/googlecloudlogentry_encoding: Parse VPC flow logs
      into log record attributes instead of placing them in the
      body directly. (#43017)
  * New components
    - receiver/icmpcheckreceiver: Add initial skeleton of ICMP
      check receiver (README, config, factory, metadata) with In
      Development stability. (#29009)
    - receiver/redfish: adds a redfish receiver (#33724)
  * Enhancements
    - all: Changelog entries will now have their component field
      checked against a list of valid components. (#43179)
    - This will ensure a more standardized changelog format which
      makes it easier to parse.
    - cmd/telemetrygen: Enable creation of attributes with values
      of slice type (#39018)
    - exporter/coralogix: Add HTTP/protobuf protocol support
      alongside existing gRPC transport. (#43216)
    - The exporter now supports both gRPC (default) and
      HTTP/protobuf protocols for sending telemetry data.
    - HTTP transport enables proxy support and provides an
      alternative for environments where gRPC is restricted.
    - Configure using the protocol field with values "grpc" or
      "http".
    - exporter/datadog: Make defaults for sending_queue::batch
      section to work out of the box with Datadog API intake
      limits. (#43082)
    - exporter/elasticsearch: Support experimental
      'encoding.format' scope attribute for dataset routing.
      (#42844)
    - exporter/kafka: Add support for partitioning log records by
      trace ID (#39146)
    - exporter/prometheus: Enable sending_queue section for the
      Prometheus exporter. (#42629)
    - extension/awslogs_encoding: Add feature gate to set
      aws.vpc.flow.start timestamp field to ISO8601 format (#43392)
    - Feature gate ID:
      extension.awslogsencoding.vpcflow.start.iso8601
    - When enabled, the aws.vpc.flow.start field will be formatted
      as an ISO-8601 string
    - instead of a Unix timestamp integer in seconds since epoch.
      Default behavior remains unchanged for backward
      compatibility.
    - Enable with:
      --feature-gates=extension.awslogsencoding.vpcflow.start.iso8601
    - extension/encoding: Add user_agent.original,
      destination.address, destination.port, url.domain to ELB
      access logs (#43141)
    - internal/kafka: Log a hint when broker connections fail due
      to possible TLS misconfiguration (#40145)
    - pkg/ottl: Add XXH3 Converter function to converts a value to
      a XXH3 hash/digest (#42792)
    - pkg/sampling: Note that pkg/sampling implements the new
      OpenTelemetry specification (#43396)
    - processor/filter: Add profiles support (#42762)
    - processor/isolationforest: Add adaptive window sizing feature
      that automatically adjusts window size based on traffic
      patterns, memory usage, and model stability (#42751)
    - The adaptive window sizing feature enables dynamic adjustment
      of the isolation forest sliding window size based on:
      - Traffic velocity and throughput patterns
      - Memory usage and resource constraints
      - Model stability and performance metrics
      - This enhancement improves resource utilization and anomaly
        detection accuracy for varying workload patterns.
    - processor/resourcedetection: Add Openstack Nova resource
      detector to gather Openstack instance metadata as resource
      attributes (#39117)
    - The Openstack Nova resource detector has been added to gather
      metadata such as host name, ID, cloud provider, region, and
      availability zone as resource attributes, enhancing the
      observability of Openstack environments.
    - processor/resourcedetection: Add Azure availability zone to
      resourcedetectionprocessor (#40983)
    - receiver/azuremonitor: parallelize calls by subscriptions in
      Batch API mode (#39417)
    - receiver/ciscoosreceiver: Add ciscoosreceiver to collect
      metrics from Cisco OS devices via SSH (#42647)
    - Supports SSH-based metric collection from Cisco devices
      including:
      - System metrics (CPU, memory utilization)
      - Interface metrics (bytes, packets, errors, status)
      - Configurable scrapers for modular metric collection
      - Device authentication via password or SSH key
    - receiver/gitlab: Add span attributes in GitLab receiver
      (#35207)
    - receiver/hostmetrics: Add metrics, Linux scraper, and tests
      to hostmetricsreceiver's nfsscraper (#40134)
    - receiver/icmpcheckreceiver: Add complete scraping
      implementation with ICMP ping/echo to collect metrics
      (#29009)
    - Replaces skeleton implementation with full production-ready
      collector functionality.
    - Includes metrics metadata and completed configuration.
    - Includes real scraper implementation that performs ICMP
      checks and collects metrics.
    - Includes README docs.
    - receiver/mysql: Support query-level collection. (#41847)
    - Added top query (most time consumed) collection. The query
      will gather the queries took most of the time during the last
    - query interval and report related metrics. The number of
      queries can be configured. This will enable user to have
      better
    - understanding on what is going on with the database. This
      enhancement empowers users to not only monitor but also
      actively
    - manage and optimize their MySQL database performance based on
      real usage patterns.
    - receiver/prometheus: added NHCB(native histogram wit custom
      buckets) to explicit histogram conversion (#41131)
    - receiver/redis: Add ClusterInfo capability to redisreceiver
      (#38117)
    - receiver/splunkenterprise: Added a new metric
      splunk.license.expiration.seconds_remaining to report the
      time remaining in seconds before a Splunk Enterprise license
      expires. (#42630)
      - Includes the following attributes: status, label, type.
    - receiver/sqlserver: Removing instance name usage in the SQL
      for top-query collection. (#43558)
    - Additional config of instance name is not required for
      collecting the top queries.
    - receiver/syslog: Promote Syslog receiver to beta stability
      (#28551)
  * Bug fixes
    - exporter/awss3: Support compression with the sumo_ic
      marshaller (#43574)
    - exporter/elasticsearch: Ensure metadata keys are always
      propagated in client context with batching enabled. (#41937)
    - exporter/prometheus: Fixes data_type field formatting in the
      error logs message when exporting unknown metrics types -
      e.g. native histograms. (#43595)
    - exporter/syslog: Fix timestamp formatting in rfc5424 syslog
      messages to use microsecond precision (#43114)
    - processor/metricstarttime: Fixes bug where adjustment only
      relied on the DoubleValue and ignored the IntValue (#42202)
    - receiver/k8s_cluster: Fix for k8sclusterreceiver to handle
      empty containerID in ContainerStatus (#43147)
    - receiver/libhoney: fix panic when decompressing poorly
      formatted data (#42272)
    - When decompressing poorly formatted data, the receiver would
      panic. This has now been fixed.
    - receiver/oracledb: Fix to use time from database clock for
      more accurate collection window calculation. (#43621)
    - Fixed the top-query collection logic to use database clock
      instead of the time from collector instance.
- update to 0.137.0:
  The full changelog for this release can be found here:
  https://github.com/open-telemetry/opentelemetry-collector-contrib/releases/tag/v0.137.0
  The changelog for the core distribution, which is also included
  in the opentelemetry-collector-contrib distribution, can be found
  here:
  https://github.com/open-telemetry/opentelemetry-collector/releases/tag/v0.137.0
  * Breaking changes
    - spanmetricsconnector: Exclude all resource attributes in
      spanmetrics (#42103)
    - This change aligns with the ServiceGraph implementation and
      may introduce a breaking change:
      - Users utilizing Prometheus remote write will not experience
        a breaking change.
      - Users using OTLP/HTTP may encounter a breaking change.
    - The change is currently guarded by the feature gate
      connector.spanmetrics.excludeResourceMetrics and is disabled
      by default.
    - It will be enabled by default in the next release.
    - spanmetricsconnector: Change default duration metrics unit
      from ms to s (#42462)
    - This change introduces a breaking change, which is now
      guarded by the feature gate
      connector.spanmetrics.useSecondAsDefaultMetricsUnit.
    - Currently, the feature gate is disabled by default, so the
      unit will remain ms. After one release cycle, the unit will
      switch to s and the feature gate will also be enabled by
      default.
    - splunkhecexporter: Removed deprecated HecToOtelAttrs
      configuration from splunkhecexporter (#43005)
    - signalfxreceiver: Removed deprecated configuration option:
      access_token_passthrough (#43048)
    - As access token passthrough option is no longer supported, to
      achieve similar behavior configure your collector
    - to use the headers_setter extension to pass the access token.
    - stefexporter, stefreceiver: Update to STEF 0.0.8. This is a
      breaking change in protocol format. (#42949)
    - Make sure to update both ends (receiver and exporter) to the
      same STEF version.
  * Deprecations
    - awslogsencodingextension: Rename awslogsencodingextension
      format values to shorter, more concise identifiers. Old
      format values are still supported until v0.138.0. (#42901)
    - pkg/datadog, exporter/datadog, extension/datadog: Deprecates
      StaticAPIKeyCheck, stops doing validation for API key
      characters in Datadog exporter and extension. (#42677)
    - This was causing issues to users since validation of secrets
      is challenging
  * New components
    - googlecloudstorageexporter: Add skeleton of
      googlecloudstorage exporter (#42137)
    - receiver/ciscoosreceiver: Add initial skeleton of Cisco OS
      receiver (README, config, factory, metadata) with In
      Development stability. (#42647)
    - This PR adds structure only (no scraping implementation yet).
    - Scrapers and SSH-based collection logic (BGP, Environment,
      Facts, Interfaces, Optics) will be added in follow-up PRs.
    - unrollprocessor: Adds a processor that generically takes a
      log body of slices and creates new entries from that slice.
      (#42491)
    - resourcedetectionprocessor: Added Oracle Cloud resource
      detection support to resourcedetectionprocessor, enabling
      automatic population of Oracle Cloud-specific resource
      attributes. (#35091)
    - This update allows the OpenTelemetry Collector to detect and
      annotate telemetry with Oracle Cloud resource metadata when
      running in Oracle Cloud environments.
    - Includes new unit tests and documentation.
  * Enhancements
    - redactionprocessor: Add support for URL sanitization in the
      redaction processor. (#41535)
    - unrollprocessor: Bump the stability to Alpha, and include it
      in otelcontribcol (#42917)
    - awscloudwatchlogsexporter: Adding yaten2302 as code owner for
      awscloudwatchlogsexporter, move it from unmaintained to alpha
      (#43039)
    - coralogixexporter: Add Automatic AWS PrivateLink set up via
      new private_link configuration option (#43075)
    - When enabled, the exporter will automatically use the AWS
      PrivateLink endpoint for the configured domain.
    - If the domain is already set to a PrivateLink one, no further
      change to the endpoint will be made.
    - receiver/kafkametricsreceiver: Add support for using franz-go
      client under a feature gate (#41480)
    - receiver/k8seventsreceiver: Added support for Leader Election
      into k8seventsreceiver using k8sleaderelector extension.
      (#42266)
    - receiver/k8sobjectsreceiver: Switch to standby mode when
      leader lease is lost instead of shutdown (#42706)
    - kafkareceiver: Add max_partition_fetch_size configuration
      option to kafkareceiver (#43097)
    - processor/resourcedetection: Add support for DigitalOcean in
      resourcedetectionprocessor (#42803)
    - processor/resourcedetection: Add support for upcloud in
      resourcedetectionprocessor (#42801)
    - receiver/kafka: Add support for disabling KIP-320 (truncation
      detection via leader epoch) for Franz-Go (#42226)
    - haproxyreceiver: Add support for act, weight, ctime, qtime,
      rtime, bck and slim metrics from HAProxy (#42829)
    - hostmetricsreceiver: Add useMemAvailable feature gate to use
      the MemAvailable kernel's statistic to compute the "used"
      memory usage (#42221)
    - otlpencodingextension: Promote the otlpencodingextension
      extension to beta. (#41596)
    - receiver/kafkareceiver: Use franz-go client for Kafka
      receiver as default, promoting the
      receiver.kafkareceiver.UseFranzGo feature gate to Beta.
      (#42155)
    - oracledbreceiver: Add service.instance.id resource attribute
      (#42402)
    - The service.instance.id resource attribute is added in the
      format <host>:<port>/<service> to uniquely identify
    - Oracle DB hosts. This resource attribute is enabled by
      default for metrics and logs.
    - extension/SumologicExtension: removing collector name from
      credential path for sumologic extension (#42511)
    - opensearchexporter: Add support for bodymap mapping mode
      (#41654)
    - The bodymap mapping mode supports only logs and uses the body
      of a log record as the exact content of the OpenSearch
      document, without any transformation.
    - tailsamplingprocessor: Add support for extensions that
      implement sampling policies. (#31582)
    - Extension support for tailsamplingprocessor is still in
      development and the interfaces may change at any time.
    - telemetrygen: Add span links support to telemetrygen (#43007)
    - The new --span-links flag allows generating spans with links
      to previously created spans.
    - Each span can link to random existing span contexts, creating
      relationships between spans for testing
    - distributed tracing scenarios. Links include attributes for
      link type and index identification.
    - telemetrygen: Add load size to telemetrygen metrics and logs.
      (#42322)
  * Bug fixes
    - awsxrayexporter: infer downstream service for producer spans
      (#40995)
    - azureeventhubreceiver: Use $Default as the default consumer
      group with the new azeventhubs SDK (#43049)
    - azureeventhubreceiver: Offset configuration option is now
      correctly honored, and the default start position is set to
      latest. (#38487)
    - elasticsearchexporter: Fix routing of collector
      self-telemetry data (#42679)
    - elasticsearchexporter: profiling: fix fetching location for
      stack (#42891)
    - receiver/googlecloudmonitoring: Add metric labels from Google
      Cloud metrics to all OTel metric attributes (#42232)
    - jmxreceiver: Fix the jmx-scraper hash for version 1.49.0
      (#121332)
    - postgreqsqlreceiver: Fix for memory leak when using top
      queries (#43076)
    - ntpreceiver: Fix missing resource attribute 'ntp.host' to
      ntpreceiver metrics (#43129)
    - receiver/k8seventsreceiver: Prevent potential panic in the
      events receiver by safely checking that informer objects are
      *corev1.Event before handling them. (#43014)
    - awscloudwatchlogexporter, awsemfexporter, awsxrayexporter:
      Fix support for role_arn (STS, short-lived token
      authentication). (#42115)
    - jmxreceiver: restart the java process on error (#42138)
    - Previously, the java process would not restart on error. By
      default, this receiver will now
    - always restart the process on error.
    - processor/k8sattributes: Use podUID instead podName to
      determine which pods should be deleted from cache (#42978)
    - kafka: Fix support for protocol_version in franz-go client
      (#42795)
    - libhoneyreceiver: return full array of statuses per event
      (#42272)
    - Libhoney has a per-event-within-each-batch response code
      array for each batch received. This has now been implemented
      for both initial parsing errors as well as downstream
      consumer errors.
    - telemetrygen: Publish int and bool attributes for logs
      (#43090)
    - oracledbreceiver: Fix for wrong trace id in oracle top query
      records (#43111)
    - oracledbreceiver: Fix for memory leak in top queries and
      query samples collection. (#43074)
    - prometheusexporter, prometheusremotewriteexporter: Connect
      pkg.translator.prometheus.PermissiveLabelSanitization with
      relevant logic. (#43077)
    - postgresqlreceiver: Properly set network.peer.address
      attribute (#42447)
    - postgresqlreceiver: Fix for inflated metric values in query
      metrics collection (#43071)
    - prometheusexporter: Fix 'failed to build namespace' logged as
      error when namespace is not configured (#43015)
    - signalfxexporter: Add HostID resource attribute to Histogram
      data in OTLP format (#42905)
    - statsdreceiver: Fix a data race in statsdreceiver on shutdown
      (#42878)

-------------------------------------------------------------------
Tue Sep 23 05:38:37 UTC 2025 - Johannes Kastl <opensuse_buildservice@ojkastl.de>

- update to 0.136.0:
  The full changelog for this release can be found here:
  https://github.com/open-telemetry/opentelemetry-collector-contrib/releases/tag/v0.136.0
  The changelog for the core distribution, which is also included
  in the opentelemetry-collector-contrib distribution, can be found
  here:
  https://github.com/open-telemetry/opentelemetry-collector/releases/tag/v0.136.0
  * Breaking changes
    - countconnector: Upgrade profiles proto to 1.8.0 (#42526)
    - datadogexporter: Deprecate zorkian codepath (#17373)
      Feature gate
      exporter.datadogexporter.metricexportnativeclient is now
      deprecated; the default metrics exporter is now Metrics
      Export Serializer unless feature gate
      exporter.datadogexporter.metricexportserializerclient is
      disabled.
      See
      https://github.com/open-telemetry/opentelemetry-collector-contrib/releases/tag/v0.122.0
      and #37930 for more info about Metrics Export Serializer.
    - elasticsearchexporter: Upgrade profiles proto to 1.8.0
      (#42526)
    - internal/kafka: Disable Kafka client metrics (#42662)
      We disable publishing Kafka client metrics to brokers, since
      they were not added intentionally and may lead to log spam
      when the broker does not really support metrics. We may make
      this configurable in the future.
    - golden: Upgrade profiles proto to 1.8.0 (#42526)
    - pkg/ottl: Upgrade profiles proto to 1.8.0 (#42526)
      See proto changelog.
      https://github.com/open-telemetry/opentelemetry-proto/blob/main/CHANGELOG.md#180---2025-09-02
    - signaltometricsconnector: Upgrade profiles proto to 1.8.0
      (#42526)
    - transformprocessor: Upgrade profiles proto to 1.8.0 (#42526)
  * Enhancements
    - azureblobexporter: Added template_enabled option to
      azureblobexporter blob_name_format to enable or disable
      template rendering. (#42643)
    - prometheusremotewritereceiver: Adds support to accept
      METRIC_TYPE_UNSPECIFIED as gauge type (#41840)
    - isolationforestprocessor: Add comprehensive unit tests with
      93% coverage (#42693)
    - exporter/awss3: Add S3PartitionTimezone config value to be
      able to change the timezone used for time-based partitioning
      (#42319)
    - clickhouseexporter: Add TLS configuration for cert based
      authentication. (#22805)
    - telemetrygen: Updates the semconv to use 1.37.0 (#42567)
    - coralogixexporter: Enable rate limiter mechanism in the
      Coralogix exporter. To disable it set rate_limiter.enabled to
      false. (#42552)
    - failoverconnector: Adds queue_settings to failoverconnector
      to enable queueing on the "exporter portion" of the
      connector. (#33077)
    - farotranslator, faroreceiver: Do not use faro event timestamp
      as the log record timestamp (#42600) Faro events originate in
      the user's browser, where the local clock may differ from
      actual time. | As a result, log record timestamps can be
      inaccurate, leading to ingestion issues (e.g., timestamps too
      old or too far in the future).
    - processor/k8sattributesprocessor: Add support for
      k8s.cronjob.uid attribute in k8sattributesprocessor (#42557)
    - awslogsencodingextension: Add instrumentation scope
      attributes to aws logs (#42788)
    - opampsupervisor: Add support for client initiated OpAMP
      heartbeats in the supervisor. (#42533)
    - internal/tools: Add support for modernize in Makefile
      (#42542)
    - processor/resourcedetection: Add support for linode cloud in
      resourcedetectionprocessor (#42543)
    - processor/resourcedetectionprocessor: Add support for
      Scaleway host image attributes in the
      resourcedetectionprocessor (#42682)
    - processor/resourcedetectionprocessor: Add support for Vultr
      cloud provider in the resourcedetectionprocessor (#42569)
    - spanmetricsconnector: Supports adding the
      collector.instance.id attribute to data points generated by
      the spanmetrics connector. (#40400) This feature currently in
      alpha stage, user should enable it by feature-gate
      --feature-gates=+connector.spanmetrics.includeCollectorInstanceID
    - processor/resourcedetectionprocessor: Add support for
      Scaleway cloud provider in the resourcedetectionprocessor
      (#42664)
    - exporter/awss3exporter: adds configuration field
      's3_base_prefix' to be able to set a base path for all S3
      file uploads (#42661)
    - journaldreceiver: Enable reading from all journals, including
      remote ones. A new option merge is added to the
      configuration. (#39188)
    - kafkametricsreceiver: Implement client reset for recoverable
      errors in Sarama calls (#41363) This change implements client
      reset functionality to address recoverable errors in Sarama
      calls, such as connection resets and EOF errors. When a
      recoverable error is encountered, the client is reset,
      enabling the scraper to reconnect and resume metric
      collection seamlessly.
    - tailsamplingprocessor: Set a tailsampling.cached_decision
      attribute on traces that were sampled by the decision cache.
      (#42535)
    - postgresqlreceiver: Including execution time metric for
      currently running queries in query samples. (#42429) The
      duration for currently running queries is calculated using
      the query_start time available in pg_stat_activity table.
    - receiver/k8scluster: Add experimental metric for container
      status reason (#32457)
    - telemetrygen: Add --allow-export-failures flag to
      telemetrygen to continue running when export operations fail
      (instead of terminating) (#42135)
    - telemetrygen: Add exponential histogram metric type to
      telemetrygen (#42322)
    - countconnector: Updates the countconnector metric timestamps
      to use earliest timestamp from batch as start timestamp and
      latest as timestamp, instead of using timestamp from metric
      creation time. (#40573)
  * Bug fixes
    - receiver/snowflake, receiver/sqlquery: Fix panic on startup
      caused by gosnowflake v1.16.0 (#42605) The solution was to
      downgrade the dependency version to v1.15.0.  For more
      information, refer to the upstream gosnowflake issue
    - elasticsearchexporter: Fix a bug where data stream attributes
      in 'none' mapping mode have invalid prefix. (#42454)
    - kafkaexporter: Fix bug where Kafka exporter ignored auth.tls
      configuration syntax. (#42754)
    - extension/storage: Fix 'recreate' rename file only on panic
      (#41802)
      - This recovers from a panic when the bbolt db is corrupted
        and renames the file when a panic occurs.
      - This changes the recreate behavior to not rename the file
        upon every start of the collector.
    - isolationforestprocessor: This PR fixes goroutine leaks in
      the isolation forest processor caused by improper shutdown
      coordination of background modelUpdateLoop goroutines.
      (#42675)
    - servicegraphconnector: Fix exponential histogram doesn't
      clean when expire (#42019)
    - awss3receiver: Ensures default wait time is applied in SQS
      configuration when not explicitly set. (#42608)
    - exporter/loadbalancing: Drop resources if the service routing
      key does not exist (#41550)
    - processor/redaction: Support redaction of scope level
      atrributes (#42659)
    - faroexporter: Fix success response handling in faroexporter
      so any HTTP 2xx status code indicates success instead of only
      202 Accepted. (#42658)
    - splunkenterprisereceiver: Fix a typo from a previous PR
      implementing the search artifact size metrics, which has
      caused errors from parsing empty strings. (#42615)
    - signalfxexporter: Only validate the root_path of the
      collector if sync_host_metadata is enabled. (#42688)

-------------------------------------------------------------------
Mon Sep 22 07:04:10 UTC 2025 - Johannes Kastl <opensuse_buildservice@ojkastl.de>

- update to 0.135.0:
  The full changelog for this release can be found here:
  https://github.com/open-telemetry/opentelemetry-collector-contrib/releases/tag/v0.135.0
  The changelog for the core distribution, which is also included
  in the opentelemetry-collector-contrib distribution, can be found
  here:
  https://github.com/open-telemetry/opentelemetry-collector/releases/tag/v0.135.0
  * Breaking Changes
    - apachereceiver: Add number of connections per async state
      metrics. (#41886)
    - githubreceiver: Update semantic conventions from v1.27.0 to
      v1.37.0 with standardized VCS and CICD attributes (#42378)
      - Resource attributes changed: organization.name ->
        vcs.owner.name, vcs.vendor.name -> vcs.provider.name
      - Trace attributes now use standardized VCS naming:
        vcs.ref.head.type -> vcs.ref.type
      - Added new standardized attributes: vcs.ref.base.name,
        vcs.ref.base.type, vcs.ref.type
      - Delta metrics now include base reference tracking
        attributes
      - Updated schema URL to
        https://opentelemetry.io/schemas/1.37.0
    - k8sattributesprocessor: Introduce
      allowLabelsAnnotationsSingular feature gate to use singular
      format for k8s label and annotation resource attributes
      (#39774)
    - The feature gate, when enabled, will change the default
      resource attribute key format from k8s..labels. to
      k8s..label.. Same applies for annotations.
    - receiver/sapm: The SAPM Receiver component has been removed
      from the repo and is no longer being published as it has been
      deprecated since 22nd October 2024 and the removal date of
      April 2025 has passed. (#41411)
- update to 0.134.0:
  The full changelog for this release can be found here:
  https://github.com/open-telemetry/opentelemetry-collector-contrib/releases/tag/v0.134.0
  The changelog for the core distribution, which is also included
  in the opentelemetry-collector-contrib distribution, can be found
  here:
  https://github.com/open-telemetry/opentelemetry-collector/releases/tag/v0.134.0
  * Breaking Changes
    - receiver/awscloudwatchmetrics: Remove unmaintained component
      (#42238)
    - opencensusreceiver: Remove the deprecated opencensus
      receiver. (#36791)
    - opencensusexporter: Remove the deprecated opencensus
      exporter. (#36791)
    - pkg/ottl: Keep the original map and continue processing keys
      if an error is encountered when calling an optional
      replacement function in replace_all_patterns. (#42359)
- update to 0.133.0:
  The full changelog for this release can be found here:
  https://github.com/open-telemetry/opentelemetry-collector-contrib/releases/tag/v0.133.0
  The changelog for the core distribution, which is also included
  in the opentelemetry-collector-contrib distribution, can be found
  here:
  https://github.com/open-telemetry/opentelemetry-collector/releases/tag/v0.133.0
  * Breaking Changes
    - coralogixexporter: Remove unused deprecated
      configgrpc.ClientConfig (#40853)
    - googlecloudlogentry_encoding: Parse cloud audit logs into log
      record attributes instead of placing it in the body as is.
      (#42035)
    - all: Increase minimum Go version to 1.24 (#41968)
    - signaltometricsconnector: Use configoptional for optional
      metric fields (#41922)
    - routingprocessor: Remove deprecated component
      routingprocessor (#19739)
      Please use the routing connector instead.
- update to 0.132.0:
  The full changelog for this release can be found here:
  https://github.com/open-telemetry/opentelemetry-collector-contrib/releases/tag/v0.132.0
  The changelog for the core distribution, which is also included
  in the opentelemetry-collector-contrib distribution, can be found
  here:
  https://github.com/open-telemetry/opentelemetry-collector/releases/tag/v0.132.0
  * Breaking Changes
    - azuremonitorreceiver: Updated append_tags_as_attributes
      configuration type from boolean to array. It controls which
      Azure resource tags are added as resource attributes to the
      metrics. The values can be a list of specific tag names or
      ["*"] to include all tags.
      (#40988)
    - elasticsearchexporter: Change default flush::interval and
      batcher::flush_timeout to 10s (#41726)
    - googlecloudlogentry_encoding: Add 'observedTimestamp' and
      'flags' field to resulting log, and throw error if log failed
      to parse. (#41467)
    - googlecloudlogentry_encoding: Fix type on apphub destination
      GCP fields (#41836)
    - googlecloudlogentry_encoding: Rename the remaining common
      fields in log entry to follow the semantic conventions.
      (#41087)
    - googlecloudlogentry_encoding: Use semantic conventions for
      the cloud log entry fields (part 1 of 2) (#41718)
    - googlepubsubreceiver: Remove build-in support for
      cloud_logging and raw_text encoding. (#41812)
    - The build-in encodings now have alternative encoding
      extensions to replace them.
    - stefexporter, stefreceiver: Update STEF to v0.0.7. This is a
      breaking change in protocol. (#41858)
    - postgresqlreceiver: unify the configuration to align with
      mdatagen tools and enable events by default (#41700)
      Removed the existing query_sample_collection.enabled and
      top_query_collection.enabled flags in favor of using the
      field generated by mdatagen. Both collections are now enabled
      by default.
  * Deprecations
    - elasticsearchexporter: Allow sending_queue to queue and batch
      based on the new API and deprecate batcher config (#41338)
    - kafkareceiver: Improve kafkareceiver internal metrics
      telemetry consistency, measure latency in seconds (#41109)
      Add a new metric kafka_receiver_records_delay to capture the
      time between producing and receiving a batch of records.
      Improve internal metrics telemetry consistency:
      - kafka_broker_throttling_duration is deprecated in favor of
        kafka_broker_throttling_latency and will be removed in the
        next minor release
      - kafka_receiver_latency is deprecated in favor of
        kafka_receiver_read_latency and will be removed in the next
        minor release
      - kafka_receiver_messages is deprecated in favor
        kafka_receiver_records and will be removed in the next
        minor release
  * New components
    - isolationforestprocessor: The processor applies the
      Isolation-Forest algorithm (an unsupervised, tree-based
      outlier-detection method) to every incoming span, trace, log,
      or metric. (#41707)
      It emits an anomaly score (iforest.anomaly_score) and/or a
      boolean flag (iforest.is_anomaly) inside the Collector—no
      external ML service required.
- update to 0.131.0:
  The full changelog for this release can be found here:
  https://github.com/open-telemetry/opentelemetry-collector-contrib/releases/tag/v0.131.0
  The changelog for the core distribution, which is also included
  in the opentelemetry-collector-contrib distribution, can be found
  here:
  https://github.com/open-telemetry/opentelemetry-collector/releases/tag/v0.131.0
  * Breaking Changes
    - iisreceiver: Enable IIS Application Pool state and uptime
      metrics by default. (#34924)
      WARNING: This change enables the iis.application_pool.state
      and iis.application_pool.uptime metrics by default.  This may
      cause a significant increase in the number of metrics
      collected if you have many application pools.  If you are
      concerned about the number of metrics, you can disable these
      metrics in your configuration.
    - kineticaexporter: Remove the kineticaexporter (#38911)
    - exporter/loki: The Loki Exporter component has been removed
      from the repo and is no longer being published as it has been
      deprecated since 9th July 2024. (#41413)
      Users of the lokiexporter can migrate to using an OTLP
      exporter. See #33916
  * Deprecations
    - kafkaexporter: Improve kafkaexporter internal metrics
      telemetry consistency, measure latency in seconds (#41108)
      Improve internal metrics telemetry consistency:
      - kafka_broker_throttling_duration is deprecated in favor of
        kafka_broker_throttling_latency
      - kafka_exporter_latency is deprecated in favor of
        kafka_exporter_write_latency
      - kafka_exporter_messages is deprecated in favor
        kafka_exporter_records
  * New components
    - tinybirdexporter: Mark the tinybirdexporter as alpha (#40475)
- update to 0.130.0:
  The full changelog for this release can be found here:
  https://github.com/open-telemetry/opentelemetry-collector-contrib/releases/tag/v0.130.0
  The changelog for the core distribution, which is also included
  in the opentelemetry-collector-contrib distribution, can be found
  here:
  https://github.com/open-telemetry/opentelemetry-collector/releases/tag/v0.130.0
  * Known Issues
    Due to a bug in the internal telemetry Prometheus exporter, if
    you are configuring an internal telemetry Prometheus exporter,
    the collector's internal metrics will be emitted with an
    unexpected suffix in its name. For example, the metric
    otelcol_exporter_sent_spans__spans__total instead of
    otelcol_exporter_sent_spans_total. The workaround is to
    manually configure without_units: true in your internal
    telemetry Prometheus exporter config

      service:
        telemetry:
          metrics:
            readers:
              - pull:
                  exporter:
                    prometheus:
                      host: 0.0.0.0
                      port: 8888
                      without_units: true

    If you are using the collector's default internal telemetry
    Prometheus exporter for exporting internal metrics you are
    unaffected.
  * Breaking Changes
    - kubeletstats: Move
      receiver.kubeletstats.enableCPUUsageMetrics feature gate to
      stable (#39650)
    - geoipprocessor: Use semantic convention Geo attributes
      (#34745) Replace geo.continent_code, geo.country_iso_code,
      geo.region_iso_code with semantic conventions
      geo.continent.code, geo.country.iso_code, geo.region.iso_code
      attributes.
    - kafka: The default client ID for Kafka components now honours
      configuration, and defaults to "otel-collector". (#41090) The
      client ID configuration was ineffective, and (when using the
      Sarama implementation) always defaulted to "sarama". We now
      honour the configuration, and the default has changed, hence
      this is a breaking change for anyone relying on the client ID
      being "sarama".
    - servicegraphconnector: Remove deprecated field
      database_name_attribute and update the documentation.
      (#41094)
    - cmd/opampsupervisor: Remote configuration by default now
      merges on top of user-provided config files. (#39963)
      Previous, by default, user-provided config files were merged
      on top of all other configuration. This is not the case
      anymore.
      The new default order configuration merging is as follows
      (from lowest to highest precedence):
          $OWN_TELEMETRY_CONFIG
          <USER_PROVIDED_CONFIG_FILES>
          $OPAMP_EXTENSION_CONFIG
          $REMOTE_CONFIG
  * Deprecations
    - splunkhecexporter: Deprecate 'batcher' config, use
      'sending_queue::batch' instead (#41224)
    - spanmetricsconnector: Mark dimensions_cache_size as
      deprecated following the upstream guidelines (#41101)
  * New components
    - tinybird: Implement logs propagation for Tinybird exporter
      (#40475)
- update to 0.129.0:
  The full changelog for this release can be found here:
  https://github.com/open-telemetry/opentelemetry-collector-contrib/releases/tag/v0.129.0
  The changelog for the core distribution, which is also included
  in the opentelemetry-collector-contrib distribution, can be found
  here:
  https://github.com/open-telemetry/opentelemetry-collector/releases/tag/v0.129.0
  * Breaking Changes
    - elasticsearchexporter: Add better ECS mapping for traces when
      using ECS mapping mode. Previously, traces were incorrectly
      processed by the generic encoder instead of applying
      ECS-compliant field mappings. (#40807)
    - receiver/httpcheck: Always close resp.Body and add timeout
      (#40552)
    - pkg/stanza: Remove deprecated decode package (#40861)
    - podmanreceiver: Deprecate "ssh-dss" host key algorithm for
      SSH connections (#40796)
    - pkg: Remove the fields from category FrontDoorAccessLog from
      the body log record and place them as log record attributes
      in translator azurelogs. (#40453)
    - kafka: remove broken SASL/AWS_MSK_IAM auth mechanism from
      Kafka components (#40554)
    - kafkareceiver: Improve kafkareceiver internal metrics
      telemetry (#40816)
      This change adds the following internal telemetry metrics to
      the receiver:
      - kafka_broker_connects
      - kafka_broker_closed
      - kafka_broker_throttling_duration
      - kafka_receiver_bytes
      - kafka_receiver_bytes_uncompressed
      - kafka_receiver_latency
      In addition it removes explicit component "name" metrics
      attribute which should be enabled with
      "telemetry.newPipelineTelemetry" collector feature gate
      instead. And changes "partition" metrics attribute to more
      direct "int64" type instead of "string".
    - datadogexporter: Graduate
      exporter.datadogexporter.UseLogsAgentExporter feature gate to
      stable (#40925)
    - sqlserverreceiver: Only empty strings for query texts and
      query plans when obfuscation failed. (#40527)
      This change applies only to top query collection and query
      sample collection.
  * Deprecations
    - logzioexporter: Deprecates jsonlog and logziospan usage and
      replace with plogotlp.ExportRequest and
      ptraceotlp.ExportRequest accordingly. (#40192)
    - datadogexporter: Config logs::dump_payloads is no longer
      supported now that the UseLogsAgentExporter feature gate is
      stable. (#40925)
    - prometheusremotewriteexporter: Remove the stable
      exporter.prometheusremotewriteexporter.deprecateCreatedMetric
      featuregate (#40570) It was supposed to be removed with
      v0.118.0.
    - resourcedetectionprocessor: Promote the
      processor.resourcedetection.removeGCPFaasID feature gate to
      beta. (#40601) The faas.id attribute is replaced by the
      faas.instance attribute. | This disables detection of the
      faas.id resource attribute by default. | Re-enable by
      disabling the processor.resourcedetection.removeGCPFaasID
      feature gate.
    - googlecloudexporter: Remove the stable
      exporter.googlecloud.OTLPDirect featuregate (#17192) It was
      supposed to be removed in v0.69.
    - resourcedetectionprocessor: Remove the stable
      processor.resourcedetection.hostCPUSteppingAsString
      featuregate (#40569) It was supposed to be removed in
      v0.110.0.
    - prometheusexporter, prometheusremotewriteexporter: Promote
      the pkg.translator.prometheus.NormalizeName feature gate to
      stable. (#40603) Use the add_metric_suffixes option on the
      prometheus exporters to | control the addition of suffixes
      instead of the feature gate.
    - prometheusreceiver: Promote the
      receiver.prometheusreceiver.RemoveLegacyResourceAttributes
      featuregate to stable (#40572) It has been beta since
      v0.126.0
  * New components
    - extension/datadog: Releases Datadog Extension in alpha.
      (#39589, #40715)
      The Datadog Extension is now released in alpha status.  Using
      the configuration settings listed in the README will allow
      collectors to report configuration data to Datadog backend.
      If enabled, collector configuration and build info will be
      viewable in Datadog Infrastructure Monitoring, specifically
      in Host List and Resource Catalog.
    - tinybirdexporter: Introduce Tinybird Exporter (#40475)
- update to 0.128.0:
  The full changelog for this release can be found here:
  https://github.com/open-telemetry/opentelemetry-collector-contrib/releases/tag/v0.128.0
  The changelog for the core distribution, which is also included
  in the opentelemetry-collector-contrib distribution, can be found
  here:
  https://github.com/open-telemetry/opentelemetry-collector/releases/tag/v0.128.0
  * Breaking Changes
    - pkg: Remove the fields from category
      FrontDoorWebApplicationFirewallLog from the body log record
      and place them as log record attributes. (#39993)
    - opampsupervisor: Update passthrough logging to use Error for
      stderr pipe. (#40491)
    - countconnector: Upgrade profiles proto to 1.7.0 (#40285)
    - elasticsearchexporter: Upgrade profiles proto to 1.7.0
      (#40285)
    - golden: Upgrade profiles proto to 1.7.0 (#40285)
    - otelarrowexporter: Configure the combined queue-batch
      facility, modifies the defaults sending_queue settings.
      (#40211) Removes experimental batcher config, which was never
      recommended, and documents how to replace the formerly
      recommended concurrentbatchprocessor configuration.
    - ottl: Upgrade profiles proto to 1.7.0 (#40285)
    - redisstorageextension: Add TLS support (#40185)
      TLS is now enabled by default. To disable TLS, use:

        tls:
        insecure: true

    - pkg/ottl: Remove access to the profile lookup tables (#40227)
      the mapping_table, location_table, function_table,
      attribute_table, attribute_units, link_table, string_stable
      have been moved to a root dictionary attribute and are not
      part of profile anymore.
    - signaltometricsconnector: Upgrade profiles proto to 1.7.0
      (#40285)
    - sqlserverreceiver: Rename flags for enabling top query
      collection and query sample collection. (#40416)
      - Renamed top_query_collection.enabled to
        events."db.server.top_query".enabled in top query
        collection.
      - Renamed query_sample_collection.enabled to
        events."db.server.query_sample".enabled in query sample
        collection.
  * Deprecations
    - receiver/hostmetrics: Mark
      hostmetrics.process.onWindowsUseNewGetProcesses feature gate
      as stable (#32947)

-------------------------------------------------------------------
Fri Jun 13 20:02:08 UTC 2025 - Johannes Kastl <opensuse_buildservice@ojkastl.de>

- new package opentelemetry-collector-contrib: OpenTelemetry Collector
  distribution that contains all the components from both the
  OpenTelemetry Collector repository and the OpenTelemetry Collector
  Contrib repository. This distribution includes open source and
  vendor supported components.
openSUSE Build Service is sponsored by