You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@kafka.apache.org by mj...@apache.org on 2018/05/07 16:27:48 UTC

[kafka] branch trunk updated: KAFKA-6871: KStreams Scala API: incorrect Javadocs and misleading parameter name (#4971)

This is an automated email from the ASF dual-hosted git repository.

mjsax pushed a commit to branch trunk
in repository https://gitbox.apache.org/repos/asf/kafka.git


The following commit(s) were added to refs/heads/trunk by this push:
     new 00d1137  KAFKA-6871: KStreams Scala API: incorrect Javadocs and misleading parameter name (#4971)
00d1137 is described below

commit 00d1137570e3b877253288ad730842551b998d3b
Author: Michael G. Noll <mi...@users.noreply.github.com>
AuthorDate: Mon May 7 18:27:45 2018 +0200

    KAFKA-6871: KStreams Scala API: incorrect Javadocs and misleading parameter name (#4971)
    
    Reviewer: Matthias J. Sax <ma...@confluent.io>, Debasish Ghosh <dg...@acm.org>, Guozhang Wang <gu...@confluent.io>, Bill Bejeck <bi...@confluent.io>
---
 .../org/apache/kafka/streams/scala/kstream/KStream.scala | 16 ++++++++--------
 1 file changed, 8 insertions(+), 8 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 d3ccaec..7634b95 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
@@ -261,30 +261,30 @@ class KStream[K, V](val inner: KStreamJ[K, V]) {
   /**
    * Transform each record of the input stream into zero or more records in the output stream (both key and value type
    * can be altered arbitrarily).
-   * A `Transformer` (provided by the given `TransformerSupplier`) is applied to each input record and
-   * computes zero or more output records. In order to assign a state, the state must be created and registered 
-   * beforehand via stores added via `addStateStore` or `addGlobalStore` before they can be connected to the `Transformer` 
+   * A `Transformer` is applied to each input record and computes zero or more output records. In order to assign a
+   * state, the state must be created and registered beforehand via stores added via `addStateStore` or `addGlobalStore`
+   * before they can be connected to the `Transformer`
    *
-   * @param transformerSupplier a instance of `TransformerSupplier` that generates a `Transformer`
+   * @param transformer the `Transformer` instance
    * @param stateStoreNames     the names of the state stores used by the processor
    * @return a [[KStream]] that contains more or less records with new key and value (possibly of different type)
    * @see `org.apache.kafka.streams.kstream.KStream#transform`
    */ 
-  def transform[K1, V1](transformerSupplier: Transformer[K, V, (K1, V1)],
+  def transform[K1, V1](transformer: Transformer[K, V, (K1, V1)],
     stateStoreNames: String*): KStream[K1, V1] = {
     val transformerSupplierJ: TransformerSupplier[K, V, KeyValue[K1, V1]] = new TransformerSupplier[K, V, KeyValue[K1, V1]] {
       override def get(): Transformer[K, V, KeyValue[K1, V1]] = {
         new Transformer[K, V, KeyValue[K1, V1]] {
           override def transform(key: K, value: V): KeyValue[K1, V1] = {
-            transformerSupplier.transform(key, value) match {
+            transformer.transform(key, value) match {
               case (k1, v1) => KeyValue.pair(k1, v1)
               case _ => null
             }
           }
 
-          override def init(context: ProcessorContext): Unit = transformerSupplier.init(context)
+          override def init(context: ProcessorContext): Unit = transformer.init(context)
 
-          override def close(): Unit = transformerSupplier.close()
+          override def close(): Unit = transformer.close()
         }
       }
     }

-- 
To stop receiving notification emails like this one, please contact
mjsax@apache.org.