You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@camel.apache.org by GitBox <gi...@apache.org> on 2022/01/19 23:19:05 UTC

[GitHub] [camel-quarkus] freedev opened a new issue #3474: java.lang.IllegalStateException: The stream has no active subscriptions smallrye-reactive-messaging-camel

freedev opened a new issue #3474:
URL: https://github.com/apache/camel-quarkus/issues/3474


   I encoundered this issue with a simple project, I commited the source here:
   https://github.com/freedev/code-with-quarkus-camel
   
   ```
   mp.messaging.incoming.source-in.connector=smallrye-camel
   mp.messaging.incoming.source-in.endpoint-uri=azure-servicebus:my-topic?subscriptionName=my-topic-subscription&amqpTransportType=AmqpWebSockets&serviceBusType=topic&connectionString=Endpoint=sb://my-azuresb.servicebus.windows.net/;SharedAccessKeyName=camelTest;SharedAccessKey=XXXXXX;EntityPath=my-topic
   ```
   
   ```
       @Incoming("manifest-request-upc")
       public CompletionStage<Void> consume(Message<String> message) {
           System.out.println(message);
           return message.ack();
       }
   ```
   
   At first run, quarkus tryes to read from the azure sb topic but an exception is raised
   
   ```
   /Users/freedev/.sdkman/candidates/java/17.0.1-tem/bin/java -Dmaven.multiModuleProjectDirectory=/Users/freedev -Dmaven.home=/Users/freedev/.m2/wrapper/dists/apache-maven-3.8.4-bin/52ccbt68d252mdldqsfsn03jlf/apache-maven-3.8.4 -Dclassworlds.conf=/Users/freedev/.m2/wrapper/dists/apache-maven-3.8.4-bin/52ccbt68d252mdldqsfsn03jlf/apache-maven-3.8.4/bin/m2.conf -Dfile.encoding=UTF-8 -classpath /Users/freedev/.m2/wrapper/dists/apache-maven-3.8.4-bin/52ccbt68d252mdldqsfsn03jlf/apache-maven-3.8.4/boot/plexus-classworlds.license:/Users/freedev/.m2/wrapper/dists/apache-maven-3.8.4-bin/52ccbt68d252mdldqsfsn03jlf/apache-maven-3.8.4/boot/plexus-classworlds-2.6.0.jar org.codehaus.classworlds.Launcher -Didea.version=2021.3.1 -Ddebug=64713 quarkus:dev
   [INFO] Scanning for projects...
   [INFO] 
   [INFO] ------------< t.lux.quarkus.azure:code-with-quarkus-camel >-------------
   [INFO] Building code-with-quarkus-camel 1.0.0-SNAPSHOT
   [INFO] --------------------------------[ jar ]---------------------------------
   [INFO] 
   [INFO] --- quarkus-maven-plugin:2.6.2.Final:dev (default-cli) @ code-with-quarkus-camel ---
   [INFO] Invoking org.apache.maven.plugins:maven-resources-plugin:2.6:resources) @ code-with-quarkus-camel
   [INFO] Using 'UTF-8' encoding to copy filtered resources.
   [INFO] Copying 1 resource
   [INFO] Invoking io.quarkus.platform:quarkus-maven-plugin:2.6.2.Final:generate-code) @ code-with-quarkus-camel
   [INFO] Invoking org.apache.maven.plugins:maven-compiler-plugin:3.8.1:compile) @ code-with-quarkus-camel
   [INFO] Nothing to compile - all classes are up to date
   [INFO] Invoking org.apache.maven.plugins:maven-resources-plugin:2.6:testResources) @ code-with-quarkus-camel
   [INFO] Using 'UTF-8' encoding to copy filtered resources.
   [INFO] skip non existing resourceDirectory /Users/freedev/git/luxottica/manifest-generator/tmp/code-with-quarkus-camel/src/test/resources
   [INFO] Invoking io.quarkus.platform:quarkus-maven-plugin:2.6.2.Final:generate-code-tests) @ code-with-quarkus-camel
   [INFO] Invoking org.apache.maven.plugins:maven-compiler-plugin:3.8.1:testCompile) @ code-with-quarkus-camel
   [INFO] Nothing to compile - all classes are up to date
   Listening for transport dt_socket at address: 64713
   Connected to the target VM, address: '127.0.0.1:64713', transport: 'socket'
   Press [h] for more options>
   Tests paused
   Press [r] to resume testing, [h] for more options>
   Press [r] to resume testing, [o] Toggle test output, [h] for more options>
   2022-01-19 23:58:40,134 INFO  [io.qua.arc.pro.BeanProcessor] (build-21) Found unrecommended usage of private members (use package-private instead) in application beans:
   	- @Inject field t.lux.quarkus.azure.MyReactiveMessagingApplication#camelContext
   __  ____  __  _____   ___  __ ____  ______ 
    --/ __ \/ / / / _ | / _ \/ //_/ / / / __/ 
    -/ /_/ / /_/ / __ |/ , _/ ,< / /_/ /\ \   
   --\___\_\____/_/ |_/_/|_/_/|_|\____/___/   
   2022-01-19 23:58:40,506 INFO  [io.sma.rea.mes.camel] (Quarkus Main Thread) SRMSG17801: Creating publisher from Camel endpoint azure-servicebus:source-in?subscriptionName=source-in-subscription&amqpTransportType=AmqpWebSockets&serviceBusType=topic&connectionString=Endpoint=sb://my-azuresb.servicebus.windows.net/;SharedAccessKeyName=camelTest;SharedAccessKey=XXXXXXXX=;EntityPath=source-in
   2022-01-19 23:58:40,802 INFO  [com.azu.mes.ser.ServiceBusClientBuilder] (Quarkus Main Thread) Setting 'entityName' [source-in] from connectionString.
   2022-01-19 23:58:40,931 INFO  [com.azu.mes.ser.imp.ServiceBusConnectionProcessor] (Quarkus Main Thread) namespace[my-azuresb.servicebus.windows.net] entityPath[N/A]: Setting next AMQP channel.
   2022-01-19 23:58:40,931 INFO  [com.azu.mes.ser.imp.ServiceBusConnectionProcessor] (Quarkus Main Thread) namespace[my-azuresb.servicebus.windows.net] entityPath[N/A]: Next AMQP channel received, updating 0 current subscribers
   2022-01-19 23:58:40,933 INFO  [com.azu.mes.ser.ServiceBusClientBuilder] (Quarkus Main Thread) # of open clients with shared connection: 1
   2022-01-19 23:58:40,942 INFO  [com.azu.mes.ser.ServiceBusReceiverAsyncClient] (Quarkus Main Thread) source-in/subscriptions/source-in-subscription: Creating consumer for link 'source-in/subscriptions/source-in-subscription_74188f_1642633120942'
   2022-01-19 23:58:40,947 INFO  [com.azu.mes.ser.imp.ServiceBusReceiveLinkProcessor] (Quarkus Main Thread) Requesting a new AmqpReceiveLink from upstream.
   2022-01-19 23:58:40,957 INFO  [com.azu.cor.amq.imp.ReactorConnection] (Quarkus Main Thread) connectionId[MF_167a3f_1642633120898]: Creating and starting connection to my-azuresb.servicebus.windows.net:443
   2022-01-19 23:58:40,975 INFO  [com.azu.cor.amq.imp.ReactorExecutor] (Quarkus Main Thread) connectionId[MF_167a3f_1642633120898] message[Starting reactor.]
   2022-01-19 23:58:40,981 INFO  [com.azu.cor.amq.imp.han.ConnectionHandler] (reactor-executor-1) onConnectionInit connectionId[MF_167a3f_1642633120898] hostname[my-azuresb.servicebus.windows.net] amqpHostname[my-azuresb.servicebus.windows.net]
   2022-01-19 23:58:40,982 INFO  [com.azu.cor.amq.imp.han.ReactorHandler] (reactor-executor-1) connectionId[MF_167a3f_1642633120898] reactor.onReactorInit
   2022-01-19 23:58:40,983 INFO  [com.azu.cor.amq.imp.han.ConnectionHandler] (reactor-executor-1) onConnectionLocalOpen connectionId[MF_167a3f_1642633120898] hostname[my-azuresb.servicebus.windows.net] errorCondition[null] errorDescription[null]
   2022-01-19 23:58:40,992 INFO  [com.azu.mes.ser.FluxAutoComplete] (Quarkus Main Thread) Subscription received. Subscribing downstream. reactor.core.publisher.FluxMap$MapSubscriber@3d684327
   2022-01-19 23:58:40,994 INFO  [org.apa.cam.imp.eng.AbstractCamelContext] (Quarkus Main Thread) Routes startup summary (total:1 started:1)
   2022-01-19 23:58:40,994 INFO  [org.apa.cam.imp.eng.AbstractCamelContext] (Quarkus Main Thread)     Started route1 (azure-servicebus://source-in)
   2022-01-19 23:58:40,995 INFO  [org.apa.cam.imp.eng.AbstractCamelContext] (Quarkus Main Thread) Apache Camel 3.13.0 (camel-1) started in 382ms (build:68ms init:81ms start:233ms)
   2022-01-19 23:58:41,002 INFO  [io.quarkus] (Quarkus Main Thread) code-with-quarkus-camel 1.0.0-SNAPSHOT on JVM (powered by Quarkus 2.6.2.Final) started in 1.724s. 
   2022-01-19 23:58:41,003 INFO  [io.quarkus] (Quarkus Main Thread) Profile dev activated. Live Coding activated.
   2022-01-19 23:58:41,004 INFO  [io.quarkus] (Quarkus Main Thread) Installed features: [cdi, smallrye-context-propagation, smallrye-reactive-messaging, vertx]
   2022-01-19 23:58:41,042 INFO  [com.azu.cor.amq.imp.han.ConnectionHandler] (reactor-executor-1) onConnectionBound connectionId[MF_167a3f_1642633120898] hostname[my-azuresb.servicebus.windows.net] peerDetails[my-azuresb.servicebus.windows.net:443]
   2022-01-19 23:58:41,042 INFO  [com.azu.cor.amq.imp.han.WebSocketsConnectionHandler] (reactor-executor-1) Adding web socket layer
   2022-01-19 23:58:41,519 INFO  [com.azu.cor.amq.imp.han.ConnectionHandler] (reactor-executor-1) onConnectionRemoteOpen hostname[my-azuresb.servicebus.windows.net], connectionId[MF_167a3f_1642633120898], remoteContainer[215ad176b4464c4488eba3ba48b74039_G10]
   2022-01-19 23:58:41,519 INFO  [com.azu.mes.ser.imp.ServiceBusConnectionProcessor] (reactor-executor-1) namespace[my-azuresb.servicebus.windows.net] entityPath[N/A]: Channel is now active.
   2022-01-19 23:58:41,558 INFO  [com.azu.cor.amq.imp.han.SessionHandler] (reactor-executor-1) onSessionRemoteOpen connectionId[MF_167a3f_1642633120898], entityName[source-in/subscriptions/source-in-subscription], sessionIncCapacity[0], sessionOutgoingWindow[2147483647]
   2022-01-19 23:58:41,567 INFO  [com.azu.cor.amq.imp.ReactorConnection] (reactor-executor-1) Setting CBS channel.
   2022-01-19 23:58:41,598 INFO  [com.azu.cor.amq.imp.han.SessionHandler] (reactor-executor-1) onSessionRemoteOpen connectionId[MF_167a3f_1642633120898], entityName[cbs-session], sessionIncCapacity[0], sessionOutgoingWindow[2147483647]
   2022-01-19 23:58:41,605 INFO  [com.azu.cor.amq.imp.ReactorConnection] (reactor-executor-1) connectionId[MF_167a3f_1642633120898] entityPath[$cbs] linkName[cbs] Emitting new response channel.
   2022-01-19 23:58:41,605 INFO  [com.azu.cor.amq.imp.RequestResponseChannel:$cbs] (reactor-executor-1) namespace[MF_167a3f_1642633120898] entityPath[$cbs]: Setting next AMQP channel.
   2022-01-19 23:58:41,606 INFO  [com.azu.cor.amq.imp.RequestResponseChannel:$cbs] (reactor-executor-1) namespace[MF_167a3f_1642633120898] entityPath[$cbs]: Next AMQP channel received, updating 1 current subscribers
   2022-01-19 23:58:41,639 INFO  [com.azu.cor.amq.imp.han.SendLinkHandler] (reactor-executor-1) onLinkRemoteOpen connectionId[MF_167a3f_1642633120898], entityPath[$cbs], linkName[cbs:sender], remoteTarget[Target{address='$cbs', durable=NONE, expiryPolicy=SESSION_END, timeout=0, dynamic=false, dynamicNodeProperties=null, capabilities=null}]
   2022-01-19 23:58:41,640 INFO  [com.azu.cor.amq.imp.han.ReceiveLinkHandler] (reactor-executor-1) onLinkRemoteOpen connectionId[MF_167a3f_1642633120898], entityPath[$cbs], linkName[cbs:receiver], remoteSource[Source{address='$cbs', durable=NONE, expiryPolicy=SESSION_END, timeout=0, dynamic=false, dynamicNodeProperties=null, distributionMode=null, filter=null, defaultOutcome=null, outcomes=null, capabilities=null}]
   2022-01-19 23:58:41,640 INFO  [com.azu.cor.amq.imp.RequestResponseChannel:$cbs] (reactor-executor-1) namespace[MF_167a3f_1642633120898] entityPath[$cbs]: Channel is now active.
   2022-01-19 23:58:41,671 INFO  [com.azu.cor.amq.imp.ActiveClientTokenManager] (reactor-executor-1) Scheduling refresh token task. scopes[amqp://my-azuresb.servicebus.windows.net/source-in/subscriptions/source-in-subscription]
   2022-01-19 23:58:41,677 INFO  [com.azu.cor.amq.imp.ReactorSession] (reactor-executor-1) connectionId[MF_167a3f_1642633120898] sessionId[source-in/subscriptions/source-in-subscription] linkName[source-in/subscriptions/source-in-subscription_74188f_1642633120942] Creating a new receiver link.
   2022-01-19 23:58:41,682 INFO  [com.azu.mes.ser.imp.ServiceBusReceiveLinkProcessor] (reactor-executor-1) linkName[source-in/subscriptions/source-in-subscription_74188f_1642633120942] entityPath[source-in/subscriptions/source-in-subscription]. Setting next AMQP receive link.
   2022-01-19 23:58:41,692 INFO  [com.azu.mes.ser.imp.ServiceBusReceiveLinkProcessor] (reactor-executor-1) linkCredits: '0', expectedTotalCredit: '1'
   2022-01-19 23:58:41,692 INFO  [com.azu.mes.ser.imp.ServiceBusReceiveLinkProcessor] (reactor-executor-1) prefetch: '0', requested: '1', linkCredits: '0', expectedTotalCredit: '1', queuedMessages:'0', creditsToAdd: '1', messageQueue.size(): '0'
   2022-01-19 23:58:41,693 INFO  [com.azu.mes.ser.imp.ServiceBusReceiveLinkProcessor] (reactor-executor-1) Link credits='0', Link credits to add: '1'
   2022-01-19 23:58:41,695 INFO  [com.azu.cor.amq.imp.ReactorSession] (reactor-executor-1) linkName[source-in/subscriptions/source-in-subscription_74188f_1642633120942] entityPath[source-in/subscriptions/source-in-subscription] Returning existing receive link.
   2022-01-19 23:58:41,730 INFO  [com.azu.cor.amq.imp.han.ReceiveLinkHandler] (reactor-executor-1) onLinkRemoteOpen connectionId[MF_167a3f_1642633120898], entityPath[source-in/subscriptions/source-in-subscription], linkName[source-in/subscriptions/source-in-subscription_74188f_1642633120942], remoteSource[Source{address='source-in/subscriptions/source-in-subscription', durable=NONE, expiryPolicy=SESSION_END, timeout=0, dynamic=false, dynamicNodeProperties=null, distributionMode=null, filter=null, defaultOutcome=null, outcomes=null, capabilities=null}]
   2022-01-19 23:59:12,246 INFO  [com.azu.cor.imp.jac.JacksonVersion] (boundedElastic-2) Package versions: jackson-annotations=2.12.6, jackson-core=2.12.6, jackson-databind=2.12.6, jackson-dataformat-xml=2.12.6, jackson-datatype-jsr310=2.12.6, azure-core=1.21.0
   2022-01-19 23:59:12,418 ERROR [org.apa.cam.pro.err.DefaultErrorHandler] (boundedElastic-2) Failed delivery for (MessageId: 27C071FB177B97B-0000000000000001 on ExchangeId: 27C071FB177B97B-0000000000000001). Exhausted after delivery attempt: 1 caught: java.lang.IllegalStateException: The stream has no active subscriptions
   
   Message History (complete message history is disabled)
   ---------------------------------------------------------------------------------------------------------------------------------------
   RouteId              ProcessorId          Processor                                                                        Elapsed (ms)
   [route1            ] [route1            ] [from[azure-servicebus://source-in?amqpTransportType=AmqpWebSockets&] [       253]
   	...
   [route1            ] [to1               ] [reactive-streams:27C071FB177B97B-0000000000000000                             ] [         0]
   
   Stacktrace
   ---------------------------------------------------------------------------------------------------------------------------------------
   : java.lang.IllegalStateException: The stream has no active subscriptions
   	at org.apache.camel.component.reactive.streams.engine.CamelPublisher.publish(CamelPublisher.java:110)
   	at org.apache.camel.component.reactive.streams.engine.DefaultCamelReactiveStreamsService.sendCamelExchange(DefaultCamelReactiveStreamsService.java:151)
   	at org.apache.camel.component.reactive.streams.ReactiveStreamsProducer.process(ReactiveStreamsProducer.java:52)
   	at org.apache.camel.processor.SendProcessor.process(SendProcessor.java:172)
   	at org.apache.camel.processor.errorhandler.RedeliveryErrorHandler$SimpleTask.run(RedeliveryErrorHandler.java:469)
   	at org.apache.camel.impl.engine.DefaultReactiveExecutor$Worker.schedule(DefaultReactiveExecutor.java:187)
   	at org.apache.camel.impl.engine.DefaultReactiveExecutor.scheduleMain(DefaultReactiveExecutor.java:64)
   	at org.apache.camel.processor.Pipeline.process(Pipeline.java:184)
   	at org.apache.camel.impl.engine.CamelInternalProcessor.process(CamelInternalProcessor.java:398)
   	at org.apache.camel.component.azure.servicebus.ServiceBusConsumer.onEventListener(ServiceBusConsumer.java:147)
   	at reactor.core.publisher.LambdaSubscriber.onNext(LambdaSubscriber.java:160)
   	at reactor.core.publisher.FluxPublishOn$PublishOnSubscriber.runAsync(FluxPublishOn.java:440)
   	at reactor.core.publisher.FluxPublishOn$PublishOnSubscriber.run(FluxPublishOn.java:527)
   	at reactor.core.scheduler.ImmediateScheduler$ImmediateSchedulerWorker.schedule(ImmediateScheduler.java:84)
   	at reactor.core.publisher.FluxPublishOn$PublishOnSubscriber.trySchedule(FluxPublishOn.java:312)
   	at reactor.core.publisher.FluxPublishOn$PublishOnSubscriber.onNext(FluxPublishOn.java:237)
   	at reactor.core.publisher.FluxHandle$HandleSubscriber.onNext(FluxHandle.java:119)
   	at reactor.core.publisher.FluxOnErrorResume$ResumeSubscriber.onNext(FluxOnErrorResume.java:79)
   	at com.azure.messaging.servicebus.FluxAutoComplete$AutoCompleteSubscriber.hookOnNext(FluxAutoComplete.java:89)
   	at com.azure.messaging.servicebus.FluxAutoComplete$AutoCompleteSubscriber.hookOnNext(FluxAutoComplete.java:52)
   	at reactor.core.publisher.BaseSubscriber.onNext(BaseSubscriber.java:160)
   	at com.azure.messaging.servicebus.FluxAutoLockRenew$LockRenewSubscriber.hookOnNext(FluxAutoLockRenew.java:171)
   	at com.azure.messaging.servicebus.FluxAutoLockRenew$LockRenewSubscriber.hookOnNext(FluxAutoLockRenew.java:76)
   	at reactor.core.publisher.BaseSubscriber.onNext(BaseSubscriber.java:160)
   	at reactor.core.publisher.FluxMap$MapSubscriber.onNext(FluxMap.java:120)
   	at reactor.core.publisher.FluxMap$MapSubscriber.onNext(FluxMap.java:120)
   	at com.azure.messaging.servicebus.implementation.ServiceBusReceiveLinkProcessor.drainQueue(ServiceBusReceiveLinkProcessor.java:478)
   	at com.azure.messaging.servicebus.implementation.ServiceBusReceiveLinkProcessor.drain(ServiceBusReceiveLinkProcessor.java:437)
   	at com.azure.messaging.servicebus.implementation.ServiceBusReceiveLinkProcessor.lambda$onNext$2(ServiceBusReceiveLinkProcessor.java:210)
   	at reactor.core.publisher.LambdaSubscriber.onNext(LambdaSubscriber.java:160)
   	at reactor.core.publisher.FluxPublishOn$PublishOnSubscriber.runAsync(FluxPublishOn.java:440)
   	at reactor.core.publisher.FluxPublishOn$PublishOnSubscriber.run(FluxPublishOn.java:527)
   	at reactor.core.scheduler.WorkerTask.call(WorkerTask.java:84)
   	at reactor.core.scheduler.WorkerTask.call(WorkerTask.java:37)
   	at java.base/java.util.concurrent.FutureTask.run(FutureTask.java:264)
   	at java.base/java.util.concurrent.ScheduledThreadPoolExecutor$ScheduledFutureTask.run(ScheduledThreadPoolExecutor.java:304)
   	at java.base/java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1136)
   	at java.base/java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:635)
   	at java.base/java.lang.Thread.run(Thread.java:833)
   
   2022-01-19 23:59:12,422 WARN  [org.apa.cam.com.azu.ser.ServiceBusConsumer] (boundedElastic-2) Error during processing exchange.. Exchange[27C071FB177B97B-0000000000000001]. Caused by: [java.lang.IllegalStateException - The stream has no active subscriptions]: java.lang.IllegalStateException: The stream has no active subscriptions
   	at org.apache.camel.component.reactive.streams.engine.CamelPublisher.publish(CamelPublisher.java:110)
   	at org.apache.camel.component.reactive.streams.engine.DefaultCamelReactiveStreamsService.sendCamelExchange(DefaultCamelReactiveStreamsService.java:151)
   	at org.apache.camel.component.reactive.streams.ReactiveStreamsProducer.process(ReactiveStreamsProducer.java:52)
   	at org.apache.camel.processor.SendProcessor.process(SendProcessor.java:172)
   	at org.apache.camel.processor.errorhandler.RedeliveryErrorHandler$SimpleTask.run(RedeliveryErrorHandler.java:469)
   	at org.apache.camel.impl.engine.DefaultReactiveExecutor$Worker.schedule(DefaultReactiveExecutor.java:187)
   	at org.apache.camel.impl.engine.DefaultReactiveExecutor.scheduleMain(DefaultReactiveExecutor.java:64)
   	at org.apache.camel.processor.Pipeline.process(Pipeline.java:184)
   	at org.apache.camel.impl.engine.CamelInternalProcessor.process(CamelInternalProcessor.java:398)
   	at org.apache.camel.component.azure.servicebus.ServiceBusConsumer.onEventListener(ServiceBusConsumer.java:147)
   	at reactor.core.publisher.LambdaSubscriber.onNext(LambdaSubscriber.java:160)
   	at reactor.core.publisher.FluxPublishOn$PublishOnSubscriber.runAsync(FluxPublishOn.java:440)
   	at reactor.core.publisher.FluxPublishOn$PublishOnSubscriber.run(FluxPublishOn.java:527)
   	at reactor.core.scheduler.ImmediateScheduler$ImmediateSchedulerWorker.schedule(ImmediateScheduler.java:84)
   	at reactor.core.publisher.FluxPublishOn$PublishOnSubscriber.trySchedule(FluxPublishOn.java:312)
   	at reactor.core.publisher.FluxPublishOn$PublishOnSubscriber.onNext(FluxPublishOn.java:237)
   	at reactor.core.publisher.FluxHandle$HandleSubscriber.onNext(FluxHandle.java:119)
   	at reactor.core.publisher.FluxOnErrorResume$ResumeSubscriber.onNext(FluxOnErrorResume.java:79)
   	at com.azure.messaging.servicebus.FluxAutoComplete$AutoCompleteSubscriber.hookOnNext(FluxAutoComplete.java:89)
   	at com.azure.messaging.servicebus.FluxAutoComplete$AutoCompleteSubscriber.hookOnNext(FluxAutoComplete.java:52)
   	at reactor.core.publisher.BaseSubscriber.onNext(BaseSubscriber.java:160)
   	at com.azure.messaging.servicebus.FluxAutoLockRenew$LockRenewSubscriber.hookOnNext(FluxAutoLockRenew.java:171)
   	at com.azure.messaging.servicebus.FluxAutoLockRenew$LockRenewSubscriber.hookOnNext(FluxAutoLockRenew.java:76)
   	at reactor.core.publisher.BaseSubscriber.onNext(BaseSubscriber.java:160)
   	at reactor.core.publisher.FluxMap$MapSubscriber.onNext(FluxMap.java:120)
   	at reactor.core.publisher.FluxMap$MapSubscriber.onNext(FluxMap.java:120)
   	at com.azure.messaging.servicebus.implementation.ServiceBusReceiveLinkProcessor.drainQueue(ServiceBusReceiveLinkProcessor.java:478)
   	at com.azure.messaging.servicebus.implementation.ServiceBusReceiveLinkProcessor.drain(ServiceBusReceiveLinkProcessor.java:437)
   	at com.azure.messaging.servicebus.implementation.ServiceBusReceiveLinkProcessor.lambda$onNext$2(ServiceBusReceiveLinkProcessor.java:210)
   	at reactor.core.publisher.LambdaSubscriber.onNext(LambdaSubscriber.java:160)
   	at reactor.core.publisher.FluxPublishOn$PublishOnSubscriber.runAsync(FluxPublishOn.java:440)
   	at reactor.core.publisher.FluxPublishOn$PublishOnSubscriber.run(FluxPublishOn.java:527)
   	at reactor.core.scheduler.WorkerTask.call(WorkerTask.java:84)
   	at reactor.core.scheduler.WorkerTask.call(WorkerTask.java:37)
   	at java.base/java.util.concurrent.FutureTask.run(FutureTask.java:264)
   	at java.base/java.util.concurrent.ScheduledThreadPoolExecutor$ScheduledFutureTask.run(ScheduledThreadPoolExecutor.java:304)
   	at java.base/java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1136)
   	at java.base/java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:635)
   	at java.base/java.lang.Thread.run(Thread.java:833)
   
   2022-01-19 23:59:12,424 WARN  [org.apa.cam.com.azu.ser.ServiceBusConsumer] (boundedElastic-2) Error processing exchange. Exchange[27C071FB177B97B-0000000000000001]. Caused by: [java.lang.IllegalStateException - The stream has no active subscriptions]: java.lang.IllegalStateException: The stream has no active subscriptions
   	at org.apache.camel.component.reactive.streams.engine.CamelPublisher.publish(CamelPublisher.java:110)
   	at org.apache.camel.component.reactive.streams.engine.DefaultCamelReactiveStreamsService.sendCamelExchange(DefaultCamelReactiveStreamsService.java:151)
   	at org.apache.camel.component.reactive.streams.ReactiveStreamsProducer.process(ReactiveStreamsProducer.java:52)
   	at org.apache.camel.processor.SendProcessor.process(SendProcessor.java:172)
   	at org.apache.camel.processor.errorhandler.RedeliveryErrorHandler$SimpleTask.run(RedeliveryErrorHandler.java:469)
   	at org.apache.camel.impl.engine.DefaultReactiveExecutor$Worker.schedule(DefaultReactiveExecutor.java:187)
   	at org.apache.camel.impl.engine.DefaultReactiveExecutor.scheduleMain(DefaultReactiveExecutor.java:64)
   	at org.apache.camel.processor.Pipeline.process(Pipeline.java:184)
   	at org.apache.camel.impl.engine.CamelInternalProcessor.process(CamelInternalProcessor.java:398)
   	at org.apache.camel.component.azure.servicebus.ServiceBusConsumer.onEventListener(ServiceBusConsumer.java:147)
   	at reactor.core.publisher.LambdaSubscriber.onNext(LambdaSubscriber.java:160)
   	at reactor.core.publisher.FluxPublishOn$PublishOnSubscriber.runAsync(FluxPublishOn.java:440)
   	at reactor.core.publisher.FluxPublishOn$PublishOnSubscriber.run(FluxPublishOn.java:527)
   	at reactor.core.scheduler.ImmediateScheduler$ImmediateSchedulerWorker.schedule(ImmediateScheduler.java:84)
   	at reactor.core.publisher.FluxPublishOn$PublishOnSubscriber.trySchedule(FluxPublishOn.java:312)
   	at reactor.core.publisher.FluxPublishOn$PublishOnSubscriber.onNext(FluxPublishOn.java:237)
   	at reactor.core.publisher.FluxHandle$HandleSubscriber.onNext(FluxHandle.java:119)
   	at reactor.core.publisher.FluxOnErrorResume$ResumeSubscriber.onNext(FluxOnErrorResume.java:79)
   	at com.azure.messaging.servicebus.FluxAutoComplete$AutoCompleteSubscriber.hookOnNext(FluxAutoComplete.java:89)
   	at com.azure.messaging.servicebus.FluxAutoComplete$AutoCompleteSubscriber.hookOnNext(FluxAutoComplete.java:52)
   	at reactor.core.publisher.BaseSubscriber.onNext(BaseSubscriber.java:160)
   	at com.azure.messaging.servicebus.FluxAutoLockRenew$LockRenewSubscriber.hookOnNext(FluxAutoLockRenew.java:171)
   	at com.azure.messaging.servicebus.FluxAutoLockRenew$LockRenewSubscriber.hookOnNext(FluxAutoLockRenew.java:76)
   	at reactor.core.publisher.BaseSubscriber.onNext(BaseSubscriber.java:160)
   	at reactor.core.publisher.FluxMap$MapSubscriber.onNext(FluxMap.java:120)
   	at reactor.core.publisher.FluxMap$MapSubscriber.onNext(FluxMap.java:120)
   	at com.azure.messaging.servicebus.implementation.ServiceBusReceiveLinkProcessor.drainQueue(ServiceBusReceiveLinkProcessor.java:478)
   	at com.azure.messaging.servicebus.implementation.ServiceBusReceiveLinkProcessor.drain(ServiceBusReceiveLinkProcessor.java:437)
   	at com.azure.messaging.servicebus.implementation.ServiceBusReceiveLinkProcessor.lambda$onNext$2(ServiceBusReceiveLinkProcessor.java:210)
   	at reactor.core.publisher.LambdaSubscriber.onNext(LambdaSubscriber.java:160)
   	at reactor.core.publisher.FluxPublishOn$PublishOnSubscriber.runAsync(FluxPublishOn.java:440)
   	at reactor.core.publisher.FluxPublishOn$PublishOnSubscriber.run(FluxPublishOn.java:527)
   	at reactor.core.scheduler.WorkerTask.call(WorkerTask.java:84)
   	at reactor.core.scheduler.WorkerTask.call(WorkerTask.java:37)
   	at java.base/java.util.concurrent.FutureTask.run(FutureTask.java:264)
   	at java.base/java.util.concurrent.ScheduledThreadPoolExecutor$ScheduledFutureTask.run(ScheduledThreadPoolExecutor.java:304)
   	at java.base/java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1136)
   	at java.base/java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:635)
   	at java.base/java.lang.Thread.run(Thread.java:833)
   
   2022-01-19 23:59:12,425 INFO  [com.azu.mes.ser.imp.ServiceBusReceiveLinkProcessor] (boundedElastic-2) linkCredits: '0', expectedTotalCredit: '2'
   2022-01-19 23:59:12,425 INFO  [com.azu.mes.ser.imp.ServiceBusReceiveLinkProcessor] (boundedElastic-2) prefetch: '0', requested: '2', linkCredits: '0', expectedTotalCredit: '2', queuedMessages:'1', creditsToAdd: '1', messageQueue.size(): '0'
   2022-01-19 23:59:12,425 INFO  [com.azu.mes.ser.imp.ServiceBusReceiveLinkProcessor] (boundedElastic-2) Link credits='0', Link credits to add: '1'
   ```
   
   


