Skip to content

Conversation

@renovate
Copy link
Contributor

@renovate renovate bot commented Oct 16, 2024

Note: This PR body was truncated due to platform limits.

This PR contains the following updates:

Package Change Age Confidence
github.com/open-telemetry/opentelemetry-collector-contrib/connector/spanmetricsconnector v0.93.0v0.142.0 age confidence

Release Notes

open-telemetry/opentelemetry-collector-contrib (github.com/open-telemetry/opentelemetry-collector-contrib/connector/spanmetricsconnector)

v0.142.0

Compare Source

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

v0.141.0

Compare Source

🛑 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)

v0.140.1

Compare Source

v0.140.0

Compare Source

🛑 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 mess


Configuration

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

🚦 Automerge: Disabled by config. Please merge this manually once you are satisfied.

Rebasing: Whenever PR becomes conflicted, or you tick the rebase/retry checkbox.

🔕 Ignore: Close this PR and you won't be reminded about this update again.


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

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

@renovate renovate bot force-pushed the renovate/github.com-open-telemetry-opentelemetry-collector-contrib-connector-spanmetricsconnector-0.x branch from 6cdbed2 to d7638a7 Compare October 23, 2024 14:39
@renovate renovate bot changed the title Update module github.com/open-telemetry/opentelemetry-collector-contrib/connector/spanmetricsconnector to v0.111.0 Update module github.com/open-telemetry/opentelemetry-collector-contrib/connector/spanmetricsconnector to v0.112.0 Oct 23, 2024
@renovate renovate bot force-pushed the renovate/github.com-open-telemetry-opentelemetry-collector-contrib-connector-spanmetricsconnector-0.x branch from d7638a7 to 5f3c131 Compare November 6, 2024 21:29
@renovate renovate bot changed the title Update module github.com/open-telemetry/opentelemetry-collector-contrib/connector/spanmetricsconnector to v0.112.0 Update module github.com/open-telemetry/opentelemetry-collector-contrib/connector/spanmetricsconnector to v0.113.0 Nov 6, 2024
@renovate
Copy link
Contributor Author

renovate bot commented Nov 6, 2024

ℹ Artifact update notice

File name: go.mod

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

  • 51 additional dependencies were updated
  • The go directive was updated for compatibility reasons

Details:

Package Change
go 1.20 -> 1.23.5
github.com/stretchr/testify v1.8.4 -> v1.10.0
go.opentelemetry.io/collector/component v0.93.0 -> v0.118.0
go.opentelemetry.io/collector/receiver v0.93.0 -> v0.118.0
golang.org/x/sys v0.16.0 -> v0.28.0
cloud.google.com/go/compute/metadata v0.2.4-0.20230617002413-005d2dfb6b68 -> v0.5.2
github.com/GoogleCloudPlatform/opentelemetry-operations-go/detectors/gcp v1.21.0 -> v1.24.2
github.com/Microsoft/go-winio v0.6.1 -> v0.6.2
github.com/cenkalti/backoff/v4 v4.2.1 -> v4.3.0
github.com/cespare/xxhash/v2 v2.2.0 -> v2.3.0
github.com/cncf/xds/go v0.0.0-20230607035331-e9ce68804cb4 -> v0.0.0-20240905190251-b4127c9b8d78
github.com/docker/docker v24.0.7+incompatible -> v27.3.1+incompatible
github.com/envoyproxy/go-control-plane v0.11.1 -> v0.13.1
github.com/envoyproxy/protoc-gen-validate v1.0.2 -> v1.1.0
github.com/go-logr/logr v1.4.1 -> v1.4.2
github.com/golang/protobuf v1.5.3 -> v1.5.4
github.com/grpc-ecosystem/grpc-gateway/v2 v2.19.0 -> v2.20.0
github.com/hashicorp/go-version v1.6.0 -> v1.7.0
github.com/klauspost/compress v1.17.4 -> v1.17.9
github.com/knadh/koanf/v2 v2.0.1 -> v2.1.2
github.com/open-telemetry/opentelemetry-collector-contrib/internal/coreinternal v0.93.0 -> v0.118.0
github.com/open-telemetry/opentelemetry-collector-contrib/pkg/pdatautil v0.93.0 -> v0.118.0
github.com/opencontainers/image-spec v1.1.0-rc5 -> v1.1.0
github.com/prometheus/client_model v0.5.0 -> v0.6.0
github.com/shirou/gopsutil/v3 v3.23.12 -> v3.24.5
github.com/stretchr/objx v0.5.0 -> v0.5.2
github.com/yusufpapurcu/wmi v1.2.3 -> v1.2.4
go.opentelemetry.io/collector/config/configtelemetry v0.93.0 -> v0.118.0
go.opentelemetry.io/collector/confmap v0.93.0 -> v1.24.0
go.opentelemetry.io/collector/featuregate v1.0.1 -> v1.24.0
go.opentelemetry.io/collector/pdata v1.0.1 -> v1.24.0
go.opentelemetry.io/contrib/instrumentation/net/http/otelhttp v0.47.0 -> v0.49.0
go.opentelemetry.io/otel v1.22.0 -> v1.32.0
go.opentelemetry.io/otel/exporters/otlp/otlptrace v1.22.0 -> v1.28.0
go.opentelemetry.io/otel/exporters/otlp/otlptrace/otlptracehttp v1.22.0 -> v1.28.0
go.opentelemetry.io/otel/metric v1.22.0 -> v1.32.0
go.opentelemetry.io/otel/sdk v1.22.0 -> v1.32.0
go.opentelemetry.io/otel/sdk/metric v1.22.0 -> v1.32.0
go.opentelemetry.io/otel/trace v1.22.0 -> v1.32.0
go.opentelemetry.io/proto/otlp v1.0.0 -> v1.3.1
go.uber.org/zap v1.26.0 -> v1.27.0
golang.org/x/crypto v0.18.0 -> v0.31.0
golang.org/x/mod v0.14.0 -> v0.19.0
golang.org/x/net v0.20.0 -> v0.33.0
golang.org/x/oauth2 v0.16.0 -> v0.23.0
golang.org/x/term v0.16.0 -> v0.27.0
golang.org/x/text v0.14.0 -> v0.21.0
golang.org/x/tools v0.16.0 -> v0.23.0
google.golang.org/genproto/googleapis/api v0.0.0-20240102182953-50ed04b92917 -> v0.0.0-20241015192408-796eee8c2d53
google.golang.org/genproto/googleapis/rpc v0.0.0-20240102182953-50ed04b92917 -> v0.0.0-20241104194629-dd2ea8efbc28
google.golang.org/grpc v1.60.1 -> v1.69.4
google.golang.org/protobuf v1.32.0 -> v1.36.3

