Class AbstractStreamOperatorFactory<OUT>
- java.lang.Object
-
- org.apache.flink.streaming.api.operators.AbstractStreamOperatorFactory<OUT>
-
- All Implemented Interfaces:
Serializable
,StreamOperatorFactory<OUT>
,ProcessingTimeServiceAware
- Direct Known Subclasses:
AsyncWaitOperatorFactory
,BatchMultipleInputStreamOperatorFactory
,CodeGenOperatorFactory
,CommitterOperatorFactory
,CompactCoordinatorFactory
,CompactCoordinatorStateHandlerFactory
,CompactorOperatorFactory
,CompactorOperatorStateHandlerFactory
,ContinuousFileReaderOperatorFactory
,DynamicFilteringDataCollectorOperatorFactory
,OperatorFusionCodegenFactory
,SimpleOperatorFactory
,SinkWriterOperatorFactory
,SourceOperatorFactory
,StateBootstrapWrapperOperatorFactory
,TimestampsAndWatermarksOperatorFactory
,WatermarkAssignerOperatorFactory
,WindowOperatorFactory
@Experimental public abstract class AbstractStreamOperatorFactory<OUT> extends Object implements StreamOperatorFactory<OUT>, ProcessingTimeServiceAware
Base class for all stream operator factories. It implements some common methods and theProcessingTimeServiceAware
interface which enables stream operators to accessProcessingTimeService
.- See Also:
- Serialized Form
-
-
Field Summary
Fields Modifier and Type Field Description protected ChainingStrategy
chainingStrategy
protected ProcessingTimeService
processingTimeService
-
Constructor Summary
Constructors Constructor Description AbstractStreamOperatorFactory()
-
Method Summary
All Methods Instance Methods Concrete Methods Modifier and Type Method Description ChainingStrategy
getChainingStrategy()
Get the chaining strategy of operator factory.protected MailboxExecutor
getMailboxExecutor()
Provides the mailbox executor iff this factory implementsYieldingOperatorFactory
.void
setChainingStrategy(ChainingStrategy strategy)
Set the chaining strategy for operator factory.void
setMailboxExecutor(MailboxExecutor mailboxExecutor)
void
setProcessingTimeService(ProcessingTimeService processingTimeService)
-
Methods inherited from class java.lang.Object
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
-
Methods inherited from interface org.apache.flink.streaming.api.operators.StreamOperatorFactory
createStreamOperator, getOperatorAttributes, getStreamOperatorClass, isInputTypeConfigurable, isLegacySource, isOutputTypeConfigurable, isStreamSource, setInputType, setOutputType
-
-
-
-
Field Detail
-
chainingStrategy
protected ChainingStrategy chainingStrategy
-
processingTimeService
protected transient ProcessingTimeService processingTimeService
-
-
Method Detail
-
setChainingStrategy
public void setChainingStrategy(ChainingStrategy strategy)
Description copied from interface:StreamOperatorFactory
Set the chaining strategy for operator factory.- Specified by:
setChainingStrategy
in interfaceStreamOperatorFactory<OUT>
-
getChainingStrategy
public ChainingStrategy getChainingStrategy()
Description copied from interface:StreamOperatorFactory
Get the chaining strategy of operator factory.- Specified by:
getChainingStrategy
in interfaceStreamOperatorFactory<OUT>
-
setProcessingTimeService
public void setProcessingTimeService(ProcessingTimeService processingTimeService)
- Specified by:
setProcessingTimeService
in interfaceProcessingTimeServiceAware
-
setMailboxExecutor
public void setMailboxExecutor(MailboxExecutor mailboxExecutor)
-
getMailboxExecutor
protected MailboxExecutor getMailboxExecutor()
Provides the mailbox executor iff this factory implementsYieldingOperatorFactory
.
-
-