-- 
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: commits-unsubscribe@camel.apache.org

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



[GitHub] [camel-quarkus] jamesnetherton commented on issue #3474: java.lang.IllegalStateException: The stream has no active subscriptions smallrye-reactive-messaging-camel

Posted by GitBox <gi...@apache.org>.
jamesnetherton commented on issue #3474:
URL: https://github.com/apache/camel-quarkus/issues/3474#issuecomment-1017258773


   I opened a pull request on your project fix up the dependencies https://github.com/freedev/code-with-quarkus-camel/pull/1.
   
   That should allow the app to launch at least.
   
   Note that there is no Camel Quarkus extension for `camel-azure-servicebus` yet. So its not guaranteed to work 100% correctly if you just refer to the plain Camel component dependency, especially if you expect native mode support for it. See also https://github.com/apache/camel-quarkus/issues/3386.


-- 
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: commits-unsubscribe@camel.apache.org

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



[GitHub] [camel-quarkus] freedev closed issue #3474: java.lang.IllegalStateException: The stream has no active subscriptions smallrye-reactive-messaging-camel

Posted by GitBox <gi...@apache.org>.
freedev closed issue #3474:
URL: https://github.com/apache/camel-quarkus/issues/3474


   


-- 
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: commits-unsubscribe@camel.apache.org

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