@renovate renovate bot force-pushed the renovate/github.com-open-telemetry-opentelemetry-collector-contrib-connector-spanmetricsconnector-0.x branch 2 times, most recently from c66904c to 05375ea Compare November 19, 2024 01:50
@renovate renovate bot changed the title Update module github.com/open-telemetry/opentelemetry-collector-contrib/connector/spanmetricsconnector to v0.113.0 Update module github.com/open-telemetry/opentelemetry-collector-contrib/connector/spanmetricsconnector to v0.114.0 Nov 19, 2024
@renovate renovate bot force-pushed the renovate/github.com-open-telemetry-opentelemetry-collector-contrib-connector-spanmetricsconnector-0.x branch from 05375ea to 6f322a7 Compare December 4, 2024 13:31
@renovate renovate bot changed the title Update module github.com/open-telemetry/opentelemetry-collector-contrib/connector/spanmetricsconnector to v0.114.0 Update module github.com/open-telemetry/opentelemetry-collector-contrib/connector/spanmetricsconnector to v0.115.0 Dec 4, 2024
@renovate renovate bot force-pushed the renovate/github.com-open-telemetry-opentelemetry-collector-contrib-connector-spanmetricsconnector-0.x branch from 6f322a7 to aff64c9 Compare December 17, 2024 15:32
@renovate renovate bot changed the title Update module github.com/open-telemetry/opentelemetry-collector-contrib/connector/spanmetricsconnector to v0.115.0 Update module github.com/open-telemetry/opentelemetry-collector-contrib/connector/spanmetricsconnector to v0.116.0 Dec 17, 2024
@renovate renovate bot force-pushed the renovate/github.com-open-telemetry-opentelemetry-collector-contrib-connector-spanmetricsconnector-0.x branch from aff64c9 to fdfb990 Compare January 8, 2025 04:28
@renovate renovate bot changed the title Update module github.com/open-telemetry/opentelemetry-collector-contrib/connector/spanmetricsconnector to v0.116.0 Update module github.com/open-telemetry/opentelemetry-collector-contrib/connector/spanmetricsconnector to v0.117.0 Jan 8, 2025
@renovate renovate bot force-pushed the renovate/github.com-open-telemetry-opentelemetry-collector-contrib-connector-spanmetricsconnector-0.x branch from fdfb990 to b56d5e9 Compare January 21, 2025 20:59
@renovate renovate bot changed the title Update module github.com/open-telemetry/opentelemetry-collector-contrib/connector/spanmetricsconnector to v0.117.0 Update module github.com/open-telemetry/opentelemetry-collector-contrib/connector/spanmetricsconnector to v0.118.0 Jan 21, 2025
@renovate renovate bot force-pushed the renovate/github.com-open-telemetry-opentelemetry-collector-contrib-connector-spanmetricsconnector-0.x branch from b56d5e9 to aec1cf6 Compare February 4, 2025 09:16
@renovate renovate bot changed the title Update module github.com/open-telemetry/opentelemetry-collector-contrib/connector/spanmetricsconnector to v0.118.0 Update module github.com/open-telemetry/opentelemetry-collector-contrib/connector/spanmetricsconnector to v0.119.0 Feb 4, 2025
@renovate
Copy link
Contributor Author

renovate bot commented Feb 4, 2025

⚠️ Artifact update problem

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

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

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

The artifact failure details are included below:

