Package | Description |
---|---|
org.apache.flink.streaming.api.scala |
Modifier and Type | Method and Description |
---|---|
<T2> ConnectedStreams<T,T2> |
DataStream.connect(DataStream<T2> dataStream)
Creates a new ConnectedStreams by connecting
DataStream outputs of different type with each other.
|
<K1,K2> ConnectedStreams<IN1,IN2> |
ConnectedStreams.keyBy(scala.Function1<IN1,K1> fun1,
scala.Function1<IN2,K2> fun2,
TypeInformation<K1> evidence$6,
TypeInformation<K2> evidence$7)
Keys the two connected streams together.
|
ConnectedStreams<IN1,IN2> |
ConnectedStreams.keyBy(int[] keyPositions1,
int[] keyPositions2)
Keys the two connected streams together.
|
ConnectedStreams<IN1,IN2> |
ConnectedStreams.keyBy(int keyPosition1,
int keyPosition2)
Keys the two connected streams together.
|
ConnectedStreams<IN1,IN2> |
ConnectedStreams.keyBy(String[] fields1,
String[] fields2)
Keys the two connected streams together.
|
ConnectedStreams<IN1,IN2> |
ConnectedStreams.keyBy(String field1,
String field2)
Keys the two connected streams together.
|
Modifier and Type | Method and Description |
---|---|
<R,F> DataStream<R> |
DataStream.iterate(scala.Function1<ConnectedStreams<T,F>,scala.Tuple2<DataStream<F>,DataStream<R>>> stepFunction,
long maxWaitTimeMillis,
TypeInformation<F> evidence$5)
Initiates an iterative part of the program that creates a loop by feeding
back data streams.
|
Copyright © 2014–2017 The Apache Software Foundation. All rights reserved.