risingwave_pb::stream_plan::stream_node

Enum NodeBody

source
pub enum NodeBody {
Show 48 variants Source(Box<SourceNode>), Project(Box<ProjectNode>), Filter(Box<FilterNode>), Materialize(Box<MaterializeNode>), StatelessSimpleAgg(Box<SimpleAggNode>), SimpleAgg(Box<SimpleAggNode>), HashAgg(Box<HashAggNode>), AppendOnlyTopN(Box<TopNNode>), HashJoin(Box<HashJoinNode>), TopN(Box<TopNNode>), HopWindow(Box<HopWindowNode>), Merge(Box<MergeNode>), Exchange(Box<ExchangeNode>), StreamScan(Box<StreamScanNode>), BatchPlan(Box<BatchPlanNode>), Lookup(Box<LookupNode>), Arrange(Box<ArrangeNode>), LookupUnion(Box<LookupUnionNode>), Union(UnionNode), DeltaIndexJoin(Box<DeltaIndexJoinNode>), Sink(Box<SinkNode>), Expand(Box<ExpandNode>), DynamicFilter(Box<DynamicFilterNode>), ProjectSet(Box<ProjectSetNode>), GroupTopN(Box<GroupTopNNode>), Sort(Box<SortNode>), WatermarkFilter(Box<WatermarkFilterNode>), Dml(Box<DmlNode>), RowIdGen(Box<RowIdGenNode>), Now(Box<NowNode>), AppendOnlyGroupTopN(Box<GroupTopNNode>), TemporalJoin(Box<TemporalJoinNode>), BarrierRecv(Box<BarrierRecvNode>), Values(Box<ValuesNode>), AppendOnlyDedup(Box<DedupNode>), NoOp(NoOpNode), EowcOverWindow(Box<EowcOverWindowNode>), OverWindow(Box<OverWindowNode>), StreamFsFetch(Box<StreamFsFetchNode>), StreamCdcScan(Box<StreamCdcScanNode>), CdcFilter(Box<CdcFilterNode>), SourceBackfill(Box<SourceBackfillNode>), Changelog(Box<ChangeLogNode>), LocalApproxPercentile(Box<LocalApproxPercentileNode>), GlobalApproxPercentile(Box<GlobalApproxPercentileNode>), RowMerge(Box<RowMergeNode>), AsOfJoin(Box<AsOfJoinNode>), SyncLogStore(Box<SyncLogStoreNode>),
}

Variants§

§

Source(Box<SourceNode>)

§

Project(Box<ProjectNode>)

§

Filter(Box<FilterNode>)

§

Materialize(Box<MaterializeNode>)

§

StatelessSimpleAgg(Box<SimpleAggNode>)

§

SimpleAgg(Box<SimpleAggNode>)

§

HashAgg(Box<HashAggNode>)

§

AppendOnlyTopN(Box<TopNNode>)

§

HashJoin(Box<HashJoinNode>)

§

TopN(Box<TopNNode>)

§

HopWindow(Box<HopWindowNode>)

§

Merge(Box<MergeNode>)

§

Exchange(Box<ExchangeNode>)

§

StreamScan(Box<StreamScanNode>)

§

BatchPlan(Box<BatchPlanNode>)

§

Lookup(Box<LookupNode>)

§

Arrange(Box<ArrangeNode>)

§

LookupUnion(Box<LookupUnionNode>)

§

Union(UnionNode)

§

DeltaIndexJoin(Box<DeltaIndexJoinNode>)

§

Sink(Box<SinkNode>)

§

Expand(Box<ExpandNode>)

§

DynamicFilter(Box<DynamicFilterNode>)

§

ProjectSet(Box<ProjectSetNode>)

§

GroupTopN(Box<GroupTopNNode>)

§

Sort(Box<SortNode>)

§

WatermarkFilter(Box<WatermarkFilterNode>)

§

Dml(Box<DmlNode>)

§

RowIdGen(Box<RowIdGenNode>)

§

Now(Box<NowNode>)

§

AppendOnlyGroupTopN(Box<GroupTopNNode>)

§

TemporalJoin(Box<TemporalJoinNode>)

§

BarrierRecv(Box<BarrierRecvNode>)

§

Values(Box<ValuesNode>)

§

AppendOnlyDedup(Box<DedupNode>)

§

NoOp(NoOpNode)

§

EowcOverWindow(Box<EowcOverWindowNode>)

§

OverWindow(Box<OverWindowNode>)

§

StreamFsFetch(Box<StreamFsFetchNode>)

§

StreamCdcScan(Box<StreamCdcScanNode>)

§

CdcFilter(Box<CdcFilterNode>)

§

SourceBackfill(Box<SourceBackfillNode>)

§

Changelog(Box<ChangeLogNode>)

§

LocalApproxPercentile(Box<LocalApproxPercentileNode>)

§

GlobalApproxPercentile(Box<GlobalApproxPercentileNode>)

§

RowMerge(Box<RowMergeNode>)

§

AsOfJoin(Box<AsOfJoinNode>)

§

SyncLogStore(Box<SyncLogStoreNode>)

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 Box<SourceNode>>

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

