Package | Description |
---|---|
org.apache.flink.api.common.io | |
org.apache.flink.api.java.io | |
org.apache.flink.formats.avro | |
org.apache.flink.orc | |
org.apache.flink.streaming.api.functions.source |
Modifier and Type | Field and Description |
---|---|
protected FileInputSplit |
FileInputFormat.currentSplit
The current split that this parallel instance must consume.
|
Modifier and Type | Method and Description |
---|---|
FileInputSplit[] |
FileInputFormat.createInputSplits(int minNumSplits)
Computes the input splits for the file.
|
FileInputSplit[] |
BinaryInputFormat.createInputSplits(int minNumSplits) |
protected FileInputSplit[] |
BinaryInputFormat.getInputSplits() |
Modifier and Type | Method and Description |
---|---|
protected FSDataInputStream |
FileInputFormat.decorateInputStream(FSDataInputStream inputStream,
FileInputSplit fileSplit)
This method allows to wrap/decorate the raw
FSDataInputStream for a certain file split, e.g., for decoding. |
LocatableInputSplitAssigner |
FileInputFormat.getInputSplitAssigner(FileInputSplit[] splits) |
void |
FileInputFormat.open(FileInputSplit fileSplit)
Opens an input stream to the file defined in the input format.
|
void |
GenericCsvInputFormat.open(FileInputSplit split) |
void |
DelimitedInputFormat.open(FileInputSplit split)
Opens the given input split.
|
void |
BinaryInputFormat.open(FileInputSplit split) |
void |
DelimitedInputFormat.reopen(FileInputSplit split,
Long state) |
void |
BinaryInputFormat.reopen(FileInputSplit split,
Tuple2<Long,Long> state) |
Constructor and Description |
---|
InputSplitOpenThread(FileInputSplit split,
long timeout) |
Modifier and Type | Method and Description |
---|---|
void |
PojoCsvInputFormat.open(FileInputSplit split) |
void |
CsvInputFormat.open(FileInputSplit split) |
void |
PrimitiveInputFormat.open(FileInputSplit split) |
Modifier and Type | Method and Description |
---|---|
void |
AvroInputFormat.open(FileInputSplit split) |
void |
AvroInputFormat.reopen(FileInputSplit split,
Tuple2<Long,Long> state) |
Modifier and Type | Method and Description |
---|---|
void |
OrcRowInputFormat.open(FileInputSplit fileSplit) |
Modifier and Type | Class and Description |
---|---|
class |
TimestampedFileInputSplit
An extended
FileInputSplit that also includes information about:
The modification time of the file this split belongs to.
When checkpointing, the state of the split at the moment of the checkpoint.
This class is used by the ContinuousFileMonitoringFunction and the
ContinuousFileReaderOperator to perform continuous file processing. |
Copyright © 2014–2020 The Apache Software Foundation. All rights reserved.