-
exporterhelper
: Reduce the default queue size to 1000 from 5000 (#7359) Affects any exporter which enables the queue by default and doesn't set its own default size. For example: otlphttp. -
featuregate
: Remove deprecatedRemovalVersion
andWithRegisterRemovalVersion
functions. (#7587)
service
: Adds ResourceAttributes map to telemetry settings and thus CreateSettings. (#6599)service
: Allows users to disable high cardinality OTLP attributes behind a feature flag. (#7517)featuregate
: Finalize purpose oftoVersion
. Allow stable gates to be explicitly set to true, but produce a warning log. (#7626)
config/confighttp
: Ensure Auth RoundTripper follows compression/header changes (#7574)otlpreceiver
: do not reject requests having 'content-type' header with optional parameters (#7452)
confmap
: Using an Invalid Scheme in a URI will throw an error. (#7504)
featuregate
: Deprecate Gate.RemovalVersion and WithRegisterRemovalVersion in favor of ToVersion. (#7043)
-
batchprocessor
: Support zero timeout. (#7508) This allows the batchprocessor to limit request sizes without introducing delay in a pipeline, to act only as a splitter. -
service
: use the otel opencensus bridge when telemetry.useOtelForInternalMetrics is enabled (#7483) -
connector
: Mark 'service.connectors' featuregate as stable (#2336) -
featuregate
: Add a new Deprecated stage for feature gates, when features are abandoned. (#7043) -
loggingexporter
: Show more counters in not detailed verbosity (#7461) The logging exporter now shows more counters when the verbosity is not detailed. The following numbers are added:- Number of resource logs
- Number of resource spans
- Number of resource metrics
- Number of data points
-
configtls
: Reload mTLS ClientCA certificates on file change (#6524) -
confmap
: Add support for nested URIs. (#7117) -
featuregate
: Add concept of gate lifetime, [fromVersion, toVersion]. (#7043)
obsreport
: fix issue where send_failed_requests counter was reporting an incorrect value. (#7456)
featuregate
: Remove deprecated featuregate.FlagValue (#7401)
provider
: Added userfriendly error on incorrect type. (#7399)
loggingexporter
: Fix display of bucket boundaries of exponential histograms to correctly reflect inclusive/exclusive bounds. (#7445)exporterhelper
: Fix a deadlock in persistent queue initialization (#7400)
consumererror
: Remove deprecated funcs in consumererror (#7357)
featuregate
: DeprecateFlagValue
in favor ofNewFlag
. (#7042)
service
: Enable connectors by default by moving service.connectors featuregate to beta (#7369)
consumererror
: RemoveGet
prefix from methods returning failed signal data (#7048)service
: Feature gateservice.graph
is now stable and cannot be disabled. It will be removed in the next version. (#2336)
exporter
: split exporter into its own module (#7239)receiver
: split receiver into its own module (#7174)connectors
: Provide connectors with a mechanism to route data to specific pipelines (#7152)confmap
: Markconfmap.expandEnabled
as stable (#7323)
all
: Remove go 1.18 support, bump minimum to go 1.19 and add testing for 1.20 (#7151)pdata
: Remove deprecated[Metrics|Traces|Logs]MoveTo
methods. (#7165)featuregate
: Remove deprecated funcs in featuregate. (#7173)
semconv
: Generated Semantic conventions 1.17 that now contains theevent
type. (#7170)semconv
: Generated Semantic conventions 1.18. (#7168)
memorylimiterprocessor
: Fix incorrect parsing of cgroups when running Collector with host mount (#6826)confmap
: Clear list of old already closed closers. (#7215)
pdata
: Add private method to GrpcServer interface, disallow direct implementation (#6966)featuregate
: Remove deprecated GetRegistry (#7011)pcommon
: Remove deprecated Map.Sort (#6688)
featuregate
: Deprecate Registry.List in favor of Registry.VisitAll. (#7041)featuregate
: Deprecate Apply in favor of Set (#7018)pdata
: Deprecate [Metrics|Logs|Traces].MoveTo methods. (#7091)featuregate
: Deprecate RegistryOption in favor of RegisterOption (#7012)featuregate
: Deprecate featuregate.Registry.[IsEnabled, RegisterID, MustRegister] (#6998)
httpsprovider
: Add the httpsprovider. This component allows the collector to fetch configurations from web servers using the HTTPS protocol. (#6683)
-
exporter
: Allow configuration of fields,RandomizationFactor
andMultiplier
, for exponential backoff algorithm when retry on failure is enabled (#6610) -
connectors
: Add "connectors", a new type of pipeline component (#2336)- Connectors connect pipelines by acting as an exporter in one or more pipelines and simultaneously
as a receiver of corresponding data in one or more other pipelines. For example:
- The
forward
connector can export data to another pipeline of the same type. This allows you to merge data from multiple pipelines onto a common pipeline. Or, you can replicate data onto multiple pipelines so that it may be processed in different ways and/or exported to different backends. - The
count
connector can count data of any type. Regardless of the type of data that is counted, it emits counts as metrics onto a metrics pipeline.
- The
- Connectors are currently disabled by default but can be enabled with the
service.connectors
feature gate. - See the connectors README for more details on how to use connectors.
- Connectors connect pipelines by acting as an exporter in one or more pipelines and simultaneously
as a receiver of corresponding data in one or more other pipelines. For example:
-
service
: Enable new pipelines implementation using graphs. Controlled by theservice.graph
featuregate. (#2336) -
builder
: added ldflags command option (#6940) -
proctelemetry
: Instrumentproctelemetry.ProcessMetrics
metrics with otel-go (#6886) -
capabilityconsumer
: If the consumer has already the desired capability, don't wrap (#7116) -
confmap
: Add support to resolve embedded uris inside a string, concatenate results. (#6932)
confmap
: Fix bug in confmap validation that allowed the usage of case-insensitive keys in the configurations, despite them failing silently. (#6876)logging
: Fix the attribute key used to identify the receiver data type in logging configuration (#7033)
pdata
: Start enforcing grpc server implementation to embed UnimplementedGRPCServer, dissallow client implementation (#6966)config/configgrpc
: Change configgrpc.GRPCClientSettings.Headers type to map[string]configopaque.String (#6852) Useconfigopaque.String(str)
andstring(opaque)
to turn a string opaque/clear.pdata
: Remove deprecated pcommon.Value.Equal (#6860)
pdata
: Deprecate pcommon.Map.Sort(). (#6688)featuregate
: Deprecate GetRegistry in favor of GlobalRegistry (#6979)
builder
: Add remote debug option for otel-collector to builder (#6149)connector
: Add Builder (#6867)cmd/builder
: Add support for connector configurations (#6789)exporter/otlphttp
: Retry only on status code 429/502/503/504 (#6845)featuregate
: Reduce contention in featuregate by using sync.Map instead of mutex. (#6980)
loggingexporter
: Fix undefined symbol errors on building otelcorecol for other platforms than darwin, linux, windows. (#6924)otlpexporter
: Fix a dataloss bug in persistent storage when collector shuts down or restarts (#6771)
various modules
: Fix issue where some collector modules imported previous version of other modules (#6929)
component
: Remove deprecated Exporter types (#6880)component
: Remove deprecated Extension types (#6865)component
: Remove deprecated ProcessorFactoryOptions (#6881)component
: Remove deprecated Receiver types (#6882)componenttest
: Remove deprecated funcs from componenttest (#6836)batchprocessor
: Remove deprecated batchprocessor.MetricViews and batchprocessor.OtelMetricViews (#6861)component
: Remove deprecated component.[Factories|MakePorcessorFactoryMap] and componenttest.NewNopFactories (#6835)config
: Remove deprecated cofig.*Settings (#6837)obsereporttest
: Remove deprecated obsereporttest.SetupTelemetryWithID (#6861)component
: Remove deprecated component [Traces|Metrics|Logs]Processor and ProcessorFactory (#6884)service
: Remove deprecated service service.ConfigService and service.ConfigServicePipeline (#6859)
connector
: Add MakeFactoryMap (#6889)semconv
: Add semantic conventions for specification v1.16.0 (#6714)
config
: use [REDACTED] when marshaling to text a configopaque.String, instead of disclosing secret length. (#6868)
componenttest
: Move NopFactories to otelcoltest (#6792)config/confighttp
: Change confighttp.HTTPClientSettings.Headers type to map[string]configopaque.String (#5653)config
: Remove deprecatedcomponent.Config.[ID|SetIDName]
. (#4714)configauth
: Remove deprecated funcs/types fromconfigauth
(#6719)component
: Remove deprecated funcs/types from component package (#6769)component.[Exporter|Processor|Receiver|Extension]Config
component.Unmarshal[Exporter|Processor|Receiver|Extension]Config
component.[Exporter|Processor|Receiver|Extension]CreateDefaultConfigFunc
component.[Exporter|Receiver|Extension]FactoryOption
component.New[Exporter|Receiver|Extension]Factory
component.With[Traces|Metrics|Logs][Exporter|Receiver]
component.Create[Traces|Metrics|Logs][Exporter|Receiver]Func
component.CreateExtensionFunc
componenttest
: Remove deprecated componenttest.NewNop*CreateSettings (#6761)service
: Remove deprecatedservice.[Collector|New|CollectorSettings|ConfigProvider]
(#5564)service
: Remove deprecated funcsservice.NewCommand
andservice.NewSvcHandler
. (#5564)obsreporttest
: Remove deprecate obsreporttest.Check* (#6720)service
: Remove deprecatedservice.Config
. (#6774)servicetest
: Remove deprecatedservicetest
package. (#5564)
service
: Deprecateservice.ConfigService
in favor ofservice.Config
andservice.ConfigServicePipeline
in favor ofservice.PipelineConfig
. (#6787)pdata
: Deprecatepcommon.Value.Equal
method (#6811)component
: DeprecateProcessor
related structs and functions in favor ofprocessor
package (#6709)component
: Deprecate component.Factories in favor of otelcol.Factories (#6723)config
: Deprecateconfig.[Extension|Exporter|Connector|Receiver|Processor]Settings
. (#6718)batchprocessor
: Deprecate metric views funcs, for OC and Otel. (#6730)obsreporttest
: Deprecate obsreporttest.SetupTelemetryWithID in favor of obsreporttest.SetupTelemetry (#6720)
forwardconnector
: Add forward connector (#6763)
components
: Add [receiver|processor|exporter|extension].Builder to help with creating components form a set of configs and factories (#6803)configunmarshaler
: Consolidate package into generic implementation (#6801)service
: Shutdown internal telemetry with the Service (every time config changes). (#5564)
configgrpc
: Fix todo to add MeterProvider to grpc instrumentation (#4030)otlpreceiver
: Fix otlpreceiver transport metrics attribute (#6695)
We are excited to announce that the pdata
module is now available as a
v1.0.0 release candidate. While breaking changes may still happen in this
module before v1.0.0, we believe it is ready for final assessment and validation
and hope to make a v1.0.0 release soon.
overwritepropertiesconverter
: Remove deprecated packageoverwritepropertiesconverter
(#6656)pdata
: Change [...Slice|Map].Sort methods to not return any value (#6660)featuregate
: remove deprecated functions (#6594)featuregate.GetID()
featuregate.GetDescription()
obsreport
: remove deprecated functions. (#6595)obsreport.MustNewExporter
obsreport.MustNewProcessor
obsreport.MustNewReceiver
obsreport.MustNewScraper
service
: Remove deprecatedservice.State
enum values. (#6605)component
: Remove deprecated func/types from component (#6606)config
: Remove deprecated config.Pipelines and config.Pipeline (#6664)ballastextension
: Remove deprecatedballastextension.MemoryBallast
type (#6628)component
: RemoveValidate()
from component.*Config interfaces and make it optional interface (#6544)confmap
: Splitting confmap into its own module (#6185) The import path for the confmap module can now be access directly:go.opentelemetry.io/collector/confmap
-
service
: Deprecate service.[Collector|NewSvcHandler|CollectorSettings|State|NewCommand] in favor of otelcol package" (#6608)- Deprecate
service.Config
in favor ofotelcol.Config
. - Deprecate
service.ConfigProvider
in favor ofotelcol.ConfigProvider
. - Deprecate
service.NewConfigProvider
in favor ofotelcol.NewConfigProvider
. - Deprecate
service.CollectorSettings
in favor ofotelcol.CollectorSettings
. - Deprecate
service.Collector
in favor ofotelcol.Collector
. - Deprecate
service.New
in favor ofotelcol.NewCollector
. - Deprecate
service.State
in favor ofotelcol.State
. - Deprecate
service.NewSvcHandler
in favor ofotelcol.NewSvcHandler
. - Deprecate
service.NewCommand
in favor ofotelcol.NewCommand
.
- Deprecate
-
obsreporttest
: Deprecate obsreporttest.Check* in favor of TestTelemetry.Check (#6678) -
component
: Deprecate Exporter related types/funcs from component package in favor of exporter package. (#6578)component.ExporterCreateSettings
->exporter.CreateSettings
component.CreateTracesExporterFunc
->exporter.CreateTracesFunc
component.CreateMetricsExporterFunc
->exporter.CreateMetricsFunc
component.CreateLogsExporterFunc
->exporter.CreateLogsFunc
component.ExporterFactory
->exporter.Factory
component.NewExporterFactory
->exporter.NewFactory
component.MakeExporterFactoryMap
->exporter.MakeFactoryMap
componenttest.NewNopExporterCreateSettings
->exportertest.NewNopCreateSettings
componenttest.NewNopExporterFactory
->exportertest.NewNopFactory
-
component
: Change Config to be opaque for otel collector core. (#4714)- Deprecate
component.Config.ID()
in favor ofcomponent.[*]CreateSettings.ID
. - Deprecate
component.Config.SetIDName()
, no replacement needed since ID in settings is public member. - Deprecate
obsreporttest.SetupTelemetry
in favor ofobsreporttest.SetupTelemetryWithID
.
- Deprecate
-
component
: Deprecatecomponent.Unmarshal[*]Config
in favor ofcomponent.UnmarshalConfig
(#6613) -
component
: Deprecate Extension related types/funcs from component package in favor of extension package. (#6578)component.Extension
->extension.Extension
component.PipelineWatcher
-> extension.PipelineWatchercomponent.ExtensionCreateSettings
->extension.CreateSettings
component.CreateExtensionFunc
->extension.CreateFunc
component.ExtensionFactory
->extension.Factory
component.NewExtensionFactory
->extension.NewFactory
component.MakeExtensionFactoryMap
->extension.MakeFactoryMap
componenttest.NewNopExtensionCreateSettings
->extensiontest.NewNopCreateSettings
componenttest.NewNopExtensionFactory
->extensiontest.NewNopFactory
-
component
: DeprecateReceiver
related structs and functions in favor ofreceiver
package (#6687) -
component
: Deprecatecomponent.[Exporter|Extension|Processor|Receiver]Config
in favor ofcomponent.Config
(#6578) -
pdata
: Remove deprecated funcspdata.[Span|Trace]ID.HexString
(#6627)
config/configopaque
: Add newconfigopaque.String
type alias for opaque strings. (#5653)service
: Added components sub command which outputs components in collector distribution. (#4671)component
: Define new component type 'connectors' (#6577)connector
: Add connector factory (#6611)connector
: Add connector types (TracesConnector, MetricsConnector, LogsConnector) (#6689)connectortest
: Add connector/connectortest package (#6711)component
: Add recursive validation check for configs (#4584)service
: Improve config error messages, split Validate functionality (#6665)extension/authextension
: Define new authextension package and use new package in collector repo (#6467)- configauth.ClientAuthenticator -> auth.Client
- configauth.NewClientAuthenticator -> auth.NewClient
- configauth.ClientOption -> auth.ClientOption
- configauth.WithClientStart -> auth.WithClientStart
- configauth.WithClientShutdown -> auth.WithClientShutdown
- configauth.WithClientRoundTripper -> auth.WithClientRoundTripper
- configauth.WithPerRPCCredentials -> auth.WithClientPerRPCCredentials
- configauth.ServerAuthenticator -> auth.Server
- configauth.NewServerAuthenticator -> auth.NewServer
- configauth.Option -> auth.ServerOption
- configauth.AuthenticateFunc -> auth.ServerAuthenticateFunc
- configauth.WithAuthenticate -> auth.WithServerAuthenticate
- configauth.WithStart -> auth.WithServerStart
- configauth.WithShutdown -> auth.WithServerShutdown
obsreport
: Instrumentobsreport.Processor
metrics with otel-go (#6607)pdata
: Add ability to clear optional fields (#6474)
otlpexporter
: Fix nil panic from otlp exporter in case of errors during Start. (#6633)service
: Stop notification for signals before shutdown, increase channel size. (#6522)confmap
: Fix support for concatenating envvars with colon (#6580)otlpexporter
: Fix a bug that exporter persistent queue is sending duplicate data after restarting. (#6692)
-
featuregate
: Capitalizefeaturegate.Stage
string values, remove Stage prefix. (#6490) -
configtelemetry
: Update values returned byLevel.String
andLevel.MarshalText
method. (#6490)- All returned strings are capitalized.
- "" is returned for integers that are out of Level enum range.
- It also affects
Level.Marshal
output, but it's not a problem becauseUnmarshal
method accepts strings in all cases, e.g. "normal", "Normal" and "NORMAL".
-
featuregate
: Make impossible to implement RegistryOption outsidefeaturegate
package (#6532) -
service/telemetry
: Remove unit suffixes from metrics exported by the otel-go prometheus exporter. (#6403) -
obsreport
:obsreport.New[Receiver|Scraper|Processor|Exporter]
returns error now (#6458) -
configgrpc
: Remove deprecated funcs inconfiggrpc
. (#6529)configgrpc.GRPCClientSettings.ToDialOptions
configgrpc.GRPCServerSettings.ToServerOption
-
config/configtest
: Remove deprecatedconfigtest
package. (#6542) -
config
: Remove deprecated types and funcs from config. Usecomponent
package. (#6511)- config.ComponentID
- config.Type
- config.DataType
- config.Receiver
- config.UnmarshalReceiver
- config.Processor
- config.UnmarshalProcessor
- config.Exporter
- config.UnmarshalExporter
- config.Extension
- config.UnmarshalExtension
-
featuregate
: Remove deprecated funcs and struct members fromfeaturegate
package (#6523)- featuregate.Gate.ID
- featuregate.Gate.Description
- featuregate.Gate.Enabled
- featuregate.Registry.Register
- featuregate.Registry.MustRegister
-
experimental
: Remove experimental configsource code. (#6558) -
component
: Update values returned byStabilityLevel.String
method. (#6490)- All returned strings are capitalized.
- "Undefined" is returned only for
StabilityLevelUndefined
. - "" is returned for integers that are out of StabilityLevel enum range.
-
pdata
: Deprecatepcommon.[Span|Trace]ID.HexString
methods. Callhex.EncodeToString
explicitly instead. (#6514) -
obsreport
: deprecateobsreport.MustNew[Receiver|Scraper|Processor|Exporter]
in favor ofobsreport.New[Receiver|Scraper|Processor|Exporter]
(#6458)- Deprecate
obsreport.MustNewReceiver()
in favor ofobsreport.NewReceiver()
- Deprecate
obsreport.MustNewScraper()
in favor ofobsreport.NewScraper()
- Deprecate
obsreport.MustNewProcessor()
in favor ofobsreport.NewProcessor()
- Deprecate
obsreport.MustNewExporter()
in favor ofobsreport.NewExporter()
- Deprecate
-
component
: Deprecatecomponent.Receiver
,component.Processor
, andcomponent.Exporter
. (#6553) -
featuregate
: Deprecate Get prefix funcs forfeaturegate.Gate
(#6528)featuregate.Gate.GetID
->featuregate.Gate.ID
featuregate.Gate.GetDescription
->featuregate.Gate.Description
-
component
: Deprecatecomponent.Config.Validate
in favor ofcomponent.ValidateConfig
(#6572) -
component
: DeprecateStabilityLevelInDevelopment
enum const in favor ofStabilityLevelDevelopment
. (#6561) Also rename all mentions of "In development" stability level to "Development". -
service
: Deprecateservice.[Starting|Running|Closing|Closed]
in favor ofservice.State[Starting|Running|Closing|Closed]
(#6492)
component
:component.Extension
is temporarily set to be an alias ofcomponent.Component
which will be reverted once it's moved to theextension
package. Change yourcomponent.Host.GetExtensions()
implementation to returnmap[ID]component.Component
instead ofmap[ID]component.Extension
(#6553)pdata
: Return error frompcommon.[Value|Map|Slice].FromRaw
when unsupported type. (#6579)batchprocessor
: instrument thebatch
processor with OpenTelemetry Go SDK (#6423)obsreport
: Instrumentobsreport.Scraper
metrics with otel-go (#6460)service/collector
: Support SIGHUP configuration reloading (#5966)component
: Split component into its own package (#6187) The import path for the component module can now be access directly:go.opentelemetry.io/collector/component
consumer
: Split consumer into its own package (#6186) The import path for the consumer module can now be accessed directly:go.opentelemetry.io/collector/consumer
featuregate
: Split featuregate into its own package (#6526) The import path for the featuregate module can now be accessed directly:go.opentelemetry.io/collector/featuregate
service
: Disallow duplicate references to processors within a single pipeline (#6540)
loggingexporter
: Fix logging exporter to not mutate the data (#6420)
-
config
: Remove already deprecatesconfig.Service
. (#6395) -
pdata
: Change output of String() method of the following enum types to more a concise form: (#6251)- plog.SeverityNumber
- ptrace.SpanKind
- ptrace.StatusCode
-
config
: Remove already deprecatesconfig.Config
. (#6394) -
pdata
: Remove deprecated code from pdata (#6417)p[trace|metric|log]otlp.[Request|Response]
p[trace|metric|log]otlp.New[Request|Response]
p[trace|metric|log]otlp.NewRequestFrom[Traces|Metrics|Logs]
p[trace|metric|log]otlp.NewClient
p[trace|metric|log]New[JSON|Proto][Marshaler|Unmarshale]
-
extension
: Splitting ballast/zpages extension into their own modules (#6191) The import path for the extension modules can now be accessed directly:go.opentelemetry.io/collector/extension/ballastextension
go.opentelemetry.io/collector/extension/zpagesextension
If using one of these extensions, modify your Collector builder configuration to use
gomod
directly, such as:gomod: go.opentelemetry.io/collector/extension/ballastextension v0.64.0
-
processor
: Splitting batch/memorylimiter processors into their own modules (#6188, #6192, #6193) The import path for the processor modules can now be access directly:go.opentelemetry.io/collector/processor/batchprocessor
go.opentelemetry.io/collector/processor/memorylimiter
If using this processor, modify your Collector builder configuration to use
gomod
directly, such as:gomod: go.opentelemetry.io/collector/processor/batchprocessor v0.64.0
-
otlpreceiver
: Splitting otlp receiver into its own module (#6190) The import path for the OTLP receiver can now be access directly:go.opentelemetry.io/collector/receiver/otlpreceiver
If using this receiver, modify your Collector builder configuration to use
gomod
directly, such as:gomod: go.opentelemetry.io/collector/receiver/otlpreceiver v0.64.0
-
confmap
: Remove unused public membersync.Mutex
fromconfmap.Resolver
. (#6489) This is an exception from the deprecation rule since this is not used anywhere and it is very unlikely that is used by external users.
-
config
: Deprecate multiple types and funcs inconfig
package (#6422)- config.ComponentID => component.ID
- config.Type => component.Type
- config.DataType => component.DataType
- config.[Traces|Metrics|Logs]DataType => component.DataType[Traces|Metrics|Logs]
- config.Receiver => component.ReceiverConfig
- config.UnmarshalReceiver => component.UnmarshalReceiverConfig
- config.Processor => component.ProcessorConfig
- config.UnmarshalProcessor => component.UnmarshalProcessorConfig
- config.Exporter => component.ExporterConfig
- config.UnmarshalExporter => component.UnmarshalExporterConfig
- config.Extension => component.ExtensionConfig
- config.UnmarshalExtension => component.UnmarshalExtensionConfig
-
obsreport
: deprecateobsreport.New[Receiver|Scraper|Processor|Exporter]
in favor ofobsreport.MustNew[Receiver|Scraper|Processor|Exporter]
(#6458) -
config/configgrpc
: Provide better helpers for configgrpc, consistent with confighttp (#6441)- Deprecate
GRPCClientSettings.ToDialOptions
in favor ofGRPCClientSettings.ToClientConn
. - Deprecate
GRPCServerSettings.ToServerOption
in favor ofGRPCServerSettings.ToServer
.
- Deprecate
-
featuregates
: Removing Gates being configurable externally to the Registry (#6167)- Deprecate
Gate.ID
in favour ofRegistry.RegisterID
- Deprecate
Gate.Enabled
in favour ofGate.IsEnabled()
- Deprecate
Gate.Description
in favour ofWithRegisterDescription
to be used withRegistry.RegisterID
- Deprecate
Registry.Register
in favour ofRegistry.RegisterID
- Deprecate
Registry.MustRegister
in favour ofRegistry.MustRegisterID
- Deprecate
service/telemetry
: Allow to configure sampling config for logs. (#4554)featuregates
: Extend feature gate definition to include support for issue links and expected deprecated version (#6167)receiver/otlp
: Add warning when using unspecified (0.0.0.0
) address on HTTP or gRPC servers (#6151)obsreport
: Instrumentobsreport.Exporter
metrics with otel-go (#6346)config
: Add validation for empty address [telemetry::metrics::address] (#5661)
cgroups
: split line into exactly 3 parts while parsing /proc/{pid}/cgroup (#6389)cgroups
: Use int64 for cgroup v1 parsing (#6443)
service
: Fix running collector as a windows service. (#6433)
-
pdata
: JSON marshaler emits enums as ints per spec reuqirements. This may be a breaking change if receivers were not confirming with the spec. (#6338) -
confmap
: Remove deprecatedconfmap.Conf.UnmarshalExact
API in 0.62.0 (#6315) -
pdata
: Remove API deprecated in 0.62.0 (#6314)- Remove deprecated
pcommon.NewValueString
- Remove deprecated
pcommon.Map.PutString
- Remove deprecated
plog.SeverityNumberUndefined
- Remove deprecated
p[metric|log|trace]otlp.RegisterServer
- Remove deprecated
pmetric.[Default]?MetricDataPointFlags
- Remove deprecated
pmetric.MetricAggregationTemporality*
- Remove deprecated
pmetric.MetricTypeNone
- Remove deprecated
pmetric.NumberDataPointValueTypeNone
- Remove deprecated
pmetric.ExemplarValueTypeNone
- Remove deprecated
pmetric.[New]?Buckets
- Remove deprecated
pmetric.[New]?ValueAtQuantile
- Remove deprecated
pmetric.[New]?ValueAtQuantileSlice
- Remove deprecated
ptrace.[New]?SpanStatus
- Remove deprecated
-
exporter
: Splitting otlp, otlphttp and logging exporters into their own modules (#6343) The import path for these exporters can now be access directly:go.opentelemetry.io/collector/exporter/loggingexporter
go.opentelemetry.io/collector/exporter/otlpexporter
go.opentelemetry.io/collector/exporter/otlphttpexporter
If using these exporters, modify your Collector builder configuration to use
gomod
directly, such as:gomod: go.opentelemetry.io/collector/exporter/otlpexporter v0.63.0
-
overwritepropertiesconverter
: Deprecateoverwritepropertiesconverter
, only used by non builder distributions. (#6294) -
pdata
: AddExport
prefix top[trace|metric|log]otlp.[Request|Response]
(#6365)- Deprecate
p[trace|metric|log]otlp.[Request|Response]
in favor ofp[trace|metric|log]otlp.Export[Request|Response]
- Deprecate
p[trace|metric|log]otlp.New[Request|Response]
in favor ofp[trace|metric|log]otlp.NewExport[Request|Response]
- Deprecate
p[trace|metric|log]otlp.NewRequestFrom[Traces|Metrics|Logs]
in favor ofp[trace|metric|log]otlp.NewExportRequestFrom[Traces|Metrics|Logs]
- Deprecate
-
pdata
: Deprecatep[trace|metric|log]otlp.NewClient
in favor ofp[trace|metric|log]otlp.NewGRPCClient
(#6350) -
exporter/logging
: Deprecate 'loglevel' in favor of 'verbosity' option (#5878) -
pdata
: DeprecateNew[JSON|Proto][Marshaler|Unmarshale]
in favor of exposing the underlying structs (#6340)
pdata
: Introduce partial success fields in ExportResponse. (#5815, #5816, #6365)obsreport
: Instrumentobsreport.Receiver
metrics with otel-go (#6222)service/telemetry
: Move logging and tracing initialization to service/telemetry (#5564)confmap
: Fail fast when a resolver has URIs with unsupported schemes. (#6274)service
: Use the sameprometheus.Registry
for the OpenCensus and OpenTelemetry Go prometheus exporters to act as a bridge for internal telemetry (#6297)
pdata
: Because of wrong deprecation/rename in proto, services still send the fake 1000 proto id. See open-telemetry/opentelemetry-proto#431 (#6342)confmap
: When a sub-config implements Unmarshaler, do not reinitialized it unless necessary. (#6392)pdata
: Enable enums as ints for otlp messages, switch to jsoniter for responses. (#6345)collector
: Fixed collector service not cleaning up if it failed during Start (#6352)
- Fix support for new line in config URI location. (#6306)
- Delete deprecated
go.opentelemetry.io/collector/service/featuregate
. (#6178) - Delete deprecated
pmetric.OptionalType
. (#6178) - Delete deprecated
ptrace.Span[Link]?.TraceStateStruct
. (#6178) - Delete deprecated
pcommon.NewValueBytesEmpty
. (#6178) - Delete deprecated
pmetric.MetricDataType
. (#6178) - Delete deprecated
pmetric.Metric.DataType()
. (#6178) - Delete deprecated
pmetric.NumberDataPoint.[Set]?[Int|Double]Val()
. (#6178) - Delete deprecated
pmetric.Exemplar.[Set]?[Int|Double]Val()
. (#6178) - Delete deprecated
p[metric|log|trace]otlp.[Client|Server]
. (#6178) - Delete deprecated pdata Clone methods. (#6178)
- Delete deprecated
pcommon.Value
getter/setter methods withVal
suffix. (#6178) - Delete deprecated
StringVal
andSetStringVal
methods. (#6178) - Delete deprecated
ValueTypeString
method. (#6178) - Change AggregationTemporality.String to simpler, easier to read. (#6117)
- Update
pcommon.ValueType.String
output to string representation of corresponding type identifiers. The following values will be returned: (#6247)- ValueTypeEmpty.String() -> "Empty"
- ValueTypeStr.String() -> "Str"
- ValueTypeBool.String() -> "Bool"
- ValueTypeInt.String() -> "Int"
- ValueTypeDouble.String() -> "Double"
- ValueTypeMap.String() -> "Map"
- ValueTypeSlice.String() -> "Slice"
- ValueTypeBytes.String() -> "Bytes"
- Rename output of
[MetricType|NumberDataPointValueType|ExemplarValueType].String()
for zero values from"None"
to"Empty"
(#6270)
- Deprecate
p[metric|log|trace]otlp.RegiserServer
in favor ofp[metric|log|trace]otlp.RegiserGRPCServer
(#6182) - Deprecate
pcommon.Map.PutString
in favor ofpcommon.Map.PutStr
(#6210) - Deprecate
pcommon.NewValueString
in favor ofpcommon.NewValueStr
(#6209) - Deprecate
pmetric.MetricAggregationTemporality
enum type in favor ofpmetric.AggregationTemporality
(#6253) - Deprecate
confmap.Conf.UnmarshalExact
in favor ofconfmap.Conf.Unmarshal(.., WithErrorUnused)
(#6231) - Deprecate
pmetric.[Default]?MetricDataPointFlags
favor ofpmetric.[Default]?DataPointFlags
(#6259) - Deprecate
ptrace.[New]?SpanStatus
favor ofptrace.[New]?Status
(#6258) - Deprecate
pmetric.[New]?Buckets
in favor ofpmetric.[New]?ExponentialHistogramDataPointBuckets
(#6261) - Deprecate
plog.SeverityNumberUndefined
in favor ofplog.SeverityNumberUnspecified
(#6269) - Deprecate
pmetric.[New]?ValueAtQuantile[Slice]?
in favor ofpmetric.[New]?SummaryDataPointValueAtQuantile[Slice]?
(#6262) - Deprecate enum zero constants ending with
None
(#6270)- Deprecate
pmetric.MetricTypeNone
in favor ofpmetric.MetricTypeEmpty
- Deprecate
pmetric.NumberDataPointValueTypeNone
in favor ofpmetric.NumberDataPointValueTypeEmpty
- Deprecate
pmetric.ExemplarValueTypeNone
in favor ofpmetric.ExemplarValueTypeEmpty
- Deprecate
- Add config marshaler (#5566)
- Add semantic conventions for specification v1.10-v1.13 (#6213)
receiver/otlp
: Make logs related to gRCPC and HTTP server startup clearer (#6174)- Add prometheus metric prefix to Collector's own telemetry when using OpenTelemetry for internal telemetry (#6223)
exporter/logging
: Apply consistent rendering of map values (#6244)- Add support in the confmap.Resolver to expand embedded config URIs inside configuration. (#6276)
- Fixed bug where
telemetryInitializer
is not cleaned up whennewService
errors (#6239)
- Change
ptrace.Span[Link]?.TraceState
signature to matchptrace.Span[Link]?.TraceStateStruct
(#6085) - Delete deprecated
pmetric.NewMetricDataPointFlagsImmutable
func. (#6097) - Delete deprecated
pmetric.*DataPoint.[Set]FlagsImmutable()
funcs. (#6097) - Delete deprecated
config.Unmarshalable
interface. (#6084) - Delete deprecated
p[metric|log|trace].MarshalerSizer
interfaces (#6083) - Delete deprecated
pcommon.Map.Insert*
funcs. (#6088) - Delete deprecated
pcommon.Map.Upsert*
funcs. (#6088) - Delete deprecated
pcommon.Map.Update*
funcs. (#6088) - Change
pcommon.NewValueBytes
signature to matchpcommon.NewValueBytesEmpty
. (#6088) - Delete deprecated
pcommon.Empty[Trace|Span]ID
. (#6098) - Delete deprecated
pcommon.[Trace|Span]ID.Bytes()
. (#6098) - Delete deprecated
pcommon.New[Trace|Span]ID()
. (#6098) - Delete deprecated
pcommon.Value.SetBytesVal
. (#6088) - Delete deprecated
pmetric.Metric.SetDataType
. (#6095) - Delete deprecated
plog.LogRecord.[Set]FlagStruct
funcs. (#6100) - Delete deprecated
pcommon.ImmutableByteSlice
andpcommon.NewImmutableByteSlice
. (#6107) - Delete deprecated
pcommon.ImmutableFloat64Slice
andpcommon.NewImmutableFloat64Slice
. (#6107) - Delete deprecated
pcommon.ImmutableUInt64Slice
andpcommon.NewImmutableUInt64Slice
. (#6107) - Delete deprecated
*DataPoint.SetBucketCounts
and*DataPoint.SetExplicitBounds
. (#6108)
- Deprecate
go.opentelemetry.io/collector/service/featuregate
in favor ofgo.opentelemetry.io/collector/featuregate
. (#6094) - Deprecate
pmetric.OptionalType
, unused enum type. (#6096) - Deprecate
ptrace.Span[Link]?.TraceStateStruct
in favor ofptrace.Span[Link]?.TraceState
(#6085) - Deprecate
pcommon.NewValueBytesEmpty
in favor ofpcommon.NewValueBytes
that now has the same signature. (#6105) - Deprecate
pmetric.MetricDataType
and related constants in favor ofpmetric.MetricType
. (#6127) - Deprecate
pmetric.Metric.DataType()
in favor ofpmetric.Metric.Type()
. (#6127) - Deprecate
pmetric.NumberDataPoint.[Set]?[Int|Double]Val()
in favor ofpmetric.NumberDataPoint.[Set]?[Int|Double]Value()
. (#6134) - Deprecate
pmetric.Exemplar.[Set]?[Int|Double]Val()
in favor ofpmetric.Exemplar.[Set]?[Int|Double]Value()
. (#6134) - Deprecate
p[metric|log|trace]otlp.[Client|Server]
in favor ofp[metric|log|trace]otlp.GRPC[Client|Server]
(#6165) - Deprecate pdata Clone methods in favor of CopyTo for consistency with other pdata structs (#6164)
pmetric.Metrics.Clone
is deprecated in favor ofpmetric.Metrics.CopyTo
ptrace.Traces.Clone
is deprecated in favor ofpmetric.Traces.CopyTo
plog.Logs.Clone
is deprecated in favor ofplogs.Logs.CopyTo
- Rename all
pcommon.Value
getter/setter methods by removingVal
suffix. (#6092)- Old methods with
Val
suffix are deprecated. StringVal
andSetStringVal
are deprecated in favor ofStr
andSetStr
to avoid implementingfmt.Stringer
interface.- Therefore,
ValueTypeString
is deprecated in favour ofValueTypeStr
for consistency.
- Old methods with
- Add AppendEmpty and EnsureCapacity method to primitive pdata slices (#6060)
- Expose
AsRaw
andFromRaw
pcommon.Value
methods (#6090) - Convert
ValueTypeBytes
attributes in logging exporter (#6153) - service.name Resource attribute is added to Collector's own telemetry, defaults to the value of
BuildInfo.Command
and can be overridden in the config (#6152) - Updated how
telemetryInitializer
is created so it's instanced per Collector instance rather than global to the process (#6138)
- Replace deprecated
*DataPoint.Flags()
with*DataPoint.[Set]FlagsImmutable()
. (#6017) - Remove deprecated
MetricDataPointFlagsStruct
struct andNewMetricDataPointFlagsStruct
func. (#6017) - Replace deprecated
MetricDataPointFlags
withMetricDataPointFlagsImmutable
. (#6017) - Replace deprecated
LogRecord.[Set]Flags()
withLogRecord.[Set]FlagsStruct()
. (#6007) - Remove deprecated components helpers funcs (#6006)
exporterhelper.New[Traces|Metrics|Logs]ExporterWithContext
processorhelper.New[Traces|Metrics|Logs]ProcessorWithCreateSettings
component.NewExtensionFactoryWithStabilityLevel
- Remove deprecated
pcommon.InvalidTraceID
andpcommon.InvalidSpanID
funcs (#6008) - Remove deprecated
pcommon.Map
methods:Update
,Upsert
,InsertNull
(#6019)
- Deprecate pmetric.Metric.SetDataType, in favor of empty setters for each type. (#5979)
- Deprecate
p[metric|log|trace].MarshalerSizer
in favor ofp[metric|log|trace].MarshalSizer
. (#6033) - Deprecate
pcommon.Map.Update+
in favor ofpcommon.Map.Get
+pcommon.Value.Set+
(#6013) - Deprecate
pcommon.Empty[Trace|Span]ID
in favor ofpcommon.New[Trace|Span]IDEmpty
(#6008) - Deprecate
pcommon.[Trace|Span]ID.Bytes
in favor direct conversion. (#6008) - Deprecate
pcommon.New[Trace|Span]ID
in favor direct conversion. (#6008) - Deprecate
MetricDataPointFlagsImmutable
type. (#6017) - Deprecate
*DataPoint.[Set]FlagsImmutable()
funcs in favor of*DataPoint.[Set]Flags()
. (#6017) - Deprecate
LogRecord.FlagsStruct()
andLogRecord.SetFlagsStruct()
in favor ofLogRecord.Flags()
andLogRecord.SetFlags()
. (#6007) - Deprecate
config.Unmarshallable
in favor ofconfmap.Unmarshaler
. (#6031) - Primitive slice wrapper are now mutable (#5971):
pcommon.ImmutableByteSlice
is deprecated in favor ofpcommon.ByteSlice
pcommon.ImmutableFloat64Slice
is deprecated in favor ofpcommon.Float64Slice
pcommon.ImmutableUInt64Slice
is deprecated in favor ofpcommon.UInt64Slice
- Temporarily deprecate
pcommon.NewValueBytes
that will be replaced withpcommon.NewValueBytesEmpty
in 0.60.0 - Deprecate
pcommon.Map.UpsertBytes
in favor ofpcommon.Map.PutEmptyBytes
(#6064) - Deprecate
pcommon.Value.SetBytesVal
in favor ofpcommon.Value.SetEmptyBytesVal
- Deprecate
pcommon.New[Slice|Map]FromRaw
functions in favor ofNew[Slice|Map]().FromRaw
(#6045)
- Deprecate
pcommon.Map.Insert*
methods (#6051) - Deprecate
pcommon.Map.Upsert*
methods in favor ofpcommon.Map.Put*
(#6064) - Deprecate
ptrace.TraceState
in favor ofpcommon.TraceState
. (#6052)ptrace.Span.TraceState
in favor ofptrace.Span.TraceStateStruct().AsRaw()
ptrace.Span.SetTraceState
in favor ofptrace.Span.TraceStateStruct().FromRaw
ptrace.SpanLink.TraceState
in favor ofptrace.SpanLink.TraceStateStruct().AsRaw()
ptrace.SpanLink.SetTraceState
in favor ofptrace.SpanLink.TraceStateStruct().FromRaw
TraceStateStruct
is a temporary name that will be replaced back toTraceState
in the next release.
- Add
skip-get-modules
builder flag to support isolated environment executions (#6009)- Skip unnecessary Go binary path validation when the builder is used with
skip-compilation
andskip-get-modules
flags (#6026)
- Skip unnecessary Go binary path validation when the builder is used with
- Make the otlpreceiver support to use jsoniter to unmarshal JSON payloads. (#6040)
- Add mapstructure hook function for confmap.Unmarshaler interface (#6029)
- Add CopyTo and MoveTo methods to primitive slices (#6044)
- Add support to unmarshalls bytes into plogs.Logs with
jsoniter
in jsonUnmarshaler (#6021) - Instead of exiting,
ocb
now generates a default Collector when no build configuration is supplied (#5752)
- otlpjson: Correctly skip unknown JSON value types. (#6038)
- Fix reading resource attributes from trace JSON. (#6023)
- Remove deprecated fields/funcs from
service
(#5907)- Remove
ConfigProviderSettings.Location
- Remove
ConfigProviderSettings.MapProviders
- Remove
ConfigProviderSettings.MapConverters
- Remove
featuregate.Registry.MustAppy
- Remove
- Remove deprecated funcs from
pdata
module. (#5911)- Remove
pmetric.MetricDataPointFlags.String()
- Remove
pmetric.NumberDataPoint.FlagsStruct()
- Remove
pmetric.HistogramDataPoint.FlagsStruct()
- Remove
pmetric.ExponentialHistogramDataPoint.FlagsStruct()
- Remove
pmetric.SummaryDataPoint.FlagsStruct()
- Remove
- Remove deprecated settings from
obsreport
,ProcessorSettings.Level
andExporterSettings.Level
(#5918) - Replace
processorhelper.New[Traces|Metrics|Logs]Exporter
withprocessorhelper.New[Traces|Metrics|Logs]ProcessorWithCreateSettings
definition (#5915) - Replace
exporterhelper.New[Traces|Metrics|Logs]Exporter
withexporterhelper.New[Traces|Metrics|Logs]ExporterWithContext
definition (#5914) - Replace
component.NewExtensionFactory
withcomponent.NewExtensionFactoryWithStabilityLevel
definition (#5917) - Set TLS 1.2 as default for
min_version
for TLS configuration in case this property is not defined (affects servers). (#5956)
- Deprecate
processorhelper.New[Traces|Metrics|Logs]ProcessorWithCreateSettings
in favor ofprocessorhelper.New[Traces|Metrics|Logs]Exporter
(#5915) - Deprecates
LogRecord.Flags()
andLogRecord.SetFlags()
in favor ofLogRecord.FlagsStruct()
andLogRecord.SetFlagsStruct()
. (#5972) - Deprecate
exporterhelper.New[Traces|Metrics|Logs]ExporterWithContext
in favor ofexporterhelper.New[Traces|Metrics|Logs]Exporter
(#5914) - Deprecate
component.NewExtensionFactoryWithStabilityLevel
in favor ofcomponent.NewExtensionFactory
(#5917) - Deprecate
plog.SeverityNumber[UPPERCASE]
constants (#5927) - Deprecate
pcommon.Map.InsertNull
method (#5955) - Deprecate FlagsStruct types (#5933):
MetricDataPointFlagsStruct
->MetricDataPointFlags
NewMetricDataPointFlagsStruct
->NewMetricDataPointFlags
- Deprecate builder distribution flags, use configuration. (#5946)
- Enforce naming conventions for Invalid[Trace|Span]ID: (#5969)
- Deprecate funcs
pcommon.InvalidTraceID
andpcommon.InvalidSpanID
in favor of varspcommon.EmptyTraceID
andpcommon.EmptySpanID
- Deprecate funcs
- Deprecate
Update
andUpsert
methods ofpcommon.Map
(#5975) - Deprecated the current MetricDataPointFlags API. The new API provides functions to check and set Flags. (#5999)
NumberDataPoint.Flags
->NumberDataPoint.FlagsImmutable
HistogramDataPoint.Flags
->HistogramDataPoint.FlagsImmutable
ExponentialHistogramDataPoint.Flags
->ExponentialHistogramDataPoint.FlagsImmutable
SummaryDataPoint.Flags
->SummaryDataPoint.FlagsImmutable
MetricDataPointFlags
->MetricDataPointFlagsImmutable
NewMetricDataPointFlags
->MetricDataPointFlagsImmutable
- Added
MarshalerSizer
interface toptrace
,plog
, andpmetric
packages.NewProtoMarshaler
now returns aMarshalerSizer
(#5929) - Add support to unmarshalls bytes into pmetric.Metrics with
jsoniter
in jsonUnmarshaler(#5433) - Add httpprovider to allow loading config files stored in HTTP (#5810)
- Added
service.telemetry.traces.propagators
configuration to set propagators for collector's internal spans. (#5572) - Remove unnecessary duplicate code and allocations for reading enums in JSON. (#5928)
- Add "dist.build_tags" configuration option to support passing go build flags to builder. (#5659)
- Add an AsRaw func on the flags, lots of places to encode these flags. (#5934)
- Change pdata generated types to use type definition instead of aliases. (#5936)
- Improves documentation, and makes code easier to read/understand.
- Log
InstrumentationScope
attributes inloggingexporter
(#5976) - Add
UpsertEmpty
,UpsertEmptyMap
andUpsertEmptySlice
methods topcommon.Map
(#5975) - Add
SetEmptyMapVal
andSetEmptySliceVal
methods topcommon.Value
(#5975)
- Fix reading scope attributes for trace JSON, remove duplicate code. (#5930)
- otlpjson/trace: skip unknown fields instead of error. (#5931)
- Fix bug in setting the correct collector state after a configuration change event. (#5830)
- Fix json trace unmarshalling for numbers (#5924):
- Accept both string and number for float64.
- Accept both string and number for int32/uint32.
- Read uint64 numbers without converting from int64.
- Fix persistent storage client not closing when shutting down (#6003)
- Remove the InstrumentationLibrary to Scope translation (part of transition to OTLP 0.19). (#5819)
- This has a side effect that when sending JSON encoded telemetry using OTLP proto <= 0.15.0, telemetry will be dropped.
- Require the storage to be explicitly set for the (experimental) persistent queue (#5784)
- Remove deprecated
confighttp.HTTPClientSettings.ToClientWithHost
(#5803) - Remove deprecated component stability helpers (#5802):
component.WithTracesExporterAndStabilityLevel
component.WithMetricsExporterAndStabilityLevel
component.WithLogsExporterAndStabilityLevel
component.WithTracesReceiverAndStabilityLevel
component.WithMetricsReceiverAndStabilityLevel
component.WithLogsReceiverAndStabilityLevel
component.WithTracesProcessorAndStabilityLevel
component.WithMetricsProcessorAndStabilityLevel
component.WithLogsProcessorAndStabilityLevel
- ABI breaking change:
featuregate.Registry.Apply
returns error now. - Update minimum go version to 1.18 (#5795)
- Remove deprecated
Flags
API from pdata (#5814) - Change
confmap.Provider
to return pointer toRetrieved
(#5839)
- Deprecate duplicate settings in service.ConfigProvider, embed ResolverSettings (#5843)
- Deprecate
featuregate.Registry.MustApply
in favor offeaturegate.Registry.Apply
. (#5801) - Deprecate the
component.Factory.StabilityLevel(config.DataType)
in favor of Stability per component (#5762):component.ExporterFactory.TracesExporterStability
component.ExporterFactory.MetricsExporterStability
component.ExporterFactory.LogsExporterStability
component.ProcessorFactory.TracesProcessorStability
component.ProcessorFactory.MetricsProcessorStability
component.ProcessorFactory.LogsProcessorStability
component.ReceiverFactory.TracesReceiverStability
component.ReceiverFactory.MetricsReceiverStability
component.ReceiverFactory.LogsReceiverStability
- Deprecate
obsreport.ProcessorSettings.Level
andobsreport.ExporterSettings.Level
, use MetricsLevel from CreateSettings (#5824) - Deprecate
processorhelper.New[Traces|Metrics|Logs]Processor
in favor ofprocessorhelper.New[Traces|Metrics|Logs]ProcessorWithCreateSettings
(#5833) - Deprecate MetricDataPointFlags.String(), no other pdata flags have this method (#5868)
- Deprecates
FlagsStruct
in favor ofFlags
(#5842)FlagsStruct
->Flags
- Deprecate
exporterhelper.New[Traces|Metrics|Logs]Exporter
in favor ofexporterhelper.New[Traces|Metrics|Logs]ExporterWithContext
(#5834)
- Enable persistent queue in the build by default (#5828)
- Bump to opentelemetry-proto v0.19.0. (#5823)
- Expose
Scope.Attributes
in pdata (#5826) - Remove unnecessary limitation on
pcommon.Value.Equal
that slices have only primitive values. (#5865) - Add support to handle 404, 405 http error code as permanent errors in OTLP exporter (#5827)
- Enforce scheme name restrictions to all
confmap.Provider
implementations. (#5861)
See the changelog for v0.57.0.
This was a failed release.
There isn't a valid core binary for this release. Use v0.57.2 instead.
- Remove deprecated funcs/types from service related to
Config
(#5755) - Change
confighttp.ToClient
to accept acomponent.Host
(#5737) - Remove deprecated funcs from pdata related to mutable slices (#5754)
- Change the following deprecated component functions to ensure a stability level is set:
component.WithTracesExporter
component.WithMetricsExporter
component.WithLogsExporter
component.WithTracesReceiver
component.WithMetricsReceiver
component.WithLogsReceiver
component.WithTracesProcessor
component.WithMetricsProcessor
component.WithLogsProcessor
- Deprecated the current Flag API. The new API provides functions to check and set Flags (#5790) (#5602):
NumberDataPoint.Flags
->NumberDataPoint.FlagsStruct
NumberDataPoint.SetFlags
->NumberDataPoint.FlagsStruct
HistogramDataPoint.Flags
->HistogramDataPoint.FlagsStruct
HistogramDataPoint.SetFlags
->HistogramDataPoint.FlagsStruct
ExponentialHistogramDataPoint.Flags
->ExponentialHistogramDataPoint.FlagsStruct
ExponentialHistogramDataPoint.SetFlags
->ExponentialHistogramDataPoint.FlagsStruct
SummaryDataPoint.Flags
->SummaryDataPoint.FlagsStruct
SummaryDataPoint.SetFlags
->SummaryDataPoint.FlagsStruct
MetricDataPointFlags
->MetricDataPointFlagsStruct
NewMetricDataPointFlags
->NewMetricDataPointFlagsStruct
MetricDataPointFlagsNone
->MetricDataPointFlagsStruct.NoRecordedValue
MetricDataPointFlagNoRecordedValue
->MetricDataPointFlagsStruct.NoRecordedValue
MetricDataPointFlag
- Deprecate the following component functions added to ensure a stability level is set:
component.WithTracesExporterAndStabilityLevel
->component.WithTracesExporter
component.WithMetricsExporterAndStabilityLevel
->component.WithMetricsExporter
component.WithLogsExporterAndStabilityLevel
->component.WithLogsExporter
component.WithTracesReceiverAndStabilityLevel
->component.WithTracesReceiver
component.WithMetricsReceiverAndStabilityLevel
->component.WithMetricsReceiver
component.WithLogsReceiverAndStabilityLevel
->component.WithLogsReceiver
component.WithTracesProcessorAndStabilityLevel
->component.WithTracesProcessor
component.WithMetricsProcessorAndStabilityLevel
->component.WithMetricsProcessor
component.WithLogsProcessorAndStabilityLevel
->component.WithLogsProcessor
- Make the in-memory and persistent queues more consistent (#5764)
ocb
now exits with an error if it fails to load the build configuration. (#5731)- Deprecate
HTTPClientSettings.ToClientWithHost
(#5737)
- Fix bug in ocb where flags did not take precedence. (#5726)
- Add
linux-ppc64le
architecture to cross build tests in CI (#5645) client
: perform case insensitive lookups in case the requested metadata value isn't found (#5646)loggingexporter
: Decoupleloglevel
field from level of logged messages (#5678)- Expose
pcommon.NewSliceFromRaw
function (#5679) loggingexporter
: create the exporter's logger from the service's logger (#5677)- Add
otelcol_exporter_queue_capacity
metrics show the collector's exporter queue capacity (#5475) - Add support to handle 402, 413, 414, 431 http error code as permanent errors in OTLP exporter (#5685)
- Fix Collector panic when disabling telemetry metrics (#5642)
- Fix Collector panic when featuregate value is empty (#5663)
- Fix confighttp.compression panic due to nil request.Body. (#5628)
- Remove deprecated
config.ServiceTelemetry
(#5565) - Remove deprecated
config.ServiceTelemetryLogs
(#5565) - Remove deprecated
config.ServiceTelemetryMetrics
(#5565)
- Deprecate
service.ConfigServiceTelemetry
,service.ConfigServiceTelemetryLogs
, andservice.ConfigServiceTelemetryMetrics
(#5565) - Deprecate the following component functions to ensure a stability level is set (#5580):
component.WithTracesExporter
->component.WithTracesExporterAndStabilityLevel
component.WithMetricsExporter
->component.WithMetricsExporterAndStabilityLevel
component.WithLogsExporter
->component.WithLogsExporterAndStabilityLevel
component.WithTracesReceiver
->component.WithTracesReceiverAndStabilityLevel
component.WithMetricsReceiver
->component.WithMetricsReceiverAndStabilityLevel
component.WithLogsReceiver
->component.WithLogsReceiverAndStabilityLevel
component.WithTracesProcessor
->component.WithTracesProcessorAndStabilityLevel
component.WithMetricsProcessor
->component.WithMetricsProcessorAndStabilityLevel
component.WithLogsProcessor
->component.WithLogsProcessorAndStabilityLevel
- Deprecate
Registry.Apply
inservice.featuregate
(#5660)
- Components stability levels are now logged. By default components which haven't defined their stability levels, or which are unmaintained, deprecated or in development will log a message. (#5580)
exporter/logging
: Skip "bad file descriptor" sync errors (#5585)
- Fix initialization of the OpenTelemetry MetricProvider. (#5571)
- Set log level for
undefined
stability level to debug. (#5635)
- Remove deprecated
GetLogger
. (#5504) - Remove deprecated
configtest.LoadConfigMap
(#5505) - Remove deprecated
config.Map
(#5505) - Remove deprecated
config.MapProvider
(#5505) - Remove deprecated
config.MapConverter
(#5505) - Remove deprecated
config.Received
(#5505) - Remove deprecated
config.CloseFunc
(#5505) - Deprecated
pcommon.Value.NewValueBytes
is brought back takingpcommon.ImmutableByteSlice
as an argument instead of[]byte
(#5299)
- Use immutable slices for primitive types slices to restrict mutations. (#5299)
Value.NewValueMBytes
func is deprecated in favor ofValue.NewValueBytes
func that takesImmutableByteSlice
instead of[]byte
Value.SetMBytesVal
func is deprecated in favor ofValue.SetBytesVal
func that takespcommon.ImmutableByteSlice
instead of []byte.Value.BytesVal
func is deprecated in favor ofValue.BytesVal
func that returnspcommon.ImmutableByteSlice
instead of []byte.<HistogramDataPoint|Buckets>.SetMBucketCounts
funcs are deprecated in favor of<HistogramDataPoint|Buckets>.SetBucketCounts
funcs that takepcommon.ImmutableUInt64Slice
instead of []uint64.<HistogramDataPoint|Buckets>.MBucketCounts
funcs are deprecated in favor of<HistogramDataPoint|Buckets>.BucketCounts
funcs that returnpcommon.ImmutableUInt64Slice
instead of []uint64.HistogramDataPoint.SetMExplicitBounds
func is deprecated in favor ofHistogramDataPoint.SetExplicitBounds
func that takespcommon.ImmutableFloat64Slice
instead of []float64.HistogramDataPoint.MExplicitBounds
func func is deprecated in favor ofHistogramDataPoint.ExplicitBounds
returnspcommon.ImmutableFloat64Slice
instead of []float64.
- Deprecate
HTTPClientSettings.ToClient
in favor ofHTTPClientSettings.ToClientWithHost
(#5584) - Use OpenCensus
metric
package for process metrics instead ofstats
package (#5486) - Update OTLP to v0.18.0 (#5530)
- Log histogram min/max fields with
logging
exporter (#5520)
- Update sum field of exponential histograms to make it optional (#5530)
- Remove redundant extension shutdown call (#5532)
- Refactor pipelines builder, fix some issues (#5512)
- Unconfigured receivers are not identified, this was not a real problem in final binaries since the validation of the config catch this.
- Allow configurations to contain "unused" receivers. Receivers that are configured but not used in any pipeline, this was possible already for exporters and processors.
- Remove the enforcement/check that Receiver factories create the same instance for the same config.
- Remove deprecated
componenterror
package. (#5420) - Remove deprecated
config.MapConverterFunc
. (#5419) - Remove
AddCollectorVersionTag
, enabled for long time already. (#5471)
- Move
config.Map
to its own packageconfmap
which does not depend on any component concept (#5237)config.Map
->confmap.ConfMap
config.MapProvider
->confmap.Provider
config.Received
->confmap.Received
config.NewReceivedFromMap
->confmap.NewReceived
config.CloseFunc
->confmap.CloseFunc
config.ChangeEvent
->confmap.ChangeEvent
config.MapConverter
->confmap.Converter
- Package
envmapprovider
->envprovider
- Package
filemapprovider
->fileprovider
- Package
yamlmapprovider
->yamlprovider
- Package
expandmapconverter
->expandconverter
- Package
filemapprovider
->fileprovider
- Package
overwritepropertiesmapconverter
->overwritepropertiesconverter
- Deprecate
component.ExtensionDefaultConfigFunc
in favor ofcomponent.ExtensionCreateDefaultConfigFunc
(#5451) - Deprecate
confmap.Received.AsMap
in favor ofconfmap.Received.AsConf
(#5465) - Deprecate
confmap.Conf.Set
, not used anywhere for the moment (#5485)
- Move
service.mapResolver
toconfmap.Resolver
(#5444) - Add
linux-arm
architecture to cross build tests in CI (#5472)
- Fixes the "service.version" label value for internal metrics, always was "latest" in core/contrib distros. (#5449).
- Send correct batch stats when SendBatchMaxSize is set (#5385)
- TLS
MinVersion
andMaxVersion
defaults will be handled bycrypto/tls
(#5480)
- Remove
configunmarshaler.Unmarshaler
interface, per deprecation comment (#5348) - Remove deprecated pdata funcs/structs from v0.50.0 (#5345)
- Remove deprecated pdata getters and setters of primitive slice values:
Value.BytesVal
,Value.SetBytesVal
,Value.UpdateBytes
,Value.InsertBytes
,Value.UpsertBytes
,<HistogramDataPoint|Buckets>.BucketCounts
,<HistogramDataPoint|Buckets>.SetBucketCounts
,HistogramDataPoint.ExplicitBounds
,HistogramDataPoint.SetExplicitBounds
(#5347) - Remove deprecated featuregate funcs/structs from v0.50.0 (#5346)
- Remove access to deprecated members of the config.Retrieved struct (#5363)
- Replace usage of
config.MapConverterFunc
withconfig.MapConverter
(#5382)
- Deprecate
config.Config
andconfig.Service
, useservice.Config*
(#4608) - Deprecate
componenterror
package, move everything tocomponent
(#5383) pcommon.Value.NewValueBytes
is deprecated in favor ofValue.NewValueMBytes
in preparation of migration to immutable slices (#5367)
- Update OTLP to v0.17.0 (#5335)
- Add optional min/max fields to histograms (#5399)
- User-defined Resource attributes can be specified under
service.telemetry.resource
configuration key and will be included as metric lables for own telemetry. Ifservice.instance.id
is not specified it will be auto-generated. Previouslyservice.instance.id
was always auto-generated, so the default of the new behavior matches the old behavior. (#5402)
- Remove deprecated model module, everything is available in
pdata
andsemconv
. (#5281)- Old versions of the module are still available, but no new versions will be released.
- Remove deprecated LogRecord.Name field. (#5202)
- In preparation of migration to immutable slices for primitive type items, the following methods are renamed (#5344)
Value.BytesVal
func is deprecated in favor ofValue.MBytesVal
.Value.SetBytesVal
func is deprecated in favor ofValue.SetMBytesVal
.Value.UpdateBytes
func is deprecated in favor ofValue.UpdateMBytes
.Value.InsertBytes
func is deprecated in favor ofValue.InsertMBytes
.Value.UpsertBytes
func is deprecated in favor ofValue.UpsertMBytes
.<HistogramDataPoint|Buckets>.BucketCounts
funcs are deprecated in favor of<HistogramDataPoint|Buckets>.MBucketCounts
.<HistogramDataPoint|Buckets>.SetBucketCounts
funcs are deprecated in favor of<HistogramDataPoint|Buckets>.SetMBucketCounts
.HistogramDataPoint.ExplicitBounds
func is deprecated in favor ofHistogramDataPoint.MExplicitBounds
.HistogramDataPoint.SetExplicitBounds
func is deprecated in favor ofHistogramDataPoint.SetMExplicitBounds
.
pdata
: Exposepcommon.NewSliceFromRaw
andpcommon.Slice.AsRaw
functions (#5311)
- Fix Windows Event Logs ignoring user-specified logging options (#5298)
- Remove pdata deprecated funcs from 2 versions (v0.48.0) ago. (#5219)
- Remove non pdata deprecated funcs/structs (#5220)
pmetric.Exemplar.ValueType()
now returns new typeExemplarValueType
(#5233)- Remove deprecated
Delete
pdata func in favor ofpdata.Remove
from (v0.47.0). (#5307)
- Deprecate
configunmarshaler
package, move it to internal (#5151) - Deprecate all API in
model/semconv
. The package is moved to a newsemcomv
module (#5196) - Deprecate access to
config.Retrieved
fields, use the newly added funcs to interact with the internal fields (#5198) - Deprecate
p<signal>otlp.Request.Set<Logs|Metrics|Traces>
(#5234)plogotlp.Request.SetLogs
func is deprecated in favor ofplogotlp.NewRequestFromLogs
pmetricotlp.Request.SetMetrics
func is deprecated in favor ofpmetricotlp.NewRequestFromMetrics
ptraceotlp.Request.SetTraces
func is deprecated in favor ofptraceotlp.NewRequestFromTraces
pmetric.NumberDataPoint.ValueType()
now returns new typeNumberDataPointValueType
(#5233)pmetric.MetricValueType
is deprecated in favor ofNumberDataPointValueType
pmetric.MetricValueTypeNone
is deprecated in favor ofNumberDataPointValueTypeNone
pmetric.MetricValueTypeInt
is deprecated in favor ofNumberDataPointValueTypeInt
pmetric.MetricValueTypeDouble
is deprecated in favor ofNumberDataPointValueTypeDouble
- Deprecate
plog.LogRecord.SetName()
function (#5230) - Deprecate global
featuregate
funcs in favor ofGetRegistry
and a publicRegistry
type (#5160)
-
Add
jsoniter
Unmarshaller (#4817) -
Extend config.Map.Unmarshal hook to check map key string to any TextUnmarshaler not only ComponentID (#5244)
-
Collector will no longer print error with stack trace when the collector is shutdown due to a context cancel. (#5258)
- Fix translation from otlp.Request to pdata representation, changes to the returned pdata not all reflected to the otlp.Request (#5197)
exporterhelper
now properly consumes any remaining items on stop (#5203)pdata
: Fix copying ofValue
withValueTypeBytes
type (#5267)pdata
: Fix copying of metric fields of primitive items slice type (#5271)
- Remove deprecated structs/funcs from previous versions (#5131)
- Do not set TraceProvider to global otel (#5138)
- Remove deprecated funcs from otlpgrpc (#5144)
- Add Scheme to MapProvider interface (#5068)
- Do not set MeterProvider to global otel (#5146)
- Make
InstrumentationLibrary<signal>ToScope
helper functions unexported (#5164) - Remove Log's "ShortName" from logging exporter output (#5172)
exporter/otlp
: Retry RESOURCE_EXHAUSTED only if the server returns RetryInfo (#5147)
- All pdata related APIs from model (model/pdata, model/otlp and model/otlpgrpc) are deprecated in
favor of packages in the new pdata module separated by telemetry signal type (#5168)
model/pdata
,model/otlp
->pdata/pcommon
,pdata/plog
,pdata/pmetric
,pdata/ptrace
model/otlpgrpc
->pdata/plog/plogotlp
,pdata/pmetric/pmetricotlp
,pdata/ptrace/ptraceotlp
- Deprecate configmapprovider package, replace with mapconverter (#5167)
- Deprecate
service.MustNewConfigProvider
andservice.MustNewDefaultConfigProvider
in favor ofservice.NewConfigProvider
(#4936)
- OTLP HTTP receiver will use HTTP/2 over TLS if client supports it (#5109)
- Add
ObservedTimestamp
field topdata.LogRecord
(#5171)
- Setup the correct meter provider if telemetry.useOtelForInternalMetrics featuregate enabled (#5146)
- Fix pdata.Value.asRaw() to correctly return elements of Slice and Map type (#5153)
- Update pdata.Slice.asRaw() to return raw representation of Slice and Map elements (#5157)
- The codepath through the OTLP receiver for gRPC was not translating the InstrumentationLibrary* to Scope* (#5189)
- Remove deprecated
consumerhelper
package (#5028) - Remove pdata
InternalRep
deprecated funcs (#5018) - Remove service/defaultcomponents deprecated package (#5019)
- Remove deprecated UseOpenTelemetryForInternalMetrics (#5026)
- Change outcome of
pdata.Value.MapVal()
andpdata.Value.SliceVal()
functions misuse. In case of type mismatch, they now return an invalid zero-initialized instance instead of a detached collection (#5034) - OTLP JSON field changes following upgrade to OTLP v0.15.0:
- "instrumentationLibraryLogs" is now "scopeLogs"
- "instrumentationLibraryMetrics" is now "scopeMetrics"
- "instrumentationLibrarySpans" is now "scopeSpans"
- "instrumentationLibrary" is now "scope"
- AsString for pdata.Value now returns the JSON-encoded string of floats. (#4934)
- Move MapProvider to config, split providers in their own package (#5030)
- API related to
pdata.AttributeValue
is deprecated in favor ofpdata.Value
(#4978)pdata.AttributeValue
struct is deprecated in favor ofpdata.Value
pdata.AttributeValueType
type is deprecated in favor ofpdata.ValueType
pdata.AttributeValueType...
constants are deprecated in favor ofpdata.ValueType...
pdata.NewAttributeValue...
funcs are deprecated in favor ofpdata.NewValue...
- Deprecate featureflags.FlagValue.SetSlice, unnecessary public (#5053)
- Remove "Attribute" part from common pdata collections names (#5001)
- Deprecate
pdata.AttributeMap
struct in favor ofpdata.Map
- Deprecate
pdata.NewAttributeMap
func in favor ofpdata.NewMap
- Deprecate
pdata.NewAttributeMapFromMap
func in favor ofpdata.NewMapFromRaw
- Deprecate
pdata.AttributeValueSlice
struct in favor ofpdata.Slice
- Deprecate
pdata.NewAttributeValueSlice
func in favor ofpdata.NewSlice
- Deprecate
- Deprecate LogRecord.Name(), it was deprecated in the data model (#5054)
- Rename
Array
type ofpdata.Value
toSlice
(#5066)- Deprecate
pdata.AttributeValueTypeArray
type in favor ofpdata.ValueTypeSlice
- Deprecate
pdata.NewAttributeValueArray
func in favor ofpdata.NewValueSlice
- Deprecate
- Deprecate global flag in
featuregates
(#5060) - Deprecate last funcs/structs in componenthelper (#5069)
- Change structs in otlpgrpc to follow standard go encoding interfaces (#5062)
- Deprecate UnmarshalJSON[Traces|Metrics|Logs][Reques|Response] in favor of
UnmarshalJSON
. - Deprecate [Traces|Metrics|Logs][Reques|Response].Marshal in favor of
MarshalProto
. - Deprecate UnmarshalJSON[Traces|Metrics|Logs][Reques|Response] in favor of
UnmarshalProto
.
- Deprecate UnmarshalJSON[Traces|Metrics|Logs][Reques|Response] in favor of
- Deprecating following pdata methods/types following OTLP v0.15.0 upgrade (#5076): - InstrumentationLibrary is now InstrumentationScope - NewInstrumentationLibrary is now NewInstrumentationScope - InstrumentationLibraryLogsSlice is now ScopeLogsSlice - NewInstrumentationLibraryLogsSlice is now NewScopeLogsSlice - InstrumentationLibraryLogs is now ScopeLogs - NewInstrumentationLibraryLogs is now NewScopeLogs - InstrumentationLibraryMetricsSlice is now ScopeMetricsSlice - NewInstrumentationLibraryMetricsSlice is now NewScopeMetricsSlice - InstrumentationLibraryMetrics is now ScopeMetrics - NewInstrumentationLibraryMetrics is now NewScopeMetrics - InstrumentationLibrarySpansSlice is now ScopeSpansSlice - NewInstrumentationLibrarySpansSlice is now NewScopeSpansSlice - InstrumentationLibrarySpans is now ScopeSpans - NewInstrumentationLibrarySpans is now NewScopeSpans
- Add semconv definitions for v1.9.0 (#5090)
- Change outcome of
pdata.Metric.<Gauge|Sum|Histogram|ExponentialHistogram>()
functions misuse. In case of type mismatch, they don't panic right away but return an invalid zero-initialized instance for consistency with other OneOf field accessors (#5035) - Update OTLP to v0.15.0 (#5064)
- Adding support for transition from older versions of OTLP to OTLP v0.15.0 (#5085)
- Add missing files for semconv definitions v1.7.0 and v1.8.0 (#5091)
- The
featuregates
were not configured from the "--feature-gates" flag on windows service (#5060) - Fix Semantic Convention Schema URL definition for 1.5.0 and 1.6.1 versions (#5103)
- Remove
Type
funcs in pdata (#4933) - Remove all deprecated funcs/structs from v0.46.0 (#4995)
- pdata: deprecate funcs working with InternalRep (#4957)
- Deprecate
pdata.AttributeMap.Delete
in favor ofpdata.AttributeMap.Remove
(#4914) - Deprecate consumerhelper, move helpers to consumer (#5006)
- Add
pdata.AttributeMap.RemoveIf
, which is a more performant way to remove multiple keys (#4914) - Add
pipeline
key with pipeline identifier to processor loggers (#4968) - Add a new yaml provider, allows providing yaml bytes (#4998)
- Collector
Run
will now exit when a context cancels (#4954) - Add missing droppedAttributesCount to pdata generated resource (#4979)
- Collector
Run
will now set state toClosed
if startup fails (#4974)
- Change otel collector to enable open telemetry metrics through feature gate instead of a constant (#4912)
- Remove support for legacy otlp/http port. (#4916)
- Remove deprecated funcs in pdata (#4809)
- Remove deprecated Retrieve funcs/calls (#4922)
- Remove deprecated NewConfigProvider funcs (#4937)
- Deprecated funcs
config.DefaultConfig
,confighttp.DefaultHTTPSettings
,exporterhelper.DefaultTimeoutSettings
,exporthelper.DefaultQueueSettings
,exporterhelper.DefaultRetrySettings
,testcomponents.DefaultFactories
, andscraperhelper.DefaultScraperControllerSettings
in favour for theirNewDefault
method to adhere to contribution guidelines (#4865) - Deprecated funcs
componenthelper.StartFunc
,componenthelper.ShutdownFunc
in favour ofcomponent.StartFunc
andcomponent.ShutdownFunc
(#4803) - Move helpers from extensionhelper to component (#4805)
- Deprecated
extensionhelper.CreateDefaultConfig
in favour ofcomponent.ExtensionDefaultConfigFunc
- Deprecated
extensionhelper.CreateServiceExtension
in favour ofcomponent.CreateExtensionFunc
- Deprecated
extensionhelper.NewFactory
in favour ofcomponent.NewExtensionFactory
- Deprecated
- Move helpers from processorhelper to component (#4889)
- Deprecated
processorhelper.CreateDefaultConfig
in favour ofcomponent.ProcessorDefaultConfigFunc
- Deprecated
processorhelper.WithTraces
in favour ofcomponent.WithTracesProcessor
- Deprecated
processorhelper.WithMetrics
in favour ofcomponent.WithMetricsProcessor
- Deprecated
processorhelper.WithLogs
in favour ofcomponent.WithLogsProcessor
- Deprecated
processorhelper.NewFactory
in favour ofcomponent.NewProcessorFactory
- Deprecated
- Move helpers from exporterhelper to component (#4899)
- Deprecated
exporterhelper.CreateDefaultConfig
in favour ofcomponent.ExporterDefaultConfigFunc
- Deprecated
exporterhelper.WithTraces
in favour ofcomponent.WithTracesExporter
- Deprecated
exporterhelper.WithMetrics
in favour ofcomponent.WithMetricsExporter
- Deprecated
exporterhelper.WithLogs
in favour ofcomponent.WithLogsExporter
- Deprecated
exporterhelper.NewFactory
in favour ofcomponent.NewExporterFactory
- Deprecated
- Move helpers from receiverhelper to component (#4891)
- Deprecated
receiverhelper.CreateDefaultConfig
in favour ofcomponent.ReceiverDefaultConfigFunc
- Deprecated
receiverhelper.WithTraces
in favour ofcomponent.WithTracesReceiver
- Deprecated
receiverhelper.WithMetrics
in favour ofcomponent.WithMetricsReceiver
- Deprecated
receiverhelper.WithLogs
in favour ofcomponent.WithLogsReceiver
- Deprecated
receiverhelper.NewFactory
in favour ofcomponent.NewReceiverFactory
- Deprecated
- Add validation to check at least one endpoint is specified in otlphttpexporter's configuration (#4860)
- Implement default client authenticators (#4837)
- Initialized logger with collector to avoid potential race condition panic on
Shutdown
(#4827) - In addition to traces, now logs and metrics processors will start the memory limiter.
Added thread-safe logic so only the first processor can launch the
checkMemLimits
go-routine and the last processor that calls shutdown to terminate it; this is done per memory limiter instance. Added memory limiter factory to cache initiated object and be reused by similar config. This guarantees a single runningcheckMemLimits
per config (#4886) - Resolved race condition in collector when calling
Shutdown
(#4878)
- Remove deprecated funcs in configtelemetry (#4808)
otlphttp
andotlp
exporters enable gzip compression by default (#4632)
- Deprecate
service/defaultcomponents
go package (#4622) - Deprecate
pdata.NumberDataPoint.Type()
andpdata.Exemplar.Type()
in favor ofNumberDataPoint.ValueType()
andExemplar.ValueType()
(#4850)
- Reject invalid queue size exporterhelper (#4799)
- Transform configmapprovider.Retrieved interface to a struct (#4789)
- Added feature gate summary to zpages extension (#4834)
- Add support for reloading TLS certificates (#4737)
confighttp
: Allow CORS requests with configured auth (#4869)
- Updated to OTLP 0.12.0. Deprecated traces and metrics messages that existed in 0.11.0 are no longer converted to the messages and fields that replaced the deprecated ones. Received deprecated messages and fields will be now ignored. In OTLP/JSON in the instrumentationLibraryLogs object the "logs" field is now named "logRecords" (#4724)
- Deprecate
service.NewWindowsService
, addservice.NewSvcHandler
(#4783).
- Deprecate
service.NewConfigProvider
, and a new versionservice.MustNewConfigProvider
(#4734).
- Invalid requests now return an appropriate unsupported (
405
) or method not allowed (415
) response (#4735) client.Info
: Add Host property for Metadata (#4736)
- ExpandStringValues function support to map[string]interface{} (#4748)
- Change configmapprovider.Provider to accept a location for retrieve (#4657)
- Change Properties Provider to be a Converter (#4666)
- Define a type
WatcherFunc
for onChange func instead of func pointer (#4656) - Remove deprecated
configtest.LoadConfig
andconfigtest.LoadConfigAndValidate
(#4659) - Move service.ConfigMapConverterFunc to config.MapConverterFunc (#4673)
- Add context to config.MapConverterFunc (#4678)
- Builder: the skip compilation should only be supplied as a CLI flag. Previously, it was possible to specify that in the YAML file, contrary to the original intention (#4645)
- Builder: Remove deprecated config option module::core (#4693)
- Remove deprecate flags --metrics-level and --metrics-addr (#4695)
- Usages of
--metrics-level={VALUE}
can be replaced by--set=service.telemetry.metrics.level={VALUE}
; - Usages of
--metrics-addr={VALUE}
can be replaced by--set=service.telemetry.metrics.address={VALUE}
;
- Usages of
- Updated confighttp
ToClient
to support passing telemetry settings for instrumenting otlphttp exporter(#4449) - Remove support to some arches and platforms from
ocb
(opentelemetry-collector-builder) (#4710) - Remove deprecated legacy path ("v1/trace") support for otlp http receiver (#4720)
- Change the
service.NewDefaultConfigProvider
to accept a slice of location strings (#4727).
- Deprecate
configtelemetry.Level.Set()
(#4700)
- Ensure Windows path (e.g: C:) is recognized as a file path (#4726)
- Fix structured logging issue for windows service (#4686)
- Expose experimental API
configmapprovider.NewExpandConverter()
(#4672) service.NewConfigProvider
: copy slice argument, disallow changes from caller to the input slice (#4729)confighttp
andconfiggrpc
: New config optioninclude_metadata
to persist request metadata/headers inclient.Info.Metadata
(experimental) (#4547)- Remove expand cases that cannot happen with config.Map (#4649)
- Add
max_request_body_size
to confighttp.HTTPServerSettings (#4677) - Move
compression.go
intoconfighttp.go
to internalize functions incompression.go
file. (#4651)- create
configcompression
package to manage compression methods inconfighttp
andconfiggrpc
- create
- Add support for cgroupv2 memory limit (#4654)
- Enable end users to provide multiple files for config location (#4727)
- Remove
configmapprovider.NewInMemory()
(#4507) - Disallow direct implementation of
configmapprovider.Retrieved
(#4577) configauth
: remove interceptor functions from the ServerAuthenticator interface (#4583)- Replace ConfigMapProvider and ConfigUnmarshaler in collector settings by one simpler ConfigProvider (#4590)
- Remove deprecated consumererror.Combine (#4597)
- Remove
configmapprovider.NewDefault
,configmapprovider.NewExpand
,configmapprovider.NewMerge
(#4600)- The merge functionality is now embedded into
service.NewConfigProvider
(#4637).
- The merge functionality is now embedded into
- Move
configtest.LoadConfig
andconfigtest.LoadConfigAndValidate
toservicetest
(#4606) - Builder: Remove deprecated
include-core
flag (#4616) - Collector telemetry level must now be accessed through an atomic function. (#4549)
confighttp
: add client-side compression support. (#4441)- Each exporter should remove
compression
field if they have and should useconfighttp.HTTPClientSettings
- Each exporter should remove
- Allow more zap logger configs:
disable_caller
,disable_stacktrace
,output_paths
,error_output_paths
,initial_fields
(#1048) - Allow the custom zap logger encoding (#4532)
- Collector self-metrics may now be configured through the configuration file. (#4069)
- CLI flags for configuring self-metrics are deprecated and will be removed in a future release.
service.telemetry.metrics.level
andservice.telemetry.metrics.address
should be used to configure collector self-metrics.
configauth
: add helpers to create new server authenticators. (#4558)- Refactor
configgrpc
for compression methods (#4624) - Add an option to allow
config.Map
conversion in theservice.ConfigProvider
(#4634) - Added support to expose gRPC framework's logs as part of collector logs (#4501)
- Builder: Enable unmarshal exact to help finding hard to find typos #4644
- Fix merge config map provider to close the watchers (#4570)
- Fix expand map provider to call close on the base provider (#4571)
- Fix correct the value of
otelcol_exporter_send_failed_requests
(#4629) otlp
receiver: Fix legacy port cfg value override and HTTP server starting bug (#4631)
- Remove reference to
defaultcomponents
in core and deprecateinclude_core
flag (#4087) - Remove
config.NewConfigMapFrom[File|Buffer]
, add testonly version (#4502) configtls
: TLS 1.2 is the new default mininum version (#4503)confighttp
:ToServer
now accepts acomponent.Host
, in line with gRPC's counterpart (#4514)- CORS configuration for OTLP/HTTP receivers has been moved into a
cors:
block, instead of individualcors_allowed_origins
andcors_allowed_headers
settings (#4492)
- OTLP/HTTP receivers now support setting the
Access-Control-Max-Age
header for CORS caching. (#4492) client.Info
pre-populated for all receivers using common helpers likeconfighttp
andconfiggrpc
(#4423)
- Fix handling of corrupted records by persistent buffer (experimental) (#4475)
- Extending the contribution guide to help clarify what is acceptable defaults and recommendations.
- Package
client
refactored (#4416) and auth data included in it (#4422). Final PR to be merged in the next release (#4423) - Remove
pdata.AttributeMap.InitFromMap
(#4429) - Updated configgrpc
ToDialOptions
to support passing providers to instrumentation library (#4451) - Make state information propagation non-blocking on the collector (#4460)
- Add semconv 1.7.0 and 1.8.0 (#4452)
- Added
feature-gates
CLI flag for controlling feature gate state. (#4368) - Add a default user-agent header to the OTLP/gRPC and OTLP/HTTP exporters containing collector build information (#3970)
- Remove deprecated config (already no-op)
ballast_size_mib
in memorylimiterprocessor (#4365) - Remove
config.Receivers
,config.Exporters
,config.Processors
, andconfig.Extensions
. Use map directly (#4344) - Remove
component.BaseProcessorFactory
, useprocessorhelper.NewFactory
instead (#4175) - Force usage of
exporterhelper.NewFactory
to implementcomponent.ExporterFactory
(#4338) - Force usage of
receiverhelper.NewFactory
to implementcomponent.ReceiverFactory
(#4338) - Force usage of
extensionhelper.NewFactory
to implementcomponent.ExtensionFactory
(#4338) - Move
service/parserprovider
package toconfig/configmapprovider
(#4206)- Rename
MapProvider
interface toProvider
- Remove
MapProvider
from helper names
- Rename
- Renamed slice-valued
pdata
types and functions for consistency. (#4325)- Rename
pdata.AnyValueArray
topdata.AttributeValueSlice
- Rename
ArrayVal()
toSliceVal()
- Rename
SetArrayVal()
toSetSliceVal()
- Rename
- Remove
config.Pipeline.Name
(#4326) - Rename
config.Mapprovider
asconfigmapprovider.Provider
(#4337) - Move
config.WatchableRetrieved
andconfig.Retrieved
interfaces toconfig/configmapprovider
package (#4337) - Remove
config.Pipeline.InputDataType
(#4343) - otlpexporter: Do not retry on PermissionDenied and Unauthenticated (#4349)
- Enable configuring collector metrics through service config file. (#4069)
- New
service::telemetry::metrics
structure added to configuration - Existing metrics configuration CLI flags are deprecated and to be removed in the future.
--metrics-prefix
is no longer operative; the prefix is determined by the value ofservice.buildInfo.Command
.--add-instance-id
is no longer operative; an instance ID will always be added.
- New
- Remove deprecated funcs
consumererror.As[Traces|Metrics|Logs]
(#4364) - Remove support to expand env variables in default configs (#4366)
- Supports more compression methods(
snappy
andzstd
) for configgrpc, in addition to currentgzip
(#4088) - Moved the OpenTelemetry Collector Builder to core (#4307)
- Fix AggregationTemporality and IsMonotonic when metric descriptors are split in the batch processor (#4389)
- Removed
configauth.HTTPClientAuthenticator
andconfigauth.GRPCClientAuthenticator
in favor ofconfigauth.ClientAuthenticator
. (#4255) - Rename
parserprovider.MapProvider
asconfig.MapProvider
. (#4178) - Rename
parserprovider.Watchable
asconfig.WatchableMapProvider
. (#4178) - Remove deprecated no-op flags to setup Collector's logging "--log-level", "--log-profile", "--log-format". (#4213)
- Move
cmd/pdatagen
as internal packagemodel/internal/cmd/pdatagen
. (#4243) - Use directly the ComponentID in configauth. (#4238)
- Refactor configauth, getters use the map instead of iteration. (#4234)
- Change scraperhelper to follow the recommended append model for pdata. (#4202)
- Update proto to 0.11.0. (#4209)
- Change pdata to use the newly added [Traces|Metrics|Logs]Data. (#4214)
- Add ExponentialHistogram field to pdata. (#4219)
- Make sure otlphttp exporter tests include TraceID and SpanID. (#4268)
- Use multimod tool in release process. (#4229)
- Change queue metrics to use opencensus metrics instead of stats, close to otel-go. (#4220)
- Make receiver data delivery guarantees explicit (#4262)
- Simplify unmarshal logic by adding more supported hooks. (#4237)
- Add unmarshaler for otlpgrpc.[]Request and otlpgrp.[]Response (#4215)
- Move
configcheck.ValidateConfigFromFactories
as internal function in service package (#3876) - Rename
configparser.Parser
asconfig.Map
(#4075) - Rename
component.DefaultBuildInfo()
tocomponent.NewDefaultBuildInfo()
(#4129) - Rename
consumererror.Permanent
toconsumererror.NewPermanent
(#4118) - Rename
config.NewID
toconfig.NewComponentID
andconfig.NewIDFromString
toconfig.NewComponentIDFromString
(#4137) - Rename
config.NewIDWithName
toconfig.NewComponentIDWithName
(#4151) - Move
extension/storage
toextension/experimental/storage
(#4082) - Rename
obsreporttest.SetupRecordedMetricsTest()
toobsreporttest.SetupTelemetry()
andobsreporttest.TestTelemetrySettings
toobsreporttest.TestTelemetry
(#4157)
- Add Gen dependabot into CI (#4083)
- Update OTLP to v0.10.0 (#4045).
- Add Flags field to NumberDataPoint, HistogramDataPoint, SummaryDataPoint (#4081).
- Add feature gate library (#4108)
- Add version to the internal telemetry metrics (#4140)
- Fix panic when not using
service.NewCommand
(#4139)
- Remove deprecated pdata.AttributeMapToMap (#3994)
- Move ValidateConfig from configcheck to configtest (#3956)
- Remove
mem-ballast-size-mib
, already deprecated and no-op (#4005) - Remove
semconv.AttributeMessageType
(#4020) - Remove
semconv.AttributeHTTPStatusText
(#4015) - Remove squash on
configtls.TLSClientSetting
and move TLS client configs undertls
(#4063) - Rename TLS server config
*configtls.TLSServerSetting
fromtls_settings
totls
(#4063) - Split
service.Collector
from thecobra.Command
(#4074) - Rename
memorylimiter
tomemorylimiterprocessor
(#4064)
- Create new semconv package for v1.6.1 (#3948)
- Add AttributeValueBytes support to AsString (#4002)
- Add AttributeValueTypeBytes support to AttributeMap.AsRaw (#4003)
- Add MeterProvider to TelemetrySettings (#4031)
- Add configuration to setup collector logs via config file. (#4009)
- Remove the legacy gRPC port(
55680
) support in OTLP receiver (#3966) - Rename configparser.Parser to configparser.ConfigMap (#3964)
- Remove obsreport.ScraperContext, embed into StartMetricsOp (#3969)
- Remove dependency on deprecated go.opentelemetry.io/otel/oteltest (#3979)
- Remove deprecated pdata.AttributeValueToString (#3953)
- Remove deprecated pdata.TimestampFromTime. Closes: #3925 (#3935)
- Add TelemetryCreateSettings (#3984)
- Only initialize collector telemetry once (#3918)
- Add trace context info to LogRecord log (#3959)
- Add new view for AWS ECS health check extension. (#3776)
- Artifacts are no longer published in this repository, check here (#3941)
- Remove deprecated
tracetranslator.AttributeValueToString
andtracetranslator.AttributeMapToMap
(#3873) - Change semantic conventions for status (code, msg) as per specifications (#3872)
- Move
fileexporter
to contrib (#3474) - Move
jaegerexporter
to contrib (#3474) - Move
kafkaexporter
to contrib (#3474) - Move
opencensusexporter
to contrib (#3474) - Move
prometheusexporter
to contrib (#3474) - Move
prometheusremotewriteexporter
to contrib (#3474) - Move
zipkinexporter
to contrib (#3474) - Move
attributeprocessor
to contrib (#3474) - Move
filterprocessor
to contrib (#3474) - Move
probabilisticsamplerprocessor
to contrib (#3474) - Move
resourceprocessor
to contrib (#3474) - Move
spanprocessor
to contrib (#3474) - Move
hostmetricsreceiver
to contrib (#3474) - Move
jaegerreceiver
to contrib (#3474) - Move
kafkareceiver
to contrib (#3474) - Move
opencensusreceiver
to contrib (#3474) - Move
prometheusreceiver
to contrib (#3474) - Move
zipkinreceiver
to contrib (#3474) - Move
bearertokenauthextension
to contrib (#3474) - Move
healthcheckextension
to contrib (#3474) - Move
oidcauthextension
to contrib (#3474) - Move
pprofextension
to contrib (#3474) - Move
translator/internaldata
to contrib (#3474) - Move
translator/trace/jaeger
to contrib (#3474) - Move
translator/trace/zipkin
to contrib (#3474) - Move
testbed
to contrib (#3474) - Move
exporter/exporterhelper/resource_to_telemetry
to contrib (#3474) - Move
processor/processorhelper/attraction
to contrib (#3474) - Move
translator/conventions
tomodel/semconv
(#3901)
- Add
pdata.NewTimestampFromTime
, deprecatepdata.TimestampFromTime
(#3868) - Add
pdata.NewAttributeMapFromMap
, deprecatepdata.AttributeMap.InitFromMap
(#3936)
- Rename
configloader
interface toconfigunmarshaler
(#3774) - Remove
LabelsMap
from all the metrics points (#3706) - Update generated K8S attribute labels to fix capitalization (#3823)
- Collector has now full support for metrics proto v0.9.0.
This release is marked as "bad" since the metrics pipelines will produce bad data.
- Rename
CustomUnmarshable
interface toUnmarshallable
(#3774)
- Change default OTLP/HTTP port number from 55681 to 4318 (#3743)
- Update OTLP proto to v0.9.0 (#3740)
- Remove
SetValue
/Value
func forNumberDataPoint
/Exemplar
(#3730) - Remove
IntGauge
/IntSum
from pdata (#3731) - Remove
IntDataPoint
from pdata (#3735) - Add support for
Bytes
attribute type (#3756) - Add
SchemaUrl
field (#3759) - Add
Attributes
toNumberDataPoint
,HistogramDataPoint
,SummaryDataPoint
(#3761)
- Remove
conventions
translator: Replace with conventions generated from spec v1.5.0 (#3494)prometheus
receiver: AddToMetricPdata
method (#3695)- Make configsource
Watchable
an optional interface (#3792) obsreport
exporter: Change to acceptExporterCreateSettings
(#3789)
configgrpc
: Use chained interceptors in the gRPC server (#3744)prometheus
receiver: Use actual interval startTimeMs for cumulative types (#3694)jaeger
translator: Fix bug that could generate empty proto spans (#3808)
- Remove Resize() from pdata slice APIs (#3675)
- Remove the ballast allocation when
mem-ballast-size-mib
is set in command line (#3626)- Use
ballast extension
to set memory ballast instead.
- Use
- Rename
DoubleDataPoint
toNumberDataPoint
(#3633) - Remove
IntHistogram
(#3676)
- Update to OTLP 0.8.0:
- Translate
IntHistogram
toHistogram
inotlp_wrappers
(#3676) - Translate
IntGauge
toGauge
inotlp_wrappers
(#3619) - Translate
IntSum
toSum
inotlp_wrappers
(#3621) - Update
NumberDataPoint
to supportDoubleVal
andIntVal
(#3689) - Update
Exemplar
to useoneOfPrimitiveValue
(#3699) - Remove
IntExemplar
andIntExemplarSlice
frompdata
(#3705) - Mark
IntGauge
/IntSum
/IntDataPoint
as deprecated (#3707) - Remove
IntGauge
/IntSum
frombatchprocessor
(#3718) prometheusremotewrite
exporter: Convert to new Number metrics (#3714)prometheus
receiver: Convert to new Number metrics (#3716)prometheus
exporter: Convert to new Number metrics (#3709)hostmetrics
receiver: Convert to new Number metrics (#3710)opencensus
: Convert to new Number metrics (#3708)scraperhelper
receiver: Convert to new Number metrics (#3717)testbed
: Convert to new Number metrics (#3719)expoerterhelper
: Convertresourcetolabel
to new Number metrics (#3723)
- Translate
configauth
: Prepare auth API to return a context (#3618)pdata
:- Implement
Equal()
for map-valuedAttributeValues
(#3612) - Add
[Type]Slice.Sort(func)
to sort slices (#3671)
- Implement
memorylimiter
:- Add validation on ballast size between
memorylimiter
andballastextension
(#3532) - Access Ballast extension via
Host.GetExtensions
(#3634)
- Add validation on ballast size between
prometheusremotewrite
exporter: Add a WAL implementation without wiring up (#3597)prometheus
receiver: AddmetricGroup.toDistributionPoint
pdata conversion (#3667)- Use
ComponentID
as identifier instead of config (#3696) zpages
: Move config validation from factory toValidate
(#3697)- Enable
tracez
z-pages from otel-go, disable opencensus (#3698) - Convert temporality and monotonicity for deprecated sums (#3729)
otlpexporter
: Allow endpoint to be configured with a scheme ofhttp
orhttps
(#3575)- Handle errors when reloading the collector service (#3615)
- Do not report fatal error when
cmux.ErrServerClosed
(#3703) - Fix bool attribute equality in
pdata
(#3688)
- Rename
pdata.DoubleSum
topdata.Sum
(#3583) - Rename
pdata.DoubleGauge
topdata.Gauge
(#3599) - Migrated
pdata
to a dedicated package (#3483) - Change Marshaler/Unmarshaler to be consistent with other interfaces (#3502)
- Remove consumer/simple package (#3438)
- Remove unnecessary interfaces from pdata (#3506)
- zipkinv1 implement directly Unmarshaler interface (#3504)
- zipkinv2 implement directly Marshaler/Unmarshaler interface (#3505)
- Change exporterhelper to accept ExporterCreateSettings instead of just logger (#3569)
- Use Func pattern in processorhelper, consistent with others (#3570)
- Deprecate Resize() from pdata slice APIs (#3573)
- Update OTLP to v0.8.0 (#3572)
- Migrate from OpenCensus to OpenTelemetry for internal tracing (#3567)
- Move internal/pdatagrpc to model/otlpgrpc (#3507)
- Move internal/otlp to model/otlp (#3508)
- Create http Server via Config, enable cors and decompression (#3513)
- Allow users to set min and max TLS versions (#3591)
- Support setting ballast size in percentage of total Mem in ballast extension (#3456)
- Publish go.opentelemetry.io/collector/model as a separate module (#3530)
- Pass a TracerProvider via construct settings to all the components (#3592)
- Make graceful shutdown optional (#3577)
scraperhelper
: Include the scraper name in log messages (#3487)scraperhelper
: fix case when returned pdata is empty (#3520)- Record the correct number of points not metrics in Kafka receiver (#3553)
- Validate the Prometheus configuration (#3589)
- Rename
service.Application
toservice.Collector
(#3268) - Provide case sensitivity in config yaml mappings by using Koanf instead of Viper (#3337)
- Move zipkin constants to an internal package (#3431)
- Disallow renaming metrics using metric relabel configs (#3410)
- Move cgroup and iruntime utils from memory_limiter to internal folder (#3448)
- Move model pdata interfaces to pdata, expose them publicly (#3455)
- Change obsreport helpers for scraper to use the same pattern as Processor/Exporter (#3327)
- Convert
otlptext
to implement Marshaler interfaces (#3366) - Add encoder/decoder and marshaler/unmarshaler for OTLP protobuf (#3401)
- Use the new marshaler/unmarshaler in
kafka
exporter (#3403) - Convert
zipkinv2
to to/from translator interfaces (#3409) zipkinv1
: Move to translator and encoders interfaces (#3419)- Use the new marshaler/unmarshaler in
kafka
receiver #3402 - Change
oltp
receiver to use the new unmarshaler, avoid grpc-gateway dependency (#3406) - Use the new Marshaler in the
otlphttp
exporter (#3433) - Add grpc response struct for all signals instead of returning interface in
otlp
receiver/exporter (#3437) zipkinv2
: Add encoders, decoders, marshalers (#3426)scrapererror
receiver: Return concrete error type (#3360)kafka
receiver: Add metrics support (#3452)prometheus
receiver:- Add store to track stale metrics (#3414)
- Add
up
andscrape_xxxx
internal metrics (#3116)
prometheus
receiver:- Reject datapoints with duplicate label keys (#3408)
- Scrapers are not stopped when receiver is shutdown (#3450)
prometheusremotewrite
exporter: Adjust default retry settings (#3416)hostmetrics
receiver: Fix missing startTimestamp forprocesses
scraper (#3461)
- Remove unused logstest package (#3222)
- Introduce
AppSettings
instead ofParameters
(#3163) - Remove unused testutil.TempSocketName (#3291)
- Move BigEndian helper functions in
tracetranslator
to an internal package.(#3298) - Rename
configtest.LoadConfigFile
toconfigtest.LoadConfigAndValidate
(#3306) - Replace
ExtensionCreateParams
withExtensionCreateSettings
(#3294) - Replace
ProcessorCreateParams
withProcessorCreateSettings
. (#3181) - Replace
ExporterCreateParams
withExporterCreateSettings
(#3164) - Replace
ReceiverCreateParams
withReceiverCreateSettings
. (#3167) - Change
batchprocessor
logic to limit data points rather than metrics (#3141) - Rename
PrwExporter
toPRWExporter
andNewPrwExporter
toNewPRWExporter
(#3246) - Avoid exposing OpenCensus reference in public APIs (#3253)
- Move
config.Parser
toconfigparser.Parser
(#3304) - Remove deprecated funcs inside the obsreceiver (#3314)
- Remove
obsreport.GRPCServerWithObservabilityEnabled
, enable observability in config (#3315) - Remove
obsreport.ProcessorMetricViews
, useBuildProcessorCustomMetricName
where needed (#3316) - Remove "Receive" from
obsreport.Receiver
funcs (#3326) - Remove "Export" from
obsreport.Exporter
funcs (#3333) - Hide unnecessary public struct
obsreport.StartReceiveOptions
(#3353) - Avoid exposing internal implementation public in OC/OTEL receivers (#3355)
- Updated configgrpc
ToDialOptions
and confighttpToClient
apis to take extensions configuration map (#3340) - Remove
GenerateSequentialTraceID
andGenerateSequentialSpanIDin
functions in testbed (#3390) - Change "grpc" to "GRPC" in configauth function/type names (#3285)
- Add
doc.go
files to the consumer package and its subpackages (#3270) - Improve documentation of consumer package and subpackages (#3269, #3361)
- Automate triggering of doc-update on release (#3234)
- Enable Dependabot for Github Actions (#3312)
- Remove the proto dependency in
goldendataset
for traces (#3322) - Add telemetry for dropped data due to exporter sending queue overflow (#3328)
- Add initial implementation of
pdatagrcp
(#3231) - Change receiver obsreport helpers pattern to match the Processor/Exporter (#3227)
- Add model translation and encoding interfaces (#3200)
- Add otlpjson as a serializer implementation (#3238)
prometheus
receiver:- Add
createNodeAndResourcePdata
for Prometheus->OTLP pdata (#3139) - Direct metricfamily Prometheus->OTLP (#3145)
- Add
- Add
componenttest.NewNop*CreateSettings
to simplify tests (#3375) - Add support for markdown generation (#3100)
- Refactor components for the Client Authentication Extensions (#3287)
- Use dedicated
zapcore.Core
for Windows service (#3147) - Hook up start and shutdown functions in fileexporter (#3260)
- Fix oc to pdata translation for sum non-monotonic cumulative (#3272)
- Fix
timeseriesSignature
in prometheus receiver (#3310)
- Change
Marshal
signatures in kafkaexporter's Marshalers to directly convert pdata tosarama.ProducerMessage
(#3162) - Remove
tracetranslator.DetermineValueType
, only used internally by Zipkin (#3114) - Remove OpenCensus conventions, should not be used (#3113)
- Remove Zipkin specific translation constants, move to internal (#3112)
- Remove
tracetranslator.TagHTTPStatusCode
, useconventions.AttributeHTTPStatusCode
(#3111) - Remove OpenCensus status constants and transformation (#3110)
- Remove
tracetranslator.AttributeArrayToSlice
, not used in core or contrib (#3109) - Remove
internaldata.MetricsData
, same APIs as for traces (#3156) - Rename
config.IDFromString
toNewIDFromString
, removeMustIDFromString
(#3177) - Move consumerfanout package to internal (#3207)
- Canonicalize enum names in pdata. Fix usage of uppercase names (#3208)
- Use
config.ComponentID
for obsreport receiver/scraper (#3098) - Add initial implementation of the consumerhelper (#3146)
- Add Collector version to Prometheus Remote Write Exporter user-agent header (#3094)
- Refactor processorhelper to use consumerhelper, split by signal type (#3180)
- Use consumerhelper for exporterhelper, add WithCapabilities (#3186)
- Set capabilities for all core exporters, remove unnecessary funcs (#3190)
- Add an internal sharedcomponent to be shared by receivers with shared resources (#3198)
- Allow users to configure the Prometheus remote write queue (#3046)
- Mark internaldata traces translation as deprecated for external usage (#3176)
- Fix Prometheus receiver metric start time and reset determination logic. (#3047)
- The receiver will no longer drop the first sample for
counter
,summary
, andhistogram
metrics.
- The receiver will no longer drop the first sample for
- The Prometheus remote write exporter will no longer force
counter
metrics to have a_total
suffix. (#2993) - Remove locking from jaeger receiver start and stop processes (#3070)
- Fix batch processor metrics reorder, improve performance (#3034)
- Fix batch processor traces reorder, improve performance (#3107)
- Fix batch processor logs reorder, improve performance (#3125)
- Avoid one unnecessary allocation in grpc OTLP exporter (#3122)
batch
processor: Validate that batch config max size is greater than send size (#3126)- Add capabilities to consumer, remove from processor (#2770)
- Remove internal protos usage in Prometheusremotewrite exporter (#3184)
prometheus
receiver: Honor Prometheus external labels (#3127)- Validate that remote write queue settings are not negative (#3213)
- Change
With*Unmarshallers
signatures in Kafka exporter/receiver (#2973) - Rename
marshall
tomarshal
in all the occurrences (#2977) - Remove
componenterror.ErrAlreadyStarted
andcomponenterror.ErrAlreadyStopped
, components should not protect against this, Service will start/stop once. - Rename
ApplicationStartInfo
toBuildInfo
- Rename
ApplicationStartInfo.ExeName
toBuildInfo.Command
- Rename
ApplicationStartInfo.LongName
toBuildInfo.Description
- Add AppendEmpty and deprecate Append for slices (#2970)
kafka
exporter: Add logs support (#2943)- Update mdatagen to create factories of init instead of new (#2978)
zipkin
receiver: Reduce the judgment of zipkin v1 version (#2990)- Custom authenticator logic to accept a
component.Host
which will extract the authenticator to use based on a new authenticator name property (#2767) prometheusremotewrite
exporter: Addresource_to_telemetry_conversion
config option (#3031)logging
exporter: Extract OTLP text logging (#3082)- Format timestamps as strings instead of int in otlptext output (#3088)
- Add darwin arm64 build (#3090)
- Fix Jaeger receiver to honor TLS Settings (#2866)
zipkin
translator: Handle missing starttime case for zipkin json v2 format spans (#2506)prometheus
exporter: Fix OTEL resource label drops (#2899)prometheusremotewrite
exporter:- Enable the queue internally (#2974)
- Don't drop instance and job labels (#2979)
jaeger
receiver: Wait for server goroutines exit on shutdown (#2985)logging
exporter: Ignore invalid handle on close (#2994)- Fix service zpages (#2996)
batch
processor: Fix to avoid reordering and send max size (#3029)
- Rename ForEach (in pdata) with Range to be consistent with sync.Map (#2931)
- Rename
componenthelper.Start
tocomponenthelper.StartFunc
(#2880) - Rename
componenthelper.Stop
tocomponenthelper.StopFunc
(#2880) - Remove
exporterheleper.WithCustomUnmarshaler
,processorheleper.WithCustomUnmarshaler
,receiverheleper.WithCustomUnmarshaler
,extensionheleper.WithCustomUnmarshaler
, implementconfig.CustomUnmarshaler
interface instead (#2867) - Remove
component.CustomUnmarshaler
implementconfig.CustomUnmarshaler
interface instead (#2867) - Remove
testutil.HostPortFromAddr
, users can write their own parsing helper (#2919) - Remove
configparser.DecodeTypeAndName
, useconfig.IDFromString
(#2869) - Remove
config.NewViper
, users should useconfig.NewParser
(#2917) - Remove
testutil.WaitFor
, usetestify.Eventually
helper if needed (#2920) - Remove testutil.WaitForPort, users can use testify.Eventually (#2926)
- Rename
processorhelper.NewTraceProcessor
toprocessorhelper.NewTracesProcessor
(#2935) - Rename
exporterhelper.NewTraceExporter
toexporterhelper.NewTracesExporter
(#2937) - Remove InitEmptyWithCapacity, add EnsureCapacity and Clear (#2845)
- Rename traces methods/objects to include Traces in Kafka receiver (#2966)
- Add
validatable
interface withValidate()
to allconfig.<component>
(#2898)- add the empty
Validate()
implementation for all component configs
- add the empty
- Experimental: Add a config source manager that wraps the interaction with config sources (#2857, #2903, #2948)
kafka
exporter: Key jaeger messages on traceid (#2855)scraperhelper
: Don't try to count metrics if scraper returns an error (#2902)- Extract ConfigFactory in a ParserProvider interface (#2868)
prometheus
exporter: Allows Summary metrics to be exported to Prometheus (#2900)prometheus
receiver: OptimizedpgSignature
function (#2945)kafka
receiver: Add logs support (#2944)
prometheus
receiver:- Treat Summary and Histogram metrics without "_sum" counter as valid metric (#2812)
- Add
job
andinstance
as well-known labels (#2897)
prometheusremotewrite
exporter:- Sort Sample by Timestamp to avoid out of order errors (#2941)
- Remove incompatible queued retry (#2951)
kafka
receiver: Fix data race with batchprocessor (#2957)jaeger
receiver: Jaeger agent should not report ErrServerClosed (#2965)
- Remove legacy internal metrics for memorylimiter processor,
spans_dropped
andtrace_batches_dropped
(#2841)- For
spans_dropped
useprocessor/refused_spans
withprocessor=memorylimiter
- For
- Rename pdata..[Start|End]Time to pdata..[Start|End]Timestamp (#2847)
- Rename pdata.DoubleExemplar to pdata.Exemplar (#2804)
- Rename pdata.DoubleHistogram to pdata.Histogram (#2797)
- Rename pdata.DoubleSummary to pdata.Summary (#2774)
- Refactor
consumererror
package (#2768)- Remove
PartialError
type in favor of signal-specific types - Rename
CombineErrors()
toCombine()
- Remove
- Refactor
componenthelper
package (#2778)- Remove
ComponentSettings
andDefaultComponentSettings()
- Rename
NewComponent()
toNew()
- Remove
- obsReport.NewExporter accepts a settings struct (#2668)
- Remove ErrorWaitingHost from
componenttest
(#2582) - Move
config.Load
toconfigparser.Load
(#2796) - Remove
configtest.NewViperFromYamlFile()
, useconfig.Parser.NewParserFromFile()
(#2806) - Remove
config.ViperSubExact()
, useconfig.Parser.Sub()
(#2806) - Update LoadReceiver signature to remove unused params (#2823)
- Move
configerror.ErrDataTypeIsNotSupported
tocomponenterror.ErrDataTypeIsNotSupported
(#2886) - Rename
CreateTraceExporter
type toCreateTracesExporter
inexporterhelper
(#2779) - Move
fluentbit
extension to contrib (#2795) - Move
configmodels
toconfig
(#2808) - Move
fluentforward
receiver to contrib (#2723)
- Deprecate
consumetest.New[${SIGNAL}]Nop
in favor ofconsumetest.NewNop
(#2878) - Deprecate
consumetest.New[${SIGNAL}]Err
in favor ofconsumetest.NewErr
(#2878)
batch
processor: - Support max batch size for logs (#2736)- Use
Endpoint
for health check extension (#2782) - Use
confignet.TCPAddr
forpprof
andzpages
extensions (#2829) - Add watcher to values retrieved via config sources (#2803)
- Updates for cloud semantic conventions (#2809)
cloud.infrastructure_service
->cloud.platform
cloud.zone
->cloud.availability_zone
- Add systemd environment file for deb/rpm packages (#2822)
- Add validate interface in
configmodels
to force each component do configuration validation (#2802, #2856) - Add
aws.ecs.task.revision
to semantic conventions list (#2816) - Set unprivileged user to container image (#2838)
- Add New funcs for extension, exporter, processor config settings (#2872)
- Report metric about current size of the exporter retry queue (#2858)
- Allow adding new signals in
ProcessorFactory
by forcing everyone to embedBaseProcessorFactory
(#2885)
pdata.TracesFromOtlpProtoBytes
: Fixes to handle backwards compatibility changes in proto (#2798)jaeger
receiver: Escape user input used in output (#2815)prometheus
exporter: Ensure same time is used for updated time (#2745)prometheusremotewrite
exporter: Close HTTP response body (#2875)
- Move fanout consumers to fanoutconsumer package (#2615)
- Rename ExporterObsReport to Exporter (#2658)
- Rename ProcessorObsReport to Processor (#2657)
- Remove ValidateConfig and add Validate on the Config struct (#2665)
- Rename pdata Size to OtlpProtoSize (#2726)
- Rename [Traces|Metrics|Logs]Consumer to [Traces|Metrics|Logs] (#2761)
- Remove public access for
componenttest.Example*
components:- Users of these structs for testing configs should use the newly added
componenttest.Nop*
(update all components name in the configexample*
->nop
and usecomponenttest.NopComponents()
). - Users of these structs for sink like behavior should use
consumertest.*Sink
.
- Users of these structs for testing configs should use the newly added
hostmetrics
receiver: List labels along with respective metrics in metadata (#2662)exporter
helper: Remove obsreport.ExporterContext, always add exporter name as a tag to the metrics (#2682)jaeger
exporter: Change to not use internal data (#2698)kafka
receiver: Change to not use internal data (#2697)zipkin
receiver: Change to not use internal data (#2699)kafka
exporter: Change to not use internal data (#2696)- Ensure that extensions can be created and started multiple times (#2679)
- Use otlp request in logs wrapper, hide members in the wrapper (#2692)
- Add MetricsWrapper to dissallow access to internal representation (#2693)
- Add TracesWrapper to dissallow access to internal representation (#2721)
- Allow multiple OTLP receivers to be created (#2743)
prometheus
exporter: Fix to work with standard labels that follow the naming convention of using periods instead of underscores (#2707)- Propagate name and transport for
prometheus
receiver and exporter (#2680) zipkin
receiver: Ensure shutdown correctness (#2765)
- Rename ServiceExtension to just Extension (#2581)
- Remove
consumerdata.TraceData
(#2551) - Move
consumerdata.MetricsData
tointernaldata.MetricsData
(#2512) - Remove custom OpenCensus sematic conventions that have equivalent in otel (#2552)
- Move ScrapeErrors and PartialScrapeError to
scrapererror
(#2580) - Remove support for deprecated unmarshaler
CustomUnmarshaler
, onlyUnmarshal
is supported (#2591) - Remove deprecated componenterror.CombineErrors (#2598)
- Rename
pdata.TimestampUnixNanos
topdata.Timestamp
(#2549)
prometheus
exporter: Re-implement on top ofgithub.com/prometheus/client_golang/prometheus
and addmetric_expiration
optionlogging
exporter: Add support for AttributeMap (#2609)- Add semantic conventions for instrumentation library (#2602)
otlp
receiver: FixShutdown()
bug (#2564)batch
processor: Fix Shutdown behavior (#2537)logging
exporter: Fix handling the loop for empty attributes (#2610)prometheusremotewrite
exporter: Fix counter name check (#2613)
- Remove deprecated function
IsValid
from trace/span ID (#2522) - Remove accessors for deprecated status code (#2521)
otlphttp
exporter: Addcompression
option for gzip encoding of outgoing http requests (#2502)- Add
ScrapeErrors
struct toconsumererror
to simplify errors usage (#2414) - Add
cors_allowed_headers
option toconfighttp
(#2454) - Add SASL/SCRAM authentication mechanism on
kafka
receiver and exporter (#2503)
otlp
receiver: Sets the correct deprecated status code before sending data to the pipeline (#2521)- Fix
IsPermanent
to account for wrapped errors (#2455) otlp
exporter: Preserve original error messages (#2459)
- Rename
samplingprocessor/probabilisticsamplerprocessor
toprobabilisticsamplerprocessor
(#2392)
hostmetrics
receiver: Refactor to use metrics metadata utilities (#2405, #2406, #2421)- Add k8s.node semantic conventions (#2425)
- Remove deprecated
queued_retry
processor - Remove deprecated configs from
resource
processor:type
(set "opencensus.type" key in "attributes.upsert" map instead) andlabels
(use "attributes.upsert" instead).
hostmetrics
receiver: Refactor load metrics to use generated metrics (#2375)- Add uptime to the servicez debug page (#2385)
- Add new semantic conventions for AWS (#2365)
jaeger
exporter: Improve connection state logging (#2239)pdatagen
: Fix slice of values generated code (#2403)filterset
processor: Avoid returning always nil error in strict filterset (#2399)
- Rename host metrics according to metrics spec and rename
swap
scraper topaging
(#2311)
- Add check for
NO_WINDOWS_SERVICE
environment variable to force interactive mode on Windows (#2272) hostmetrics
receiver: Adddisk/weighted_io_time
metric (Linux only) (#2312)opencensus
exporter: Add queue-retry (#2307)filter
processor: Filter metrics using resource attributes (#2251)
fluentforward
receiver: Fix string conversions (#2314)- Fix zipkinv2 translation error tag handling (#2253)
- Default config environment variable expansion (#2231)
prometheusremotewrite
exporter: Add batched exports (#2249)memorylimiter
processor: Introduce soft and hard limits (#2250)
- Fix nits in pdata usage (#2235)
- Convert status to not be a pointer in the Span (#2242)
- Report the error from
pprof.StartCPUProfile
(#2263) - Rename
service.Application.SignalTestComplete
toShutdown
(#2277)
- Rename Push functions to be consistent across signals in
exporterhelper
(#2203)
- Change default OTLP/gRPC port number to 4317, also continue receiving on legacy port 55680 during transition period (#2104).
kafka
exporter: Add support for exporting metrics as otlp Protobuf. (#1966)- Move scraper helpers to its own
scraperhelper
package (#2185) - Add
componenthelper
package to help build components (#2186) - Remove usage of custom init/stop in
scraper
and use start/shutdown fromcomponent
(#2193) - Add more trace annotations, so zpages are more useful to determine failures (#2206)
- Add support to skip TLS verification (#2202)
- Expose non-nullable metric types (#2208)
- Expose non-nullable elements from slices of pointers (#2200)
- Change InstrumentationLibrary to be non-nullable (#2196)
- Add support for slices to non-pointers, use non-nullable AnyValue (#2192)
- Fix
--set
flag to work with{}
in configs (#2162)
- Remove legacy metrics, they were marked as legacy for ~12 months #2105
- Implement conversion between OpenCensus and OpenTelemetry Summary Metric (#2048)
- Add ability to generate non nullable messages (#2005)
- Implement Summary Metric in Prometheus RemoteWrite Exporter (#2083)
- Add
resource_to_telemetry_conversion
to exporter helper expose exporter settings (#2060) - Add
CustomRoundTripper
function to httpclientconfig (#2085) - Allow for more logging options to be passed to
service
(#2132) - Add config parameters for
jaeger
receiver (#2068) - Map unset status code for
jaegar
translator as per spec (#2134) - Add more trace annotations to the queue-retry logic (#2136)
- Add config settings for component telemetry (#2148)
- Use net.SplitHostPort for IPv6 support in
prometheus
receiver (#2154) - Add --log-format command line option (default to "console") #2177.
logging
exporter: Add Logging for Summary Datapoint (#2084)hostmetrics
receiver: use correct TCP state labels on Unix systems (#2087)- Fix otlp_log receiver wrong use of trace measurement (#2117)
- Fix "process/memory/rss" metric units (#2112)
- Fix "process/cpu_seconds" metrics (#2113)
- Add check for nil logger in exporterhelper functions (#2141)
prometheus
receiver:- Upgrade Prometheus version to fix race condition (#2121)
- Fix the scraper/discover manager coordination (#2089)
- Fix panic when adjusting buckets (#2168)
otlphttp
exporter which implements OTLP over HTTP protocol.
- Rename consumer.TraceConsumer to consumer.TracesConsumer #1974
- Rename component.TraceReceiver to component.TracesReceiver #1975
- Rename component.TraceProcessor to component.TracesProcessor #1976
- Rename component.TraceExporter to component.TracesExporter #1975
- Move
tailsampling
processor to contrib (#2012) - Remove NewAttributeValueSlice (#2028) and mark NewAttributeValue as deprecated (#2022)
- Remove pdata.StringValue (#2021)
- Remove pdata.InitFromAttributeMap, use CopyTo if needed (#2042)
- Remove SetMapVal and SetArrayVal for pdata.AttributeValue (#2039)
- Deprecate NopExporter, add NopConsumer (#1972)
- Deprecate SinkExporter, add SinkConsumer (#1973)
zipkin
exporter: Add queue retry to zipkin (#1971)prometheus
exporter: Addsend_timestamps
option (#1951)filter
processor: Addexpr
pdata.Metric filtering support (#1940, #1996)attribute
processor: Add log support (#1934)logging
exporter: Add index for histogram buckets count (#2009)otlphttp
exporter: Add correct handling of server error responses (#2016)prometheusremotewrite
exporter:- Add user agent header to outgoing http request (#2000)
- Convert histograms to cumulative (#2049)
- Return permanent errors (#2053)
- Add external labels (#2044)
hostmetrics
receiver: Use scraper controller (#1949)- Change Span/Trace ID to be byte array (#2001)
- Add
simple
metrics helper to facilitate building pdata.Metrics in receivers (#1540) - Improve diagnostic logging for exporters (#2020)
- Add obsreport to receiverhelper scrapers (#1961)
- Update OTLP to 0.6.0 and use the new Span Status code (#2031)
- Add support of partial requests for logs and metrics to the exporterhelper (#2059)
logging
exporter: Added array serialization (#1994)zipkin
receiver: Allow receiver to parse string tags (#1893)batch
processor: Fix shutdown race (#1967)- Guard for nil data points (#2055)
- Host metric
system.disk.time
renamed tosystem.disk.operation_time
(#1887) - Use consumer for sender interface, remove unnecessary receiver address from Runner (#1941)
- Enable sending queue by default in all exporters configured to use it (#1924)
- Removed
groupbytraceprocessor
(#1891) - Remove ability to configure collection interval per scraper (#1947)
- Host Metrics receiver now reports both
system.disk.io_time
andsystem.disk.operation_time
(#1887) - Match spans against the instrumentation library and resource attributes (#928)
- Add
receiverhelper
for creating flexible "scraper" metrics receiver (#1886, #1890, #1945, #1946) - Migrate
tailsampling
processor to new OTLP-based internal data model and add Composite Sampler (#1894) - Metadata Generator: Change Metrics fields to implement an interface with new methods (#1912)
- Add unmarshalling for
pdata.Traces
(#1948) - Add debug-level message on error for
jaeger
exporter (#1964)
- Fix bug where the service does not correctly start/stop the log exporters (#1943)
- Fix Queued Retry Unusable without Batch Processor (#1813) - (#1930)
prometheus
receiver: Log error message whenprocess_start_time_seconds
gauge is missing (#1921)- Fix trace jaeger conversion to internal traces zero time bug (#1957)
- Fix panic in otlp traces to zipkin (#1963)
- Fix OTLP/HTTP receiver's path to be /v1/traces (#1979)
configauth
package with the auth settings that can be used by receivers (#1807, #1808, #1809, #1810)perfcounters
package that uses perflib for host metrics receiver (#1835, #1836, #1868, #1869, #1870)
- Remove
queued_retry
and enableotlp
metrics receiver in default config (#1823, #1838) - Add
limit_percentage
andspike_limit_percentage
options tomemorylimiter
processor (#1622) hostmetrics
receiver:- Collect additional labels from partitions in the filesystems scraper (#1858)
- Add filters for mount point and filesystem type (#1866)
- Add cloud.provider semantic conventions (#1865)
attribute
processor: Add log support (#1783)- Introduce SpanID data type, not yet used in Protobuf messages ($1854, #1855)
- Enable
otlp
trace by default in the released docker image (#1883) tailsampling
processor: Combine batches of spans into a single batch (#1864)filter
processor: Update to use pdata (#1885)- Allow MSI upgrades (#1914)
- Deprecate OpenCensus-based internal data structures (#1843)
prometheus
receiver: Print a more informative message about 'up' metric value (#1826)- Use custom data type and custom JSON serialization for traceid (#1840)
- Skip creation of redundant nil resource in translation from OC if there are no combined metrics (#1803)
tailsampling
processor: Only send to next consumer once (#1735)- Report Windows pagefile usage in bytes (#1837)
- Fix issue where Prometheus SD config cannot be parsed (#1877)
- Rename service.Start() to Run() since it's a blocking call
- Fix slice Append to accept by value the element in pdata
- Change CreateTraceProcessor and CreateMetricsProcessor to use the same parameter order as receivers/logs processor and exporters.
- Prevent accidental use of LogsToOtlp and LogsFromOtlp and the OTLP data structs (#1703)
- Remove SetType from configmodels, ensure all registered factories set the type in config (#1798)
- Move process telemetry to service/internal (#1794)
- Add map and array attribute value type support (#1656)
- Add authentication support to kafka (#1632)
- Implement InstrumentationLibrary translation to jaeger (#1645)
- Add public functions to export pdata to ExportXServicesRequest Protobuf bytes (#1741)
- Expose telemetry level in the configtelemetry (#1796)
- Add configauth package (#1807)
- Add config to docker image (#1792)
- Use zap int argument for int values instead of conversion (#1779)
- Add support for gzip encoded payload in OTLP/HTTP receiver (#1581)
- Return proto status for OTLP receiver when failed (#1788)
- Update OTLP to v0.5.0, incompatible metrics protocol.
- Remove support for propagating summary metrics in OtelCollector.
- This is a temporary change, and will affect mostly OpenCensus users who use metrics.
- Support zipkin proto in
kafka
receiver (#1646) - Prometheus Remote Write Exporter supporting Cortex (#1577, #1643)
- Add deployment environment semantic convention (#1722)
- Add logs support to
batch
andresource
processors (#1723, #1729)
- Identify config error when expected map is other value type (#1641)
- Fix Kafka receiver closing ready channel multiple times (#1696)
- Fix a panic issue while processing Zipkin spans with an empty service name (#1742)
- Zipkin Receiver: Always set the endtime (#1750)
- Remove old base factories:
ReceiverFactoryBase
(#1583)ProcessorFactoryBase
(#1596)ExporterFactoryBase
(#1630)
- Remove logs factories and merge with normal factories (#1569)
- Remove
reconnection_delay
from OpenCensus exporter (#1516) - Remove
ConsumerOld
interfaces (#1631)
prometheusremotewrite
exporter: Send metrics data in Prometheus TimeSeries format to Cortex or any Prometheus (#1544)kafka
receiver: Receive traces from Kafka (#1410)
kafka
exporter: Enable queueing, retry, timeout (#1455)- Add
Headers
field in HTTPClientSettings (#1552) - Change OpenCensus receiver (#1556) and exporter (#1571) to the new interfaces
- Add semantic attribute for
telemetry.auto.version
(#1578) - Add uptime and RSS memory self-observability metrics (#1549)
- Support conversion for OpenCensus
SameProcessAsParentSpan
(#1629) - Access application version in components (#1559)
- Make Kafka payload encoding configurable (#1584)
- Stop further processing if
filterprocessor
filters all data (#1500) processscraper
: Use same scrape time for all data points coming from same process (#1539)- Ensure that time conversion for 0 returns nil timestamps or Time where IsZero returns true (#1550)
- Fix multiple exporters panic (#1563)
- Allow
attribute
processor for external use (#1574) - Do not duplicate filesystem metrics for devices with many mount points (#1617)
groupbytrace
processor that waits for a trace to be completed (#1362)
- Migrate
zipkin
receiver/exporter to the new interfaces (#1484) - Migrate
prometheus
receiver/exporter to the new interfaces (#1477, #1515) - Add new FactoryUnmarshaler support to all components, deprecate old way (#1468)
- Update
fileexporter
to write data in OTLP (#1488) - Add extension factory helper (#1485)
- Host scrapers: Use same scrape time for all data points coming from same source (#1473)
- Make logs SeverityNumber publicly available (#1496)
- Add recently included conventions for k8s and container resources (#1519)
- Add new config StartTimeMetricRegex to
prometheus
receiver (#1511) - Convert Zipkin receiver and exporter to use OTLP (#1446)
- Infer OpenCensus resource type based on OpenTelemetry's semantic conventions (#1462)
- Fix log adapter in
prometheus
receiver (#1493) - Avoid frequent errors for process telemetry on Windows (#1487)
- Receivers
fluentfoward
runs a TCP server that accepts events via the Fluent Forward protocol (#1173)
- Exporters
kafka
exports traces to Kafka (#1439)
- Extensions
- Experimental
fluentbit
facilitates running a FluentBit subprocess of the collector (#1381)
- Experimental
- Updated
golang/protobuf
from v1.3.5 to v1.4.2 (#1308) - Updated
opencensus-proto
from v0.2.1 to v0.3.0 (#1308) - Added round_robin
balancer_name
as an option to gRPC client settings (#1353) hostmetrics
receiver- Switch to using perf counters to get disk io metrics on Windows (#1340)
- Add device filter for file system (#1379) and disk (#1378) scrapers
- Record process physical & virtual memory stats separately (#1403)
- Scrape system.disk.time on Windows (#1408)
- Add disk.pending_operations metric (#1428)
- Add network interface label to network metrics (#1377)
- Add
exporterhelper
(#1351) andprocessorhelper
(#1359) factories - Update OTLP to latest version (#1384)
- Disable timeout, retry on failure and sending queue for
logging
exporter (#1400) - Add support for retry and sending queue for
jaeger
exporter (#1401) - Add batch size bytes metric to
batch
processor (#1270) otlp
receiver: Add Log Support (#1444)- Allow to configure read/write buffer sizes for http Client (#1447)
- Update DB conventions to latest and add exception conventions (#1452)
- Fix
resource
processor for old metrics (#1412) jaeger
receiver: Do not try to stop if failed to start. Collector service will do that (#1434)
- Renamed the metrics generated by
hostmetrics
receiver to match the (currently still pending) OpenTelemetry system metric conventions (#1261) (#1269) - Removed
vmmetrics
receiver (#1282) - Removed
cpu
scraperreport_per_cpu
config option (#1326)
- Added disk merged (#1267) and process count (#1268) metrics to
hostmetrics
- Log metric data points in
logging
exporter (#1258) - Changed the
batch
processor to not ignore the errors returned by the exporters (#1259) - Build and publish MSI (#1153) and DEB/RPM packages (#1278, #1335)
- Added batch size metric to
batch
processor (#1241) - Added log support for
memorylimiter
processor (#1291) andlogging
exporter (#1298) - Always add tags for
observability
, other metrics may use them (#1312) - Added metrics support (#1313) and allow partial retries in
queued_retry
processor (#1297) - Update
resource
processor: introduceattributes
config parameter to specify actions on attributes similar toattributes
processor, old config interface is deprecated (#1315) - Update memory state labels for non-Linux OSs (#1325)
- Ensure tcp connection value is provided for all states, even when count is 0 (#1329)
- Set
batch
processor channel size to num cpus (#1330) - Add
send_batch_max_size
config parameter tobatch
processor enforcing hard limit on batch size (#1310) - Add support for including a per-RPC authentication to gRPC settings (#1250)
- Fixed OTLP waitForReady, not set from config (#1254)
- Fixed all translation diffs between OTLP and Jaeger (#1222)
- Disabled
process
scraper for any non Linux/Windows OS (#1328)
- Update OTLP to v0.4.0 (#1142): Collector will be incompatible with any other sender or receiver of OTLP protocol of different versions
- Make "--new-metrics" command line flag the default (#1148)
- Change
endpoint
tourl
in Zipkin exporter config (#1186) - Change
tls_credentials
totls_settings
in Jaegar receiver config (#1233) - OTLP receiver config change for
protocols
to support mTLS (#1223) - Remove
export_resource_labels
flag from Zipkin exporter (#1163)
- Receivers
- Added process scraper to the
hostmetrics
receiver (#1047)
- Added process scraper to the
- otlpexporter: send configured headers in request (#1130)
- Enable Collector to be run as a Windows service (#1120)
- Add config for HttpServer (#1196)
- Allow cors in HTTPServerSettings (#1211)
- Add a generic grpc server settings config, cleanup client config (#1183)
- Rely on gRPC to batch and loadbalance between connections instead of custom logic (#1212)
- Allow to tune the read/write buffers for gRPC clients (#1213)
- Allow to tune the read/write buffers for gRPC server (#1218)
- Handle overlapping metrics from different jobs in prometheus exporter (#1096)
- Fix handling of SpanKind INTERNAL in OTLP OC translation (#1143)
- Unify zipkin v1 and v2 annotation/tag parsing logic (#1002)
- mTLS: Add support to configure client CA and enforce ClientAuth (#1185)
- Fixed untyped Prometheus receiver bug (#1194)
- Do not embed ProtocolServerSettings in gRPC (#1210)
- Add Context to the missing CreateMetricsReceiver method (#1216)
Released 2020-06-16
isEnabled
configuration option removed (#909)thrift_tchannel
protocol moved fromjaeger
receiver tojaeger_legacy
in contrib (#636)
- Switch from
localhost
to0.0.0.0
by default for all receivers (#1006) - Internal API Changes (only impacts contributors)
- Add context to
Start
andStop
methods in the component (#790) - Rename
AttributeValue
andAttributeMap
method names (#781) (other breaking changes in the internal trace data types) - Change entire repo to use the new vanityurl go.opentelemetry.io/collector (#977)
- Add context to
- Receivers
hostmetrics
receiver with CPU (#862), disk (#921), load (#974), filesystem (#926), memory (#911), network (#930), and virtual memory (#989) support
- Processors
batch
for batching received metrics (#1060)filter
for filtering (dropping) received metrics (#1001)
otlp
receiver implement HTTP X-Protobuf (#1021)- Exporters: Support mTLS in gRPC exporters (#927)
- Extensions: Add
zpages
for service (servicez, pipelinez, extensions) (#894)
- Add missing logging for metrics at
debug
level (#1108) - Fix setting internal status code in
jaeger
receivers (#1105) zipkin
export fails on span without timestamp when used withqueued_retry
(#1068)- Fix
zipkin
receiver status code conversion (#996) - Remove extra send/receive annotations with using
zipkin
v1 (#960) - Fix resource attribute mutation bug when exporting in
jaeger
proto (#907) - Fix metric/spans count, add tests for nil entries in the slices (#787)
Receivers | Processors | Exporters |
---|---|---|
Jaeger | Attributes | File |
OpenCensus | Batch | Jaeger |
OTLP | Memory Limiter | Logging |
Zipkin | Queued Retry | OpenCensus |
Resource | OTLP | |
Sampling | Zipkin | |
Span |
Receivers | Processors | Exporters |
---|---|---|
HostMetrics | Batch | File |
OpenCensus | Filter | Logging |
OTLP | Memory Limiter | OpenCensus |
Prometheus | OTLP | |
VM Metrics | Prometheus |
- Health Check
- Performance Profiler
- zPages
Released 2020-03-30
- Make prometheus receiver config loading strict. #697 Prometheus receiver will now fail fast if the config contains unused keys in it.
- Enable best effort serve by default of Prometheus Exporter (orijtech/prometheus-go-metrics-exporter#6)
- Fix null pointer exception in the logging exporter #743
- Remove unnecessary condition to have at least one processor #744
Receivers / Exporters | Processors | Extensions |
---|---|---|
Jaeger | Attributes | Health Check |
OpenCensus | Batch | Performance Profiler |
OpenTelemetry | Memory Limiter | zPages |
Zipkin | Queued Retry | |
Resource | ||
Sampling | ||
Span |
Alpha v0.2.8 of OpenTelemetry Collector
- Implemented OTLP receiver and exporter.
- Added ability to pass config to the service programmatically (useful for custom builds).
- Improved own metrics / observability.
- Refactored component and factory interface definitions (breaking change #683)
Alpha v0.2.7 of OpenTelemetry Collector
- Improved error handling on shutdown
- Partial implementation of new metrics (new obsreport package)
- Include resource labels for Zipkin exporter
- New
HASH
action to attribute processor
Alpha v0.2.6 of OpenTelemetry Collector.
- Update metrics prefix to
otelcol
and expose command line argument to modify the prefix value. - Extend Span processor to have include/exclude span logic.
- Batch dropped span now emits zero when no spans are dropped.
Alpha v0.2.5 of OpenTelemetry Collector.
- Regexp-based filtering of spans based on service names.
- Ability to choose strict or regexp matching for include/exclude filters.
Alpha v0.2.4 of OpenTelemetry Collector.
- Regexp-based filtering of span names.
- Ability to extract attributes from span names and rename span.
- File exporter for debugging.
- Span processor is now enabled by default.
Alpha v0.2.3 of OpenTelemetry Collector.
Changes: 21a70d6 Add a memory limiter processor (#498) 9778b16 Refactor Jaeger Receiver config (#490) ec4ad0c Remove workers from OpenCensus receiver implementation (#497) 4e01fa3 Update k8s config to use opentelemetry docker image and configuration (#459)
Alpha v0.2.2 of OpenTelemetry Collector.
Main changes visible to users since previous release:
- Improved Testbed and added more E2E tests.
- Made component interfaces more uniform (this is a breaking change).
Note: v0.2.1 never existed and is skipped since it was tainted in some dependencies.
Alpha v0.2 of OpenTelemetry Collector.
Docker image: omnition/opentelemetry-collector:v0.2.0 (we are working on getting this under an OpenTelemetry org)
Main changes visible to users since previous release:
-
Rename from
service
tocollector
, the binary is now namedotelcol
-
Configuration reorganized and using strict mode
-
Concurrency issues for pipelines transforming data addressed
Commits:
0e505d5 Refactor config: pipelines now under service (#376)
402b80c Add Capabilities to Processor and use for Fanout cloning decision (#374)
b27d824 Use strict mode to read config (#375)
d769eb5 Fix concurrency handling when data is fanned out (#367)
dc6b290 Rename all github paths from opentelemtry-service to opentelemetry-collector (#371)
d038801 Rename otelsvc to otelcol (#365)
c264e0e Add Include/Exclude logic for Attributes Processor (#363)
8ce427a Pin a commit for Prometheus dependency in go.mod (#364)
2393774 Bump Jaeger version to 1.14.0 (latest) (#349)
63362d5 Update testbed modules (#360)
c0e2a27 Change dashes to underscores to separate words in config files (#357)
7609eaa Rename OpenTelemetry Service to Collector in docs and comments (#354)
bc5b299 Add common gRPC configuration settings (#340)
b38505c Remove network access popups on macos (#348)
f7727d1 Fixed loop variable pointer bug in jaeger translator (#341)
958beed Ensure that ConsumeMetricsData() is not passed empty metrics in the Prometheus receiver (#345)
0be295f Change log statement in Prometheus receiver from info to debug. (#344)
d205393 Add Owais to codeowners (#339)
8fa6afe Translate OC resource labels to Jaeger process tags (#325)
Alpha release of OpenTelemetry Service.
Docker image: omnition/opentelemetry-service:v0.0.2 (we are working on getting this under an OpenTelemetry org)
Main changes visible to users since previous release:
8fa6afe Translate OC resource labels to Jaeger process tags (#325)
047b0f3 Allow environment variables in config (#334)
96c24a3 Add exclude/include spans option to attributes processor (#311)
4db0414 Allow metric processors to be specified in pipelines (#332)
c277569 Add observability instrumentation for Prometheus receiver (#327)
f47aa79 Add common configuration for receiver tls (#288)
a493765 Refactor extensions to new config format (#310)
41a7afa Add Span Processor logic
97a71b3 Use full name for the metrics and spans created for observability (#316)
fed4ed2 Add support to record metrics for metricsexporter (#315)
5edca32 Add include_filter configuration to prometheus receiver (#298)
0068d0a Passthrough CORS allowed origins (#260)
This is the first alpha release of OpenTelemetry Service.
Docker image: omnition/opentelemetry-service:v0.0.1