Class CsvInputFormat<OUT>
- java.lang.Object
-
- org.apache.flink.api.common.io.RichInputFormat<OT,FileInputSplit>
-
- org.apache.flink.api.common.io.FileInputFormat<OT>
-
- org.apache.flink.api.common.io.DelimitedInputFormat<OT>
-
- org.apache.flink.api.common.io.GenericCsvInputFormat<OUT>
-
- org.apache.flink.table.sources.format.CsvInputFormat<OUT>
-
- Type Parameters:
OUT
-
- All Implemented Interfaces:
Serializable
,CheckpointableInputFormat<FileInputSplit,Long>
,InputFormat<OUT,FileInputSplit>
,InputSplitSource<FileInputSplit>
- Direct Known Subclasses:
RowCsvInputFormat
@Deprecated @Internal public abstract class CsvInputFormat<OUT> extends GenericCsvInputFormat<OUT>
Deprecated.InputFormat that reads csv files.This class is copied from
flink-java
module and should be removed later.- See Also:
- Serialized Form
-
-
Nested Class Summary
-
Nested classes/interfaces inherited from class org.apache.flink.api.common.io.FileInputFormat
FileInputFormat.FileBaseStatistics, FileInputFormat.InputSplitOpenThread
-
-
Field Summary
Fields Modifier and Type Field Description static String
DEFAULT_FIELD_DELIMITER
Deprecated.static String
DEFAULT_LINE_DELIMITER
Deprecated.protected Object[]
parsedValues
Deprecated.-
Fields inherited from class org.apache.flink.api.common.io.GenericCsvInputFormat
commentCount, commentPrefix, fieldIncluded, invalidLineCount, lineDelimiterIsLinebreak
-
Fields inherited from class org.apache.flink.api.common.io.DelimitedInputFormat
currBuffer, currLen, currOffset, RECORD_DELIMITER
-
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 Modifier Constructor Description protected
CsvInputFormat(Path filePath)
Deprecated.
-
Method Summary
All Methods Static Methods Instance Methods Abstract Methods Concrete Methods Deprecated Methods Modifier and Type Method Description protected static boolean[]
createDefaultMask(int size)
Deprecated.protected abstract OUT
fillRecord(OUT reuse, Object[] parsedValues)
Deprecated.Class<?>[]
getFieldTypes()
Deprecated.protected void
initializeSplit(FileInputSplit split, Long offset)
Deprecated.Initialization method that is called after opening or reopening an input split.OUT
nextRecord(OUT record)
Deprecated.Reads the next record from the input.OUT
readRecord(OUT reuse, byte[] bytes, int offset, int numBytes)
Deprecated.This function parses the given byte array which represents a serialized record.protected static boolean[]
toBooleanMask(int[] sourceFieldIndices)
Deprecated.String
toString()
Deprecated.-
Methods inherited from class org.apache.flink.api.common.io.GenericCsvInputFormat
checkAndCoSort, checkForMonotonousOrder, close, enableQuotedStringParsing, getCommentPrefix, getFieldDelimiter, getFieldParsers, getGenericFieldTypes, getNumberOfFieldsTotal, getNumberOfNonNullFields, isLenient, isSkippingFirstLineAsHeader, parseRecord, setCharset, setCommentPrefix, setFieldDelimiter, setFieldsGeneric, setFieldsGeneric, setFieldTypesGeneric, setLenient, setSkipFirstLineAsHeader, skipFields
-
Methods inherited from class org.apache.flink.api.common.io.DelimitedInputFormat
configure, getBufferSize, getCharset, getCurrentState, getDelimiter, getLineLengthLimit, getNumLineSamples, getStatistics, loadConfigParameters, open, reachedEnd, readLine, reopen, setBufferSize, setDelimiter, setDelimiter, setDelimiter, setLineLengthLimit, setNumLineSamples
-
Methods inherited from class org.apache.flink.api.common.io.FileInputFormat
acceptFile, createInputSplits, decorateInputStream, extractFileExtension, getFilePaths, getFileStats, getFileStats, getInflaterInputStreamFactory, getInputSplitAssigner, getMinSplitSize, getNestedFileEnumeration, getNumSplits, getOpenTimeout, getSplitLength, getSplitStart, getSupportedCompressionFormats, registerInflaterInputStreamFactory, setFilePath, setFilePath, setFilePaths, setFilePaths, setFilesFilter, setMinSplitSize, setNestedFileEnumeration, setNumSplits, setOpenTimeout, testForUnsplittable
-
Methods inherited from class org.apache.flink.api.common.io.RichInputFormat
closeInputFormat, getRuntimeContext, openInputFormat, setRuntimeContext
-
-
-
-
Field Detail
-
DEFAULT_LINE_DELIMITER
public static final String DEFAULT_LINE_DELIMITER
Deprecated.- See Also:
- Constant Field Values
-
DEFAULT_FIELD_DELIMITER
public static final String DEFAULT_FIELD_DELIMITER
Deprecated.- See Also:
- Constant Field Values
-
parsedValues
protected transient Object[] parsedValues
Deprecated.
-
-
Constructor Detail
-
CsvInputFormat
protected CsvInputFormat(Path filePath)
Deprecated.
-
-
Method Detail
-
initializeSplit
protected void initializeSplit(FileInputSplit split, Long offset) throws IOException
Deprecated.Description copied from class:DelimitedInputFormat
Initialization method that is called after opening or reopening an input split.- Overrides:
initializeSplit
in classGenericCsvInputFormat<OUT>
- Parameters:
split
- Split that was opened or reopenedoffset
- Checkpointed state if the split was reopened- Throws:
IOException
-
nextRecord
public OUT nextRecord(OUT record) throws IOException
Deprecated.Description copied from interface:InputFormat
Reads the next record from the input.When this method is called, the input format it guaranteed to be opened.
- Specified by:
nextRecord
in interfaceInputFormat<OUT,FileInputSplit>
- Overrides:
nextRecord
in classDelimitedInputFormat<OUT>
- Parameters:
record
- Object that may be reused.- Returns:
- Read record.
- Throws:
IOException
- Thrown, if an I/O error occurred.
-
readRecord
public OUT readRecord(OUT reuse, byte[] bytes, int offset, int numBytes) throws IOException
Deprecated.Description copied from class:DelimitedInputFormat
This function parses the given byte array which represents a serialized record. The function returns a valid record or throws an IOException.- Specified by:
readRecord
in classDelimitedInputFormat<OUT>
- Parameters:
reuse
- An optionally reusable object.bytes
- Binary data of serialized records.offset
- The offset where to start to read the record data.numBytes
- The number of bytes that can be read starting at the offset position.- Returns:
- Returns the read record if it was successfully deserialized.
- Throws:
IOException
- if the record could not be read.
-
getFieldTypes
public Class<?>[] getFieldTypes()
Deprecated.
-
createDefaultMask
protected static boolean[] createDefaultMask(int size)
Deprecated.
-
toBooleanMask
protected static boolean[] toBooleanMask(int[] sourceFieldIndices)
Deprecated.
-
toString
public String toString()
Deprecated.- Overrides:
toString
in classFileInputFormat<OUT>
-
-