@Deprecated @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
commentCount, commentPrefix, fieldIncluded, invalidLineCount, lineDelimiterIsLinebreak
构造器和说明 |
---|
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)
已过时。
|
限定符和类型 | 方法和说明 |
---|---|
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, initializeSplit, nextRecord, 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, open, 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, getSupportedCompressionFormats, 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
在类中 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
在类中 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
在接口中 org.apache.flink.api.java.typeutils.ResultTypeQueryable<org.apache.flink.types.Row>
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.