You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@kafka.apache.org by ma...@apache.org on 2022/09/02 08:52:32 UTC

[kafka] 03/06: MINOR: Disable kraft system tests in 2.8 branch

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

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

commit 301a0d3f6434e7f9ec0a20ad0669eea01f936e40
Author: Manikumar Reddy <ma...@gmail.com>
AuthorDate: Thu Sep 1 23:26:03 2022 +0530

    MINOR: Disable kraft system tests in 2.8 branch
---
 tests/kafkatest/sanity_checks/test_bounce.py       |  4 --
 .../sanity_checks/test_console_consumer.py         |  5 +-
 .../sanity_checks/test_verifiable_producer.py      | 74 ----------------------
 tests/kafkatest/services/kafka/quorum.py           |  6 +-
 tests/kafkatest/tests/core/security_test.py        |  2 +-
 5 files changed, 5 insertions(+), 86 deletions(-)

diff --git a/tests/kafkatest/sanity_checks/test_bounce.py b/tests/kafkatest/sanity_checks/test_bounce.py
index c01f23b0cb..c954fba17c 100644
--- a/tests/kafkatest/sanity_checks/test_bounce.py
+++ b/tests/kafkatest/sanity_checks/test_bounce.py
@@ -44,10 +44,6 @@ class TestBounce(Test):
         if self.zk:
             self.zk.start()
 
-    @cluster(num_nodes=6)
-    @parametrize(metadata_quorum=quorum.remote_raft)
-    @cluster(num_nodes=4)
-    @parametrize(metadata_quorum=quorum.colocated_raft)
     @cluster(num_nodes=4)
     @parametrize(metadata_quorum=quorum.zk)
     def test_simple_run(self, metadata_quorum):
diff --git a/tests/kafkatest/sanity_checks/test_console_consumer.py b/tests/kafkatest/sanity_checks/test_console_consumer.py
index 0847ce0cb4..2448b75e03 100644
--- a/tests/kafkatest/sanity_checks/test_console_consumer.py
+++ b/tests/kafkatest/sanity_checks/test_console_consumer.py
@@ -43,12 +43,9 @@ class ConsoleConsumerTest(Test):
         if self.zk:
             self.zk.start()
 
-    @cluster(num_nodes=3)
-    @matrix(security_protocol=['PLAINTEXT', 'SSL'], metadata_quorum=quorum.all_raft)
+
     @cluster(num_nodes=4)
-    @matrix(security_protocol=['SASL_SSL'], sasl_mechanism=['PLAIN'], metadata_quorum=quorum.all_raft)
     @matrix(security_protocol=['SASL_SSL'], sasl_mechanism=['SCRAM-SHA-256', 'SCRAM-SHA-512']) # SCRAM not yet supported with Raft
-    @matrix(security_protocol=['SASL_PLAINTEXT', 'SASL_SSL'], metadata_quorum=quorum.all_raft)
     def test_lifecycle(self, security_protocol, sasl_mechanism='GSSAPI', metadata_quorum=quorum.zk):
         """Check that console consumer starts/stops properly, and that we are capturing log output."""
 
diff --git a/tests/kafkatest/sanity_checks/test_verifiable_producer.py b/tests/kafkatest/sanity_checks/test_verifiable_producer.py
index 7fcb603d59..fb21c08da5 100644
--- a/tests/kafkatest/sanity_checks/test_verifiable_producer.py
+++ b/tests/kafkatest/sanity_checks/test_verifiable_producer.py
@@ -96,77 +96,3 @@ class TestVerifiableProducer(Test):
         num_produced = self.producer.num_acked
         assert num_produced == self.num_messages, "num_produced: %d, num_messages: %d" % (num_produced, self.num_messages)
 
