pub enum NodeBody {
Show 35 variants
Insert(InsertNode),
Delete(DeleteNode),
Update(UpdateNode),
Project(ProjectNode),
HashAgg(HashAggNode),
Filter(FilterNode),
Exchange(ExchangeNode),
Sort(SortNode),
NestedLoopJoin(NestedLoopJoinNode),
TopN(TopNNode),
SortAgg(SortAggNode),
RowSeqScan(RowSeqScanNode),
Limit(LimitNode),
Values(ValuesNode),
HashJoin(HashJoinNode),
MergeSortExchange(MergeSortExchangeNode),
HopWindow(HopWindowNode),
TableFunction(TableFunctionNode),
SysRowSeqScan(SysRowSeqScanNode),
Expand(ExpandNode),
LocalLookupJoin(LocalLookupJoinNode),
ProjectSet(ProjectSetNode),
Union(UnionNode),
GroupTopN(GroupTopNNode),
DistributedLookupJoin(DistributedLookupJoinNode),
Source(SourceNode),
SortOverWindow(SortOverWindowNode),
MaxOneRow(MaxOneRowNode),
LogRowSeqScan(LogRowSeqScanNode),
FileScan(FileScanNode),
IcebergScan(IcebergScanNode),
PostgresQuery(PostgresQueryNode),
MysqlQuery(MySqlQueryNode),
BlockExecutor(bool),
BusyLoopExecutor(bool),
}
Variants§
Insert(InsertNode)
Delete(DeleteNode)
Update(UpdateNode)
Project(ProjectNode)
HashAgg(HashAggNode)
Filter(FilterNode)
Exchange(ExchangeNode)
Sort(SortNode)
NestedLoopJoin(NestedLoopJoinNode)
TopN(TopNNode)
SortAgg(SortAggNode)
RowSeqScan(RowSeqScanNode)
Limit(LimitNode)
Values(ValuesNode)
HashJoin(HashJoinNode)
MergeSortExchange(MergeSortExchangeNode)
HopWindow(HopWindowNode)
TableFunction(TableFunctionNode)
SysRowSeqScan(SysRowSeqScanNode)
Expand(ExpandNode)
LocalLookupJoin(LocalLookupJoinNode)
ProjectSet(ProjectSetNode)
Union(UnionNode)
GroupTopN(GroupTopNNode)
DistributedLookupJoin(DistributedLookupJoinNode)
Source(SourceNode)
SortOverWindow(SortOverWindowNode)
MaxOneRow(MaxOneRowNode)
LogRowSeqScan(LogRowSeqScanNode)
FileScan(FileScanNode)
IcebergScan(IcebergScanNode)
PostgresQuery(PostgresQueryNode)
MysqlQuery(MySqlQueryNode)
BlockExecutor(bool)
The following nodes are used for testing.
BusyLoopExecutor(bool)
Implementations§
source§impl NodeBody
impl NodeBody
sourcepub fn merge(
field: &mut Option<NodeBody>,
tag: u32,
wire_type: WireType,
buf: &mut impl Buf,
ctx: DecodeContext,
) -> Result<(), DecodeError>
pub fn merge( field: &mut Option<NodeBody>, tag: u32, wire_type: WireType, buf: &mut impl Buf, ctx: DecodeContext, ) -> Result<(), DecodeError>
Decodes an instance of the message from a buffer, and merges it into self.
sourcepub fn encoded_len(&self) -> usize
pub fn encoded_len(&self) -> usize
Returns the encoded length of the message without a length delimiter.
source§impl NodeBody
impl NodeBody
sourcepub fn as_insert_mut(&mut self) -> Option<&mut InsertNode>
pub fn as_insert_mut(&mut self) -> Option<&mut InsertNode>
Optionally returns mutable references to the inner fields if this is a NodeBody::Insert
, otherwise None
sourcepub fn as_insert(&self) -> Option<&InsertNode>
pub fn as_insert(&self) -> Option<&InsertNode>
Optionally returns references to the inner fields if this is a NodeBody::Insert
, otherwise None
sourcepub fn into_insert(self) -> Result<InsertNode, Self>
pub fn into_insert(self) -> Result<InsertNode, Self>
Returns the inner fields if this is a NodeBody::Insert
, otherwise returns back the enum in the Err
case of the result
sourcepub fn as_delete_mut(&mut self) -> Option<&mut DeleteNode>
pub fn as_delete_mut(&mut self) -> Option<&mut DeleteNode>
Optionally returns mutable references to the inner fields if this is a NodeBody::Delete
, otherwise None
sourcepub fn as_delete(&self) -> Option<&DeleteNode>
pub fn as_delete(&self) -> Option<&DeleteNode>
Optionally returns references to the inner fields if this is a NodeBody::Delete
, otherwise None
sourcepub fn into_delete(self) -> Result<DeleteNode, Self>
pub fn into_delete(self) -> Result<DeleteNode, Self>
Returns the inner fields if this is a NodeBody::Delete
, otherwise returns back the enum in the Err
case of the result
sourcepub fn as_update_mut(&mut self) -> Option<&mut UpdateNode>
pub fn as_update_mut(&mut self) -> Option<&mut UpdateNode>
Optionally returns mutable references to the inner fields if this is a NodeBody::Update
, otherwise None
sourcepub fn as_update(&self) -> Option<&UpdateNode>
pub fn as_update(&self) -> Option<&UpdateNode>
Optionally returns references to the inner fields if this is a NodeBody::Update
, otherwise None
sourcepub fn into_update(self) -> Result<UpdateNode, Self>
pub fn into_update(self) -> Result<UpdateNode, Self>
Returns the inner fields if this is a NodeBody::Update
, otherwise returns back the enum in the Err
case of the result
sourcepub fn is_project(&self) -> bool
pub fn is_project(&self) -> bool
Returns true if this is a NodeBody::Project
, otherwise false
sourcepub fn as_project_mut(&mut self) -> Option<&mut ProjectNode>
pub fn as_project_mut(&mut self) -> Option<&mut ProjectNode>
Optionally returns mutable references to the inner fields if this is a NodeBody::Project
, otherwise None
sourcepub fn as_project(&self) -> Option<&ProjectNode>
pub fn as_project(&self) -> Option<&ProjectNode>
Optionally returns references to the inner fields if this is a NodeBody::Project
, otherwise None
sourcepub fn into_project(self) -> Result<ProjectNode, Self>
pub fn into_project(self) -> Result<ProjectNode, Self>
Returns the inner fields if this is a NodeBody::Project
, otherwise returns back the enum in the Err
case of the result
sourcepub fn is_hash_agg(&self) -> bool
pub fn is_hash_agg(&self) -> bool
Returns true if this is a NodeBody::HashAgg
, otherwise false
sourcepub fn as_hash_agg_mut(&mut self) -> Option<&mut HashAggNode>
pub fn as_hash_agg_mut(&mut self) -> Option<&mut HashAggNode>
Optionally returns mutable references to the inner fields if this is a NodeBody::HashAgg
, otherwise None
sourcepub fn as_hash_agg(&self) -> Option<&HashAggNode>
pub fn as_hash_agg(&self) -> Option<&HashAggNode>
Optionally returns references to the inner fields if this is a NodeBody::HashAgg
, otherwise None
sourcepub fn into_hash_agg(self) -> Result<HashAggNode, Self>
pub fn into_hash_agg(self) -> Result<HashAggNode, Self>
Returns the inner fields if this is a NodeBody::HashAgg
, otherwise returns back the enum in the Err
case of the result
sourcepub fn as_filter_mut(&mut self) -> Option<&mut FilterNode>
pub fn as_filter_mut(&mut self) -> Option<&mut FilterNode>
Optionally returns mutable references to the inner fields if this is a NodeBody::Filter
, otherwise None
sourcepub fn as_filter(&self) -> Option<&FilterNode>
pub fn as_filter(&self) -> Option<&FilterNode>
Optionally returns references to the inner fields if this is a NodeBody::Filter
, otherwise None
sourcepub fn into_filter(self) -> Result<FilterNode, Self>
pub fn into_filter(self) -> Result<FilterNode, Self>
Returns the inner fields if this is a NodeBody::Filter
, otherwise returns back the enum in the Err
case of the result
sourcepub fn is_exchange(&self) -> bool
pub fn is_exchange(&self) -> bool
Returns true if this is a NodeBody::Exchange
, otherwise false
sourcepub fn as_exchange_mut(&mut self) -> Option<&mut ExchangeNode>
pub fn as_exchange_mut(&mut self) -> Option<&mut ExchangeNode>
Optionally returns mutable references to the inner fields if this is a NodeBody::Exchange
, otherwise None
sourcepub fn as_exchange(&self) -> Option<&ExchangeNode>
pub fn as_exchange(&self) -> Option<&ExchangeNode>
Optionally returns references to the inner fields if this is a NodeBody::Exchange
, otherwise None
sourcepub fn into_exchange(self) -> Result<ExchangeNode, Self>
pub fn into_exchange(self) -> Result<ExchangeNode, Self>
Returns the inner fields if this is a NodeBody::Exchange
, otherwise returns back the enum in the Err
case of the result
sourcepub fn as_sort_mut(&mut self) -> Option<&mut SortNode>
pub fn as_sort_mut(&mut self) -> Option<&mut SortNode>
Optionally returns mutable references to the inner fields if this is a NodeBody::Sort
, otherwise None
sourcepub fn as_sort(&self) -> Option<&SortNode>
pub fn as_sort(&self) -> Option<&SortNode>
Optionally returns references to the inner fields if this is a NodeBody::Sort
, otherwise None
sourcepub fn into_sort(self) -> Result<SortNode, Self>
pub fn into_sort(self) -> Result<SortNode, Self>
Returns the inner fields if this is a NodeBody::Sort
, otherwise returns back the enum in the Err
case of the result
sourcepub fn is_nested_loop_join(&self) -> bool
pub fn is_nested_loop_join(&self) -> bool
Returns true if this is a NodeBody::NestedLoopJoin
, otherwise false
sourcepub fn as_nested_loop_join_mut(&mut self) -> Option<&mut NestedLoopJoinNode>
pub fn as_nested_loop_join_mut(&mut self) -> Option<&mut NestedLoopJoinNode>
Optionally returns mutable references to the inner fields if this is a NodeBody::NestedLoopJoin
, otherwise None
sourcepub fn as_nested_loop_join(&self) -> Option<&NestedLoopJoinNode>
pub fn as_nested_loop_join(&self) -> Option<&NestedLoopJoinNode>
Optionally returns references to the inner fields if this is a NodeBody::NestedLoopJoin
, otherwise None
sourcepub fn into_nested_loop_join(self) -> Result<NestedLoopJoinNode, Self>
pub fn into_nested_loop_join(self) -> Result<NestedLoopJoinNode, Self>
Returns the inner fields if this is a NodeBody::NestedLoopJoin
, otherwise returns back the enum in the Err
case of the result
sourcepub fn as_top_n_mut(&mut self) -> Option<&mut TopNNode>
pub fn as_top_n_mut(&mut self) -> Option<&mut TopNNode>
Optionally returns mutable references to the inner fields if this is a NodeBody::TopN
, otherwise None
sourcepub fn as_top_n(&self) -> Option<&TopNNode>
pub fn as_top_n(&self) -> Option<&TopNNode>
Optionally returns references to the inner fields if this is a NodeBody::TopN
, otherwise None
sourcepub fn into_top_n(self) -> Result<TopNNode, Self>
pub fn into_top_n(self) -> Result<TopNNode, Self>
Returns the inner fields if this is a NodeBody::TopN
, otherwise returns back the enum in the Err
case of the result
sourcepub fn is_sort_agg(&self) -> bool
pub fn is_sort_agg(&self) -> bool
Returns true if this is a NodeBody::SortAgg
, otherwise false
sourcepub fn as_sort_agg_mut(&mut self) -> Option<&mut SortAggNode>
pub fn as_sort_agg_mut(&mut self) -> Option<&mut SortAggNode>
Optionally returns mutable references to the inner fields if this is a NodeBody::SortAgg
, otherwise None
sourcepub fn as_sort_agg(&self) -> Option<&SortAggNode>
pub fn as_sort_agg(&self) -> Option<&SortAggNode>
Optionally returns references to the inner fields if this is a NodeBody::SortAgg
, otherwise None
sourcepub fn into_sort_agg(self) -> Result<SortAggNode, Self>
pub fn into_sort_agg(self) -> Result<SortAggNode, Self>
Returns the inner fields if this is a NodeBody::SortAgg
, otherwise returns back the enum in the Err
case of the result
sourcepub fn is_row_seq_scan(&self) -> bool
pub fn is_row_seq_scan(&self) -> bool
Returns true if this is a NodeBody::RowSeqScan
, otherwise false
sourcepub fn as_row_seq_scan_mut(&mut self) -> Option<&mut RowSeqScanNode>
pub fn as_row_seq_scan_mut(&mut self) -> Option<&mut RowSeqScanNode>
Optionally returns mutable references to the inner fields if this is a NodeBody::RowSeqScan
, otherwise None
sourcepub fn as_row_seq_scan(&self) -> Option<&RowSeqScanNode>
pub fn as_row_seq_scan(&self) -> Option<&RowSeqScanNode>
Optionally returns references to the inner fields if this is a NodeBody::RowSeqScan
, otherwise None
sourcepub fn into_row_seq_scan(self) -> Result<RowSeqScanNode, Self>
pub fn into_row_seq_scan(self) -> Result<RowSeqScanNode, Self>
Returns the inner fields if this is a NodeBody::RowSeqScan
, otherwise returns back the enum in the Err
case of the result
sourcepub fn as_limit_mut(&mut self) -> Option<&mut LimitNode>
pub fn as_limit_mut(&mut self) -> Option<&mut LimitNode>
Optionally returns mutable references to the inner fields if this is a NodeBody::Limit
, otherwise None
sourcepub fn as_limit(&self) -> Option<&LimitNode>
pub fn as_limit(&self) -> Option<&LimitNode>
Optionally returns references to the inner fields if this is a NodeBody::Limit
, otherwise None
sourcepub fn into_limit(self) -> Result<LimitNode, Self>
pub fn into_limit(self) -> Result<LimitNode, Self>
Returns the inner fields if this is a NodeBody::Limit
, otherwise returns back the enum in the Err
case of the result
sourcepub fn as_values_mut(&mut self) -> Option<&mut ValuesNode>
pub fn as_values_mut(&mut self) -> Option<&mut ValuesNode>
Optionally returns mutable references to the inner fields if this is a NodeBody::Values
, otherwise None
sourcepub fn as_values(&self) -> Option<&ValuesNode>
pub fn as_values(&self) -> Option<&ValuesNode>
Optionally returns references to the inner fields if this is a NodeBody::Values
, otherwise None
sourcepub fn into_values(self) -> Result<ValuesNode, Self>
pub fn into_values(self) -> Result<ValuesNode, Self>
Returns the inner fields if this is a NodeBody::Values
, otherwise returns back the enum in the Err
case of the result
sourcepub fn is_hash_join(&self) -> bool
pub fn is_hash_join(&self) -> bool
Returns true if this is a NodeBody::HashJoin
, otherwise false
sourcepub fn as_hash_join_mut(&mut self) -> Option<&mut HashJoinNode>
pub fn as_hash_join_mut(&mut self) -> Option<&mut HashJoinNode>
Optionally returns mutable references to the inner fields if this is a NodeBody::HashJoin
, otherwise None
sourcepub fn as_hash_join(&self) -> Option<&HashJoinNode>
pub fn as_hash_join(&self) -> Option<&HashJoinNode>
Optionally returns references to the inner fields if this is a NodeBody::HashJoin
, otherwise None
sourcepub fn into_hash_join(self) -> Result<HashJoinNode, Self>
pub fn into_hash_join(self) -> Result<HashJoinNode, Self>
Returns the inner fields if this is a NodeBody::HashJoin
, otherwise returns back the enum in the Err
case of the result
sourcepub fn is_merge_sort_exchange(&self) -> bool
pub fn is_merge_sort_exchange(&self) -> bool
Returns true if this is a NodeBody::MergeSortExchange
, otherwise false
sourcepub fn as_merge_sort_exchange_mut(
&mut self,
) -> Option<&mut MergeSortExchangeNode>
pub fn as_merge_sort_exchange_mut( &mut self, ) -> Option<&mut MergeSortExchangeNode>
Optionally returns mutable references to the inner fields if this is a NodeBody::MergeSortExchange
, otherwise None
sourcepub fn as_merge_sort_exchange(&self) -> Option<&MergeSortExchangeNode>
pub fn as_merge_sort_exchange(&self) -> Option<&MergeSortExchangeNode>
Optionally returns references to the inner fields if this is a NodeBody::MergeSortExchange
, otherwise None
sourcepub fn into_merge_sort_exchange(self) -> Result<MergeSortExchangeNode, Self>
pub fn into_merge_sort_exchange(self) -> Result<MergeSortExchangeNode, Self>
Returns the inner fields if this is a NodeBody::MergeSortExchange
, otherwise returns back the enum in the Err
case of the result
sourcepub fn is_hop_window(&self) -> bool
pub fn is_hop_window(&self) -> bool
Returns true if this is a NodeBody::HopWindow
, otherwise false
sourcepub fn as_hop_window_mut(&mut self) -> Option<&mut HopWindowNode>
pub fn as_hop_window_mut(&mut self) -> Option<&mut HopWindowNode>
Optionally returns mutable references to the inner fields if this is a NodeBody::HopWindow
, otherwise None
sourcepub fn as_hop_window(&self) -> Option<&HopWindowNode>
pub fn as_hop_window(&self) -> Option<&HopWindowNode>
Optionally returns references to the inner fields if this is a NodeBody::HopWindow
, otherwise None
sourcepub fn into_hop_window(self) -> Result<HopWindowNode, Self>
pub fn into_hop_window(self) -> Result<HopWindowNode, Self>
Returns the inner fields if this is a NodeBody::HopWindow
, otherwise returns back the enum in the Err
case of the result
sourcepub fn is_table_function(&self) -> bool
pub fn is_table_function(&self) -> bool
Returns true if this is a NodeBody::TableFunction
, otherwise false
sourcepub fn as_table_function_mut(&mut self) -> Option<&mut TableFunctionNode>
pub fn as_table_function_mut(&mut self) -> Option<&mut TableFunctionNode>
Optionally returns mutable references to the inner fields if this is a NodeBody::TableFunction
, otherwise None
sourcepub fn as_table_function(&self) -> Option<&TableFunctionNode>
pub fn as_table_function(&self) -> Option<&TableFunctionNode>
Optionally returns references to the inner fields if this is a NodeBody::TableFunction
, otherwise None
sourcepub fn into_table_function(self) -> Result<TableFunctionNode, Self>
pub fn into_table_function(self) -> Result<TableFunctionNode, Self>
Returns the inner fields if this is a NodeBody::TableFunction
, otherwise returns back the enum in the Err
case of the result
sourcepub fn is_sys_row_seq_scan(&self) -> bool
pub fn is_sys_row_seq_scan(&self) -> bool
Returns true if this is a NodeBody::SysRowSeqScan
, otherwise false
sourcepub fn as_sys_row_seq_scan_mut(&mut self) -> Option<&mut SysRowSeqScanNode>
pub fn as_sys_row_seq_scan_mut(&mut self) -> Option<&mut SysRowSeqScanNode>
Optionally returns mutable references to the inner fields if this is a NodeBody::SysRowSeqScan
, otherwise None
sourcepub fn as_sys_row_seq_scan(&self) -> Option<&SysRowSeqScanNode>
pub fn as_sys_row_seq_scan(&self) -> Option<&SysRowSeqScanNode>
Optionally returns references to the inner fields if this is a NodeBody::SysRowSeqScan
, otherwise None
sourcepub fn into_sys_row_seq_scan(self) -> Result<SysRowSeqScanNode, Self>
pub fn into_sys_row_seq_scan(self) -> Result<SysRowSeqScanNode, Self>
Returns the inner fields if this is a NodeBody::SysRowSeqScan
, otherwise returns back the enum in the Err
case of the result
sourcepub fn as_expand_mut(&mut self) -> Option<&mut ExpandNode>
pub fn as_expand_mut(&mut self) -> Option<&mut ExpandNode>
Optionally returns mutable references to the inner fields if this is a NodeBody::Expand
, otherwise None
sourcepub fn as_expand(&self) -> Option<&ExpandNode>
pub fn as_expand(&self) -> Option<&ExpandNode>
Optionally returns references to the inner fields if this is a NodeBody::Expand
, otherwise None
sourcepub fn into_expand(self) -> Result<ExpandNode, Self>
pub fn into_expand(self) -> Result<ExpandNode, Self>
Returns the inner fields if this is a NodeBody::Expand
, otherwise returns back the enum in the Err
case of the result
sourcepub fn is_local_lookup_join(&self) -> bool
pub fn is_local_lookup_join(&self) -> bool
Returns true if this is a NodeBody::LocalLookupJoin
, otherwise false
sourcepub fn as_local_lookup_join_mut(&mut self) -> Option<&mut LocalLookupJoinNode>
pub fn as_local_lookup_join_mut(&mut self) -> Option<&mut LocalLookupJoinNode>
Optionally returns mutable references to the inner fields if this is a NodeBody::LocalLookupJoin
, otherwise None
sourcepub fn as_local_lookup_join(&self) -> Option<&LocalLookupJoinNode>
pub fn as_local_lookup_join(&self) -> Option<&LocalLookupJoinNode>
Optionally returns references to the inner fields if this is a NodeBody::LocalLookupJoin
, otherwise None
sourcepub fn into_local_lookup_join(self) -> Result<LocalLookupJoinNode, Self>
pub fn into_local_lookup_join(self) -> Result<LocalLookupJoinNode, Self>
Returns the inner fields if this is a NodeBody::LocalLookupJoin
, otherwise returns back the enum in the Err
case of the result
sourcepub fn is_project_set(&self) -> bool
pub fn is_project_set(&self) -> bool
Returns true if this is a NodeBody::ProjectSet
, otherwise false
sourcepub fn as_project_set_mut(&mut self) -> Option<&mut ProjectSetNode>
pub fn as_project_set_mut(&mut self) -> Option<&mut ProjectSetNode>
Optionally returns mutable references to the inner fields if this is a NodeBody::ProjectSet
, otherwise None
sourcepub fn as_project_set(&self) -> Option<&ProjectSetNode>
pub fn as_project_set(&self) -> Option<&ProjectSetNode>
Optionally returns references to the inner fields if this is a NodeBody::ProjectSet
, otherwise None
sourcepub fn into_project_set(self) -> Result<ProjectSetNode, Self>
pub fn into_project_set(self) -> Result<ProjectSetNode, Self>
Returns the inner fields if this is a NodeBody::ProjectSet
, otherwise returns back the enum in the Err
case of the result
sourcepub fn as_union_mut(&mut self) -> Option<&mut UnionNode>
pub fn as_union_mut(&mut self) -> Option<&mut UnionNode>
Optionally returns mutable references to the inner fields if this is a NodeBody::Union
, otherwise None
sourcepub fn as_union(&self) -> Option<&UnionNode>
pub fn as_union(&self) -> Option<&UnionNode>
Optionally returns references to the inner fields if this is a NodeBody::Union
, otherwise None
sourcepub fn into_union(self) -> Result<UnionNode, Self>
pub fn into_union(self) -> Result<UnionNode, Self>
Returns the inner fields if this is a NodeBody::Union
, otherwise returns back the enum in the Err
case of the result
sourcepub fn is_group_top_n(&self) -> bool
pub fn is_group_top_n(&self) -> bool
Returns true if this is a NodeBody::GroupTopN
, otherwise false
sourcepub fn as_group_top_n_mut(&mut self) -> Option<&mut GroupTopNNode>
pub fn as_group_top_n_mut(&mut self) -> Option<&mut GroupTopNNode>
Optionally returns mutable references to the inner fields if this is a NodeBody::GroupTopN
, otherwise None
sourcepub fn as_group_top_n(&self) -> Option<&GroupTopNNode>
pub fn as_group_top_n(&self) -> Option<&GroupTopNNode>
Optionally returns references to the inner fields if this is a NodeBody::GroupTopN
, otherwise None
sourcepub fn into_group_top_n(self) -> Result<GroupTopNNode, Self>
pub fn into_group_top_n(self) -> Result<GroupTopNNode, Self>
Returns the inner fields if this is a NodeBody::GroupTopN
, otherwise returns back the enum in the Err
case of the result
sourcepub fn is_distributed_lookup_join(&self) -> bool
pub fn is_distributed_lookup_join(&self) -> bool
Returns true if this is a NodeBody::DistributedLookupJoin
, otherwise false
sourcepub fn as_distributed_lookup_join_mut(
&mut self,
) -> Option<&mut DistributedLookupJoinNode>
pub fn as_distributed_lookup_join_mut( &mut self, ) -> Option<&mut DistributedLookupJoinNode>
Optionally returns mutable references to the inner fields if this is a NodeBody::DistributedLookupJoin
, otherwise None
sourcepub fn as_distributed_lookup_join(&self) -> Option<&DistributedLookupJoinNode>
pub fn as_distributed_lookup_join(&self) -> Option<&DistributedLookupJoinNode>
Optionally returns references to the inner fields if this is a NodeBody::DistributedLookupJoin
, otherwise None
sourcepub fn into_distributed_lookup_join(
self,
) -> Result<DistributedLookupJoinNode, Self>
pub fn into_distributed_lookup_join( self, ) -> Result<DistributedLookupJoinNode, Self>
Returns the inner fields if this is a NodeBody::DistributedLookupJoin
, otherwise returns back the enum in the Err
case of the result
sourcepub fn as_source_mut(&mut self) -> Option<&mut SourceNode>
pub fn as_source_mut(&mut self) -> Option<&mut SourceNode>
Optionally returns mutable references to the inner fields if this is a NodeBody::Source
, otherwise None
sourcepub fn as_source(&self) -> Option<&SourceNode>
pub fn as_source(&self) -> Option<&SourceNode>
Optionally returns references to the inner fields if this is a NodeBody::Source
, otherwise None
sourcepub fn into_source(self) -> Result<SourceNode, Self>
pub fn into_source(self) -> Result<SourceNode, Self>
Returns the inner fields if this is a NodeBody::Source
, otherwise returns back the enum in the Err
case of the result
sourcepub fn is_sort_over_window(&self) -> bool
pub fn is_sort_over_window(&self) -> bool
Returns true if this is a NodeBody::SortOverWindow
, otherwise false
sourcepub fn as_sort_over_window_mut(&mut self) -> Option<&mut SortOverWindowNode>
pub fn as_sort_over_window_mut(&mut self) -> Option<&mut SortOverWindowNode>
Optionally returns mutable references to the inner fields if this is a NodeBody::SortOverWindow
, otherwise None
sourcepub fn as_sort_over_window(&self) -> Option<&SortOverWindowNode>
pub fn as_sort_over_window(&self) -> Option<&SortOverWindowNode>
Optionally returns references to the inner fields if this is a NodeBody::SortOverWindow
, otherwise None
sourcepub fn into_sort_over_window(self) -> Result<SortOverWindowNode, Self>
pub fn into_sort_over_window(self) -> Result<SortOverWindowNode, Self>
Returns the inner fields if this is a NodeBody::SortOverWindow
, otherwise returns back the enum in the Err
case of the result
sourcepub fn is_max_one_row(&self) -> bool
pub fn is_max_one_row(&self) -> bool
Returns true if this is a NodeBody::MaxOneRow
, otherwise false
sourcepub fn as_max_one_row_mut(&mut self) -> Option<&mut MaxOneRowNode>
pub fn as_max_one_row_mut(&mut self) -> Option<&mut MaxOneRowNode>
Optionally returns mutable references to the inner fields if this is a NodeBody::MaxOneRow
, otherwise None
sourcepub fn as_max_one_row(&self) -> Option<&MaxOneRowNode>
pub fn as_max_one_row(&self) -> Option<&MaxOneRowNode>
Optionally returns references to the inner fields if this is a NodeBody::MaxOneRow
, otherwise None
sourcepub fn into_max_one_row(self) -> Result<MaxOneRowNode, Self>
pub fn into_max_one_row(self) -> Result<MaxOneRowNode, Self>
Returns the inner fields if this is a NodeBody::MaxOneRow
, otherwise returns back the enum in the Err
case of the result
sourcepub fn is_log_row_seq_scan(&self) -> bool
pub fn is_log_row_seq_scan(&self) -> bool
Returns true if this is a NodeBody::LogRowSeqScan
, otherwise false
sourcepub fn as_log_row_seq_scan_mut(&mut self) -> Option<&mut LogRowSeqScanNode>
pub fn as_log_row_seq_scan_mut(&mut self) -> Option<&mut LogRowSeqScanNode>
Optionally returns mutable references to the inner fields if this is a NodeBody::LogRowSeqScan
, otherwise None
sourcepub fn as_log_row_seq_scan(&self) -> Option<&LogRowSeqScanNode>
pub fn as_log_row_seq_scan(&self) -> Option<&LogRowSeqScanNode>
Optionally returns references to the inner fields if this is a NodeBody::LogRowSeqScan
, otherwise None
sourcepub fn into_log_row_seq_scan(self) -> Result<LogRowSeqScanNode, Self>
pub fn into_log_row_seq_scan(self) -> Result<LogRowSeqScanNode, Self>
Returns the inner fields if this is a NodeBody::LogRowSeqScan
, otherwise returns back the enum in the Err
case of the result
sourcepub fn is_file_scan(&self) -> bool
pub fn is_file_scan(&self) -> bool
Returns true if this is a NodeBody::FileScan
, otherwise false
sourcepub fn as_file_scan_mut(&mut self) -> Option<&mut FileScanNode>
pub fn as_file_scan_mut(&mut self) -> Option<&mut FileScanNode>
Optionally returns mutable references to the inner fields if this is a NodeBody::FileScan
, otherwise None
sourcepub fn as_file_scan(&self) -> Option<&FileScanNode>
pub fn as_file_scan(&self) -> Option<&FileScanNode>
Optionally returns references to the inner fields if this is a NodeBody::FileScan
, otherwise None
sourcepub fn into_file_scan(self) -> Result<FileScanNode, Self>
pub fn into_file_scan(self) -> Result<FileScanNode, Self>
Returns the inner fields if this is a NodeBody::FileScan
, otherwise returns back the enum in the Err
case of the result
sourcepub fn is_iceberg_scan(&self) -> bool
pub fn is_iceberg_scan(&self) -> bool
Returns true if this is a NodeBody::IcebergScan
, otherwise false
sourcepub fn as_iceberg_scan_mut(&mut self) -> Option<&mut IcebergScanNode>
pub fn as_iceberg_scan_mut(&mut self) -> Option<&mut IcebergScanNode>
Optionally returns mutable references to the inner fields if this is a NodeBody::IcebergScan
, otherwise None
sourcepub fn as_iceberg_scan(&self) -> Option<&IcebergScanNode>
pub fn as_iceberg_scan(&self) -> Option<&IcebergScanNode>
Optionally returns references to the inner fields if this is a NodeBody::IcebergScan
, otherwise None
sourcepub fn into_iceberg_scan(self) -> Result<IcebergScanNode, Self>
pub fn into_iceberg_scan(self) -> Result<IcebergScanNode, Self>
Returns the inner fields if this is a NodeBody::IcebergScan
, otherwise returns back the enum in the Err
case of the result
sourcepub fn is_postgres_query(&self) -> bool
pub fn is_postgres_query(&self) -> bool
Returns true if this is a NodeBody::PostgresQuery
, otherwise false
sourcepub fn as_postgres_query_mut(&mut self) -> Option<&mut PostgresQueryNode>
pub fn as_postgres_query_mut(&mut self) -> Option<&mut PostgresQueryNode>
Optionally returns mutable references to the inner fields if this is a NodeBody::PostgresQuery
, otherwise None
sourcepub fn as_postgres_query(&self) -> Option<&PostgresQueryNode>
pub fn as_postgres_query(&self) -> Option<&PostgresQueryNode>
Optionally returns references to the inner fields if this is a NodeBody::PostgresQuery
, otherwise None
sourcepub fn into_postgres_query(self) -> Result<PostgresQueryNode, Self>
pub fn into_postgres_query(self) -> Result<PostgresQueryNode, Self>
Returns the inner fields if this is a NodeBody::PostgresQuery
, otherwise returns back the enum in the Err
case of the result
sourcepub fn is_mysql_query(&self) -> bool
pub fn is_mysql_query(&self) -> bool
Returns true if this is a NodeBody::MysqlQuery
, otherwise false
sourcepub fn as_mysql_query_mut(&mut self) -> Option<&mut MySqlQueryNode>
pub fn as_mysql_query_mut(&mut self) -> Option<&mut MySqlQueryNode>
Optionally returns mutable references to the inner fields if this is a NodeBody::MysqlQuery
, otherwise None
sourcepub fn as_mysql_query(&self) -> Option<&MySqlQueryNode>
pub fn as_mysql_query(&self) -> Option<&MySqlQueryNode>
Optionally returns references to the inner fields if this is a NodeBody::MysqlQuery
, otherwise None
sourcepub fn into_mysql_query(self) -> Result<MySqlQueryNode, Self>
pub fn into_mysql_query(self) -> Result<MySqlQueryNode, Self>
Returns the inner fields if this is a NodeBody::MysqlQuery
, otherwise returns back the enum in the Err
case of the result
sourcepub fn is_block_executor(&self) -> bool
pub fn is_block_executor(&self) -> bool
Returns true if this is a NodeBody::BlockExecutor
, otherwise false
sourcepub fn as_block_executor_mut(&mut self) -> Option<&mut bool>
pub fn as_block_executor_mut(&mut self) -> Option<&mut bool>
Optionally returns mutable references to the inner fields if this is a NodeBody::BlockExecutor
, otherwise None
sourcepub fn as_block_executor(&self) -> Option<&bool>
pub fn as_block_executor(&self) -> Option<&bool>
Optionally returns references to the inner fields if this is a NodeBody::BlockExecutor
, otherwise None
sourcepub fn into_block_executor(self) -> Result<bool, Self>
pub fn into_block_executor(self) -> Result<bool, Self>
Returns the inner fields if this is a NodeBody::BlockExecutor
, otherwise returns back the enum in the Err
case of the result
sourcepub fn is_busy_loop_executor(&self) -> bool
pub fn is_busy_loop_executor(&self) -> bool
Returns true if this is a NodeBody::BusyLoopExecutor
, otherwise false
sourcepub fn as_busy_loop_executor_mut(&mut self) -> Option<&mut bool>
pub fn as_busy_loop_executor_mut(&mut self) -> Option<&mut bool>
Optionally returns mutable references to the inner fields if this is a NodeBody::BusyLoopExecutor
, otherwise None
sourcepub fn as_busy_loop_executor(&self) -> Option<&bool>
pub fn as_busy_loop_executor(&self) -> Option<&bool>
Optionally returns references to the inner fields if this is a NodeBody::BusyLoopExecutor
, otherwise None
sourcepub fn into_busy_loop_executor(self) -> Result<bool, Self>
pub fn into_busy_loop_executor(self) -> Result<bool, Self>
Returns the inner fields if this is a NodeBody::BusyLoopExecutor
, otherwise returns back the enum in the Err
case of the result
Trait Implementations§
impl StructuralPartialEq for NodeBody
Auto Trait Implementations§
impl Freeze for NodeBody
impl RefUnwindSafe for NodeBody
impl Send for NodeBody
impl Sync for NodeBody
impl Unpin for NodeBody
impl UnwindSafe for NodeBody
Blanket Implementations§
source§impl<T> BorrowMut<T> for Twhere
T: ?Sized,
impl<T> BorrowMut<T> for Twhere
T: ?Sized,
source§fn borrow_mut(&mut self) -> &mut T
fn borrow_mut(&mut self) -> &mut T
source§impl<T> CloneToUninit for Twhere
T: Clone,
impl<T> CloneToUninit for Twhere
T: Clone,
source§unsafe fn clone_to_uninit(&self, dst: *mut T)
unsafe fn clone_to_uninit(&self, dst: *mut T)
clone_to_uninit
)§impl<T> Instrument for T
impl<T> Instrument for T
§fn instrument(self, span: Span) -> Instrumented<Self>
fn instrument(self, span: Span) -> Instrumented<Self>
§fn in_current_span(self) -> Instrumented<Self>
fn in_current_span(self) -> Instrumented<Self>
source§impl<T> IntoRequest<T> for T
impl<T> IntoRequest<T> for T
source§fn into_request(self) -> Request<T>
fn into_request(self) -> Request<T>
T
in a tonic::Request