Modifier and Type | Class and Description |
---|---|
class |
TableInputSplit
This class implements a input splits for HBase.
|
Modifier and Type | Interface and Description |
---|---|
interface |
CheckpointableInputFormat<S extends InputSplit,T extends Serializable>
An interface that describes
InputFormat 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 any
InputFormat 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.
|
Modifier and Type | Method and Description |
---|---|
S[] |
ReplicatingInputFormat.createInputSplits(int minNumSplits) |
T[] |
InputFormat.createInputSplits(int minNumSplits)
Creates the different splits of the input that can be processed in parallel.
|
InputSplit |
ReplicatingInputSplitAssigner.getNextInputSplit(String host,
int taskId) |
InputSplit |
DefaultInputSplitAssigner.getNextInputSplit(String host,
int taskId) |
Modifier and Type | Method and Description |
---|---|
InputSplitAssigner |
ReplicatingInputFormat.getInputSplitAssigner(S[] inputSplits) |
InputSplitAssigner |
InputFormat.getInputSplitAssigner(T[] inputSplits)
Gets the type of the input splits that are processed by this input format.
|
Constructor and Description |
---|
DefaultInputSplitAssigner(InputSplit[] splits) |
ReplicatingInputSplitAssigner(InputSplit[] splits) |
Constructor and Description |
---|
DefaultInputSplitAssigner(Collection<? extends InputSplit> splits) |
ReplicatingInputSplitAssigner(Collection<InputSplit> splits) |
Modifier and Type | Class and Description |
---|---|
class |
HadoopInputFormatCommonBase<T,SPITTYPE extends InputSplit>
A common base for both "mapred" and "mapreduce" Hadoop input formats.
|
Modifier and Type | Class and Description |
---|---|
class |
HadoopInputSplit
A wrapper that represents an input split from the Hadoop mapreduce API as
a Flink
InputSplit . |
Modifier and Type | Method and Description |
---|---|
InputSplit[] |
JDBCInputFormat.createInputSplits(int minNumSplits) |
Modifier and Type | Method and Description |
---|---|
InputSplitAssigner |
JDBCInputFormat.getInputSplitAssigner(InputSplit[] inputSplits) |
void |
JDBCInputFormat.open(InputSplit inputSplit)
Connects to the source database and executes the query in a parallel
fashion if
this
InputFormat is built using a parameterized query (i.e. |
Modifier and Type | Method and Description |
---|---|
InputSplit[] |
CassandraInputFormat.createInputSplits(int minNumSplits) |
Modifier and Type | Method and Description |
---|---|
InputSplitAssigner |
CassandraInputFormat.getInputSplitAssigner(InputSplit[] inputSplits) |
void |
CassandraInputFormat.open(InputSplit ignored)
Opens a Session and executes the query.
|
Modifier and Type | Class and 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.
|
Modifier and Type | Interface and Description |
---|---|
interface |
InputSplitSource<T extends InputSplit>
InputSplitSources create
InputSplit s that define portions of data to be produced
by InputFormat s. |
Modifier and Type | Class and 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.
|
Modifier and Type | Method and 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.
|
Modifier and Type | Method and Description |
---|---|
InputSplitAssigner |
InputSplitSource.getInputSplitAssigner(T[] inputSplits)
Returns the assigner for the input splits.
|
Modifier and Type | Class and Description |
---|---|
class |
FileCopyTaskInputSplit
Implementation of
InputSplit for copying files. |
Modifier and Type | Method and Description |
---|---|
InputSplit |
InputSplitProvider.getNextInputSplit(ClassLoader userCodeClassLoader)
Requests the next input split to be consumed by the calling task.
|
Modifier and Type | Method and Description |
---|---|
InputSplit |
RpcInputSplitProvider.getNextInputSplit(ClassLoader userCodeClassLoader) |
Modifier and Type | Method and Description |
---|---|
InputSplit |
TaskInputSplitProvider.getNextInputSplit(ClassLoader userCodeClassLoader) |
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. |
Modifier and Type | Method and Description |
---|---|
InputFormat<OUT,InputSplit> |
InputFormatSourceFunction.getFormat()
Returns the
InputFormat . |
Copyright © 2014–2019 The Apache Software Foundation. All rights reserved.