From 329d2aed5ae2a8b69ddc4d79c51d9c5c99de46b3 Mon Sep 17 00:00:00 2001 From: Joao Pedro Fonseca Dantas Date: Fri, 15 Nov 2024 18:05:13 -0300 Subject: [PATCH] kstream scala: remove transform values Signed-off-by: Joao Pedro Fonseca Dantas --- .../kafka/streams/scala/kstream/KStream.scala | 88 ------------------- 1 file changed, 88 deletions(-) diff --git a/streams/streams-scala/src/main/scala/org/apache/kafka/streams/scala/kstream/KStream.scala b/streams/streams-scala/src/main/scala/org/apache/kafka/streams/scala/kstream/KStream.scala index 5e6cc4f3f220..80d43fc2315b 100644 --- a/streams/streams-scala/src/main/scala/org/apache/kafka/streams/scala/kstream/KStream.scala +++ b/streams/streams-scala/src/main/scala/org/apache/kafka/streams/scala/kstream/KStream.scala @@ -584,94 +584,6 @@ class KStream[K, V](val inner: KStreamJ[K, V]) { ): KStream[K, VR] = new KStream(inner.flatTransformValues[VR](valueTransformerSupplier.asJava, named, stateStoreNames: _*)) - /** - * Transform the value of each input record into a new value (with possible new type) of the output record. - * A `ValueTransformer` (provided by the given `ValueTransformerSupplier`) is applied to each input - * record value and computes a new value for it. - * In order to assign a state, the state must be created and added via `addStateStore` before they can be connected - * to the `ValueTransformer`. - * It's not required to connect global state stores that are added via `addGlobalStore`; - * read-only access to global state stores is available by default. - * - * @param valueTransformerSupplier a instance of `ValueTransformerSupplier` that generates a `ValueTransformer` - * @param stateStoreNames the names of the state stores used by the processor - * @return a [[KStream]] that contains records with unmodified key and new values (possibly of different type) - * @see `org.apache.kafka.streams.kstream.KStream#transformValues` - */ - @deprecated(since = "3.3", message = "Use processValues(FixedKeyProcessorSupplier, String*) instead.") - def transformValues[VR]( - valueTransformerSupplier: ValueTransformerSupplier[V, VR], - stateStoreNames: String* - ): KStream[K, VR] = - new KStream(inner.transformValues[VR](valueTransformerSupplier, stateStoreNames: _*)) - - /** - * Transform the value of each input record into a new value (with possible new type) of the output record. - * A `ValueTransformer` (provided by the given `ValueTransformerSupplier`) is applied to each input - * record value and computes a new value for it. - * In order to assign a state, the state must be created and added via `addStateStore` before they can be connected - * to the `ValueTransformer`. - * It's not required to connect global state stores that are added via `addGlobalStore`; - * read-only access to global state stores is available by default. - * - * @param valueTransformerSupplier a instance of `ValueTransformerSupplier` that generates a `ValueTransformer` - * @param named a [[Named]] config used to name the processor in the topology - * @param stateStoreNames the names of the state stores used by the processor - * @return a [[KStream]] that contains records with unmodified key and new values (possibly of different type) - * @see `org.apache.kafka.streams.kstream.KStream#transformValues` - */ - @deprecated(since = "3.3", message = "Use processValues(FixedKeyProcessorSupplier, Named, String*) instead.") - def transformValues[VR]( - valueTransformerSupplier: ValueTransformerSupplier[V, VR], - named: Named, - stateStoreNames: String* - ): KStream[K, VR] = - new KStream(inner.transformValues[VR](valueTransformerSupplier, named, stateStoreNames: _*)) - - /** - * Transform the value of each input record into a new value (with possible new type) of the output record. - * A `ValueTransformer` (provided by the given `ValueTransformerSupplier`) is applied to each input - * record value and computes a new value for it. - * In order to assign a state, the state must be created and added via `addStateStore` before they can be connected - * to the `ValueTransformer`. - * It's not required to connect global state stores that are added via `addGlobalStore`; - * read-only access to global state stores is available by default. - * - * @param valueTransformerSupplier a instance of `ValueTransformerWithKeySupplier` that generates a `ValueTransformerWithKey` - * @param stateStoreNames the names of the state stores used by the processor - * @return a [[KStream]] that contains records with unmodified key and new values (possibly of different type) - * @see `org.apache.kafka.streams.kstream.KStream#transformValues` - */ - @deprecated(since = "3.3", message = "Use processValues(FixedKeyProcessorSupplier, String*) instead.") - def transformValues[VR]( - valueTransformerSupplier: ValueTransformerWithKeySupplier[K, V, VR], - stateStoreNames: String* - ): KStream[K, VR] = - new KStream(inner.transformValues[VR](valueTransformerSupplier, stateStoreNames: _*)) - - /** - * Transform the value of each input record into a new value (with possible new type) of the output record. - * A `ValueTransformer` (provided by the given `ValueTransformerSupplier`) is applied to each input - * record value and computes a new value for it. - * In order to assign a state, the state must be created and added via `addStateStore` before they can be connected - * to the `ValueTransformer`. - * It's not required to connect global state stores that are added via `addGlobalStore`; - * read-only access to global state stores is available by default. - * - * @param valueTransformerSupplier a instance of `ValueTransformerWithKeySupplier` that generates a `ValueTransformerWithKey` - * @param named a [[Named]] config used to name the processor in the topology - * @param stateStoreNames the names of the state stores used by the processor - * @return a [[KStream]] that contains records with unmodified key and new values (possibly of different type) - * @see `org.apache.kafka.streams.kstream.KStream#transformValues` - */ - @deprecated(since = "3.3", message = "Use processValues(FixedKeyProcessorSupplier, Named, String*) instead.") - def transformValues[VR]( - valueTransformerSupplier: ValueTransformerWithKeySupplier[K, V, VR], - named: Named, - stateStoreNames: String* - ): KStream[K, VR] = - new KStream(inner.transformValues[VR](valueTransformerSupplier, named, stateStoreNames: _*)) - /** * Process all records in this stream, one record at a time, by applying a `Processor` (provided by the given * `processorSupplier`).