-    @cluster(num_nodes=4)
-    @matrix(inter_broker_security_protocol=['PLAINTEXT', 'SSL'], metadata_quorum=[quorum.remote_raft])
-    @matrix(inter_broker_security_protocol=['SASL_SSL'], inter_broker_sasl_mechanism=['PLAIN', 'GSSAPI'],
-            metadata_quorum=[quorum.remote_raft])
-    def test_multiple_raft_security_protocols(
-            self, inter_broker_security_protocol, inter_broker_sasl_mechanism='GSSAPI', metadata_quorum=quorum.remote_raft):
-        """
-        Test for remote Raft cases that we can start VerifiableProducer on the current branch snapshot version, and
-        verify that we can produce a small number of messages.  The inter-controller and broker-to-controller
-        security protocols are defined to be different (which differs from the above test, where they were the same).
-        """
-        self.kafka.security_protocol = self.kafka.interbroker_security_protocol = inter_broker_security_protocol
-        self.kafka.client_sasl_mechanism = self.kafka.interbroker_sasl_mechanism = inter_broker_sasl_mechanism
-        controller_quorum = self.kafka.controller_quorum
-        sasl_mechanism = 'PLAIN' if inter_broker_sasl_mechanism == 'GSSAPI' else 'GSSAPI'
-        if inter_broker_security_protocol == 'PLAINTEXT':
-            controller_security_protocol = 'SSL'
-            intercontroller_security_protocol = 'SASL_SSL'
-        elif inter_broker_security_protocol == 'SSL':
-            controller_security_protocol = 'SASL_SSL'
-            intercontroller_security_protocol = 'PLAINTEXT'
-        else: # inter_broker_security_protocol == 'SASL_SSL'
-            controller_security_protocol = 'PLAINTEXT'
-            intercontroller_security_protocol = 'SSL'
-        controller_quorum.controller_security_protocol = controller_security_protocol
-        controller_quorum.controller_sasl_mechanism = sasl_mechanism
-        controller_quorum.intercontroller_security_protocol = intercontroller_security_protocol
-        controller_quorum.intercontroller_sasl_mechanism = sasl_mechanism
-        self.kafka.start()
-
-        node = self.producer.nodes[0]
-        node.version = KafkaVersion(str(DEV_BRANCH))
-        self.producer.start()
-        wait_until(lambda: self.producer.num_acked > 5, timeout_sec=15,
-             err_msg="Producer failed to start in a reasonable amount of time.")
-
-        # See above comment above regarding use of version.vstring (distutils.version.LooseVersion)
-        assert is_version(node, [node.version.vstring], logger=self.logger)
-
-        self.producer.wait()
-        num_produced = self.producer.num_acked
-        assert num_produced == self.num_messages, "num_produced: %d, num_messages: %d" % (num_produced, self.num_messages)
-
-    @cluster(num_nodes=4)
-    @parametrize(metadata_quorum=quorum.remote_raft)
-    def test_multiple_raft_sasl_mechanisms(self, metadata_quorum):
-        """
-        Test for remote Raft cases that we can start VerifiableProducer on the current branch snapshot version, and
-        verify that we can produce a small number of messages.  The inter-controller and broker-to-controller
-        security protocols are both SASL_PLAINTEXT but the SASL mechanisms are different (we set
-        GSSAPI for the inter-controller mechanism and PLAIN for the broker-to-controller mechanism).
-        This test differs from the above tests -- he ones above used the same SASL mechanism for both paths.
-        """
-        self.kafka.security_protocol = self.kafka.interbroker_security_protocol = 'PLAINTEXT'
-        controller_quorum = self.kafka.controller_quorum
-        controller_quorum.controller_security_protocol = 'SASL_PLAINTEXT'
-        controller_quorum.controller_sasl_mechanism = 'PLAIN'
-        controller_quorum.intercontroller_security_protocol = 'SASL_PLAINTEXT'
-        controller_quorum.intercontroller_sasl_mechanism = 'GSSAPI'
-        self.kafka.start()
-
-        node = self.producer.nodes[0]
-        node.version = KafkaVersion(str(DEV_BRANCH))
-        self.producer.start()
-        wait_until(lambda: self.producer.num_acked > 5, timeout_sec=15,
-             err_msg="Producer failed to start in a reasonable amount of time.")
-
-        # See above comment above regarding use of version.vstring (distutils.version.LooseVersion)
-        assert is_version(node, [node.version.vstring], logger=self.logger)
-
-        self.producer.wait()
-        num_produced = self.producer.num_acked
-        assert num_produced == self.num_messages, "num_produced: %d, num_messages: %d" % (num_produced, self.num_messages)
-
diff --git a/tests/kafkatest/services/kafka/quorum.py b/tests/kafkatest/services/kafka/quorum.py
index 7348fc1594..9513c8e74b 100644
--- a/tests/kafkatest/services/kafka/quorum.py
+++ b/tests/kafkatest/services/kafka/quorum.py
@@ -21,14 +21,14 @@ remote_raft = 'REMOTE_RAFT' # separate Controllers in KRaft mode, used during/af
 # How we will parameterize tests that exercise all quorum styles
 #   [“ZK”, “REMOTE_RAFT”, "COLOCATED_RAFT"] during the KIP-500 bridge release(s)
 #   [“REMOTE_RAFT”, "COLOCATED_RAFT”] after the KIP-500 bridge release(s)
-all = [zk, remote_raft, colocated_raft]
+all = [zk]
 # How we will parameterize tests that exercise all KRaft quorum styles
-all_raft = [remote_raft, colocated_raft]
+all_raft = []
 # How we will parameterize tests that are unrelated to upgrades:
 #   [“ZK”] before the KIP-500 bridge release(s)
 #   [“ZK”, “REMOTE_RAFT”] during the KIP-500 bridge release(s) and in preview releases
 #   [“REMOTE_RAFT”] after the KIP-500 bridge release(s)
-all_non_upgrade = [zk, remote_raft]
+all_non_upgrade = [zk]
 
 def for_test(test_context):
     # A test uses ZooKeeper if it doesn't specify a metadata quorum or if it explicitly specifies ZooKeeper
diff --git a/tests/kafkatest/tests/core/security_test.py b/tests/kafkatest/tests/core/security_test.py
index 8e2b695074..bf54632a98 100644
--- a/tests/kafkatest/tests/core/security_test.py
+++ b/tests/kafkatest/tests/core/security_test.py
@@ -132,7 +132,7 @@ class SecurityTest(EndToEndTest):
         self.consumer.start()
 
     @cluster(num_nodes=2)
-    @matrix(metadata_quorum=[quorum.zk, quorum.remote_raft])
+    @matrix(metadata_quorum=[quorum.zk])
     def test_quorum_ssl_endpoint_validation_failure(self, metadata_quorum=quorum.zk):
         """
         Test that invalid hostname in ZooKeeper or Raft Controller results in broker inability to start.