@PublicEvolving
public class PrimitiveInputFormat<OT>
extends org.apache.flink.api.common.io.DelimitedInputFormat<OT>
CsvInputFormat
is that it won't go through Tuple1
.构造器和说明 |
---|
PrimitiveInputFormat(org.apache.flink.core.fs.Path filePath,
Class<OT> primitiveClass) |
PrimitiveInputFormat(org.apache.flink.core.fs.Path filePath,
String delimiter,
Class<OT> primitiveClass) |
限定符和类型 | 方法和说明 |
---|---|
protected void |
initializeSplit(org.apache.flink.core.fs.FileInputSplit split,
Long offset) |
OT |
readRecord(OT reuse,
byte[] bytes,
int offset,
int numBytes) |
close, configure, getBufferSize, getCharset, getCurrentState, getDelimiter, getLineLengthLimit, getNumLineSamples, getStatistics, loadConfigParameters, loadGlobalConfigParams, nextRecord, open, reachedEnd, readLine, reopen, setBufferSize, setCharset, 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, supportsMultiPaths, testForUnsplittable, toString
public PrimitiveInputFormat(org.apache.flink.core.fs.Path filePath, Class<OT> primitiveClass)
protected void initializeSplit(org.apache.flink.core.fs.FileInputSplit split, Long offset) throws IOException
initializeSplit
在类中 org.apache.flink.api.common.io.DelimitedInputFormat<OT>
IOException
public OT readRecord(OT reuse, byte[] bytes, int offset, int numBytes) throws IOException
readRecord
在类中 org.apache.flink.api.common.io.DelimitedInputFormat<OT>
IOException
Copyright © 2014–2021 The Apache Software Foundation. All rights reserved.