Step 1 of 4: Choose Issues

Cancel

T Patch Info Key Summary Assignee Reporter P Status Resolution Created Updated Due Development
Sub-task SPARK-18477

SPARK-8360 Enable interrupts for HDFS in HDFSMetadataLog

Shixiong Zhu Shixiong Zhu Major Resolved Fixed  
Sub-task SPARK-18474

SPARK-8360 Add StreamingQuery.status in python

Tathagata Das Tathagata Das Major Closed Duplicate  
Sub-task SPARK-18461

SPARK-8360 Improve docs on StreamingQueryListener and StreamingQuery.status

Tathagata Das Tathagata Das Major Resolved Fixed  
Sub-task SPARK-18460

SPARK-8360 Include triggerDetails in StreamingQueryStatus.json

Tathagata Das Tathagata Das Major Resolved Fixed  
Sub-task SPARK-18459

SPARK-8360 Rename triggerId to batchId in StreamingQueryStatus.triggerDetails

Tathagata Das Tathagata Das Major Resolved Fixed  
Sub-task SPARK-18440

SPARK-8360 Fix FileStreamSink with aggregation + watermark + append mode

Tathagata Das Tathagata Das Major Resolved Fixed  
Sub-task SPARK-18416

SPARK-8360 State Store leaks temporary files

Tathagata Das Tathagata Das Major Resolved Fixed  
Sub-task SPARK-18164

SPARK-8360 ForeachSink should fail the Spark job if `process` throws exception

Shixiong Zhu Shixiong Zhu Major Resolved Fixed  
Sub-task SPARK-18143

SPARK-8360 History Server is broken because of the refactoring work in Structured Streaming

Shixiong Zhu Shixiong Zhu Blocker Resolved Fixed  
Sub-task SPARK-17926

SPARK-8360 Add methods to convert StreamingQueryStatus to json

Tathagata Das Tathagata Das Major Resolved Fixed  
Sub-task SPARK-17731

SPARK-8360 Metrics for Structured Streaming

Tathagata Das Tathagata Das Major Resolved Fixed  
Sub-task SPARK-17372

SPARK-8360 Running a file stream on a directory with partitioned subdirs throw NotSerializableException/StackOverflowError

Tathagata Das Tathagata Das Major Resolved Fixed  
Sub-task SPARK-17096

SPARK-8360 Fix StreamingQueryListener to return message and stacktrace of actual exception

Tathagata Das Tathagata Das Minor Resolved Fixed  
Sub-task SPARK-16430

SPARK-8360 Add an option in file stream source to read 1 file at a time

Tathagata Das Tathagata Das Major Resolved Fixed  
Sub-task SPARK-16266

SPARK-8360 Move python DataStreamReader/Writer from pyspark.sql to pyspark.sql.streaming package

Tathagata Das Tathagata Das Major Resolved Fixed  
Sub-task SPARK-16256

SPARK-8360 Add Structured Streaming Programming Guide

Tathagata Das Tathagata Das Major Resolved Fixed  
Sub-task SPARK-16116

SPARK-8360 ConsoleSink should not require checkpointLocation

Shixiong Zhu Shixiong Zhu Major Resolved Fixed  
Sub-task SPARK-16114

SPARK-8360 Add network word count example

James Thomas James Thomas Major Resolved Fixed  
Sub-task SPARK-16050

SPARK-8360 Flaky Test: Complete aggregation with Console sink

Shixiong Zhu Burak Yavuz Critical Resolved Fixed  
Sub-task SPARK-16020

SPARK-8360 Fix complete mode aggregation with console sink

Shixiong Zhu Shixiong Zhu Major Resolved Fixed  
Sub-task SPARK-16002

SPARK-8360 Sleep when no new data arrives to avoid 100% CPU usage

Shixiong Zhu Shixiong Zhu Major Resolved Fixed  
Sub-task SPARK-15981

SPARK-8360 Fix bug in python DataStreamReader

Tathagata Das Tathagata Das Blocker Resolved Fixed  
Sub-task SPARK-15953

SPARK-8360 Renamed ContinuousQuery to StreamingQuery for simplicity

Tathagata Das Tathagata Das Major Resolved Fixed  
Sub-task SPARK-15935

SPARK-8360 Enable test for sql/streaming.py and fix these tests

Shixiong Zhu Shixiong Zhu Major Resolved Fixed  
Sub-task SPARK-15933

