connector/servicegraphconnector/connector.go (7 lines): - line 492: // TODO: Support other aggregation temporalities - line 514: // TODO: Support other aggregation temporalities - line 536: // TODO: Remove this once legacy metric names are removed - line 556: // TODO: Support other aggregation temporalities - line 569: // TODO: Support exemplars - line 589: // TODO: Support other aggregation temporalities - line 602: // TODO: Support exemplars pkg/translator/prometheusremotewrite/metrics_to_prw_v2.go (7 lines): - line 36: // TODO handle conflicts - line 61: // TODO: decide if instrumentation library information should be exported as labels - line 93: // TODO implement - line 95: // TODO implement - line 97: // TODO implement - line 103: // TODO implement - line 122: // TODO: Read the PRW spec to see if labels need to be sorted. If it is, then we need to sort in export code. If not, we can sort in the test. (@dashpole have more context on this) processor/redactionprocessor/processor.go (5 lines): - line 53: // TODO: Placeholder for an error metric in the next PR - line 58: // TODO: Placeholder for an error metric in the next PR - line 64: // TODO: Placeholder for an error metric in the next PR - line 194: // TODO: Use the context for recording metrics - line 369: // TODO: Placeholder for an error metric in the next PR cmd/opampsupervisor/supervisor/supervisor.go (4 lines): - line 139: // TODO: store this persistently so that when starting we can compose the effective - line 251: // TODO currently we do not have the build info containing the version available to set semconv.AttributeServiceVersion - line 680: // TODO: https://github.com/open-telemetry/opentelemetry-collector-contrib/issues/21079 - line 1418: // TODO: decide why the agent stopped. If it was due to bad config, report it to server. receiver/prometheusreceiver/internal/metrics_adjuster.go (4 lines): - line 349: // TODO: Investigate why this does not reset. - line 401: // TODO: Investigate why this does not reset. - line 446: // TODO: Investigate why this does not reset. - line 491: // TODO: Investigate why this does not reset. pkg/translator/zipkin/zipkinthriftconverter/to_domain.go (4 lines): - line 53: // TODO move to domain model - line 57: // TODO move to domain model - line 65: // TODO consider using different return type instead of `error`. - line 73: // TODO consider using different return type instead of `error`. processor/metricstarttimeprocessor/internal/truereset/adjuster.go (4 lines): - line 107: // TODO: Investigate why this does not reset. - line 144: // TODO: Investigate why this does not reset. - line 175: // TODO: Investigate why this does not reset. - line 207: // TODO: Investigate why this does not reset. processor/datadogsemanticsprocessor/processor.go (3 lines): - line 118: // TODO import this from datadog-agent pending https://github.com/DataDog/datadog-agent/pull/33753 - line 150: // TODO (OTEL-1791) Remove this and use a map from status code to status text. - line 161: // TODO remove once Status2Error is imported from datadog-agent pkg/translator/opencensus/traces_to_oc.go (3 lines): - line 25: // TODO: move this function to OpenCensus package. - line 37: // TODO: Handle instrumentation library name and version. - line 269: // TODO: Find a better way to check for message_event. Maybe use the event.Name. exporter/splunkhecexporter/factory.go (3 lines): - line 32: // TODO: Find a place for this to be shared. - line 38: // TODO: Find a place for this to be shared. - line 44: // TODO: Find a place for this to be shared. exporter/azuremonitorexporter/trace_to_envelope.go (3 lines): - line 555: // TODO Understand how to map attributes to RequestData fields - line 570: // TODO Understand how to map attributes to RemoteDependencyData fields - line 772: // TODO error handling exporter/otelarrowexporter/otelarrow.go (3 lines): - line 219: // TODO: These should be counted, similar to dropped items. - line 241: // TODO: These should be counted, similar to dropped items. - line 263: // TODO: These should be counted, similar to dropped items. internal/coreinternal/attraction/attraction.go (3 lines): - line 153: // TODO https://go.opentelemetry.io/collector/issues/296 - line 289: // TODO https://go.opentelemetry.io/collector/issues/296 - line 374: // TODO: Warn about unexpected attribute types. receiver/k8slogreceiver/runtime_api_config.go (2 lines): - line 87: // TODO implement me - line 118: // TODO implement me receiver/githubreceiver/model.go (2 lines): - line 119: // TODO: Evaluate if there is a need to truncate long workflow files names. - line 327: // TODO: Support enterpise server configuration with custom domain. receiver/prometheusremotewritereceiver/receiver.go (2 lines): - line 379: // TODO: Implement this function - line 383: // TODO: Implement this function pkg/translator/zipkin/zipkinv2/to_translator.go (2 lines): - line 441: // TODO: Find a way to avoid this duplicate code. Consider to expose this in pdata. - line 462: // TODO: Find a way to avoid this duplicate code. Consider to expose this in pdata. exporter/elasticsearchexporter/internal/serializer/otelserializer/metrics.go (2 lines): - line 70: // TODO here's potential for more optimization by directly serializing the value instead of allocating a pcommon.Value - line 81: // TODO: support quantiles pkg/translator/prometheusremotewrite/histograms.go (2 lines): - line 73: // TODO: using created time stamp should be accurate, but we - line 81: // TODO use zero_threshold, if set, see extension/jaegerremotesampling/internal/source/filesource/filesource.go (2 lines): - line 204: // TODO good candidate for a global util function - line 342: // TODO OperationSamplingStrategy only supports probabilistic sampling receiver/receivercreator/observerhandler.go (2 lines): - line 54: // TODO: Should keep track of which receiver the error is associated with - line 140: // TODO: optimize to only restart if effective config has changed. receiver/datadogreceiver/internal/translator/series.go (2 lines): - line 136: dimensions.resourceAttrs.PutStr("source", serie.SourceTypeName) // TODO: check if this is correct handling of SourceTypeName field - line 147: metric.Sum().SetAggregationTemporality(pmetric.AggregationTemporalityDelta) // TODO: verify that this is always the case exporter/otelarrowexporter/internal/arrow/bestofn.go (2 lines): - line 74: // TODO It's not clear if/when the prioritizer can - line 150: // TODO: skip channels w/ a pending item (maybe) processor/geoipprocessor/geoip_processor.go (2 lines): - line 60: // TODO: propagate an error once error_mode configuration option is available (e.g. transformprocessor) - line 95: // TODO: log IP error not found pkg/translator/azurelogs/resourcelogs_to_logs.go (2 lines): - line 27: // TODO: Remove once these are available in semconv - line 230: // TODO: check if this is a valid JSON string and parse it? receiver/pulsarreceiver/pulsar_receiver.go (2 lines): - line 95: // TODO: Ensure returned errors are handled - line 209: // TODO: Ensure returned errors are handled receiver/huaweicloudcesreceiver/receiver.go (2 lines): - line 83: // TODO: Improve error handling for client-server interactions - line 187: // TODO: Implement deduplication: There may be a need for deduplication, possibly using a Processor to ensure unique metrics are processed. receiver/awsfirehosereceiver/metrics_receiver.go (2 lines): - line 69: // TODO: make cwmetrics an encoding extension - line 72: // TODO: make otlp_v1 an encoding extension exporter/signalfxexporter/exporter.go (2 lines): - line 30: // TODO: Find a place for this to be shared. - line 36: // TODO: Find a place for this to be shared. pkg/translator/zipkin/zipkinv1/thrift.go (2 lines): - line 56: // TODO: (@pjanotti) ideally we should error here instead of generating invalid Traces - line 179: // TODO: (@pjanotti) add reference to OpenTracing and change related tags to use them receiver/redisreceiver/config.go (2 lines): - line 20: // TODO: Use one of the configs from core. - line 24: // TODO allow users to add additional resource key value pairs? processor/resourcedetectionprocessor/internal/aws/elasticbeanstalk/elasticbeanstalk.go (2 lines): - line 57: // TODO: Log a more specific message with zap - line 66: // TODO: Log a more specific error with zap testbed/testbed/validator.go (2 lines): - line 125: // TODO: Fix Jaeger span links attributes and tracestate. - line 168: // TODO: Remove this hack, and add a way to retrieve all sent data. receiver/prometheusreceiver/internal/transaction.go (2 lines): - line 368: // TODO: implement this func - line 541: // TODO: implement this func receiver/sqlserverreceiver/factory.go (2 lines): - line 118: // TODO: Test if this needs to be re-defined for each scraper - line 159: // TODO: Test if this needs to be re-defined for each scraper receiver/receivercreator/rules.go (2 lines): - line 34: // TODO: Try validating against bytecode instead. - line 38: // TODO: Maybe use https://godoc.org/github.com/expr-lang/expr#Env in type checking pkg/translator/signalfx/to_metrics.go (2 lines): - line 35: // TODO: Log or metric for this odd ball? - line 120: // TODO: Log or metric for this odd ball? receiver/receivercreator/discovery.go (2 lines): - line 55: // TODO: Log receiver configurations are only created for Pod Container Endpoints. - line 244: // with . in case of Port event or # TODO: . in case of Pod Container event receiver/k8slogreceiver/config.go (2 lines): - line 29: // TODO: refactor fileconsumer and add it's config of k8s implementation here. - line 35: // TODO: supported metadata fields and default values. extension/observer/hostobserver/extension.go (2 lines): - line 122: // TODO: Move this field to observer.Endpoint and - line 166: // TODO: Move this field to observer.Endpoint and receiver/kubeletstatsreceiver/internal/kubelet/volume.go (2 lines): - line 26: // TODO: Support more types - line 50: // TODO: Support more types receiver/splunkhecreceiver/receiver.go (2 lines): - line 126: // TODO: Evaluate what properties should be configurable, for now - line 175: // TODO: Evaluate what properties should be configurable, for now exporter/elasticsearchexporter/bulkindexer.go (2 lines): - line 154: // TODO acquire docappender.BulkIndexer from pool in StartSession, release here - line 177: backoff := retryBackoff(attempts + 1) // TODO: use exporterhelper retry_sender receiver/opencensusreceiver/internal/octrace/opencensus.go (2 lines): - line 23: receiverTransport = "grpc" // TODO: transport is being hard coded for now, investigate if info is available on context. - line 57: // TODO: Implement when we define the config receiver/sender. receiver/googlecloudmonitoringreceiver/receiver.go (2 lines): - line 318: // TODO: Add support for HISTOGRAM - line 319: // TODO: Add support for EXPONENTIAL_HISTOGRAM pkg/translator/prometheusremotewrite/number_data_points_v2.go (2 lines): - line 78: // TODO: properly add exemplars to the TimeSeries - line 103: // TODO append labels to promExemplar.Labels processor/k8sattributesprocessor/internal/kube/client.go (2 lines): - line 289: // TODO: update or remove based on whether container is ready/unready?. - line 1111: // TODO hard coding the timeout for now, check if we should make this configurable exporter/opensearchexporter/logger.go (2 lines): - line 48: // TODO: introduce setting log the bodies for more detailed debug logs - line 54: // TODO: introduce setting log the bodies for more detailed debug logs exporter/splunkhecexporter/logdata_to_splunk.go (1 line): - line 61: // TODO: remove this once HecToOtelAttrs is removed from Config. cmd/opampsupervisor/supervisor/supervisor_windows.go (1 line): - line 161: // TODO: If supervisor logging becomes configurable, update this function to respect that config receiver/carbonreceiver/metadata.yaml (1 line): - line 13: # TODO: Update the exporter to pass the tests extension/observer/dockerobserver/metadata.yaml (1 line): - line 11: # TODO: The tests are not passing on Windows. Either fix them or mark component as not supported on Windows. exporter/signalfxexporter/dpclient.go (1 line): - line 137: // TODO: Mark errors as partial errors wherever applicable when, partial exporter/carbonexporter/metricdata_to_plaintext.go (1 line): - line 98: // TODO: log error info processor/k8sattributesprocessor/options.go (1 line): - line 28: // TODO: use k8s.cluster.uid, container.image.repo_digests extension/observer/ecstaskobserver/metadata.yaml (1 line): - line 12: # TODO: Update the extension to make the tests pass pkg/translator/opencensus/metrics_to_oc.go (1 line): - line 40: // TODO: Handle instrumentation library name and version. processor/geoipprocessor/internal/convention/attributes.go (1 line): - line 6: // TODO: replace for semconv once https://github.com/open-telemetry/semantic-conventions/issues/1033 is closed. extension/observer/ecsobserver/config.go (1 line): - line 45: // TODO: https://github.com/open-telemetry/opentelemetry-collector-contrib/issues/3188 exporter/prometheusremotewriteexporter/wal.go (1 line): - line 66: // TODO: Perhaps log that the WAL wasn't enabled. cmd/opampsupervisor/supervisor/healthchecker/healthchecker.go (1 line): - line 13: // TODO: Support more settings receiver/k8sclusterreceiver/internal/node/nodes.go (1 line): - line 108: // TODO: Generate a schema URL for the node metrics in the metadata package and use them here. processor/metricstransformprocessor/metrics_transform_processor_otlp.go (1 line): - line 251: // TODO: report via trace / metric instead exporter/awsxrayexporter/internal/translator/cause.go (1 line): - line 24: // TODO: Remove this when collector defines this semantic convention. exporter/otelarrowexporter/internal/arrow/stream.go (1 line): - line 370: // timeout. TODO: possibly, improve to wait for no outstanding requests and then stop reading. receiver/awsxrayreceiver/internal/translator/translator.go (1 line): - line 24: // TODO: It might be nice to consolidate the `fromPdata` in x-ray exporter and internal/kafka/configkafka/config.go (1 line): - line 310: // TODO validate c.AWSMSK exporter/sumologicexporter/metadata.yaml (1 line): - line 12: # TODO: Update the exporter to pass the tests processor/routingprocessor/traces.go (1 line): - line 79: // TODO: determine the proper action when errors happen exporter/tencentcloudlogserviceexporter/metadata.yaml (1 line): - line 12: # TODO: Update the exporter to pass the tests connector/servicegraphconnector/factory.go (1 line): - line 37: // TODO: Remove this feature gate when the legacy metric names are removed. processor/spanprocessor/factory.go (1 line): - line 29: // TODO https://github.com/open-telemetry/opentelemetry-collector/issues/215 receiver/awsxrayreceiver/metadata.yaml (1 line): - line 11: # TODO: Update the receiver to make the tests pass pkg/translator/jaeger/traces_to_jaegerproto.go (1 line): - line 372: // TODO Bring this inline with solution for jaegertracing/jaeger-client-java #702 once available exporter/elasticsearchexporter/metric_grouping.go (1 line): - line 35: // TODO use https://github.com/open-telemetry/opentelemetry-collector-contrib/tree/main/internal/exp/metrics/identity receiver/githubreceiver/trace_event_handling.go (1 line): - line 84: // TODO: Determine if this is the best hashing algorithm to use. This is receiver/awsxrayreceiver/internal/translator/sdk.go (1 line): - line 24: // TODO: Update this once the exporter is more flexible processor/sumologicprocessor/aggregate_attributes_processor.go (1 line): - line 127: // TODO: Potential name conflict to resolve, eg.: pkg/stanza/fileconsumer/internal/trie/trie.go (1 line): - line 40: // TODO []byte, T value parameters processor/deltatocumulativeprocessor/config.go (1 line): - line 39: // TODO: find good default pkg/stanza/fileconsumer/config.go (1 line): - line 91: PollsToArchive int `mapstructure:"-"` // TODO: activate this config once archiving is set up exporter/kineticaexporter/metadata.yaml (1 line): - line 13: # TODO: Update the exporter to pass the tests processor/schemaprocessor/internal/translation/revision_v1.go (1 line): - line 98: // TODO: Implement split pkg/translator/skywalking/skywalkingproto_to_traces.go (1 line): - line 113: // TODO: SegmentReference references usually have only one element, but in batch consumer case, such as in MQ or async batch process, it could be multiple. extension/observer/ecsobserver/metadata.yaml (1 line): - line 12: # TODO: Update the extension to make the tests pass receiver/azureblobreceiver/metadata.yaml (1 line): - line 11: # TODO: Update the exporter to pass the tests exporter/stefexporter/config.go (1 line): - line 56: // TODO: move this to configgrpc.ClientConfig to avoid this code duplication (copied from OTLP exporter). extension/azureauthextension/extension.go (1 line): - line 161: // TODO Cache the tokens receiver/opencensusreceiver/internal/ocmetrics/opencensus.go (1 line): - line 52: receiverTransport = "grpc" // TODO: transport is being hard coded for now, investigate if info is available on context. processor/schemaprocessor/internal/translation/cacheable_provider.go (1 line): - line 40: // TODO make cache configurable receiver/awscontainerinsightreceiver/internal/stores/servicestore.go (1 line): - line 82: // TODO handle serviceNames len is larger than 1. We need to duplicate the metric object pkg/ottl/ottlfuncs/func_limit.go (1 line): - line 77: // TODO: Write log when limiting is performed internal/coreinternal/metricstestutil/metric_diff.go (1 line): - line 201: // TODO: HasSum, Min, HasMin, Max, HasMax are not covered in tests. exporter/awss3exporter/internal/upload/partition.go (1 line): - line 43: // TODO: Expose the ability to config additional UniqueKeyField via config extension/sumologicextension/metadata.yaml (1 line): - line 12: # TODO: Update the extension to make the tests pass pkg/translator/signalfx/from_metrics.go (1 line): - line 59: // TODO: Remove this and change signalfxexporter to us FromMetrics. receiver/awsxrayreceiver/receiver.go (1 line): - line 84: // TODO: Might want to pass `host` into read() below to report a fatal error pkg/translator/jaeger/jaegerproto_to_traces.go (1 line): - line 434: // TODO Bring this inline with solution for jaegertracing/jaeger-client-java #702 once available pkg/translator/opencensus/oc_to_traces.go (1 line): - line 24: // TODO: move this function to OpenCensus package. connector/signaltometricsconnector/internal/aggregator/explicithistogram.go (1 line): - line 59: // TODO determine appropriate start time processor/redactionprocessor/factory.go (1 line): - line 46: // TODO: Placeholder for an error metric in the next PR testbed/testbed/receivers.go (1 line): - line 41: // TODO: Move these constants. exporter/signalfxexporter/internal/hostmetadata/host.go (1 line): - line 91: // TODO: This is not ideal... if there are different processors receiver/osqueryreceiver/metadata.yaml (1 line): - line 10: # TODO: Update the receiver to pass the tests exporter/datasetexporter/metadata.yaml (1 line): - line 11: # TODO: Update the exporter to pass the tests receiver/kafkareceiver/kafka_receiver.go (1 line): - line 34: // TODO: update the following attributes to reflect semconv receiver/chronyreceiver/metadata.yaml (1 line): - line 77: # TODO: Update the exporter to pass the tests connector/routingconnector/internal/pmetricutil/metrics.go (1 line): - line 66: // TODO condense this code connector/signaltometricsconnector/internal/aggregator/exphistogram.go (1 line): - line 45: // TODO determine appropriate start time exporter/clickhouseexporter/internal/histogram_metrics.go (1 line): - line 172: // TODO latency metrics pkg/ottl/contexts/internal/ctxmetric/metric.go (1 line): - line 87: // TODO Implement methods so correctly convert data types. exporter/dorisexporter/metadata.yaml (1 line): - line 12: # TODO: Update the exporter to pass the tests exporter/splunkhecexporter/client.go (1 line): - line 211: // TODO record this drop as a metric receiver/azuremonitorreceiver/scraper.go (1 line): - line 369: // TODO: switch to parsing services from exporter/clickhouseexporter/internal/summary_metrics.go (1 line): - line 148: // TODO latency metrics exporter/clickhouseexporter/internal/exponential_histogram_metrics.go (1 line): - line 185: // TODO latency metrics extension/jaegerremotesampling/metadata.yaml (1 line): - line 12: # TODO: Update the extension to make the tests pass receiver/sqlqueryreceiver/logs_receiver.go (1 line): - line 211: // TODO: Extract persistence into its own component receiver/awsxrayreceiver/internal/udppoller/poller.go (1 line): - line 174: // TODO: We may want to attempt to shutdown/clean the broken socket and open a new one receiver/awsecscontainermetricsreceiver/metadata.yaml (1 line): - line 11: # TODO: Update the receiver to pass the tests testbed/testbed/in_process_collector.go (1 line): - line 84: // TODO: Pass this to the error handler. extension/observer/k8sobserver/metadata.yaml (1 line): - line 12: # TODO: Update the extension to make the tests pass exporter/awsemfexporter/datapoint.go (1 line): - line 95: // TODO: Calculate delta value for count and sum value with exponential histogram extension/sumologicextension/extension.go (1 line): - line 1094: // TODO: try to dynamically extract this from the resource processor in the pipeline extension/storage/dbstorage/metadata.yaml (1 line): - line 11: # TODO: Update the extension to make the tests pass extension/storage/filestorage/extension.go (1 line): - line 58: // TODO clean up data files that did not have a client receiver/signalfxreceiver/receiver.go (1 line): - line 146: // TODO: Evaluate what properties should be configurable, for now receiver/awsecscontainermetricsreceiver/receiver.go (1 line): - line 83: // TODO: report self metrics using obsreport connector/countconnector/counter.go (1 line): - line 124: // TODO determine appropriate start time exporter/googlecloudpubsubexporter/metadata.yaml (1 line): - line 11: # TODO: Update the exporter to pass the tests exporter/elasticsearchexporter/internal/datapoints/summary.go (1 line): - line 28: // TODO: Add support for quantiles connector/spanmetricsconnector/factory.go (1 line): - line 29: // TODO: Remove this feature gate when the legacy metric names are removed. receiver/activedirectorydsreceiver/metadata.yaml (1 line): - line 214: # TODO: Update the receiver to pass the tests pkg/ottl/ottlfuncs/func_truncate_all.go (1 line): - line 51: // TODO: Write log when truncation is performed receiver/awscontainerinsightreceiver/metadata.yaml (1 line): - line 12: # TODO: Update the receiver to pass the tests exporter/awskinesisexporter/metadata.yaml (1 line): - line 11: # TODO: Update the exporter to pass the tests exporter/sapmexporter/exporter.go (1 line): - line 27: // TODO: Find a place for this to be shared. processor/spanprocessor/span.go (1 line): - line 194: // TODO: Pre-allocate len(submatches) space in the attributes. exporter/azuremonitorexporter/conventions.go (1 line): - line 18: // TODO replace with convention.* values once/if available connector/servicegraphconnector/internal/store/store.go (1 line): - line 97: // TODO: try to evict expired items exporter/syslogexporter/metadata.yaml (1 line): - line 11: # TODO: Update the exporter to pass the tests internal/k8sconfig/config.go (1 line): - line 36: // TODO: Add option for TLS once receiver/awsxrayreceiver/internal/translator/cause.go (1 line): - line 17: // TODO: Remove this when collector defines this semantic convention. receiver/awsfirehosereceiver/logs_receiver.go (1 line): - line 70: // TODO: make cwlogs an encoding extension extension/encoding/awslogsencodingextension/internal/unmarshaler/vpc-flow-log/vpc_flow_log_unmarshaler.go (1 line): - line 320: // TODO Replace with conventions variable once it becomes available internal/coreinternal/goldendataset/traces_generator.go (1 line): - line 46: // TODO: use math/rand/v2.ChaCha8.Read when we upgrade to go1.23. receiver/splunkhecreceiver/splunkhec_to_metricdata.go (1 line): - line 163: // TODO: Log or metric for this odd ball? processor/schemaprocessor/internal/translation/manager.go (1 line): - line 60: // TODO make cache configurable exporter/cassandraexporter/metadata.yaml (1 line): - line 11: # TODO: Update the exporter to pass the tests exporter/clickhouseexporter/internal/sum_metrics.go (1 line): - line 160: // TODO latency metrics receiver/solacereceiver/metadata.yaml (1 line): - line 11: # TODO: Update the receiver to pass the tests internal/coreinternal/goldendataset/metrics_gen.go (1 line): - line 187: // TODO: HasSum, Min, HasMin, Max, HasMax are not covered in tests. pkg/translator/zipkin/zipkinv1/json.go (1 line): - line 176: // TODO: (@pjanotti) add reference to OpenTracing and change related tags to use them receiver/sapmreceiver/factory.go (1 line): - line 46: // TODO make this a utility function extension/asapauthextension/metadata.yaml (1 line): - line 11: # TODO: Update the extension to make the tests pass receiver/k8sclusterreceiver/internal/constants/constants.go (1 line): - line 8: // TODO: Remove after switch to new Metrics definition connector/signaltometricsconnector/internal/aggregator/sumdp.go (1 line): - line 53: // TODO determine appropriate start time processor/resourcedetectionprocessor/factory.go (1 line): - line 101: // TODO: Once issue(https://github.com/open-telemetry/opentelemetry-collector/issues/4001) gets resolved, internal/aws/cwlogs/cwlog_client.go (1 line): - line 127: // TODO: Should have metrics to provide visibility of these failures receiver/mongodbatlasreceiver/internal/mongodb_atlas_client.go (1 line): - line 185: // TODO: Add error to a metric extension/observer/ecsobserver/filter.go (1 line): - line 39: // TODO: print out the pattern to include both pattern and port receiver/googlecloudmonitoringreceiver/metadata.yaml (1 line): - line 12: # TODO: Update the receiver to pass the tests receiver/k8seventsreceiver/metadata.yaml (1 line): - line 11: # TODO: Update the receiver to pass the tests exporter/elasticsearchexporter/exporter.go (1 line): - line 483: // TODO add support for routing profiles to different data_stream.namespaces? internal/aws/ecsutil/rest_client.go (1 line): - line 23: // TODO: Instead of using this, expose it as a argument to NewRestClient. exporter/prometheusexporter/collector.go (1 line): - line 227: // TODO: In the off chance that we have multiple points processor/k8sattributesprocessor/internal/kube/kube.go (1 line): - line 84: // TODO: move these to config with default values receiver/hostmetricsreceiver/internal/scraper/processscraper/process.go (1 line): - line 57: // TODO insert slice here once this is supported by the data model receiver/datadogreceiver/internal/translator/sketches.go (1 line): - line 176: // TODO: look into better algorithms for applying fractional counts exporter/loadbalancingexporter/loadbalancer.go (1 line): - line 158: // TODO: set a timeout? exporter/awsemfexporter/config.go (1 line): - line 68: // TODO: we can support directing output to a file (in the future) while customer specifies a file path here. exporter/awsemfexporter/emf_exporter.go (1 line): - line 150: // TODO now we only have one logPusher, so it's ok to return after first error occurred pkg/translator/prometheusremotewrite/metrics_to_prw.go (1 line): - line 67: // TODO: decide if instrumentation library information should be exported as labels internal/coreinternal/consumerretry/logs.go (1 line): - line 84: // TODO: take delay from the error once it is available in the consumererror package. receiver/kafkareceiver/metadata.yaml (1 line): - line 13: # TODO: Update the receiver to pass the tests receiver/wavefrontreceiver/receiver.go (1 line): - line 51: Type: "plaintext", // TODO: update after other parsers are implemented for Carbon receiver. processor/resourcedetectionprocessor/internal/resourcedetection.go (1 line): - line 207: // TODO: handle the case when the schema URLs are different by performing exporter/datadogexporter/traces_exporter.go (1 line): - line 258: tracelog.SetLogger(&datadog.Zaplogger{Logger: params.Logger}) // TODO: This shouldn't be a singleton receiver/awscontainerinsightreceiver/internal/cadvisor/container_info_processor.go (1 line): - line 22: // TODO: https://github.com/containerd/cri/issues/922#issuecomment-423729537 the container name can be empty on containerd exporter/azuredataexplorerexporter/metadata.yaml (1 line): - line 12: # TODO: Update the exporter to pass the tests exporter/clickhouseexporter/metadata.yaml (1 line): - line 12: # TODO: Update the exporter to pass the tests exporter/signalfxexporter/internal/apm/correlations/client.go (1 line): - line 284: // TODO: pool the reader receiver/otlpjsonfilereceiver/file.go (1 line): - line 229: // TODO Append token.Attributes exporter/elasticsearchexporter/internal/serializer/otelserializer/serializeprofiles/transform.go (1 line): - line 217: Count: 1, // TODO: Check whether count can be dropped with nanosecond timestamps receiver/podmanreceiver/metadata.yaml (1 line): - line 129: # TODO: Update the receiver to pass the tests cmd/opampsupervisor/supervisor/config/config.go (1 line): - line 235: // TODO: Add more telemetry options receiver/zipkinreceiver/trace_receiver.go (1 line): - line 139: // TODO: (@odeke-em) record the unique types of Content-Type uploads cmd/telemetrygen/config.go (1 line): - line 82: // TODO: Uncomment the line below when using run instead of RunE in the xxxCmd functions receiver/simpleprometheusreceiver/config.go (1 line): - line 32: // TODO: Move to a common package for use by other receivers and also pull exporter/stefexporter/exporter.go (1 line): - line 256: // TODO: check if err is because STEF encoding failed. If so we must not processor/schemaprocessor/internal/migrate/attributes.go (1 line): - line 60: // TODO: Since the spec hasn't decided the behavior on what receiver/k8sclusterreceiver/internal/collection/collector.go (1 line): - line 35: // TODO: Consider moving some of these constants to exporter/sumologicexporter/sender.go (1 line): - line 449: // TODO: add support for HTTP limits receiver/pulsarreceiver/metadata.yaml (1 line): - line 11: # TODO: Update the receiver to pass the tests