datafusion/expr-common/src/statistics.rs (9 lines): - line 295: // TODO: Should we ensure that this always returns a real number data type? - line 317: // TODO: Should we ensure that this always returns a real number data type? - line 374: // TODO: Should we ensure that this always returns a real number data type? - line 385: // TODO: Should we ensure that this always returns a real number data type? - line 396: // TODO: Should we ensure that this always returns a real number data type? - line 704: // TODO: We can handle inequality operators and calculate a - line 714: // TODO: We can handle Gaussian comparisons and calculate a `p` value - line 763: // TODO: We can calculate the mean for division when we support reciprocals, - line 845: // TODO: We can calculate the variance for division when we support reciprocals, datafusion/optimizer/src/simplify_expressions/expr_simplifier.rs (7 lines): - line 626: // TODO: remove the next line after `Expr::Wildcard` is removed - line 700: // TODO: support the optimization for `Map` type after support impl hash for it - line 715: // TODO: support the optimization for `Map` type after support impl hash for it - line 1614: // TODO: handle escape characters - line 1928: // TODO: We might not need this after defer pattern for Box is stabilized. https://github.com/rust-lang/rust/issues/87121 - line 1943: // TODO: We might not need this after defer pattern for Box is stabilized. https://github.com/rust-lang/rust/issues/87121 - line 3922: // TODO: Further simplify this expression datafusion/functions-aggregate/src/first_last.rs (6 lines): - line 184: // TODO: extract to function - line 212: // TODO: extract to function - line 314: // TODO: rename to PrimitiveGroupsAccumulator - line 340: // TODO: rename to extreme_of_each_group_buf - line 454: // TODO make this more efficient rather than two - line 539: /// TODO: rename to get_filtered_extreme_of_each_group datafusion/expr/src/expr.rs (6 lines): - line 1801: // TODO: remove the next line after `Expr::Wildcard` is removed - line 2200: // TODO: normalize_eq for lists, for example `a IN (c1 + c3, c3)` is equal to `a IN (c3, c1 + c3)` - line 2221: // TODO: normalize_eq for when_then_expr - line 2447: // TODO: remove the next line after `Expr::Wildcard` is removed - line 2877: // TODO: Use ", " to standardize the formatting of Vec, - line 3019: // TODO: use udf's display_name, need to fix the separator issue, datafusion/expr-common/src/type_coercion/binary.rs (5 lines): - line 284: // TODO Move the rest inside of BinaryTypeCoercer - line 553: // TODO: Add binary view, list view with tests - line 933: // TODO if we convert the floating-point data to the decimal type, it maybe overflow. - line 951: // TODO if we convert the floating-point data to the decimal type, it maybe overflow. - line 2440: // TODO add other data type datafusion/catalog/src/information_schema.rs (5 lines): - line 562: // TODO: Stream this - line 654: // TODO: Stream this - line 769: // TODO: Stream this - line 1013: // TODO: Stream this - line 1059: // TODO: Stream this datafusion/common/src/file_options/parquet_writer.rs (4 lines): - line 29: // TODO: handle once deprecated - line 162: // TODO: remove once deprecated - line 178: /// TODO: use extern parquet's private method, once publicly available. - line 191: // TODO: change after addressing ARROW-9777 datafusion/core/src/schema_equivalence.rs (4 lines): - line 78: // TODO (DataType::Union(, _), DataType::Union(_, _)) => {} - line 79: // TODO (DataType::Dictionary(_, _), DataType::Dictionary(_, _)) => {} - line 80: // TODO (DataType::Map(_, _), DataType::Map(_, _)) => {} - line 81: // TODO (DataType::RunEndEncoded(_, _), DataType::RunEndEncoded(_, _)) => {} datafusion/common/src/scalar/mod.rs (4 lines): - line 1181: // TODO: replace the constants with next_up/next_down when - line 1771: // TODO: we might want to look into supporting ceil/floor here for floats. - line 2850: // TODO: There is no test for FixedSizeList now, add it later - line 6540: // TODO: if negate supports f16, add these cases to `test_scalar_negative_overflows` test case datafusion/physical-optimizer/src/pruning.rs (4 lines): - line 1686: // TODO Handle ILIKE perhaps by making the min lowercase and max uppercase - line 4611: // TODO: add test for other case and op - line 4708: // TODO: add other negative test for other case and op - line 5151: // TODO refactor other tests to use this to reduce boiler plate datafusion/physical-plan/src/aggregates/mod.rs (4 lines): - line 717: // TODO: Emission type and boundedness information can be enhanced here - line 737: // TODO stats: group expressions: - line 740: // TODO stats: aggr expression: - line 1897: // TODO: collect info datafusion/datasource-avro/src/avro_to_arrow/arrow_array_reader.rs (4 lines): - line 337: // TODO: ARROW-10335: APIs of dictionary arrays and others are different. Unify - line 467: // TODO: unboxing Union(Array(Union(...))) should probably be done earlier - line 678: // TODO: this is incomplete - line 1067: // TODO: Fixed, Enum, Dictionary datafusion/functions/src/math/monotonicity.rs (4 lines): - line 183: // TODO: Implement ordering rule of the ATAN2 function. - line 251: // TODO: Implement ordering rule of the ATAN2 function. - line 462: // TODO: Implement ordering rule of the SIN function. - line 530: // TODO: Implement ordering rule of the TAN function. datafusion/functions-aggregate/src/correlation.rs (4 lines): - line 174: // TODO: null input skipping logic duplicated across Correlation - line 463: // TODO: Old datafusion implementation returns 0.0 for these invalid cases. - line 467: // TODO: Evaluate as `Null` (see notes above) - line 488: // TODO: Evaluate as `Null` (see notes above) datafusion/physical-plan/src/recursive_query.rs (4 lines): - line 149: // TODO: control these hints and see whether we can - line 184: // TODO: we might be able to handle multiple partitions in the future. - line 227: // TODO: collect info - line 402: // TODO: we should use this poll to record some metrics! datafusion/expr/src/type_coercion/functions.rs (4 lines): - line 238: // TODO: Deprecate this branch after all signatures are well-supported (aka coercion has happened already) - line 471: // TODO: Switch to Utf8View if all the string functions supports Utf8View - line 715: // TODO: Replace with `can_cast_types` after failing cases are resolved - line 730: /// TODO: I think this function should replace `maybe_data_types` after signature are well-supported. datafusion/datasource/src/file_scan_config.rs (4 lines): - line 702: // TODO provide accurate stat for partition column (#1186) - line 710: // TODO correct byte size: https://github.com/apache/datafusion/issues/14936 - line 1573: // TODO implement tests for partition column statistics once implemented - line 1642: // TODO implement tests for proj_stat_cols[0] once partition column datafusion/physical-expr/src/equivalence/properties/mod.rs (4 lines): - line 145: /// TODO: We do not need to track constants separately, they can be tracked - line 796: /// TODO: Add one-to-ones analysis for monotonic ScalarFunctions. - line 797: /// TODO: we could precompute all the scenario that is computable, for example: atan(x + 1000) should also be substituted if - line 816: // TODO: Add one-to-ones analysis for ScalarFunctions. datafusion/catalog-listing/src/helpers.rs (4 lines): - line 94: // TODO: Stable functions could be `applicable`, but that would require access to the context - line 102: // TODO other expressions are not handled yet: - line 106: // TODO: remove the next line after `Expr::Wildcard` is removed - line 292: // TODO: Plumb this down datafusion/expr/src/logical_plan/plan.rs (4 lines): - line 2668: // TODO (https://github.com/apache/datafusion/issues/14380): Avoid creating uncoerced union at all. - line 2720: /// TODO (): This is not necessarily reasonable behavior. - line 2838: // TODO apply type coercion here, or document why it's better to defer - line 3848: // TODO: may be implement NormalizeEq for LogicalPlan? datafusion/physical-plan/src/analyze.rs (3 lines): - line 112: // TODO: collect info - line 227: // TODO use some sort of enum rather than strings? - line 237: // TODO make this more sophisticated datafusion/functions-aggregate-common/src/aggregate/groups_accumulator/accumulate.rs (3 lines): - line 222: // TODO make this more efficient rather than two - line 342: // iterator. TODO file a ticket - line 358: // iterators. TODO file a ticket datafusion/physical-optimizer/src/join_selection.rs (3 lines): - line 58: // TODO: We need some performance test for Right Semi/Right Join swap to Left Semi/Left Join in case that the right side is smaller but not much smaller. - line 59: // TODO: In PrestoSQL, the optimizer flips join sides only if one side is much smaller than the other by more than SIZE_DIFFERENCE_THRESHOLD times, by default is 8 times. - line 93: // TODO check the logic in datasource::get_statistics_with_limit() datafusion/common/src/config.rs (3 lines): - line 524: // TODO: remove once deprecated - line 1225: // TODO: Let's decide how we treat the numerical strings. - line 1904: // TODO: remove once deprecated datafusion/substrait/src/physical_plan/producer.rs (3 lines): - line 88: // FIXME: duckdb doesn't set this field, keep it as default variant 0. - line 100: // FIXME: duckdb sets this to None, but it's not clear why. - line 120: // FIXME: duckdb set this to true, but it's not clear why. datafusion/expr-common/src/signature.rs (3 lines): - line 218: // TODO: - line 519: // TODO: Implement for other types - line 554: // TODO: support other native types datafusion/functions-aggregate/src/min_max.rs (3 lines): - line 84: // TODO add checker, if the value type is complex data type - line 87: // TODO add checker for datatype which min and max supported - line 187: // TODO optimize with exprs other than Column datafusion/optimizer/src/common_subexpr_eliminate.rs (3 lines): - line 187: // TODO: Although `find_common_exprs()` inserts aliases around extracted - line 376: // TODO: Although `find_common_exprs()` inserts aliases around - line 681: // TODO: remove the next line after `Expr::Wildcard` is removed datafusion/physical-plan/src/topk/mod.rs (3 lines): - line 143: // TODO: make a builder or some other nicer API - line 160: // TODO there is potential to add special cases for single column sort fields - line 210: // TODO make this algorithmically better?: datafusion/physical-plan/src/joins/cross_join.rs (2 lines): - line 147: // TODO: Check equivalence properties of cross join, it may preserve - line 160: // TODO: Optimize the cross join implementation to generate M * N datafusion/expr/src/logical_plan/ddl.rs (2 lines): - line 448: // TODO: There is open question should we expose sqlparser types or redefine them here? - line 495: // TODO: figure out how to support mode datafusion/catalog/src/cte_worktable.rs (2 lines): - line 93: // TODO: pushdown filters and limits - line 104: // TODO: should we support filter pushdown? datafusion/physical-optimizer/src/enforce_sorting/sort_pushdown.rs (2 lines): - line 319: // TODO: Add support for Projection push down - line 349: // TODO: Add support for Projection push down datafusion/expr/src/utils.rs (2 lines): - line 274: // TODO: remove the next line after `Expr::Wildcard` is removed - line 1341: // FIXME use as_ref datafusion/optimizer/src/propagate_empty_relation.rs (2 lines): - line 76: // TODO: For Join, more join type need to be careful: - line 478: // TODO: fix this long name datafusion/physical-plan/src/aggregates/row_hash.rs (2 lines): - line 977: // TODO: support group_ordering for spilling - line 1034: /// TODO: support group_ordering for early emitting datafusion/physical-optimizer/src/aggregate_statistics.rs (2 lines): - line 73: // TODO: we need all aggr_expr to be resolved (cf TODO fullres) - line 78: // TODO fullres: use statistics even if not all aggr_expr could be resolved datafusion/expr/src/logical_plan/builder.rs (2 lines): - line 181: // TODO: we need to do a bunch of validation here. Maybe more. - line 1559: // TODO: find a good way to do that datafusion/physical-plan/src/aggregates/group_values/row.rs (2 lines): - line 212: // TODO file some ticket in arrow-rs to make this more efficient? - line 235: // TODO: Materialize dictionaries in group keys datafusion/physical-plan/src/projection.rs (2 lines): - line 293: // TODO stats: estimate more statistics from expressions - line 789: // TODO: Clippy wants the "map" call removed, but doing so generates datafusion/functions-aggregate/src/approx_distinct.rs (2 lines): - line 337: // TODO u8, i8, u16, i16 shall really be done using bitmap, not HLL - line 338: // TODO support for boolean (trivial case) datafusion/optimizer/src/push_down_filter.rs (2 lines): - line 288: // TODO: remove the next line after `Expr::Wildcard` is removed - line 2537: /// TODO: In this case we can sometimes convert the join to an INNER join datafusion/expr/src/tree_node.rs (2 lines): - line 70: // TODO: remove the next line after `Expr::Wildcard` is removed - line 118: // TODO: remove the next line after `Expr::Wildcard` is removed datafusion/physical-plan/src/joins/nested_loop_join.rs (2 lines): - line 593: // TODO: currently if there is projection in NestedLoopJoinExec, we can't push down projection to left or right input. Maybe we can pushdown the mixed projection later. - line 721: // TODO: support null aware equal datafusion/core/src/datasource/listing/table.rs (2 lines): - line 1334: // TODO correct byte size: https://github.com/apache/datafusion/issues/14936 - line 2370: // TODO test with create statement options such as compression datafusion/physical-expr/src/expressions/binary.rs (2 lines): - line 602: /// TODO: There may be rules specific to some data types and expression ranges. - line 4015: // TODO: now we do not refactor the `is distinct or is not distinct` rule of coercion. datafusion/physical-plan/src/windows/bounded_window_agg_exec.rs (2 lines): - line 207: // TODO: Emission type and boundedness information can be enhanced here - line 233: // TODO stats: some windowing function will maintain invariants such as min, max... datafusion/substrait/src/logical_plan/producer.rs (2 lines): - line 2070: invocation: 0, // TODO: fix - line 2184: // TODO: Support GROUPS datafusion/physical-plan/src/sorts/sort.rs (2 lines): - line 256: // TODO: make a builder or some other nicer API to avoid the - line 1191: // TODO support RangePartition and OrderedDistribution datafusion/datasource-csv/src/source.rs (2 lines): - line 77: // TODO: it seems like these format options could be reused across all the various CSV config - line 93: // TODO: these defaults are duplicated from `CsvOptions` - should they be computed? datafusion/physical-expr/src/intervals/cp_solver.rs (2 lines): - line 366: // TODO: Propagation is not possible until we support interval sets. - line 1386: // TODO: We expect nodes a@0 and b@1 to be pruned, and intervals to be provided from the a@0 + b@1 node. datafusion/expr/src/window_state.rs (2 lines): - line 408: // TODO: Handle positive overflows. - line 416: // TODO: Handle negative overflows. datafusion/physical-plan/src/joins/sort_merge_join.rs (2 lines): - line 338: // TODO: OR this condition with having a built-in projection (like - line 524: // TODO stats: it is not possible in general to know the output size of joins datafusion/physical-plan/src/windows/window_agg_exec.rs (2 lines): - line 137: // TODO: Emission type and boundedness information can be enhanced here - line 164: // TODO stats: some windowing function will maintain invariants such as min, max... datafusion/common/src/scalar/struct_builder.rs (2 lines): - line 132: /// TODO potentially upstream this to arrow-rs so that we can - line 161: /// TODO potentially upstream this to arrow-rs so that we can datafusion/physical-expr/src/equivalence/properties/union.rs (2 lines): - line 101: // TODO: In some cases, we should be able to preserve some equivalence - line 692: // TODO tests with multiple constants datafusion/sql/src/expr/identifier.rs (2 lines): - line 39: // TODO: figure out if ScalarVariables should be insensitive. - line 175: // TODO: remove when can support nested identifiers for OuterReferenceColumn datafusion/physical-plan/src/joins/hash_join.rs (2 lines): - line 893: // TODO stats: it is not possible in general to know the output size of joins - line 914: // TODO: currently if there is projection in HashJoinExec, we can't push down projection to left or right input. Maybe we can pushdown the mixed projection later. datafusion/sql/src/statement.rs (2 lines): - line 82: // TODO: It might be better to return an error - line 956: // TODO: support multiple tables in UPDATE SET FROM datafusion/substrait/src/extensions.rs (2 lines): - line 28: /// TODO: DF doesn't yet use extensions for type variations - line 29: /// TODO: DF doesn't yet provide valid extensionUris datafusion/core/src/physical_planner.rs (2 lines): - line 911: // TODO: Can we extract this transformation to somewhere before physical plan - line 2829: // TODO: collect info datafusion/sql/src/unparser/expr.rs (2 lines): - line 463: // TODO: unparsing wildcard addition options - line 531: // TODO: support for the construct and access functions of the `map` type datafusion/datasource-parquet/src/file_format.rs (2 lines): - line 1017: // TODO: collect info - line 1052: // TODO: avoid this clone in follow up PR, where the writer properties & schema datafusion/core/src/datasource/file_format/parquet.rs (2 lines): - line 623: // TODO correct byte size: https://github.com/apache/datafusion/issues/14936 - line 672: // TODO correct byte size: https://github.com/apache/datafusion/issues/14936 datafusion/functions-aggregate/src/median.rs (2 lines): - line 378: // TODO: avoid using iterator of the `ListArray`, this will lead to - line 406: // TODO: maybe we can use `OffsetBuffer::new_unchecked` like what in `convert_to_state`, datafusion/substrait/src/variation_const.rs (2 lines): - line 28: //! TODO: Definitions here are not the final form. All the non-system-preferred variations will be defined - line 36: // TODO: Define as extensions: datafusion/optimizer/src/analyzer/type_coercion.rs (2 lines): - line 576: // TODO: remove the next line after `Expr::Wildcard` is removed - line 1547: // TODO: we should cast col(a). datafusion/sql/src/utils.rs (2 lines): - line 622: // TODO: This can be resolved after this issue is resolved: https://github.com/apache/datafusion/issues/10102 - line 634: // TODO: remove the next line after `Expr::Wildcard` is removed datafusion/proto/src/logical_plan/to_proto.rs (1 line): - line 313: // TODO: support null treatment in proto test-utils/src/array_gen/primitive.rs (1 line): - line 38: // TODO: support generating more primitive arrays datafusion/functions/src/datetime/date_bin.rs (1 line): - line 317: // TODO (my next PR): without `INTERVAL` keyword, the stride was converted into ScalarValue::IntervalDayTime somewhere datafusion/physical-expr/src/equivalence/class.rs (1 line): - line 58: // TODO: Consider refactoring the `across_partitions` and `value` fields into an enum: datafusion-cli/src/main.rs (1 line): - line 233: // TODO maybe we can have thiserror for cli but for now let's keep it simple datafusion/physical-plan/src/memory.rs (1 line): - line 196: //TODO: remove batch_size, add one line per generator datafusion/substrait/src/logical_plan/consumer/utils.rs (1 line): - line 268: // TODO: from_substrait_struct_type needs to be updated to set the nullability correctly. It defaults to true for now. datafusion/physical-plan/src/joins/stream_join_utils.rs (1 line): - line 161: // TODO: switch to using [HashTable::allocation_size] when available after upgrading hashbrown to 0.15 datafusion/physical-plan/src/aggregates/group_values/null_builder.rs (1 line): - line 81: // TODO: it would be great to use something like `set_bits` from arrow here. datafusion/physical-plan/src/empty.rs (1 line): - line 98: // TODO: collect info datafusion/expr/src/logical_plan/invariants.rs (1 line): - line 207: // TODO revisit this validation logic datafusion/functions-aggregate/src/array_agg.rs (1 line): - line 685: // TODO: Calculate size of each `PhysicalSortExpr` more accurately. datafusion/optimizer/src/analyzer/resolve_grouping_function.rs (1 line): - line 151: // TODO: Do something better than name here should grouping be a built datafusion/substrait/src/logical_plan/consumer/rel/read_rel.rs (1 line): - line 176: // TODO: currently does not support multiple local files datafusion/substrait/src/logical_plan/consumer/types.rs (1 line): - line 225: // TODO: remove the code below once the producer has been updated datafusion/physical-expr/src/equivalence/ordering.rs (1 line): - line 552: // TODO: If we know that exp function is 1-to-1 function. datafusion/expr-common/src/accumulator.rs (1 line): - line 300: // TODO add retract for all accumulators datafusion/execution/src/memory_pool/pool.rs (1 line): - line 581: // TODO: the insufficient_capacity_err() message is per reservation, not per consumer. datafusion/physical-plan/src/aggregates/order/partial.rs (1 line): - line 120: /// TODO: Remove unnecessary `input_schema` parameter. datafusion/ffi/src/plan_properties.rs (1 line): - line 182: // TODO Extend FFI to get the registry and codex datafusion/optimizer/src/replace_distinct_aggregate.rs (1 line): - line 135: // TODO use LogicalPlanBuilder directly rather than recreating the Aggregate datafusion/functions-aggregate/src/count.rs (1 line): - line 377: // TODO optimize with exprs other than Column datafusion/substrait/src/physical_plan/consumer.rs (1 line): - line 110: // TODO substrait plans do not have `last_modified` or `size` but `ObjectMeta` datafusion/physical-plan/src/execution_plan.rs (1 line): - line 996: // TODO: Replace with [join_next_with_id](https://docs.rs/tokio/latest/tokio/task/struct.JoinSet.html#method.join_next_with_id datafusion/physical-expr/src/expressions/cast.rs (1 line): - line 775: #[ignore] // TODO: https://github.com/apache/datafusion/issues/5396 datafusion/physical-plan/src/values.rs (1 line): - line 166: // TODO: collect info datafusion/physical-optimizer/src/output_requirements.rs (1 line): - line 143: // TODO: collect info datafusion/common/src/file_options/mod.rs (1 line): - line 300: // TODO expand unit test if csv::WriterBuilder allows public read access to properties datafusion/datasource/src/file_format.rs (1 line): - line 81: /// TODO: should the file source return statistics for only columns referred to in the table schema? datafusion/physical-plan/src/spill/spill_manager.rs (1 line): - line 47: // TODO: Add general-purpose compression options datafusion/functions-aggregate-common/src/aggregate/groups_accumulator/nulls.rs (1 line): - line 116: /// TODO: replace when upstreamed in arrow-rs: datafusion/core/src/datasource/physical_plan/json.rs (1 line): - line 188: // TODO: this is not where schema inference should be tested datafusion/functions-aggregate/src/sum.rs (1 line): - line 260: // TODO: Expand these utilizing statistics. datafusion/sql/src/query.rs (1 line): - line 188: // TODO: Support other types of expressions datafusion/optimizer/src/simplify_expressions/unwrap_cast.rs (1 line): - line 263: // Only try for integer types (TODO can we do this for other types datafusion/expr/src/type_coercion/other.rs (1 line): - line 50: // TODO: now just use the `equal` coercion rule for case when. If find the issue, and datafusion/common/src/utils/mod.rs (1 line): - line 839: // TODO: Remove this function when `is_sorted` graduates from Rust nightly. datafusion/functions-aggregate/src/lib.rs (1 line): - line 210: // TODO: remove this datafusion/physical-expr/src/expressions/try_cast.rs (1 line): - line 313: // TODO we should add function to create Decimal128Array with value and metadata datafusion/expr-common/src/interval_arithmetic.rs (1 line): - line 3495: // TODO: Add tests for non-exponential boundary aligned intervals too. datafusion/common/src/stats.rs (1 line): - line 417: // TODO: Can input stats still be used, but adjusted, when `skip` datafusion/functions-nested/src/planner.rs (1 line): - line 69: // TODO: concat function ignore null, but string concat takes null into consideration datafusion/core/src/datasource/listing_table_factory.rs (1 line): - line 56: // TODO (https://github.com/apache/datafusion/issues/11600) remove downcast_ref from here. Should file format factory be an extension to session state? datafusion/core/src/execution/context/mod.rs (1 line): - line 700: // TODO what about the other statements (like TransactionStart and TransactionEnd) datafusion/physical-expr/src/utils/guarantee.rs (1 line): - line 811: // TODO this should be in_guarantee("b", [1, 2, 3]) but currently we don't support to analyze this kind of disjunction. Only `ColOpLit OR ColOpLit` is supported. datafusion/physical-plan/src/render_tree.rs (1 line): - line 31: // TODO: It's never used. datafusion/functions-window/src/planner.rs (1 line): - line 82: // TODO: remove the next line after `Expr::Wildcard` is removed datafusion/ffi/src/execution_plan.rs (1 line): - line 213: // TODO: collect info datafusion/physical-plan/src/display.rs (1 line): - line 559: // TODO: Make these variables configurable. datafusion/optimizer/src/simplify_expressions/guarantees.rs (1 line): - line 51: // TODO: Clippy wants the "map" call removed, but doing so generates datafusion/physical-optimizer/src/optimizer.rs (1 line): - line 116: // TODO: `try_embed_to_hash_join` in the ProjectionPushdown rule would be block by the CoalesceBatches, so add it before CoalesceBatches. Maybe optimize it in the future. datafusion/proto/src/physical_plan/from_proto.rs (1 line): - line 170: // TODO: Remove extended_schema if functions are all UDAF datafusion/physical-plan/src/sorts/sort_preserving_merge.rs (1 line): - line 1393: // TODO: collect info datafusion/common/src/column.rs (1 line): - line 272: // TODO If [`DFSchema`] had spans, we could show the datafusion/substrait/src/logical_plan/consumer/expr/literal.rs (1 line): - line 403: // TODO: remove the code below once the producer has been updated datafusion/optimizer/src/optimize_projections/mod.rs (1 line): - line 318: // TODO: For some subquery variants (e.g. a subquery arising from an datafusion/functions-aggregate/src/planner.rs (1 line): - line 85: // TODO: remove the next line after `Expr::Wildcard` is removed datafusion/datasource/src/write/demux.rs (1 line): - line 289: // TODO: upstream RecordBatch::take to arrow-rs datafusion/physical-optimizer/src/enforce_distribution.rs (1 line): - line 314: // TODO: although projection is not used in the join here, because projection pushdown is after enforce_distribution. Maybe we need to handle it later. Same as filter. datafusion/spark/src/function/error_utils.rs (1 line): - line 18: // TODO: https://github.com/apache/spark/tree/master/common/utils/src/main/resources/error datafusion/physical-expr/src/expressions/case.rs (1 line): - line 1401: // TODO: now just use the `equal` coercion rule for case when. If find the issue, and datafusion/physical-plan/src/explain.rs (1 line): - line 98: // TODO: collect info datafusion/functions-nested/src/array_has.rs (1 line): - line 137: // TODO: support LargeList datafusion/datasource/src/sink.rs (1 line): - line 65: // TODO add desired input ordering datafusion/datasource-avro/src/file_format.rs (1 line): - line 127: // TODO: Fetching entire file to get schema is potentially wasteful datafusion/expr/src/udf.rs (1 line): - line 416: // TODO: join with ", " to standardize the formatting of Vec, datafusion/physical-expr-common/src/datum.rs (1 line): - line 131: // TODO: make SortOptions configurable datafusion/physical-plan/src/aggregates/group_values/multi_group_by/mod.rs (1 line): - line 1159: // TODO: Materialize dictionaries in group keys (#7647) datafusion/functions-aggregate-common/src/stats.rs (1 line): - line 18: /// TODO: Move this to functions-aggregate module test-utils/src/array_gen/random_data.rs (1 line): - line 77: // TODO: constrain this range to valid dates if necessary datafusion/functions/src/core/version.rs (1 line): - line 81: // TODO it would be great to add rust version and arrow version, datafusion/functions-aggregate/src/nth_value.rs (1 line): - line 395: // TODO: Calculate size of each `PhysicalSortExpr` more accurately. datafusion/proto/src/logical_plan/from_proto.rs (1 line): - line 294: // TODO: support proto for null treatment datafusion/datasource-parquet/src/row_filter.rs (1 line): - line 408: // TODO How do we know this? datafusion/physical-plan/src/joins/symmetric_hash_join.rs (1 line): - line 475: // TODO stats: it is not possible in general to know the output size of joins datafusion/substrait/src/logical_plan/consumer/substrait_consumer.rs (1 line): - line 160: // TODO: Remove these two methods datafusion/physical-plan/src/aggregates/group_values/multi_group_by/bytes.rs (1 line): - line 388: // TODO: Current approach copy the remaining and truncate the original one datafusion/functions-window/src/lead_lag.rs (1 line): - line 394: // TODO: change the original arrow::compute::kernels::window::shift impl to support an optional default value datafusion/optimizer/src/optimize_projections/required_indices.rs (1 line): - line 115: // TODO could remove these clones (and visit the expression directly) datafusion/datasource/src/memory.rs (1 line): - line 756: // TODO: collect info datafusion/physical-plan/src/aggregates/no_grouping.rs (1 line): - line 195: /// TODO: Make this a member function datafusion/optimizer/src/analyzer/mod.rs (1 line): - line 158: // TODO add common rule executor for Analyzer and Optimizer datafusion/common/src/rounding.rs (1 line): - line 19: //! TODO: Remove this custom implementation and the "libc" dependency when