Module executor

Source

Re-exports§

pub use error::StreamExecutorError;
pub use error::StreamExecutorResult;
pub use hash_join::*;

Modules§

AsOfJoinType
JoinType
actor πŸ”’
aggregate
approx_percentile πŸ”’
asof_join
backfill πŸ”’
barrier_align πŸ”’
barrier_recv πŸ”’
batch_query πŸ”’
chain πŸ”’
changelog πŸ”’
dedup πŸ”’
dispatch πŸ”’
dml
dynamic_filter πŸ”’
eowc
error
exchange
expand πŸ”’
filter πŸ”’
hash_join
hop_window πŸ”’
join πŸ”’
lookup πŸ”’
lookup_union πŸ”’
merge πŸ”’
monitor
mview πŸ”’
nested_loop_temporal_join πŸ”’
no_op πŸ”’
now πŸ”’
over_window πŸ”’
prelude πŸ”’
project
rearranged_chain πŸ”’
receiver πŸ”’
row_id_gen
row_merge πŸ”’
sink πŸ”’
source
stream_reader πŸ”’
subtask
sync_kv_log_store πŸ”’
This contains the synced kv log store implementation. It’s meant to buffer a large number of records emitted from upstream, to avoid overwhelming the downstream executor.
temporal_join πŸ”’
test_utils
top_n πŸ”’
troublemaker πŸ”’
union πŸ”’
utils πŸ”’
values πŸ”’
watermark πŸ”’
watermark_filter πŸ”’
wrapper πŸ”’

Structs§

Actor
Actor is the basic execution unit in the streaming framework.
ActorContext
Shared by all operators of an actor.
AddMutation
AppendOnlyDedupExecutor
AppendOnlyDedupExecutor drops any message that has duplicate pk columns with previous messages. It only accepts append-only input, and its output will be append-only as well.
ArrangementBackfillExecutor
Similar to super::no_shuffle_backfill::BackfillExecutor. Main differences:
AsOfDesc
BackfillExecutor
An implementation of the RFC: Use Backfill To Let Mv On Mv Stream Again. BackfillExecutor is used to create a materialized view on another materialized view.
BackfillState
Schema: | vnode | pk … | backfill_finished | row_count | We can decode that into BackfillState on recovery.
BarrierInner
The generic type M is the mutation type of the barrier.
BarrierRecvExecutor
The executor only for receiving barrier from the meta service. It always resides in the leaves of the streaming graph.
BatchQueryExecutor
CdcBackfillExecutor
CdcScanOptions
ChainExecutor
ChainExecutor is an executor that enables synchronization between the existing stream and newly appended executors. Currently, ChainExecutor is mainly used to implement MV on MV feature. It pipes new data of existing MVs to newly created MV only all of the old data in the existing MVs are dispatched.
ChangeLogExecutor
DispatchExecutor
DispatchExecutor consumes messages and send them into downstream actors. Usually, data chunks will be dispatched with some specified policy, while control message such as barriers will be distributed to all receivers.
DummyExecutor
DynamicFilterExecutor
EowcOverWindowExecutor
EowcOverWindowExecutor consumes ordered input (on order key column with watermark in ascending order) and outputs window function results. One EowcOverWindowExecutor can handle one combination of partition key and order key.
EowcOverWindowExecutorArgs
Executor
Executor combines the static information (ExecutorInfo) and the executable object to handle messages (Execute).
ExecutorInfo
Static information of an executor.
ExpandExecutor
ExternalStorageTable
This struct represents an external table to be read during backfill
FilterExecutor
FilterExecutor filters data with the expr. The expr takes a chunk of data, and returns a boolean array on whether each item should be retained. And then, FilterExecutor will insert, delete or update element into next executor according to the result of the expression.
GlobalApproxPercentileExecutor
HopWindowExecutor
LocalApproxPercentileExecutor
LookupExecutor
LookupExecutor takes one input stream and one arrangement. It joins the input stream with the arrangement. Currently, it only supports inner join. See LookupExecutorParams for more information.
LookupExecutorParams
Parameters for LookupExecutor.
LookupUnionExecutor
Merges data from multiple inputs with order. If order = [2, 1, 0], then it will first pipe data from the third input; after the third input gets a barrier, it will then pipe the second, and finally the first. In the future we could have more efficient implementation.
MaterializeBuffer
MaterializeBuffer is a buffer to handle chunk into KeyOp.
MaterializeCache
A cache for materialize executors.
MaterializeExecutor
MaterializeExecutor materializes changes in stream into a materialized view on storage.
MergeExecutor
MergeExecutor merges data from multiple channels. Dataflow from one channel will be stopped on barrier.
NestedLoopTemporalJoinExecutor
NoOpExecutor
No-op executor directly forwards the input stream. Currently used to break the multiple edges in the fragment graph.
NowExecutor
OverWindowExecutor
OverWindowExecutor consumes retractable input stream and produces window function outputs. One OverWindowExecutor can handle one combination of partition key and order key.
OverWindowExecutorArgs
RearrangedChainExecutor
ChainExecutor is an executor that enables synchronization between the existing stream and newly appended executors. Currently, ChainExecutor is mainly used to implement MV on MV feature. It pipes new data of existing MVs to newly created MV only all of the old data in the existing MVs are dispatched.
ReceiverExecutor
ReceiverExecutor is used along with a channel. After creating a mpsc channel, there should be a ReceiverExecutor running in the background, so as to push messages down to the executors.
RowMergeExecutor
SinkExecutor
SnapshotBackfillExecutor
SyncedKvLogStoreExecutor
SyncedKvLogStoreMetrics
TemporalJoinExecutor
TroublemakerExecutor
TroublemakerExecutor is used to make some trouble in the stream graph. Specifically, it is attached to StreamScan and Source executors in insane mode. It randomly corrupts the stream chunks it receives and sends them downstream, making the stream inconsistent. This should ONLY BE USED IN INSANE MODE FOR TESTING PURPOSES.
UnionExecutor
UnionExecutor merges data from multiple inputs.
UpdateMutation
UpstreamTableExecutor
ValuesExecutor
Execute values in stream. As is a leaf, current workaround holds a barrier_executor. May refractor with BarrierRecvExecutor in the near future.
Watermark
WatermarkFilterExecutor
The executor will generate a Watermark after each chunk. This will also guarantee all later rows with event time less than the watermark will be filtered.
WrapperExecutor
WrapperExecutor will do some sanity checks and logging for the wrapped executor.

