Uploaded image for project: 'Flink'
  1. Flink
  2. FLINK-30049

CsvBulkWriter is unsupported for S3 FileSystem in streaming sink

    XMLWordPrintableJSON

Details

    Description

      Caused by: org.apache.flink.util.SerializedThrowable: Cannot sync state to system like S3. Use persist() to create a persistent recoverable intermediate point.
      	at org.apache.flink.core.fs.RefCountedBufferingFileStream.sync(RefCountedBufferingFileStream.java:111) 
      	at org.apache.flink.fs.s3.common.writer.S3RecoverableFsDataOutputStream.sync
      	at org.apache.flink.formats.csv.CsvBulkWriter.finish(CsvBulkWriter.java:106) 
      	at org.apache.flink.connector.file.table.FileSystemTableSink$ProjectionBulkFactory$1.finish(FileSystemTableSink.java:653) 
      	at org.apache.flink.streaming.api.functions.sink.filesystem.BulkPartWriter.closeForCommit(BulkPartWriter.java:64) 
      

      It looks like we should not call `sync` in CsvBulkWriter, we should just use `flush`.

      Attachments

        Activity

          People

            Unassigned Unassigned
            lzljs3620320 Jingsong Lee
            Votes:
            0 Vote for this issue
            Watchers:
            2 Start watching this issue

            Dates

              Created:
              Updated: