pub enum NodeBody {
Show 47 variants
Source(SourceNode),
Project(ProjectNode),
Filter(FilterNode),
Materialize(MaterializeNode),
StatelessSimpleAgg(SimpleAggNode),
SimpleAgg(SimpleAggNode),
HashAgg(HashAggNode),
AppendOnlyTopN(TopNNode),
HashJoin(HashJoinNode),
TopN(TopNNode),
HopWindow(HopWindowNode),
Merge(MergeNode),
Exchange(ExchangeNode),
StreamScan(StreamScanNode),
BatchPlan(BatchPlanNode),
Lookup(LookupNode),
Arrange(ArrangeNode),
LookupUnion(LookupUnionNode),
Union(UnionNode),
DeltaIndexJoin(DeltaIndexJoinNode),
Sink(SinkNode),
Expand(ExpandNode),
DynamicFilter(DynamicFilterNode),
ProjectSet(ProjectSetNode),
GroupTopN(GroupTopNNode),
Sort(SortNode),
WatermarkFilter(WatermarkFilterNode),
Dml(DmlNode),
RowIdGen(RowIdGenNode),
Now(NowNode),
AppendOnlyGroupTopN(GroupTopNNode),
TemporalJoin(TemporalJoinNode),
BarrierRecv(BarrierRecvNode),
Values(ValuesNode),
AppendOnlyDedup(DedupNode),
NoOp(NoOpNode),
EowcOverWindow(EowcOverWindowNode),
OverWindow(OverWindowNode),
StreamFsFetch(StreamFsFetchNode),
StreamCdcScan(StreamCdcScanNode),
CdcFilter(CdcFilterNode),
SourceBackfill(SourceBackfillNode),
Changelog(ChangeLogNode),
LocalApproxPercentile(LocalApproxPercentileNode),
GlobalApproxPercentile(GlobalApproxPercentileNode),
RowMerge(RowMergeNode),
AsOfJoin(AsOfJoinNode),
}
Variants§
Source(SourceNode)
Project(ProjectNode)
Filter(FilterNode)
Materialize(MaterializeNode)
StatelessSimpleAgg(SimpleAggNode)
SimpleAgg(SimpleAggNode)
HashAgg(HashAggNode)
AppendOnlyTopN(TopNNode)
HashJoin(HashJoinNode)
TopN(TopNNode)
HopWindow(HopWindowNode)
Merge(MergeNode)
Exchange(ExchangeNode)
StreamScan(StreamScanNode)
BatchPlan(BatchPlanNode)
Lookup(LookupNode)
Arrange(ArrangeNode)
LookupUnion(LookupUnionNode)
Union(UnionNode)
DeltaIndexJoin(DeltaIndexJoinNode)
Sink(SinkNode)
Expand(ExpandNode)
DynamicFilter(DynamicFilterNode)
ProjectSet(ProjectSetNode)
GroupTopN(GroupTopNNode)
Sort(SortNode)
WatermarkFilter(WatermarkFilterNode)
Dml(DmlNode)
RowIdGen(RowIdGenNode)
Now(NowNode)
AppendOnlyGroupTopN(GroupTopNNode)
TemporalJoin(TemporalJoinNode)
BarrierRecv(BarrierRecvNode)
Values(ValuesNode)
AppendOnlyDedup(DedupNode)
NoOp(NoOpNode)
EowcOverWindow(EowcOverWindowNode)
OverWindow(OverWindowNode)
StreamFsFetch(StreamFsFetchNode)
StreamCdcScan(StreamCdcScanNode)
CdcFilter(CdcFilterNode)
SourceBackfill(SourceBackfillNode)
Changelog(ChangeLogNode)
LocalApproxPercentile(LocalApproxPercentileNode)
GlobalApproxPercentile(GlobalApproxPercentileNode)
RowMerge(RowMergeNode)
AsOfJoin(AsOfJoinNode)
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_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_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 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_materialize(&self) -> bool
pub fn is_materialize(&self) -> bool
Returns true if this is a NodeBody::Materialize
, otherwise false
sourcepub fn as_materialize_mut(&mut self) -> Option<&mut MaterializeNode>
pub fn as_materialize_mut(&mut self) -> Option<&mut MaterializeNode>
Optionally returns mutable references to the inner fields if this is a NodeBody::Materialize
, otherwise None
sourcepub fn as_materialize(&self) -> Option<&MaterializeNode>
pub fn as_materialize(&self) -> Option<&MaterializeNode>
Optionally returns references to the inner fields if this is a NodeBody::Materialize
, otherwise None
sourcepub fn into_materialize(self) -> Result<MaterializeNode, Self>
pub fn into_materialize(self) -> Result<MaterializeNode, Self>
Returns the inner fields if this is a NodeBody::Materialize
, otherwise returns back the enum in the Err
case of the result
sourcepub fn is_stateless_simple_agg(&self) -> bool
pub fn is_stateless_simple_agg(&self) -> bool
Returns true if this is a NodeBody::StatelessSimpleAgg
, otherwise false
sourcepub fn as_stateless_simple_agg_mut(&mut self) -> Option<&mut SimpleAggNode>
pub fn as_stateless_simple_agg_mut(&mut self) -> Option<&mut SimpleAggNode>
Optionally returns mutable references to the inner fields if this is a NodeBody::StatelessSimpleAgg
, otherwise None
sourcepub fn as_stateless_simple_agg(&self) -> Option<&SimpleAggNode>
pub fn as_stateless_simple_agg(&self) -> Option<&SimpleAggNode>
Optionally returns references to the inner fields if this is a NodeBody::StatelessSimpleAgg
, otherwise None
sourcepub fn into_stateless_simple_agg(self) -> Result<SimpleAggNode, Self>
pub fn into_stateless_simple_agg(self) -> Result<SimpleAggNode, Self>
Returns the inner fields if this is a NodeBody::StatelessSimpleAgg
, otherwise returns back the enum in the Err
case of the result
sourcepub fn is_simple_agg(&self) -> bool
pub fn is_simple_agg(&self) -> bool
Returns true if this is a NodeBody::SimpleAgg
, otherwise false
sourcepub fn as_simple_agg_mut(&mut self) -> Option<&mut SimpleAggNode>
pub fn as_simple_agg_mut(&mut self) -> Option<&mut SimpleAggNode>
Optionally returns mutable references to the inner fields if this is a NodeBody::SimpleAgg
, otherwise None
sourcepub fn as_simple_agg(&self) -> Option<&SimpleAggNode>
pub fn as_simple_agg(&self) -> Option<&SimpleAggNode>
Optionally returns references to the inner fields if this is a NodeBody::SimpleAgg
, otherwise None
sourcepub fn into_simple_agg(self) -> Result<SimpleAggNode, Self>
pub fn into_simple_agg(self) -> Result<SimpleAggNode, Self>
Returns the inner fields if this is a NodeBody::SimpleAgg
, 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 is_append_only_top_n(&self) -> bool
pub fn is_append_only_top_n(&self) -> bool
Returns true if this is a NodeBody::AppendOnlyTopN
, otherwise false
sourcepub fn as_append_only_top_n_mut(&mut self) -> Option<&mut TopNNode>
pub fn as_append_only_top_n_mut(&mut self) -> Option<&mut TopNNode>
Optionally returns mutable references to the inner fields if this is a NodeBody::AppendOnlyTopN
, otherwise None
sourcepub fn as_append_only_top_n(&self) -> Option<&TopNNode>
pub fn as_append_only_top_n(&self) -> Option<&TopNNode>
Optionally returns references to the inner fields if this is a NodeBody::AppendOnlyTopN
, otherwise None
sourcepub fn into_append_only_top_n(self) -> Result<TopNNode, Self>
pub fn into_append_only_top_n(self) -> Result<TopNNode, Self>
Returns the inner fields if this is a NodeBody::AppendOnlyTopN
, 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 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_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 as_merge_mut(&mut self) -> Option<&mut MergeNode>
pub fn as_merge_mut(&mut self) -> Option<&mut MergeNode>
Optionally returns mutable references to the inner fields if this is a NodeBody::Merge
, otherwise None
sourcepub fn as_merge(&self) -> Option<&MergeNode>
pub fn as_merge(&self) -> Option<&MergeNode>
Optionally returns references to the inner fields if this is a NodeBody::Merge
, otherwise None
sourcepub fn into_merge(self) -> Result<MergeNode, Self>
pub fn into_merge(self) -> Result<MergeNode, Self>
Returns the inner fields if this is a NodeBody::Merge
, 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 is_stream_scan(&self) -> bool
pub fn is_stream_scan(&self) -> bool
Returns true if this is a NodeBody::StreamScan
, otherwise false
sourcepub fn as_stream_scan_mut(&mut self) -> Option<&mut StreamScanNode>
pub fn as_stream_scan_mut(&mut self) -> Option<&mut StreamScanNode>
Optionally returns mutable references to the inner fields if this is a NodeBody::StreamScan
, otherwise None
sourcepub fn as_stream_scan(&self) -> Option<&StreamScanNode>
pub fn as_stream_scan(&self) -> Option<&StreamScanNode>
Optionally returns references to the inner fields if this is a NodeBody::StreamScan
, otherwise None
sourcepub fn into_stream_scan(self) -> Result<StreamScanNode, Self>
pub fn into_stream_scan(self) -> Result<StreamScanNode, Self>
Returns the inner fields if this is a NodeBody::StreamScan
, otherwise returns back the enum in the Err
case of the result
sourcepub fn is_batch_plan(&self) -> bool
pub fn is_batch_plan(&self) -> bool
Returns true if this is a NodeBody::BatchPlan
, otherwise false
sourcepub fn as_batch_plan_mut(&mut self) -> Option<&mut BatchPlanNode>
pub fn as_batch_plan_mut(&mut self) -> Option<&mut BatchPlanNode>
Optionally returns mutable references to the inner fields if this is a NodeBody::BatchPlan
, otherwise None
sourcepub fn as_batch_plan(&self) -> Option<&BatchPlanNode>
pub fn as_batch_plan(&self) -> Option<&BatchPlanNode>
Optionally returns references to the inner fields if this is a NodeBody::BatchPlan
, otherwise None
sourcepub fn into_batch_plan(self) -> Result<BatchPlanNode, Self>
pub fn into_batch_plan(self) -> Result<BatchPlanNode, Self>
Returns the inner fields if this is a NodeBody::BatchPlan
, otherwise returns back the enum in the Err
case of the result
sourcepub fn as_lookup_mut(&mut self) -> Option<&mut LookupNode>
pub fn as_lookup_mut(&mut self) -> Option<&mut LookupNode>
Optionally returns mutable references to the inner fields if this is a NodeBody::Lookup
, otherwise None
sourcepub fn as_lookup(&self) -> Option<&LookupNode>
pub fn as_lookup(&self) -> Option<&LookupNode>
Optionally returns references to the inner fields if this is a NodeBody::Lookup
, otherwise None
sourcepub fn into_lookup(self) -> Result<LookupNode, Self>
pub fn into_lookup(self) -> Result<LookupNode, Self>
Returns the inner fields if this is a NodeBody::Lookup
, otherwise returns back the enum in the Err
case of the result
sourcepub fn is_arrange(&self) -> bool
pub fn is_arrange(&self) -> bool
Returns true if this is a NodeBody::Arrange
, otherwise false
sourcepub fn as_arrange_mut(&mut self) -> Option<&mut ArrangeNode>
pub fn as_arrange_mut(&mut self) -> Option<&mut ArrangeNode>
Optionally returns mutable references to the inner fields if this is a NodeBody::Arrange
, otherwise None
sourcepub fn as_arrange(&self) -> Option<&ArrangeNode>
pub fn as_arrange(&self) -> Option<&ArrangeNode>
Optionally returns references to the inner fields if this is a NodeBody::Arrange
, otherwise None
sourcepub fn into_arrange(self) -> Result<ArrangeNode, Self>
pub fn into_arrange(self) -> Result<ArrangeNode, Self>
Returns the inner fields if this is a NodeBody::Arrange
, otherwise returns back the enum in the Err
case of the result
sourcepub fn is_lookup_union(&self) -> bool
pub fn is_lookup_union(&self) -> bool
Returns true if this is a NodeBody::LookupUnion
, otherwise false
sourcepub fn as_lookup_union_mut(&mut self) -> Option<&mut LookupUnionNode>
pub fn as_lookup_union_mut(&mut self) -> Option<&mut LookupUnionNode>
Optionally returns mutable references to the inner fields if this is a NodeBody::LookupUnion
, otherwise None
sourcepub fn as_lookup_union(&self) -> Option<&LookupUnionNode>
pub fn as_lookup_union(&self) -> Option<&LookupUnionNode>
Optionally returns references to the inner fields if this is a NodeBody::LookupUnion
, otherwise None
sourcepub fn into_lookup_union(self) -> Result<LookupUnionNode, Self>
pub fn into_lookup_union(self) -> Result<LookupUnionNode, Self>
Returns the inner fields if this is a NodeBody::LookupUnion
, 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_delta_index_join(&self) -> bool
pub fn is_delta_index_join(&self) -> bool
Returns true if this is a NodeBody::DeltaIndexJoin
, otherwise false
sourcepub fn as_delta_index_join_mut(&mut self) -> Option<&mut DeltaIndexJoinNode>
pub fn as_delta_index_join_mut(&mut self) -> Option<&mut DeltaIndexJoinNode>
Optionally returns mutable references to the inner fields if this is a NodeBody::DeltaIndexJoin
, otherwise None
sourcepub fn as_delta_index_join(&self) -> Option<&DeltaIndexJoinNode>
pub fn as_delta_index_join(&self) -> Option<&DeltaIndexJoinNode>
Optionally returns references to the inner fields if this is a NodeBody::DeltaIndexJoin
, otherwise None
sourcepub fn into_delta_index_join(self) -> Result<DeltaIndexJoinNode, Self>
pub fn into_delta_index_join(self) -> Result<DeltaIndexJoinNode, Self>
Returns the inner fields if this is a NodeBody::DeltaIndexJoin
, otherwise returns back the enum in the Err
case of the result
sourcepub fn as_sink_mut(&mut self) -> Option<&mut SinkNode>
pub fn as_sink_mut(&mut self) -> Option<&mut SinkNode>
Optionally returns mutable references to the inner fields if this is a NodeBody::Sink
, otherwise None
sourcepub fn as_sink(&self) -> Option<&SinkNode>
pub fn as_sink(&self) -> Option<&SinkNode>
Optionally returns references to the inner fields if this is a NodeBody::Sink
, otherwise None
sourcepub fn into_sink(self) -> Result<SinkNode, Self>
pub fn into_sink(self) -> Result<SinkNode, Self>
Returns the inner fields if this is a NodeBody::Sink
, 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_dynamic_filter(&self) -> bool
pub fn is_dynamic_filter(&self) -> bool
Returns true if this is a NodeBody::DynamicFilter
, otherwise false
sourcepub fn as_dynamic_filter_mut(&mut self) -> Option<&mut DynamicFilterNode>
pub fn as_dynamic_filter_mut(&mut self) -> Option<&mut DynamicFilterNode>
Optionally returns mutable references to the inner fields if this is a NodeBody::DynamicFilter
, otherwise None
sourcepub fn as_dynamic_filter(&self) -> Option<&DynamicFilterNode>
pub fn as_dynamic_filter(&self) -> Option<&DynamicFilterNode>
Optionally returns references to the inner fields if this is a NodeBody::DynamicFilter
, otherwise None
sourcepub fn into_dynamic_filter(self) -> Result<DynamicFilterNode, Self>
pub fn into_dynamic_filter(self) -> Result<DynamicFilterNode, Self>
Returns the inner fields if this is a NodeBody::DynamicFilter
, 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 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 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_watermark_filter(&self) -> bool
pub fn is_watermark_filter(&self) -> bool
Returns true if this is a NodeBody::WatermarkFilter
, otherwise false
sourcepub fn as_watermark_filter_mut(&mut self) -> Option<&mut WatermarkFilterNode>
pub fn as_watermark_filter_mut(&mut self) -> Option<&mut WatermarkFilterNode>
Optionally returns mutable references to the inner fields if this is a NodeBody::WatermarkFilter
, otherwise None
sourcepub fn as_watermark_filter(&self) -> Option<&WatermarkFilterNode>
pub fn as_watermark_filter(&self) -> Option<&WatermarkFilterNode>
Optionally returns references to the inner fields if this is a NodeBody::WatermarkFilter
, otherwise None
sourcepub fn into_watermark_filter(self) -> Result<WatermarkFilterNode, Self>
pub fn into_watermark_filter(self) -> Result<WatermarkFilterNode, Self>
Returns the inner fields if this is a NodeBody::WatermarkFilter
, otherwise returns back the enum in the Err
case of the result
sourcepub fn as_dml_mut(&mut self) -> Option<&mut DmlNode>
pub fn as_dml_mut(&mut self) -> Option<&mut DmlNode>
Optionally returns mutable references to the inner fields if this is a NodeBody::Dml
, otherwise None
sourcepub fn as_dml(&self) -> Option<&DmlNode>
pub fn as_dml(&self) -> Option<&DmlNode>
Optionally returns references to the inner fields if this is a NodeBody::Dml
, otherwise None
sourcepub fn into_dml(self) -> Result<DmlNode, Self>
pub fn into_dml(self) -> Result<DmlNode, Self>
Returns the inner fields if this is a NodeBody::Dml
, otherwise returns back the enum in the Err
case of the result
sourcepub fn is_row_id_gen(&self) -> bool
pub fn is_row_id_gen(&self) -> bool
Returns true if this is a NodeBody::RowIdGen
, otherwise false
sourcepub fn as_row_id_gen_mut(&mut self) -> Option<&mut RowIdGenNode>
pub fn as_row_id_gen_mut(&mut self) -> Option<&mut RowIdGenNode>
Optionally returns mutable references to the inner fields if this is a NodeBody::RowIdGen
, otherwise None
sourcepub fn as_row_id_gen(&self) -> Option<&RowIdGenNode>
pub fn as_row_id_gen(&self) -> Option<&RowIdGenNode>
Optionally returns references to the inner fields if this is a NodeBody::RowIdGen
, otherwise None
sourcepub fn into_row_id_gen(self) -> Result<RowIdGenNode, Self>
pub fn into_row_id_gen(self) -> Result<RowIdGenNode, Self>
Returns the inner fields if this is a NodeBody::RowIdGen
, otherwise returns back the enum in the Err
case of the result
sourcepub fn as_now_mut(&mut self) -> Option<&mut NowNode>
pub fn as_now_mut(&mut self) -> Option<&mut NowNode>
Optionally returns mutable references to the inner fields if this is a NodeBody::Now
, otherwise None
sourcepub fn as_now(&self) -> Option<&NowNode>
pub fn as_now(&self) -> Option<&NowNode>
Optionally returns references to the inner fields if this is a NodeBody::Now
, otherwise None
sourcepub fn into_now(self) -> Result<NowNode, Self>
pub fn into_now(self) -> Result<NowNode, Self>
Returns the inner fields if this is a NodeBody::Now
, otherwise returns back the enum in the Err
case of the result
sourcepub fn is_append_only_group_top_n(&self) -> bool
pub fn is_append_only_group_top_n(&self) -> bool
Returns true if this is a NodeBody::AppendOnlyGroupTopN
, otherwise false
sourcepub fn as_append_only_group_top_n_mut(&mut self) -> Option<&mut GroupTopNNode>
pub fn as_append_only_group_top_n_mut(&mut self) -> Option<&mut GroupTopNNode>
Optionally returns mutable references to the inner fields if this is a NodeBody::AppendOnlyGroupTopN
, otherwise None
sourcepub fn as_append_only_group_top_n(&self) -> Option<&GroupTopNNode>
pub fn as_append_only_group_top_n(&self) -> Option<&GroupTopNNode>
Optionally returns references to the inner fields if this is a NodeBody::AppendOnlyGroupTopN
, otherwise None
sourcepub fn into_append_only_group_top_n(self) -> Result<GroupTopNNode, Self>
pub fn into_append_only_group_top_n(self) -> Result<GroupTopNNode, Self>
Returns the inner fields if this is a NodeBody::AppendOnlyGroupTopN
, otherwise returns back the enum in the Err
case of the result
sourcepub fn is_temporal_join(&self) -> bool
pub fn is_temporal_join(&self) -> bool
Returns true if this is a NodeBody::TemporalJoin
, otherwise false
sourcepub fn as_temporal_join_mut(&mut self) -> Option<&mut TemporalJoinNode>
pub fn as_temporal_join_mut(&mut self) -> Option<&mut TemporalJoinNode>
Optionally returns mutable references to the inner fields if this is a NodeBody::TemporalJoin
, otherwise None
sourcepub fn as_temporal_join(&self) -> Option<&TemporalJoinNode>
pub fn as_temporal_join(&self) -> Option<&TemporalJoinNode>
Optionally returns references to the inner fields if this is a NodeBody::TemporalJoin
, otherwise None
sourcepub fn into_temporal_join(self) -> Result<TemporalJoinNode, Self>
pub fn into_temporal_join(self) -> Result<TemporalJoinNode, Self>
Returns the inner fields if this is a NodeBody::TemporalJoin
, otherwise returns back the enum in the Err
case of the result
sourcepub fn is_barrier_recv(&self) -> bool
pub fn is_barrier_recv(&self) -> bool
Returns true if this is a NodeBody::BarrierRecv
, otherwise false
sourcepub fn as_barrier_recv_mut(&mut self) -> Option<&mut BarrierRecvNode>
pub fn as_barrier_recv_mut(&mut self) -> Option<&mut BarrierRecvNode>
Optionally returns mutable references to the inner fields if this is a NodeBody::BarrierRecv
, otherwise None
sourcepub fn as_barrier_recv(&self) -> Option<&BarrierRecvNode>
pub fn as_barrier_recv(&self) -> Option<&BarrierRecvNode>
Optionally returns references to the inner fields if this is a NodeBody::BarrierRecv
, otherwise None
sourcepub fn into_barrier_recv(self) -> Result<BarrierRecvNode, Self>
pub fn into_barrier_recv(self) -> Result<BarrierRecvNode, Self>
Returns the inner fields if this is a NodeBody::BarrierRecv
, 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_append_only_dedup(&self) -> bool
pub fn is_append_only_dedup(&self) -> bool
Returns true if this is a NodeBody::AppendOnlyDedup
, otherwise false
sourcepub fn as_append_only_dedup_mut(&mut self) -> Option<&mut DedupNode>
pub fn as_append_only_dedup_mut(&mut self) -> Option<&mut DedupNode>
Optionally returns mutable references to the inner fields if this is a NodeBody::AppendOnlyDedup
, otherwise None
sourcepub fn as_append_only_dedup(&self) -> Option<&DedupNode>
pub fn as_append_only_dedup(&self) -> Option<&DedupNode>
Optionally returns references to the inner fields if this is a NodeBody::AppendOnlyDedup
, otherwise None
sourcepub fn into_append_only_dedup(self) -> Result<DedupNode, Self>
pub fn into_append_only_dedup(self) -> Result<DedupNode, Self>
Returns the inner fields if this is a NodeBody::AppendOnlyDedup
, otherwise returns back the enum in the Err
case of the result
sourcepub fn as_no_op_mut(&mut self) -> Option<&mut NoOpNode>
pub fn as_no_op_mut(&mut self) -> Option<&mut NoOpNode>
Optionally returns mutable references to the inner fields if this is a NodeBody::NoOp
, otherwise None
sourcepub fn as_no_op(&self) -> Option<&NoOpNode>
pub fn as_no_op(&self) -> Option<&NoOpNode>
Optionally returns references to the inner fields if this is a NodeBody::NoOp
, otherwise None
sourcepub fn into_no_op(self) -> Result<NoOpNode, Self>
pub fn into_no_op(self) -> Result<NoOpNode, Self>
Returns the inner fields if this is a NodeBody::NoOp
, otherwise returns back the enum in the Err
case of the result
sourcepub fn is_eowc_over_window(&self) -> bool
pub fn is_eowc_over_window(&self) -> bool
Returns true if this is a NodeBody::EowcOverWindow
, otherwise false
sourcepub fn as_eowc_over_window_mut(&mut self) -> Option<&mut EowcOverWindowNode>
pub fn as_eowc_over_window_mut(&mut self) -> Option<&mut EowcOverWindowNode>
Optionally returns mutable references to the inner fields if this is a NodeBody::EowcOverWindow
, otherwise None
sourcepub fn as_eowc_over_window(&self) -> Option<&EowcOverWindowNode>
pub fn as_eowc_over_window(&self) -> Option<&EowcOverWindowNode>
Optionally returns references to the inner fields if this is a NodeBody::EowcOverWindow
, otherwise None
sourcepub fn into_eowc_over_window(self) -> Result<EowcOverWindowNode, Self>
pub fn into_eowc_over_window(self) -> Result<EowcOverWindowNode, Self>
Returns the inner fields if this is a NodeBody::EowcOverWindow
, otherwise returns back the enum in the Err
case of the result
sourcepub fn is_over_window(&self) -> bool
pub fn is_over_window(&self) -> bool
Returns true if this is a NodeBody::OverWindow
, otherwise false
sourcepub fn as_over_window_mut(&mut self) -> Option<&mut OverWindowNode>
pub fn as_over_window_mut(&mut self) -> Option<&mut OverWindowNode>
Optionally returns mutable references to the inner fields if this is a NodeBody::OverWindow
, otherwise None
sourcepub fn as_over_window(&self) -> Option<&OverWindowNode>
pub fn as_over_window(&self) -> Option<&OverWindowNode>
Optionally returns references to the inner fields if this is a NodeBody::OverWindow
, otherwise None
sourcepub fn into_over_window(self) -> Result<OverWindowNode, Self>
pub fn into_over_window(self) -> Result<OverWindowNode, Self>
Returns the inner fields if this is a NodeBody::OverWindow
, otherwise returns back the enum in the Err
case of the result
sourcepub fn is_stream_fs_fetch(&self) -> bool
pub fn is_stream_fs_fetch(&self) -> bool
Returns true if this is a NodeBody::StreamFsFetch
, otherwise false
sourcepub fn as_stream_fs_fetch_mut(&mut self) -> Option<&mut StreamFsFetchNode>
pub fn as_stream_fs_fetch_mut(&mut self) -> Option<&mut StreamFsFetchNode>
Optionally returns mutable references to the inner fields if this is a NodeBody::StreamFsFetch
, otherwise None
sourcepub fn as_stream_fs_fetch(&self) -> Option<&StreamFsFetchNode>
pub fn as_stream_fs_fetch(&self) -> Option<&StreamFsFetchNode>
Optionally returns references to the inner fields if this is a NodeBody::StreamFsFetch
, otherwise None
sourcepub fn into_stream_fs_fetch(self) -> Result<StreamFsFetchNode, Self>
pub fn into_stream_fs_fetch(self) -> Result<StreamFsFetchNode, Self>
Returns the inner fields if this is a NodeBody::StreamFsFetch
, otherwise returns back the enum in the Err
case of the result
sourcepub fn is_stream_cdc_scan(&self) -> bool
pub fn is_stream_cdc_scan(&self) -> bool
Returns true if this is a NodeBody::StreamCdcScan
, otherwise false
sourcepub fn as_stream_cdc_scan_mut(&mut self) -> Option<&mut StreamCdcScanNode>
pub fn as_stream_cdc_scan_mut(&mut self) -> Option<&mut StreamCdcScanNode>
Optionally returns mutable references to the inner fields if this is a NodeBody::StreamCdcScan
, otherwise None
sourcepub fn as_stream_cdc_scan(&self) -> Option<&StreamCdcScanNode>
pub fn as_stream_cdc_scan(&self) -> Option<&StreamCdcScanNode>
Optionally returns references to the inner fields if this is a NodeBody::StreamCdcScan
, otherwise None
sourcepub fn into_stream_cdc_scan(self) -> Result<StreamCdcScanNode, Self>
pub fn into_stream_cdc_scan(self) -> Result<StreamCdcScanNode, Self>
Returns the inner fields if this is a NodeBody::StreamCdcScan
, otherwise returns back the enum in the Err
case of the result
sourcepub fn is_cdc_filter(&self) -> bool
pub fn is_cdc_filter(&self) -> bool
Returns true if this is a NodeBody::CdcFilter
, otherwise false
sourcepub fn as_cdc_filter_mut(&mut self) -> Option<&mut CdcFilterNode>
pub fn as_cdc_filter_mut(&mut self) -> Option<&mut CdcFilterNode>
Optionally returns mutable references to the inner fields if this is a NodeBody::CdcFilter
, otherwise None
sourcepub fn as_cdc_filter(&self) -> Option<&CdcFilterNode>
pub fn as_cdc_filter(&self) -> Option<&CdcFilterNode>
Optionally returns references to the inner fields if this is a NodeBody::CdcFilter
, otherwise None
sourcepub fn into_cdc_filter(self) -> Result<CdcFilterNode, Self>
pub fn into_cdc_filter(self) -> Result<CdcFilterNode, Self>
Returns the inner fields if this is a NodeBody::CdcFilter
, otherwise returns back the enum in the Err
case of the result
sourcepub fn is_source_backfill(&self) -> bool
pub fn is_source_backfill(&self) -> bool
Returns true if this is a NodeBody::SourceBackfill
, otherwise false
sourcepub fn as_source_backfill_mut(&mut self) -> Option<&mut SourceBackfillNode>
pub fn as_source_backfill_mut(&mut self) -> Option<&mut SourceBackfillNode>
Optionally returns mutable references to the inner fields if this is a NodeBody::SourceBackfill
, otherwise None
sourcepub fn as_source_backfill(&self) -> Option<&SourceBackfillNode>
pub fn as_source_backfill(&self) -> Option<&SourceBackfillNode>
Optionally returns references to the inner fields if this is a NodeBody::SourceBackfill
, otherwise None
sourcepub fn into_source_backfill(self) -> Result<SourceBackfillNode, Self>
pub fn into_source_backfill(self) -> Result<SourceBackfillNode, Self>
Returns the inner fields if this is a NodeBody::SourceBackfill
, otherwise returns back the enum in the Err
case of the result
sourcepub fn is_changelog(&self) -> bool
pub fn is_changelog(&self) -> bool
Returns true if this is a NodeBody::Changelog
, otherwise false
sourcepub fn as_changelog_mut(&mut self) -> Option<&mut ChangeLogNode>
pub fn as_changelog_mut(&mut self) -> Option<&mut ChangeLogNode>
Optionally returns mutable references to the inner fields if this is a NodeBody::Changelog
, otherwise None
sourcepub fn as_changelog(&self) -> Option<&ChangeLogNode>
pub fn as_changelog(&self) -> Option<&ChangeLogNode>
Optionally returns references to the inner fields if this is a NodeBody::Changelog
, otherwise None
sourcepub fn into_changelog(self) -> Result<ChangeLogNode, Self>
pub fn into_changelog(self) -> Result<ChangeLogNode, Self>
Returns the inner fields if this is a NodeBody::Changelog
, otherwise returns back the enum in the Err
case of the result
sourcepub fn is_local_approx_percentile(&self) -> bool
pub fn is_local_approx_percentile(&self) -> bool
Returns true if this is a NodeBody::LocalApproxPercentile
, otherwise false
sourcepub fn as_local_approx_percentile_mut(
&mut self,
) -> Option<&mut LocalApproxPercentileNode>
pub fn as_local_approx_percentile_mut( &mut self, ) -> Option<&mut LocalApproxPercentileNode>
Optionally returns mutable references to the inner fields if this is a NodeBody::LocalApproxPercentile
, otherwise None
sourcepub fn as_local_approx_percentile(&self) -> Option<&LocalApproxPercentileNode>
pub fn as_local_approx_percentile(&self) -> Option<&LocalApproxPercentileNode>
Optionally returns references to the inner fields if this is a NodeBody::LocalApproxPercentile
, otherwise None
sourcepub fn into_local_approx_percentile(
self,
) -> Result<LocalApproxPercentileNode, Self>
pub fn into_local_approx_percentile( self, ) -> Result<LocalApproxPercentileNode, Self>
Returns the inner fields if this is a NodeBody::LocalApproxPercentile
, otherwise returns back the enum in the Err
case of the result
sourcepub fn is_global_approx_percentile(&self) -> bool
pub fn is_global_approx_percentile(&self) -> bool
Returns true if this is a NodeBody::GlobalApproxPercentile
, otherwise false
sourcepub fn as_global_approx_percentile_mut(
&mut self,
) -> Option<&mut GlobalApproxPercentileNode>
pub fn as_global_approx_percentile_mut( &mut self, ) -> Option<&mut GlobalApproxPercentileNode>
Optionally returns mutable references to the inner fields if this is a NodeBody::GlobalApproxPercentile
, otherwise None
sourcepub fn as_global_approx_percentile(&self) -> Option<&GlobalApproxPercentileNode>
pub fn as_global_approx_percentile(&self) -> Option<&GlobalApproxPercentileNode>
Optionally returns references to the inner fields if this is a NodeBody::GlobalApproxPercentile
, otherwise None
sourcepub fn into_global_approx_percentile(
self,
) -> Result<GlobalApproxPercentileNode, Self>
pub fn into_global_approx_percentile( self, ) -> Result<GlobalApproxPercentileNode, Self>
Returns the inner fields if this is a NodeBody::GlobalApproxPercentile
, otherwise returns back the enum in the Err
case of the result
sourcepub fn is_row_merge(&self) -> bool
pub fn is_row_merge(&self) -> bool
Returns true if this is a NodeBody::RowMerge
, otherwise false
sourcepub fn as_row_merge_mut(&mut self) -> Option<&mut RowMergeNode>
pub fn as_row_merge_mut(&mut self) -> Option<&mut RowMergeNode>
Optionally returns mutable references to the inner fields if this is a NodeBody::RowMerge
, otherwise None
sourcepub fn as_row_merge(&self) -> Option<&RowMergeNode>
pub fn as_row_merge(&self) -> Option<&RowMergeNode>
Optionally returns references to the inner fields if this is a NodeBody::RowMerge
, otherwise None
sourcepub fn into_row_merge(self) -> Result<RowMergeNode, Self>
pub fn into_row_merge(self) -> Result<RowMergeNode, Self>
Returns the inner fields if this is a NodeBody::RowMerge
, otherwise returns back the enum in the Err
case of the result
sourcepub fn is_as_of_join(&self) -> bool
pub fn is_as_of_join(&self) -> bool
Returns true if this is a NodeBody::AsOfJoin
, otherwise false
sourcepub fn as_as_of_join_mut(&mut self) -> Option<&mut AsOfJoinNode>
pub fn as_as_of_join_mut(&mut self) -> Option<&mut AsOfJoinNode>
Optionally returns mutable references to the inner fields if this is a NodeBody::AsOfJoin
, otherwise None
sourcepub fn as_as_of_join(&self) -> Option<&AsOfJoinNode>
pub fn as_as_of_join(&self) -> Option<&AsOfJoinNode>
Optionally returns references to the inner fields if this is a NodeBody::AsOfJoin
, otherwise None
sourcepub fn into_as_of_join(self) -> Result<AsOfJoinNode, Self>
pub fn into_as_of_join(self) -> Result<AsOfJoinNode, Self>
Returns the inner fields if this is a NodeBody::AsOfJoin
, 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