Uploaded image for project: 'ActiveMQ Artemis'
  1. ActiveMQ Artemis
  2. ARTEMIS-1216

Unable to send messages from AMQP to MQTT

    XMLWordPrintableJSON

Details

    • Bug
    • Status: Resolved
    • Major
    • Resolution: Fixed
    • 2.1.0
    • None
    • AMQP, Broker, MQTT
    • None
    • Linux

    Description

      Subscribing by MQTT to "#" and publishing a JMS message by AMQP results in the following message in the broker:

      12:17:23,457 WARN  [org.apache.activemq.artemis.core.protocol.mqtt] Unable to send message: 163 Cause: org.apache.activemq.artemis.protocol.amqp.broker.AMQPMessage cannot be cast to org.apache.activemq.artemis.core.message.impl.CoreMessage: java.lang.ClassCastException: org.apache.activemq.artemis.protocol.amqp.broker.AMQPMessage cannot be cast to org.apache.activemq.artemis.core.message.impl.CoreMessage
      	at org.apache.activemq.artemis.core.protocol.mqtt.MQTTSessionCallback.sendMessage(MQTTSessionCallback.java:52) [artemis-mqtt-protocol-2.1.0.jar:]
      	at org.apache.activemq.artemis.core.server.impl.ServerConsumerImpl.deliverStandardMessage(ServerConsumerImpl.java:1057) [artemis-server-2.1.0.jar:2.1.0]
      	at org.apache.activemq.artemis.core.server.impl.ServerConsumerImpl.proceedDeliver(ServerConsumerImpl.java:432) [artemis-server-2.1.0.jar:2.1.0]
      	at org.apache.activemq.artemis.core.server.impl.QueueImpl.proceedDeliver(QueueImpl.java:2705) [artemis-server-2.1.0.jar:2.1.0]
      	at org.apache.activemq.artemis.core.server.impl.QueueImpl.deliver(QueueImpl.java:2190) [artemis-server-2.1.0.jar:2.1.0]
      	at org.apache.activemq.artemis.core.server.impl.QueueImpl.access$1900(QueueImpl.java:103) [artemis-server-2.1.0.jar:2.1.0]
      	at org.apache.activemq.artemis.core.server.impl.QueueImpl$DeliverRunner.run(QueueImpl.java:2938) [artemis-server-2.1.0.jar:2.1.0]
      	at org.apache.activemq.artemis.utils.OrderedExecutorFactory$OrderedExecutor$ExecutorTask.run(OrderedExecutorFactory.java:101) [artemis-commons-2.1.0.jar:2.1.0]
      	at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1142) [rt.jar:1.8.0_131]
      	at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:617) [rt.jar:1.8.0_131]
      	at java.lang.Thread.run(Thread.java:748) [rt.jar:1.8.0_131]
      
      
      

      Attachments

        Activity

          People

            Unassigned Unassigned
            ctron Jens Reimann
            Votes:
            0 Vote for this issue
            Watchers:
            3 Start watching this issue

            Dates

              Created:
              Updated:
              Resolved: