@PublicEvolving public class RowCsvInputFormat extends CsvInputFormat<org.apache.flink.types.Row> implements org.apache.flink.api.java.typeutils.ResultTypeQueryable<org.apache.flink.types.Row>
Row
.DEFAULT_FIELD_DELIMITER, DEFAULT_LINE_DELIMITER, parsedValues
Constructor and Description |
---|
RowCsvInputFormat(org.apache.flink.core.fs.Path filePath,
org.apache.flink.api.common.typeinfo.TypeInformation[] fieldTypes) |
RowCsvInputFormat(org.apache.flink.core.fs.Path filePath,
org.apache.flink.api.common.typeinfo.TypeInformation[] fieldTypes,
boolean emptyColumnAsNull) |
RowCsvInputFormat(org.apache.flink.core.fs.Path filePath,
org.apache.flink.api.common.typeinfo.TypeInformation[] fieldTypes,
int[] selectedFields) |
RowCsvInputFormat(org.apache.flink.core.fs.Path filePath,
org.apache.flink.api.common.typeinfo.TypeInformation[] fieldTypes,
String lineDelimiter,
String fieldDelimiter) |
RowCsvInputFormat(org.apache.flink.core.fs.Path filePath,
org.apache.flink.api.common.typeinfo.TypeInformation[] fieldTypes,
String lineDelimiter,
String fieldDelimiter,
int[] selectedFields) |
RowCsvInputFormat(org.apache.flink.core.fs.Path filePath,
org.apache.flink.api.common.typeinfo.TypeInformation[] fieldTypeInfos,
String lineDelimiter,
String fieldDelimiter,
int[] selectedFields,
boolean emptyColumnAsNull) |
Modifier and Type | Method and Description |
---|---|
protected org.apache.flink.types.Row |
fillRecord(org.apache.flink.types.Row reuse,
Object[] parsedValues) |
org.apache.flink.api.common.typeinfo.TypeInformation<org.apache.flink.types.Row> |
getProducedType() |
protected boolean |
parseRecord(Object[] holders,
byte[] bytes,
int offset,
int numBytes) |
createDefaultMask, getFieldTypes, nextRecord, open, readRecord, toBooleanMask, toString
checkAndCoSort, checkForMonotonousOrder, close, enableQuotedStringParsing, getCommentPrefix, getFieldDelimiter, getFieldParsers, getGenericFieldTypes, getNumberOfFieldsTotal, getNumberOfNonNullFields, isLenient, isSkippingFirstLineAsHeader, setCharset, setCommentPrefix, setFieldDelimiter, setFieldsGeneric, setFieldsGeneric, setFieldTypesGeneric, setLenient, setSkipFirstLineAsHeader, skipFields, supportsMultiPaths
configure, getBufferSize, getCharset, getCurrentState, getDelimiter, getLineLengthLimit, getNumLineSamples, getStatistics, loadConfigParameters, loadGlobalConfigParams, 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 RowCsvInputFormat(org.apache.flink.core.fs.Path filePath, org.apache.flink.api.common.typeinfo.TypeInformation[] fieldTypeInfos, String lineDelimiter, String fieldDelimiter, int[] selectedFields, boolean emptyColumnAsNull)
public RowCsvInputFormat(org.apache.flink.core.fs.Path filePath, org.apache.flink.api.common.typeinfo.TypeInformation[] fieldTypes, String lineDelimiter, String fieldDelimiter, int[] selectedFields)
public RowCsvInputFormat(org.apache.flink.core.fs.Path filePath, org.apache.flink.api.common.typeinfo.TypeInformation[] fieldTypes, String lineDelimiter, String fieldDelimiter)
public RowCsvInputFormat(org.apache.flink.core.fs.Path filePath, org.apache.flink.api.common.typeinfo.TypeInformation[] fieldTypes, int[] selectedFields)
public RowCsvInputFormat(org.apache.flink.core.fs.Path filePath, org.apache.flink.api.common.typeinfo.TypeInformation[] fieldTypes, boolean emptyColumnAsNull)
public RowCsvInputFormat(org.apache.flink.core.fs.Path filePath, org.apache.flink.api.common.typeinfo.TypeInformation[] fieldTypes)
protected org.apache.flink.types.Row fillRecord(org.apache.flink.types.Row reuse, Object[] parsedValues)
fillRecord
in class CsvInputFormat<org.apache.flink.types.Row>
protected boolean parseRecord(Object[] holders, byte[] bytes, int offset, int numBytes) throws org.apache.flink.api.common.io.ParseException
parseRecord
in class org.apache.flink.api.common.io.GenericCsvInputFormat<org.apache.flink.types.Row>
org.apache.flink.api.common.io.ParseException
public org.apache.flink.api.common.typeinfo.TypeInformation<org.apache.flink.types.Row> getProducedType()
getProducedType
in interface org.apache.flink.api.java.typeutils.ResultTypeQueryable<org.apache.flink.types.Row>
Copyright © 2014–2018 The Apache Software Foundation. All rights reserved.