Class and Description |
---|
Committer
The
Committer is responsible for committing the data staged by the sink. |
GlobalCommitter
The
GlobalCommitter is responsible for creating and committing an aggregated committable,
which we call global committable (see GlobalCommitter.combine(java.util.List<CommT>) ). |
Sink.InitContext
The interface exposes some runtime info for creating a
SinkWriter . |
Sink.ProcessingTimeService
A service that allows to get the current processing time and register timers that will
execute the given
Sink.ProcessingTimeService.ProcessingTimeCallback when firing. |
Sink.ProcessingTimeService.ProcessingTimeCallback
A callback that can be registered via
Sink.ProcessingTimeService.registerProcessingTimer(long,
ProcessingTimeCallback) . |
SinkWriter
The
SinkWriter is responsible for writing data and handling any potential tmp area used
to write yet un-staged data, e.g. |
SinkWriter.Context
Context that
SinkWriter.write(InputT, org.apache.flink.api.connector.sink.SinkWriter.Context) can use for getting additional data about an input record. |
Class and Description |
---|
Committer
The
Committer is responsible for committing the data staged by the sink. |
GlobalCommitter
The
GlobalCommitter is responsible for creating and committing an aggregated committable,
which we call global committable (see GlobalCommitter.combine(java.util.List<CommT>) ). |
Sink
This interface lets the sink developer build a simple sink topology, which could guarantee the
exactly once semantics in both batch and stream execution mode if there is a
Committer or
GlobalCommitter . |
Sink.InitContext
The interface exposes some runtime info for creating a
SinkWriter . |
SinkWriter
The
SinkWriter is responsible for writing data and handling any potential tmp area used
to write yet un-staged data, e.g. |
Class and Description |
---|
Committer
The
Committer is responsible for committing the data staged by the sink. |
Class and Description |
---|
Sink.ProcessingTimeService
A service that allows to get the current processing time and register timers that will
execute the given
Sink.ProcessingTimeService.ProcessingTimeCallback when firing. |
Sink.ProcessingTimeService.ProcessingTimeCallback
A callback that can be registered via
Sink.ProcessingTimeService.registerProcessingTimer(long,
ProcessingTimeCallback) . |
SinkWriter
The
SinkWriter is responsible for writing data and handling any potential tmp area used
to write yet un-staged data, e.g. |
SinkWriter.Context
Context that
SinkWriter.write(InputT, org.apache.flink.api.connector.sink.SinkWriter.Context) can use for getting additional data about an input record. |
Class and Description |
---|
Sink
This interface lets the sink developer build a simple sink topology, which could guarantee the
exactly once semantics in both batch and stream execution mode if there is a
Committer or
GlobalCommitter . |
Class and Description |
---|
Sink
This interface lets the sink developer build a simple sink topology, which could guarantee the
exactly once semantics in both batch and stream execution mode if there is a
Committer or
GlobalCommitter . |
Class and Description |
---|
Sink
This interface lets the sink developer build a simple sink topology, which could guarantee the
exactly once semantics in both batch and stream execution mode if there is a
Committer or
GlobalCommitter . |
Copyright © 2014–2021 The Apache Software Foundation. All rights reserved.