File name: go.sum
Command failed: go get -t ./...
go: downloading github.com/open-telemetry/opentelemetry-collector-contrib/connector/spanmetricsconnector v0.142.0
go: downloading github.com/open-telemetry/opentelemetry-collector-contrib/exporter/kafkaexporter v0.93.0
go: downloading github.com/open-telemetry/opentelemetry-collector-contrib/exporter/prometheusexporter v0.93.0
go: downloading github.com/open-telemetry/opentelemetry-collector-contrib/extension/bearertokenauthextension v0.93.0
go: downloading github.com/open-telemetry/opentelemetry-collector-contrib/extension/healthcheckextension v0.93.0
go: downloading github.com/open-telemetry/opentelemetry-collector-contrib/extension/jaegerremotesampling v0.93.0
go: downloading github.com/open-telemetry/opentelemetry-collector-contrib/extension/oauth2clientauthextension v0.93.0
go: downloading github.com/open-telemetry/opentelemetry-collector-contrib/extension/pprofextension v0.93.0
go: downloading github.com/open-telemetry/opentelemetry-collector-contrib/processor/attributesprocessor v0.93.0
go: downloading github.com/open-telemetry/opentelemetry-collector-contrib/processor/filterprocessor v0.93.0
go: downloading github.com/open-telemetry/opentelemetry-collector-contrib/processor/k8sattributesprocessor v0.93.0
go: downloading github.com/open-telemetry/opentelemetry-collector-contrib/processor/resourcedetectionprocessor v0.93.0
go: downloading github.com/open-telemetry/opentelemetry-collector-contrib/processor/resourceprocessor v0.93.0
go: downloading github.com/open-telemetry/opentelemetry-collector-contrib/processor/routingprocessor v0.93.0
go: downloading github.com/open-telemetry/opentelemetry-collector-contrib/processor/spanprocessor v0.93.0
go: downloading github.com/open-telemetry/opentelemetry-collector-contrib/receiver/filelogreceiver v0.93.0
go: downloading github.com/open-telemetry/opentelemetry-collector-contrib/receiver/jaegerreceiver v0.93.0
go: downloading github.com/open-telemetry/opentelemetry-collector-contrib/receiver/journaldreceiver v0.93.0
go: downloading github.com/open-telemetry/opentelemetry-collector-contrib/receiver/kafkareceiver v0.93.0
go: downloading github.com/open-telemetry/opentelemetry-collector-contrib/receiver/opencensusreceiver v0.93.0
go: downloading github.com/open-telemetry/opentelemetry-collector-contrib/receiver/prometheusreceiver v0.93.0
go: downloading github.com/open-telemetry/opentelemetry-collector-contrib/receiver/zipkinreceiver v0.93.0
go: downloading go.opentelemetry.io/collector/component v1.48.0
go: downloading go.opentelemetry.io/collector v0.93.0
go: downloading go.opentelemetry.io/collector/connector v0.142.0
go: downloading go.opentelemetry.io/collector/exporter v0.93.0
go: downloading go.opentelemetry.io/collector/exporter/debugexporter v0.93.0
go: downloading go.opentelemetry.io/collector/exporter/loggingexporter v0.93.0
go: downloading go.opentelemetry.io/collector/exporter/otlpexporter v0.93.0
go: downloading go.opentelemetry.io/collector/exporter/otlphttpexporter v0.93.0
go: downloading go.opentelemetry.io/collector/extension v0.93.0
go: downloading go.opentelemetry.io/collector/extension/ballastextension v0.93.0
go: downloading go.opentelemetry.io/collector/extension/zpagesextension v0.93.0
go: downloading go.opentelemetry.io/collector/otelcol v0.93.0
go: downloading go.opentelemetry.io/collector/processor v0.93.0
go: downloading go.opentelemetry.io/collector/processor/batchprocessor v0.93.0
go: downloading go.opentelemetry.io/collector/processor/memorylimiterprocessor v0.93.0
go: downloading go.opentelemetry.io/collector/receiver v1.48.0
go: downloading go.opentelemetry.io/collector/receiver/otlpreceiver v0.93.0
go: downloading golang.org/x/sys v0.39.0
go: downloading github.com/stretchr/testify v1.11.1
go: downloading go.opentelemetry.io/collector/component/componenttest v0.142.0
go: downloading github.com/google/uuid v1.6.0
go: downloading github.com/hashicorp/golang-lru/v2 v2.0.7
go: downloading github.com/hashicorp/golang-lru v1.0.2
go: downloading github.com/jonboulle/clockwork v0.5.0
go: downloading github.com/lightstep/go-expohisto v1.0.0
go: downloading github.com/open-telemetry/opentelemetry-collector-contrib/internal/coreinternal v0.142.0
go: downloading github.com/open-telemetry/opentelemetry-collector-contrib/internal/pdatautil v0.142.0
go: downloading github.com/open-telemetry/opentelemetry-collector-contrib/pkg/pdatautil v0.142.0
go: downloading go.opentelemetry.io/collector/config/configoptional v1.48.0
go: downloading go.opentelemetry.io/collector/confmap v1.48.0
go: downloading go.opentelemetry.io/collector/confmap/xconfmap v0.142.0
go: downloading go.opentelemetry.io/collector/consumer v1.48.0
go: downloading go.opentelemetry.io/collector/featuregate v1.48.0
go: downloading go.opentelemetry.io/collector/pdata v1.48.0
go: downloading go.opentelemetry.io/otel v1.39.0
go: downloading go.uber.org/zap v1.27.1
go: downloading github.com/IBM/sarama v1.42.1
go: downloading github.com/gogo/protobuf v1.3.2
go: downloading github.com/jaegertracing/jaeger v1.53.0
go: downloading github.com/open-telemetry/opentelemetry-collector-contrib/internal/kafka v0.93.0
go: downloading github.com/open-telemetry/opentelemetry-collector-contrib/pkg/batchpersignal v0.93.0
go: downloading github.com/open-telemetry/opentelemetry-collector-contrib/pkg/translator/jaeger v0.93.0
go: downloading github.com/open-telemetry/opentelemetry-collector-contrib/pkg/translator/zipkin v0.93.0
go: downloading go.opentelemetry.io/collector/config/configretry v0.93.0
go: downloading go.opentelemetry.io/collector/consumer/consumererror v0.142.0
go: downloading go.uber.org/multierr v1.11.0
go: downloading github.com/open-telemetry/opentelemetry-collector-contrib/pkg/resourcetotelemetry v0.93.0
go: downloading github.com/open-telemetry/opentelemetry-collector-contrib/pkg/translator/prometheus v0.93.0
go: downloading github.com/prometheus/client_golang v1.18.0
go: downloading github.com/prometheus/common v0.46.0
go: downloading go.opentelemetry.io/collector/config/confighttp v0.93.0
go: downloading go.opentelemetry.io/collector/semconv v0.93.0
go: downloading github.com/fsnotify/fsnotify v1.7.0
go: downloading go.opentelemetry.io/collector/config/configopaque v0.93.0
go: downloading go.opentelemetry.io/collector/extension/auth v0.93.0
go: downloading google.golang.org/grpc v1.77.0
go: downloading go.opencensus.io v0.24.0
go: downloading go.opentelemetry.io/collector/config/configgrpc v0.93.0
go: downloading go.opentelemetry.io/collector/config/confignet v0.93.0
go: downloading go.opentelemetry.io/collector/config/configtls v0.93.0
go: downloading golang.org/x/oauth2 v0.32.0
go: downloading github.com/open-telemetry/opentelemetry-collector-contrib/internal/filter v0.93.0
go: downloading github.com/open-telemetry/opentelemetry-collector-contrib/pkg/ottl v0.93.0
go: downloading github.com/open-telemetry/opentelemetry-collector-contrib/internal/k8sconfig v0.93.0
go: downloading k8s.io/apimachinery v0.28.4
go: downloading go.opentelemetry.io/otel/metric v1.39.0
go: downloading github.com/open-telemetry/opentelemetry-collector-contrib/pkg/stanza v0.93.0
go: downloading github.com/apache/thrift v0.19.0
go: downloading github.com/gorilla/mux v1.8.1
go: downloading github.com/json-iterator/go v1.1.12
go: downloading github.com/open-telemetry/opentelemetry-collector-contrib/pkg/translator/azure v0.93.0
go: downloading github.com/census-instrumentation/opencensus-proto v0.4.1
go: downloading github.com/grpc-ecosystem/grpc-gateway/v2 v2.20.0
go: downloading github.com/open-telemetry/opentelemetry-collector-contrib/internal/sharedcomponent v0.93.0
go: downloading github.com/rs/cors v1.10.1
go: downloading github.com/soheilhy/cmux v0.1.5
go: downloading github.com/go-kit/log v0.2.1
go: downloading github.com/mitchellh/hashstructure/v2 v2.0.2
go: downloading github.com/prometheus/prometheus v0.48.1
go: downloading gopkg.in/yaml.v2 v2.4.0
go: downloading go.opentelemetry.io/otel/trace v1.39.0
go: downloading go.opentelemetry.io/collector/pipeline v1.48.0
go: downloading go.opentelemetry.io/collector/config/configtelemetry v0.93.0
go: downloading go.opentelemetry.io/collector/config/configcompression v0.93.0
go: downloading google.golang.org/genproto/googleapis/rpc v0.0.0-20251022142026-3a174f9686a8
go: downloading google.golang.org/genproto v0.0.0-20231212172506-995d672761c0
go: downloading google.golang.org/protobuf v1.36.10
go: downloading go.opentelemetry.io/contrib/zpages v0.47.0
go: downloading go.opentelemetry.io/otel/sdk v1.39.0
go: downloading github.com/spf13/cobra v1.8.0
go: downloading go.opentelemetry.io/collector/service v0.93.0
go: downloading gopkg.in/yaml.v3 v3.0.1
go: downloading github.com/davecgh/go-spew v1.1.2-0.20180830191138-d8f796af33cc
go: downloading github.com/pmezard/go-difflib v1.0.1-0.20181226105442-5d4384ee4fb2
go: downloading go.opentelemetry.io/otel/sdk/metric v1.39.0
go: downloading github.com/cespare/xxhash/v2 v2.3.0
go: downloading github.com/hashicorp/go-version v1.8.0
go: downloading github.com/eapache/go-resiliency v1.4.0
go: downloading github.com/eapache/go-xerial-snappy v0.0.0-20230731223053-c322873962e3
go: downloading github.com/eapache/queue v1.1.0
go: downloading github.com/hashicorp/go-multierror v1.1.1
go: downloading github.com/jcmturner/gofork v1.7.6
go: downloading github.com/jcmturner/gokrb5/v8 v8.4.4
go: downloading github.com/klauspost/compress v1.18.0
go: downloading github.com/pierrec/lz4/v4 v4.1.18
go: downloading github.com/rcrowley/go-metrics v0.0.0-20201227073835-cf1acfcdf475
go: downloading golang.org/x/net v0.47.0
go: downloading github.com/xdg-go/scram v1.1.2
go: downloading github.com/openzipkin/zipkin-go v0.4.2
go: downloading github.com/cenkalti/backoff/v4 v4.3.0
go: downloading github.com/beorn7/perks v1.0.1
go: downloading github.com/prometheus/client_model v0.5.0
go: downloading github.com/prometheus/procfs v0.12.0
go: downloading github.com/golang/snappy v0.0.4
go: downloading go.opentelemetry.io/collector/config/configauth v0.93.0
go: downloading go.opentelemetry.io/collector/config/internal v0.93.0
go: downloading go.opentelemetry.io/contrib/instrumentation/net/http/otelhttp v0.49.0
go: downloading github.com/spf13/viper v1.18.2
go: downloading github.com/tilinna/clock v1.1.0
go: downloading github.com/mostynb/go-grpc-compression v1.2.2
go: downloading go.opentelemetry.io/contrib/instrumentation/google.golang.org/grpc/otelgrpc v0.47.0
go: downloading github.com/alecthomas/participle/v2 v2.1.1
go: downloading github.com/iancoleman/strcase v0.3.0
go: downloading golang.org/x/exp v0.0.0-20240103183307-be819d1f06fc
go: downloading github.com/openshift/client-go v0.0.0-20210521082421-73d9475a9142
go: downloading k8s.io/client-go v0.28.4
go: downloading k8s.io/api v0.28.4
go: downloading github.com/aws/aws-sdk-go v1.50.2
go: downloading github.com/open-telemetry/opentelemetry-collector-contrib/internal/metadataproviders v0.93.0
go: downloading github.com/open-telemetry/opentelemetry-collector-contrib/internal/aws/ecsutil v0.93.0
go: downloading github.com/hashicorp/consul/api v1.27.0
go: downloading cloud.google.com/go/compute/metadata v0.9.0
go: downloading cloud.google.com/go/compute v1.23.3
go: downloading github.com/GoogleCloudPlatform/opentelemetry-operations-go/detectors/gcp v1.30.0
go: downloading github.com/shirou/gopsutil/v3 v3.23.12
go: downloading go.opentelemetry.io/collector/consumer/consumertest v0.142.0
go: downloading github.com/gogo/googleapis v1.4.1
go: downloading go.yaml.in/yaml/v3 v3.0.4
go: downloading github.com/modern-go/concurrent v0.0.0-20180306012644-bacd9c7ef1dd
go: downloading github.com/modern-go/reflect2 v1.0.3-0.20250322232337-35a7c28c31ee
go: downloading golang.org/x/text v0.31.0
go: downloading github.com/relvacode/iso8601 v1.3.0
go: downloading google.golang.org/genproto/googleapis/api v0.0.0-20251022142026-3a174f9686a8
go: downloading github.com/open-telemetry/opentelemetry-collector-contrib/pkg/translator/opencensus v0.93.0
go: downloading github.com/go-logfmt/logfmt v0.6.0
go: downloading github.com/mwitkow/go-conntrack v0.0.0-20190716064945-2f068394615f
go: downloading github.com/alecthomas/units v0.0.0-20211218093645-b94a6e3cc137
go: downloading github.com/grafana/regexp v0.0.0-20221122212121-6b5c0a4cb7fd
go: downloading github.com/prometheus/common/sigv4 v0.1.0
go: downloading github.com/pkg/errors v0.9.1
go: downloading github.com/inconshreveable/mousetrap v1.1.0
go: downloading github.com/spf13/pflag v1.0.5
go: downloading go.opentelemetry.io/contrib/config v0.2.0
go: downloading go.opentelemetry.io/contrib/propagators/b3 v1.22.0
go: downloading github.com/hashicorp/errwrap v1.1.0
go: downloading github.com/jcmturner/dnsutils/v2 v2.0.0
go: downloading github.com/hashicorp/go-uuid v1.0.3
go: downloading github.com/xdg-go/pbkdf2 v1.0.0
go: downloading github.com/xdg-go/stringprep v1.0.4
go: downloading go.opentelemetry.io/collector/pdata/pprofile v0.142.0
go: downloading github.com/felixge/httpsnoop v1.0.4
go: downloading github.com/go-logr/logr v1.4.3
go: downloading github.com/mitchellh/mapstructure v1.5.1-0.20231216201459-8508981c8b6c
go: downloading github.com/sagikazarmark/locafero v0.4.0
go: downloading github.com/sagikazarmark/slog-shim v0.1.0
go: downloading github.com/spf13/afero v1.11.0
go: downloading github.com/spf13/cast v1.6.0
go: downloading github.com/expr-lang/expr v1.15.8
go: downloading github.com/gobwas/glob v0.2.3
go: downloading k8s.io/klog/v2 v2.100.1
go: downloading k8s.io/utils v0.0.0-20230711102312-30195339c3c7
go: downloading github.com/imdario/mergo v0.3.16
go: downloading golang.org/x/term v0.37.0
go: downloading github.com/google/gofuzz v1.2.0
go: downloading sigs.k8s.io/structured-merge-diff/v4 v4.3.0
go: downloading github.com/open-telemetry/opentelemetry-collector-contrib/internal/common v0.93.0
go: downloading github.com/hashicorp/go-cleanhttp v0.5.2
go: downloading github.com/hashicorp/go-hclog v1.6.1
go: downloading github.com/hashicorp/go-rootcerts v1.0.2
go: downloading github.com/hashicorp/serf v0.10.1
go: downloading github.com/docker/docker v28.5.1+incompatible
go: downloading github.com/Showmax/go-fqdn v1.0.0
go: downloading github.com/lufia/plan9stats v0.0.0-20220913051719-115f729f3c8c
go: downloading github.com/power-devops/perfstat v0.0.0-20220216144756-c35f1ee13d7c
go: downloading github.com/shoenig/go-m1cpu v0.1.6
go: downloading github.com/tklauser/go-sysconf v0.3.12
go: downloading github.com/yusufpapurcu/wmi v1.2.4
go: downloading go.opentelemetry.io/collector/consumer/xconsumer v0.142.0
go: downloading github.com/valyala/fastjson v1.6.4
go: downloading github.com/influxdata/go-syslog/v3 v3.0.1-0.20230911200830-875f5bc594a4
go: downloading gonum.org/v1/gonum v0.16.0
go: downloading github.com/go-viper/mapstructure/v2 v2.4.0
go: downloading github.com/knadh/koanf/maps v0.1.2
go: downloading github.com/knadh/koanf/providers/confmap v1.0.0
go: downloading github.com/knadh/koanf/v2 v2.3.0
go: downloading github.com/golang/protobuf v1.5.4
go: downloading github.com/jpillora/backoff v1.0.0
go: downloading github.com/Azure/azure-sdk-for-go/sdk/azcore v1.8.0
go: downloading github.com/Azure/azure-sdk-for-go/sdk/azidentity v1.4.0
go: downloading github.com/Azure/azure-sdk-for-go/sdk/resourcemanager/compute/armcompute/v4 v4.2.1
go: downloading github.com/Azure/azure-sdk-for-go/sdk/resourcemanager/network/armnetwork/v2 v2.2.1
go: downloading github.com/digitalocean/godo v1.104.1
go: downloading github.com/miekg/dns v1.1.56
go: downloading google.golang.org/api v0.155.0
go: downloading github.com/hetznercloud/hcloud-go/v2 v2.4.0
go: downloading github.com/ionos-cloud/sdk-go/v6 v6.1.9
go: downloading github.com/linode/linodego v1.23.0
go: downloading github.com/hashicorp/nomad/api v0.0.0-20230721134942-515895c7690c
go: downloading github.com/gophercloud/gophercloud v1.7.0
go: downloading github.com/ovh/go-ovh v1.4.3
go: downloading github.com/scaleway/scaleway-sdk-go v1.0.0-beta.21
go: downloading github.com/kolo/xmlrpc v0.0.0-20220921171641-a4b6fa1dd06b
go: downloading github.com/vultr/govultr/v2 v2.17.2
go: downloading github.com/envoyproxy/go-control-plane v0.13.5-0.20251024222203-75eaa193e329
go: downloading github.com/envoyproxy/go-control-plane/envoy v1.35.0
go: downloading github.com/envoyproxy/protoc-gen-validate v1.2.1
go: downloading github.com/go-zookeeper/zk v1.0.3
go: downloading golang.org/x/time v0.5.0
go: downloading github.com/go-logr/stdr v1.2.2
go: downloading go.opentelemetry.io/auto/sdk v1.2.1
go: downloading go.opentelemetry.io/otel/bridge/opencensus v0.45.0
go: downloading go.opentelemetry.io/otel/exporters/otlp/otlpmetric/otlpmetricgrpc v0.45.0
go: downloading go.opentelemetry.io/otel/exporters/otlp/otlpmetric/otlpmetrichttp v0.45.0
go: downloading go.opentelemetry.io/otel/exporters/otlp/otlptrace/otlptracegrpc v1.22.0
go: downloading go.opentelemetry.io/otel/exporters/otlp/otlptrace v1.28.0
go: downloading go.opentelemetry.io/otel/exporters/otlp/otlptrace/otlptracehttp v1.28.0
go: downloading go.opentelemetry.io/otel/exporters/prometheus v0.45.0
go: downloading go.opentelemetry.io/otel/exporters/stdout/stdoutmetric v0.45.0
go: downloading go.opentelemetry.io/otel/exporters/stdout/stdouttrace v1.22.0
go: downloading golang.org/x/crypto v0.45.0
go: downloading github.com/jcmturner/rpc/v2 v2.0.3
go: downloading github.com/sourcegraph/conc v0.3.0
go: downloading github.com/subosito/gotenv v1.6.0
go: downloading github.com/hashicorp/hcl v1.0.0
go: downloading gopkg.in/ini.v1 v1.67.0
go: downloading github.com/magiconair/properties v1.8.10
go: downloading github.com/pelletier/go-toml/v2 v2.1.0
go: downloading github.com/elastic/lunes v0.2.0
go: downloading github.com/openshift/api v3.9.0+incompatible
go: downloading github.com/google/gnostic-models v0.6.8
go: downloading sigs.k8s.io/json v0.0.0-20221116044647-bc3834ca7abd
go: downloading sigs.k8s.io/yaml v1.3.0
go: downloading gopkg.in/inf.v0 v0.9.1
go: downloading github.com/google/go-cmp v0.7.0
go: downloading github.com/jmespath/go-jmespath v0.4.0
go: downloading github.com/stretchr/objx v0.5.2
go: downloading github.com/fatih/color v1.15.0
go: downloading github.com/mattn/go-colorable v0.1.13
go: downloading github.com/mattn/go-isatty v0.0.19
go: downloading github.com/mitchellh/go-homedir v1.1.0
go: downloading github.com/armon/go-metrics v0.4.1
go: downloading github.com/Microsoft/go-winio v0.6.2
go: downloading github.com/containerd/errdefs v1.0.0
go: downloading github.com/containerd/errdefs/pkg v0.3.0
go: downloading github.com/distribution/reference v0.6.0
go: downloading github.com/docker/go-connections v0.6.0
go: downloading github.com/opencontainers/go-digest v1.0.0
go: downloading github.com/opencontainers/image-spec v1.1.1
go: downloading github.com/tklauser/numcpus v0.6.1
go: downloading github.com/go-ole/go-ole v1.2.6
go: downloading github.com/leodido/ragel-machinery v0.0.0-20181214104525-299bdde78165
go: downloading github.com/mitchellh/copystructure v1.2.0
go: downloading github.com/golang/groupcache v0.0.0-20210331224755-41bb18bfe9da
go: downloading github.com/dennwc/varint v1.0.0
go: downloading go.uber.org/atomic v1.11.0
go: downloading github.com/Azure/azure-sdk-for-go/sdk/internal v1.3.0
go: downloading github.com/AzureAD/microsoft-authentication-library-for-go v1.1.1
go: downloading github.com/google/go-querystring v1.1.0
go: downloading github.com/hashicorp/go-retryablehttp v0.7.4
go: downloading golang.org/x/tools v0.38.0
go: downloading github.com/go-resty/resty/v2 v2.7.0
go: downloading github.com/gorilla/websocket v1.5.0
go: downloading github.com/hashicorp/cronexpr v1.1.2
go: downloading github.com/cncf/xds/go v0.0.0-20251022180443-0feb69152e9f
go: downloading github.com/planetscale/vtprotobuf v0.6.1-0.20240319094008-0393e58bdf10
go: downloading go.opentelemetry.io/proto/otlp v1.3.1
go: downloading github.com/jcmturner/aescts/v2 v2.0.0
go: downloading github.com/magefile/mage v1.15.0
go: downloading k8s.io/kube-openapi v0.0.0-20230717233707-2695361300d9
go: downloading github.com/hashicorp/go-immutable-radix v1.3.1
go: downloading github.com/docker/go-units v0.5.0
go: downloading github.com/moby/docker-image-spec v1.3.1
go: downloading github.com/bmatcuk/doublestar/v4 v4.6.1
go: downloading github.com/mitchellh/reflectwalk v1.0.2
go: downloading github.com/kylelemons/godebug v1.1.0
go: downloading github.com/pkg/browser v0.0.0-20210911075715-681adbf594b8
go: downloading golang.org/x/sync v0.18.0
go: downloading github.com/google/s2a-go v0.1.7
go: downloading github.com/googleapis/gax-go/v2 v2.12.0
go: downloading github.com/munnerz/goautoneg v0.0.0-20191010083416-a7dc8b61c822
go: downloading github.com/go-openapi/swag v0.22.4
go: downloading github.com/go-openapi/jsonreference v0.20.2
go: downloading github.com/golang-jwt/jwt/v5 v5.0.0
go: downloading golang.org/x/mod v0.29.0
go: downloading github.com/googleapis/enterprise-certificate-proxy v0.3.2
go: downloading github.com/emicklei/go-restful/v3 v3.10.2
go: downloading github.com/mailru/easyjson v0.7.7
go: downloading github.com/go-openapi/jsonpointer v0.20.0
go: downloading github.com/josharian/intern v1.0.0
go: downloading github.com/grpc-ecosystem/grpc-gateway/v2 v2.26.3
go: downloading github.com/prometheus/client_model v0.6.2
go: downloading go.opentelemetry.io/proto/otlp v1.7.0
go: downloading github.com/open-telemetry/opentelemetry-collector-contrib v0.142.0
go: downloading go.opentelemetry.io v0.1.0
go: downloading go.opentelemetry.io/collector v0.142.0
go: downloading go.opentelemetry.io/collector/confmap/converter/expandconverter v0.113.0
go: downloading go.opentelemetry.io/collector/confmap/provider/envprovider v1.48.0
go: downloading go.opentelemetry.io/collector/confmap/provider/fileprovider v1.48.0
go: downloading go.opentelemetry.io/collector/confmap/provider/httpprovider v1.48.0
go: downloading go.opentelemetry.io/collector/confmap/provider/httpsprovider v1.48.0
go: downloading go.opentelemetry.io/collector/confmap/provider/yamlprovider v1.48.0
go: downloading go.opentelemetry.io/collector/receiver/receiverhelper v0.142.0
go: github.com/os-observability/redhat-opentelemetry-collector imports
	github.com/open-telemetry/opentelemetry-collector-contrib/exporter/kafkaexporter imports
	github.com/open-telemetry/opentelemetry-collector-contrib/pkg/translator/jaeger imports
	github.com/open-telemetry/opentelemetry-collector-contrib/internal/coreinternal/idutils: cannot find module providing package github.com/open-telemetry/opentelemetry-collector-contrib/internal/coreinternal/idutils
