Interface RetractStreamTableSink<T>

  • Type Parameters:
    T - Type of records that this TableSink expects and supports.
    All Superinterfaces:
    StreamTableSink<org.apache.flink.api.java.tuple.Tuple2<Boolean,​T>>, org.apache.flink.table.legacy.sinks.TableSink<org.apache.flink.api.java.tuple.Tuple2<Boolean,​T>>

    @Deprecated
    @Internal
    public interface RetractStreamTableSink<T>
    extends StreamTableSink<org.apache.flink.api.java.tuple.Tuple2<Boolean,​T>>
    Deprecated.
    This interface has been replaced by DynamicTableSink. The new interface consumes internal data structures. See FLIP-95 for more information.
    Defines an external TableSink to emit a streaming Table with insert, update, and delete changes.

    The table will be converted into a stream of accumulate and retraction messages which are encoded as Tuple2. The first field is a Boolean flag to indicate the message type. The second field holds the record of the requested type RetractStreamTableSink.

    A message with true Boolean flag is an accumulate (or add) message.

    A message with false flag is a retract message.

    • Method Detail

      • getRecordType

        org.apache.flink.api.common.typeinfo.TypeInformation<T> getRecordType()
        Deprecated.
        Returns the requested record type.
      • getOutputType

        default org.apache.flink.api.common.typeinfo.TypeInformation<org.apache.flink.api.java.tuple.Tuple2<Boolean,​T>> getOutputType()
        Deprecated.
        Specified by:
        getOutputType in interface org.apache.flink.table.legacy.sinks.TableSink<T>