You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@kafka.apache.org by ij...@apache.org on 2016/07/09 01:09:23 UTC

kafka git commit: MINOR: Typo fix in comments

Repository: kafka
Updated Branches:
  refs/heads/trunk c2459d325 -> a5da2a4f4


MINOR: Typo fix in comments

Author: Nafer Sanabria <na...@gmail.com>

Reviewers: Grant Henke <gr...@gmail.com>, Ismael Juma <is...@juma.me.uk>

Closes #1595 from naferx/minor-typo


Project: http://git-wip-us.apache.org/repos/asf/kafka/repo
Commit: http://git-wip-us.apache.org/repos/asf/kafka/commit/a5da2a4f
Tree: http://git-wip-us.apache.org/repos/asf/kafka/tree/a5da2a4f
Diff: http://git-wip-us.apache.org/repos/asf/kafka/diff/a5da2a4f

Branch: refs/heads/trunk
Commit: a5da2a4f4c3b9d1917cbafc0e79d8e8318f7cbff
Parents: c2459d3
Author: Nafer Sanabria <na...@gmail.com>
Authored: Sat Jul 9 02:09:14 2016 +0100
Committer: Ismael Juma <is...@juma.me.uk>
Committed: Sat Jul 9 02:09:14 2016 +0100

----------------------------------------------------------------------
 core/src/main/scala/kafka/network/SocketServer.scala             | 2 +-
 .../test/scala/integration/kafka/api/ConsumerBounceTest.scala    | 2 +-
 .../src/main/java/org/apache/kafka/streams/kstream/KStream.java  | 4 ++--
 3 files changed, 4 insertions(+), 4 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/kafka/blob/a5da2a4f/core/src/main/scala/kafka/network/SocketServer.scala
----------------------------------------------------------------------
diff --git a/core/src/main/scala/kafka/network/SocketServer.scala b/core/src/main/scala/kafka/network/SocketServer.scala
index f00dd7b..1ab8149 100644
--- a/core/src/main/scala/kafka/network/SocketServer.scala
+++ b/core/src/main/scala/kafka/network/SocketServer.scala
@@ -279,7 +279,7 @@ private[kafka] class Acceptor(val endPoint: EndPoint,
         }
         catch {
           // We catch all the throwables to prevent the acceptor thread from exiting on exceptions due
-          // to a select operation on a specific channel or a bad request. We don't want the
+          // to a select operation on a specific channel or a bad request. We don't want
           // the broker to stop responding to requests from other clients in these scenarios.
           case e: ControlThrowable => throw e
           case e: Throwable => error("Error occurred", e)

http://git-wip-us.apache.org/repos/asf/kafka/blob/a5da2a4f/core/src/test/scala/integration/kafka/api/ConsumerBounceTest.scala
----------------------------------------------------------------------
diff --git a/core/src/test/scala/integration/kafka/api/ConsumerBounceTest.scala b/core/src/test/scala/integration/kafka/api/ConsumerBounceTest.scala
index c76a216..7064052 100644
--- a/core/src/test/scala/integration/kafka/api/ConsumerBounceTest.scala
+++ b/core/src/test/scala/integration/kafka/api/ConsumerBounceTest.scala
@@ -83,7 +83,7 @@ class ConsumerBounceTest extends IntegrationTestHarness with Logging {
 
     consumer.subscribe(List(topic), new ConsumerRebalanceListener {
       override def onPartitionsAssigned(partitions: util.Collection[TopicPartition]) {
-        // TODO: until KAFKA-2017 is merged, we have to handle the case in which the
+        // TODO: until KAFKA-2017 is merged, we have to handle the case in which
         // the commit fails on prior to rebalancing on coordinator fail-over.
         consumer.seek(tp, consumed)
       }

http://git-wip-us.apache.org/repos/asf/kafka/blob/a5da2a4f/streams/src/main/java/org/apache/kafka/streams/kstream/KStream.java
----------------------------------------------------------------------
diff --git a/streams/src/main/java/org/apache/kafka/streams/kstream/KStream.java b/streams/src/main/java/org/apache/kafka/streams/kstream/KStream.java
index 8133aa7..f526889 100644
--- a/streams/src/main/java/org/apache/kafka/streams/kstream/KStream.java
+++ b/streams/src/main/java/org/apache/kafka/streams/kstream/KStream.java
@@ -547,7 +547,7 @@ public interface KStream<K, V> {
      * @param selector      select the grouping key and value to be aggregated
      * @param <K1>          the key type of the {@link KGroupedStream}
      *
-     * @return a {@link KGroupedStream} that contains the the grouped records of the original {@link KStream}
+     * @return a {@link KGroupedStream} that contains the grouped records of the original {@link KStream}
      */
     <K1> KGroupedStream<K1, V> groupBy(KeyValueMapper<K, V, K1> selector);
 
@@ -562,7 +562,7 @@ public interface KStream<K, V> {
      *                      if not specified the default serdes defined in the configs will be used
      * @param <K1>          the key type of the {@link KGroupedStream}
      *
-     * @return a {@link KGroupedStream} that contains the the grouped records of the original {@link KStream}
+     * @return a {@link KGroupedStream} that contains the grouped records of the original {@link KStream}
      */
     <K1> KGroupedStream<K1, V> groupBy(KeyValueMapper<K, V, K1> selector,
                                             Serde<K1> keySerde,