OUT
- @Internal
public abstract class CsvInputFormat<OUT>
extends org.apache.flink.api.common.io.GenericCsvInputFormat<OUT>
限定符和类型 | 字段和说明 |
---|---|
static String |
DEFAULT_FIELD_DELIMITER |
static String |
DEFAULT_LINE_DELIMITER |
protected Object[] |
parsedValues |
限定符 | 构造器和说明 |
---|---|
protected |
CsvInputFormat(org.apache.flink.core.fs.Path filePath) |
限定符和类型 | 方法和说明 |
---|---|
protected static boolean[] |
createDefaultMask(int size) |
protected abstract OUT |
fillRecord(OUT reuse,
Object[] parsedValues) |
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) |
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, 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
protected transient Object[] parsedValues
public void open(org.apache.flink.core.fs.FileInputSplit split) throws IOException
open
在接口中 org.apache.flink.api.common.io.InputFormat<OUT,org.apache.flink.core.fs.FileInputSplit>
open
在类中 org.apache.flink.api.common.io.GenericCsvInputFormat<OUT>
IOException
public OUT nextRecord(OUT record) throws IOException
nextRecord
在接口中 org.apache.flink.api.common.io.InputFormat<OUT,org.apache.flink.core.fs.FileInputSplit>
nextRecord
在类中 org.apache.flink.api.common.io.DelimitedInputFormat<OUT>
IOException
public OUT readRecord(OUT reuse, byte[] bytes, int offset, int numBytes) throws IOException
readRecord
在类中 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–2019 The Apache Software Foundation. All rights reserved.