risingwave_pb::stream_plan::stream_node

Enum NodeBody

source
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

source

pub fn encode(&self, buf: &mut impl BufMut)

Encodes the message to a buffer.

source

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.

source

pub fn encoded_len(&self) -> usize

Returns the encoded length of the message without a length delimiter.

source§

impl NodeBody

source

pub fn is_source(&self) -> bool

Returns true if this is a NodeBody::Source, otherwise false

source

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

source

pub fn as_source(&self) -> Option<&SourceNode>

Optionally returns references to the inner fields if this is a NodeBody::Source, otherwise None

source

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

source

pub fn is_project(&self) -> bool

Returns true if this is a NodeBody::Project, otherwise false

source

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

source

pub fn as_project(&self) -> Option<&ProjectNode>

Optionally returns references to the inner fields if this is a NodeBody::Project, otherwise None

source

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

source

pub fn is_filter(&self) -> bool

Returns true if this is a NodeBody::Filter, otherwise false

source

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

source

pub fn as_filter(&self) -> Option<&FilterNode>

Optionally returns references to the inner fields if this is a NodeBody::Filter, otherwise None

source

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

source

pub fn is_materialize(&self) -> bool

Returns true if this is a NodeBody::Materialize, otherwise false

source

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

source

pub fn as_materialize(&self) -> Option<&MaterializeNode>

Optionally returns references to the inner fields if this is a NodeBody::Materialize, otherwise None

source

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

source

pub fn is_stateless_simple_agg(&self) -> bool

Returns true if this is a NodeBody::StatelessSimpleAgg, otherwise false

source

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

source

pub fn as_stateless_simple_agg(&self) -> Option<&SimpleAggNode>

Optionally returns references to the inner fields if this is a NodeBody::StatelessSimpleAgg, otherwise None

source

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

source

pub fn is_simple_agg(&self) -> bool

Returns true if this is a NodeBody::SimpleAgg, otherwise false

source

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

source

pub fn as_simple_agg(&self) -> Option<&SimpleAggNode>

Optionally returns references to the inner fields if this is a NodeBody::SimpleAgg, otherwise None

source

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

source

pub fn is_hash_agg(&self) -> bool

Returns true if this is a NodeBody::HashAgg, otherwise false

source

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

source

pub fn as_hash_agg(&self) -> Option<&HashAggNode>

Optionally returns references to the inner fields if this is a NodeBody::HashAgg, otherwise None

source

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

source

pub fn is_append_only_top_n(&self) -> bool

Returns true if this is a NodeBody::AppendOnlyTopN, otherwise false

source

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

source

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

source

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

source

pub fn is_hash_join(&self) -> bool

Returns true if this is a NodeBody::HashJoin, otherwise false

source

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

source

pub fn as_hash_join(&self) -> Option<&HashJoinNode>

Optionally returns references to the inner fields if this is a NodeBody::HashJoin, otherwise None

source

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

source

pub fn is_top_n(&self) -> bool

Returns true if this is a NodeBody::TopN, otherwise false

source

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

source

pub fn as_top_n(&self) -> Option<&TopNNode>

Optionally returns references to the inner fields if this is a NodeBody::TopN, otherwise None

source

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

source

pub fn is_hop_window(&self) -> bool

Returns true if this is a NodeBody::HopWindow, otherwise false

source

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

source

pub fn as_hop_window(&self) -> Option<&HopWindowNode>

Optionally returns references to the inner fields if this is a NodeBody::HopWindow, otherwise None

source

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

source

pub fn is_merge(&self) -> bool

Returns true if this is a NodeBody::Merge, otherwise false

source

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

source

pub fn as_merge(&self) -> Option<&MergeNode>

Optionally returns references to the inner fields if this is a NodeBody::Merge, otherwise None

source

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

source

pub fn is_exchange(&self) -> bool

Returns true if this is a NodeBody::Exchange, otherwise false

source

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

source

pub fn as_exchange(&self) -> Option<&ExchangeNode>

Optionally returns references to the inner fields if this is a NodeBody::Exchange, otherwise None

source

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

source

pub fn is_stream_scan(&self) -> bool

Returns true if this is a NodeBody::StreamScan, otherwise false

source

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

source

pub fn as_stream_scan(&self) -> Option<&StreamScanNode>

Optionally returns references to the inner fields if this is a NodeBody::StreamScan, otherwise None

source

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

source

pub fn is_batch_plan(&self) -> bool

Returns true if this is a NodeBody::BatchPlan, otherwise false

source

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

source

pub fn as_batch_plan(&self) -> Option<&BatchPlanNode>

Optionally returns references to the inner fields if this is a NodeBody::BatchPlan, otherwise None

source

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

source

