Interface OutputTypeConfigurable<OUT>
-
- All Known Implementing Classes:
AbstractAsyncStateUdfStreamOperator
,AbstractUdfStreamOperator
,AsyncWaitOperator
,BatchCoBroadcastWithKeyedOperator
,BatchCoBroadcastWithNonKeyedOperator
,BatchGroupedReduceOperator
,BroadcastStateBootstrapOperator
,CepOperator
,CoBroadcastWithKeyedOperator
,CoBroadcastWithNonKeyedOperator
,CollectSinkOperator
,ContinuousFileReaderOperator
,CoProcessOperator
,CoStreamFlatMap
,CoStreamMap
,DataGeneratorSource
,EvictingWindowOperator
,FromElementsFunction
,FromElementsGeneratorFunction
,GroupReduceOperator
,IntervalJoinOperator
,KeyedCoProcessOperator
,KeyedCoProcessOperatorWithWatermarkDelay
,KeyedProcessOperator
,KeyedProcessOperator
,KeyedStateBootstrapOperator
,KeyedTwoInputBroadcastProcessOperator
,KeyedTwoInputNonBroadcastProcessOperator
,KeyedTwoOutputProcessOperator
,LegacyKeyedCoProcessOperator
,LegacyKeyedProcessOperator
,MapPartitionOperator
,PartitionAggregateOperator
,PartitionReduceOperator
,ProcessOperator
,ProcessOperator
,SinkOperator
,StateBootstrapOperator
,StreamFilter
,StreamFlatMap
,StreamGroupedReduceOperator
,StreamMap
,StreamSink
,StreamSource
,TwoInputBroadcastProcessOperator
,TwoInputNonBroadcastProcessOperator
,TwoOutputProcessOperator
,UnionStreamOperator
,WindowOperator
@PublicEvolving public interface OutputTypeConfigurable<OUT>
Stream operators can implement this interface if they need access to the output type information atorg.apache.flink.streaming.api.graph.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.NOTE: this class was moved from flink-streaming-java to the same package in flink-core. This was required in order to avoid cyclic dependencies for internal connectors, such as flink-connector-datagen that is used in flink-streaming-java but also relies on
OutputTypeConfigurable
. Since flink-core is the dependency of flink-streaming-java, this does not introduce breaking changes.
-
-
Method Summary
All Methods Instance Methods Abstract Methods Modifier and Type Method Description void
setOutputType(TypeInformation<OUT> outTypeInfo, ExecutionConfig executionConfig)
Is called by theorg.apache.flink.streaming.api.graph.StreamGraph#addOperator(Integer, String, StreamOperator, TypeInformation, TypeInformation, String)
method when theorg.apache.flink.streaming.api.graph.StreamGraph
is generated.
-
-
-
Method Detail
-
setOutputType
void setOutputType(TypeInformation<OUT> outTypeInfo, ExecutionConfig executionConfig)
Is called by theorg.apache.flink.streaming.api.graph.StreamGraph#addOperator(Integer, String, StreamOperator, TypeInformation, TypeInformation, String)
method when theorg.apache.flink.streaming.api.graph.StreamGraph
is generated. The method is called with the outputTypeInformation
which is also used for theorg.apache.flink.streaming.runtime.tasks.StreamTask
output serializer.- Parameters:
outTypeInfo
- Output type information of theorg.apache.flink.streaming.runtime.tasks.StreamTask
executionConfig
- Execution configuration
-
-