Releases: open-telemetry/opentelemetry-collector-contrib
v0.61.0
The OpenTelemetry Collector Contrib contains everything in the opentelemetry-collector release (be sure to check the release notes here as well!).
🛑 Breaking changes 🛑
dockerstatsreceiver
: For V2 scraper implementation, change the defaults from emitting everything to a sensible set of defaults. (#9794, #14093)
This is only breaking if you have explicitly enabled the featuregatereceiver.dockerstats.useScraperV2
.dockerstatsreceiver
: Change 'stats' config key to 'metrics'. (#9794, #14184)
Note: this is only breaking for those who have explicitly enabled the featuregatereceiver.dockerstatsd.useScraperV2
.iisreceiver
: Emit metrics per-site and per-app-pool with new resource attributes. (#14448)pkg/telemetryquerylanguage
: UnexportBoolExpressionEvaluator
,Literal
,NewGetter
, andNewFunctionCall
. (#13737)mongodbatlasreceiver
: Retain actual raw log line as Body. Theraw
attribute is now removed. Use Body instead for the raw log line. (#14178)mysqlreceiver
: The metrics are now being emitted with a resource attribute marking the endpoint of the database. (#14138)pkg/ottl
: RenameParseQueries
toParseStatements
and renameQuery
toStatement
. (#14444)jaegerreceiver
: Remove remote sampling endpoint from the Jaeger receiver (#6633)oteltransformationlanguage
: Renames ottldatapoints to ottldatapoints to better represent how the context is intended to be used. (#14384)pkg/ottl
: Renames Telemetry Query Language to OpenTelemetry Transformation Language to avoid confusion with an analysis language. (#14150)pkg/ottl
: Flattens ottlcommon and ottlotel into ottlfuncs. (#14386)pkg/ottl
: Replaced Logger with TelemetrySettings (#14389)
🚩 Deprecations 🚩
coralogixexporter
: deprecating jaeger based tracing configuration in favour of OpenTelemetry protocol based one. (#7931)
Please remove theendpoint
field and use the newtraces.endpoint
field with your OpenTelemetry endpoint.elasticsearchreceiver, hostmetricsreceiver, kubelestatsreceiver, memcachedreceiver, vcenterreceiver, zookeeperreceiver
: Log message to announcedirection
attribute feature gate deprecation (#14129)
The change to remove thedirection
attribute has been reverted in the specification. As a result, the following feature gates will be removed in v0.62.0:receiver.elasticsearchreceiver.emitMetricsWithDirectionAttribute
receiver.elasticsearchreceiver.emitMetricsWithoutDirectionAttribute
receiver.hostmetricsreceiver.emitMetricsWithDirectionAttribute
receiver.hostmetricsreceiver.emitMetricsWithoutDirectionAttribute
receiver.kubelestatsreceiver.emitMetricsWithDirectionAttribute
receiver.kubelestatsreceiver.emitMetricsWithoutDirectionAttribute
receiver.memcachedreceiver.emitMetricsWithDirectionAttribute
receiver.memcachedreceiver.emitMetricsWithoutDirectionAttribute
receiver.vcenterreceiver.emitMetricsWithDirectionAttribute
receiver.vcenterreceiver.emitMetricsWithoutDirectionAttribute
receiver.zookeeperreceiver.emitMetricsWithDirectionAttribute
receiver.zookeeperreceiver.emitMetricsWithoutDirectionAttribute
extensions/headerssetter
: Deprecate theextensions/headerssetter
module, useextensions/headerssetterextenions
instead. (#13774)
🚀 New components 🚀
s3mapprovider
: A new implementation of ConfigMapProvider for Amazon S3 (s3mapprovider) allows OTEL Collector the ability to load configuration for itself by fetching and reading config files stored in Amazon S3. (#12939)
💡 Enhancements 💡
loki
: Split the conversion OTLP -> Loki into its own package (#13649)kafkareceiver
: Add direct unmarshaler, inserting Kafka payload bytes as the body of a log record (#13252)apachereceiver
: The receiver now supports 6 more metrics, more information in the linked issue. (#14095)datadogexporter
: Add logs support (#2651)datadogexporter
: The "hostmetrics" receiver metrics are now correctly mapped to Datadog system metrics. (#14005)fileexporter
: support for compressing the telemetry data before exporting. (#13626)fileexporter
: support for encoding telemetry data using proto marshaler (#13626)googlecloudspannerreceiver
: Fixed errors when transaction-stats columns are NULL (#14189)cumulativetodeltaprocessor
: Reduce memory consumption of histograms in cumulativetodeltaprocessor by allocating only a single identity per datapoint. (#13751)chronyreceiver
: Improved chronyreceiver's context and timeout handling (#14131)
Updated chronyreceiver to usenet.Dialer.DialContext
and respect timeouts more closelyfilterspan
: Add span kind filtering. (#13612)mysqlreceiver
: The receiver now scraper 16 new metrics related to io_waits. (#14138)filelog
,journald
,syslog
,tcplog
,udplog
,windowseventlog
: Allow 'parse_to' fields to accept 'attributes' and 'resource' (#14089)sentryexporter
: Make sentry status more detailed - use HTTP and Grpc codes from tags (#13407)routingprocessor
: Add support for using OpenTelemetry Transformation Language (OTTL) expressions as routing conditions. (#13158)transformprocessor
: AddSplit
function, which separates a string by the delimiter and returns an array of substrings. (#11790)pkg/winperfcounters
: Add counter path to error if scraping fails (#14443)
🧰 Bug fixes 🧰
awsemfexporter
: Fix regression that causes null dimensions to be appended during dimension roll up. (#14532)k8sprocessor
: check every association for eventual update (#13119)sentryexporter
: Omit empty parent span id (#13415)pkg/ottl
: Replace invalid comparison print statement with a debug log entry (#14467)servicegraphprocessor
: Fixed metric names to match the specification. (#14187)hostmetricsreceiver
: On Windows systems, do not fail to start if a performance counter is missing or inaccessible. (#14032)loki
: Fix converting log resources to loki labels for more than one log record. (#14288)mongodbatlasreceiver
: Fix timestamp parsing for mongodb 4.2 audit logs (#14168)mongodbatlasreceiver
: Add missing fields for audit logs (#14177)mongodbatlasreceiver
: Fix potential infinite loop when scraping audit logs (#14169)otlpjsonfilereceiver
: logs receive operations should use StartLogsOp/EndLogsOp (#14535)pkg/translator/prometheus
: do not normalize metric name with colon (#14135)
v0.60.0
The OpenTelemetry Collector Contrib contains everything in the opentelemetry-collector release (be sure to check the release notes here as well!).
🛑 Breaking changes 🛑
-
pkg/stanza
: Change name of ParserConfig.Config to more specific ParserConfig.SeverityConfig (#14126) -
pkg/stanza/adapter
: RemoveOperatorConfigs
type, renameLogReceiverType.DecodeInputConfig
toLogReceiverType.InputConfig
. (#14078) -
postgresqlreceiver
: The receiver will now emit resource attributes via default. (#13811)
old behavior can be established by setting the featuregatesreceiver.postgresql.emitMetricsWithResourceAttributes
to false andreceiver.postgresql.emitMetricsWithoutResourceAttributes
to true -
k8sattributesprocessor
: Change the way howkey_regex
setting is handled. After this change, provided expressions are applied to the full length of attribute values. (#9716) -
pkg/telemetryquerylanguage
: Add ability to specify attribute keys in thelimit
function that aren't allowed to be dropped (#9734)
This breaking change affects the transform processor since we don't have a way to default values in a function call.
🚩 Deprecations 🚩
exporter/influxdb
: Change status to unmaintained (#14098)receiver/influxdb
: Change status to unmaintained (#14099)
🚀 New components 🚀
instanaexporter
: Enable Instana exporter (#13395)servicegraph
: Add traces processor that builds a map representing the interrelationships between various services in a system (#9232)
💡 Enhancements 💡
-
elasticsearchreceiver
: Add additional node metric for cache count (#14027) -
pkg/telemetryquerylanguage
: AddConcat
, which allows concatenating an arbitrary number of strings with a delimiter (#12476) -
processor/filter
: Added ability to filter by metric type using expressionMetricType
keyword. (#14107) -
elasticsearchreceiver
: Add additional two cluster-level metrics (#13748)
Add additional cluster metrics for elasticsearch.cluster.in_flight_fetch & elasticsearch.cluster.pending_tasks. -
dockerstatsreceiver
: Simplify BlockIO metrics by taking operation out of the metric name and putting it in an attribute. (#9794, #13445) -
elasticsearchreceiver
: Addednode.fs.disk.{free,total}
to elasticsearch receiver (#13571) -
elasticsearchexporter
: Support sending OpenTelemetry tracing data to Elasticsearch index or data stream. (#12069) -
elasticsearchreceiver
: Adds new method Version in the client request to get the elasticsearch version number (#14012) -
fileexporter
: Support for rotation of telemetry files (#13626) -
processor/filer
: Add support for ExponentialHistogram and Summary metrics (#14116) -
receiver/k8scluster
: Moving initialization of k8s client from receiver init to receiver start phase. (#12582) -
lokiexporter
: Overhaul of the Loki Exporter, in preparation for native OTLP support at Loki (#12873) -
awskinesisexporter
: Upgrading client to use v2 of the AWS SDK (#13898) -
prometheusreceiver
: Remove storing pointers to pdata points, allow removing unnecessary pdata points copy. (#13922) -
sigv4authextension
: Add more context to credential errors generated by the sigv4auth extension. (#14031) -
tailsampling
: Add support for all sampling policies in and & composite policy (#11505) -
pkg/telemetryquerylanguage
: Add a Logger interface and allow it to be specified as an argument type in TQL functions. (#9730) -
telemetryquerylanguage
: Adds inequality operators<
,<=
,>=
,>
to TQL. (#12491) -
telemetryquerylanguage
: Add the Int factory function. (#11810) -
telemetryquerylanguage
: Add split factory function to separate a string by the delimiter, and returns an array of substrings. (#11790) -
processor/transform
: AddConcat
, which allows concatenating an arbitrary number of strings with a delimiter (#12476)
🧰 Bug fixes 🧰
hostmetricsreceiver
: Set process metrics start time to process create time (#11447)awsemfexporter
: Properly handle empty dimension set in metric_declarations (#13766)clickhouseexporter
: cast FlagsStruct into uint32 in ExecContext to fix export failure (#13843)k8sprocessor
: fix the passthrough mode (#13765)
Treating k8s.pod.ip resource attribute in special way, as it is added by passthrough modeelasticsearchreceiver
: Fix issue whereelasticsearch.os.*
metrics were not being collected (#13983)elasticsearchreceiver
: Fix issue whereelasticsearch.node.script.*
metrics were not being collected (#13983)elasticsearchreceiver
: Fix issue whereelasticsearch.node.translog.*
metrics were not being collected (#13983)elasticsearchreceiver
: Fix issue whereelasticsearch.cluster_state.*
metrics were not being collected (#13930)elasticsearchreceiver
: Fix issue whereelasticsearch.node.shards.data_set.size
emits 0 value for unsupported version (#14012)elasticsearchreceiver
: Fix elasticsearch.node.disk.io.read/write metrics from By to KiBy (#13815)elasticsearchreceiver
: Fix issue whereelasticsearch.indexing_pressure.memory.limit
emits 0 value for unsupported version (#14012)elasticsearchreceiver
: Fix issue whereelasticsearch.cluster.state_update.time
emits attributes pairs that don't exist (#13984)awsxrayexporter
: Fixes a bug in the logic for parsing CloudWatch Log Group ARNs (#13702)loadbalancingexporter
: Fixed the case in loadbalancingexporter where a DNS resolver is defined without an explicit Port. (#10321)k8sattributesprocessor
: k8sattributesprocessor now correctly adds attributes to new pods that start after the collector (#13619)tailsamplingprocessor
: Fixes SpanCount sampler not using the correct span count for decision. (#13865)filelogreceiver
: Fix issue for missingkey_value_parser
operator (#13631)mongodbatlasreceiver
: fix log parsing for clusters using major version 4.2 (#14008)chronyreceiver
: When trying to read from socket, the socket type was incorrect (#13862)postgresqlreceiver
: Uses the postgres databasename when retrieving database inventory information (#13641)prometheusreceiver/prometheusremotewriteexporter
: Leave the sum unset in histograms without sums, and don't produce _sum metric points for histograms without sums (#7546)processor/redaction
: Update redaction attributes in case if data sent through the processor more than once, not not ignore them. (#13854)chloggen
: changelog generation tool moved to https://github.com/open-telemetry/opentelemetry-go-build-tools (#14022)exporter/AlibabaCloudLogServiceExporter
: Fix issue that promethus occuring error when the resource metric labels contains dot (#3429)exporter/tanzuobservabilityexporter
: This change causes tanzuobservabilityexporter to depend on 0.10.4 of the
wavefront-sdk-go library.
(#13417)transformprocessor
: Fixes panic of transformprocessor handling Gauge types (#13905)vcenterreceiver
: Fix incorrect KBy and MBy units, updating them to KiBy and MiBy (#13935)
v0.59.0
The OpenTelemetry Collector Contrib contains everything in the opentelemetry-collector release (be sure to check the release notes here as well!).
🛑 Breaking changes 🛑
-
elasticsearchreceiver
: Remove direction for metrics. The feature gate: receiver.elasticsearchreceiver.emitMetricsWithoutDirectionAttribute can be set to apply the following (#13258) (#12189)elasticsearch
metrics:elasticsearch.node.cluster.io
will become:elasticsearch.node.cluster.io.received
elasticsearch.node.cluster.io.sent
-
kubeletstatsreceiver
: Remove direction for metrics. The feature gate: receiver.kubeletstatsreceiver.emitMetricsWithoutDirectionAttribute can be set to apply the following (#12588) (#12164)kubeletstats
metrics:k8s.node.network.io
will become:k8s.node.network.io.transmit
k8s.node.network.io.receive
k8s.node.network.errors
will become:k8s.node.network.errors.transmit
k8s.node.network.errors.receive
-
processor/metricstransform
: Removeprocessor.metricstransformprocessor.UseOTLPDataModel
feature flag. OpenCensus-based implementation is not available anymore.
(#13405) -
exporter/mezmoexporter
: This change removes the hardcoded "otel" hostname that was embedded
in outgoing logs data.
(#13410)
It is replaced by:-
Sending to a new collector endpoint that does not require the
hostname parameter. -
Recognizing the "host.name" resource attribute and using that
value to fill in log metadata recognized upstream.
This is a breaking change, and as such will generate a startup
error if the exporter is configured to send to an endpoint that
does not support this feature. -
-
``filelog
,
journald`, `otlpjsonfile`, `syslog`, `tcplog`, `udplog`, `windowseventlog` receivers`: Remove `helper.Duration` struct. Configured time values no longer have a default unit of `s` (#13439) -
pkg/stanza
: Remove HostIdentifier, HostIdentifierConfig and associated functions (#13396) -
``filelog
,
journald`, `syslog`, `tcplog`, `udplog`, and `windowseventlog` receivers`: Fix a bug where original severity text was not preserved. (#13263) -
pkg/stanza
: Update function and struct names in keyvalue parser (#13418) -
cmd/mdatagen
: Remove old metadata generator (#13374)
🚩 Deprecations 🚩
jaegerreceiver
: Add remote sampling deprecation warning (#6633)
🚀 New components 🚀
pulsarreceiver
: Add Apache Pulsar receiver (#9796)instanaexporter
: Add Instana exporter implementation (#13395)instanaexporter
: Add initial structure of the Instana exporter (#13395)
💡 Enhancements 💡
-
loadbalancingexporter
: Addedinterval
andtimeout
to the dns configuration in the loadbalancer exporter (#10199) -
pkg/telemetryquerylanguage
: AddJoin
, which allows joining an arbitrary number of strings with a delimiter (#12476) -
elasticsearchreceiver
: Add additional metrics (#13115)
Add additional metrics for indexing_pressure, published_states, state_queue, ingest, script. -
hostmetricsreceiver
: Add threads count metric (#12482) -
aerospikereceiver
: Add query_count and query_tracked metrics (#13255) -
docsgen
: use contrib components, add makefile target (#12639) -
dockerstatsreceiver
: Change relevant memory metrics from gauges to sums, so they are aligned with spec recommendations and can be aggregated. (#9794) -
pkg/stanza/csv_parser
: Addignore_quotes
option that ignores all quoting in fields if true. (#13656) -
pkg/telemetryquerylanguage
: Add TQL mappings forInstrumentationScope.attributes
(#13639) -
k8sattributesprocessor
: Add support for discovering Kubernetes CronJob name (#141) -
coreinternal
: Move test utilities out of testbed into coreinternal, allow use of these lightweight helpers from other modules. (#5742) -
kafkametricsreceiver
: Migrate receiver to the new metrics builder (#7142)
This allows users to disable particular metrics in through user settings. -
mongodbatlasreceiver
: Add logs retrieval capability (#12347) -
mongodbreceiver
: Enhance partial error handling with descriptive metric/attribute messages. (#13367) -
``filelog
,
journald`, `syslog`, `tcplog`, `udplog`, `windowseventlog` receivers`: Add ability to set log body when when parsing. (#10274) -
``filelog
,
journald`, `syslog`, `tcplog`, `udplog`, `windowseventlog` receivers`: Enhance error message when csv_parser finds unexpected number of fields (#13427) -
``filelog
,
journald`, `syslog`, `tcplog`, `udplog`, `windowseventlog` receivers`: Enable debugging operators `stdout` and `file_output` (#13394) -
postgresqlreceiver
: Adds background writer metrics (#13327)
Adds the following metrics:- postgresql.bgwriter.buffers.allocated
- postgresql.bgwriter.buffers.writes
- postgresql.bgwriter.checkpoint.count
- postgresql.bgwriter.duration
- postgresql.bgwriter.maxwritten.count
-
postgresqlreceiver
: Adds more metrics regarding database tables. (#13228)
metrics added:
postgresql.database.count
postgresql.table.count
postgresql.table.size
postgresql.table.vacuum.count -
postgresqlreceiver
: Adds WAL and connections metrics (#13399)
metrics added- postgresql.replication.data_delay
- postgresql.wal.age
- postgresql.wal.lag
- postgresql.connection.max
-
prometheusreceiver
: allow to query scrape jobs from OpenTelemetryOperators TargetAllocator (#7944) -
prometheusremotewrite
: Support customization of target_info metric including the ability to disable it (#12300) -
prometheusexporter
: Adds a feature to prometheusexporter that enables it to export exemplars along with histogram metrics. (#5192) -
prometheusexporter
: Use HTTPServerSettings in the exporter to leverage inbuilt TLS. (#10851) -
receivercreator
: adds the unique EndpointID to generated receiver componentID to prevent collisions (#12670) -
spanmetricsprocessor
: The unit of thelatency
metric is now explicitly defined. (#13423) -
extension/storage/storagetest
: Add in-memory and file-backed test extensions and clients (#13086) -
telemetryquerylanguage
: Avoid copying attributes when filtering on keys in thekeep_keys
TQL function (#4756) -
prometheusreceiver
: Remove temporary maps to dedup and remove unuseful labels (#13705)
🧰 Bug fixes 🧰
processor/metricstransform
: Aggregate cumulative data points with different start time. (#12611)expvarreceiver
: Fixes an bug where the mSpanSys value was recorded into the mCacheSys metric. (#13171)extension/filestorage
: Allow putting the compaction temp folder on a different filesystem. (#13449)prometheusremotewriteexporter
: Handle the case with 0 metrics gracefully. (#10364)prometheusreceiver
: Fix num data point for metrics recorded in prometheusreceiver (#13705)loadbalancingexporter
: Fixed a crash ifendpointFor
is called before any endpoints have been discovered (#10110)prometheusreceiver
: Fix timestamp for histograms and summaries with no Sum (#13705)exporter/sumologic
: Mark the exporter as mutating. (#13647)jaegerremotesampling
: Mark as alpha (#13005)mongodbreceiver
: Adds metric versioning checks to prevent partial errors (#13155)mongodbreceiver
: Change lpu integration test to use a mongodb 4.4 (#12981)pkg/translator/prometheus
: do not normalize metric name with multiple underscore (#13322)prometheusreceiver
: Make the error returned when dropping summary metrics that collide with histograms clearer. (#12976)prometheusremotewriteexporter
: Don't emit the target_info metric when it would only contain job and instance (#12768)receiver_creator
: Correct observer instance reference by updating watch_observers use ComponentID instead of just Type (#12801)vcenterreceiver
: Re-establish sessions when running with particular TLS settings. (#13447)
Release version 0.58.0
🛑 Breaking changes 🛑
-
clickhouseexporter
: update table schema (#8028)- add ServiceName field as primary key.
- use Map type for attribute, add secondary index.
-
postgresqlreceiver
: Moves metric attributestable
anddatabase
to resource attributes. (#12960)
This move has been hidden behind a featuregate. Please see https://github.com/open-telemetry/opentelemetry-collector-contrib/blob/main/receiver/postgresqlreceiver/README.md#feature-gate-configurations for more information transitioning.
This affects the following metrics.- postgresql.blocks_read
- postgresql.commits
- postgresql.db_size
- postgresql.backends
- postgresql.operations
- postgresql.rollbacks
-
all
: Update minimum go version to 1.18 (#12918)
🚩 Deprecations 🚩
dotnetdiagnosticsreceiver
: Change status to unmaintained (#12757)
🚀 New components 🚀
azureblobreceiver
: Add a new componentazureblobreciver
(#8834)
Add a new componentazureblobreceiver
that reads logs and traces from Azure Blob Storageazureeventhubreceiver
: New component to receive logs from Azure Event Hubs (#12786)headers_setter
: Add support for setting exporter headers from the upstream requests context (#5733, #7945, #4814)
💡 Enhancements 💡
filterprocessor
: Add ability to filter based on logs SeverityText and Body. (#9235)aerospikereceiver
: Support tls configuration. Add tls and tlsname config items. (#12770)datadogexporter
: Send host info when sending hostmetadata from datadogexporter (#12944)jaegerremotesampling
: extend jaegerremotesampling with remote sampling via gRPC (#6694)filterprocessor
: Add log filtering based on SeverityNumber (#12959)hostmetricsreceiver
: Add new resource attributeprocess.parent_pid
. The value of the attribute is the parent PID (#12290)k8sattributesprocessor
: Add support for discovering Kubernetes DaemonSet name and DaemonSet UID" (#141)k8sattributesprocessor
: Add support for discovering Kubernetes Job name and Job UID" (#141)k8sattributesprocessor
: Add support for discovering Kubernetes ReplicaSet name and ReplicaSet UID (#141)k8sattributesprocessor
: Add support for discovering Kubernetes StatefulSet name and StatefulSet UID" (#141)loadbalancingexporter
: Exporting trace pipelines based on Service name to avoid duplicate label svc + operation in collector hosts. (#12652)lokiexporter
: Don't retry on 4xx responses (excluding 429) from loki (#12930)observers
: Adds multiple observer.Notify subscriber support to observer.EndpointWatcher for multiple Endpoint event consumers. (#10830, #11541, #11544)filelogreceiver
: Process batches consecutively, rather than one per poll interval (#10285)postgresqlreceiver
: Client refactor to eventually support resource attributes. (#13087)postgresqlreceiver
: Adds Index Resource Attribute and Metrics Collection. (#13167)
This enhancement will only be enabled with the receiver.postgresql.emitMetricsWithResourceAttributes feature gate being enabled.pkg/translator/signalfx
: report Histogram min/max when present, do not report sum when not present (#13153)sigv4authextension
: Added separate region for STS for cross region auth (#12736)solacereceiver
: Adds topic destination as a new attribute to receiver's spans (#12640)pkg/telemetryquerylanguage
: Add Getter slices to the TQL parser, allowing them to be specified as function parameters. (#12476)
🧰 Bug fixes 🧰
aerospikereceiver
: Fix crash when connecting to an Aerospike server with authentication using a config with collect_cluster_metrics == false and no username or password. (#12979)apachereceiver
: Fix some partial errors not being correctly reported (#13133)couchdbreceiver
: Fix some partial errors not being correctly reported (#13007)signalfxreceiver
: log attempts to divide by zero at the debug level (#12969)mongodbreceiver
: Fix partial scraper errors not being reported (#13108)mysqlreceiver
: Fix some partial errors not being correctly reported (#13009)tailsamplingprocessor
: Fixing null pointer exception for span count sampling strategy. (#12745)
Release v0.57.2
Note: we skipped v0.57.0 and v0.57.1 in order to have the same version number as core.
The OpenTelemetry Collector Contrib contains everything in the opentelemetry-collector release (be sure to check the release notes there as well!)"
🛑 Breaking changes 🛑
healthcheckextension
: Remove deprecatedport
field from config. (#12668)processor/cumulativetodelta
: Removes the deprecatedmetrics
config option. Useinclude
/exclude
instead. (#12732)lokiexporter
: Deprecate theformat
option (#12897)metricstransformprocessor
: Remove deprecatedmetric_name
settings option (#12737)pkg/stanza/fileconsumer
: Unexport several fields that are meant for internal usage only (#12793)pkg/stanza/fileconsumer
: Rename fileconsumer.Input to fileconsumer.Manager (#12876)prometheusremotewriteexporter
: Exporttarget_info
nottarget
for resource attributes (#12079)pkg/translator/signalfx
: Remove no longer necessary prom compatible configuration fromFromTranslator
(#12671)signalfxexporter
: Remove no longer necessary feature gate for prom compatible metrics (#12671)zookeeperreceiver
: Remove direction for metrics. The feature gate: receiver.zookeeperreceiver.emitMetricsWithoutDirectionAttribute can be set to apply the following (#12772) (#12184)zookeeper
metrics:zookeeper.packet.count
will become:zookeeper.packet.received.count
zookeeper.packet.sent.count
🚀 New components 🚀
chronyreceiver
: This will add in support for measuring tracking data fromchronyd
(#11789)
💡 Enhancements 💡
-
datadogexporter
: Add host metadata tags to metrics on serverless environments (#12486) -
observer
: Add observer.Endpoint.ID to Env() (#12751) -
aerospikereceiver
: Scrape nodes in parallel when in collect_cluster_metrics mode. (#11563) -
coralogixexporter
: Add logs client to coralogixexporter (#12601) -
awscontainerinsightreceiver
: Pod Detection changes to support Containerd runtime in K8s (#12638) -
dockerstatsreceiver
: Enable a featuregate for the new implementation of scrape. Change the units in the new implementation to align to semantic convention. (#9794)
This allows the new implementation of scrape to be used via a featuregate.
It also updates the tests, which now test for expected descriptions and units in the new implementation. -
healthcheckextension
: Useconfighttp.HTTPServerSettings
to allow tls and auth. (#12668) -
demo
: Add connection time out for client in examples/demo/client (#12431) -
prometheusexporter
: Export target_info metrics with the resource attributes. (#8265) -
resourcedetectionprocessor
: update Azure resource detector to save "name" from Azure metadata API in azure.vm.name attribute (#12779) -
pkg/telemetryquerylanguage
: Adds standard contexts to the module that should be used when interacting with OTLP traces, metrics, and logs. (#12589) -
pkg/telemetryquerylanguage
: Adds a set of otel functions to the telemetryquerylanguage module. (#12754) -
pkg/telemetryquerylanguage
: Adds a set of common functions to the telemetryquerylanguage module. (#12739) -
cumulativetodeltaprocessor
: Cumulative Histogram metrics will now be converted to delta temporality and are no longer skipped. (#12423)
This means that consumers who currently rely on Histograms being skipped would need to ensure they are excluded via config. -
dockerstatsreceiver
: Initial PR for onboarding dockerstats onto mdatagen scraping. (#9794)
Additionally appends the internal docker client to allow options (bug fix). -
mongodbreceiver
: Enhance mongodbreceiver by adding new metrics (#12672) -
chronyreceiver
: Added internal chrony client (#11789)
-| Added an internal client for the receiver with modifications of the upstream client to fit the collector -
receivercreator
: add per-receiverresource_attribute
and validate endpoint type keys on global (#11766) -
pkg/translator/signalfx
: Optimize ToMetrics to emit datapoints under the same metric when same name and type. (#12902) -
sqlqueryreceiver
: Add static_attributes optional configuration to allow adding attributes/tags to queried metrics. (#11868)
🧰 Bug fixes 🧰
spanmetricsprocessor
: Fix panic caused by race condition when accessing span attributes. (#12644)awsxrayexporter
: Stop dropping exception in aws xray events for non error codes (#12643)signalfxexporter
: use azure.vm.name instead of host.name to build azure resource id (#12779)otelcontribcol
: Enabled multi-arch build for local development container builds (#11873)receiver/hostmetrics
: Do not throw scraping errors if conntrack metrics collection is disabled (#12799)kubeletstatsreceiver
: Fetch metadata from initContainers (#12887)metricstransformprocessor
: Fix logic in merging exponential histogram. (#12865)resourcedetectionprocessor
: Add backhost.name
attribute when running on GKE (#12354)filelogreceiver
: Fix issue where checkpoints could be ignored ifstart_at`` was set to
end`` (#12769)pkg/stanza
: Stop readerFactory from returning an error when creating an unsafeReader (#12766)
This bug caused the filelog receiver to crash when the collector was restarted and the logs were being read from the end of the fileprometheusreceiver
: Fix handling of timestamps to prevent reset when a new datapoint is recorded (#12746)exporter/prometheusremotewrite
: Fix a panic when a histogram does not have any buckets (#12777)signalfxexporter
: fix invalid response error message (#12654)skywalkingreceiver
: Add extra link attributes from skywalking ref. (#12651)spanmetricsprocessor
: Modifies spanmetrics processor to handle negative durations without crashing. Related to open-telemetry/opentelemetry-js-contrib#1013 (#7250)
Sets negative durations to count towards the smallest histogram bucket.splunkhecexporter
: use proper config flags to configure content length of gzip buffers for metrics and traces (#12906)
v0.56.0
The OpenTelemetry Collector Contrib contains everything in the opentelemetry-collector release (be sure to check the release notes here as well!).
🛑 Breaking changes 🛑
-
datadogexporter
: Change default value ofhost_metadata::hostname_source
toconfig_or_system
(#10424)- This behavior can be reverted by disabling the
exporter.datadog.hostname.preview
feature gate.
- This behavior can be reverted by disabling the
-
datadogexporter
: Make automatically detected hostname match the one reported by other Datadog products. (#10424)- This behavior can be reverted by disabling the
exporter.datadog.hostname.preview
feature gate.
- This behavior can be reverted by disabling the
-
dynatraceexporter
: Improve serialization of certain Instrument/Temporality pairings (#11828)- Non-monotonic cumulative Sum metrics will be exported as Gauges from now on. Non-monotonic cumulative Sums (usually UpDownCounters) will show the current value instead of a change rate.
-
transformprocessor
: Fieldmetric.type
is now accessed as an enum/int64 instead of a string. (#10349) -
memcachedreceiver
: Remove direction for metrics. The feature gate: receiver.memcachedreceiver.emitMetricsWithoutDirectionAttribute can be set to apply the following (#12404) (#12165)memcached
metrics:memcached.network
will become:memcached.network.sent
memcached.network.received
-
tracegen
: Moving component undercmd
for consistency (#12474) -
datadogexporter
: Remove deprecated configuration features. (#9099, #9016, #8845, #8783, #8781, #8489, #8396)- Remove
env
in favor ofdeployment.environment
semantic convention - Remove
version
in favor ofservice.version
semantic convention - Remove
service
in favor ofservice.name
semantic convention - Remove
tags
,send_metadata
anduse_resource_metadata
in favor ofhost_metadata
section - Remove
metrics::report_quantiles
in favor ofmetrics::summaries::mode
- Remove
metrics::send_monotonic_counter
in favor ofmetrics::sums::cumulative_monotonic_mode
- Remove automatic support for environment variable detection in favor of Collector's
${}
syntax - Remove
metrics::instrumentation_library_metadata_as_tags
in favor ofmetrics::instrumentation_scope_as_tags
- Remove
-
datadogexporter
: Remove deprecatedconfig
package. (#8373) -
observiqexporter
: Remove the observiq exporter (#12406) -
vcenterreceiver
: Adds thevcenter.cluster.name
resource attribute tovcenter.datastore
metrics (#12357) -
vcenterreceiver
: remove metadata declaration and references to uncollected metricvcenter.vm.cpu.utilization
(#12358) -
vcenterreceiver
: Remove direction for metrics. The feature gate: receiver.vcenterreceiver.emitMetricsWithoutDirectionAttribute can be set to apply the following (#11849) (#12185)vcenter.host.disk.throughput
will become:vcenter.host.disk.throughput.read
vcenter.host.disk.throughput.write
vcenter.host.disk.latency.avg
will become:vcenter.host.disk.latency.avg.read
vcenter.host.disk.latency.avg.write
vcenter.host.network.throughput
will become:vcenter.host.network.throughputt.receive
vcenter.host.network.throughput.transmit
vcenter.host.network.packet.errors
will become:vcenter.host.network.packet.errors.receive
vcenter.host.network.packet.errors.transmit
vcenter.host.network.packet.count
will become:vcenter.host.network.packet.count.receive
vcenter.host.network.packet.count.transmit
vcenter.vm.disk.latency.avg.read
will become:vcenter.vm.disk.latency.avg.read
vcenter.vm.disk.latency.avg.write
vcenter.vm.network.throughput
will become:vcenter.vm.network.throughput.receive
vcenter.vm.network.throughput.transmit
vcenter.vm.network.packet.count
will become:vcenter.vm.network.packet.count.receive
vcenter.vm.network.packet.count.transmit
🚩 Deprecations 🚩
hostmetricsreceiver
: Remove direction for disk metrics. The feature gate: receiver.hostmetricsreceiver.emitMetricsWithoutDirectionAttribute can be set to apply the following (#11849) (#11816)disk
scraper metrics:system.disk.io
will become:system.disk.io.read
system.disk.io.write
system.disk.operations
will become:system.disk.operations.read
system.disk.operations.write
system.disk.operation_time
will become:system.disk.operation_time.read
system.disk.operation_time.write
system.disk.merged
will become:system.disk.merged.read
system.disk.merged.write
🚀 New components 🚀
telemetryquerylanguage
: Expose the telemetry query language as a package. (#11751)chronyreceiver
: -| This component is a pure go implementation for capturing data from chrony (#11789)otlpjsonfilereceiver
: Add a new file receiver reading JSON-encoded OTLP data, after serialization specification (#10836)pulsarexporter
: Add Apache Pulsar exporter (#9795)solacereceiver
: Add Solace receiver to receive trace data from a Solace PubSub+ Event Broker. (#10572)
💡 Enhancements 💡
-
tanzuobservabilityexporter
: Improve algorithm to translate OTEL delta exponential histograms into tanzu observability histograms (#12173) -
internal/scrapertest
: Add sortation functions for scrapertest (#10837) -
elasticsearchreceiver
: Add additional metrics (#12176)
Add additional metrics for circuit breakers, disk IO r/w, translog, and CPU load. -
supported platforms
: Addlinux-ppc64le
architecture to cross build tests in CI (#12350) -
dockerobserver
: incorporate observer.EndpointsWatcher in preparation of multiple event subscribers and use existing internal event loop watcher (#10830, #11541) -
hostmetrics
: Adding connection tracking count and max metrics for linux (#11769) -
hostmetricsreceiver
: New config setting scrape_process_delay is used to indicate the minimum amount of time a process must be running before process metrics can be scraped for it. The default value is 0 seconds ("0s"). (#8976) -
transformprocessor
: Add ability to interact with enums via sybmols. (#10349) -
telemetryquerylanguage
: Adds to the grammar the ability to interpret Enums. (#11751) -
transformprocessor
: Update the transform processor to use the Telemetry Query Language package (#11751) -
transformprocessor
: Adddelete_key
anddelete_matching_keys
which allow deleting keys from maps. (#11823) -
receiver/jaeger
: Handle spans with own process (#10186) -
k8sobserver
: incorporate observer.EndpointsWatcher in preparation for multiple event subscribers (#10830, #11544) -
exporter/loki
: Handle multi-tenant use-cases (#3121) -
metricstransformprocessor
: Do not produce empty metrics (#12210) -
schemaprocessor
: renaming some internal packages to help improve maintainability (#8495) -
groupbytrace
: Promote groupbytrace to beta (#12169) -
redisreceiver
: Add redis.version resource attribute. (#12139) -
podmanreceiver
: Fetch containers stats one by one and add container image as metric attribute (#9013) -
all
: Components now report their stability level. (#12104) -
sqlqueryreceiver
: Add Oracle DB Support (#12137) -
sqlserverreceiver
: Added tests to validate counter names and a scraper test. (#9374) -
templatequerylanguage
: TQL grammar now supports complexwhere
expressions withand
,or
and parentheses (#10195) -
transformprocessor
: Add .string accessor to get hex string for trace_id and span_id (#11555) -
pkg/translator/jaeger
: Handle spans with own process (#10186)
🧰 Bug fixes 🧰
cmd/chloggen
: Compare changelog to common ancestor with main (#12149)logstransformprocessor
: Remove support for storage (#12424)elasticsearchreceiver
: Remove unuseddisk_usage_state
attribute from documentation (#12429)filterlog
: change OR to AND logic for filtering logs - as desribed, and as is done for span filtering (#11439)lokiexporter
: Wrap quotes around log message (#11827)tooling
: Fix a bug in the makefile causingmake rpm-package
to fail (#12162)prometheusexporter
: Fix cumulative condition for the delta-to-cumulative (#4153)xrayreceiver
: Ensure that the UDP Poller ends the obsreport span it creates with every loop. (#12299)
This avoids a memory leak that can happen when spans are created to track received
segments but never ended.googlecloudexporter
: Various bug fixes in parsing OTel logs to GCP LogEntries (#12157)datadogexporter
: Fix logs related to the source provider. (#12160)pkg/stanza/fileconsumer
: Fix issue where reader could become stuck on newlines (#10125, #10127, #10128)receivercreator
: dynamically created receivers log with theirname
field (#16481)skywalkingreceiver
: Fix skywalking traceid and spanid convertion (#11562)spanmetricsprocessor
: Fixes the number of explicit bucket counts by removing the manually added "catch-all" bucket. (#11784)- `spanme...
v0.55.0
The OpenTelemetry Collector Contrib contains everything in the opentelemetry-collector release (be sure to check the release notes here as well!).
🛑 Breaking changes 🛑
-
datadogexporter
: RemoveSanitize
method fromConfig
struct. (#8373) -
datadogexporter
: (Underexporter.datadog.hostname.preview
feature gate) Removedocker
hostname detector (#11834) -
k8sclusterreceiver
: Thereceiver.k8sclusterreceiver.reportCpuMetricsAsDouble
feature gate has been removed (#10838)- If users were disabling this feature gate, they may have to update
monitoring for a few Kubernetes cpu metrics. For more details see feature-gate-configurations.
- If users were disabling this feature gate, they may have to update
-
prometheusexporter
: Automatically rename metrics with units to follow Prometheus naming convention (#8950)
🚩 Deprecations 🚩
-
datadogexporter
: Deprecateconfig
package in favor of structs on thedatadogexporter
package. (#8373) -
k8sattributesprocessor
: Announcingpod_association
rules will be deprecated. Usepod_association.sources
rules instead. This is in order to support metadata enrichment based on multiple attributes. (#4309) -
hostmetricsreceiver
: Remove direction for network, paging and process metrics. The feature gatesreceiver.hostmetricsreceiver.emitMetricsWithoutDirectionAttribute
andreceiver.hostmetricsreceiver.emitMetricsWithDirectionAttribute
can be used to control the transition (#11815)system.network.dropped
will become:system.network.dropped.receive
system.network.dropped.transmit
system.network.errors
will become:system.network.errors.receive
system.network.errors.transmit
system.network.io
will become:system.network.io.receive
system.network.io.transmit
system.network.packets
will become:system.network.packets.receive
system.network.packets.transmit
system.paging.operations
will become:system.paging.operations.page_in
system.paging.operations.page_out
process.disk.io
will become:process.disk.io.read
process.disk.io.write
See https://github.com/open-telemetry/opentelemetry-collector-contrib/tree/main/receiver/hostmetricsreceiver#transition-from-metrics-with-direction-attribute for more details.
-
logzioexporter
: Announcingcustom_endpoint
,drain_interval
,queue_capacity
,queue_max_length
configuration options will be deprecated in upcoming releases (#10821) -
simpleprometheusreceiver
: Announcingtls_enable
,tls_config
will be deprecated and useconfighttp.HTTPClientSettings
instead. (#11553)
🚀 New components 🚀
sqlqueryreceiver
: Enable the component (#11848)
💡 Enhancements 💡
cmd/chloggen
: Update CI process to validate new changelog strategy (#11841)cmd/chloggen
: Add new tool for conflict-free CHANGELOG.md management (#11539)coralogixexporter
: Add support for metrics (#11065)coreinternal/attraction
: Supports pattern for delete and hash attractions (#11886)filterprocessor
: Add ability to filterSpans
(#6341)flinkmetricsreceiver
: Add attribute values to metadata (#11520)k8sattributesprocessor
: do not ignore hostNetwork pods for enrichment based on non IP attribute (#12073)logzioexporter
: Add support for logs pipeline and support for exporterhelper (#10821)pkg/stanza
: Exportpkg/stanza/fileconsumer
package (#11844)prometheusreceiver
: Addtarget_info
labels to resource attributes (#11034)redisreceiver
: Add more metrics,redis.maxmemory
,redis.role
,redis.cmd.calls
redis.cmd.usec
(#11090)sapmexporter
: Add config option to log responses from Splunk APM (#11425)splunkhecexporter
: Update limits for max_content_length settings (#11550)sqlqueryreceiver
: Add core functionality (#10867)tracegen
: Add additional resource attributes (#11145)transformprocessor
: Add IsMatch factory function. This function allows regex matching in conditions. (#10903)transformprocessor
: replace_patternand
replace_all_patterns` use regex for pattern matching and replacing text in attributes/metrics (#11125)
🧰 Bug fixes 🧰
aerospikereceiver
: Fix issue where namespaces would not be collected (#11465)aerospikereceiver
: Fix typo in metric name. Ensure namespace transactions are collected (#12085) (#12083)coralogixexporter
: Fix metrics bearer token (#11831)datadogexporter
: (Underexporter.datadog.hostname.preview
feature gate) Make the hostname reported on GKE match the Datadog GCP integration hostname. (#11893)datadogexporter
: Thetraces.span_name_remappings
setting now correctly refers to the OpenTelemetry key to be renamed without any sort of normalization. (#9693)datadogexporter
: Unify traces exporter behavior with Datadog Agent OTLP traces ingest. (#9693)filelogreceiver
: Read log lines from lost files first in a poll cycle (#12084)filestorageextension
: Copy values returned by Get (#11776)cmd/chloggen
: Fix problem where 'new' command would fail when branch name contained '/' (#11887)kafkaexporter
: Fixed config.Topic mutation causing Logs|Metrics|Traces to default to 1 topic (#11420)mongodbreceiver
: do not ignore TLS Settings in mongodbreceiver (#12092)prometheusexporter
: Expose the same metric from different targets correctly (#4986)redactionprocessor
: Respect allow_all_keys configuration (#11542)saphanareceiver
: Fix component memory query, add better error handling (#11507)sapmreceiver
: Fix issue where component instance use in multiple pipelines leads to start failures (#11518)signalfxreceiver
: Fix issue where component instance use in multiple pipelines leads to start failures (#11513)splunkhecreceiver
: Fix issue where component instance use in multiple pipelines leads to start failures (#11517)
v0.54.0
The OpenTelemetry Collector Contrib contains everything in the opentelemetry-collector release (be sure to check the release notes here as well!).
🛑 Breaking changes 🛑
transformprocessor
:metric.is_monotonic
is now accessed via a bool literal instead of a string. (#10473)vcenterreceiver
: Changed the attributeeffective
onvcenter.cluster.host.count
as it will now be reported as a bool rather than a string (#10914)
🚩 Deprecations 🚩
datadogexporter
: Deprecateinstrumentation_library_metadata_as_tags
(#11135)datadogexporter
: DeprecateSanitize
method ofConfig
struct (#8829)observiqexporter
: Deprecate the observiq exporter (#10977)honeycombexporter
: Deprecate honeycomb exporter (#10318)
🚀 New components 🚀
expvarreceiver
: Includeexpvarreceiver
in components (#10847)googlemanagedprometheusexporter
Add the Google Managed Service for Prometheus exporter. (#10840)googlemanagedprometheusexporter
The Google Managed Service for Prometheus exporter is alpha. (#10925)
💡 Enhancements 💡
tailsamplingprocessor
: Add trace_state policy (#10852)mongodbatlasreceiver
Add support for receiving alerts (#10854)cmd/mdatagen
: Allow attribute values of any types (#9245)metricstransformprocessor
: Migrate the processor from OC to pdata (#10817)- This behavior can be reverted by disabling the
processor.metricstransformprocessor.UseOTLPDataModel
feature gate.
- This behavior can be reverted by disabling the
transformprocessor
: Add byte slice literal to the grammar. Add new SpanID and TraceID functions that take a byte slice and return a Span/Trace ID. (#10487)transformprocessor
: Add Summary transform functions. (#11041)transformprocessor
: Add nil literal to the grammar. (#11150)elasticsearchreceiver
: Add integration test for elasticsearch receiver (#10165)tailsamplingprocessor
: New sampler added that allows to sample based on minimum number of spansdatadogexporter
: Some config validation and unmarshaling steps are now done onValidate
andUnmarshal
instead ofSanitize
(#8829)datadogexporter
: Addexporter.datadog.hostname.preview
feature flag and related warnings (#10926)datadogexporter
: Addinstrumentation_scope_metadata_as_tags
instead ofinstrumentation_library_metadata_as_tags
in favor of https://github.com/open-telemetry/opentelemetry-proto/releases/tag/v0.15.0 (#11135)examples
: Add an example for scraping Couchbase metrics (#10894)filestorageextension
: Add background compaction capability (#9327)googlecloudpubsubreceiver
: Added newEndpoint
andInsecure
connection configuration options. (#10845)dynatraceexporter
: Provide better estimated summaries for partial histograms. (#11044)mongodbreceiver
: Add integration test for mongodb receiver (#10864)mezmoexporter
: add logging for HTTP errors (#10875)googlecloudexporter
: Support writing to multiple GCP projects by setting thegcp.project.id
resource attribute, and support service account impersonation (#11051)prometheusreceiver
: Addtarget_info
labels to resource attributes. (#11034)k8sattributeprocessor
: Add debug logs to help identify missing attributes (#11060)jmxreceiver
: Add latest releases of jmx metrics gatherer & wildfly jar to supported jars hash list (#11134)rabbitmqreceiver
: Add integration test for rabbitmq receiver (#10865)transformprocessor
: Allow using trace_state with key-value struct (#11029)
🧰 Bug fixes 🧰
kubletetstatsreceiver
: Bring backk8s.container.name
attribute (#10848)transformprocessor
: Fix issue where some metric fields were not working correctly in conditions. (#10473)transformprocessor
: Fix issue where some trace fields were not working correctly in conditions. (#10471)transformprocessor
: Fix issue where some log fields were not working correctly in conditions. (#10903)pkg/stanza
: Skip building fingerprint in case of configuration change (#10485)windowseventlogreceiver
: Fixed example config in readme (#10971)pkg/stanza
: Fix access to atomic variable without using atomic package (#11023)exporter/awsemfexporter:
: Fix dead links in README.md. (#11027)googlecloudexporter
: Fix (self-obs) point_count metric calculation, concurrent map write panic, and dropped log attributes (#11051)signalfxexporter
: Event Type is a required field, if not set, set it tounknown
to prevent signalfx ingest from dropping it (#11121)prometheusreceiver
: validate that combined metric points (e.g. histograms) have the same timestamp (#9385)splunkhecexporter
: Fix flaky test when exporting traces (#11418)mongodbatlasexporter
: Fix mongodbatlas.system.memory.usage.max not being reported (#11126)receiver/awsxrayreceiver
: Fix null span exception fields causing null pointer exception (#11431)pkg/stanza
: use ObservedTimestamp to decide if flush log for recombine operator (#11433)
v0.53.0
Images and binaries here: https://github.com/open-telemetry/opentelemetry-collector-releases/releases/tag/v0.53.0
🛑 Breaking changes 🛑
jmxreceiver
: Remove properties & groovyscript parameters from JMX Receiver. Add ResourceAttributes & LogLevel parameter to supply some of the removed functionality with reduced attack surface (#9685)resourcedetectionprocessor
: 'gke' and 'gce' resource detectors are replaced with a single 'gcp' detector (#10347)pkg/stanza
: Removed reference to deprecatedClusterName
(#10426)couchbasereceiver
: Fully removed unimplemented Couchbase receiver (#10482)hostmetricsreciever
: Fix Load Scraper to normalize 1m, 5m, and 15m averages independently (#8267)
🚀 New components 🚀
flinkmetricsreceiver
: Add implementation of Flink Metric Receiver (#10121)windowseventlogreceiver
Added implementation of Windows Event Log Receiver (#9228)vcenterreceiver
: Add metrics receiver for new vcenterreceiver component (#9224)googlecloudpubsubreceiver
Activate the Google Cloud Pubsub receiver. (#10580)googlecloudpubsubexporter
Activate the Google Cloud Pubsub exporter. (#10580)
💡 Enhancements 💡
awsemfexporter
: Add min and max support for histograms (#10577)tailsamplingprocessor
: Add support for string invert matching toand
policy (#9553)mezemoexporter
: Add user agent string to outgoing HTTP requests (#10470)prometheusreceiver
: Improve performance of metrics builder (#10546)transformprocessor
: Add functions for conversion of scalar metric types (gauge_to_sum
andsum_to_gauge
) (#10255)dynatraceexporter
: Truncate unmarshalable responses to avoid long log lines (#10568)
🧰 Bug fixes 🧰
transformprocessor
: Fix issue where incorrect error was returned if a bad path was passed to a function (#10141)tanzuobservabilityexporter
: Improve how negative values in exponential histograms are handled. (#10135)dynatraceexporter
: Ensure min is always less than or equal to mean and max is always greater or equal to mean for histogram estimation. (#10257)resourcedetectionprocessor
: GCP resource detector now properly detects zone/region on GKE (#10347)resourcedetectionprocessor
: GCP resource detector no longer fails to detect resource when using workload identity (#10486)tailsamplingprocessor
: Fix composite sampler with inverse policyawsprometheusremotewriteexporter
: Fix signing of empty request bodies. (#10578)sigv4authextension
: Fix signing of empty request bodies. (#10578)prometheusexporter
: Converting monotonic Delta to Cumulative sums (#9919)statsdreceiver
: Update the lastIntervalTime for Counter metrics (#9919)resourcedetectionprocessor
: GCP resource detector now correctly detects region on Google App Engine standard (#10814)
v0.52.0
Images and binaries here: https://github.com/open-telemetry/opentelemetry-collector-releases/releases/tag/v0.52.0
🛑 Breaking changes 🛑
jmxreceiver
: Remove properties & groovyscript parameters from JMX Receiver. Add ResourceAttributes & LogLevel parameter to supply some of the removed functionality with reduced attack surface (#9685)
🚀 New components 🚀
bigipreceiver
: Add implementation of F5 Big-IP Metric Receiver (#9680)expvarreceiver
: Initial work for a receiver designed to scrapememstats
from Golang applications. (#9747)mezmoexporter
: Add implementation of Mezmo Log exporter (#9743)nsxtreceiver
: Added implementation of NSX-T Metric Receiver (#9568)expvarreceiver
: Add implementation of new receiver. (#10183)
💡 Enhancements 💡
transformprocessor
: Add transformation of metrics (#10100)transformprocessor
: Include transform processor in components (#10134)kubeletstatsreceiver
: Update receiver to use new Metrics Builder. All emitted metrics remain the same. (#9744)transformprocessor
: Add newreplace_match
andreplace_all_matches
functions (#10132)resourcedetectionprocessor
: Add "cname" and "lookup" hostname sourcesjmxreceiver
: Communicate with JMX metrics gatherer subprocess via properties file (#9685)
🧰 Bug fixes 🧰
datadogexporter
: add error checks for datadog exporter (#9964)datadogexporter
: Fix host aliases not being properly sent to the Datadog backend (#9748)groupbyattrsprocessor
: copied aggregationtemporality when grouping metrics. (#9088)jaeger
: Update OTLP-Jaeger translation of span events according to the OTel Spec: useevent
log field instead
ofmessage
to represent OTel Span Event Name (#10273)mongodbreceiver
: Fix issue where receiver startup could hang (#10111)transformprocessor
: Fix issue where metric.aggregation_temporality and metric.is_monotic were not actually gettable or settable (#10197)signalfxexporter
: Emit prometheus compatible histogram/summary to signalfx #10299- This behavior can be reverted using the
exporter.signalfxexporter.PrometheusCompatible
featuregate.
- This behavior can be reverted using the
podmanreceiver
: Container Stats Error structure (#9397)pkg/stanza
: pipeline.Operators() will return a consistently ordered list of operators whenever possible (#9761)tanzuobservabilityexporter
: add error checks for tanzuobservability exporter (#10188)