You are viewing a plain text version of this content. The canonical link for it is here.
Posted to gitbox@activemq.apache.org by "gemmellr (via GitHub)" <gi...@apache.org> on 2023/04/10 09:15:18 UTC

[GitHub] [activemq-artemis] gemmellr commented on a diff in pull request #4421: ARTEMIS-4212 fix sending msgs to address w/mismatching routing types

gemmellr commented on code in PR #4421:
URL: https://github.com/apache/activemq-artemis/pull/4421#discussion_r1161555436


##########
artemis-core-client/src/main/java/org/apache/activemq/artemis/core/client/impl/AddressQueryImpl.java:
##########
@@ -133,4 +141,14 @@ public Integer getDefaultConsumersBeforeDispatch() {
    public Long getDefaultDelayBeforeDispatch() {
       return defaultDelayBeforeDispatch;
    }
+
+   @Override
+   public Boolean isSupportsMulticast() {
+      return supportsMulticast;
+   }
+
+   @Override
+   public Boolean isSupportsAnycast() {
+      return supportsAnycast;
+   }

Review Comment:
   Using primitive boolean may be nicer for the method returns, even if using Boolean for the field? Doesnt seem like any of the usage would actually handle a null being returned. Isnt clear it really needs 'presence' detection offered by use of Boolean field either (could use 'boolean hasSupportsMulticast()' style detection later though if ever so)



##########
artemis-server/src/main/java/org/apache/activemq/artemis/core/security/impl/SecurityStoreImpl.java:
##########
@@ -304,6 +304,7 @@ public void check(final SimpleString address,
             if (bareQueue == null) {
                ex = ActiveMQMessageBundle.BUNDLE.userNoPermissions(session.getUsername(), checkType, bareAddress);
             } else {
+               new Exception("trace").printStackTrace();

Review Comment:
   Leftover debug stacktrace



##########
artemis-server/src/main/java/org/apache/activemq/artemis/core/server/impl/ActiveMQServerImpl.java:
##########
@@ -3943,6 +3943,7 @@ public Queue createQueue(final QueueConfiguration queueConfiguration) throws Exc
 
    @Override
    public Queue createQueue(final QueueConfiguration queueConfiguration, boolean ignoreIfExists) throws Exception {
+//      new Exception("trace").printStackTrace();

Review Comment:
   commented out debug stacktrace



##########
tests/integration-tests/src/test/java/org/apache/activemq/artemis/tests/integration/jms/multiprotocol/JMSMismatchedRoutingTypeTest.java:
##########
@@ -0,0 +1,126 @@
+/*
+ * 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.activemq.artemis.tests.integration.jms.multiprotocol;
+
+import javax.jms.Connection;
+import javax.jms.InvalidDestinationException;
+import javax.jms.JMSException;
+import javax.jms.MessageProducer;
+import javax.jms.Queue;
+import javax.jms.Session;
+import javax.jms.Topic;
+
+import org.apache.activemq.artemis.api.core.QueueConfiguration;
+import org.apache.activemq.artemis.api.core.RoutingType;
+import org.apache.activemq.artemis.api.core.SimpleString;
+import org.apache.activemq.artemis.core.server.ActiveMQServer;
+import org.apache.activemq.artemis.core.server.impl.AddressInfo;
+import org.apache.activemq.artemis.jms.client.ActiveMQConnection;
+import org.apache.activemq.artemis.tests.util.RandomUtil;
+import org.junit.Test;
+
+public class JMSMismatchedRoutingTypeTest extends MultiprotocolJMSClientTestSupport {
+
+   protected final String ANYCAST_ADDRESS = RandomUtil.randomString();
+   protected final String MULTICAST_ADDRESS = RandomUtil.randomString();
+
+   @Override
+   protected boolean isAutoCreateAddresses() {
+      return false;
+   }
+
+   @Override
+   protected boolean isAutoCreateQueues() {
+      return false;
+   }
+
+   @Override
+   protected void createAddressAndQueues(ActiveMQServer server) throws Exception {
+      server.addAddressInfo(new AddressInfo(SimpleString.toSimpleString(ANYCAST_ADDRESS), RoutingType.ANYCAST));
+      server.createQueue(new QueueConfiguration(RandomUtil.randomString()).setAddress(ANYCAST_ADDRESS).setRoutingType(RoutingType.ANYCAST));
+
+      server.addAddressInfo(new AddressInfo(SimpleString.toSimpleString(MULTICAST_ADDRESS), RoutingType.MULTICAST));
+      server.createQueue(new QueueConfiguration(RandomUtil.randomString()).setAddress(MULTICAST_ADDRESS).setRoutingType(RoutingType.MULTICAST));
+   }
+
+   @Test
+   public void testSendingMulticastToAnycastAMQP() throws Exception {
+      internalTestSendingMulticastToAnycast(AMQPConnection);
+   }
+
+   @Test
+   public void testSendingMulticastToAnycastCore() throws Exception {
+      internalTestSendingMulticastToAnycast(CoreConnection);
+   }
+
+   @Test
+   public void testSendingMulticastToAnycastOpenWire() throws Exception {
+      internalTestSendingMulticastToAnycast(OpenWireConnection);
+   }
+
+   private void internalTestSendingMulticastToAnycast(ConnectionSupplier connectionSupplier) throws Exception {
+      Connection connection = connectionSupplier.createConnection();
+      Session s = connection.createSession(false, Session.AUTO_ACKNOWLEDGE);
+      Topic topic = s.createTopic(ANYCAST_ADDRESS);
+      try {
+         MessageProducer producer = s.createProducer(topic);
+         producer.send(s.createMessage());
+         fail("Sending message here should fail!");
+      } catch (InvalidDestinationException e) {
+         // expected
+      }
+   }
+
+   @Test
+   public void testSendingAnycastToMulticastAMQP() throws Exception {
+      internalTestSendingAnycastToMulticast(AMQPConnection);
+   }
+
+   @Test
+   public void testSendingAnycastToMulticastCore() throws Exception {
+      internalTestSendingAnycastToMulticast(CoreConnection);
+   }
+
+   @Test
+   public void testSendingAnycastToMulticastOpenWire() throws Exception {
+      internalTestSendingAnycastToMulticast(OpenWireConnection);
+   }
+
+   private void internalTestSendingAnycastToMulticast(ConnectionSupplier connectionSupplier) throws Exception {
+      Connection connection = connectionSupplier.createConnection();
+      Session s = connection.createSession(false, Session.AUTO_ACKNOWLEDGE);
+      Queue q;
+      try {
+         // when using core this will fail because the client actually checks for the queue on the broker (which won't be there)
+         q = s.createQueue(MULTICAST_ADDRESS);
+      } catch (JMSException e) {
+         if (connection instanceof ActiveMQConnection) {
+            // expected
+            return;
+         } else {
+            throw e;
+         }
+      }
+      try {
+         MessageProducer producer = s.createProducer(q);
+         producer.send(s.createMessage());
+         fail("Sending message here should fail!");
+      } catch (InvalidDestinationException e) {
+         // expected
+      }
+   }

Review Comment:
   Should clean up connection.



##########
tests/integration-tests/src/test/java/org/apache/activemq/artemis/tests/integration/jms/multiprotocol/JMSMismatchedRoutingTypeTest.java:
##########
@@ -0,0 +1,126 @@
+/*
+ * 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.activemq.artemis.tests.integration.jms.multiprotocol;
+
+import javax.jms.Connection;
+import javax.jms.InvalidDestinationException;
+import javax.jms.JMSException;
+import javax.jms.MessageProducer;
+import javax.jms.Queue;
+import javax.jms.Session;
+import javax.jms.Topic;
+
+import org.apache.activemq.artemis.api.core.QueueConfiguration;
+import org.apache.activemq.artemis.api.core.RoutingType;
+import org.apache.activemq.artemis.api.core.SimpleString;
+import org.apache.activemq.artemis.core.server.ActiveMQServer;
+import org.apache.activemq.artemis.core.server.impl.AddressInfo;
+import org.apache.activemq.artemis.jms.client.ActiveMQConnection;
+import org.apache.activemq.artemis.tests.util.RandomUtil;
+import org.junit.Test;
+
+public class JMSMismatchedRoutingTypeTest extends MultiprotocolJMSClientTestSupport {
+
+   protected final String ANYCAST_ADDRESS = RandomUtil.randomString();
+   protected final String MULTICAST_ADDRESS = RandomUtil.randomString();
+
+   @Override
+   protected boolean isAutoCreateAddresses() {
+      return false;
+   }
+
+   @Override
+   protected boolean isAutoCreateQueues() {
+      return false;
+   }
+
+   @Override
+   protected void createAddressAndQueues(ActiveMQServer server) throws Exception {
+      server.addAddressInfo(new AddressInfo(SimpleString.toSimpleString(ANYCAST_ADDRESS), RoutingType.ANYCAST));
+      server.createQueue(new QueueConfiguration(RandomUtil.randomString()).setAddress(ANYCAST_ADDRESS).setRoutingType(RoutingType.ANYCAST));
+
+      server.addAddressInfo(new AddressInfo(SimpleString.toSimpleString(MULTICAST_ADDRESS), RoutingType.MULTICAST));
+      server.createQueue(new QueueConfiguration(RandomUtil.randomString()).setAddress(MULTICAST_ADDRESS).setRoutingType(RoutingType.MULTICAST));
+   }
+
+   @Test
+   public void testSendingMulticastToAnycastAMQP() throws Exception {
+      internalTestSendingMulticastToAnycast(AMQPConnection);
+   }
+
+   @Test
+   public void testSendingMulticastToAnycastCore() throws Exception {
+      internalTestSendingMulticastToAnycast(CoreConnection);
+   }
+
+   @Test
+   public void testSendingMulticastToAnycastOpenWire() throws Exception {
+      internalTestSendingMulticastToAnycast(OpenWireConnection);
+   }
+
+   private void internalTestSendingMulticastToAnycast(ConnectionSupplier connectionSupplier) throws Exception {
+      Connection connection = connectionSupplier.createConnection();
+      Session s = connection.createSession(false, Session.AUTO_ACKNOWLEDGE);
+      Topic topic = s.createTopic(ANYCAST_ADDRESS);
+      try {
+         MessageProducer producer = s.createProducer(topic);
+         producer.send(s.createMessage());
+         fail("Sending message here should fail!");
+      } catch (InvalidDestinationException e) {
+         // expected
+      }
+   }

Review Comment:
   Should clean up connection.



-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: gitbox-unsubscribe@activemq.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org