Class BatchMultipleInputStreamOperatorFactory
- java.lang.Object
-
- org.apache.flink.streaming.api.operators.AbstractStreamOperatorFactory<RowData>
-
- org.apache.flink.table.runtime.operators.multipleinput.BatchMultipleInputStreamOperatorFactory
-
- All Implemented Interfaces:
Serializable
,StreamOperatorFactory<RowData>
,ProcessingTimeServiceAware
public class BatchMultipleInputStreamOperatorFactory extends AbstractStreamOperatorFactory<RowData>
The factory to createBatchMultipleInputStreamOperator
.- See Also:
- Serialized Form
-
-
Field Summary
-
Fields inherited from class org.apache.flink.streaming.api.operators.AbstractStreamOperatorFactory
chainingStrategy, processingTimeService
-
-
Constructor Summary
Constructors Constructor Description BatchMultipleInputStreamOperatorFactory(List<InputSpec> inputSpecs, List<TableOperatorWrapper<?>> headWrappers, TableOperatorWrapper<?> tailWrapper)
-
Method Summary
All Methods Instance Methods Concrete Methods Modifier and Type Method Description <T extends StreamOperator<RowData>>
TcreateStreamOperator(StreamOperatorParameters<RowData> parameters)
Create the operator.Class<? extends StreamOperator>
getStreamOperatorClass(ClassLoader classLoader)
Returns the runtime class of the stream operator.-
Methods inherited from class org.apache.flink.streaming.api.operators.AbstractStreamOperatorFactory
getChainingStrategy, getMailboxExecutor, setChainingStrategy, setMailboxExecutor, setProcessingTimeService
-
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
getOperatorAttributes, isInputTypeConfigurable, isLegacySource, isOutputTypeConfigurable, isStreamSource, setInputType, setOutputType
-
-
-
-
Constructor Detail
-
BatchMultipleInputStreamOperatorFactory
public BatchMultipleInputStreamOperatorFactory(List<InputSpec> inputSpecs, List<TableOperatorWrapper<?>> headWrappers, TableOperatorWrapper<?> tailWrapper)
-
-
Method Detail
-
createStreamOperator
public <T extends StreamOperator<RowData>> T createStreamOperator(StreamOperatorParameters<RowData> parameters)
Description copied from interface:StreamOperatorFactory
Create the operator. Sets access to the context and the output.
-
getStreamOperatorClass
public Class<? extends StreamOperator> getStreamOperatorClass(ClassLoader classLoader)
Description copied from interface:StreamOperatorFactory
Returns the runtime class of the stream operator.
-
-