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 2018/06/09 23:12:19 UTC

[kafka] branch 2.0 updated: MINOR: Remove APIs deprecated in 0.11.0 for core and clients (#5158)

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

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


The following commit(s) were added to refs/heads/2.0 by this push:
     new 991f9d2  MINOR: Remove APIs deprecated in 0.11.0 for core and clients (#5158)
991f9d2 is described below

commit 991f9d253e266584db6989937cbcf93c79deb137
Author: Ismael Juma <is...@juma.me.uk>
AuthorDate: Sat Jun 9 16:10:31 2018 -0700

    MINOR: Remove APIs deprecated in 0.11.0 for core and clients (#5158)
    
    Not included: old consumers and checksum methods
    
    Reviewers: Dong Lin <li...@gmail.com>
---
 .../kafka/clients/producer/RecordMetadata.java     | 10 -----
 .../GroupCoordinatorNotAvailableException.java     | 47 ----------------------
 .../errors/GroupLoadInProgressException.java       | 46 ---------------------
 .../errors/NotCoordinatorForGroupException.java    | 46 ---------------------
 .../scala/kafka/common/KafkaStorageException.scala | 27 -------------
 core/src/main/scala/kafka/utils/ZkUtils.scala      |  6 ---
 6 files changed, 182 deletions(-)

diff --git a/clients/src/main/java/org/apache/kafka/clients/producer/RecordMetadata.java b/clients/src/main/java/org/apache/kafka/clients/producer/RecordMetadata.java
index 0924244..1ae5cf6 100644
--- a/clients/src/main/java/org/apache/kafka/clients/producer/RecordMetadata.java
+++ b/clients/src/main/java/org/apache/kafka/clients/producer/RecordMetadata.java
@@ -57,16 +57,6 @@ public final class RecordMetadata {
     }
 
     /**
-     * @deprecated As of 0.11.0. Use @{@link RecordMetadata#RecordMetadata(TopicPartition, long, long, long, Long, int, int)}.
-     */
-    @Deprecated
-    public RecordMetadata(TopicPartition topicPartition, long baseOffset, long relativeOffset, long timestamp,
-                          long checksum, int serializedKeySize, int serializedValueSize) {
-        this(topicPartition, baseOffset, relativeOffset, timestamp, Long.valueOf(checksum), serializedKeySize,
-                serializedValueSize);
-    }
-
-    /**
      * Indicates whether the record metadata includes the offset.
      * @return true if the offset is included in the metadata, false otherwise.
      */
diff --git a/clients/src/main/java/org/apache/kafka/common/errors/GroupCoordinatorNotAvailableException.java b/clients/src/main/java/org/apache/kafka/common/errors/GroupCoordinatorNotAvailableException.java
deleted file mode 100644
index 03a7719..0000000
--- a/clients/src/main/java/org/apache/kafka/common/errors/GroupCoordinatorNotAvailableException.java
+++ /dev/null
@@ -1,47 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements. See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License. You may obtain a copy of the License at
- *
- *    http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-package org.apache.kafka.common.errors;
-
-/**
- * The broker returns this error code for consumer metadata requests or offset commit requests if the offsets topic has
- * not yet been created.
- *
- * @deprecated As of Kafka 0.11, this has been replaced by {@link CoordinatorNotAvailableException}
- */
-@Deprecated
-public class GroupCoordinatorNotAvailableException extends RetriableException {
-    public static final GroupCoordinatorNotAvailableException INSTANCE = new GroupCoordinatorNotAvailableException();
-
-    private static final long serialVersionUID = 1L;
-
-    public GroupCoordinatorNotAvailableException() {
-        super();
-    }
-
-    public GroupCoordinatorNotAvailableException(String message) {
-        super(message);
-    }
-
-    public GroupCoordinatorNotAvailableException(String message, Throwable cause) {
-        super(message, cause);
-    }
-
-    public GroupCoordinatorNotAvailableException(Throwable cause) {
-        super(cause);
-    }
-
-}
diff --git a/clients/src/main/java/org/apache/kafka/common/errors/GroupLoadInProgressException.java b/clients/src/main/java/org/apache/kafka/common/errors/GroupLoadInProgressException.java
deleted file mode 100644
index 73daa5f..0000000
--- a/clients/src/main/java/org/apache/kafka/common/errors/GroupLoadInProgressException.java
+++ /dev/null
@@ -1,46 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements. See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License. You may obtain a copy of the License at
- *
- *    http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-package org.apache.kafka.common.errors;
-
-/**
- * The broker returns this error code for any coordinator request if it is still loading the metadata (after a leader change
- * for that offsets topic partition) for this group.
- *
- * @deprecated As of Kafka 0.11, this has been replaced by {@link CoordinatorLoadInProgressException}
- */
-@Deprecated
-public class GroupLoadInProgressException extends RetriableException {
-
-    private static final long serialVersionUID = 1L;
-
-    public GroupLoadInProgressException() {
-        super();
-    }
-
-    public GroupLoadInProgressException(String message) {
-        super(message);
-    }
-
-    public GroupLoadInProgressException(String message, Throwable cause) {
-        super(message, cause);
-    }
-
-    public GroupLoadInProgressException(Throwable cause) {
-        super(cause);
-    }
-
-}
diff --git a/clients/src/main/java/org/apache/kafka/common/errors/NotCoordinatorForGroupException.java b/clients/src/main/java/org/apache/kafka/common/errors/NotCoordinatorForGroupException.java
deleted file mode 100644
index cee6495..0000000
--- a/clients/src/main/java/org/apache/kafka/common/errors/NotCoordinatorForGroupException.java
+++ /dev/null
@@ -1,46 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements. See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License. You may obtain a copy of the License at
- *
- *    http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-package org.apache.kafka.common.errors;
-
-/**
- * The broker returns this error code if it receives an offset fetch or commit request for a consumer group that it is
- * not a coordinator for.
- *
- * @deprecated As of Kafka 0.11, this has been replaced by {@link NotCoordinatorException}
- */
-@Deprecated
-public class NotCoordinatorForGroupException extends RetriableException {
-
-    private static final long serialVersionUID = 1L;
-
-    public NotCoordinatorForGroupException() {
-        super();
-    }
-
-    public NotCoordinatorForGroupException(String message) {
-        super(message);
-    }
-
-    public NotCoordinatorForGroupException(String message, Throwable cause) {
-        super(message, cause);
-    }
-
-    public NotCoordinatorForGroupException(Throwable cause) {
-        super(cause);
-    }
-
-}
diff --git a/core/src/main/scala/kafka/common/KafkaStorageException.scala b/core/src/main/scala/kafka/common/KafkaStorageException.scala
deleted file mode 100644
index e0ecff3..0000000
--- a/core/src/main/scala/kafka/common/KafkaStorageException.scala
+++ /dev/null
@@ -1,27 +0,0 @@
-/**
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
- *
- *    http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
-*/
-package kafka.common
-
-/**
- * Kafka exception caused by disk-related IOException
- * This class is deprecated and will be replaced by org.apache.kafka.common.errors.KafkaStorageException
- */
-@Deprecated
-class KafkaStorageException(message: String, t: Throwable) extends RuntimeException(message, t) {
-  def this(message: String) = this(message, null)
-  def this(t: Throwable) = this("", t)
-}
diff --git a/core/src/main/scala/kafka/utils/ZkUtils.scala b/core/src/main/scala/kafka/utils/ZkUtils.scala
index 0179937..8f093fd 100644
--- a/core/src/main/scala/kafka/utils/ZkUtils.scala
+++ b/core/src/main/scala/kafka/utils/ZkUtils.scala
@@ -96,9 +96,6 @@ object ZkUtils {
     (zkClient, zkConnection)
   }
 
-  @deprecated("This is deprecated, use defaultAcls(isSecure, path) which doesn't make sensitive data world readable", since = "0.10.2.1")
-  def DefaultAcls(isSecure: Boolean): java.util.List[ACL] = defaultAcls(isSecure, "")
-
   def sensitivePath(path: String): Boolean = ZkData.sensitivePath(path)
 
   def defaultAcls(isSecure: Boolean, path: String): java.util.List[ACL] = ZkData.defaultAcls(isSecure, path).asJava
@@ -201,9 +198,6 @@ class ZkUtils(val zkClient: ZkClient,
   // Visible for testing
   val zkPath = new ZkPath(zkClient)
 
-  @deprecated("This is deprecated, use defaultAcls(path) which doesn't make sensitive data world readable", since = "0.10.2.1")
-  val DefaultAcls: java.util.List[ACL] = ZkUtils.defaultAcls(isSecure, "")
-
   def defaultAcls(path: String): java.util.List[ACL] = ZkUtils.defaultAcls(isSecure, path)
 
   def getController(): Int = {

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