Modifier and Type | Method and Description |
---|---|
void |
JDBCAppendTableSink.emitDataStream(DataStream<Row> dataStream) |
Modifier and Type | Method and Description |
---|---|
DataStream<T> |
PatternStream.getInputStream() |
Modifier and Type | Method and Description |
---|---|
static <T> PatternStream<T> |
CEP.pattern(DataStream<T> input,
Pattern<T,?> pattern)
Creates a
PatternStream from an input data stream and a pattern. |
static <T> PatternStream<T> |
CEP.pattern(DataStream<T> input,
Pattern<T,?> pattern,
EventComparator<T> comparator)
Creates a
PatternStream from an input data stream and a pattern. |
Modifier and Type | Method and Description |
---|---|
static <IN,OUT> SingleOutputStreamOperator<OUT> |
CEPOperatorUtils.createPatternStream(DataStream<IN> inputStream,
Pattern<IN,?> pattern,
EventComparator<IN> comparator,
PatternFlatSelectFunction<IN,OUT> selectFunction,
TypeInformation<OUT> outTypeInfo)
Creates a data stream containing results of
PatternFlatSelectFunction to fully matching event patterns. |
static <IN,OUT> SingleOutputStreamOperator<OUT> |
CEPOperatorUtils.createPatternStream(DataStream<IN> inputStream,
Pattern<IN,?> pattern,
EventComparator<IN> comparator,
PatternSelectFunction<IN,OUT> selectFunction,
TypeInformation<OUT> outTypeInfo)
Creates a data stream containing results of
PatternSelectFunction to fully matching event patterns. |
static <IN,OUT1,OUT2> |
CEPOperatorUtils.createTimeoutPatternStream(DataStream<IN> inputStream,
Pattern<IN,?> pattern,
EventComparator<IN> comparator,
PatternFlatSelectFunction<IN,OUT1> selectFunction,
TypeInformation<OUT1> outTypeInfo,
OutputTag<OUT2> outputTag,
PatternFlatTimeoutFunction<IN,OUT2> timeoutFunction)
Creates a data stream containing results of
PatternFlatSelectFunction to fully matching event patterns and
also timed out partially matched with applied PatternFlatTimeoutFunction as a sideoutput. |
static <IN,OUT1,OUT2> |
CEPOperatorUtils.createTimeoutPatternStream(DataStream<IN> inputStream,
Pattern<IN,?> pattern,
EventComparator<IN> comparator,
PatternSelectFunction<IN,OUT1> selectFunction,
TypeInformation<OUT1> outTypeInfo,
OutputTag<OUT2> outputTag,
PatternTimeoutFunction<IN,OUT2> timeoutFunction)
Creates a data stream containing results of
PatternSelectFunction to fully matching event patterns and
also timed out partially matched with applied PatternTimeoutFunction as a sideoutput. |
Modifier and Type | Method and Description |
---|---|
DataStream<Row> |
StreamSQLTestProgram.GeneratorTableSource.getDataStream(StreamExecutionEnvironment execEnv) |
Modifier and Type | Class and Description |
---|---|
class |
DataStreamSource<T>
The DataStreamSource represents the starting point of a DataStream.
|
class |
IterativeStream<T>
The iterative data stream represents the start of an iteration in a
DataStream . |
class |
KeyedStream<T,KEY>
A
KeyedStream represents a DataStream on which operator state is
partitioned by key using a provided KeySelector . |
class |
SingleOutputStreamOperator<T>
SingleOutputStreamOperator represents a user defined transformation
applied on a DataStream with one predefined output type. |
class |
SplitStream<OUT>
The SplitStream represents an operator that has been split using an
OutputSelector . |
Modifier and Type | Field and Description |
---|---|
protected DataStream<IN1> |
ConnectedStreams.inputStream1 |
protected DataStream<IN2> |
ConnectedStreams.inputStream2 |
Modifier and Type | Method and Description |
---|---|
<T> DataStream<T> |
CoGroupedStreams.WithWindow.apply(CoGroupFunction<T1,T2,T> function)
Completes the co-group operation with the user function that is executed
for windowed groups.
|
<T> DataStream<T> |
CoGroupedStreams.WithWindow.apply(CoGroupFunction<T1,T2,T> function,
TypeInformation<T> resultType)
Completes the co-group operation with the user function that is executed
for windowed groups.
|
<T> DataStream<T> |
JoinedStreams.WithWindow.apply(FlatJoinFunction<T1,T2,T> function)
Completes the join operation with the user function that is executed
for each combination of elements with the same key in a window.
|
<T> DataStream<T> |
JoinedStreams.WithWindow.apply(FlatJoinFunction<T1,T2,T> function,
TypeInformation<T> resultType)
Completes the join operation with the user function that is executed
for each combination of elements with the same key in a window.
|
<T> DataStream<T> |
JoinedStreams.WithWindow.apply(JoinFunction<T1,T2,T> function)
Completes the join operation with the user function that is executed
for each combination of elements with the same key in a window.
|
<T> DataStream<T> |
JoinedStreams.WithWindow.apply(JoinFunction<T1,T2,T> function,
TypeInformation<T> resultType)
Completes the join operation with the user function that is executed
for each combination of elements with the same key in a window.
|
DataStream<T> |
DataStream.broadcast()
Sets the partitioning of the
DataStream so that the output elements
are broadcast to every parallel instance of the next operation. |
DataStream<F> |
IterativeStream.ConnectedIterativeStreams.closeWith(DataStream<F> feedbackStream)
Closes the iteration.
|
DataStream<T> |
IterativeStream.closeWith(DataStream<T> feedbackStream)
Closes the iteration.
|
DataStream<T> |
DataStream.forward()
Sets the partitioning of the
DataStream so that the output elements
are forwarded to the local subtask of the next operation. |
DataStream<IN1> |
BroadcastConnectedStream.getFirstInput()
Returns the non-broadcast
DataStream . |
DataStream<IN1> |
ConnectedStreams.getFirstInput()
Returns the first
DataStream . |
DataStream<IN2> |
ConnectedStreams.getSecondInput()
Returns the second
DataStream . |
<X> DataStream<X> |
SingleOutputStreamOperator.getSideOutput(OutputTag<X> sideOutputTag)
Gets the
DataStream that contains the elements that are emitted from an operation
into the side output with the given OutputTag . |
DataStream<T> |
DataStream.global()
Sets the partitioning of the
DataStream so that the output values
all go to the first instance of the next processing operator. |
<K> DataStream<T> |
DataStream.partitionCustom(Partitioner<K> partitioner,
int field)
Partitions a tuple DataStream on the specified key fields using a custom partitioner.
|
<K> DataStream<T> |
DataStream.partitionCustom(Partitioner<K> partitioner,
KeySelector<T,K> keySelector)
Partitions a DataStream on the key returned by the selector, using a custom partitioner.
|
<K> DataStream<T> |
DataStream.partitionCustom(Partitioner<K> partitioner,
String field)
Partitions a POJO DataStream on the specified key fields using a custom partitioner.
|
DataStream<T> |
DataStream.rebalance()
Sets the partitioning of the
DataStream so that the output elements
are distributed evenly to instances of the next operation in a round-robin
fashion. |
DataStream<T> |
DataStream.rescale()
Sets the partitioning of the
DataStream so that the output elements
are distributed evenly to a subset of instances of the next operation in a round-robin
fashion. |
DataStream<OUT> |
SplitStream.select(String... outputNames)
Sets the output names for which the next operator will receive values.
|
protected DataStream<T> |
DataStream.setConnectionType(StreamPartitioner<T> partitioner)
Internal function for setting the partitioner for the DataStream.
|
protected DataStream<T> |
KeyedStream.setConnectionType(StreamPartitioner<T> partitioner) |
DataStream<T> |
DataStream.shuffle()
Sets the partitioning of the
DataStream so that the output elements
are shuffled uniformly randomly to the next operation. |
DataStream<T> |
DataStream.union(DataStream<T>... streams)
Creates a new
DataStream by merging DataStream outputs of
the same type with each other. |
Modifier and Type | Method and Description |
---|---|
DataStream<F> |
IterativeStream.ConnectedIterativeStreams.closeWith(DataStream<F> feedbackStream)
Closes the iteration.
|
DataStream<T> |
IterativeStream.closeWith(DataStream<T> feedbackStream)
Closes the iteration.
|
<T2> CoGroupedStreams<T,T2> |
DataStream.coGroup(DataStream<T2> otherStream)
Creates a join operation.
|
static <OUT> Iterator<OUT> |
DataStreamUtils.collect(DataStream<OUT> stream)
Returns an iterator to iterate over the elements of the DataStream.
|
<R> ConnectedStreams<T,R> |
DataStream.connect(DataStream<R> dataStream)
Creates a new
ConnectedStreams by connecting
DataStream outputs of (possible) different types with each other. |
<T2> JoinedStreams<T,T2> |
DataStream.join(DataStream<T2> otherStream)
Creates a join operation.
|
static <IN,OUT> SingleOutputStreamOperator<OUT> |
AsyncDataStream.orderedWait(DataStream<IN> in,
AsyncFunction<IN,OUT> func,
long timeout,
TimeUnit timeUnit)
Add an AsyncWaitOperator.
|
static <IN,OUT> SingleOutputStreamOperator<OUT> |
AsyncDataStream.orderedWait(DataStream<IN> in,
AsyncFunction<IN,OUT> func,
long timeout,
TimeUnit timeUnit,
int capacity)
Add an AsyncWaitOperator.
|
static <T,K> KeyedStream<T,K> |
DataStreamUtils.reinterpretAsKeyedStream(DataStream<T> stream,
KeySelector<T,K> keySelector)
|
static <T,K> KeyedStream<T,K> |
DataStreamUtils.reinterpretAsKeyedStream(DataStream<T> stream,
KeySelector<T,K> keySelector,
TypeInformation<K> typeInfo)
|
DataStream<T> |
DataStream.union(DataStream<T>... streams)
Creates a new
DataStream by merging DataStream outputs of
the same type with each other. |
static <IN,OUT> SingleOutputStreamOperator<OUT> |
AsyncDataStream.unorderedWait(DataStream<IN> in,
AsyncFunction<IN,OUT> func,
long timeout,
TimeUnit timeUnit)
Add an AsyncWaitOperator.
|
static <IN,OUT> SingleOutputStreamOperator<OUT> |
AsyncDataStream.unorderedWait(DataStream<IN> in,
AsyncFunction<IN,OUT> func,
long timeout,
TimeUnit timeUnit,
int capacity)
Add an AsyncWaitOperator.
|
Constructor and Description |
---|
AllWindowedStream(DataStream<T> input,
WindowAssigner<? super T,W> windowAssigner) |
BroadcastConnectedStream(StreamExecutionEnvironment env,
DataStream<IN1> input1,
BroadcastStream<IN2> input2,
List<MapStateDescriptor<?,?>> broadcastStateDescriptors) |
BroadcastStream(StreamExecutionEnvironment env,
DataStream<T> input,
MapStateDescriptor<?,?>... broadcastStateDescriptors) |
CoGroupedStreams(DataStream<T1> input1,
DataStream<T2> input2)
Creates new CoGrouped data streams, which are the first step towards building a streaming
co-group.
|
CoGroupedStreams(DataStream<T1> input1,
DataStream<T2> input2)
Creates new CoGrouped data streams, which are the first step towards building a streaming
co-group.
|
ConnectedIterativeStreams(DataStream<I> input,
TypeInformation<F> feedbackType,
long waitTime) |
ConnectedStreams(StreamExecutionEnvironment env,
DataStream<IN1> input1,
DataStream<IN2> input2) |
ConnectedStreams(StreamExecutionEnvironment env,
DataStream<IN1> input1,
DataStream<IN2> input2) |
DataStreamSink(DataStream<T> inputStream,
StreamSink<T> operator) |
IterativeStream(DataStream<T> dataStream,
long maxWaitTime) |
JoinedStreams(DataStream<T1> input1,
DataStream<T2> input2)
Creates new JoinedStreams data streams, which are the first step towards building a streaming co-group.
|
JoinedStreams(DataStream<T1> input1,
DataStream<T2> input2)
Creates new JoinedStreams data streams, which are the first step towards building a streaming co-group.
|
KeyedStream(DataStream<T> dataStream,
KeySelector<T,KEY> keySelector)
Creates a new
KeyedStream using the given KeySelector
to partition operator state by key. |
KeyedStream(DataStream<T> dataStream,
KeySelector<T,KEY> keySelector,
TypeInformation<KEY> keyType)
Creates a new
KeyedStream using the given KeySelector
to partition operator state by key. |
SplitStream(DataStream<OUT> dataStream,
OutputSelector<OUT> outputSelector) |
StreamProjection(DataStream<IN> dataStream,
int[] fieldIndexes) |
WithWindow(DataStream<T1> input1,
DataStream<T2> input2,
KeySelector<T1,KEY> keySelector1,
KeySelector<T2,KEY> keySelector2,
TypeInformation<KEY> keyType,
WindowAssigner<? super CoGroupedStreams.TaggedUnion<T1,T2>,W> windowAssigner,
Trigger<? super CoGroupedStreams.TaggedUnion<T1,T2>,? super W> trigger,
Evictor<? super CoGroupedStreams.TaggedUnion<T1,T2>,? super W> evictor) |
WithWindow(DataStream<T1> input1,
DataStream<T2> input2,
KeySelector<T1,KEY> keySelector1,
KeySelector<T2,KEY> keySelector2,
TypeInformation<KEY> keyType,
WindowAssigner<? super CoGroupedStreams.TaggedUnion<T1,T2>,W> windowAssigner,
Trigger<? super CoGroupedStreams.TaggedUnion<T1,T2>,? super W> trigger,
Evictor<? super CoGroupedStreams.TaggedUnion<T1,T2>,? super W> evictor) |
WithWindow(DataStream<T1> input1,
DataStream<T2> input2,
KeySelector<T1,KEY> keySelector1,
KeySelector<T2,KEY> keySelector2,
TypeInformation<KEY> keyType,
WindowAssigner<? super CoGroupedStreams.TaggedUnion<T1,T2>,W> windowAssigner,
Trigger<? super CoGroupedStreams.TaggedUnion<T1,T2>,? super W> trigger,
Evictor<? super CoGroupedStreams.TaggedUnion<T1,T2>,? super W> evictor) |
WithWindow(DataStream<T1> input1,
DataStream<T2> input2,
KeySelector<T1,KEY> keySelector1,
KeySelector<T2,KEY> keySelector2,
TypeInformation<KEY> keyType,
WindowAssigner<? super CoGroupedStreams.TaggedUnion<T1,T2>,W> windowAssigner,
Trigger<? super CoGroupedStreams.TaggedUnion<T1,T2>,? super W> trigger,
Evictor<? super CoGroupedStreams.TaggedUnion<T1,T2>,? super W> evictor) |
Modifier and Type | Method and Description |
---|---|
DataStream<String> |
StreamExecutionEnvironment.readFileStream(String filePath,
long intervalMillis,
FileMonitoringFunction.WatchType watchType)
Deprecated.
|
Modifier and Type | Field and Description |
---|---|
protected DataStream<IN> |
CassandraSink.CassandraSinkBuilder.input |
Modifier and Type | Method and Description |
---|---|
static <IN> CassandraSink.CassandraSinkBuilder<IN> |
CassandraSink.addSink(DataStream<IN> input)
Writes a DataStream into a Cassandra database.
|
void |
CassandraAppendTableSink.emitDataStream(DataStream<Row> dataStream) |
Constructor and Description |
---|
CassandraPojoSinkBuilder(DataStream<IN> input,
TypeInformation<IN> typeInfo,
TypeSerializer<IN> serializer) |
CassandraRowSinkBuilder(DataStream<Row> input,
TypeInformation<Row> typeInfo,
TypeSerializer<Row> serializer) |
CassandraScalaProductSinkBuilder(DataStream<IN> input,
TypeInformation<IN> typeInfo,
TypeSerializer<IN> serializer) |
CassandraSinkBuilder(DataStream<IN> input,
TypeInformation<IN> typeInfo,
TypeSerializer<IN> serializer) |
CassandraTupleSinkBuilder(DataStream<IN> input,
TypeInformation<IN> typeInfo,
TypeSerializer<IN> serializer) |
Modifier and Type | Method and Description |
---|---|
DataStream<Row> |
KafkaTableSource.getDataStream(StreamExecutionEnvironment env)
NOTE: This method is for internal use only for defining a TableSource.
|
Modifier and Type | Method and Description |
---|---|
static DataStream<Tuple2<String,Integer>> |
WindowJoinSampleData.GradeSource.getSource(StreamExecutionEnvironment env,
long rate) |
static DataStream<Tuple2<String,Integer>> |
WindowJoinSampleData.SalarySource.getSource(StreamExecutionEnvironment env,
long rate) |
static DataStream<Tuple3<String,Integer,Integer>> |
WindowJoin.runWindowJoin(DataStream<Tuple2<String,Integer>> grades,
DataStream<Tuple2<String,Integer>> salaries,
long windowSize) |
Modifier and Type | Method and Description |
---|---|
static DataStream<Tuple3<String,Integer,Integer>> |
WindowJoin.runWindowJoin(DataStream<Tuple2<String,Integer>> grades,
DataStream<Tuple2<String,Integer>> salaries,
long windowSize) |
static DataStream<Tuple3<String,Integer,Integer>> |
WindowJoin.runWindowJoin(DataStream<Tuple2<String,Integer>> grades,
DataStream<Tuple2<String,Integer>> salaries,
long windowSize) |
Modifier and Type | Class and Description |
---|---|
class |
PythonDataStream<D extends DataStream<org.python.core.PyObject>>
A
PythonDataStream is a thin wrapper layer over DataStream , which represents a
stream of elements of the same type. |
Modifier and Type | Field and Description |
---|---|
protected D |
PythonDataStream.stream |
Modifier and Type | Method and Description |
---|---|
PythonDataStream |
PythonIterativeStream.close_with(PythonDataStream<? extends DataStream<org.python.core.PyObject>> feedback_stream)
A thin wrapper layer over
IterativeStream.closeWith(org.apache.flink.streaming.api.datastream.DataStream) |
Modifier and Type | Method and Description |
---|---|
void |
CollectStreamTableSink.emitDataStream(DataStream<Tuple2<Boolean,Row>> stream) |
Copyright © 2014–2019 The Apache Software Foundation. All rights reserved.