Interface StreamOperatorFactory<OUT>
-
- Type Parameters:
OUT
- The output type of the operator
- All Superinterfaces:
Serializable
- All Known Subinterfaces:
CoordinatedOperatorFactory<OUT>
,InputFormatOperatorFactory<OUT>
,OneInputStreamOperatorFactory<IN,OUT>
,OutputFormatOperatorFactory<IN,OUT>
,TwoInputStreamOperatorFactory<IN1,IN2,OUT>
,UdfStreamOperatorFactory<OUT>
,YieldingOperatorFactory<OUT>
- All Known Implementing Classes:
AbstractStreamOperatorFactory
,AsyncWaitOperatorFactory
,BatchMultipleInputStreamOperatorFactory
,CodeGenOperatorFactory
,CollectSinkOperatorFactory
,CommitterOperatorFactory
,CompactCoordinatorFactory
,CompactCoordinatorStateHandlerFactory
,CompactorOperatorFactory
,CompactorOperatorStateHandlerFactory
,ContinuousFileReaderOperatorFactory
,DynamicFilteringDataCollectorOperatorFactory
,EvictingWindowOperatorFactory
,OperatorFusionCodegenFactory
,SimpleInputFormatOperatorFactory
,SimpleOperatorFactory
,SimpleOutputFormatOperatorFactory
,SimpleUdfStreamOperatorFactory
,SinkWriterOperatorFactory
,SourceOperatorFactory
,StateBootstrapWrapperOperatorFactory
,TimestampsAndWatermarksOperatorFactory
,WatermarkAssignerOperatorFactory
,WindowOperatorFactory
@PublicEvolving public interface StreamOperatorFactory<OUT> extends Serializable
A factory to createStreamOperator
.
-
-
Method Summary
-
-
-
Method Detail
-
createStreamOperator
<T extends StreamOperator<OUT>> T createStreamOperator(StreamOperatorParameters<OUT> parameters)
Create the operator. Sets access to the context and the output.
-
setChainingStrategy
void setChainingStrategy(ChainingStrategy strategy)
Set the chaining strategy for operator factory.
-
getChainingStrategy
ChainingStrategy getChainingStrategy()
Get the chaining strategy of operator factory.
-
isStreamSource
default boolean isStreamSource()
Is this factory forStreamSource
.
-
isLegacySource
default boolean isLegacySource()
-
isOutputTypeConfigurable
default boolean isOutputTypeConfigurable()
If the stream operator need access to the output type information atStreamGraph
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.
-
setOutputType
default void setOutputType(TypeInformation<OUT> type, ExecutionConfig executionConfig)
Is called by theStreamGraph.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 theStreamGraph
is generated. The method is called with the outputTypeInformation
which is also used for theStreamTask
output serializer.- Parameters:
type
- Output type information of theStreamTask
executionConfig
- Execution configuration
-
isInputTypeConfigurable
default boolean isInputTypeConfigurable()
If the stream operator need to be configured with the data type they will operate on.
-
setInputType
default void setInputType(TypeInformation<?> type, ExecutionConfig executionConfig)
Is called by theStreamGraph.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 theStreamGraph
is generated.- Parameters:
type
- The data type of the input.executionConfig
- The execution config for this parallel execution.
-
getStreamOperatorClass
Class<? extends StreamOperator> getStreamOperatorClass(ClassLoader classLoader)
Returns the runtime class of the stream operator.
-
getOperatorAttributes
@Experimental default OperatorAttributes getOperatorAttributes()
Is called to get the OperatorAttributes of the operator. OperatorAttributes can inform the frame to optimize the job performance.- Returns:
- OperatorAttributes of the operator.
-
-