public class ContinuousFileReaderOperatorFactory<OUT,T extends TimestampedInputSplit> extends AbstractStreamOperatorFactory<OUT> implements YieldingOperatorFactory<OUT>, OneInputStreamOperatorFactory<T,OUT>
ContinuousFileReaderOperator
factory.chainingStrategy, processingTimeService
Constructor and Description |
---|
ContinuousFileReaderOperatorFactory(InputFormat<OUT,? super T> inputFormat) |
ContinuousFileReaderOperatorFactory(InputFormat<OUT,? super T> inputFormat,
TypeInformation<OUT> type,
ExecutionConfig executionConfig) |
Modifier and Type | Method and Description |
---|---|
<O extends StreamOperator<OUT>> |
createStreamOperator(StreamOperatorParameters<OUT> parameters)
Create the operator.
|
Class<? extends StreamOperator> |
getStreamOperatorClass(ClassLoader classLoader)
Returns the runtime class of the stream operator.
|
boolean |
isOutputTypeConfigurable()
If the stream operator need access to the output type information at
StreamGraph
generation. |
void |
setOutputType(TypeInformation<OUT> type,
ExecutionConfig executionConfig)
Is called by the
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. |
getChainingStrategy, getMailboxExecutor, setChainingStrategy, setMailboxExecutor, setProcessingTimeService
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
setMailboxExecutor
getChainingStrategy, getOperatorAttributes, isInputTypeConfigurable, isLegacySource, isStreamSource, setChainingStrategy, setInputType
public ContinuousFileReaderOperatorFactory(InputFormat<OUT,? super T> inputFormat)
public ContinuousFileReaderOperatorFactory(InputFormat<OUT,? super T> inputFormat, TypeInformation<OUT> type, ExecutionConfig executionConfig)
public <O extends StreamOperator<OUT>> O createStreamOperator(StreamOperatorParameters<OUT> parameters)
StreamOperatorFactory
createStreamOperator
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 configurationpublic Class<? extends StreamOperator> getStreamOperatorClass(ClassLoader classLoader)
StreamOperatorFactory
getStreamOperatorClass
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>
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.