public 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 |
| Constructor and Description |
|---|
CsvInputFormat(org.apache.flink.core.fs.Path filePath,
String lineDelimiter,
String fieldDelimiter,
org.apache.flink.api.common.typeinfo.TypeInformation<OUT> typeInformation) |
CsvInputFormat(org.apache.flink.core.fs.Path filePath,
org.apache.flink.api.common.typeinfo.TypeInformation<OUT> typeInformation) |
| Modifier and Type | Method and Description |
|---|---|
Class<?>[] |
getFieldTypes() |
OUT |
nextRecord(OUT record) |
void |
open(org.apache.flink.core.fs.FileInputSplit split) |
OUT |
readRecord(OUT reuse,
byte[] bytes,
int offset,
int numBytes) |
void |
setFields(boolean[] sourceFieldMask,
Class<?>[] fieldTypes) |
void |
setFields(int[] sourceFieldIndices,
Class<?>[] fieldTypes) |
void |
setFieldTypes(Class<?>... fieldTypes) |
void |
setOrderOfPOJOFields(String[] fieldsOrder) |
String |
toString() |
checkAndCoSort, checkForMonotonousOrder, close, enableQuotedStringParsing, getCommentPrefix, getFieldDelimiter, getFieldParsers, getGenericFieldTypes, getNumberOfFieldsTotal, getNumberOfNonNullFields, isLenient, isSkippingFirstLineAsHeader, parseRecord, setCommentPrefix, setCommentPrefix, setCommentPrefix, setCommentPrefix, setCommentPrefix, setFieldDelimiter, setFieldDelimiter, setFieldDelimiter, setFieldsGeneric, setFieldsGeneric, setFieldTypesGeneric, setLenient, setSkipFirstLineAsHeader, skipFieldsconfigure, configureDelimitedFormat, getBufferSize, getDelimiter, getLineLengthLimit, getNumLineSamples, getStatistics, loadGloablConfigParams, reachedEnd, readLine, setBufferSize, setDelimiter, setDelimiter, setDelimiter, setLineLengthLimit, setNumLineSamplesacceptFile, configureFileFormat, createInputSplits, decorateInputStream, extractFileExtension, getFilePath, getFileStats, getInflaterInputStreamFactory, getInputSplitAssigner, getMinSplitSize, getNumSplits, getOpenTimeout, getSplitLength, getSplitStart, registerInflaterInputStreamFactory, setFilePath, setFilePath, setMinSplitSize, setNumSplits, setOpenTimeout, testForUnsplittablepublic static final String DEFAULT_LINE_DELIMITER
public static final String DEFAULT_FIELD_DELIMITER
public CsvInputFormat(org.apache.flink.core.fs.Path filePath,
org.apache.flink.api.common.typeinfo.TypeInformation<OUT> typeInformation)
public void setOrderOfPOJOFields(String[] fieldsOrder)
public void setFieldTypes(Class<?>... fieldTypes)
public void setFields(int[] sourceFieldIndices,
Class<?>[] fieldTypes)
public void setFields(boolean[] sourceFieldMask,
Class<?>[] fieldTypes)
public Class<?>[] getFieldTypes()
public void open(org.apache.flink.core.fs.FileInputSplit split)
throws IOException
open in interface org.apache.flink.api.common.io.InputFormat<OUT,org.apache.flink.core.fs.FileInputSplit>open in class org.apache.flink.api.common.io.GenericCsvInputFormat<OUT>IOExceptionpublic 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>IOExceptionpublic OUT readRecord(OUT reuse, byte[] bytes, int offset, int numBytes) throws IOException
readRecord in class org.apache.flink.api.common.io.DelimitedInputFormat<OUT>IOExceptionCopyright © 2014–2015 The Apache Software Foundation. All rights reserved.