SPARK-8360 Refactor reader-writer interface for streaming DFs to use DataStreamReader/Writer

Tathagata Das Tathagata Das Major Resolved Fixed  
Sub-task SPARK-15889

SPARK-8360 Add a unique id to ContinuousQuery

Tathagata Das Tathagata Das Major Resolved Fixed  
Sub-task SPARK-15853

SPARK-8360 HDFSMetadataLog.get leaks the input stream

Shixiong Zhu Shixiong Zhu Major Resolved Fixed  
Sub-task SPARK-15842

SPARK-8360 Add support for socket stream.

Prashant Sharma Prashant Sharma Major Closed Not A Problem  
Sub-task SPARK-15812

SPARK-8360 Allow sorting on aggregated streaming dataframe when the output mode is Complete

Tathagata Das Tathagata Das Major Resolved Fixed  
Sub-task SPARK-15765

SPARK-8360 Make continuous Parquet writes consistent with non-continuous Parquet writes

Unassigned Liwei Lin(Inactive) Major Closed Duplicate  
Sub-task SPARK-15593

SPARK-8360 Add DataFrameWriter.foreach to allow the user consuming data in ContinuousQuery

Shixiong Zhu Shixiong Zhu Major Resolved Fixed  
Sub-task SPARK-15580

SPARK-8360 Add ContinuousQueryInfo to make ContinuousQueryListener events serializable

Shixiong Zhu Shixiong Zhu Major Resolved Fixed  
Sub-task SPARK-15517

SPARK-8360 Add support for complete output mode

Tathagata Das Tathagata Das Major Resolved Fixed  
Sub-task SPARK-15458

SPARK-8360 Disable schema inference for streaming datasets on file streams

Tathagata Das Tathagata Das Major Resolved Fixed  
Sub-task SPARK-15443

SPARK-8360 Properly explain the streaming queries

Shixiong Zhu Saisai Shao Minor Resolved Fixed  
Sub-task SPARK-15428

SPARK-8360 Disable support for multiple streaming aggregations

Tathagata Das Tathagata Das Major Resolved Fixed  
Sub-task SPARK-15375

SPARK-8360 Add ConsoleSink for structure streaming to display the dataframe on the fly

Saisai Shao Saisai Shao Minor Resolved Fixed  
Sub-task SPARK-15103

SPARK-8360 Add support for batch jobs correctly inferring partitions from data written with file stream sink

Tathagata Das Tathagata Das Major Resolved Fixed  
Sub-task SPARK-15077

SPARK-8360 StreamExecution.awaitOffset may take too long because of thread starvation

Shixiong Zhu Shixiong Zhu Major Resolved Fixed  
Sub-task SPARK-14860

SPARK-8360 Fix flaky test: o.a.s.sql.util.ContinuousQueryListenerSuite "event ordering"

Shixiong Zhu Shixiong Zhu Major Resolved Fixed  
Sub-task SPARK-14837

SPARK-8360 Add support in file stream source for reading new files added to subdirs

Tathagata Das Tathagata Das Major Resolved Fixed  
Sub-task SPARK-14833

SPARK-8360 Refactor StreamTests to test for source fault-tolerance correctly.

Tathagata Das Tathagata Das Major Resolved Fixed  
Sub-task SPARK-14832

SPARK-8360 Refactor DataSource to ensure schema is inferred only once when creating a file stream

Tathagata Das Tathagata Das Major Resolved Fixed  
Sub-task SPARK-14716

SPARK-8360 Add partitioned parquet support file stream sink

Tathagata Das Tathagata Das Major Resolved Fixed  
Sub-task SPARK-14678

SPARK-8360 Add a file sink log to support versioning and compaction

Shixiong Zhu Shixiong Zhu Major Resolved Fixed  
Sub-task SPARK-14579

SPARK-8360 Fix a race condition in StreamExecution.processAllAvailable

Shixiong Zhu Shixiong Zhu Major Resolved Fixed  
Sub-task SPARK-14555

SPARK-8360 Python API for methods introduced for Structured Streaming

Burak Yavuz Burak Yavuz Major Resolved Fixed  
Sub-task SPARK-14494

SPARK-8360 Fix the race conditions in MemoryStream and MemorySink

Shixiong Zhu Shixiong Zhu Major Resolved Fixed  
Sub-task SPARK-14474

