Class VeniceWriter<K,​V,​U>

  • All Implemented Interfaces:
    java.io.Closeable, java.lang.AutoCloseable

    public class VeniceWriter<K,​V,​U>
    extends AbstractVeniceWriter<K,​V,​U>
    Class which acts as the primary writer API.
    • Field Detail

      • VENICE_WRITER_CONFIG_PREFIX

        public static final java.lang.String VENICE_WRITER_CONFIG_PREFIX
        See Also:
        Constant Field Values
      • CLOSE_TIMEOUT_MS

        public static final java.lang.String CLOSE_TIMEOUT_MS
        See Also:
        Constant Field Values
      • ENABLE_RMD_CHUNKING

        public static final java.lang.String ENABLE_RMD_CHUNKING
        See Also:
        Constant Field Values
      • MAX_ATTEMPTS_WHEN_TOPIC_MISSING

        public static final java.lang.String MAX_ATTEMPTS_WHEN_TOPIC_MISSING
        See Also:
        Constant Field Values
      • SLEEP_TIME_MS_WHEN_TOPIC_MISSING

        public static final java.lang.String SLEEP_TIME_MS_WHEN_TOPIC_MISSING
        See Also:
        Constant Field Values
      • MAX_ELAPSED_TIME_FOR_SEGMENT_IN_MS

        public static final java.lang.String MAX_ELAPSED_TIME_FOR_SEGMENT_IN_MS
        A negative value or 0 will disable the feature.
        See Also:
        Constant Field Values
      • MAX_SIZE_FOR_USER_PAYLOAD_PER_MESSAGE_IN_BYTES

        public static final java.lang.String MAX_SIZE_FOR_USER_PAYLOAD_PER_MESSAGE_IN_BYTES
        Chunk size. Default: 972800 N.B.: This must be configured in relation to the following configs: 1. Kafka broker's global setting: `message.max.bytes` (default is 1000012, or ~976 KB) 2. Kafka broker's topic setting: `max.message.bytes` (default is 1000012, or ~976 KB) 3. Kafka producer's setting: `max.request.size` (default is 1048576)
        See Also:
        Constant Field Values
      • DEFAULT_MAX_SIZE_FOR_USER_PAYLOAD_PER_MESSAGE_IN_BYTES

        public static final int DEFAULT_MAX_SIZE_FOR_USER_PAYLOAD_PER_MESSAGE_IN_BYTES
        950 KB for user payload should be conservative enough.
        See Also:
        Constant Field Values
      • DEFAULT_CLOSE_TIMEOUT_MS

        public static final int DEFAULT_CLOSE_TIMEOUT_MS
        This controls the Kafka producer's close timeout.
        See Also:
        Constant Field Values
      • DEFAULT_CHECK_SUM_TYPE

        public static final java.lang.String DEFAULT_CHECK_SUM_TYPE
        Default checksum type. N.B.: Only MD5 (and having no checksums) supports checkpointing mid-checksum.
      • DEFAULT_MAX_ATTEMPTS_WHEN_TOPIC_MISSING

        public static final int DEFAULT_MAX_ATTEMPTS_WHEN_TOPIC_MISSING
        Default number of attempts when trying to produce to a Kafka topic and an exception is caught saying the topic is missing.
        See Also:
        Constant Field Values
      • DEFAULT_SLEEP_TIME_MS_WHEN_TOPIC_MISSING

        public static final int DEFAULT_SLEEP_TIME_MS_WHEN_TOPIC_MISSING
        Sleep time in between retry attempts when a topic is missing. Under default settings, the writer will stall 30 * 10 seconds = 300 seconds = 5 minutes (assuming the failure from Kafka is instantaneous, which of course it isn't, therefore this is a minimum stall time, not a max).
        See Also:
        Constant Field Values
      • DEFAULT_UPSTREAM_OFFSET

        public static final long DEFAULT_UPSTREAM_OFFSET
        The default value of the "upstreamOffset" field in avro record LeaderMetadata. Even though we have set the default value for "upstreamOffset" field as -1, the initial value for the long field "upstreamOffset" is still 0 when we construct a LeaderMetadata record. Default field values are primarily used when reading records that don't have those fields, typically when we deserialize a record from older version to newer version.
      • DEFAULT_UPSTREAM_KAFKA_CLUSTER_ID

        public static final int DEFAULT_UPSTREAM_KAFKA_CLUSTER_ID
      • OPEN_VENICE_WRITER_COUNT

        public static final java.util.concurrent.atomic.AtomicLong OPEN_VENICE_WRITER_COUNT
        A static counter shared by all VeniceWriter instances to track the number of active VeniceWriter
      • VENICE_WRITER_CLOSE_FAILED_COUNT

        public static final java.util.concurrent.atomic.AtomicLong VENICE_WRITER_CLOSE_FAILED_COUNT
        A static counter shared by all VeniceWriter instances to track the number of VeniceWriter that fails to close
      • VENICE_DEFAULT_LOGICAL_TS

        public static final long VENICE_DEFAULT_LOGICAL_TS
        This sentinel value indicates that the venice samza apps do not support the logical timestamp.
        See Also:
        Constant Field Values
      • APP_DEFAULT_LOGICAL_TS

        public static final long APP_DEFAULT_LOGICAL_TS
        This sentinel value indicates that the venice samza apps have not provided the logical timestamp.
        See Also:
        Constant Field Values
      • VENICE_DEFAULT_TIMESTAMP_METADATA_VERSION_ID

        public static final int VENICE_DEFAULT_TIMESTAMP_METADATA_VERSION_ID
        This sentinel value indicates that metadata version id is not present.
        See Also:
        Constant Field Values
      • VENICE_DEFAULT_VALUE_SCHEMA_ID

        public static final int VENICE_DEFAULT_VALUE_SCHEMA_ID
        This sentinel value indicates that value schema id is not present.
        See Also:
        Constant Field Values
      • EMPTY_BYTE_ARRAY

        public static final byte[] EMPTY_BYTE_ARRAY
      • EMPTY_BYTE_BUFFER

        public static final java.nio.ByteBuffer EMPTY_BYTE_BUFFER
      • DEFAULT_LEADER_METADATA_WRAPPER

        public static final LeaderMetadataWrapper DEFAULT_LEADER_METADATA_WRAPPER
    • Constructor Detail

      • VeniceWriter

        public VeniceWriter​(VeniceWriterOptions params,
                            VeniceProperties props,
                            PubSubProducerAdapter producerAdapter,
                            org.apache.avro.Schema overrideProtocolSchema)
        This constructor is currently used only in tests, in order to override the behavior of passing the protocol schema into the header of control messages.
        Parameters:
        overrideProtocolSchema - The schema to pass in CM headers, or null to omit that header entirely
    • Method Detail

      • close

        public void close​(boolean gracefulClose)
        Close the VeniceWriter
        Specified by:
        close in class AbstractVeniceWriter<K,​V,​U>
        Parameters:
        gracefulClose - whether to end the segments and send END_OF_SEGMENT control message.
      • close

        @Deprecated
        public void close​(boolean gracefulClose,
                          boolean retryOnGracefulCloseFailure)
        Deprecated.
        Close the VeniceWriter. Deprecating this method due to the concern of sending END_OF_SEGMENT control message to a non-existing topic can be blocked indefinitely as it is calling sendMessage(KeyProvider, KafkaMessageEnvelopeProvider, int, PubSubProducerCallback, boolean).get() without timeout.
        Parameters:
        gracefulClose - whether to end the segments and send END_OF_SEGMENT control message.
        retryOnGracefulCloseFailure - whether to retry on graceful close failure.
      • closeAsync

        public java.util.concurrent.CompletableFuture<VeniceResourceCloseResult> closeAsync​(boolean gracefulClose)
      • closeAsync

        public java.util.concurrent.CompletableFuture<VeniceResourceCloseResult> closeAsync​(boolean gracefulClose,
                                                                                            boolean retryOnGracefulCloseFailure)
      • close

        public void close()
      • toString

        public java.lang.String toString()
        Overrides:
        toString in class java.lang.Object
      • getProducerGUID

        public GUID getProducerGUID()
      • delete

        public java.util.concurrent.Future<PubSubProduceResult> delete​(K key,
                                                                       PubSubProducerCallback callback)
        Execute a standard "delete" on the key.
        Parameters:
        key - - The key to delete in storage.
        callback - - callback will be executed after Kafka producer completes on sending the message.
        Returns:
        a java.util.concurrent.Future Future for the RecordMetadata that will be assigned to this record. Invoking java.util.concurrent.Future's get() on this future will block until the associated request completes and then return the metadata for the record or throw any exception that occurred while sending the record.
      • delete

        public java.util.concurrent.Future<PubSubProduceResult> delete​(K key,
                                                                       long logicalTs,
                                                                       PubSubProducerCallback callback)
        Execute a standard "delete" on the key.
        Parameters:
        key - - The key to delete in storage.
        logicalTs - - An timestamp field to indicate when this record was produced from apps point of view.
        callback - - callback will be executed after Kafka producer completes on sending the message.
        Returns:
        a java.util.concurrent.Future Future for the RecordMetadata that will be assigned to this record. Invoking java.util.concurrent.Future's get() on this future will block until the associated request completes and then return the metadata for the record or throw any exception that occurred while sending the record.
      • delete

        public java.util.concurrent.Future<PubSubProduceResult> delete​(K key,
                                                                       PubSubProducerCallback callback,
                                                                       LeaderMetadataWrapper leaderMetadataWrapper)
        Execute a standard "delete" on the key.
        Parameters:
        key - - The key to delete in storage.
        callback - - Callback function invoked by Kafka producer after sending the message.
        leaderMetadataWrapper - - The leader Metadata of this message in the source topic: -1: VeniceWriter is sending this message in a Samza app to the real-time topic; or it's sending the message in VPJ plugin to the version topic; >=0: Leader replica consumes a delete message from real-time topic, VeniceWriter in leader is sending this message to version topic with extra info: offset in the real-time topic.
        Returns:
        a java.util.concurrent.Future Future for the RecordMetadata that will be assigned to this record. Invoking java.util.concurrent.Future's get() on this future will block until the associated request completes and then return the metadata for the record or throw any exception that occurred while sending the record.
      • delete

        public java.util.concurrent.Future<PubSubProduceResult> delete​(K key,
                                                                       PubSubProducerCallback callback,
                                                                       LeaderMetadataWrapper leaderMetadataWrapper,
                                                                       long logicalTs)
        Execute a standard "delete" on the key.
        Parameters:
        key - - The key to delete in storage.
        callback - - callback will be executed after Kafka producer completes on sending the message.
        leaderMetadataWrapper - - The leader Metadata of this message in the source topic: -1: VeniceWriter is sending this message in a Samza app to the real-time topic; or it's sending the message in VPJ plugin to the version topic; >=0: Leader replica consumes a delete message from real-time topic, VeniceWriter in leader is sending this message to version topic with extra info: offset in the real-time topic.
        logicalTs - - An timestamp field to indicate when this record was produced from apps point of view.
        Returns:
        a java.util.concurrent.Future Future for the RecordMetadata that will be assigned to this record. Invoking java.util.concurrent.Future's get() on this future will block until the associated request completes and then return the metadata for the record or throw any exception that occurred while sending the record.
      • delete

        public java.util.concurrent.Future<PubSubProduceResult> delete​(K key,
                                                                       PubSubProducerCallback callback,
                                                                       LeaderMetadataWrapper leaderMetadataWrapper,
                                                                       DeleteMetadata deleteMetadata)
        Execute a standard "delete" on the key.
        Parameters:
        key - - The key to delete in storage.
        callback - - callback will be executed after Kafka producer completes on sending the message.
        leaderMetadataWrapper - - The leader Metadata of this message in the source topic: -1: VeniceWriter is sending this message in a Samza app to the real-time topic; or it's sending the message in VPJ plugin to the version topic; >=0: Leader replica consumes a delete message from real-time topic, VeniceWriter in leader is sending this message to version topic with extra info: offset in the real-time topic.
        deleteMetadata - - a DeleteMetadata containing replication metadata related fields.
        Returns:
        a java.util.concurrent.Future Future for the RecordMetadata that will be assigned to this record. Invoking java.util.concurrent.Future's get() on this future will block until the associated request completes and then return the metadata for the record or throw any exception that occurred while sending the record.
      • delete

        public java.util.concurrent.Future<PubSubProduceResult> delete​(K key,
                                                                       PubSubProducerCallback callback,
                                                                       LeaderMetadataWrapper leaderMetadataWrapper,
                                                                       long logicalTs,
                                                                       DeleteMetadata deleteMetadata,
                                                                       ChunkedValueManifest oldValueManifest,
                                                                       ChunkedValueManifest oldRmdManifest)
        Execute a standard "delete" on the key.
        Parameters:
        key - - The key to delete in storage.
        callback - - Callback function invoked by Kafka producer after sending the message.
        leaderMetadataWrapper - - The leader Metadata of this message in the source topic: -1: VeniceWriter is sending this message in a Samza app to the real-time topic; or it's sending the message in VPJ plugin to the version topic; >=0: Leader replica consumes a DELETE message from real-time topic, VeniceWriter in leader is sending this message to version topic with extra info: offset in the real-time topic.
        logicalTs - - An timestamp field to indicate when this record was produced from apps point of view.
        deleteMetadata - - a DeleteMetadata containing replication metadata related fields (can be null).
        Returns:
        a java.util.concurrent.Future. Future for the RecordMetadata that will be assigned to this record. Invoking java.util.concurrent.Future's get() on this future will block until the associated request completes and then return the metadata for the record or throw any exception that occurred while sending the record.
      • put

        public java.util.concurrent.CompletableFuture<PubSubProduceResult> put​(K key,
                                                                               V value,
                                                                               int valueSchemaId,
                                                                               PubSubProducerCallback callback)
        Execute a standard "put" on the key.
        Specified by:
        put in class AbstractVeniceWriter<K,​V,​U>
        Parameters:
        key - - The key to put in storage.
        value - - The value to be associated with the given key
        valueSchemaId - - value schema id for the given value
        callback - - Callback function invoked by Kafka producer after sending the message
        Returns:
        a java.util.concurrent.Future. Future for the RecordMetadata that will be assigned to this record. Invoking java.util.concurrent.Future's get() on this future will block until the associated request completes and then return the metadata for the record or throw any exception that occurred while sending the record.
      • put

        public java.util.concurrent.Future<PubSubProduceResult> put​(K key,
                                                                    V value,
                                                                    int valueSchemaId,
                                                                    long logicalTs,
                                                                    PubSubProducerCallback callback)
        Execute a standard "put" on the key.
        Parameters:
        key - - The key to put in storage.
        value - - The value to be associated with the given key
        valueSchemaId - - value schema id for the given value
        logicalTs - - A timestamp field to indicate when this record was produced from apps view.
        callback - - Callback function invoked by Kafka producer after sending the message
        Returns:
        a java.util.concurrent.Future Future for the RecordMetadata that will be assigned to this record. Invoking java.util.concurrent.Future's get() on this future will block until the associated request completes and then return the metadata for the record or throw any exception that occurred while sending the record.
      • put

        public java.util.concurrent.Future<PubSubProduceResult> put​(K key,
                                                                    V value,
                                                                    int valueSchemaId,
                                                                    PubSubProducerCallback callback,
                                                                    LeaderMetadataWrapper leaderMetadataWrapper)
        VeniceWriter in the leader replica should call this API to fulfill extra metadata information --- upstreamOffset. UpstreamOffset is the offset of PUT message in the source topic: -1: VeniceWriter is sending this message in a Samza app to the real-time topic; or it's sending the message in VPJ plugin to the version topic; >=0: Leader replica consumes a put message from real-time topic, VeniceWriter in leader is sending this message to version topic with extra info: offset in the real-time topic.
      • put

        public java.util.concurrent.CompletableFuture<PubSubProduceResult> put​(K key,
                                                                               V value,
                                                                               int valueSchemaId,
                                                                               PubSubProducerCallback callback,
                                                                               LeaderMetadataWrapper leaderMetadataWrapper,
                                                                               long logicalTs,
                                                                               PutMetadata putMetadata,
                                                                               ChunkedValueManifest oldValueManifest,
                                                                               ChunkedValueManifest oldRmdManifest)
        Execute a standard "put" on the key. VeniceReducer and VeniceSystemProducer should call this API.
        Parameters:
        key - - The key to put in storage.
        value - - The value to be associated with the given key
        valueSchemaId - - value schema id for the given value
        callback - - Callback function invoked by Kafka producer after sending the message
        leaderMetadataWrapper - - The leader Metadata of this message in the source topic: -1: VeniceWriter is sending this message in a Samza app to the real-time topic; or it's sending the message in VPJ plugin to the version topic; >=0: Leader replica consumes a put message from real-time topic, VeniceWriter in leader is sending this message to version topic with extra info: offset in the real-time topic.
        logicalTs - - An timestamp field to indicate when this record was produced from apps view.
        putMetadata - - a PutMetadata containing replication metadata related fields (can be null).
        Returns:
        a java.util.concurrent.Future Future for the RecordMetadata that will be assigned to this record. Invoking java.util.concurrent.Future's get() on this future will block until the associated request completes and then return the metadata for the record or throw any exception that occurred while sending the record.
      • put

        @Deprecated
        public java.util.concurrent.Future<PubSubProduceResult> put​(KafkaKey kafkaKey,
                                                                    KafkaMessageEnvelope kafkaMessageEnvelope,
                                                                    PubSubProducerCallback callback,
                                                                    int upstreamPartition,
                                                                    LeaderMetadataWrapper leaderMetadataWrapper)
        Deprecated.
        Write a message with the kafka message envelope (KME) passed in. This allows users re-using existing KME to speed up the performance. If this is called, VeniceWriter will also reuse the existing DIV data (producer metadata). It's the "pass-through" mode. TODO: move pass-through supports into a server-specific extension of VeniceWriter
      • broadcastStartOfPush

        public void broadcastStartOfPush​(java.util.Map<java.lang.String,​java.lang.String> debugInfo)
        Parameters:
        debugInfo - arbitrary key/value pairs of information that will be propagated alongside the control message.
      • broadcastStartOfPush

        public void broadcastStartOfPush​(boolean sorted,
                                         java.util.Map<java.lang.String,​java.lang.String> debugInfo)
      • broadcastStartOfPush

        public void broadcastStartOfPush​(boolean sorted,
                                         boolean chunked,
                                         CompressionStrategy compressionStrategy,
                                         java.util.Map<java.lang.String,​java.lang.String> debugInfo)
        Parameters:
        sorted - whether the messages between 'StartOfPush' control messages and 'EndOfPush' control message in current topic partition is lexicographically sorted by key bytes
        chunked - whether the push has chunking support enabled, in which case all keys are to be appended with ChunkedKeySuffix and the Put may contain either chunks or ChunkedValueManifest records, in addition to regular (small) values.
        compressionStrategy - the store-version's CompressionStrategy
        debugInfo - arbitrary key/value pairs of information that will be propagated alongside the control message.
      • broadcastStartOfPush

        public void broadcastStartOfPush​(boolean sorted,
                                         boolean chunked,
                                         CompressionStrategy compressionStrategy,
                                         java.util.Optional<java.nio.ByteBuffer> optionalCompressionDictionary,
                                         java.util.Map<java.lang.String,​java.lang.String> debugInfo)
        Parameters:
        sorted - whether the messages between 'StartOfPush' control messages and 'EndOfPush' control message in current topic partition is lexicographically sorted by key bytes
        chunked - whether the push has chunking support enabled, in which case all keys are to be appended with ChunkedKeySuffix and the Put may contain either chunks or ChunkedValueManifest records, in addition to regular (small) values.
        compressionStrategy - the store-version's CompressionStrategy
        optionalCompressionDictionary - The raw bytes of dictionary used to compress/decompress records.
        debugInfo - arbitrary key/value pairs of information that will be propagated alongside the control message.
      • broadcastEndOfPush

        public void broadcastEndOfPush​(java.util.Map<java.lang.String,​java.lang.String> debugInfo)
        This function might need synchronized locking. It might be possible that segments are ended while another thread is broadcasting EOP. However, we could not trigger this scenario using tests. This issue could surface when we support fully auto stream reprocessing in future. Users would call broadcastEndOfPush inside their Samza processors which can have multiple threads. Here is an example without synchronization: - Thread A: broadcastControlMessage execution completes. - Thread B: is in the middle of executing broadcastControlMessage - Thread A: begins endAllSegments - Segments that Thread B was writing to have now been ended. Thus causing the consumer to see messages not inside segments.
        Parameters:
        debugInfo - arbitrary key/value pairs of information that will be propagated alongside the control message.
      • broadcastTopicSwitch

        public void broadcastTopicSwitch​(@Nonnull
                                         java.util.List<java.lang.CharSequence> sourceKafkaCluster,
                                         @Nonnull
                                         java.lang.String sourceTopicName,
                                         @Nonnull
                                         java.lang.Long rewindStartTimestamp,
                                         java.util.Map<java.lang.String,​java.lang.String> debugInfo)
      • broadcastVersionSwap

        public void broadcastVersionSwap​(@Nonnull
                                         java.lang.String oldServingVersionTopic,
                                         @Nonnull
                                         java.lang.String newServingVersionTopic,
                                         java.util.Map<java.lang.String,​java.lang.String> debugInfo)
        Broadcast control message to real-time topic partition, to be consumed by venice leader. Partition high watermarks are left to local venice leader to prepare and then been produced to version topic partition.
        Parameters:
        oldServingVersionTopic - the version topic change capture consumer should switch from.
        newServingVersionTopic - the version topic change capture consumer should switch to.
        debugInfo - arbitrary key/value pairs of information that will be propagated alongside the control message.
      • broadcastStartOfIncrementalPush

        public void broadcastStartOfIncrementalPush​(java.lang.String version,
                                                    java.util.Map<java.lang.String,​java.lang.String> debugInfo)
      • broadcastEndOfIncrementalPush

        public void broadcastEndOfIncrementalPush​(java.lang.String version,
                                                  java.util.Map<java.lang.String,​java.lang.String> debugInfo)
      • closePartition

        public void closePartition​(int partition)
        Close a single partition from this writer. It will send a final EOS to the partition and remove it from segment map.
        Parameters:
        partition - The partition to be closed.
      • sendStartOfSegment

        public void sendStartOfSegment​(int partition,
                                       java.util.Map<java.lang.String,​java.lang.String> debugInfo)
        Send a ControlMessageType.START_OF_SEGMENT control message into the designated partition.
        Parameters:
        partition - the Kafka partition to write to.
        debugInfo - arbitrary key/value pairs of information that will be propagated alongside the control message.
      • sendControlMessage

        public void sendControlMessage​(ControlMessage controlMessage,
                                       int partition,
                                       java.util.Map<java.lang.String,​java.lang.String> debugInfo,
                                       PubSubProducerCallback callback,
                                       LeaderMetadataWrapper leaderMetadataWrapper)
        This function sends a control message into the prescribed partition. If the Kafka topic does not exist, this function will back off for sleepTimeMsWhenTopicMissing ms and try again for a total of maxAttemptsWhenTopicMissing attempts. Note that this back off and retry behavior does not happen in sendMessage(KeyProvider, MessageType, Object, int, PubSubProducerCallback, LeaderMetadataWrapper, long) because that function returns a Future, and it is Future.get() which throws the relevant exception. In any case, the topic should be seeded with a ControlMessageType.START_OF_SEGMENT at first, and therefore, there should be no cases where a topic has not been created yet and we attempt to write a data message first, prior to a control message. If a topic did disappear later on in the VeniceWriter's lifecycle, then it would be appropriate to let that Future fail. This function is synchronized because if the retries need to be exercised, then it would cause a DIV failure if another message slipped in after the first attempt and before the eventually successful attempt.
        Parameters:
        controlMessage - a ControlMessage instance to persist into Kafka.
        partition - the Kafka partition to write to.
        debugInfo - arbitrary key/value pairs of information that will be propagated alongside the control message.
        callback - callback to execute when the record has been acknowledged by the Kafka server (null means no callback)
      • asyncSendControlMessage

        public java.util.concurrent.Future<PubSubProduceResult> asyncSendControlMessage​(ControlMessage controlMessage,
                                                                                        int partition,
                                                                                        java.util.Map<java.lang.String,​java.lang.String> debugInfo,
                                                                                        PubSubProducerCallback callback,
                                                                                        LeaderMetadataWrapper leaderMetadataWrapper)
        This API should be only used in Leader/Standby model for store ingestion. Producer DIV will be recalculated (not DIV pass-through mode); checksum for the input partition in this producer will also be updated.
      • getKafkaMessageEnvelope

        protected KafkaMessageEnvelope getKafkaMessageEnvelope​(MessageType messageType,
                                                               boolean isEndOfSegment,
                                                               int partition,
                                                               boolean incrementSequenceNumber,
                                                               LeaderMetadataWrapper leaderMetadataWrapper,
                                                               long logicalTs)
        A utility function to centralize some boiler plate code for the instantiation of SpecificRecord classes holding the content of our Kafka values. Note: the payloadUnion must be set on the return object before producing into Kafka.
        Parameters:
        messageType - an instance of the MessageType enum.
        Returns:
        A KafkaMessageEnvelope for producing into Kafka
      • endSegment

        public void endSegment​(int partition,
                               boolean finalSegment)
        Parameters:
        partition - in which to end the current segment
      • getTime

        public Time getTime()
      • getMaxSizeForUserPayloadPerMessageInBytes

        public int getMaxSizeForUserPayloadPerMessageInBytes()
      • getDestination

        public java.lang.String getDestination()
        Returns:
        Returns a string of format: topicName@brokerAddress