pub fn is_lookup(&self) -> bool

Returns true if this is a NodeBody::Lookup, otherwise false

source

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

source

pub fn as_lookup(&self) -> Option<&LookupNode>

Optionally returns references to the inner fields if this is a NodeBody::Lookup, otherwise None

source

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

source

pub fn is_arrange(&self) -> bool

Returns true if this is a NodeBody::Arrange, otherwise false

source

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

source

pub fn as_arrange(&self) -> Option<&ArrangeNode>

Optionally returns references to the inner fields if this is a NodeBody::Arrange, otherwise None

source

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

source

pub fn is_lookup_union(&self) -> bool

Returns true if this is a NodeBody::LookupUnion, otherwise false

source

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

source

pub fn as_lookup_union(&self) -> Option<&LookupUnionNode>

Optionally returns references to the inner fields if this is a NodeBody::LookupUnion, otherwise None

source

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

source

pub fn is_union(&self) -> bool

Returns true if this is a NodeBody::Union, otherwise false

source

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

source

pub fn as_union(&self) -> Option<&UnionNode>

Optionally returns references to the inner fields if this is a NodeBody::Union, otherwise None

source

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

source

pub fn is_delta_index_join(&self) -> bool

Returns true if this is a NodeBody::DeltaIndexJoin, otherwise false

source

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

source

pub fn as_delta_index_join(&self) -> Option<&DeltaIndexJoinNode>

Optionally returns references to the inner fields if this is a NodeBody::DeltaIndexJoin, otherwise None

source

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

source

pub fn is_sink(&self) -> bool

Returns true if this is a NodeBody::Sink, otherwise false

source

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

source

pub fn as_sink(&self) -> Option<&SinkNode>

Optionally returns references to the inner fields if this is a NodeBody::Sink, otherwise None

source

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

source

pub fn is_expand(&self) -> bool

Returns true if this is a NodeBody::Expand, otherwise false

source

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

source

pub fn as_expand(&self) -> Option<&ExpandNode>

Optionally returns references to the inner fields if this is a NodeBody::Expand, otherwise None

source

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

source

pub fn is_dynamic_filter(&self) -> bool

Returns true if this is a NodeBody::DynamicFilter, otherwise false

source

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

source

pub fn as_dynamic_filter(&self) -> Option<&DynamicFilterNode>

Optionally returns references to the inner fields if this is a NodeBody::DynamicFilter, otherwise None

source

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

source

pub fn is_project_set(&self) -> bool

Returns true if this is a NodeBody::ProjectSet, otherwise false

source

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

source

pub fn as_project_set(&self) -> Option<&ProjectSetNode>

Optionally returns references to the inner fields if this is a NodeBody::ProjectSet, otherwise None

source

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

source

pub fn is_group_top_n(&self) -> bool

Returns true if this is a NodeBody::GroupTopN, otherwise false

source

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

source

pub fn as_group_top_n(&self) -> Option<&GroupTopNNode>

Optionally returns references to the inner fields if this is a NodeBody::GroupTopN, otherwise None

source

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

source

pub fn is_sort(&self) -> bool

Returns true if this is a NodeBody::Sort, otherwise false

source

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

source

pub fn as_sort(&self) -> Option<&SortNode>

Optionally returns references to the inner fields if this is a NodeBody::Sort, otherwise None

source

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

source

pub fn is_watermark_filter(&self) -> bool

Returns true if this is a NodeBody::WatermarkFilter, otherwise false

source

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

source

pub fn as_watermark_filter(&self) -> Option<&WatermarkFilterNode>

Optionally returns references to the inner fields if this is a NodeBody::WatermarkFilter, otherwise None

source

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

source

pub fn is_dml(&self) -> bool

Returns true if this is a NodeBody::Dml, otherwise false

source

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

source

pub fn as_dml(&self) -> Option<&DmlNode>

Optionally returns references to the inner fields if this is a NodeBody::Dml, otherwise None

source

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

source

pub fn is_row_id_gen(&self) -> bool

Returns true if this is a NodeBody::RowIdGen, otherwise false

source

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

source

pub fn as_row_id_gen(&self) -> Option<&RowIdGenNode>

Optionally returns references to the inner fields if this is a NodeBody::RowIdGen, otherwise None

source

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

source

pub fn is_now(&self) -> bool

Returns true if this is a NodeBody::Now, otherwise false

source

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

source

pub fn as_now(&self) -> Option<&NowNode>

Optionally returns references to the inner fields if this is a NodeBody::Now, otherwise None

source

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

source

pub fn is_append_only_group_top_n(&self) -> bool

Returns true if this is a NodeBody::AppendOnlyGroupTopN, otherwise false

source

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

source

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

source

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

source

pub fn is_temporal_join(&self) -> bool

Returns true if this is a NodeBody::TemporalJoin, otherwise false

source

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

source

pub fn as_temporal_join(&self) -> Option<&TemporalJoinNode>

Optionally returns references to the inner fields if this is a NodeBody::TemporalJoin, otherwise None

source

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

source

pub fn is_barrier_recv(&self) -> bool

Returns true if this is a NodeBody::BarrierRecv, otherwise false

source

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

source

pub fn as_barrier_recv(&self) -> Option<&BarrierRecvNode>

Optionally returns references to the inner fields if this is a NodeBody::BarrierRecv, otherwise None

source

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

source

pub fn is_values(&self) -> bool

Returns true if this is a NodeBody::Values, otherwise false

source

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

source

pub fn as_values(&self) -> Option<&ValuesNode>

Optionally returns references to the inner fields if this is a NodeBody::Values, otherwise None

source

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

source

pub fn is_append_only_dedup(&self) -> bool

Returns true if this is a NodeBody::AppendOnlyDedup, otherwise false

source

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

source

pub fn as_append_only_dedup(&self) -> Option<&DedupNode>

Optionally returns references to the inner fields if this is a NodeBody::AppendOnlyDedup, otherwise None

source

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

source

pub fn is_no_op(&self) -> bool

Returns true if this is a NodeBody::NoOp, otherwise false

source

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

source

pub fn as_no_op(&self) -> Option<&NoOpNode>

Optionally returns references to the inner fields if this is a NodeBody::NoOp, otherwise None

source

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

source

pub fn is_eowc_over_window(&self) -> bool

Returns true if this is a NodeBody::EowcOverWindow, otherwise false

source

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

source

pub fn as_eowc_over_window(&self) -> Option<&EowcOverWindowNode>

Optionally returns references to the inner fields if this is a NodeBody::EowcOverWindow, otherwise None

source

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

source

pub fn is_over_window(&self) -> bool

Returns true if this is a NodeBody::OverWindow, otherwise false

source

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

source

pub fn as_over_window(&self) -> Option<&OverWindowNode>

Optionally returns references to the inner fields if this is a NodeBody::OverWindow, otherwise None

source

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

source

pub fn is_stream_fs_fetch(&self) -> bool

Returns true if this is a NodeBody::StreamFsFetch, otherwise false

source

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

source

pub fn as_stream_fs_fetch(&self) -> Option<&StreamFsFetchNode>

Optionally returns references to the inner fields if this is a NodeBody::StreamFsFetch, otherwise None

source

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

source

pub fn is_stream_cdc_scan(&self) -> bool

Returns true if this is a NodeBody::StreamCdcScan, otherwise false

source

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

source

pub fn as_stream_cdc_scan(&self) -> Option<&StreamCdcScanNode>

Optionally returns references to the inner fields if this is a NodeBody::StreamCdcScan, otherwise None

source

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

source

pub fn is_cdc_filter(&self) -> bool

Returns true if this is a NodeBody::CdcFilter, otherwise false

source

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

source

pub fn as_cdc_filter(&self) -> Option<&CdcFilterNode>

Optionally returns references to the inner fields if this is a NodeBody::CdcFilter, otherwise None

source

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

source

pub fn is_source_backfill(&self) -> bool

Returns true if this is a NodeBody::SourceBackfill, otherwise false

source

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

source

pub fn as_source_backfill(&self) -> Option<&SourceBackfillNode>

Optionally returns references to the inner fields if this is a NodeBody::SourceBackfill, otherwise None

source

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

source

pub fn is_changelog(&self) -> bool

Returns true if this is a NodeBody::Changelog, otherwise false

source

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

source

pub fn as_changelog(&self) -> Option<&ChangeLogNode>

Optionally returns references to the inner fields if this is a NodeBody::Changelog, otherwise None

source

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

source

pub fn is_local_approx_percentile(&self) -> bool

Returns true if this is a NodeBody::LocalApproxPercentile, otherwise false

source

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

source

pub fn as_local_approx_percentile(&self) -> Option<&LocalApproxPercentileNode>

Optionally returns references to the inner fields if this is a NodeBody::LocalApproxPercentile, otherwise None

source

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

source

pub fn is_global_approx_percentile(&self) -> bool

Returns true if this is a NodeBody::GlobalApproxPercentile, otherwise false

source

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

source

pub fn as_global_approx_percentile(&self) -> Option<&GlobalApproxPercentileNode>

Optionally returns references to the inner fields if this is a NodeBody::GlobalApproxPercentile, otherwise None

source

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

source

pub fn is_row_merge(&self) -> bool

Returns true if this is a NodeBody::RowMerge, otherwise false

source

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

source

