Package | Description |
---|---|
org.apache.flink.api.java | |
org.apache.flink.api.java.io | |
org.apache.flink.api.java.operators | |
org.apache.flink.state.api |
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 . |
<X> DataSource<X> |
ExecutionEnvironment.fromCollection(Collection<X> data)
Creates a DataSet from the given non-empty collection.
|
<X> DataSource<X> |
ExecutionEnvironment.fromCollection(Collection<X> data,
TypeInformation<X> type)
Creates a DataSet from the given non-empty collection.
|
<X> DataSource<X> |
ExecutionEnvironment.fromCollection(Iterator<X> data,
Class<X> type)
Creates a DataSet from the given iterator.
|
<X> DataSource<X> |
ExecutionEnvironment.fromCollection(Iterator<X> data,
TypeInformation<X> type)
Creates a DataSet from the given iterator.
|
<X> DataSource<X> |
ExecutionEnvironment.fromElements(Class<X> type,
X... data)
Creates a new data set that contains the given elements.
|
<X> DataSource<X> |
ExecutionEnvironment.fromElements(X... data)
Creates a new data set that contains the given elements.
|
<X> DataSource<X> |
ExecutionEnvironment.fromParallelCollection(SplittableIterator<X> iterator,
Class<X> type)
Creates a new data set that contains elements in the iterator.
|
<X> DataSource<X> |
ExecutionEnvironment.fromParallelCollection(SplittableIterator<X> iterator,
TypeInformation<X> type)
Creates a new data set that contains elements in the iterator.
|
DataSource<Long> |
ExecutionEnvironment.generateSequence(long from,
long to)
Creates a new data set that contains a sequence of numbers.
|
<X> DataSource<X> |
ExecutionEnvironment.readFile(FileInputFormat<X> inputFormat,
String filePath) |
<X> DataSource<X> |
ExecutionEnvironment.readFileOfPrimitives(String filePath,
Class<X> typeClass)
Creates a
DataSet that represents the primitive type produced by reading the given
file line wise. |
<X> DataSource<X> |
ExecutionEnvironment.readFileOfPrimitives(String filePath,
String delimiter,
Class<X> typeClass)
Creates a
DataSet that represents the primitive type produced by reading the given
file in delimited way. |
DataSource<String> |
ExecutionEnvironment.readTextFile(String filePath)
Creates a
DataSet that represents the Strings produced by reading the given file line
wise. |
DataSource<String> |
ExecutionEnvironment.readTextFile(String filePath,
String charsetName)
Creates a
DataSet that represents the Strings produced by reading the given file line
wise. |
DataSource<StringValue> |
ExecutionEnvironment.readTextFileWithValue(String filePath)
Creates a
DataSet that represents the Strings produced by reading the given file line
wise. |
DataSource<StringValue> |
ExecutionEnvironment.readTextFileWithValue(String filePath,
String charsetName,
boolean skipInvalidLines)
Creates a
DataSet that represents the Strings produced by reading the given file line
wise. |
Modifier and Type | Method and Description |
---|---|
<T> DataSource<T> |
CsvReader.pojoType(Class<T> pojoType,
String... pojoFields)
Configures the reader to read the CSV data and parse it to the given type.
|
<T extends Tuple> |
CsvReader.tupleType(Class<T> targetType)
Configures the reader to read the CSV data and parse it to the given type.
|
<T0> DataSource<Tuple1<T0>> |
CsvReader.types(Class<T0> type0)
Specifies the types for the CSV fields.
|
<T0,T1> DataSource<Tuple2<T0,T1>> |
CsvReader.types(Class<T0> type0,
Class<T1> type1)
Specifies the types for the CSV fields.
|
<T0,T1,T2> DataSource<Tuple3<T0,T1,T2>> |
CsvReader.types(Class<T0> type0,
Class<T1> type1,
Class<T2> type2)
Specifies the types for the CSV fields.
|
<T0,T1,T2,T3> |
CsvReader.types(Class<T0> type0,
Class<T1> type1,
Class<T2> type2,
Class<T3> type3)
Specifies the types for the CSV fields.
|
<T0,T1,T2,T3,T4> |
CsvReader.types(Class<T0> type0,
Class<T1> type1,
Class<T2> type2,
Class<T3> type3,
Class<T4> type4)
Specifies the types for the CSV fields.
|
<T0,T1,T2,T3,T4,T5> |
CsvReader.types(Class<T0> type0,
Class<T1> type1,
Class<T2> type2,
Class<T3> type3,
Class<T4> type4,
Class<T5> type5)
Specifies the types for the CSV fields.
|
<T0,T1,T2,T3,T4,T5,T6> |
CsvReader.types(Class<T0> type0,
Class<T1> type1,
Class<T2> type2,
Class<T3> type3,
Class<T4> type4,
Class<T5> type5,
Class<T6> type6)
Specifies the types for the CSV fields.
|
<T0,T1,T2,T3,T4,T5,T6,T7> |
CsvReader.types(Class<T0> type0,
Class<T1> type1,
Class<T2> type2,
Class<T3> type3,
Class<T4> type4,
Class<T5> type5,
Class<T6> type6,
Class<T7> type7)
Specifies the types for the CSV fields.
|
<T0,T1,T2,T3,T4,T5,T6,T7,T8> |
CsvReader.types(Class<T0> type0,
Class<T1> type1,
Class<T2> type2,
Class<T3> type3,
Class<T4> type4,
Class<T5> type5,
Class<T6> type6,
Class<T7> type7,
Class<T8> type8)
Specifies the types for the CSV fields.
|
<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9> |
CsvReader.types(Class<T0> type0,
Class<T1> type1,
Class<T2> type2,
Class<T3> type3,
Class<T4> type4,
Class<T5> type5,
Class<T6> type6,
Class<T7> type7,
Class<T8> type8,
Class<T9> type9)
Specifies the types for the CSV fields.
|
<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10> |
CsvReader.types(Class<T0> type0,
Class<T1> type1,
Class<T2> type2,
Class<T3> type3,
Class<T4> type4,
Class<T5> type5,
Class<T6> type6,
Class<T7> type7,
Class<T8> type8,
Class<T9> type9,
Class<T10> type10)
Specifies the types for the CSV fields.
|
<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11> |
CsvReader.types(Class<T0> type0,
Class<T1> type1,
Class<T2> type2,
Class<T3> type3,
Class<T4> type4,
Class<T5> type5,
Class<T6> type6,
Class<T7> type7,
Class<T8> type8,
Class<T9> type9,
Class<T10> type10,
Class<T11> type11)
Specifies the types for the CSV fields.
|
<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12> |
CsvReader.types(Class<T0> type0,
Class<T1> type1,
Class<T2> type2,
Class<T3> type3,
Class<T4> type4,
Class<T5> type5,
Class<T6> type6,
Class<T7> type7,
Class<T8> type8,
Class<T9> type9,
Class<T10> type10,
Class<T11> type11,
Class<T12> type12)
Specifies the types for the CSV fields.
|
<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13> |
CsvReader.types(Class<T0> type0,
Class<T1> type1,
Class<T2> type2,
Class<T3> type3,
Class<T4> type4,
Class<T5> type5,
Class<T6> type6,
Class<T7> type7,
Class<T8> type8,
Class<T9> type9,
Class<T10> type10,
Class<T11> type11,
Class<T12> type12,
Class<T13> type13)
Specifies the types for the CSV fields.
|
<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14> |
CsvReader.types(Class<T0> type0,
Class<T1> type1,
Class<T2> type2,
Class<T3> type3,
Class<T4> type4,
Class<T5> type5,
Class<T6> type6,
Class<T7> type7,
Class<T8> type8,
Class<T9> type9,
Class<T10> type10,
Class<T11> type11,
Class<T12> type12,
Class<T13> type13,
Class<T14> type14)
Specifies the types for the CSV fields.
|
<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15> |
CsvReader.types(Class<T0> type0,
Class<T1> type1,
Class<T2> type2,
Class<T3> type3,
Class<T4> type4,
Class<T5> type5,
Class<T6> type6,
Class<T7> type7,
Class<T8> type8,
Class<T9> type9,
Class<T10> type10,
Class<T11> type11,
Class<T12> type12,
Class<T13> type13,
Class<T14> type14,
Class<T15> type15)
Specifies the types for the CSV fields.
|
<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16> |
CsvReader.types(Class<T0> type0,
Class<T1> type1,
Class<T2> type2,
Class<T3> type3,
Class<T4> type4,
Class<T5> type5,
Class<T6> type6,
Class<T7> type7,
Class<T8> type8,
Class<T9> type9,
Class<T10> type10,
Class<T11> type11,
Class<T12> type12,
Class<T13> type13,
Class<T14> type14,
Class<T15> type15,
Class<T16> type16)
Specifies the types for the CSV fields.
|
<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17> |
CsvReader.types(Class<T0> type0,
Class<T1> type1,
Class<T2> type2,
Class<T3> type3,
Class<T4> type4,
Class<T5> type5,
Class<T6> type6,
Class<T7> type7,
Class<T8> type8,
Class<T9> type9,
Class<T10> type10,
Class<T11> type11,
Class<T12> type12,
Class<T13> type13,
Class<T14> type14,
Class<T15> type15,
Class<T16> type16,
Class<T17> type17)
Specifies the types for the CSV fields.
|
<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18> |
CsvReader.types(Class<T0> type0,
Class<T1> type1,
Class<T2> type2,
Class<T3> type3,
Class<T4> type4,
Class<T5> type5,
Class<T6> type6,
Class<T7> type7,
Class<T8> type8,
Class<T9> type9,
Class<T10> type10,
Class<T11> type11,
Class<T12> type12,
Class<T13> type13,
Class<T14> type14,
Class<T15> type15,
Class<T16> type16,
Class<T17> type17,
Class<T18> type18)
Specifies the types for the CSV fields.
|
<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18,T19> |
CsvReader.types(Class<T0> type0,
Class<T1> type1,
Class<T2> type2,
Class<T3> type3,
Class<T4> type4,
Class<T5> type5,
Class<T6> type6,
Class<T7> type7,
Class<T8> type8,
Class<T9> type9,
Class<T10> type10,
Class<T11> type11,
Class<T12> type12,
Class<T13> type13,
Class<T14> type14,
Class<T15> type15,
Class<T16> type16,
Class<T17> type17,
Class<T18> type18,
Class<T19> type19)
Specifies the types for the CSV fields.
|
<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18,T19,T20> |
CsvReader.types(Class<T0> type0,
Class<T1> type1,
Class<T2> type2,
Class<T3> type3,
Class<T4> type4,
Class<T5> type5,
Class<T6> type6,
Class<T7> type7,
Class<T8> type8,
Class<T9> type9,
Class<T10> type10,
Class<T11> type11,
Class<T12> type12,
Class<T13> type13,
Class<T14> type14,
Class<T15> type15,
Class<T16> type16,
Class<T17> type17,
Class<T18> type18,
Class<T19> type19,
Class<T20> type20)
Specifies the types for the CSV fields.
|
<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18,T19,T20,T21> |
CsvReader.types(Class<T0> type0,
Class<T1> type1,
Class<T2> type2,
Class<T3> type3,
Class<T4> type4,
Class<T5> type5,
Class<T6> type6,
Class<T7> type7,
Class<T8> type8,
Class<T9> type9,
Class<T10> type10,
Class<T11> type11,
Class<T12> type12,
Class<T13> type13,
Class<T14> type14,
Class<T15> type15,
Class<T16> type16,
Class<T17> type17,
Class<T18> type18,
Class<T19> type19,
Class<T20> type20,
Class<T21> type21)
Specifies the types for the CSV fields.
|
<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18,T19,T20,T21,T22> |
CsvReader.types(Class<T0> type0,
Class<T1> type1,
Class<T2> type2,
Class<T3> type3,
Class<T4> type4,
Class<T5> type5,
Class<T6> type6,
Class<T7> type7,
Class<T8> type8,
Class<T9> type9,
Class<T10> type10,
Class<T11> type11,
Class<T12> type12,
Class<T13> type13,
Class<T14> type14,
Class<T15> type15,
Class<T16> type16,
Class<T17> type17,
Class<T18> type18,
Class<T19> type19,
Class<T20> type20,
Class<T21> type21,
Class<T22> type22)
Specifies the types for the CSV fields.
|
<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18,T19,T20,T21,T22,T23> |
CsvReader.types(Class<T0> type0,
Class<T1> type1,
Class<T2> type2,
Class<T3> type3,
Class<T4> type4,
Class<T5> type5,
Class<T6> type6,
Class<T7> type7,
Class<T8> type8,
Class<T9> type9,
Class<T10> type10,
Class<T11> type11,
Class<T12> type12,
Class<T13> type13,
Class<T14> type14,
Class<T15> type15,
Class<T16> type16,
Class<T17> type17,
Class<T18> type18,
Class<T19> type19,
Class<T20> type20,
Class<T21> type21,
Class<T22> type22,
Class<T23> type23)
Specifies the types for the CSV fields.
|
<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18,T19,T20,T21,T22,T23,T24> |
CsvReader.types(Class<T0> type0,
Class<T1> type1,
Class<T2> type2,
Class<T3> type3,
Class<T4> type4,
Class<T5> type5,
Class<T6> type6,
Class<T7> type7,
Class<T8> type8,
Class<T9> type9,
Class<T10> type10,
Class<T11> type11,
Class<T12> type12,
Class<T13> type13,
Class<T14> type14,
Class<T15> type15,
Class<T16> type16,
Class<T17> type17,
Class<T18> type18,
Class<T19> type19,
Class<T20> type20,
Class<T21> type21,
Class<T22> type22,
Class<T23> type23,
Class<T24> type24)
Specifies the types for the CSV fields.
|
Constructor and Description |
---|
SplitDataProperties(DataSource<T> source)
Creates SplitDataProperties for the given data types.
|
Modifier and Type | Method and Description |
---|---|
DataSource<OUT> |
DataSource.withParameters(Configuration parameters)
Pass a configuration to the InputFormat.
|
Modifier and Type | Method and Description |
---|---|
<K,T,ACC,R> |
WindowReader.aggregate(String uid,
AggregateFunction<T,ACC,R> aggregateFunction,
TypeInformation<K> keyType,
TypeInformation<ACC> accType,
TypeInformation<R> outputType)
Reads window state generated using an
AggregateFunction . |
<K,T,ACC,R,OUT> |
WindowReader.aggregate(String uid,
AggregateFunction<T,ACC,R> aggregateFunction,
WindowReaderFunction<R,OUT,K,W> readerFunction,
TypeInformation<K> keyType,
TypeInformation<ACC> accType,
TypeInformation<OUT> outputType)
Reads window state generated using an
AggregateFunction . |
<K,T,OUT> DataSource<OUT> |
WindowReader.process(String uid,
WindowReaderFunction<T,OUT,K,W> readerFunction,
TypeInformation<K> keyType,
TypeInformation<T> stateType,
TypeInformation<OUT> outputType)
Reads window state generated without any preaggregation such as
WindowedStream#apply
and WindowedStream#process . |
<K,V> DataSource<Tuple2<K,V>> |
ExistingSavepoint.readBroadcastState(String uid,
String name,
TypeInformation<K> keyTypeInfo,
TypeInformation<V> valueTypeInfo)
Read operator
BroadcastState from a Savepoint . |
<K,V> DataSource<Tuple2<K,V>> |
ExistingSavepoint.readBroadcastState(String uid,
String name,
TypeInformation<K> keyTypeInfo,
TypeInformation<V> valueTypeInfo,
TypeSerializer<K> keySerializer,
TypeSerializer<V> valueSerializer)
Read operator
BroadcastState from a Savepoint when a custom serializer was
used; e.g., a different serializer than the one returned by TypeInformation#createSerializer . |
<K,OUT> DataSource<OUT> |
ExistingSavepoint.readKeyedState(String uid,
KeyedStateReaderFunction<K,OUT> function)
Read keyed state from an operator in a
Savepoint . |
<K,OUT> DataSource<OUT> |
ExistingSavepoint.readKeyedState(String uid,
KeyedStateReaderFunction<K,OUT> function,
TypeInformation<K> keyTypeInfo,
TypeInformation<OUT> outTypeInfo)
Read keyed state from an operator in a
Savepoint . |
<T> DataSource<T> |
ExistingSavepoint.readListState(String uid,
String name,
TypeInformation<T> typeInfo)
Read operator
ListState from a Savepoint . |
<T> DataSource<T> |
ExistingSavepoint.readListState(String uid,
String name,
TypeInformation<T> typeInfo,
TypeSerializer<T> serializer)
Read operator
ListState from a Savepoint when a custom serializer was used;
e.g., a different serializer than the one returned by TypeInformation#createSerializer . |
<T> DataSource<T> |
ExistingSavepoint.readUnionState(String uid,
String name,
TypeInformation<T> typeInfo)
Read operator
UnionState from a Savepoint . |
<T> DataSource<T> |
ExistingSavepoint.readUnionState(String uid,
String name,
TypeInformation<T> typeInfo,
TypeSerializer<T> serializer)
Read operator
UnionState from a Savepoint when a custom serializer was used;
e.g., a different serializer than the one returned by TypeInformation#createSerializer . |
<T,K> DataSource<T> |
WindowReader.reduce(String uid,
ReduceFunction<T> function,
TypeInformation<K> keyType,
TypeInformation<T> reduceType)
Reads window state generated using a
ReduceFunction . |
<K,T,OUT> DataSource<OUT> |
WindowReader.reduce(String uid,
ReduceFunction<T> function,
WindowReaderFunction<T,OUT,K,W> readerFunction,
TypeInformation<K> keyType,
TypeInformation<T> reduceType,
TypeInformation<OUT> outputType)
Reads window state generated using a
ReduceFunction . |
Copyright © 2014–2023 The Apache Software Foundation. All rights reserved.