Enums§

DispatcherImpl
MessageBatchInner
MessageBatchInner is used exclusively by Dispatcher and the Merger/Receiver for exchanging messages between them. It shares the same message type as the fundamental MessageInner, but batches multiple barriers into a single message.
MessageInner
Mutation
See [PbMutation] for the semantics of each mutation.
NowMode

Constants§

INVALID_EPOCH

Traits§

Execute
Execute describes the methods an executor should implement to handle control messages.
StreamConsumer
StreamConsumer is the last step in an actor.

Functions§

build_add_interval_expr
build_add_interval_expr_captured
curr_epoch
Retrieve the current epoch from the task local storage.
epoch
Retrieve the epoch pair from the task local storage.
expect_first_barrier
Expect the first message of the given stream as a barrier.
expect_first_barrier_from_aligned_stream
Expect the first message of the given stream as a barrier.
prev_epoch
Retrieve the previous epoch from the task local storage.

Type Aliases§

ActorContextRef
AppendOnlyGroupTopNExecutor
If the input is append-only, AppendOnlyGroupTopNExecutor does not need to keep all the rows seen. As long as a record is no longer in the result set, it can be deleted.
AppendOnlyTopNExecutor
If the input is append-only, AppendOnlyGroupTopNExecutor does not need to keep all the rows seen. As long as a record is no longer in the result set, it can be deleted.
Barrier
BarrierMutationType
BoxedMessageStream
DispatcherBarrier
DispatcherBarriers
DispatcherMessage
DispatcherMessageBatch
DispatcherMessageStreamItem
GroupTopNExecutor
Message
MessageBatch
MessageStreamItem
MessageStreamItemInner
PkDataTypes
PkIndices
PkIndicesRef
SplitAssignments πŸ”’
TopNExecutor
TopNExecutor works with input with modification, it keeps all the data records/rows that have been seen, and returns topN records overall.
UpstreamFragmentId πŸ”’

Trait Aliases§

DispatcherMessageStream
MessageStream
MessageStreamInner