OUT
- The output type of the operator@PublicEvolving public interface StreamOperatorFactory<OUT> extends Serializable
StreamOperator
.<T extends StreamOperator<OUT>> T createStreamOperator(StreamOperatorParameters<OUT> parameters)
void setChainingStrategy(ChainingStrategy strategy)
ChainingStrategy getChainingStrategy()
default boolean isStreamSource()
StreamSource
.default boolean isLegacySource()
default boolean isOutputTypeConfigurable()
StreamGraph
generation. This can be useful for cases where the output type is specified by the returns
method and, thus, after the stream operator has been created.default void setOutputType(TypeInformation<OUT> type, ExecutionConfig executionConfig)
StreamGraph.addOperator(java.lang.Integer, java.lang.String, java.lang.String, org.apache.flink.streaming.api.operators.StreamOperatorFactory<OUT>, org.apache.flink.api.common.typeinfo.TypeInformation<IN>, org.apache.flink.api.common.typeinfo.TypeInformation<OUT>, java.lang.String)
method when the StreamGraph
is
generated. The method is called with the output TypeInformation
which is also used
for the StreamTask
output serializer.type
- Output type information of the StreamTask
executionConfig
- Execution configurationdefault boolean isInputTypeConfigurable()
default void setInputType(TypeInformation<?> type, ExecutionConfig executionConfig)
StreamGraph.addOperator(java.lang.Integer, java.lang.String, java.lang.String, org.apache.flink.streaming.api.operators.StreamOperatorFactory<OUT>, org.apache.flink.api.common.typeinfo.TypeInformation<IN>, org.apache.flink.api.common.typeinfo.TypeInformation<OUT>, java.lang.String)
method when the StreamGraph
is
generated.type
- The data type of the input.executionConfig
- The execution config for this parallel execution.Class<? extends StreamOperator> getStreamOperatorClass(ClassLoader classLoader)
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.