Package | Description |
---|---|
org.apache.flink.connector.kafka.sink |
Modifier and Type | Class and Description |
---|---|
class |
DefaultKafkaSinkContext
Context providing information to assist constructing a
ProducerRecord . |
Modifier and Type | Method and Description |
---|---|
default void |
KafkaRecordSerializationSchema.open(SerializationSchema.InitializationContext context,
KafkaRecordSerializationSchema.KafkaSinkContext sinkContext)
Initialization method for the schema.
|
org.apache.kafka.clients.producer.ProducerRecord<byte[],byte[]> |
KafkaRecordSerializationSchema.serialize(T element,
KafkaRecordSerializationSchema.KafkaSinkContext context,
Long timestamp)
Serializes given element and returns it as a
ProducerRecord . |
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.