Class AbstractCsvInputFormat<T>

  • All Implemented Interfaces:
    Serializable, org.apache.flink.api.common.io.InputFormat<T,​org.apache.flink.core.fs.FileInputSplit>, org.apache.flink.core.io.InputSplitSource<org.apache.flink.core.fs.FileInputSplit>
    Direct Known Subclasses:
    RowCsvInputFormat

    public abstract class AbstractCsvInputFormat<T>
    extends org.apache.flink.api.common.io.FileInputFormat<T>
    Input format that reads csv. This abstract class is responsible for cutting the boundary of InputSplit.
    See Also:
    Serialized Form
    • Nested Class Summary

      • Nested classes/interfaces inherited from class org.apache.flink.api.common.io.FileInputFormat

        org.apache.flink.api.common.io.FileInputFormat.FileBaseStatistics, org.apache.flink.api.common.io.FileInputFormat.InputSplitOpenThread
    • Field Summary

      Fields 
      Modifier and Type Field Description
      protected InputStream csvInputStream  
      protected org.apache.flink.shaded.jackson2.com.fasterxml.jackson.dataformat.csv.CsvSchema csvSchema  
      • Fields inherited from class org.apache.flink.api.common.io.FileInputFormat

        currentSplit, enumerateNestedFiles, INFLATER_INPUT_STREAM_FACTORIES, minSplitSize, numSplits, openTimeout, READ_WHOLE_SPLIT_FLAG, splitLength, splitStart, stream, unsplittable
    • Constructor Summary

      Constructors 
      Constructor Description
      AbstractCsvInputFormat​(org.apache.flink.core.fs.Path[] filePaths, org.apache.flink.shaded.jackson2.com.fasterxml.jackson.dataformat.csv.CsvSchema csvSchema)  
    • Method Summary

      All Methods Instance Methods Concrete Methods 
      Modifier and Type Method Description
      void open​(org.apache.flink.core.fs.FileInputSplit split)  
      • Methods inherited from class org.apache.flink.api.common.io.FileInputFormat

        acceptFile, close, configure, createInputSplits, decorateInputStream, extractFileExtension, getFilePaths, getFileStats, getFileStats, getInflaterInputStreamFactory, getInputSplitAssigner, getMinSplitSize, getNestedFileEnumeration, getNumSplits, getOpenTimeout, getSplitLength, getSplitStart, getStatistics, getSupportedCompressionFormats, registerInflaterInputStreamFactory, setFilePath, setFilePath, setFilePaths, setFilePaths, setFilesFilter, setMinSplitSize, setNestedFileEnumeration, setNumSplits, setOpenTimeout, testForUnsplittable, toString
      • Methods inherited from class org.apache.flink.api.common.io.RichInputFormat

        closeInputFormat, getRuntimeContext, openInputFormat, setRuntimeContext
      • Methods inherited from interface org.apache.flink.api.common.io.InputFormat

        nextRecord, reachedEnd
    • Field Detail

      • csvSchema

        protected final org.apache.flink.shaded.jackson2.com.fasterxml.jackson.dataformat.csv.CsvSchema csvSchema
      • csvInputStream

        protected transient InputStream csvInputStream
    • Constructor Detail

      • AbstractCsvInputFormat

        public AbstractCsvInputFormat​(org.apache.flink.core.fs.Path[] filePaths,
                                      org.apache.flink.shaded.jackson2.com.fasterxml.jackson.dataformat.csv.CsvSchema csvSchema)
    • Method Detail

      • open

        public void open​(org.apache.flink.core.fs.FileInputSplit split)
                  throws IOException
        Specified by:
        open in interface org.apache.flink.api.common.io.InputFormat<T,​org.apache.flink.core.fs.FileInputSplit>
        Overrides:
        open in class org.apache.flink.api.common.io.FileInputFormat<T>
        Throws:
        IOException