pub fn as_row_merge(&self) -> Option<&RowMergeNode>

Optionally returns references to the inner fields if this is a NodeBody::RowMerge, otherwise None

source

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

source

pub fn is_as_of_join(&self) -> bool

Returns true if this is a NodeBody::AsOfJoin, otherwise false

source

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

source

pub fn as_as_of_join(&self) -> Option<&AsOfJoinNode>

Optionally returns references to the inner fields if this is a NodeBody::AsOfJoin, otherwise None

source

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§

source§

impl Clone for NodeBody

source§

fn clone(&self) -> NodeBody

Returns a copy of the value. Read more
1.0.0 · source§

fn clone_from(&mut self, source: &Self)

Performs copy-assignment from source. Read more
source§

impl Debug for NodeBody

source§

fn fmt(&self, f: &mut Formatter<'_>) -> Result

Formats the value using the given formatter. Read more
source§

impl Display for NodeBody

source§

fn fmt(&self, f: &mut Formatter<'_>) -> Result<(), Error>

Formats the value using the given formatter. Read more
source§

impl PartialEq for NodeBody

source§

fn eq(&self, other: &NodeBody) -> bool

Tests for self and other values to be equal, and is used by ==.
1.0.0 · source§

fn ne(&self, other: &Rhs) -> bool

Tests for !=. The default implementation is almost always sufficient, and should not be overridden without very good reason.
source§

impl StructuralPartialEq for NodeBody

Auto Trait Implementations§

Blanket Implementations§

source§

impl<T> Any for T
where T: 'static + ?Sized,

source§

fn type_id(&self) -> TypeId

Gets the TypeId of self. Read more
source§

impl<T> Borrow<T> for T
where T: ?Sized,

source§

fn borrow(&self) -> &T

Immutably borrows from an owned value. Read more
source§

impl<T> BorrowMut<T> for T
where T: ?Sized,

source§

fn borrow_mut(&mut self) -> &mut T

Mutably borrows from an owned value. Read more
source§

impl<T> CloneToUninit for T
where T: Clone,

source§

unsafe fn clone_to_uninit(&self, dst: *mut T)

🔬This is a nightly-only experimental API. (clone_to_uninit)
Performs copy-assignment from self to dst. Read more
source§

impl<T> From<T> for T

source§

fn from(t: T) -> T

Returns the argument unchanged.

§

impl<T> FromRef<T> for T
where T: Clone,

§

fn from_ref(input: &T) -> T

Converts to this type from a reference to the input type.
§

impl<T> Instrument for T

§

fn instrument(self, span: Span) -> Instrumented<Self>

Instruments this type with the provided [Span], returning an Instrumented wrapper. Read more
§

fn in_current_span(self) -> Instrumented<Self>

Instruments this type with the current Span, returning an Instrumented wrapper. Read more
source§

impl<T, U> Into<U> for T
where U: From<T>,

source§

fn into(self) -> U

Calls U::from(self).

That is, this conversion is whatever the implementation of From<T> for U chooses to do.

source§

impl<T> IntoRequest<T> for T

source§

fn into_request(self) -> Request<T>

Wrap the input message T in a tonic::Request
source§

impl<T> ToOwned for T
where T: Clone,

source§

type Owned = T

The resulting type after obtaining ownership.
source§

fn to_owned(&self) -> T

Creates owned data from borrowed data, usually by cloning. Read more
source§

fn clone_into(&self, target: &mut T)

Uses borrowed data to replace owned data, usually by cloning. Read more
source§

impl<T> ToString for T
where T: Display + ?Sized,

source§

default fn to_string(&self) -> String

Converts the given value to a String. Read more
source§

impl<T, U> TryFrom<U> for T
where U: Into<T>,

source§

type Error = Infallible

The type returned in the event of a conversion error.
source§

fn try_from(value: U) -> Result<T, <T as TryFrom<U>>::Error>

Performs the conversion.
source§

impl<T, U> TryInto<U> for T
where U: TryFrom<T>,

source§

type Error = <U as TryFrom<T>>::Error

The type returned in the event of a conversion error.
source§

fn try_into(self) -> Result<U, <U as TryFrom<T>>::Error>

Performs the conversion.
§

impl<V, T> VZip<V> for T
where V: MultiLane<T>,

§

fn vzip(self) -> V

§

impl<T> WithSubscriber for T

§

fn with_subscriber<S>(self, subscriber: S) -> WithDispatch<Self>
where S: Into<Dispatch>,

Attaches the provided Subscriber to this type, returning a [WithDispatch] wrapper. Read more
§

fn with_current_subscriber(self) -> WithDispatch<Self>

Attaches the current default Subscriber to this type, returning a [WithDispatch] wrapper. Read more