List of all items
Structs
- ColumnStatistics
- SpillManager
- Statistics
- TopK
- aggregates::AggregateExec
- aggregates::PhysicalGroupBy
- aggregates::group_values::metrics::GroupByMetrics
- aggregates::group_values::multi_group_by::GroupIndexView
- aggregates::group_values::multi_group_by::GroupValuesColumn
- aggregates::group_values::multi_group_by::VectorizedOperationBuffers
- aggregates::group_values::multi_group_by::boolean::BooleanGroupValueBuilder
- aggregates::group_values::multi_group_by::bytes::ByteGroupValueBuilder
- aggregates::group_values::multi_group_by::bytes_view::ByteViewGroupValueBuilder
- aggregates::group_values::multi_group_by::primitive::PrimitiveGroupValueBuilder
- aggregates::group_values::null_builder::MaybeNullBufferBuilder
- aggregates::group_values::row::GroupValuesRows
- aggregates::group_values::single_group_by::boolean::GroupValuesBoolean
- aggregates::group_values::single_group_by::bytes::GroupValuesBytes
- aggregates::group_values::single_group_by::bytes_view::GroupValuesBytesView
- aggregates::group_values::single_group_by::primitive::GroupValuesPrimitive
- aggregates::no_grouping::AggregateStream
- aggregates::no_grouping::AggregateStreamInner
- aggregates::order::GroupOrderingFull
- aggregates::order::GroupOrderingPartial
- aggregates::order::full::GroupOrderingFull
- aggregates::order::partial::GroupOrderingPartial
- aggregates::row_hash::GroupedHashAggregateStream
- aggregates::row_hash::SkipAggregationProbe
- aggregates::row_hash::SpillState
- aggregates::topk::hash_table::HashTableItem
- aggregates::topk::hash_table::PrimitiveHashTable
- aggregates::topk::hash_table::StringHashTable
- aggregates::topk::hash_table::TopKHashTable
- aggregates::topk::heap::HeapItem
- aggregates::topk::heap::PrimitiveHeap
- aggregates::topk::heap::TopKHeap
- aggregates::topk::priority_map::PriorityMap
- aggregates::topk_stream::GroupedTopKAggregateStream
- analyze::AnalyzeExec
- async_func::AsyncFuncExec
- async_func::AsyncMapper
- coalesce::LimitedBatchCoalescer
- coalesce_batches::CoalesceBatchesExec
- coalesce_batches::CoalesceBatchesStream
- coalesce_partitions::CoalescePartitionsExec
- coop::CooperativeExec
- coop::CooperativeStream
- display::DefaultDisplay
- display::DisplayableExecutionPlan
- display::GraphvizVisitor
- display::IndentVisitor
- display::ProjectSchemaDisplay
- display::TreeRenderVisitor
- display::VerboseDisplay
- empty::EmptyExec
- execution_plan::ColumnStatistics
- execution_plan::PlanProperties
- execution_plan::Statistics
- execution_plan::expressions::BinaryExpr
- execution_plan::expressions::CaseExpr
- execution_plan::expressions::CastColumnExpr
- execution_plan::expressions::CastExpr
- execution_plan::expressions::Column
- execution_plan::expressions::DynamicFilterPhysicalExpr
- execution_plan::expressions::InListExpr
- execution_plan::expressions::IsNotNullExpr
- execution_plan::expressions::IsNullExpr
- execution_plan::expressions::LambdaExpr
- execution_plan::expressions::LikeExpr
- execution_plan::expressions::Literal
- execution_plan::expressions::NegativeExpr
- execution_plan::expressions::NoOp
- execution_plan::expressions::NotExpr
- execution_plan::expressions::PhysicalSortExpr
- execution_plan::expressions::TryCastExpr
- execution_plan::expressions::UnKnownColumn
- explain::ExplainExec
- expressions::BinaryExpr
- expressions::CaseExpr
- expressions::CastColumnExpr
- expressions::CastExpr
- expressions::Column
- expressions::DynamicFilterPhysicalExpr
- expressions::InListExpr
- expressions::IsNotNullExpr
- expressions::IsNullExpr
- expressions::LambdaExpr
- expressions::LikeExpr
- expressions::Literal
- expressions::NegativeExpr
- expressions::NoOp
- expressions::NotExpr
- expressions::PhysicalSortExpr
- expressions::TryCastExpr
- expressions::UnKnownColumn
- filter::FilterExec
- filter::FilterExecMetrics
- filter::FilterExecStream
- filter_pushdown::ChildFilterDescription
- filter_pushdown::ChildFilterPushdownResult
- filter_pushdown::ChildPushdownResult
- filter_pushdown::FilterDescription
- filter_pushdown::FilterPushdownPropagation
- filter_pushdown::PushedDownPredicate
- joins::CrossJoinExec
- joins::HashJoinExec
- joins::NestedLoopJoinExec
- joins::PiecewiseMergeJoinExec
- joins::SortMergeJoinExec
- joins::SymmetricHashJoinExec
- joins::cross_join::CrossJoinExec
- joins::cross_join::CrossJoinStream
- joins::cross_join::JoinLeftData
- joins::hash_join::exec::BuildSideState
- joins::hash_join::exec::CollectLeftAccumulator
- joins::hash_join::exec::HashJoinExec
- joins::hash_join::exec::HashJoinExecDynamicFilter
- joins::hash_join::exec::JoinLeftData
- joins::hash_join::shared_bounds::ColumnBounds
- joins::hash_join::shared_bounds::PartitionBounds
- joins::hash_join::shared_bounds::SharedBoundsAccumulator
- joins::hash_join::shared_bounds::SharedBoundsState
- joins::hash_join::stream::BuildSideInitialState
- joins::hash_join::stream::BuildSideReadyState
- joins::hash_join::stream::HashJoinStream
- joins::hash_join::stream::ProcessProbeBatchState
- joins::join_filter::JoinFilter
- joins::join_hash_map::JoinHashMapU32
- joins::join_hash_map::JoinHashMapU64
- joins::nested_loop_join::JoinLeftData
- joins::nested_loop_join::NestedLoopJoinExec
- joins::nested_loop_join::NestedLoopJoinMetrics
- joins::nested_loop_join::NestedLoopJoinStream
- joins::piecewise_merge_join::classic_join::BatchProcessState
- joins::piecewise_merge_join::classic_join::ClassicPWMJStream
- joins::piecewise_merge_join::classic_join::SortedStreamBatch
- joins::piecewise_merge_join::exec::BufferedSideData
- joins::piecewise_merge_join::exec::BufferedSideInitialState
- joins::piecewise_merge_join::exec::BufferedSideReadyState
- joins::piecewise_merge_join::exec::PiecewiseMergeJoinExec
- joins::sort_merge_join::exec::SortMergeJoinExec
- joins::sort_merge_join::metrics::SortMergeJoinMetrics
- joins::sort_merge_join::stream::BufferedBatch
- joins::sort_merge_join::stream::BufferedData
- joins::sort_merge_join::stream::JoinedRecordBatches
- joins::sort_merge_join::stream::SortMergeJoinStream
- joins::sort_merge_join::stream::StreamedBatch
- joins::sort_merge_join::stream::StreamedJoinedChunk
- joins::stream_join_utils::PruningJoinHashMap
- joins::stream_join_utils::SortedFilterExpr
- joins::stream_join_utils::StreamJoinMetrics
- joins::stream_join_utils::StreamJoinSideMetrics
- joins::symmetric_hash_join::OneSideHashJoiner
- joins::symmetric_hash_join::SymmetricHashJoinExec
- joins::symmetric_hash_join::SymmetricHashJoinStream
- joins::utils::BatchSplitter
- joins::utils::BuildProbeJoinMetrics
- joins::utils::ColumnIndex
- joins::utils::JoinFilter
- joins::utils::NoopBatchTransformer
- joins::utils::OnceAsync
- joins::utils::OnceFut
- joins::utils::PartialJoinStatistics
- limit::GlobalLimitExec
- limit::LimitStream
- limit::LocalLimitExec
- memory::LazyMemoryExec
- memory::LazyMemoryStream
- memory::MemoryStream
- metrics::BaselineMetrics
- metrics::Count
- metrics::ExecutionPlanMetricsSet
- metrics::Gauge
- metrics::Label
- metrics::Metric
- metrics::MetricBuilder
- metrics::MetricsSet
- metrics::PruningMetrics
- metrics::RatioMetrics
- metrics::ScopedTimerGuard
- metrics::SpillMetrics
- metrics::SplitMetrics
- metrics::Time
- metrics::Timestamp
- metrics::baseline::BaselineMetrics
- metrics::baseline::SpillMetrics
- metrics::baseline::SplitMetrics
- metrics::builder::MetricBuilder
- metrics::value::Count
- metrics::value::Gauge
- metrics::value::PruningMetrics
- metrics::value::RatioMetrics
- metrics::value::ScopedTimerGuard
- metrics::value::Time
- metrics::value::Timestamp
- placeholder_row::PlaceholderRowExec
- projection::JoinData
- projection::ProjectionExec
- projection::ProjectionExpr
- projection::ProjectionExprs
- projection::ProjectionStream
- recursive_query::RecursiveQueryExec
- recursive_query::RecursiveQueryStream
- render_tree::Coordinate
- render_tree::RenderTree
- render_tree::RenderTreeNode
- repartition::BatchPartitioner
- repartition::ConsumingInputStreamsState
- repartition::PartitionChannels
- repartition::PerPartitionStream
- repartition::RepartitionExec
- repartition::RepartitionMetrics
- repartition::RepartitionStream
- repartition::distributor_channels::Channel
- repartition::distributor_channels::ChannelState
- repartition::distributor_channels::DistributionReceiver
- repartition::distributor_channels::DistributionSender
- repartition::distributor_channels::Gate
- repartition::distributor_channels::RecvFuture
- repartition::distributor_channels::SendError
- repartition::distributor_channels::SendFuture
- sorts::builder::BatchBuilder
- sorts::builder::BatchCursor
- sorts::cursor::ArrayValues
- sorts::cursor::ByteArrayValues
- sorts::cursor::Cursor
- sorts::cursor::PrimitiveValues
- sorts::cursor::RowValues
- sorts::merge::SortPreservingMergeStream
- sorts::multi_level_merge::MultiLevelMergeBuilder
- sorts::multi_level_merge::StreamAttachedReservation
- sorts::partial_sort::PartialSortExec
- sorts::partial_sort::PartialSortStream
- sorts::sort::ExternalSorter
- sorts::sort::ExternalSorterMetrics
- sorts::sort::SortExec
- sorts::sort_preserving_merge::SortPreservingMergeExec
- sorts::stream::FieldCursorStream
- sorts::stream::FusedStreams
- sorts::stream::ReusableRows
- sorts::stream::RowCursorStream
- sorts::streaming_merge::SortedSpillFile
- sorts::streaming_merge::StreamingMergeBuilder
- spill::IPCStreamWriter
- spill::SpillReaderStream
- spill::in_progress_spill_file::InProgressSpillFile
- spill::spill_manager::SpillManager
- stream::BatchSplitStream
- stream::EmptyRecordBatchStream
- stream::ObservedStream
- stream::ReceiverStreamBuilder
- stream::RecordBatchReceiverStreamBuilder
- stream::RecordBatchStreamAdapter
- streaming::StreamingTableExec
- test::TestMemoryExec
- test::TestPartitionStream
- test::exec::BarrierExec
- test::exec::BatchIndex
- test::exec::BlockingExec
- test::exec::BlockingStream
- test::exec::ErrorExec
- test::exec::MockExec
- test::exec::PanicExec
- test::exec::PanicStream
- test::exec::StatisticsExec
- test::exec::TestStream
- topk::RecordBatchEntry
- topk::RecordBatchStore
- topk::TopK
- topk::TopKDynamicFilters
- topk::TopKHeap
- topk::TopKMetrics
- topk::TopKRow
- tree_node::PlanContext
- udaf::AggregateFunctionExpr
- udaf::StatisticsArgs
- union::CombinedRecordBatchStream
- union::InterleaveExec
- union::UnionExec
- unnest::ListUnnest
- unnest::UnnestExec
- unnest::UnnestMetrics
- unnest::UnnestStream
- unnest::UnnestingResult
- windows::BoundedWindowAggExec
- windows::PlainAggregateWindowExpr
- windows::StandardWindowExpr
- windows::WindowAggExec
- windows::WindowUDFExpr
- windows::bounded_window_agg_exec::BoundedWindowAggExec
- windows::bounded_window_agg_exec::BoundedWindowAggStream
- windows::bounded_window_agg_exec::LinearSearch
- windows::bounded_window_agg_exec::SortedSearch
- windows::window_agg_exec::WindowAggExec
- windows::window_agg_exec::WindowAggStream
- work_table::ReservedBatches
- work_table::WorkTable
- work_table::WorkTableExec
Enums
- ColumnarValue
- Distribution
- InputOrderMode
- Partitioning
- aggregates::AggregateMode
- aggregates::StreamType
- aggregates::group_values::multi_group_by::Nulls
- aggregates::order::GroupOrdering
- aggregates::order::full::State
- aggregates::order::partial::State
- aggregates::row_hash::ExecutionState
- coalesce::PushBatchStatus
- display::DisplayFormatType
- display::ShowMetrics
- execution_plan::Boundedness
- execution_plan::CardinalityEffect
- execution_plan::ColumnarValue
- execution_plan::Distribution
- execution_plan::EmissionType
- execution_plan::EvaluationType
- execution_plan::InputOrderMode
- execution_plan::InvariantLevel
- execution_plan::Partitioning
- execution_plan::SchedulingType
- execution_plan::expressions::StatsType
- expressions::StatsType
- filter_pushdown::FilterPushdownPhase
- filter_pushdown::PushedDown
- joins::PartitionMode
- joins::StreamJoinPartitionMode
- joins::cross_join::CrossJoinStreamState
- joins::hash_join::stream::BuildSide
- joins::hash_join::stream::HashJoinStreamState
- joins::nested_loop_join::NLJState
- joins::piecewise_merge_join::classic_join::PiecewiseMergeJoinStreamState
- joins::piecewise_merge_join::exec::BufferedSide
- joins::sort_merge_join::stream::BufferedBatchState
- joins::sort_merge_join::stream::BufferedState
- joins::sort_merge_join::stream::SortMergeJoinState
- joins::sort_merge_join::stream::StreamedState
- joins::symmetric_hash_join::SHJStreamState
- joins::utils::OnceFutState
- joins::utils::StatefulStreamResult
- metrics::MetricType
- metrics::MetricValue
- metrics::value::MetricValue
- ordering::InputOrderMode
- repartition::BatchPartitionerState
- repartition::RepartitionBatch
- repartition::RepartitionExecState
- repartition::RepartitionStreamState
- spill::SpillReaderStreamState
Traits
- Accumulator
- ExecutionPlanVisitor
- PhysicalExpr
- RecordBatchStream
- WindowExpr
- aggregates::group_values::GroupValues
- aggregates::group_values::multi_group_by::GroupColumn
- aggregates::group_values::single_group_by::primitive::HashValue
- aggregates::topk::hash_table::ArrowHashTable
- aggregates::topk::hash_table::KeyType
- aggregates::topk::heap::ArrowHeap
- aggregates::topk::heap::Comparable
- aggregates::topk::heap::ValueType
- display::DisplayAs
- execution_plan::Accumulator
- execution_plan::ExecutionPlan
- execution_plan::ExecutionPlanProperties
- execution_plan::PhysicalExpr
- execution_plan::RecordBatchStream
- execution_plan::WindowExpr
- execution_plan::hash_utils::HashValue
- hash_utils::HashValue
- joins::join_hash_map::JoinHashMapType
- joins::utils::BatchTransformer
- joins::utils::JoinHashMapType
- memory::LazyBatchGenerator
- metrics::CustomMetricValue
- metrics::RecordOutput
- metrics::baseline::RecordOutput
- metrics::custom::CustomMetricValue
- projection::EmbeddedProjection
- sorts::cursor::CursorArray
- sorts::cursor::CursorValues
- sorts::stream::PartitionedStream
- spill::spill_manager::GetSlicedSize
- streaming::PartitionStream
- unnest::ListArrayType
- visitor::ExecutionPlanVisitor
- windows::WindowExpr
- windows::bounded_window_agg_exec::PartitionSearcher
Macros
- aggregates::group_values::multi_group_by::instantiate_primitive
- aggregates::group_values::single_group_by::primitive::hash_float
- aggregates::group_values::single_group_by::primitive::hash_integer
- aggregates::topk::hash_table::has_integer
- aggregates::topk::hash_table::hash_float
- aggregates::topk::heap::compare_float
- aggregates::topk::heap::compare_integer
- execution_plan::check_len
- execution_plan::internal_err
- handle_state
- internal_err
- joins::join_hash_map::chain_traverse
- sorts::streaming_merge::merge_helper
- sorts::streaming_merge::primitive_merge_helper
Functions
- accept
- aggregates::aggregate_expressions
- aggregates::concat_slices
- aggregates::create_accumulators
- aggregates::create_schema
- aggregates::determine_finer
- aggregates::evaluate
- aggregates::evaluate_group_by
- aggregates::evaluate_many
- aggregates::evaluate_optional
- aggregates::finalize_aggregation
- aggregates::get_aggregate_expr_req
- aggregates::get_finer_aggregate_exprs_requirement
- aggregates::group_id_array
- aggregates::group_values::multi_group_by::nulls_equal_to
- aggregates::group_values::multi_group_by::supported_schema
- aggregates::group_values::multi_group_by::supported_type
- aggregates::group_values::new_group_values
- aggregates::group_values::row::dictionary_encode_if_necessary
- aggregates::merge_expressions
- aggregates::no_grouping::aggregate_batch
- aggregates::row_hash::create_group_accumulator
- aggregates::topk::hash_table::new_hash_table
- aggregates::topk::heap::new_heap
- analyze::create_output_batch
- common::build_checked_file_list
- common::build_file_list
- common::build_file_list_recurse
- common::can_project
- common::collect
- common::compute_record_batch_statistics
- common::spawn_buffered
- coop::cooperative
- coop::make_cooperative
- display::display_orderings
- execution_plan::boundedness_from_children
- execution_plan::check_default_invariants
- execution_plan::check_not_null_constraints
- execution_plan::collect
- execution_plan::collect_partitioned
- execution_plan::displayable
- execution_plan::emission_type_from_children
- execution_plan::execute_input_stream
- execution_plan::execute_stream
- execution_plan::execute_stream_partitioned
- execution_plan::expressions::binary
- execution_plan::expressions::case
- execution_plan::expressions::cast
- execution_plan::expressions::col
- execution_plan::expressions::format_state_name
- execution_plan::expressions::in_list
- execution_plan::expressions::is_not_null
- execution_plan::expressions::is_null
- execution_plan::expressions::like
- execution_plan::expressions::lit
- execution_plan::expressions::negative
- execution_plan::expressions::not
- execution_plan::expressions::similar_to
- execution_plan::expressions::try_cast
- execution_plan::expressions::with_new_schema
- execution_plan::get_plan_string
- execution_plan::hash_utils::combine_hashes
- execution_plan::hash_utils::create_hashes
- execution_plan::need_data_exchange
- execution_plan::project_schema
- execution_plan::with_new_children_if_necessary
- explain::should_show
- expressions::binary
- expressions::case
- expressions::cast
- expressions::col
- expressions::format_state_name
- expressions::in_list
- expressions::is_not_null
- expressions::is_null
- expressions::like
- expressions::lit
- expressions::negative
- expressions::not
- expressions::similar_to
- expressions::try_cast
- expressions::with_new_schema
- filter::batch_filter
- filter::collect_columns_from_predicate
- filter::collect_columns_from_predicate_inner
- filter::collect_new_statistics
- filter::filter_and_project
- hash_utils::combine_hashes
- hash_utils::create_hashes
- joins::cross_join::build_batch
- joins::cross_join::load_left_input
- joins::cross_join::stats_cartesian_product
- joins::hash_join::exec::collect_left_input
- joins::hash_join::stream::lookup_join_hashmap
- joins::join_hash_map::get_matched_indices
- joins::join_hash_map::get_matched_indices_with_limit_offset
- joins::join_hash_map::update_from_iter
- joins::nested_loop_join::apply_filter_to_row_join_batch
- joins::nested_loop_join::build_row_join_batch
- joins::nested_loop_join::build_unmatched_batch
- joins::nested_loop_join::build_unmatched_batch_empty_schema
- joins::nested_loop_join::collect_left_input
- joins::nested_loop_join::create_record_batch_with_empty_schema
- joins::piecewise_merge_join::classic_join::build_matched_indices_and_set_buffered_bitmap
- joins::piecewise_merge_join::classic_join::create_unmatched_batch
- joins::piecewise_merge_join::classic_join::resolve_classic_join
- joins::piecewise_merge_join::exec::build_buffered_data
- joins::piecewise_merge_join::utils::build_visited_indices_map
- joins::piecewise_merge_join::utils::is_existence_join
- joins::piecewise_merge_join::utils::is_right_existence_join
- joins::piecewise_merge_join::utils::need_produce_result_in_final
- joins::sort_merge_join::stream::create_unmatched_columns
- joins::sort_merge_join::stream::fetch_right_columns_by_idxs
- joins::sort_merge_join::stream::fetch_right_columns_from_batch_by_idxs
- joins::sort_merge_join::stream::get_corrected_filter_mask
- joins::sort_merge_join::stream::get_filter_column
- joins::sort_merge_join::stream::is_join_arrays_equal
- joins::sort_merge_join::stream::join_arrays
- joins::sort_merge_join::stream::last_index_for_row
- joins::sort_merge_join::stream::produce_buffered_null_batch
- joins::stream_join_utils::build_filter_input_order
- joins::stream_join_utils::calculate_filter_expr_intervals
- joins::stream_join_utils::check_filter_expr_contains_sort_information
- joins::stream_join_utils::combine_two_batches
- joins::stream_join_utils::convert_filter_columns
- joins::stream_join_utils::convert_sort_expr_with_filter_schema
- joins::stream_join_utils::get_pruning_anti_indices
- joins::stream_join_utils::get_pruning_semi_indices
- joins::stream_join_utils::map_origin_col_to_filter_col
- joins::stream_join_utils::prepare_sorted_exprs
- joins::stream_join_utils::record_visited_indices
- joins::stream_join_utils::update_filter_expr_interval
- joins::stream_join_utils::update_sorted_exprs_with_node_indices
- joins::symmetric_hash_join::build_side_determined_results
- joins::symmetric_hash_join::calculate_indices_by_join_type
- joins::symmetric_hash_join::determine_prune_length
- joins::symmetric_hash_join::join_with_probe_batch
- joins::symmetric_hash_join::lookup_join_hashmap
- joins::symmetric_hash_join::need_to_produce_result_in_final
- joins::utils::adjust_indices_by_join_type
- joins::utils::adjust_right_output_partitioning
- joins::utils::append_probe_indices_in_order
- joins::utils::append_right_indices
- joins::utils::apply_join_filter_to_indices
- joins::utils::asymmetric_join_output_partitioning
- joins::utils::build_batch_empty_build_side
- joins::utils::build_batch_from_indices
- joins::utils::build_join_schema
- joins::utils::build_range_bitmap
- joins::utils::calculate_join_output_ordering
- joins::utils::check_join_is_valid
- joins::utils::check_join_set_is_valid
- joins::utils::compare_join_arrays
- joins::utils::eq_dyn_null
- joins::utils::equal_rows_arr
- joins::utils::estimate_disjoint_inputs
- joins::utils::estimate_inner_join_cardinality
- joins::utils::estimate_join_cardinality
- joins::utils::estimate_join_statistics
- joins::utils::get_anti_indices
- joins::utils::get_final_indices_from_bit_map
- joins::utils::get_final_indices_from_shared_bitmap
- joins::utils::get_mark_indices
- joins::utils::get_semi_indices
- joins::utils::max_distinct_count
- joins::utils::need_produce_result_in_final
- joins::utils::need_produce_right_in_final
- joins::utils::output_join_field
- joins::utils::reorder_output_after_swap
- joins::utils::swap_join_projection
- joins::utils::swap_reverting_projection
- joins::utils::symmetric_join_output_partitioning
- joins::utils::update_hash
- metrics::value::fmt_significant
- project_schema
- projection::all_alias_free_columns
- projection::all_columns
- projection::collect_column_indices
- projection::is_expr_trivial
- projection::is_projection_removable
- projection::join_allows_pushdown
- projection::join_table_borders
- projection::make_with_child
- projection::new_columns_for_join_on
- projection::new_indices_for_join_filter
- projection::new_join_children
- projection::new_projections_for_columns
- projection::physical_to_column_exprs
- projection::remove_unnecessary_projections
- projection::try_embed_projection
- projection::try_pushdown_through_join
- projection::try_unifying_projections
- projection::update_expr
- projection::update_join_filter
- projection::update_join_on
- projection::update_ordering
- projection::update_ordering_requirement
- recursive_query::assign_work_table
- recursive_query::reset_plan_states
- render_tree::create_tree_recursive
- render_tree::fmt_display
- render_tree::get_tree_width_height
- repartition::distributor_channels::channels
- repartition::distributor_channels::partition_aware_channels
- sorts::sort::get_reserved_byte_for_record_batch
- sorts::sort::get_reserved_byte_for_record_batch_size
- sorts::sort::sort_batch
- spill::count_array_data_memory_size
- spill::get_max_alignment_for_schema
- spill::get_record_batch_memory_size
- spill::spill_record_batch_by_size
- test::aggr_test_schema
- test::assert_is_pending
- test::build_table_i32
- test::build_table_i32_two_cols
- test::build_table_scan_i32
- test::exec::assert_strong_count_converges_to_zero
- test::exec::clone_error
- test::make_partition
- test::make_partition_utf8
- test::mem_exec
- test::mem_exec_utf8
- test::scan_partitioned
- test::scan_partitioned_utf8
- topk::build_sort_fields
- union::can_interleave
- union::col_stats_union
- union::stats_union
- union::union_schema
- unnest::build_batch
- unnest::create_take_indices
- unnest::find_longest_length
- unnest::flatten_struct_cols
- unnest::list_unnest_at_level
- unnest::repeat_arrs_from_indices
- unnest::unnest_list_array
- unnest::unnest_list_arrays
- visit_execution_plan
- visitor::accept
- visitor::visit_execution_plan
- windows::bounded_window_agg_exec::argmin
- windows::bounded_window_agg_exec::evaluate_partition_by_column_values
- windows::bounded_window_agg_exec::get_aggregate_result_out_column
- windows::bounded_window_agg_exec::get_last_row_batch
- windows::calc_requirements
- windows::create_udwf_window_expr
- windows::create_window_expr
- windows::get_best_fitting_window
- windows::get_ordered_partition_by_indices
- windows::get_partition_by_sort_exprs
- windows::get_window_mode
- windows::schema_add_window_field
- windows::sort_options_resolving_constant
- windows::utils::create_schema
- windows::window_agg_exec::compute_window_aggregates
- windows::window_equivalence_properties
- windows::window_expr_from_aggregate_expr
Type Aliases
- SendableRecordBatchStream
- aggregates::AccumulatorItem
- common::SharedMemoryReservation
- execution_plan::SendableRecordBatchStream
- filter::EqualAndNonEqual
- filter::PhysicalExprPairRef
- joins::JoinOn
- joins::JoinOnRef
- joins::SharedBitmapBuilder
- joins::join_hash_map::JoinHashMapOffset
- joins::utils::OnceFutPending
- repartition::InputPartitionsToCurrentPartitionReceiver
- repartition::InputPartitionsToCurrentPartitionSender
- repartition::MaybeBatch
- repartition::distributor_channels::PartitionAwareReceivers
- repartition::distributor_channels::PartitionAwareSenders
- repartition::distributor_channels::SharedChannel
- repartition::distributor_channels::SharedGate
- sorts::merge::CursorStream
- spill::NextRecordBatchResult
Constants
- aggregates::AGGREGATION_HASH_SEED
- aggregates::group_values::multi_group_by::NON_INLINED_FLAG
- aggregates::group_values::multi_group_by::VALUE_MASK
- aggregates::group_values::multi_group_by::bytes_view::BYTE_VIEW_MAX_BLOCK_SIZE
- async_func::ASYNC_FN_PREFIX
- filter::FILTER_EXEC_DEFAULT_SELECTIVITY
- joins::hash_join::exec::HASH_JOIN_SEED
- joins::symmetric_hash_join::HASHMAP_SHRINK_SCALE_FACTOR
- spill::SPILL_BATCH_MEMORY_MARGIN
- topk::ESTIMATED_BYTES_PER_ROW