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

[kafka] branch 3.3 updated: MINOR; Remove redundant version system test (#12612)

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

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


The following commit(s) were added to refs/heads/3.3 by this push:
     new c5499a6300 MINOR; Remove redundant version system test (#12612)
c5499a6300 is described below

commit c5499a630006cedca6e9032540dab73d3ab0b859
Author: Jason Gustafson <ja...@confluent.io>
AuthorDate: Thu Sep 8 18:13:59 2022 -0700

    MINOR; Remove redundant version system test (#12612)
    
    This patch removes test_kafka_version.py, which contains two tests at the moment. The first test verifies we can start a 0.8.2 cluster. The second verifies we can start a cluster with one node on 0.8.2 and another on the latest. These test are covered in greater depth by upgrade_test.py and downgrade_test.py.
    
    Reviewers: José Armando García Sancio <js...@users.noreply.github.com>
---
 .../kafkatest/sanity_checks/test_kafka_version.py  | 62 ----------------------
 1 file changed, 62 deletions(-)

diff --git a/tests/kafkatest/sanity_checks/test_kafka_version.py b/tests/kafkatest/sanity_checks/test_kafka_version.py
deleted file mode 100644
index 0265ecdbdb..0000000000
--- a/tests/kafkatest/sanity_checks/test_kafka_version.py
+++ /dev/null
@@ -1,62 +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.
-
-from ducktape.tests.test import Test
-from ducktape.mark.resource import cluster
-
-from kafkatest.services.kafka import KafkaService, config_property
-from kafkatest.services.zookeeper import ZookeeperService
-from kafkatest.utils import is_version
-from kafkatest.version import LATEST_0_8_2, DEV_BRANCH
-
-
-class KafkaVersionTest(Test):
-    """Sanity checks on kafka versioning."""
-    def __init__(self, test_context):
-        super(KafkaVersionTest, self).__init__(test_context)
-
-        self.topic = "topic"
-        self.zk = ZookeeperService(test_context, num_nodes=1)
-
-    def setUp(self):
-        self.zk.start()
-
-    @cluster(num_nodes=2)
-    def test_0_8_2(self):
-        """Test kafka service node-versioning api - verify that we can bring up a single-node 0.8.2.X cluster."""
-        self.kafka = KafkaService(self.test_context, num_nodes=1, zk=self.zk,
-                                  topics={self.topic: {"partitions": 1, "replication-factor": 1}})
-        node = self.kafka.nodes[0]
-        node.version = LATEST_0_8_2
-        self.kafka.start()
-
-        assert is_version(node, [LATEST_0_8_2], logger=self.logger)
-
-    @cluster(num_nodes=3)
-    def test_multi_version(self):
-        """Test kafka service node-versioning api - ensure we can bring up a 2-node cluster, one on version 0.8.2.X,
-        the other on the current development branch."""
-        self.kafka = KafkaService(self.test_context, num_nodes=2, zk=self.zk,
-                                  topics={self.topic: {"partitions": 1, "replication-factor": 2}})
-        # Be sure to make node[0] the one with v0.8.2 because the topic will be created using the --zookeeper option
-        # since not all nodes support the --bootstrap-server option; the --zookeeper option is removed as of v3.0,
-        # and the topic will be created against the broker on node[0], so that node has to be the one running the older
-        # version (otherwise the kafka-topics --zookeeper command will fail).
-        self.kafka.nodes[0].version = LATEST_0_8_2
-        self.kafka.nodes[0].config[config_property.INTER_BROKER_PROTOCOL_VERSION] = "0.8.2.X"
-        self.kafka.start()
-
-        assert is_version(self.kafka.nodes[0], [LATEST_0_8_2], logger=self.logger)
-        assert is_version(self.kafka.nodes[1], [DEV_BRANCH.vstring], logger=self.logger)