SPARK-8360 Move FileSource offset log into checkpointLocation

Shixiong Zhu Shixiong Zhu Major Resolved Fixed  
Sub-task SPARK-14473

SPARK-8360 Define analysis rules for operations not supported in streaming

Tathagata Das Tathagata Das Major Resolved Fixed  
Sub-task SPARK-14411

SPARK-8360 Add a note to warn that onQueryProgress is asynchronous

Shixiong Zhu Shixiong Zhu Minor Resolved Fixed  
Sub-task SPARK-14382

SPARK-8360 QueryProgress should be post after committedOffsets is updated

Shixiong Zhu Shixiong Zhu Major Resolved Fixed  
Sub-task SPARK-14316

SPARK-8360 StateStoreCoordinator should extend ThreadSafeRpcEndpoint

Shixiong Zhu Shixiong Zhu Major Resolved Fixed  
Sub-task SPARK-14288

SPARK-8360 Memory Sink

Michael Armbrust Michael Armbrust Major Resolved Fixed  
Sub-task SPARK-14287

SPARK-8360 Method to determine if Dataset is bounded or not

Burak Yavuz Burak Yavuz Major Resolved Fixed  
Sub-task SPARK-14257

SPARK-8360 Allow multiple continuous queries to be started from the same DataFrame

Shixiong Zhu Shixiong Zhu Major Resolved Fixed  
Sub-task SPARK-14255

SPARK-8360 Streaming Aggregation

Michael Armbrust Michael Armbrust Major Resolved Fixed  
Sub-task SPARK-14176

SPARK-8360 Add processing time trigger

Shixiong Zhu Shixiong Zhu Major Resolved Fixed  
Sub-task SPARK-14160

SPARK-8360 Windowing for structured streaming

Burak Yavuz Burak Yavuz Major Resolved Fixed  
Sub-task SPARK-14131

SPARK-8360 Add a workaround for HADOOP-10622 to fix DataFrameReaderWriterSuite

Shixiong Zhu Shixiong Zhu Major Resolved Fixed  
Sub-task SPARK-14078

SPARK-8360 Simple FileSink for Parquet

Michael Armbrust Michael Armbrust Major Resolved Fixed  
Sub-task SPARK-13985

SPARK-8360 WAL for determistic batches with IDs

Michael Armbrust Michael Armbrust Major Resolved Fixed  
Sub-task SPARK-13875

SPARK-8360 Old streaming DataFrame proposal by Cheng Hao (Intel)

Cheng Hao Reynold Xin Major Closed Fixed  
Sub-task SPARK-13809

SPARK-8360 State Store: A new framework for state management for computing Streaming Aggregates

Tathagata Das Tathagata Das Major Resolved Done  
Sub-task SPARK-13794

SPARK-8360 Rename DataFrameWriter.stream DataFrameWriter.startStream

Reynold Xin Reynold Xin Major Resolved Fixed  
Sub-task SPARK-13791

SPARK-8360 Add MetadataLog and HDFSMetadataLog

Shixiong Zhu Shixiong Zhu Major Resolved Fixed  
Sub-task SPARK-13584

SPARK-8360 ContinuousQueryManagerSuite floods the logs with garbage

Shixiong Zhu Shixiong Zhu Major Resolved Fixed  
Sub-task SPARK-13405

SPARK-8360 Flaky test: o.a.s.sql.util.ContinuousQueryListenerSuite.event ordering

Shixiong Zhu Shixiong Zhu Major Resolved Fixed  
Sub-task SPARK-13166

SPARK-8360 Remove DataStreamReader/Writer

Reynold Xin Reynold Xin Major Resolved Fixed  
Sub-task SPARK-13149

SPARK-8360 Add FileStreamSource

Shixiong Zhu Shixiong Zhu Major Resolved Fixed  
Sub-task SPARK-13146

SPARK-8360 API for managing streaming dataframes

Tathagata Das Tathagata Das Major Resolved Fixed  
Sub-task SPARK-10823

SPARK-8360 API design: external state management

Unassigned Reynold Xin Major Closed Later  
Sub-task SPARK-10820

SPARK-8360 Initial infrastructure

Michael Armbrust Reynold Xin Major Resolved Fixed  
Sub-task SPARK-10814

SPARK-8360 API design: convergence of batch and streaming DataFrame

Reynold Xin Reynold Xin Major Resolved Fixed  

Cancel