MicroBatchExecution — StreamExecution in Micro-Batch Stream Processing
MicroBatchExecution is a StreamExecution in Micro-Batch Stream Processing.
MicroBatchExecution is created when StreamingQueryManager is requested to create a streaming query with any type of sink but StreamWriteSupport and any type of trigger but ContinuousTrigger (when DataStreamWriter is requested to start an execution of the streaming query).
|
1 2 3 4 5 6 7 8 9 10 11 12 13 14 15 16 17 18 19 20 21 22 23 24 25 26 27 28 29 |
import org.apache.spark.sql.streaming.Trigger val sq = spark .readStream .format("rate") .load .writeStream .format("console") .option("truncate", false) .trigger(Trigger.Once) // <-- Gives MicroBatchExecution .queryName("rate2console") .start import org.apache.spark.sql.streaming.StreamingQuery assert(sq.isInstanceOf[StreamingQuery]) // The following gives access to the internals // And to MicroBatchExecution import org.apache.spark.sql.execution.streaming.StreamingQueryWrapper val engine = sq.asInstanceOf[StreamingQueryWrapper].streamingQuery import org.apache.spark.sql.execution.streaming.StreamExecution assert(engine.isInstanceOf[StreamExecution]) import org.apache.spark.sql.execution.streaming.MicroBatchExecution val microBatchEngine = engine.asInstanceOf[MicroBatchExecution] assert(microBatchEngine.trigger == Trigger.Once) |
| Name | Description | ||
|---|---|---|---|
|
|
Collection of Used when…FIXME |
||
|
|
TriggerExecutor for the Trigger:
Used when
|
Populating Start Offsets — populateStartOffsets Internal Method
|
1 2 3 4 5 |
populateStartOffsets(sparkSessionToRunBatches: SparkSession): Unit |
populateStartOffsets requests OffsetSeqLog for the latest committed batch id with its metadata if available.
|
Note
|
The batch id could not be available in metadata log if a streaming query started with a new metadata log or no batch was committed before. |
With the latest committed batch id with the metadata (from OffsetSeqLog) populateStartOffsets sets current batch id to the latest committed batch id, and availableOffsets to its offsets (considering them unprocessed yet).
|
Note
|
populateStartOffsets may re-execute the latest committed batch.
|
If the latest batch id is greater than 0, populateStartOffsets requests OffsetSeqLog for the second latest batch with its metadata (or reports a IllegalStateException if not found). populateStartOffsets sets committed offsets to the second latest committed offsets.
populateStartOffsets updates the offset metadata.
|
Caution
|
FIXME Why is the update needed? |
populateStartOffsets requests BatchCommitLog for the latest processed batch id with its metadata if available.
(only when the latest batch in OffsetSeqLog is also the latest batch in BatchCommitLog) With the latest processed batch id with the metadata (from BatchCommitLog), populateStartOffsets sets current batch id as the next after the latest processed batch. populateStartOffsets sets committed offsets to availableOffsets.
|
Caution
|
FIXME Describe what happens with availableOffsets.
|
populateStartOffsets constructs the next streaming batch.
|
Caution
|
FIXME Describe the WARN message when latestCommittedBatchId < latestBatchId - 1.
|
|
1 2 3 4 5 |
WARN Batch completion log latest batch id is [latestCommittedBatchId], which is not trailing batchid [latestBatchId] by one |
You should see the following DEBUG message in the logs:
|
1 2 3 4 5 |
DEBUG Resuming at batch [currentBatchId] with committed offsets [committedOffsets] and available offsets [availableOffsets] |
|
Caution
|
FIXME Include an example of Resuming at batch |
When the latest committed batch id with the metadata could not be found in BatchCommitLog, populateStartOffsets prints out the following INFO message to the logs:
|
1 2 3 4 5 |
INFO no commit log present |
|
Caution
|
FIXME Include an example of the case when no commit log present. |
When the latest committed batch id with the metadata could not be found in OffsetSeqLog, it is assumed that the streaming query is started for the first time. You should see the following INFO message in the logs:
|
1 2 3 4 5 |
INFO StreamExecution: Starting new streaming query. |
populateStartOffsets sets current batch id to 0 and constructs the next streaming batch.
|
Note
|
populateStartOffsets is used exclusively when MicroBatchExecution is requested to runActivatedStream.
|
Running Activated Streaming Query — runActivatedStream Method
|
1 2 3 4 5 |
runActivatedStream(sparkSessionForStream: SparkSession): Unit |
|
Note
|
runActivatedStream is part of StreamExecution Contract to run the activated streaming query.
|
runActivatedStream…FIXME
Creating MicroBatchExecution Instance
MicroBatchExecution takes the following when created:
-
Output mode (that is only used when creating
IncrementalExecutionfor a streaming batch in query planning) -
deleteCheckpointOnStopflag to control whether to delete the checkpoint directory on stop
MicroBatchExecution initializes the internal registries and counters.
Analyzed Logical Plan of Streaming Query — logicalPlan Property
|
1 2 3 4 5 |
logicalPlan: LogicalPlan |
|
Note
|
logicalPlan is part of StreamExecution Contract that is the analyzed logical plan of the streaming query.
|
logicalPlan resolves (replaces) StreamingRelation, StreamingRelationV2 logical operators to StreamingExecutionRelation logical operators.
|
Note
|
logicalPlan is a Scala lazy value and so the resolution happens only at the first access and is cached afterwards.
|
Internally, logicalPlan…FIXME
Constructing Next Streaming Batch — constructNextBatch Internal Method
|
1 2 3 4 5 |
constructNextBatch(): Unit |
constructNextBatch is made up of the following three parts:
-
Firstly, checking if there is new data available by requesting new offsets from every streaming source
-
There is some data to process (and so the next batch is constructed)
|
Note
|
constructNextBatch is used exclusively when MicroBatchExecution is requested to run the activated streaming query.
|
Checking Whether New Data Is Available (by Requesting New Offsets from Sources)
constructNextBatch starts by checking whether or not a new data is available in any of the streaming sources (in the logical query plan).
constructNextBatch acquires awaitProgressLock and gets the latest offset from every streaming data source.
|
Note
|
constructNextBatch checks out the latest offset in every streaming data source sequentially, i.e. one data source at a time.
|
|
Note
|
constructNextBatch uses the Source contract to get the latest offset (using Source.getOffset method).
|
constructNextBatch updates the status message to Getting offsets from [source] for every streaming data source.
In getOffset time-tracking section, constructNextBatch gets the offsets.
constructNextBatch prints out the following DEBUG message to the logs:
|
1 2 3 4 5 |
DEBUG StreamExecution: getOffset took [time] ms |
constructNextBatch adds the streaming sources that have the available offsets to availableOffsets.
If there is no data available (i.e. no offsets unprocessed in any of the streaming data sources), constructNextBatch turns noNewData flag on.
In the end (of this checking-data block), constructNextBatch releases awaitProgressLock
New Data Available
When new data is available, constructNextBatch updates the event time watermark (tracked using offsetSeqMetadata) if it finds one in the last IncrementalExecution.
If lastExecution is available (which may not when constructNextBatch is executed the very first time), constructNextBatch takes the executed physical plan (i.e. SparkPlan) and collects all EventTimeWatermarkExec physical operators with the count of eventTimeStats greater than 0.
|
Note
|
The executed physical plan is available as executedPlan property of IncrementalExecution (which is a custom QueryExecution).
|
You should see the following DEBUG message in the logs:
|
1 2 3 4 5 |
DEBUG StreamExecution: Observed event time stats: [eventTimeStats] |
constructNextBatch calculates the difference between the maximum value of eventTimeStats and delayMs for every EventTimeWatermarkExec physical operator.
|
Note
|
The maximum value of eventTimeStats is the youngest time, i.e. the time the closest to the current time.
|
constructNextBatch then takes the first difference (if available at all) and uses it as a possible new event time watermark.
If the event time watermark candidate is greater than the current watermark (i.e. later time-wise), constructNextBatch prints out the following INFO message to the logs:
|
1 2 3 4 5 |
INFO StreamExecution: Updating eventTime watermark to: [newWatermarkMs] ms |
constructNextBatch creates a new OffsetSeqMetadata with the new event time watermark and the current time.
Otherwise, if the eventTime watermark candidate is not greater than the current watermark, constructNextBatch simply prints out the following DEBUG message to the logs:
|
1 2 3 4 5 |
DEBUG StreamExecution: Event time didn't move: [newWatermarkMs] <= [batchWatermarkMs] |
constructNextBatch creates a new OffsetSeqMetadata with just the current time.
|
Note
|
Although constructNextBatch collects all the EventTimeWatermarkExec physical operators in the executed physical plan of lastExecution, only the first matters if available.
|
|
Note
|
A physical plan can have as many EventTimeWatermarkExec physical operators as withWatermark operator was used to create a streaming query.
|
|
Note
|
Streaming watermark can be changed between a streaming query’s restarts (and be different between what is checkpointed and the current version of the query). FIXME True? Example? |
constructNextBatch then adds the offsets to metadata log.
constructNextBatch updates the status message to Writing offsets to log.
In walCommit time-tracking section,
constructNextBatch adds the offsets in the batch to OffsetSeqLog.
|
Note
|
While writing the offsets to the metadata log,
|
constructNextBatch reports a AssertionError when writing to the metadata log has failed.
|
1 2 3 4 5 |
Concurrent update to the log. Multiple streaming jobs detected for [currentBatchId] |
|
Tip
|
Use StreamingQuery.lastProgress to access
|
|
Tip
|
Enable INFO logging level for
|
constructNextBatch commits the offsets for the batch (only when current batch id is not 0, i.e. when the query has just been started and constructNextBatch is called the first time).
constructNextBatch takes the previously-committed batch (from OffsetSeqLog), extracts the stored offsets per source.
|
Note
|
constructNextBatch uses OffsetSeq.toStreamProgress and sources registry to extract the offsets per source.
|
constructNextBatch requests every streaming source to commit the offsets
|
Note
|
constructNextBatch uses the Source contract to commit the offsets (using Source.commit method).
|
constructNextBatch reports a IllegalStateException when current batch id is 0.
|
1 2 3 4 5 |
batch [currentBatchId] doesn't exist |
In the end, constructNextBatch purges OffsetSeqLog and BatchCommitLog when current batch id is above spark.sql.streaming.minBatchesToRetain Spark property.
No New Data Available
If there is no new data available, constructNextBatch acquires a lock on awaitProgressLock, wakes up all waiting threads that are waiting for the stream to progress (using awaitProgressLockCondition), followed by releasing the lock on awaitProgressLock.
Checking Whether Data Is Available in Streaming Sources — dataAvailable Internal Method
|
1 2 3 4 5 |
dataAvailable: Boolean |
dataAvailable finds the streaming sources in availableOffsets for which the offsets committed (as recorded in committedOffsets) are different or do not exist at all.
If there are any differences in the number of sources or their committed offsets, dataAvailable is enabled (i.e. true).
|
Note
|
dataAvailable is used when StreamExecution runs streaming batches and constructs the next streaming batch.
|
Running Single Streaming Batch — runBatch Internal Method
|
1 2 3 4 5 |
runBatch(sparkSessionToRunBatch: SparkSession): Unit |
runBatch performs the following steps (aka phases):
-
getBatch Phase — Requesting New (and Hence Unprocessed) Data From Streaming Sources
-
triggerLogicalPlan Phase — Transforming Catalyst Expressions
-
queryPlanning Phase — Creating IncrementalExecution for Current Streaming Batch
-
nextBatch Phase — Creating Dataset (with IncrementalExecution for New Data)
-
awaitBatchLock Phase — Waking Up Threads Waiting For Stream to Progress
|
Note
|
runBatch is used exclusively when StreamExecution runs streaming batches.
|
getBatch Phase — Requesting New (and Hence Unprocessed) Data From Streaming Sources
Internally, runBatch first requests the streaming sources for unprocessed data (and stores them as DataFrames in newData internal registry).
In getBatch time-tracking section, runBatch goes over the available offsets per source and processes the offsets that have not been committed yet.
runBatch then requests every source for the data (as DataFrame with the new records).
|
Note
|
runBatch requests the streaming sources for new DataFrames sequentially, source by source.
|
You should see the following DEBUG message in the logs:
|
1 2 3 4 5 |
DEBUG StreamExecution: Retrieving data from [source]: [current] -> [available] |
You should then see the following DEBUG message in the logs:
|
1 2 3 4 5 |
DEBUG StreamExecution: getBatch took [timeTaken] ms |
withNewSources Phase — Replacing StreamingExecutionRelations (in Logical Plan) With Relations With New Data or Empty LocalRelation
In withNewSources phase, runBatch transforms logical query plan and replaces every StreamingExecutionRelation logical operator with the logical plan of the DataFrame with the input data in a batch for the corresponding streaming source.
|
Note
|
StreamingExecutionRelation logical operator is used to represent a streaming source in the logical query plan of a streaming Dataset.
|
runBatch finds the corresponding DataFrame (with the input data) per streaming source in newData internal registry. If found, runBatch takes the logical plan of the DataFrame. If not, runBatch creates a LocalRelation logical relation (for the output schema).
|
Note
|
newData internal registry contains entries for streaming sources that have new data available in the current batch. |
While replacing StreamingExecutionRelation operators, runBatch records the output schema of the streaming source (from StreamingExecutionRelation) and the DataFrame with the new data (in replacements temporary internal buffer).
runBatch makes sure that the output schema of the streaming source with a new data in the batch has not changed. If the output schema has changed, runBatch reports…FIXME
triggerLogicalPlan Phase — Transforming Catalyst Expressions
runBatch transforms Catalyst expressions in withNewSources new logical plan (using replacements temporary internal buffer).
-
Catalyst
Attributeis replaced with one if recorded inreplacementsinternal buffer (that corresponds to the attribute in theDataFramewith the new input data in the batch) -
CurrentTimestampandCurrentDateCatalyst expressions are replaced withCurrentBatchTimestampexpression (withbatchTimestampMsfrom OffsetSeqMetadata).
|
Note
|
Find more about |
|
Note
|
Find more about |
queryPlanning Phase — Creating IncrementalExecution for Current Streaming Batch
In queryPlanning time-tracking section, runBatch creates a new IncrementalExecution with the following:
-
Transformed logical query plan with logical relations for every streaming source and corresponding attributes
-
the streaming query’s output mode
-
statecheckpoint directory for managing state
The new IncrementalExecution is recorded in lastExecution property.
Before leaving queryPlanning section, runBatch forces preparation of the physical plan for execution (i.e. requesting IncrementalExecution for executedPlan).
|
Note
|
executedPlan is a physical plan (i.e. SparkPlan) ready for execution with state optimization rules applied.
|
nextBatch Phase — Creating Dataset (with IncrementalExecution for New Data)
runBatch creates a DataFrame with the new IncrementalExecution (as QueryExecution) and its analyzed output schema.
|
Note
|
The new DataFrame represents the result of a streaming query.
|
addBatch Phase — Adding Current Streaming Batch to Sink
In addBatch time-tracking section, runBatch requests the one and only streaming Sink to add the results of a streaming query (as the DataFrame created in nextBatch Phase).
|
Note
|
runBatch uses Sink.addBatch method to request the Sink to add the results.
|
|
Note
|
runBatch uses SQLExecution.withNewExecutionId to execute and track all the Spark actions (under one execution id) that Sink can use when requested to add the results.
|
|
Note
|
The new DataFrame will only be executed in Sink.addBatch.
|
|
Note
|
SQLExecution.withNewExecutionId posts a SparkListenerSQLExecutionStart event before executing Sink.addBatch and a SparkListenerSQLExecutionEnd event right afterwards.
|
|
Tip
|
Register You can find more information on |
awaitBatchLock Phase — Waking Up Threads Waiting For Stream to Progress
In awaitBatchLock code block (it is not a time-tracking section), runBatch acquires a lock on awaitProgressLock, wakes up all waiting threads on awaitProgressLockCondition and immediatelly releases awaitProgressLock lock.
|
Note
|
awaitProgressLockCondition is used mainly when StreamExecution processAllAvailable (and also when awaitOffset, but that seems mainly for testing).
|
isNewDataAvailable Internal Method
|
1 2 3 4 5 |
isNewDataAvailable: Boolean |
isNewDataAvailable…FIXME
|
Note
|
isNewDataAvailable is used when MicroBatchExecution is requested to runActivatedStream and constructNextBatch.
|
spark技术分享