source

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

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

source

pub fn into_source(self) -> Result<Box<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 Box<ProjectNode>>

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

source

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

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

source

pub fn into_project(self) -> Result<Box<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 Box<FilterNode>>

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

source

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

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

source

pub fn into_filter(self) -> Result<Box<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 Box<MaterializeNode>>

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

source

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

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

source

pub fn into_materialize(self) -> Result<Box<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 Box<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<&Box<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<Box<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 Box<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<&Box<SimpleAggNode>>

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

source

pub fn into_simple_agg(self) -> Result<Box<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 Box<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<&Box<HashAggNode>>

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

source

pub fn into_hash_agg(self) -> Result<Box<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 Box<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<&Box<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<Box<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 Box<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<&Box<HashJoinNode>>

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

source

pub fn into_hash_join(self) -> Result<Box<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 Box<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<&Box<TopNNode>>

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

source

pub fn into_top_n(self) -> Result<Box<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 Box<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<&Box<HopWindowNode>>

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

source

pub fn into_hop_window(self) -> Result<Box<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 Box<MergeNode>>

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

source

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

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

source

pub fn into_merge(self) -> Result<Box<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 Box<ExchangeNode>>

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

source

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

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

source

pub fn into_exchange(self) -> Result<Box<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 Box<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<&Box<StreamScanNode>>

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

source

pub fn into_stream_scan(self) -> Result<Box<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 Box<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<&Box<BatchPlanNode>>

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

source

pub fn into_batch_plan(self) -> Result<Box<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 Box<LookupNode>>

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

source

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

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

source

pub fn into_lookup(self) -> Result<Box<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 Box<ArrangeNode>>

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

source

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

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

source

pub fn into_arrange(self) -> Result<Box<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 Box<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<&Box<LookupUnionNode>>

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

source

pub fn into_lookup_union(self) -> Result<Box<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 Box<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<&Box<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<Box<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 Box<SinkNode>>

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

source

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

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

source

pub fn into_sink(self) -> Result<Box<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 Box<ExpandNode>>

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

source

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

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

source

pub fn into_expand(self) -> Result<Box<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 Box<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<&Box<DynamicFilterNode>>

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

source

pub fn into_dynamic_filter(self) -> Result<Box<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 Box<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<&Box<ProjectSetNode>>

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

source

pub fn into_project_set(self) -> Result<Box<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 Box<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<&Box<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<Box<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 Box<SortNode>>

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

source

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

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

source

pub fn into_sort(self) -> Result<Box<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 Box<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<&Box<WatermarkFilterNode>>

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

source

pub fn into_watermark_filter(self) -> Result<Box<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 Box<DmlNode>>

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

source

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

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

source

pub fn into_dml(self) -> Result<Box<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 Box<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<&Box<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<Box<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 Box<NowNode>>

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

source

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

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

source

pub fn into_now(self) -> Result<Box<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 Box<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<&Box<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<Box<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 Box<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<&Box<TemporalJoinNode>>

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

source

pub fn into_temporal_join(self) -> Result<Box<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 Box<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<&Box<BarrierRecvNode>>

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

source

pub fn into_barrier_recv(self) -> Result<Box<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 Box<ValuesNode>>

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

source

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

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

source

pub fn into_values(self) -> Result<Box<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 Box<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<&Box<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<Box<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 Box<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<&Box<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<Box<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 Box<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<&Box<OverWindowNode>>

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

source

pub fn into_over_window(self) -> Result<Box<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 Box<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<&Box<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<Box<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 Box<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<&Box<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<Box<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 Box<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<&Box<CdcFilterNode>>

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

source

pub fn into_cdc_filter(self) -> Result<Box<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 Box<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<&Box<SourceBackfillNode>>

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

source

pub fn into_source_backfill(self) -> Result<Box<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 Box<ChangeLogNode>>

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

source

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

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

source

pub fn into_changelog(self) -> Result<Box<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 Box<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<&Box<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<Box<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 Box<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<&Box<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<Box<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 Box<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<&Box<RowMergeNode>>

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

source

pub fn into_row_merge(self) -> Result<Box<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 Box<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<&Box<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<Box<AsOfJoinNode>, Self>

Returns the inner fields if this is a NodeBody::AsOfJoin, otherwise returns back the enum in the Err case of the result

source

pub fn is_sync_log_store(&self) -> bool

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

source

pub fn as_sync_log_store_mut(&mut self) -> Option<&mut Box<SyncLogStoreNode>>

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

source

pub fn as_sync_log_store(&self) -> Option<&Box<SyncLogStoreNode>>

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

source

pub fn into_sync_log_store(self) -> Result<Box<SyncLogStoreNode>, Self>

Returns the inner fields if this is a NodeBody::SyncLogStore, 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<'_enum> From<&'_enum NodeBody> for NodeBodyDiscriminants

source§

fn from(val: &'_enum NodeBody) -> NodeBodyDiscriminants

Converts to this type from the input type.
source§

impl From<NodeBody> for NodeBodyDiscriminants

source§

fn from(val: NodeBody) -> NodeBodyDiscriminants

Converts to this type from the input type.
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