Uses of Interface
org.apache.flink.core.io.InputSplit
-
-
Uses of InputSplit in org.apache.flink.api.common.io
Classes in org.apache.flink.api.common.io with type parameters of type InputSplit Modifier and Type Interface Description interface
CheckpointableInputFormat<S extends InputSplit,T extends Serializable>
An interface that describesInputFormat
s that allow checkpointing/restoring their state.interface
InputFormat<OT,T extends InputSplit>
The base interface for data sources that produces records.class
ReplicatingInputFormat<OT,S extends InputSplit>
A ReplicatingInputFormat replicates anyInputFormat
to all parallel instances of a DataSource, i.e., the full input of the replicated InputFormat is completely processed by each parallel instance of the DataSource.class
RichInputFormat<OT,T extends InputSplit>
An abstract stub implementation for Rich input formats.Methods in org.apache.flink.api.common.io that return InputSplit Modifier and Type Method Description T[]
InputFormat. createInputSplits(int minNumSplits)
S[]
ReplicatingInputFormat. createInputSplits(int minNumSplits)
InputSplit
DefaultInputSplitAssigner. getNextInputSplit(String host, int taskId)
InputSplit
ReplicatingInputSplitAssigner. getNextInputSplit(String host, int taskId)
Methods in org.apache.flink.api.common.io with parameters of type InputSplit Modifier and Type Method Description InputSplitAssigner
InputFormat. getInputSplitAssigner(T[] inputSplits)
InputSplitAssigner
ReplicatingInputFormat. getInputSplitAssigner(S[] inputSplits)
Method parameters in org.apache.flink.api.common.io with type arguments of type InputSplit Modifier and Type Method Description void
DefaultInputSplitAssigner. returnInputSplit(List<InputSplit> splits, int taskId)
void
LocatableInputSplitAssigner. returnInputSplit(List<InputSplit> splits, int taskId)
void
ReplicatingInputSplitAssigner. returnInputSplit(List<InputSplit> splits, int taskId)
Constructors in org.apache.flink.api.common.io with parameters of type InputSplit Constructor Description DefaultInputSplitAssigner(InputSplit[] splits)
ReplicatingInputSplitAssigner(InputSplit[] splits)
Constructor parameters in org.apache.flink.api.common.io with type arguments of type InputSplit Constructor Description DefaultInputSplitAssigner(Collection<? extends InputSplit> splits)
ReplicatingInputSplitAssigner(Collection<InputSplit> splits)
-
Uses of InputSplit in org.apache.flink.api.java.hadoop.common
Classes in org.apache.flink.api.java.hadoop.common with type parameters of type InputSplit Modifier and Type Class Description class
HadoopInputFormatCommonBase<T,SPITTYPE extends InputSplit>
A common base for both "mapred" and "mapreduce" Hadoop input formats. -
Uses of InputSplit in org.apache.flink.api.java.hadoop.mapred.wrapper
Classes in org.apache.flink.api.java.hadoop.mapred.wrapper that implement InputSplit Modifier and Type Class Description class
HadoopInputSplit
A wrapper that represents an input split from the Hadoop mapred API as a FlinkInputSplit
. -
Uses of InputSplit in org.apache.flink.api.java.hadoop.mapreduce.wrapper
Classes in org.apache.flink.api.java.hadoop.mapreduce.wrapper that implement InputSplit Modifier and Type Class Description class
HadoopInputSplit
A wrapper that represents an input split from the Hadoop mapreduce API as a FlinkInputSplit
. -
Uses of InputSplit in org.apache.flink.core.fs
Classes in org.apache.flink.core.fs that implement InputSplit Modifier and Type Class Description class
FileInputSplit
A file input split provides information on a particular part of a file, possibly hosted on a distributed file system and replicated among several hosts. -
Uses of InputSplit in org.apache.flink.core.io
Classes in org.apache.flink.core.io with type parameters of type InputSplit Modifier and Type Interface Description interface
InputSplitSource<T extends InputSplit>
InputSplitSources createInputSplit
s that define portions of data to be produced byInputFormat
s.Classes in org.apache.flink.core.io that implement InputSplit Modifier and Type Class Description class
GenericInputSplit
A generic input split that has only a partition number.class
LocatableInputSplit
A locatable input split is an input split referring to input data which is located on one or more hosts.Methods in org.apache.flink.core.io that return InputSplit Modifier and Type Method Description T[]
InputSplitSource. createInputSplits(int minNumSplits)
Computes the input splits.InputSplit
InputSplitAssigner. getNextInputSplit(String host, int taskId)
Returns the next input split that shall be consumed.Methods in org.apache.flink.core.io with parameters of type InputSplit Modifier and Type Method Description InputSplitAssigner
InputSplitSource. getInputSplitAssigner(T[] inputSplits)
Returns the assigner for the input splits.Method parameters in org.apache.flink.core.io with type arguments of type InputSplit Modifier and Type Method Description void
InputSplitAssigner. returnInputSplit(List<InputSplit> splits, int taskId)
Return the splits to assigner if the task failed to process it. -
Uses of InputSplit in org.apache.flink.runtime.executiongraph
Methods in org.apache.flink.runtime.executiongraph that return types with arguments of type InputSplit Modifier and Type Method Description Optional<InputSplit>
Execution. getNextInputSplit()
Optional<InputSplit>
ExecutionVertex. getNextInputSplit(String host, int attemptNumber)
Optional<InputSplit>
SpeculativeExecutionVertex. getNextInputSplit(String host, int attemptNumber)
-
Uses of InputSplit in org.apache.flink.runtime.jobgraph
Methods in org.apache.flink.runtime.jobgraph with type parameters of type InputSplit Modifier and Type Method Description <OT,T extends InputSplit>
org.apache.commons.lang3.tuple.Pair<OperatorID,InputFormat<OT,T>>InputOutputFormatContainer. getUniqueInputFormat()
-
Uses of InputSplit in org.apache.flink.runtime.jobgraph.tasks
Methods in org.apache.flink.runtime.jobgraph.tasks that return InputSplit Modifier and Type Method Description InputSplit
InputSplitProvider. getNextInputSplit(ClassLoader userCodeClassLoader)
Requests the next input split to be consumed by the calling task. -
Uses of InputSplit in org.apache.flink.runtime.taskexecutor.rpc
Methods in org.apache.flink.runtime.taskexecutor.rpc that return InputSplit Modifier and Type Method Description InputSplit
RpcInputSplitProvider. getNextInputSplit(ClassLoader userCodeClassLoader)
-
Uses of InputSplit in org.apache.flink.state.api.input.splits
Subinterfaces of InputSplit in org.apache.flink.state.api.input.splits Modifier and Type Interface Description interface
PrioritizedOperatorSubtaskStateInputSplit
An input split that returnsPrioritizedOperatorSubtaskState
.Classes in org.apache.flink.state.api.input.splits that implement InputSplit Modifier and Type Class Description class
KeyGroupRangeInputSplit
An input split representing a key-group range from a savepoint.class
OperatorStateInputSplit
An input split containing state handles for operator state. -
Uses of InputSplit in org.apache.flink.streaming.api.functions.source
Subinterfaces of InputSplit in org.apache.flink.streaming.api.functions.source Modifier and Type Interface Description interface
TimestampedInputSplit
An extendedInputSplit
that also includes information about: The modification time of the file this split belongs to.Classes in org.apache.flink.streaming.api.functions.source that implement InputSplit Modifier and Type Class Description class
TimestampedFileInputSplit
AFileInputSplit
withTimestampedInputSplit
. -
Uses of InputSplit in org.apache.flink.streaming.api.functions.source.legacy
Methods in org.apache.flink.streaming.api.functions.source.legacy that return types with arguments of type InputSplit Modifier and Type Method Description InputFormat<OUT,InputSplit>
InputFormatSourceFunction. getFormat()
Deprecated.Returns theInputFormat
. -
Uses of InputSplit in org.apache.flink.streaming.api.operators
Methods in org.apache.flink.streaming.api.operators that return types with arguments of type InputSplit Modifier and Type Method Description InputFormat<OUT,InputSplit>
InputFormatOperatorFactory. getInputFormat()
InputFormat<OUT,InputSplit>
SimpleInputFormatOperatorFactory. getInputFormat()
-
Uses of InputSplit in org.apache.flink.table.planner.plan.nodes.exec.batch
Method parameters in org.apache.flink.table.planner.plan.nodes.exec.batch with type arguments of type InputSplit Modifier and Type Method Description protected <IN> Transformation<IN>
BatchExecLegacyTableSourceScan. createInput(StreamExecutionEnvironment env, InputFormat<IN,? extends InputSplit> inputFormat, TypeInformation<IN> typeInfo)
-
Uses of InputSplit in org.apache.flink.table.planner.plan.nodes.exec.common
Method parameters in org.apache.flink.table.planner.plan.nodes.exec.common with type arguments of type InputSplit Modifier and Type Method Description protected abstract <IN> Transformation<IN>
CommonExecLegacyTableSourceScan. createInput(StreamExecutionEnvironment env, InputFormat<IN,? extends InputSplit> inputFormat, TypeInformation<IN> typeInfo)
-
Uses of InputSplit in org.apache.flink.table.planner.plan.nodes.exec.stream
Method parameters in org.apache.flink.table.planner.plan.nodes.exec.stream with type arguments of type InputSplit Modifier and Type Method Description protected <IN> Transformation<IN>
StreamExecLegacyTableSourceScan. createInput(StreamExecutionEnvironment env, InputFormat<IN,? extends InputSplit> format, TypeInformation<IN> typeInfo)
-
Uses of InputSplit in org.apache.flink.table.runtime.functions.table.lookup.fullcache.inputformat
Constructors in org.apache.flink.table.runtime.functions.table.lookup.fullcache.inputformat with parameters of type InputSplit Constructor Description InputSplitCacheLoadTask(ConcurrentHashMap<RowData,Collection<RowData>> cache, GenericRowDataKeySelector keySelector, RowDataSerializer cacheEntriesSerializer, InputFormat<RowData,InputSplit> inputFormat, InputSplit inputSplit)
Constructor parameters in org.apache.flink.table.runtime.functions.table.lookup.fullcache.inputformat with type arguments of type InputSplit Constructor Description InputSplitCacheLoadTask(ConcurrentHashMap<RowData,Collection<RowData>> cache, GenericRowDataKeySelector keySelector, RowDataSerializer cacheEntriesSerializer, InputFormat<RowData,InputSplit> inputFormat, InputSplit inputSplit)
-