go: module github.com/open-telemetry/opentelemetry-collector-contrib/receiver/opencensusreceiver is deprecated: this receiver is no longer maintained and has reached end-of-life. See https://github.com/open-telemetry/opentelemetry-collector-contrib/issues/36791
go: module go.opentelemetry.io/collector/exporter/loggingexporter is deprecated: loggingexporter is deprecated in favour of the debugexporter. It will be removed in September 2024.
go: module go.opentelemetry.io/collector/extension/ballastextension is deprecated: Use the GOMEMLIMIT environment variable instead.
go: warning: github.com/openshift/api@v3.9.0+incompatible: retracted by module author: v3.9.0 is the only tag in openshift/api and it was created before go.mod was
go: to switch to the latest unretracted version, run:
	go get github.com/openshift/api@latest

@renovate renovate bot force-pushed the renovate/github.com-open-telemetry-opentelemetry-collector-contrib-connector-spanmetricsconnector-0.x branch from aec1cf6 to 8bddaf7 Compare February 18, 2025 06:44
@renovate renovate bot changed the title Update module github.com/open-telemetry/opentelemetry-collector-contrib/connector/spanmetricsconnector to v0.119.0 Update module github.com/open-telemetry/opentelemetry-collector-contrib/connector/spanmetricsconnector to v0.120.0 Feb 18, 2025
@renovate renovate bot force-pushed the renovate/github.com-open-telemetry-opentelemetry-collector-contrib-connector-spanmetricsconnector-0.x branch from 8bddaf7 to 8abdf7e Compare February 19, 2025 19:26
@renovate renovate bot changed the title Update module github.com/open-telemetry/opentelemetry-collector-contrib/connector/spanmetricsconnector to v0.120.0 Update module github.com/open-telemetry/opentelemetry-collector-contrib/connector/spanmetricsconnector to v0.120.1 Feb 19, 2025
@renovate renovate bot force-pushed the renovate/github.com-open-telemetry-opentelemetry-collector-contrib-connector-spanmetricsconnector-0.x branch from 8abdf7e to 50e8ed8 Compare March 4, 2025 14:51
@renovate renovate bot changed the title Update module github.com/open-telemetry/opentelemetry-collector-contrib/connector/spanmetricsconnector to v0.120.1 Update module github.com/open-telemetry/opentelemetry-collector-contrib/connector/spanmetricsconnector to v0.121.0 Mar 4, 2025
@renovate renovate bot force-pushed the renovate/github.com-open-telemetry-opentelemetry-collector-contrib-connector-spanmetricsconnector-0.x branch from 50e8ed8 to 6a7ba9e Compare March 18, 2025 07:04
@renovate renovate bot changed the title Update module github.com/open-telemetry/opentelemetry-collector-contrib/connector/spanmetricsconnector to v0.121.0 Update module github.com/open-telemetry/opentelemetry-collector-contrib/connector/spanmetricsconnector to v0.122.0 Mar 18, 2025
@renovate renovate bot force-pushed the renovate/github.com-open-telemetry-opentelemetry-collector-contrib-connector-spanmetricsconnector-0.x branch from 6a7ba9e to df4737c Compare April 1, 2025 02:49
@renovate renovate bot changed the title Update module github.com/open-telemetry/opentelemetry-collector-contrib/connector/spanmetricsconnector to v0.122.0 Update module github.com/open-telemetry/opentelemetry-collector-contrib/connector/spanmetricsconnector to v0.123.0 Apr 1, 2025
@renovate renovate bot force-pushed the renovate/github.com-open-telemetry-opentelemetry-collector-contrib-connector-spanmetricsconnector-0.x branch from df4737c to 6bf9858 Compare April 15, 2025 02:42
@renovate renovate bot changed the title Update module github.com/open-telemetry/opentelemetry-collector-contrib/connector/spanmetricsconnector to v0.128.0 Update module github.com/open-telemetry/opentelemetry-collector-contrib/connector/spanmetricsconnector to v0.129.0 Jun 30, 2025
@renovate renovate bot force-pushed the renovate/github.com-open-telemetry-opentelemetry-collector-contrib-connector-spanmetricsconnector-0.x branch from 754b183 to bdf61eb Compare July 14, 2025 19:51
@renovate renovate bot changed the title Update module github.com/open-telemetry/opentelemetry-collector-contrib/connector/spanmetricsconnector to v0.129.0 Update module github.com/open-telemetry/opentelemetry-collector-contrib/connector/spanmetricsconnector to v0.130.0 Jul 14, 2025
@renovate renovate bot force-pushed the renovate/github.com-open-telemetry-opentelemetry-collector-contrib-connector-spanmetricsconnector-0.x branch from bdf61eb to b1e5a28 Compare July 29, 2025 23:30
@renovate renovate bot changed the title Update module github.com/open-telemetry/opentelemetry-collector-contrib/connector/spanmetricsconnector to v0.130.0 Update module github.com/open-telemetry/opentelemetry-collector-contrib/connector/spanmetricsconnector to v0.131.0 Jul 29, 2025
@renovate renovate bot force-pushed the renovate/github.com-open-telemetry-opentelemetry-collector-contrib-connector-spanmetricsconnector-0.x branch from b1e5a28 to 5661dca Compare August 12, 2025 17:56
@renovate renovate bot changed the title Update module github.com/open-telemetry/opentelemetry-collector-contrib/connector/spanmetricsconnector to v0.131.0 Update module github.com/open-telemetry/opentelemetry-collector-contrib/connector/spanmetricsconnector to v0.132.0 Aug 12, 2025
@renovate renovate bot force-pushed the renovate/github.com-open-telemetry-opentelemetry-collector-contrib-connector-spanmetricsconnector-0.x branch from 5661dca to c92d36b Compare August 26, 2025 03:53
@renovate renovate bot changed the title Update module github.com/open-telemetry/opentelemetry-collector-contrib/connector/spanmetricsconnector to v0.132.0 Update module github.com/open-telemetry/opentelemetry-collector-contrib/connector/spanmetricsconnector to v0.133.0 Aug 26, 2025
@renovate renovate bot force-pushed the renovate/github.com-open-telemetry-opentelemetry-collector-contrib-connector-spanmetricsconnector-0.x branch from c92d36b to a2aaa81 Compare August 31, 2025 11:01
@renovate renovate bot changed the title Update module github.com/open-telemetry/opentelemetry-collector-contrib/connector/spanmetricsconnector to v0.133.0 Update module github.com/open-telemetry/opentelemetry-collector-contrib/connector/spanmetricsconnector to v0.134.0 Aug 31, 2025
@renovate renovate bot force-pushed the renovate/github.com-open-telemetry-opentelemetry-collector-contrib-connector-spanmetricsconnector-0.x branch from a2aaa81 to bcfe985 Compare September 8, 2025 21:13
@renovate renovate bot changed the title Update module github.com/open-telemetry/opentelemetry-collector-contrib/connector/spanmetricsconnector to v0.134.0 Update module github.com/open-telemetry/opentelemetry-collector-contrib/connector/spanmetricsconnector to v0.135.0 Sep 8, 2025
@renovate renovate bot force-pushed the renovate/github.com-open-telemetry-opentelemetry-collector-contrib-connector-spanmetricsconnector-0.x branch from bcfe985 to 88c1f5a Compare September 23, 2025 00:52
@renovate renovate bot changed the title Update module github.com/open-telemetry/opentelemetry-collector-contrib/connector/spanmetricsconnector to v0.135.0 Update module github.com/open-telemetry/opentelemetry-collector-contrib/connector/spanmetricsconnector to v0.136.0 Sep 23, 2025
@renovate renovate bot force-pushed the renovate/github.com-open-telemetry-opentelemetry-collector-contrib-connector-spanmetricsconnector-0.x branch from 88c1f5a to 93d605f Compare October 7, 2025 02:49
@renovate renovate bot changed the title Update module github.com/open-telemetry/opentelemetry-collector-contrib/connector/spanmetricsconnector to v0.136.0 Update module github.com/open-telemetry/opentelemetry-collector-contrib/connector/spanmetricsconnector to v0.137.0 Oct 7, 2025
@renovate renovate bot force-pushed the renovate/github.com-open-telemetry-opentelemetry-collector-contrib-connector-spanmetricsconnector-0.x branch from 93d605f to 05ed237 Compare October 20, 2025 21:57
@renovate renovate bot changed the title Update module github.com/open-telemetry/opentelemetry-collector-contrib/connector/spanmetricsconnector to v0.137.0 Update module github.com/open-telemetry/opentelemetry-collector-contrib/connector/spanmetricsconnector to v0.138.0 Oct 20, 2025
@renovate renovate bot force-pushed the renovate/github.com-open-telemetry-opentelemetry-collector-contrib-connector-spanmetricsconnector-0.x branch from 05ed237 to 7470b04 Compare November 4, 2025 03:00
@renovate renovate bot changed the title Update module github.com/open-telemetry/opentelemetry-collector-contrib/connector/spanmetricsconnector to v0.138.0 Update module github.com/open-telemetry/opentelemetry-collector-contrib/connector/spanmetricsconnector to v0.139.0 Nov 4, 2025
@renovate renovate bot force-pushed the renovate/github.com-open-telemetry-opentelemetry-collector-contrib-connector-spanmetricsconnector-0.x branch from 7470b04 to 6865658 Compare November 18, 2025 05:41
@renovate renovate bot changed the title Update module github.com/open-telemetry/opentelemetry-collector-contrib/connector/spanmetricsconnector to v0.139.0 Update module github.com/open-telemetry/opentelemetry-collector-contrib/connector/spanmetricsconnector to v0.140.0 Nov 18, 2025
@renovate renovate bot force-pushed the renovate/github.com-open-telemetry-opentelemetry-collector-contrib-connector-spanmetricsconnector-0.x branch from 6865658 to 6b67744 Compare November 18, 2025 22:55
@renovate renovate bot changed the title Update module github.com/open-telemetry/opentelemetry-collector-contrib/connector/spanmetricsconnector to v0.140.0 Update module github.com/open-telemetry/opentelemetry-collector-contrib/connector/spanmetricsconnector to v0.140.1 Nov 18, 2025
@renovate renovate bot force-pushed the renovate/github.com-open-telemetry-opentelemetry-collector-contrib-connector-spanmetricsconnector-0.x branch from 6b67744 to 3680a04 Compare December 1, 2025 18:52
@renovate renovate bot changed the title Update module github.com/open-telemetry/opentelemetry-collector-contrib/connector/spanmetricsconnector to v0.140.1 Update module github.com/open-telemetry/opentelemetry-collector-contrib/connector/spanmetricsconnector to v0.141.0 Dec 1, 2025
…ib/connector/spanmetricsconnector to v0.142.0
@renovate renovate bot force-pushed the renovate/github.com-open-telemetry-opentelemetry-collector-contrib-connector-spanmetricsconnector-0.x branch from 3680a04 to dd1a620 Compare December 16, 2025 02:04
@renovate renovate bot changed the title Update module github.com/open-telemetry/opentelemetry-collector-contrib/connector/spanmetricsconnector to v0.141.0 Update module github.com/open-telemetry/opentelemetry-collector-contrib/connector/spanmetricsconnector to v0.142.0 Dec 16, 2025
Sign up for free to join this conversation on GitHub. Already have an account? Sign in to comment

Labels

None yet

Projects

None yet

Development

Successfully merging this pull request may close these issues.

1 participant