[GitHub] [camel-quarkus] freedev commented on issue #3474: java.lang.IllegalStateException: The stream has no active subscriptions smallrye-reactive-messaging-camel

Posted by GitBox <gi...@apache.org>.
freedev commented on issue #3474:
URL: https://github.com/apache/camel-quarkus/issues/3474#issuecomment-1017310498


   I just had a look at #3386 but it's not clear what's missing part, well, a part the title. 
   Anyway, I've just updated https://github.com/freedev/code-with-quarkus-camel adding a proper README that explain how to do it. 


-- 
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: commits-unsubscribe@camel.apache.org

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



[GitHub] [camel-quarkus] freedev commented on issue #3474: java.lang.IllegalStateException: The stream has no active subscriptions smallrye-reactive-messaging-camel

Posted by GitBox <gi...@apache.org>.
freedev commented on issue #3474:
URL: https://github.com/apache/camel-quarkus/issues/3474#issuecomment-1017269601


   Hi thanks for helping, your pull request did the job. 
   What about add a azure service bus integration sample in https://github.com/smallrye/smallrye-reactive-messaging/tree/main/examples or even in https://github.com/apache/camel-quarkus-examples 
   Can I try a pull request?


-- 
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: commits-unsubscribe@camel.apache.org

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



[GitHub] [camel-quarkus] jamesnetherton commented on issue #3474: java.lang.IllegalStateException: The stream has no active subscriptions smallrye-reactive-messaging-camel

