Class SinkWriterOperatorFactory<InputT,CommT>
- java.lang.Object
-
- org.apache.flink.streaming.api.operators.AbstractStreamOperatorFactory<CommittableMessage<CommT>>
-
- org.apache.flink.streaming.runtime.operators.sink.SinkWriterOperatorFactory<InputT,CommT>
-
- Type Parameters:
InputT
- The input type of theSinkWriter
.CommT
- The committable type of theSinkWriter
.
- All Implemented Interfaces:
Serializable
,YieldingOperatorFactory<CommittableMessage<CommT>>
,OneInputStreamOperatorFactory<InputT,CommittableMessage<CommT>>
,StreamOperatorFactory<CommittableMessage<CommT>>
,ProcessingTimeServiceAware
@Internal public final class SinkWriterOperatorFactory<InputT,CommT> extends AbstractStreamOperatorFactory<CommittableMessage<CommT>> implements OneInputStreamOperatorFactory<InputT,CommittableMessage<CommT>>, YieldingOperatorFactory<CommittableMessage<CommT>>
AStreamOperatorFactory
forSinkWriterOperator
.- See Also:
- Serialized Form
-
-
Field Summary
-
Fields inherited from class org.apache.flink.streaming.api.operators.AbstractStreamOperatorFactory
chainingStrategy, processingTimeService
-
-
Constructor Summary
Constructors Constructor Description SinkWriterOperatorFactory(Sink<InputT> sink)
-
Method Summary
All Methods Instance Methods Concrete Methods Modifier and Type Method Description <T extends StreamOperator<CommittableMessage<CommT>>>
TcreateStreamOperator(StreamOperatorParameters<CommittableMessage<CommT>> parameters)
Create the operator.Sink<InputT>
getSink()
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
getChainingStrategy, getOperatorAttributes, isInputTypeConfigurable, isLegacySource, isOutputTypeConfigurable, isStreamSource, setChainingStrategy, setInputType, setOutputType
-
Methods inherited from interface org.apache.flink.streaming.api.operators.legacy.YieldingOperatorFactory
setMailboxExecutor
-
-
-
-
Method Detail
-
createStreamOperator
public <T extends StreamOperator<CommittableMessage<CommT>>> T createStreamOperator(StreamOperatorParameters<CommittableMessage<CommT>> parameters)
Description copied from interface:StreamOperatorFactory
Create the operator. Sets access to the context and the output.- Specified by:
createStreamOperator
in interfaceStreamOperatorFactory<InputT>
-
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<InputT>
-
getSink
@VisibleForTesting public Sink<InputT> getSink()
-
-