summaryrefslogtreecommitdiff
path: root/databases/duckdb/pkg-plist
diff options
context:
space:
mode:
Diffstat (limited to 'databases/duckdb/pkg-plist')
-rw-r--r--databases/duckdb/pkg-plist75
1 files changed, 71 insertions, 4 deletions
diff --git a/databases/duckdb/pkg-plist b/databases/duckdb/pkg-plist
index 74b47441d676..5b03957cde64 100644
--- a/databases/duckdb/pkg-plist
+++ b/databases/duckdb/pkg-plist
@@ -37,6 +37,7 @@ include/duckdb/catalog/default/builtin_types/types.hpp
include/duckdb/catalog/default/default_functions.hpp
include/duckdb/catalog/default/default_generator.hpp
include/duckdb/catalog/default/default_schemas.hpp
+include/duckdb/catalog/default/default_table_functions.hpp
include/duckdb/catalog/default/default_types.hpp
include/duckdb/catalog/default/default_views.hpp
include/duckdb/catalog/dependency.hpp
@@ -52,12 +53,14 @@ include/duckdb/common/adbc/single_batch_array_stream.hpp
include/duckdb/common/algorithm.hpp
include/duckdb/common/allocator.hpp
include/duckdb/common/array.hpp
+include/duckdb/common/array_ptr.hpp
include/duckdb/common/arrow/appender/append_data.hpp
include/duckdb/common/arrow/appender/bool_data.hpp
include/duckdb/common/arrow/appender/enum_data.hpp
include/duckdb/common/arrow/appender/fixed_size_list_data.hpp
include/duckdb/common/arrow/appender/list.hpp
include/duckdb/common/arrow/appender/list_data.hpp
+include/duckdb/common/arrow/appender/list_view_data.hpp
include/duckdb/common/arrow/appender/map_data.hpp
include/duckdb/common/arrow/appender/scalar_data.hpp
include/duckdb/common/arrow/appender/struct_data.hpp
@@ -67,9 +70,15 @@ include/duckdb/common/arrow/arrow.hpp
include/duckdb/common/arrow/arrow_appender.hpp
include/duckdb/common/arrow/arrow_buffer.hpp
include/duckdb/common/arrow/arrow_converter.hpp
+include/duckdb/common/arrow/arrow_merge_event.hpp
+include/duckdb/common/arrow/arrow_query_result.hpp
+include/duckdb/common/arrow/arrow_util.hpp
include/duckdb/common/arrow/arrow_wrapper.hpp
include/duckdb/common/arrow/nanoarrow/nanoarrow.hpp
+include/duckdb/common/arrow/physical_arrow_batch_collector.hpp
+include/duckdb/common/arrow/physical_arrow_collector.hpp
include/duckdb/common/arrow/result_arrow_wrapper.hpp
+include/duckdb/common/arrow/schema_metadata.hpp
include/duckdb/common/assert.hpp
include/duckdb/common/atomic.hpp
include/duckdb/common/bind_helpers.hpp
@@ -79,6 +88,7 @@ include/duckdb/common/bitset.hpp
include/duckdb/common/box_renderer.hpp
include/duckdb/common/bswap.hpp
include/duckdb/common/case_insensitive_map.hpp
+include/duckdb/common/cgroups.hpp
include/duckdb/common/checksum.hpp
include/duckdb/common/chrono.hpp
include/duckdb/common/common.hpp
@@ -88,6 +98,7 @@ include/duckdb/common/crypto/md5.hpp
include/duckdb/common/deque.hpp
include/duckdb/common/dl.hpp
include/duckdb/common/enable_shared_from_this_ipp.hpp
+include/duckdb/common/encryption_state.hpp
include/duckdb/common/enum_class_hash.hpp
include/duckdb/common/enum_util.hpp
include/duckdb/common/enums/access_mode.hpp
@@ -100,6 +111,8 @@ include/duckdb/common/enums/copy_overwrite_mode.hpp
include/duckdb/common/enums/cte_materialize.hpp
include/duckdb/common/enums/date_part_specifier.hpp
include/duckdb/common/enums/debug_initialize.hpp
+include/duckdb/common/enums/destroy_buffer_upon.hpp
+include/duckdb/common/enums/explain_format.hpp
include/duckdb/common/enums/expression_type.hpp
include/duckdb/common/enums/file_compression_type.hpp
include/duckdb/common/enums/file_glob_options.hpp
@@ -109,6 +122,7 @@ include/duckdb/common/enums/join_type.hpp
include/duckdb/common/enums/joinref_type.hpp
include/duckdb/common/enums/logical_operator_type.hpp
include/duckdb/common/enums/memory_tag.hpp
+include/duckdb/common/enums/metric_type.hpp
include/duckdb/common/enums/on_create_conflict.hpp
include/duckdb/common/enums/on_entry_not_found.hpp
include/duckdb/common/enums/operator_result_type.hpp
@@ -127,6 +141,7 @@ include/duckdb/common/enums/set_operation_type.hpp
include/duckdb/common/enums/set_scope.hpp
include/duckdb/common/enums/set_type.hpp
include/duckdb/common/enums/statement_type.hpp
+include/duckdb/common/enums/stream_execution_result.hpp
include/duckdb/common/enums/subquery_type.hpp
include/duckdb/common/enums/tableref_type.hpp
include/duckdb/common/enums/undo_flags.hpp
@@ -157,7 +172,7 @@ include/duckdb/common/fstream.hpp
include/duckdb/common/gzip_file_system.hpp
include/duckdb/common/helper.hpp
include/duckdb/common/hive_partitioning.hpp
-include/duckdb/common/http_state.hpp
+include/duckdb/common/http_util.hpp
include/duckdb/common/hugeint.hpp
include/duckdb/common/index_map.hpp
include/duckdb/common/index_vector.hpp
@@ -193,9 +208,11 @@ include/duckdb/common/operator/subtract.hpp
include/duckdb/common/optional_idx.hpp
include/duckdb/common/optional_ptr.hpp
include/duckdb/common/optionally_owned_ptr.hpp
+include/duckdb/common/owning_string_map.hpp
include/duckdb/common/pair.hpp
include/duckdb/common/perfect_map_set.hpp
include/duckdb/common/pipe_file_system.hpp
+include/duckdb/common/platform.hpp
include/duckdb/common/printer.hpp
include/duckdb/common/profiler.hpp
include/duckdb/common/progress_bar/display/terminal_progress_bar_display.hpp
@@ -207,17 +224,18 @@ include/duckdb/common/radix_partitioning.hpp
include/duckdb/common/random_engine.hpp
include/duckdb/common/re2_regex.hpp
include/duckdb/common/reference_map.hpp
+include/duckdb/common/render_tree.hpp
include/duckdb/common/row_operations/row_matcher.hpp
include/duckdb/common/row_operations/row_operations.hpp
include/duckdb/common/serializer/binary_deserializer.hpp
include/duckdb/common/serializer/binary_serializer.hpp
include/duckdb/common/serializer/buffered_file_reader.hpp
include/duckdb/common/serializer/buffered_file_writer.hpp
-include/duckdb/common/serializer/deserialization_data.hpp
include/duckdb/common/serializer/deserializer.hpp
include/duckdb/common/serializer/encoding_util.hpp
include/duckdb/common/serializer/memory_stream.hpp
include/duckdb/common/serializer/read_stream.hpp
+include/duckdb/common/serializer/serialization_data.hpp
include/duckdb/common/serializer/serialization_traits.hpp
include/duckdb/common/serializer/serializer.hpp
include/duckdb/common/serializer/write_stream.hpp
@@ -238,10 +256,16 @@ include/duckdb/common/swap.hpp
include/duckdb/common/thread.hpp
include/duckdb/common/to_string.hpp
include/duckdb/common/tree_renderer.hpp
+include/duckdb/common/tree_renderer/graphviz_tree_renderer.hpp
+include/duckdb/common/tree_renderer/html_tree_renderer.hpp
+include/duckdb/common/tree_renderer/json_tree_renderer.hpp
+include/duckdb/common/tree_renderer/text_tree_renderer.hpp
include/duckdb/common/type_util.hpp
+include/duckdb/common/type_visitor.hpp
include/duckdb/common/typedefs.hpp
include/duckdb/common/types.hpp
include/duckdb/common/types/arrow_aux_data.hpp
+include/duckdb/common/types/arrow_string_view_type.hpp
include/duckdb/common/types/batched_data_collection.hpp
include/duckdb/common/types/bit.hpp
include/duckdb/common/types/blob.hpp
@@ -257,6 +281,7 @@ include/duckdb/common/types/conflict_manager.hpp
include/duckdb/common/types/constraint_conflict_info.hpp
include/duckdb/common/types/data_chunk.hpp
include/duckdb/common/types/date.hpp
+include/duckdb/common/types/date_lookup_cache.hpp
include/duckdb/common/types/datetime.hpp
include/duckdb/common/types/decimal.hpp
include/duckdb/common/types/hash.hpp
@@ -287,6 +312,7 @@ include/duckdb/common/types/uuid.hpp
include/duckdb/common/types/validity_mask.hpp
include/duckdb/common/types/value.hpp
include/duckdb/common/types/value_map.hpp
+include/duckdb/common/types/varint.hpp
include/duckdb/common/types/vector.hpp
include/duckdb/common/types/vector_buffer.hpp
include/duckdb/common/types/vector_cache.hpp
@@ -319,14 +345,22 @@ include/duckdb/core_functions/aggregate/algebraic/covar.hpp
include/duckdb/core_functions/aggregate/algebraic/stddev.hpp
include/duckdb/core_functions/aggregate/algebraic_functions.hpp
include/duckdb/core_functions/aggregate/distributive_functions.hpp
+include/duckdb/core_functions/aggregate/histogram_helpers.hpp
include/duckdb/core_functions/aggregate/holistic_functions.hpp
+include/duckdb/core_functions/aggregate/minmax_n_helpers.hpp
include/duckdb/core_functions/aggregate/nested_functions.hpp
include/duckdb/core_functions/aggregate/quantile_enum.hpp
+include/duckdb/core_functions/aggregate/quantile_helpers.hpp
+include/duckdb/core_functions/aggregate/quantile_sort_tree.hpp
+include/duckdb/core_functions/aggregate/quantile_state.hpp
include/duckdb/core_functions/aggregate/regression/regr_count.hpp
include/duckdb/core_functions/aggregate/regression/regr_slope.hpp
include/duckdb/core_functions/aggregate/regression_functions.hpp
+include/duckdb/core_functions/aggregate/sort_key_helpers.hpp
include/duckdb/core_functions/aggregate/sum_helpers.hpp
+include/duckdb/core_functions/array_kernels.hpp
include/duckdb/core_functions/core_functions.hpp
+include/duckdb/core_functions/create_sort_key.hpp
include/duckdb/core_functions/function_list.hpp
include/duckdb/core_functions/lambda_functions.hpp
include/duckdb/core_functions/scalar/array_functions.hpp
@@ -354,14 +388,16 @@ include/duckdb/execution/execution_context.hpp
include/duckdb/execution/executor.hpp
include/duckdb/execution/expression_executor.hpp
include/duckdb/execution/expression_executor_state.hpp
+include/duckdb/execution/ht_entry.hpp
include/duckdb/execution/index/art/art.hpp
include/duckdb/execution/index/art/art_key.hpp
+include/duckdb/execution/index/art/base_leaf.hpp
+include/duckdb/execution/index/art/base_node.hpp
include/duckdb/execution/index/art/iterator.hpp
include/duckdb/execution/index/art/leaf.hpp
include/duckdb/execution/index/art/node.hpp
-include/duckdb/execution/index/art/node16.hpp
include/duckdb/execution/index/art/node256.hpp
-include/duckdb/execution/index/art/node4.hpp
+include/duckdb/execution/index/art/node256_leaf.hpp
include/duckdb/execution/index/art/node48.hpp
include/duckdb/execution/index/art/prefix.hpp
include/duckdb/execution/index/bound_index.hpp
@@ -382,6 +418,7 @@ include/duckdb/execution/operator/aggregate/physical_perfecthash_aggregate.hpp
include/duckdb/execution/operator/aggregate/physical_streaming_window.hpp
include/duckdb/execution/operator/aggregate/physical_ungrouped_aggregate.hpp
include/duckdb/execution/operator/aggregate/physical_window.hpp
+include/duckdb/execution/operator/aggregate/ungrouped_aggregate_state.hpp
include/duckdb/execution/operator/csv_scanner/base_scanner.hpp
include/duckdb/execution/operator/csv_scanner/column_count_scanner.hpp
include/duckdb/execution/operator/csv_scanner/csv_buffer.hpp
@@ -392,11 +429,13 @@ include/duckdb/execution/operator/csv_scanner/csv_file_handle.hpp
include/duckdb/execution/operator/csv_scanner/csv_file_scanner.hpp
include/duckdb/execution/operator/csv_scanner/csv_option.hpp
include/duckdb/execution/operator/csv_scanner/csv_reader_options.hpp
+include/duckdb/execution/operator/csv_scanner/csv_schema.hpp
include/duckdb/execution/operator/csv_scanner/csv_sniffer.hpp
include/duckdb/execution/operator/csv_scanner/csv_state.hpp
include/duckdb/execution/operator/csv_scanner/csv_state_machine.hpp
include/duckdb/execution/operator/csv_scanner/csv_state_machine_cache.hpp
include/duckdb/execution/operator/csv_scanner/global_csv_state.hpp
+include/duckdb/execution/operator/csv_scanner/header_value.hpp
include/duckdb/execution/operator/csv_scanner/quote_rules.hpp
include/duckdb/execution/operator/csv_scanner/scanner_boundary.hpp
include/duckdb/execution/operator/csv_scanner/skip_scanner.hpp
@@ -404,6 +443,7 @@ include/duckdb/execution/operator/csv_scanner/state_machine_options.hpp
include/duckdb/execution/operator/csv_scanner/string_value_scanner.hpp
include/duckdb/execution/operator/filter/physical_filter.hpp
include/duckdb/execution/operator/helper/physical_batch_collector.hpp
+include/duckdb/execution/operator/helper/physical_buffered_batch_collector.hpp
include/duckdb/execution/operator/helper/physical_buffered_collector.hpp
include/duckdb/execution/operator/helper/physical_create_secret.hpp
include/duckdb/execution/operator/helper/physical_execute.hpp
@@ -418,12 +458,14 @@ include/duckdb/execution/operator/helper/physical_reservoir_sample.hpp
include/duckdb/execution/operator/helper/physical_reset.hpp
include/duckdb/execution/operator/helper/physical_result_collector.hpp
include/duckdb/execution/operator/helper/physical_set.hpp
+include/duckdb/execution/operator/helper/physical_set_variable.hpp
include/duckdb/execution/operator/helper/physical_streaming_limit.hpp
include/duckdb/execution/operator/helper/physical_streaming_sample.hpp
include/duckdb/execution/operator/helper/physical_transaction.hpp
include/duckdb/execution/operator/helper/physical_update_extensions.hpp
include/duckdb/execution/operator/helper/physical_vacuum.hpp
include/duckdb/execution/operator/helper/physical_verify_vector.hpp
+include/duckdb/execution/operator/join/join_filter_pushdown.hpp
include/duckdb/execution/operator/join/outer_join_marker.hpp
include/duckdb/execution/operator/join/perfect_hash_join_executor.hpp
include/duckdb/execution/operator/join/physical_asof_join.hpp
@@ -519,6 +561,10 @@ include/duckdb/function/scalar_function.hpp
include/duckdb/function/scalar_macro_function.hpp
include/duckdb/function/table/arrow.hpp
include/duckdb/function/table/arrow/arrow_duck_schema.hpp
+include/duckdb/function/table/arrow/arrow_type_info.hpp
+include/duckdb/function/table/arrow/enum/arrow_datetime_type.hpp
+include/duckdb/function/table/arrow/enum/arrow_type_info_type.hpp
+include/duckdb/function/table/arrow/enum/arrow_variable_size_type.hpp
include/duckdb/function/table/list.hpp
include/duckdb/function/table/range.hpp
include/duckdb/function/table/read_csv.hpp
@@ -531,6 +577,7 @@ include/duckdb/function/udf_function.hpp
include/duckdb/logging/http_logger.hpp
include/duckdb/main/appender.hpp
include/duckdb/main/attached_database.hpp
+include/duckdb/main/buffered_data/batched_buffered_data.hpp
include/duckdb/main/buffered_data/buffered_data.hpp
include/duckdb/main/buffered_data/simple_buffered_data.hpp
include/duckdb/main/capi/capi_internal.hpp
@@ -538,7 +585,9 @@ include/duckdb/main/capi/cast/from_decimal.hpp
include/duckdb/main/capi/cast/generic.hpp
include/duckdb/main/capi/cast/to_decimal.hpp
include/duckdb/main/capi/cast/utils.hpp
+include/duckdb/main/capi/extension_api.hpp
include/duckdb/main/chunk_scan_state.hpp
+include/duckdb/main/chunk_scan_state/batched_data_collection.hpp
include/duckdb/main/chunk_scan_state/query_result.hpp
include/duckdb/main/client_config.hpp
include/duckdb/main/client_context.hpp
@@ -567,6 +616,8 @@ include/duckdb/main/materialized_query_result.hpp
include/duckdb/main/pending_query_result.hpp
include/duckdb/main/prepared_statement.hpp
include/duckdb/main/prepared_statement_data.hpp
+include/duckdb/main/profiling_info.hpp
+include/duckdb/main/profiling_node.hpp
include/duckdb/main/query_profiler.hpp
include/duckdb/main/query_result.hpp
include/duckdb/main/relation.hpp
@@ -575,6 +626,7 @@ include/duckdb/main/relation/create_table_relation.hpp
include/duckdb/main/relation/create_view_relation.hpp
include/duckdb/main/relation/cross_product_relation.hpp
include/duckdb/main/relation/delete_relation.hpp
+include/duckdb/main/relation/delim_get_relation.hpp
include/duckdb/main/relation/distinct_relation.hpp
include/duckdb/main/relation/explain_relation.hpp
include/duckdb/main/relation/filter_relation.hpp
@@ -596,6 +648,7 @@ include/duckdb/main/relation/value_relation.hpp
include/duckdb/main/relation/view_relation.hpp
include/duckdb/main/relation/write_csv_relation.hpp
include/duckdb/main/relation/write_parquet_relation.hpp
+include/duckdb/main/secret/default_secrets.hpp
include/duckdb/main/secret/secret.hpp
include/duckdb/main/secret/secret_manager.hpp
include/duckdb/main/secret/secret_storage.hpp
@@ -603,11 +656,13 @@ include/duckdb/main/settings.hpp
include/duckdb/main/stream_query_result.hpp
include/duckdb/main/table_description.hpp
include/duckdb/main/valid_checker.hpp
+include/duckdb/optimizer/build_probe_side_optimizer.hpp
include/duckdb/optimizer/column_binding_replacer.hpp
include/duckdb/optimizer/column_lifetime_analyzer.hpp
include/duckdb/optimizer/common_aggregate_optimizer.hpp
include/duckdb/optimizer/compressed_materialization.hpp
include/duckdb/optimizer/cse_optimizer.hpp
+include/duckdb/optimizer/cte_filter_pusher.hpp
include/duckdb/optimizer/deliminator.hpp
include/duckdb/optimizer/expression_heuristics.hpp
include/duckdb/optimizer/expression_rewriter.hpp
@@ -615,6 +670,7 @@ include/duckdb/optimizer/filter_combiner.hpp
include/duckdb/optimizer/filter_pullup.hpp
include/duckdb/optimizer/filter_pushdown.hpp
include/duckdb/optimizer/in_clause_rewriter.hpp
+include/duckdb/optimizer/join_filter_pushdown_optimizer.hpp
include/duckdb/optimizer/join_order/cardinality_estimator.hpp
include/duckdb/optimizer/join_order/cost_model.hpp
include/duckdb/optimizer/join_order/join_node.hpp
@@ -625,6 +681,7 @@ include/duckdb/optimizer/join_order/query_graph.hpp
include/duckdb/optimizer/join_order/query_graph_manager.hpp
include/duckdb/optimizer/join_order/relation_manager.hpp
include/duckdb/optimizer/join_order/relation_statistics_helper.hpp
+include/duckdb/optimizer/limit_pushdown.hpp
include/duckdb/optimizer/matcher/expression_matcher.hpp
include/duckdb/optimizer/matcher/expression_type_matcher.hpp
include/duckdb/optimizer/matcher/function_matcher.hpp
@@ -649,6 +706,7 @@ include/duckdb/optimizer/rule/empty_needle_removal.hpp
include/duckdb/optimizer/rule/enum_comparison.hpp
include/duckdb/optimizer/rule/equal_or_null_simplification.hpp
include/duckdb/optimizer/rule/in_clause_simplification.hpp
+include/duckdb/optimizer/rule/join_dependent_filter.hpp
include/duckdb/optimizer/rule/like_optimizations.hpp
include/duckdb/optimizer/rule/list.hpp
include/duckdb/optimizer/rule/move_constants.hpp
@@ -670,8 +728,10 @@ include/duckdb/parallel/pipeline_event.hpp
include/duckdb/parallel/pipeline_executor.hpp
include/duckdb/parallel/pipeline_finish_event.hpp
include/duckdb/parallel/pipeline_initialize_event.hpp
+include/duckdb/parallel/pipeline_prepare_finish_event.hpp
include/duckdb/parallel/task.hpp
include/duckdb/parallel/task_counter.hpp
+include/duckdb/parallel/task_executor.hpp
include/duckdb/parallel/task_scheduler.hpp
include/duckdb/parallel/thread_context.hpp
include/duckdb/parser/base_expression.hpp
@@ -792,6 +852,7 @@ include/duckdb/parser/statement/vacuum_statement.hpp
include/duckdb/parser/tableref.hpp
include/duckdb/parser/tableref/basetableref.hpp
include/duckdb/parser/tableref/column_data_ref.hpp
+include/duckdb/parser/tableref/delimgetref.hpp
include/duckdb/parser/tableref/emptytableref.hpp
include/duckdb/parser/tableref/expressionlistref.hpp
include/duckdb/parser/tableref/joinref.hpp
@@ -811,6 +872,7 @@ include/duckdb/planner/bound_result_modifier.hpp
include/duckdb/planner/bound_statement.hpp
include/duckdb/planner/bound_tableref.hpp
include/duckdb/planner/bound_tokens.hpp
+include/duckdb/planner/collation_binding.hpp
include/duckdb/planner/column_binding.hpp
include/duckdb/planner/column_binding_map.hpp
include/duckdb/planner/constraints/bound_check_constraint.hpp
@@ -939,6 +1001,7 @@ include/duckdb/planner/table_filter.hpp
include/duckdb/planner/tableref/bound_basetableref.hpp
include/duckdb/planner/tableref/bound_column_data_ref.hpp
include/duckdb/planner/tableref/bound_cteref.hpp
+include/duckdb/planner/tableref/bound_delimgetref.hpp
include/duckdb/planner/tableref/bound_dummytableref.hpp
include/duckdb/planner/tableref/bound_expressionlistref.hpp
include/duckdb/planner/tableref/bound_joinref.hpp
@@ -1077,6 +1140,7 @@ include/duckdb/transaction/transaction_data.hpp
include/duckdb/transaction/transaction_manager.hpp
include/duckdb/transaction/undo_buffer.hpp
include/duckdb/transaction/update_info.hpp
+include/duckdb/transaction/wal_write_state.hpp
include/duckdb/verification/copied_statement_verifier.hpp
include/duckdb/verification/deserialized_statement_verifier.hpp
include/duckdb/verification/external_statement_verifier.hpp
@@ -1103,4 +1167,7 @@ lib/libduckdb_skiplistlib.a
lib/libduckdb_static.a
lib/libduckdb_utf8proc.a
lib/libduckdb_yyjson.a
+@dir include/duckdb/main/capi/header_generation/apis/v0/dev
+@dir include/duckdb/main/capi/header_generation/apis/v0/v0.0
+@dir include/duckdb/main/capi/header_generation/functions
@dir include/duckdb/storage/serialization