@PublicEvolving
public class TextValueInputFormat
extends org.apache.flink.api.common.io.DelimitedInputFormat<org.apache.flink.types.StringValue>
构造器和说明 |
---|
TextValueInputFormat(org.apache.flink.core.fs.Path filePath) |
限定符和类型 | 方法和说明 |
---|---|
void |
configure(org.apache.flink.configuration.Configuration parameters) |
String |
getCharsetName() |
boolean |
isSkipInvalidLines() |
org.apache.flink.types.StringValue |
readRecord(org.apache.flink.types.StringValue reuse,
byte[] bytes,
int offset,
int numBytes) |
void |
setCharsetName(String charsetName) |
void |
setSkipInvalidLines(boolean skipInvalidLines) |
boolean |
supportsMultiPaths() |
String |
toString() |
close, 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, testForUnsplittable
public String getCharsetName()
public void setCharsetName(String charsetName)
public boolean isSkipInvalidLines()
public void setSkipInvalidLines(boolean skipInvalidLines)
public void configure(org.apache.flink.configuration.Configuration parameters)
configure
在接口中 org.apache.flink.api.common.io.InputFormat<org.apache.flink.types.StringValue,org.apache.flink.core.fs.FileInputSplit>
configure
在类中 org.apache.flink.api.common.io.DelimitedInputFormat<org.apache.flink.types.StringValue>
public org.apache.flink.types.StringValue readRecord(org.apache.flink.types.StringValue reuse, byte[] bytes, int offset, int numBytes)
readRecord
在类中 org.apache.flink.api.common.io.DelimitedInputFormat<org.apache.flink.types.StringValue>
public String toString()
toString
在类中 org.apache.flink.api.common.io.FileInputFormat<org.apache.flink.types.StringValue>
public boolean supportsMultiPaths()
supportsMultiPaths
在类中 org.apache.flink.api.common.io.FileInputFormat<org.apache.flink.types.StringValue>
Copyright © 2014–2019 The Apache Software Foundation. All rights reserved.