Posted by GitBox <gi...@apache.org>.
jamesnetherton commented on issue #3474:
URL: https://github.com/apache/camel-quarkus/issues/3474#issuecomment-1017182199


   Can you try it without the `CamelContextProducer`? Creating & managing your own `CamelContext` is something we discourage because Camel Quarkus assembles one for you at build time with various optimizations.
   
   Also add a dependency on `camel-quarkus-smallrye-reactive-messaging`.


-- 
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: commits-unsubscribe@camel.apache.org

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



[GitHub] [camel-quarkus] freedev commented on issue #3474: java.lang.IllegalStateException: The stream has no active subscriptions smallrye-reactive-messaging-camel

Posted by GitBox <gi...@apache.org>.
freedev commented on issue #3474:
URL: https://github.com/apache/camel-quarkus/issues/3474#issuecomment-1017243152


   Hi James, thanks for coming back to me! :)In the first instance I've tried `CamelContextProducer` without but failed to start quarkus.
   
        [1] Unsatisfied dependency for type org.apache.camel.CamelContext and qualifiers [@Default]
   
   This is the log:
   
   
   ```
    ~/git/personal/quarkus/code-with-quarkus-camel  master !2 ?1  mvn clean quarkus:dev                                                                                            ok
   [INFO] Scanning for projects...
   [INFO]
   [INFO] ------------< t.lux.quarkus.azure:code-with-quarkus-camel >-------------
   [INFO] Building code-with-quarkus-camel 1.0.0-SNAPSHOT
   [INFO] --------------------------------[ jar ]---------------------------------
   [INFO]
   [INFO] --- maven-clean-plugin:2.5:clean (default-clean) @ code-with-quarkus-camel ---
   [INFO] Deleting /Users/freedev/git/personal/quarkus/code-with-quarkus-camel/target
   [INFO]
   [INFO] --- quarkus-maven-plugin:2.6.2.Final:dev (default-cli) @ code-with-quarkus-camel ---
   [INFO] Invoking org.apache.maven.plugins:maven-resources-plugin:2.6:resources) @ code-with-quarkus-camel
   [INFO] Using 'UTF-8' encoding to copy filtered resources.
   [INFO] Copying 1 resource
   [INFO] Invoking io.quarkus.platform:quarkus-maven-plugin:2.6.2.Final:generate-code) @ code-with-quarkus-camel
   [INFO] Invoking org.apache.maven.plugins:maven-compiler-plugin:3.8.1:compile) @ code-with-quarkus-camel
   [INFO] Changes detected - recompiling the module!
   [INFO] Compiling 1 source file to /Users/freedev/git/personal/quarkus/code-with-quarkus-camel/target/classes
   [INFO] Invoking org.apache.maven.plugins:maven-resources-plugin:2.6:testResources) @ code-with-quarkus-camel
   [INFO] Using 'UTF-8' encoding to copy filtered resources.
   [INFO] skip non existing resourceDirectory /Users/freedev/git/personal/quarkus/code-with-quarkus-camel/src/test/resources
   [INFO] Invoking io.quarkus.platform:quarkus-maven-plugin:2.6.2.Final:generate-code-tests) @ code-with-quarkus-camel
   [INFO] Invoking org.apache.maven.plugins:maven-compiler-plugin:3.8.1:testCompile) @ code-with-quarkus-camel
   [INFO] Changes detected - recompiling the module!
   Listening for transport dt_socket at address: 5005
   2022-01-20 09:46:36,533 INFO  [io.qua.dep.dev.IsolatedDevModeMain] (main) Attempting to start live reload endpoint to recover from previous Quarkus startup failure
   2022-01-20 09:46:36,588 ERROR [io.qua.dep.dev.IsolatedDevModeMain] (main) Failed to start quarkus: java.lang.RuntimeException: io.quarkus.builder.BuildException: Build failure: Build failed due to errors
   	[error]: Build step io.quarkus.arc.deployment.ArcProcessor#validate threw an exception: javax.enterprise.inject.spi.DeploymentException: Found 2 deployment problems:
   [1] Unsatisfied dependency for type org.apache.camel.CamelContext and qualifiers [@Default]
   	- java member: t.lux.quarkus.azure.MyReactiveMessagingApplication#camelContext
   	- declared on CLASS bean [types=[t.lux.quarkus.azure.MyReactiveMessagingApplication, java.lang.Object], qualifiers=[@Default, @Any], target=t.lux.quarkus.azure.MyReactiveMessagingApplication]
   [2] Unsatisfied dependency for type org.apache.camel.CamelContext and qualifiers [@Default]
   	- java member: io.smallrye.reactive.messaging.camel.CamelConnector#camel
   	- declared on CLASS bean [types=[org.eclipse.microprofile.reactive.messaging.spi.ConnectorFactory, org.eclipse.microprofile.reactive.messaging.spi.OutgoingConnectorFactory, io.smallrye.reactive.messaging.camel.CamelConnector, org.eclipse.microprofile.reactive.messaging.spi.IncomingConnectorFactory, java.lang.Object], qualifiers=[@Connector(value = "smallrye-camel"), @Any], target=io.smallrye.reactive.messaging.camel.CamelConnector]
   	at io.quarkus.arc.processor.BeanDeployment.processErrors(BeanDeployment.java:1204)
   	at io.quarkus.arc.processor.BeanDeployment.init(BeanDeployment.java:269)
   	at io.quarkus.arc.processor.BeanProcessor.initialize(BeanProcessor.java:134)
   	at io.quarkus.arc.deployment.ArcProcessor.validate(ArcProcessor.java:454)
   	at java.base/jdk.internal.reflect.NativeMethodAccessorImpl.invoke0(Native Method)
   	at java.base/jdk.internal.reflect.NativeMethodAccessorImpl.invoke(NativeMethodAccessorImpl.java:62)
   	at java.base/jdk.internal.reflect.DelegatingMethodAccessorImpl.invoke(DelegatingMethodAccessorImpl.java:43)
   	at java.base/java.lang.reflect.Method.invoke(Method.java:566)
   	at io.quarkus.deployment.ExtensionLoader$2.execute(ExtensionLoader.java:887)
   	at io.quarkus.builder.BuildContext.run(BuildContext.java:277)
   	at org.jboss.threads.ContextHandler$1.runWith(ContextHandler.java:18)
   	at org.jboss.threads.EnhancedQueueExecutor$Task.run(EnhancedQueueExecutor.java:2449)
   	at org.jboss.threads.EnhancedQueueExecutor$ThreadBody.run(EnhancedQueueExecutor.java:1478)
   	at java.base/java.lang.Thread.run(Thread.java:829)
   	at org.jboss.threads.JBossThread.run(JBossThread.java:501)
   	Suppressed: javax.enterprise.inject.UnsatisfiedResolutionException: Unsatisfied dependency for type org.apache.camel.CamelContext and qualifiers [@Default]
   	- java member: t.lux.quarkus.azure.MyReactiveMessagingApplication#camelContext
   	- declared on CLASS bean [types=[t.lux.quarkus.azure.MyReactiveMessagingApplication, java.lang.Object], qualifiers=[@Default, @Any], target=t.lux.quarkus.azure.MyReactiveMessagingApplication]
   		at io.quarkus.arc.processor.Beans.resolveInjectionPoint(Beans.java:428)
   		at io.quarkus.arc.processor.BeanInfo.init(BeanInfo.java:508)
   		at io.quarkus.arc.processor.BeanDeployment.init(BeanDeployment.java:257)
   		... 13 more
   	Suppressed: javax.enterprise.inject.UnsatisfiedResolutionException: Unsatisfied dependency for type org.apache.camel.CamelContext and qualifiers [@Default]
   	- java member: io.smallrye.reactive.messaging.camel.CamelConnector#camel
   	- declared on CLASS bean [types=[org.eclipse.microprofile.reactive.messaging.spi.ConnectorFactory, org.eclipse.microprofile.reactive.messaging.spi.OutgoingConnectorFactory, io.smallrye.reactive.messaging.camel.CamelConnector, org.eclipse.microprofile.reactive.messaging.spi.IncomingConnectorFactory, java.lang.Object], qualifiers=[@Connector(value = "smallrye-camel"), @Any], target=io.smallrye.reactive.messaging.camel.CamelConnector]
   		at io.quarkus.arc.processor.Beans.resolveInjectionPoint(Beans.java:428)
   		at io.quarkus.arc.processor.BeanInfo.init(BeanInfo.java:508)
   		at io.quarkus.arc.processor.BeanDeployment.init(BeanDeployment.java:257)
   		... 13 more
   
   	at io.quarkus.runner.bootstrap.AugmentActionImpl.runAugment(AugmentActionImpl.java:330)
   	at io.quarkus.runner.bootstrap.AugmentActionImpl.createInitialRuntimeApplication(AugmentActionImpl.java:252)
   	at io.quarkus.runner.bootstrap.AugmentActionImpl.createInitialRuntimeApplication(AugmentActionImpl.java:60)
   	at io.quarkus.deployment.dev.IsolatedDevModeMain.firstStart(IsolatedDevModeMain.java:93)
   	at io.quarkus.deployment.dev.IsolatedDevModeMain.accept(IsolatedDevModeMain.java:456)
   	at io.quarkus.deployment.dev.IsolatedDevModeMain.accept(IsolatedDevModeMain.java:67)
   	at io.quarkus.bootstrap.app.CuratedApplication.runInCl(CuratedApplication.java:149)
   	at io.quarkus.bootstrap.app.CuratedApplication.runInAugmentClassLoader(CuratedApplication.java:105)
   	at io.quarkus.deployment.dev.DevModeMain.start(DevModeMain.java:145)
   	at io.quarkus.deployment.dev.DevModeMain.main(DevModeMain.java:63)
   Caused by: io.quarkus.builder.BuildException: Build failure: Build failed due to errors
   	[error]: Build step io.quarkus.arc.deployment.ArcProcessor#validate threw an exception: javax.enterprise.inject.spi.DeploymentException: Found 2 deployment problems:
   [1] Unsatisfied dependency for type org.apache.camel.CamelContext and qualifiers [@Default]
   	- java member: t.lux.quarkus.azure.MyReactiveMessagingApplication#camelContext
   	- declared on CLASS bean [types=[t.lux.quarkus.azure.MyReactiveMessagingApplication, java.lang.Object], qualifiers=[@Default, @Any], target=t.lux.quarkus.azure.MyReactiveMessagingApplication]
   [2] Unsatisfied dependency for type org.apache.camel.CamelContext and qualifiers [@Default]
   	- java member: io.smallrye.reactive.messaging.camel.CamelConnector#camel
   	- declared on CLASS bean [types=[org.eclipse.microprofile.reactive.messaging.spi.ConnectorFactory, org.eclipse.microprofile.reactive.messaging.spi.OutgoingConnectorFactory, io.smallrye.reactive.messaging.camel.CamelConnector, org.eclipse.microprofile.reactive.messaging.spi.IncomingConnectorFactory, java.lang.Object], qualifiers=[@Connector(value = "smallrye-camel"), @Any], target=io.smallrye.reactive.messaging.camel.CamelConnector]
   	at io.quarkus.arc.processor.BeanDeployment.processErrors(BeanDeployment.java:1204)
   	at io.quarkus.arc.processor.BeanDeployment.init(BeanDeployment.java:269)
   	at io.quarkus.arc.processor.BeanProcessor.initialize(BeanProcessor.java:134)
   	at io.quarkus.arc.deployment.ArcProcessor.validate(ArcProcessor.java:454)
   	at java.base/jdk.internal.reflect.NativeMethodAccessorImpl.invoke0(Native Method)
   	at java.base/jdk.internal.reflect.NativeMethodAccessorImpl.invoke(NativeMethodAccessorImpl.java:62)
   	at java.base/jdk.internal.reflect.DelegatingMethodAccessorImpl.invoke(DelegatingMethodAccessorImpl.java:43)
   	at java.base/java.lang.reflect.Method.invoke(Method.java:566)
   	at io.quarkus.deployment.ExtensionLoader$2.execute(ExtensionLoader.java:887)
   	at io.quarkus.builder.BuildContext.run(BuildContext.java:277)
   	at org.jboss.threads.ContextHandler$1.runWith(ContextHandler.java:18)
   	at org.jboss.threads.EnhancedQueueExecutor$Task.run(EnhancedQueueExecutor.java:2449)
   	at org.jboss.threads.EnhancedQueueExecutor$ThreadBody.run(EnhancedQueueExecutor.java:1478)
   	at java.base/java.lang.Thread.run(Thread.java:829)
   	at org.jboss.threads.JBossThread.run(JBossThread.java:501)
   	Suppressed: javax.enterprise.inject.UnsatisfiedResolutionException: Unsatisfied dependency for type org.apache.camel.CamelContext and qualifiers [@Default]
   	- java member: t.lux.quarkus.azure.MyReactiveMessagingApplication#camelContext
   	- declared on CLASS bean [types=[t.lux.quarkus.azure.MyReactiveMessagingApplication, java.lang.Object], qualifiers=[@Default, @Any], target=t.lux.quarkus.azure.MyReactiveMessagingApplication]
   		at io.quarkus.arc.processor.Beans.resolveInjectionPoint(Beans.java:428)
   		at io.quarkus.arc.processor.BeanInfo.init(BeanInfo.java:508)
   		at io.quarkus.arc.processor.BeanD(BeanDeployment.java:257)
   		... 13 more
   	Suppressed: javax.enterprise.inject.UnsatisfiedResolutionException: Unsatisfied dependency for type org.apache.camel.CamelContext and qualifiers [@Default]
   	- java member: io.smallrye.reactive.messaging.camel.CamelConnector#camel
   	- declared on CLASS bean [types=[org.eclipse.microprofile.reactive.messaging.spi.ConnectorFactory, org.eclipse.microprofile.reactive.messaging.spi.OutgoingConnectorFactory, io.smallrye.reactive.messaging.camel.CamelConnector, org.eclipse.microprofile.reactive.messaging.spi.IncomingConnectorFactory, java.lang.Object], qualifiers=[@Connector(value = "smallrye-camel"), @Any], target=io.smallrye.reactive.messaging.camel.CamelConnector]
   		at io.quarkus.arc.processor.Beans.resolveInjectionPoint(Beans.java:428)
   		at io.quarkus.arc.processor.BeanInfo.init(BeanInfo.java:508)
   		at io.quarkus.arc.processor.BeanDeployment.init(BeanDeployment.java:257)
   		... 13 more
   
   	at io.quarkus.builder.Execution.run(Execution.java:116)
   	at io.quarkus.builder.BuildExecutionBuilder.execute(BuildExecutionBuilder.java:79)
   	at io.quarkus.deployment.QuarkusAugmentor.run(QuarkusAugmentor.java:161)
   	at io.quarkus.runner.bootstrap.AugmentActionImpl.runAugment(AugmentActionImpl.java:328)
   	... 9 more
   Caused by: javax.enterprise.inject.spi.DeploymentException: Found 2 deployment problems:
   [1] Unsatisfied dependency for type org.apache.camel.CamelContext and qualifiers [@Default]
   	- java member: t.lux.quarkus.azure.MyReactiveMessagingApplication#camelContext
   	- declared on CLASS bean [types=[t.lux.quarkus.azure.MyReactiveMessagingApplication, java.lang.Object], qualifiers=[@Default, @Any], target=t.lux.quarkus.azure.MyReactiveMessagingApplication]
   [2] Unsatisfied dependency for type org.apache.camel.CamelContext and qualifiers [@Default]
   	- java member: io.smallrye.reactive.messaging.camel.CamelConnector#camel
   	- declared on CLASS bean [types=[org.eclipse.microprofile.reactive.messaging.spi.ConnectorFactory, org.eclipse.microprofile.reactive.messaging.spi.OutgoingConnectorFactory, io.smallrye.reactive.messaging.camel.CamelConnector, org.eclipse.microprofile.reactive.messaging.spi.IncomingConnectorFactory, java.lang.Object], qualifiers=[@Connector(value = "smallrye-camel"), @Any], target=io.smallrye.reactive.messaging.camel.CamelConnector]
   	at io.quarkus.arc.processor.BeanDeployment.processErrors(BeanDeployment.java:1204)
   	at io.quarkus.arc.processor.BeanDeployment.init(BeanDeployment.java:269)
   	at io.quarkus.arc.processor.BeanProcessor.initialize(BeanProcessor.java:134)
   	at io.quarkus.arc.deployment.ArcProcessor.validate(ArcProcessor.java:454)
   	at java.base/jdk.internal.reflect.NativeMethodAccessorImpl.invoke0(Native Method)
   	at java.base/jdk.internal.reflect.NativeMethodAccessorImpl.invoke(NativeMethodAccessorImpl.java:62)
   	at java.base/jdk.internal.reflect.DelegatingMethodAccessorImpl.invoke(DelegatingMethodAccessorImpl.java:43)
   	at java.base/java.lang.reflect.Method.invoke(Method.java:566)
   	at io.quarkus.deployment.ExtensionLoader$2.execute(ExtensionLoader.java:887)
   	at io.quarkus.builder.BuildContext.run(BuildContext.java:277)
   	at org.jboss.threads.ContextHandler$1.runWith(ContextHandler.java:18)
   	at org.jboss.threads.EnhancedQueueExecutor$Task.run(EnhancedQueueExecutor.java:2449)
   	at org.jboss.threads.EnhancedQueueExecutor$ThreadBody.run(EnhancedQueueExecutor.java:1478)
   	at java.base/java.lang.Thread.run(Thread.java:829)
   	at org.jboss.threads.JBossThread.run(JBossThread.java:501)
   	Suppressed: javax.enterprise.inject.UnsatisfiedResolutionException: Unsatisfied dependency for type org.apache.camel.CamelContext and qualifiers [@Default]
   	- java member: t.lux.quarkus.azure.MyReactiveMessagingApplication#camelContext
   	- declared on CLASS bean [types=[t.lux.quarkus.azure.MyReactiveMessagingApplication, java.lang.Object], qualifiers=[@Default, @Any], target=t.lux.quarkus.azure.MyReactiveMessagingApplication]
   		at io.quarkus.arc.processor.Beans.resolveInjectionPoint(Beans.java:428)
   		at io.quarkus.arc.processor.BeanInfo.init(BeanInfo.java:508)
   		at io.quarkus.arc.processor.BeanDeployment.init(BeanDeployment.java:257)
   		... 13 more
   	Suppressed: javax.enterprise.inject.UnsatisfiedResolutionException: Unsatisfied dependency for type org.apache.camel.CamelContext and qualifiers [@Default]
   	- java member: io.smallrye.reactive.messaging.camel.CamelConnector#camel
   	- declared on CLASS bean [types=[org.eclipse.microprofile.reactive.messaging.spi.ConnectorFactory, org.eclipse.microprofile.reactive.messaging.spi.OutgoingConnectorFactory, io.smallrye.reactive.messaging.camel.CamelConnector, org.eclipse.microprofile.reactive.messaging.spi.IncomingConnectorFactory, java.lang.Object], qualifiers=[@Connector(value = "smallrye-camel"), @Any], target=io.smallrye.reactive.messaging.camel.CamelConnector]
   		at io.quarkus.arc.processor.Beans.resolveInjectionPoint(Beans.java:428)
   		at io.quarkus.arc.processor.BeanInfo.init(BeanInfo.java:508)
   		at io.quarkus.arc.processor.BeanDeployment.init(BeanDeployment.java:257)
   		... 13 more
   
   
   ```


-- 
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: commits-unsubscribe@camel.apache.org

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



[GitHub] [camel-quarkus] jamesnetherton commented on issue #3474: java.lang.IllegalStateException: The stream has no active subscriptions smallrye-reactive-messaging-camel

Posted by GitBox <gi...@apache.org>.
jamesnetherton commented on issue #3474:
URL: https://github.com/apache/camel-quarkus/issues/3474#issuecomment-1017272954


   I'd wait for #3386 to be fixed before contributing an example based on `camel-azure-servicebus`.


-- 
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: commits-unsubscribe@camel.apache.org

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



[GitHub] [camel-quarkus] freedev edited a comment on issue #3474: java.lang.IllegalStateException: The stream has no active subscriptions smallrye-reactive-messaging-camel

Posted by GitBox <gi...@apache.org>.
freedev edited a comment on issue #3474:
URL: https://github.com/apache/camel-quarkus/issues/3474#issuecomment-1017310498


   I just had a look at #3386 but it's not clear what's missing part, well, apart the title. 
   Anyway, I've just updated https://github.com/freedev/code-with-quarkus-camel adding a proper README that explain how to do it. 


-- 
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: commits-unsubscribe@camel.apache.org

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