public class SourceOperatorFactory<OUT> extends AbstractStreamOperatorFactory<OUT> implements CoordinatedOperatorFactory<OUT>, ProcessingTimeServiceAware
SourceOperator
.chainingStrategy, processingTimeService
Constructor and Description |
---|
SourceOperatorFactory(Source<OUT,?,?> source,
WatermarkStrategy<OUT> watermarkStrategy) |
SourceOperatorFactory(Source<OUT,?,?> source,
WatermarkStrategy<OUT> watermarkStrategy,
boolean emitProgressiveWatermarks) |
SourceOperatorFactory(Source<OUT,?,?> source,
WatermarkStrategy<OUT> watermarkStrategy,
boolean emitProgressiveWatermarks,
int numCoordinatorWorkerThread) |
getChainingStrategy, getMailboxExecutor, setChainingStrategy, setMailboxExecutor, setProcessingTimeService
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
getChainingStrategy, getOperatorAttributes, isInputTypeConfigurable, isLegacySource, setChainingStrategy, setInputType
setProcessingTimeService
public SourceOperatorFactory(Source<OUT,?,?> source, WatermarkStrategy<OUT> watermarkStrategy)
public SourceOperatorFactory(Source<OUT,?,?> source, WatermarkStrategy<OUT> watermarkStrategy, boolean emitProgressiveWatermarks)
public SourceOperatorFactory(Source<OUT,?,?> source, WatermarkStrategy<OUT> watermarkStrategy, boolean emitProgressiveWatermarks, int numCoordinatorWorkerThread)
public Boundedness getBoundedness()
public void setCoordinatorListeningID(@Nullable String coordinatorListeningID)
public <T extends StreamOperator<OUT>> T createStreamOperator(StreamOperatorParameters<OUT> parameters)
CoordinatedOperatorFactory
OperatorEventHandler
.createStreamOperator
in interface CoordinatedOperatorFactory<OUT>
createStreamOperator
in interface StreamOperatorFactory<OUT>
public OperatorCoordinator.Provider getCoordinatorProvider(String operatorName, OperatorID operatorID)
CoordinatedOperatorFactory
getCoordinatorProvider
in interface CoordinatedOperatorFactory<OUT>
operatorName
- the name of the operator.operatorID
- the id of the operator.OperatorCoordinator
for this operator.public Class<? extends StreamOperator> getStreamOperatorClass(ClassLoader classLoader)
StreamOperatorFactory
getStreamOperatorClass
in interface StreamOperatorFactory<OUT>
public boolean isStreamSource()
StreamOperatorFactory
StreamSource
.isStreamSource
in interface StreamOperatorFactory<OUT>
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.isOutputTypeConfigurable
in interface StreamOperatorFactory<OUT>
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.setOutputType
in interface StreamOperatorFactory<OUT>
type
- Output type information of the StreamTask
executionConfig
- Execution configurationCopyright © 2014–2024 The Apache Software Foundation. All rights reserved.