OUT
- @Internal
public abstract class CsvInputFormat<OUT>
extends org.apache.flink.api.common.io.GenericCsvInputFormat<OUT>
Modifier and Type | Field and Description |
---|---|
static String |
DEFAULT_FIELD_DELIMITER |
static String |
DEFAULT_LINE_DELIMITER |
protected Object[] |
parsedValues |
commentCount, commentPrefix, fieldIncluded, invalidLineCount, lineDelimiterIsLinebreak
Modifier | Constructor and Description |
---|---|
protected |
CsvInputFormat(org.apache.flink.core.fs.Path filePath) |
Modifier and Type | Method and Description |
---|---|
protected static boolean[] |
createDefaultMask(int size) |
protected abstract OUT |
fillRecord(OUT reuse,
Object[] parsedValues) |
Class<?>[] |
getFieldTypes() |
protected void |
initializeSplit(org.apache.flink.core.fs.FileInputSplit split,
Long offset) |
OUT |
nextRecord(OUT record) |
OUT |
readRecord(OUT reuse,
byte[] bytes,
int offset,
int numBytes) |
protected static boolean[] |
toBooleanMask(int[] sourceFieldIndices) |
String |
toString() |
checkAndCoSort, checkForMonotonousOrder, close, enableQuotedStringParsing, getCommentPrefix, getFieldDelimiter, getFieldParsers, getGenericFieldTypes, getNumberOfFieldsTotal, getNumberOfNonNullFields, isLenient, isSkippingFirstLineAsHeader, parseRecord, setCharset, setCommentPrefix, setFieldDelimiter, setFieldsGeneric, setFieldsGeneric, setFieldTypesGeneric, setLenient, setSkipFirstLineAsHeader, skipFields, supportsMultiPaths
configure, getBufferSize, getCharset, getCurrentState, getDelimiter, getLineLengthLimit, getNumLineSamples, getStatistics, loadConfigParameters, loadGlobalConfigParams, open, reachedEnd, readLine, reopen, setBufferSize, setDelimiter, setDelimiter, setDelimiter, setLineLengthLimit, setNumLineSamples
acceptFile, createInputSplits, decorateInputStream, extractFileExtension, getFilePath, getFilePaths, getFileStats, getFileStats, getInflaterInputStreamFactory, getInputSplitAssigner, getMinSplitSize, getNestedFileEnumeration, getNumSplits, getOpenTimeout, getSplitLength, getSplitStart, registerInflaterInputStreamFactory, setFilePath, setFilePath, setFilePaths, setFilePaths, setFilesFilter, setMinSplitSize, setNestedFileEnumeration, setNumSplits, setOpenTimeout, testForUnsplittable
public static final String DEFAULT_LINE_DELIMITER
public static final String DEFAULT_FIELD_DELIMITER
protected transient Object[] parsedValues
protected void initializeSplit(org.apache.flink.core.fs.FileInputSplit split, Long offset) throws IOException
initializeSplit
in class org.apache.flink.api.common.io.GenericCsvInputFormat<OUT>
IOException
public OUT nextRecord(OUT record) throws IOException
nextRecord
in interface org.apache.flink.api.common.io.InputFormat<OUT,org.apache.flink.core.fs.FileInputSplit>
nextRecord
in class org.apache.flink.api.common.io.DelimitedInputFormat<OUT>
IOException
public OUT readRecord(OUT reuse, byte[] bytes, int offset, int numBytes) throws IOException
readRecord
in class org.apache.flink.api.common.io.DelimitedInputFormat<OUT>
IOException
public Class<?>[] getFieldTypes()
protected static boolean[] createDefaultMask(int size)
protected static boolean[] toBooleanMask(int[] sourceFieldIndices)
Copyright © 2014–2022 The Apache Software Foundation. All rights reserved.