You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@kafka.apache.org by gw...@apache.org on 2020/10/09 00:06:10 UTC

[kafka] branch trunk updated: MINOR update comments and docs to be gender-neutral

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

gwenshap 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 7947c18  MINOR update comments and docs to be gender-neutral
7947c18 is described below

commit 7947c18b5788fd12841de649a662336f7d3d14d8
Author: Xavier Léauté <xv...@apache.org>
AuthorDate: Thu Oct 8 17:05:15 2020 -0700

    MINOR update comments and docs to be gender-neutral
    
    While this is not technically part of KIP-629, I believe this makes our codebase more inclusive as well.
    
    cc gwenshap
    
    Author: Xavier Léauté <xv...@apache.org>
    
    Reviewers: Gwen Shapira
    
    Closes #9398 from xvrl/neutral-term
---
 core/src/main/scala/kafka/server/KafkaConfig.scala           |  2 +-
 core/src/test/scala/unit/kafka/utils/TestUtils.scala         |  2 +-
 .../org/apache/kafka/streams/scala/kstream/KStream.scala     | 12 ++++++------
 3 files changed, 8 insertions(+), 8 deletions(-)

diff --git a/core/src/main/scala/kafka/server/KafkaConfig.scala b/core/src/main/scala/kafka/server/KafkaConfig.scala
index 9b65355..a580570 100755
--- a/core/src/main/scala/kafka/server/KafkaConfig.scala
+++ b/core/src/main/scala/kafka/server/KafkaConfig.scala
@@ -1695,7 +1695,7 @@ class KafkaConfig(val props: java.util.Map[_, _], doLog: Boolean, dynamicConfigO
   }
 
   // If the user defined advertised listeners, we use those
-  // If he didn't but did define advertised host or port, we'll use those and fill in the missing value from regular host / port or defaults
+  // If they didn't but did define advertised host or port, we'll use those and fill in the missing value from regular host / port or defaults
   // If none of these are defined, we'll use the listeners
   def advertisedListeners: Seq[EndPoint] = {
     val advertisedListenersProp = getString(KafkaConfig.AdvertisedListenersProp)
diff --git a/core/src/test/scala/unit/kafka/utils/TestUtils.scala b/core/src/test/scala/unit/kafka/utils/TestUtils.scala
index c13f033..eb4f80e 100755
--- a/core/src/test/scala/unit/kafka/utils/TestUtils.scala
+++ b/core/src/test/scala/unit/kafka/utils/TestUtils.scala
@@ -536,7 +536,7 @@ object TestUtils extends Logging {
             return true
           cur = null
         }
-        // should never reach her
+        // should never reach here
         throw new RuntimeException("should not reach here")
       }
 
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 5fc77d5..1641bdb 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
@@ -208,7 +208,7 @@ class KStream[K, V](val inner: KStreamJ[K, V]) {
    * Materialize this stream to a topic and creates a new [[KStream]] from the topic using the `Produced` instance for
    * configuration of the `Serde key serde`, `Serde value serde`, and `StreamPartitioner`
    * <p>
-   * The user can either supply the `Produced` instance as an implicit in scope or she can also provide implicit
+   * The user can either supply the `Produced` instance as an implicit in scope or they can also provide implicit
    * key and value serdes that will be converted to a `Produced` instance implicitly.
    * <p>
    * {{{
@@ -250,7 +250,7 @@ class KStream[K, V](val inner: KStreamJ[K, V]) {
    * "&lt;name&gt;" is either provided via `Repartitioned#as(String)` or an internally
    * generated name, and "-repartition" is a fixed suffix.
    * <p>
-   * The user can either supply the `Repartitioned` instance as an implicit in scope or she can also provide implicit
+   * The user can either supply the `Repartitioned` instance as an implicit in scope or they can also provide implicit
    * key and value serdes that will be converted to a `Repartitioned` instance implicitly.
    * <p>
    * {{{
@@ -283,7 +283,7 @@ class KStream[K, V](val inner: KStreamJ[K, V]) {
    * Materialize this stream to a topic using the `Produced` instance for
    * configuration of the `Serde key serde`, `Serde value serde`, and `StreamPartitioner`
    * <p>
-   * The user can either supply the `Produced` instance as an implicit in scope or she can also provide implicit
+   * The user can either supply the `Produced` instance as an implicit in scope or they can also provide implicit
    * key and value serdes that will be converted to a `Produced` instance implicitly.
    * <p>
    * {{{
@@ -315,7 +315,7 @@ class KStream[K, V](val inner: KStreamJ[K, V]) {
    * configuration of the `Serde key serde`, `Serde value serde`, and `StreamPartitioner`.
    * The topic names for each record to send to is dynamically determined based on the given mapper.
    * <p>
-   * The user can either supply the `Produced` instance as an implicit in scope or she can also provide implicit
+   * The user can either supply the `Produced` instance as an implicit in scope or they can also provide implicit
    * key and value serdes that will be converted to a `Produced` instance implicitly.
    * <p>
    * {{{
@@ -494,7 +494,7 @@ class KStream[K, V](val inner: KStreamJ[K, V]) {
   /**
    * Group the records by their current key into a [[KGroupedStream]]
    * <p>
-   * The user can either supply the `Grouped` instance as an implicit in scope or she can also provide an implicit
+   * The user can either supply the `Grouped` instance as an implicit in scope or they can also provide an implicit
    * serdes that will be converted to a `Grouped` instance implicitly.
    * <p>
    * {{{
@@ -528,7 +528,7 @@ class KStream[K, V](val inner: KStreamJ[K, V]) {
    * Group the records of this [[KStream]] on a new key that is selected using the provided key transformation function
    * and the `Grouped` instance.
    * <p>
-   * The user can either supply the `Grouped` instance as an implicit in scope or she can also provide an implicit
+   * The user can either supply the `Grouped` instance as an implicit in scope or they can also provide an implicit
    * serdes that will be converted to a `Grouped` instance implicitly.
    * <p>
    * {{{