Class ContinuousFileReaderOperatorFactory<OUT,T extends TimestampedInputSplit>
- java.lang.Object
-
- org.apache.flink.streaming.api.operators.AbstractStreamOperatorFactory<OUT>
-
- org.apache.flink.streaming.api.functions.source.ContinuousFileReaderOperatorFactory<OUT,T>
-
- All Implemented Interfaces:
Serializable
,YieldingOperatorFactory<OUT>
,OneInputStreamOperatorFactory<T,OUT>
,StreamOperatorFactory<OUT>
,ProcessingTimeServiceAware
public class ContinuousFileReaderOperatorFactory<OUT,T extends TimestampedInputSplit> extends AbstractStreamOperatorFactory<OUT> implements YieldingOperatorFactory<OUT>, OneInputStreamOperatorFactory<T,OUT>
ContinuousFileReaderOperator
factory.- See Also:
- Serialized Form
-
-
Field Summary
-
Fields inherited from class org.apache.flink.streaming.api.operators.AbstractStreamOperatorFactory
chainingStrategy, processingTimeService
-
-
Constructor Summary
Constructors Constructor Description ContinuousFileReaderOperatorFactory(InputFormat<OUT,? super T> inputFormat)
ContinuousFileReaderOperatorFactory(InputFormat<OUT,? super T> inputFormat, TypeInformation<OUT> type, ExecutionConfig executionConfig)
-
Method Summary
All Methods Instance Methods Concrete Methods Modifier and Type Method Description <O extends StreamOperator<OUT>>
OcreateStreamOperator(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 atStreamGraph
generation.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.-
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
getChainingStrategy, getOperatorAttributes, isInputTypeConfigurable, isLegacySource, isStreamSource, setChainingStrategy, setInputType
-
Methods inherited from interface org.apache.flink.streaming.api.operators.legacy.YieldingOperatorFactory
setMailboxExecutor
-
-
-
-
Constructor Detail
-
ContinuousFileReaderOperatorFactory
public ContinuousFileReaderOperatorFactory(InputFormat<OUT,? super T> inputFormat)
-
ContinuousFileReaderOperatorFactory
public ContinuousFileReaderOperatorFactory(InputFormat<OUT,? super T> inputFormat, TypeInformation<OUT> type, ExecutionConfig executionConfig)
-
-
Method Detail
-
createStreamOperator
public <O extends StreamOperator<OUT>> O createStreamOperator(StreamOperatorParameters<OUT> parameters)
Description copied from interface:StreamOperatorFactory
Create the operator. Sets access to the context and the output.- Specified by:
createStreamOperator
in interfaceStreamOperatorFactory<OUT>
-
setOutputType
public void setOutputType(TypeInformation<OUT> type, ExecutionConfig executionConfig)
Description copied from interface:StreamOperatorFactory
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.- Specified by:
setOutputType
in interfaceStreamOperatorFactory<OUT>
- Parameters:
type
- Output type information of theStreamTask
executionConfig
- Execution configuration
-
getStreamOperatorClass
public Class<? extends StreamOperator> getStreamOperatorClass(ClassLoader classLoader)
Description copied from interface:StreamOperatorFactory
Returns the runtime class of the stream operator.- Specified by:
getStreamOperatorClass
in interfaceStreamOperatorFactory<OUT>
-
isOutputTypeConfigurable
public boolean isOutputTypeConfigurable()
Description copied from interface:StreamOperatorFactory
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.- Specified by:
isOutputTypeConfigurable
in interfaceStreamOperatorFactory<OUT>
-
-