Class NonKeyedPartitionStreamImpl<T>
- java.lang.Object
-
- org.apache.flink.datastream.impl.stream.AbstractDataStream<T>
-
- org.apache.flink.datastream.impl.stream.NonKeyedPartitionStreamImpl<T>
-
- All Implemented Interfaces:
DataStream
,NonKeyedPartitionStream<T>
public class NonKeyedPartitionStreamImpl<T> extends AbstractDataStream<T> implements NonKeyedPartitionStream<T>
The implementation ofNonKeyedPartitionStream
.
-
-
Nested Class Summary
-
Nested classes/interfaces inherited from interface org.apache.flink.datastream.api.stream.NonKeyedPartitionStream
NonKeyedPartitionStream.ProcessConfigurableAndNonKeyedPartitionStream<T>, NonKeyedPartitionStream.ProcessConfigurableAndTwoNonKeyedPartitionStream<OUT1,OUT2>
-
-
Field Summary
-
Fields inherited from class org.apache.flink.datastream.impl.stream.AbstractDataStream
environment, requestedSideOutputs, transformation
-
-
Constructor Summary
Constructors Constructor Description NonKeyedPartitionStreamImpl(ExecutionEnvironmentImpl environment, Transformation<T> transformation)
-
Method Summary
-
Methods inherited from class org.apache.flink.datastream.impl.stream.AbstractDataStream
getEnvironment, getSideOutputTransform, getTransformation, getType
-
-
-
-
Constructor Detail
-
NonKeyedPartitionStreamImpl
public NonKeyedPartitionStreamImpl(ExecutionEnvironmentImpl environment, Transformation<T> transformation)
-
-
Method Detail
-
process
public <OUT> NonKeyedPartitionStream.ProcessConfigurableAndNonKeyedPartitionStream<OUT> process(OneInputStreamProcessFunction<T,OUT> processFunction)
Description copied from interface:NonKeyedPartitionStream
Apply an operation to thisNonKeyedPartitionStream
.- Specified by:
process
in interfaceNonKeyedPartitionStream<T>
- Parameters:
processFunction
- to perform operation.- Returns:
- new stream with this operation.
-
process
public <OUT1,OUT2> NonKeyedPartitionStream.ProcessConfigurableAndTwoNonKeyedPartitionStream<OUT1,OUT2> process(TwoOutputStreamProcessFunction<T,OUT1,OUT2> processFunction)
Description copied from interface:NonKeyedPartitionStream
Apply a two output operation to thisNonKeyedPartitionStream
.- Specified by:
process
in interfaceNonKeyedPartitionStream<T>
- Parameters:
processFunction
- to perform two output operation.- Returns:
- new stream with this operation.
-
connectAndProcess
public <T_OTHER,OUT> NonKeyedPartitionStream.ProcessConfigurableAndNonKeyedPartitionStream<OUT> connectAndProcess(NonKeyedPartitionStream<T_OTHER> other, TwoInputNonBroadcastStreamProcessFunction<T,T_OTHER,OUT> processFunction)
Description copied from interface:NonKeyedPartitionStream
Apply to a two input operation on this and otherNonKeyedPartitionStream
.- Specified by:
connectAndProcess
in interfaceNonKeyedPartitionStream<T>
- Parameters:
other
-NonKeyedPartitionStream
to perform operation with two input.processFunction
- to perform operation.- Returns:
- new stream with this operation.
-
connectAndProcess
public <T_OTHER,OUT> NonKeyedPartitionStream.ProcessConfigurableAndNonKeyedPartitionStream<OUT> connectAndProcess(BroadcastStream<T_OTHER> other, TwoInputBroadcastStreamProcessFunction<T,T_OTHER,OUT> processFunction)
Description copied from interface:NonKeyedPartitionStream
Apply a two input operation to this and otherBroadcastStream
.- Specified by:
connectAndProcess
in interfaceNonKeyedPartitionStream<T>
processFunction
- to perform operation.- Returns:
- new stream with this operation.
-
toSink
public ProcessConfigurable<?> toSink(Sink<T> sink)
- Specified by:
toSink
in interfaceNonKeyedPartitionStream<T>
-
global
public GlobalStream<T> global()
Description copied from interface:NonKeyedPartitionStream
Coalesce this stream to aGlobalStream
.- Specified by:
global
in interfaceNonKeyedPartitionStream<T>
- Returns:
- the coalesced global stream.
-
keyBy
public <K> KeyedPartitionStream<K,T> keyBy(KeySelector<T,K> keySelector)
Description copied from interface:NonKeyedPartitionStream
Transform this stream to aKeyedPartitionStream
.- Specified by:
keyBy
in interfaceNonKeyedPartitionStream<T>
- Parameters:
keySelector
- to decide how to map data to partition.- Returns:
- the transformed stream partitioned by key.
-
shuffle
public NonKeyedPartitionStream<T> shuffle()
Description copied from interface:NonKeyedPartitionStream
Transform this stream to a newNonKeyedPartitionStream
, data will be shuffled between these two streams.- Specified by:
shuffle
in interfaceNonKeyedPartitionStream<T>
- Returns:
- the transformed stream after shuffle.
-
broadcast
public BroadcastStream<T> broadcast()
Description copied from interface:NonKeyedPartitionStream
Transform this stream to a newBroadcastStream
.- Specified by:
broadcast
in interfaceNonKeyedPartitionStream<T>
- Returns:
- the transformed
BroadcastStream
.
-
-