Modifier and Type | Class and Description |
---|---|
class |
AbstractTableInputFormat<T>
Abstract
InputFormat to read data from HBase tables. |
class |
HBaseRowInputFormat
InputFormat subclass that wraps the access for HTables. |
class |
TableInputFormat<T extends Tuple>
InputFormat subclass that wraps the access for HTables. |
Modifier and Type | Class and Description |
---|---|
class |
BinaryInputFormat<T>
Base class for all input formats that use blocks of fixed size.
|
class |
DelimitedInputFormat<OT>
Base implementation for input formats that split the input at a delimiter into records.
|
class |
FileInputFormat<OT>
The base class for
RichInputFormat s that read from files. |
class |
GenericCsvInputFormat<OT> |
class |
GenericInputFormat<OT>
Generic base class for all Rich inputs that are not based on files.
|
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.
|
class |
SerializedInputFormat<T extends IOReadableWritable>
Reads elements by deserializing them with their regular serialization/deserialization functionality.
|
Modifier and Type | Method and Description |
---|---|
InputFormat<OT,S> |
ReplicatingInputFormat.getReplicatedInputFormat() |
Constructor and Description |
---|
ReplicatingInputFormat(InputFormat<OT,S> wrappedIF) |
Modifier and Type | Class and Description |
---|---|
class |
GenericDataSourceBase<OUT,T extends InputFormat<OUT,?>>
Abstract superclass for data sources in a Pact plan.
|
Modifier and Type | Method and Description |
---|---|
<X> DataSource<X> |
ExecutionEnvironment.createInput(InputFormat<X,?> inputFormat)
Generic method to create an input
DataSet with in InputFormat . |
<X> DataSource<X> |
ExecutionEnvironment.createInput(InputFormat<X,?> inputFormat,
TypeInformation<X> producedType)
Generic method to create an input DataSet with in
InputFormat . |
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 |
HadoopInputFormat<K,V>
InputFormat implementation allowing to use Hadoop (mapreduce) InputFormats with Flink.
|
class |
HadoopInputFormatBase<K,V,T>
Base class shared between the Java and Scala API of Flink.
|
Modifier and Type | Class and Description |
---|---|
class |
CollectionInputFormat<T>
An input format that returns objects from a collection.
|
class |
CsvInputFormat<OUT>
InputFormat that reads csv files.
|
class |
IteratorInputFormat<T>
An input format that returns objects from an iterator.
|
class |
ParallelIteratorInputFormat<T>
An input format that generates data in parallel through a
SplittableIterator . |
class |
PojoCsvInputFormat<OUT>
Input format that reads csv into POJOs.
|
class |
PrimitiveInputFormat<OT>
An input format that reads single field primitive data from a given file.
|
class |
RowCsvInputFormat
Input format that reads csv into
Row . |
class |
TextInputFormat
Input Format that reads text files.
|
class |
TextValueInputFormat
Input format that reads text files.
|
class |
TupleCsvInputFormat<OUT>
Input format that reads csv into tuples.
|
class |
TypeSerializerInputFormat<T>
Reads elements by deserializing them with a given type serializer.
|
Modifier and Type | Class and Description |
---|---|
class |
JDBCInputFormat
InputFormat to read data from a database and generate Rows.
|
Modifier and Type | Method and Description |
---|---|
InputFormat<OUT,?> |
DataSource.getInputFormat()
Gets the input format that is executed by this data source.
|
Constructor and Description |
---|
DataSource(ExecutionEnvironment context,
InputFormat<OUT,?> inputFormat,
TypeInformation<OUT> type,
String dataSourceLocationName)
Creates a new data source.
|
Modifier and Type | Method and Description |
---|---|
static <IN> TypeInformation<IN> |
TypeExtractor.getInputFormatTypes(InputFormat<IN,?> inputFormatInterface) |
Modifier and Type | Class and Description |
---|---|
class |
CassandraInputFormat<OUT extends Tuple>
InputFormat to read data from Apache Cassandra and generate $
Tuple . |
class |
CassandraInputFormatBase<OUT>
Base class for
RichInputFormat to read data from Apache Cassandra and generate a custom Cassandra annotated object. |
class |
CassandraPojoInputFormat<OUT>
InputFormat to read data from Apache Cassandra and generate a custom Cassandra annotated object.
|
Modifier and Type | Class and Description |
---|---|
class |
Generator
InputFormat that generates a deterministic DataSet of Tuple2(String, Integer)
String: key, can be repeated.
Integer: uniformly distributed int between 0 and 127
|
Modifier and Type | Class and Description |
---|---|
class |
HiveTableInputFormat
The HiveTableInputFormat are inspired by the HCatInputFormat and HadoopInputFormatBase.
|
Modifier and Type | Class and Description |
---|---|
class |
FileCopyTaskInputFormat
An implementation of an input format that dynamically assigns
FileCopyTask to the mappers
that have finished previously assigned tasks. |
Modifier and Type | Class and Description |
---|---|
class |
AvroInputFormat<E>
Provides a
FileInputFormat for Avro records. |
Modifier and Type | Class and Description |
---|---|
class |
ParquetInputFormat<E>
The base InputFormat class to read from Parquet files.
|
class |
ParquetMapInputFormat
An implementation of
ParquetInputFormat to read Map records from Parquet files. |
class |
ParquetPojoInputFormat<E>
An implementation of
ParquetInputFormat to read POJO records from Parquet files. |
class |
ParquetRowInputFormat
An implementation of
ParquetInputFormat to read Row records from Parquet files. |
Modifier and Type | Class and Description |
---|---|
class |
HCatInputFormatBase<T>
A InputFormat to read from HCatalog tables.
|
Modifier and Type | Class and Description |
---|---|
class |
HCatInputFormat<T>
A InputFormat to read from HCatalog tables.
|
Modifier and Type | Class and Description |
---|---|
class |
OrcInputFormat<T>
InputFormat to read ORC files.
|
class |
OrcRowInputFormat
InputFormat to read ORC files into
Row . |
Modifier and Type | Method and Description |
---|---|
Map<OperatorID,UserCodeWrapper<? extends InputFormat<?,?>>> |
InputOutputFormatContainer.getInputFormats() |
Map<OperatorID,UserCodeWrapper<? extends InputFormat<?,?>>> |
InputOutputFormatContainer.FormatUserCodeTable.getInputFormats() |
<OT,T extends InputSplit> |
InputOutputFormatContainer.getUniqueInputFormat() |
Modifier and Type | Method and Description |
---|---|
InputOutputFormatContainer |
InputOutputFormatContainer.addInputFormat(OperatorID operatorId,
InputFormat<?,?> inputFormat) |
Modifier and Type | Method and Description |
---|---|
InputOutputFormatContainer |
InputOutputFormatContainer.addInputFormat(OperatorID operatorId,
UserCodeWrapper<? extends InputFormat<?,?>> wrapper) |
void |
InputOutputFormatContainer.FormatUserCodeTable.addInputFormat(OperatorID operatorId,
UserCodeWrapper<? extends InputFormat<?,?>> wrapper) |
Modifier and Type | Method and Description |
---|---|
InputFormat<Row,?> |
BatchSQLTestProgram.GeneratorTableSource.getInputFormat() |
Modifier and Type | Class and Description |
---|---|
class |
BroadcastStateInputFormat<K,V>
The input format for reading
BroadcastState . |
class |
KeyedStateInputFormat<K,N,OUT>
Input format for reading partitioned state.
|
class |
ListStateInputFormat<OT>
Input format for reading operator list state.
|
class |
UnionStateInputFormat<OT>
Input format for reading operator union state.
|
Modifier and Type | Method and Description |
---|---|
<OUT> DataStreamSource<OUT> |
StreamExecutionEnvironment.createInput(InputFormat<OUT,?> inputFormat)
Generic method to create an input data stream with
InputFormat . |
<OUT> DataStreamSource<OUT> |
StreamExecutionEnvironment.createInput(InputFormat<OUT,?> inputFormat,
TypeInformation<OUT> typeInfo)
Generic method to create an input data stream with
InputFormat . |
Modifier and Type | Method and Description |
---|---|
InputFormat<OUT,InputSplit> |
InputFormatSourceFunction.getFormat()
Returns the
InputFormat . |
Constructor and Description |
---|
InputFormatSourceFunction(InputFormat<OUT,?> format,
TypeInformation<OUT> typeInfo) |
Modifier and Type | Method and Description |
---|---|
InputFormat<?,?> |
StreamNode.getInputFormat() |
Modifier and Type | Method and Description |
---|---|
void |
StreamNode.setInputFormat(InputFormat<?,?> inputFormat) |
void |
StreamGraph.setInputFormat(Integer vertexID,
InputFormat<?,?> inputFormat) |
Modifier and Type | Method and Description |
---|---|
InputFormat<OUT,InputSplit> |
InputFormatOperatorFactory.getInputFormat() |
InputFormat<OUT,InputSplit> |
SimpleInputFormatOperatorFactory.getInputFormat() |
Modifier and Type | Class and Description |
---|---|
class |
GeneratedInput<F extends InputFormat<?,?>>
Describes a generated
InputFormat . |
Modifier and Type | Class and Description |
---|---|
class |
ValuesInputFormat
Generated ValuesInputFormat.
|
Modifier and Type | Method and Description |
---|---|
abstract InputFormat<T,?> |
InputFormatTableSource.getInputFormat()
Returns an
InputFormat for reading the data of the table. |
Modifier and Type | Class and Description |
---|---|
class |
TransactionRowInputFormat
An bounded input of transactions.
|
Modifier and Type | Method and Description |
---|---|
InputFormat<Row,?> |
BoundedTransactionTableSource.getInputFormat() |
Copyright © 2014–2020 The Apache Software Foundation. All rights reserved.