OUT
- The output type of the operator@Internal public class SimpleOperatorFactory<OUT> extends AbstractStreamOperatorFactory<OUT>
StreamOperator
.chainingStrategy, processingTimeService
Modifier | Constructor and Description |
---|---|
protected |
SimpleOperatorFactory(StreamOperator<OUT> operator) |
getChainingStrategy, getMailboxExecutor, setMailboxExecutor, setProcessingTimeService
protected SimpleOperatorFactory(StreamOperator<OUT> operator)
public static <OUT> SimpleOperatorFactory<OUT> of(StreamOperator<OUT> operator)
public StreamOperator<OUT> getOperator()
public <T extends StreamOperator<OUT>> T createStreamOperator(StreamOperatorParameters<OUT> parameters)
StreamOperatorFactory
public void setChainingStrategy(ChainingStrategy strategy)
StreamOperatorFactory
setChainingStrategy
in interface StreamOperatorFactory<OUT>
setChainingStrategy
in class AbstractStreamOperatorFactory<OUT>
public boolean isStreamSource()
StreamOperatorFactory
StreamSource
.public boolean isLegacySource()
public boolean isOutputTypeConfigurable()
StreamOperatorFactory
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.public void setOutputType(TypeInformation<OUT> type, ExecutionConfig executionConfig)
StreamOperatorFactory
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 configurationpublic boolean isInputTypeConfigurable()
StreamOperatorFactory
public void setInputType(TypeInformation<?> type, ExecutionConfig executionConfig)
StreamOperatorFactory
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.public Class<? extends StreamOperator> getStreamOperatorClass(ClassLoader classLoader)
StreamOperatorFactory
public OperatorAttributes getOperatorAttributes()
StreamOperatorFactory
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.