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 2020/10/28 11:51:18 UTC

[GitHub] [camel-examples] rohanKanojia commented on pull request #27: Migrate Hazelcast Route sample to Eclipse JKube

rohanKanojia commented on pull request #27:
URL: https://github.com/apache/camel-examples/pull/27#issuecomment-717882522


   Marking this PR as draft since deployed application isn't showing expected logs:
   ```
   Oct 27, 2020 4:03:34 PM com.hazelcast.client.impl.statistics.ClientStatisticsService
   INFO: Client statistics is enabled with period 5 seconds.
   2020-10-27 16:03:34,819 [main           ] INFO  AbstractCamelContext           - Apache Camel 3.7.0-SNAPSHOT (camel-1) is starting
   2020-10-27 16:03:34,824 [main           ] INFO  AbstractCamelContext           - StreamCaching is not in use. If using streams then its recommended to enable stream caching. See more details at http://camel.apache.org/stream-caching.html
   2020-10-27 16:03:34,865 [main           ] INFO  InternalRouteStartupManager    - Route: route1 started and consuming from: timer://foo
   2020-10-27 16:03:34,867 [main           ] INFO  InternalRouteStartupManager    - Route: route2 started and consuming from: hazelcast-topic://foo
   2020-10-27 16:03:34,868 [main           ] INFO  AbstractCamelContext           - Total 2 routes, of which 2 are started
   2020-10-27 16:03:34,868 [main           ] INFO  AbstractCamelContext           - Apache Camel 3.7.0-SNAPSHOT (camel-1) started in 0.049 seconds
   2020-10-27 16:03:34,885 [main           ] INFO  BaseMainSupport                - Using properties from: classpath:application.properties;optional=true
   2020-10-27 16:03:34,914 [main           ] INFO  DefaultShutdownStrategy        - Starting to graceful shutdown 1 routes (timeout 45 seconds)
   2020-10-27 16:03:34,918 [ - ShutdownTask] INFO  DefaultShutdownStrategy        - Route: route1 shutdown complete, was consuming from: timer://foo
   2020-10-27 16:03:34,919 [main           ] INFO  DefaultShutdownStrategy        - Graceful shutdown of 1 routes completed in 0 seconds
   2020-10-27 16:03:34,920 [main           ] INFO  AbstractCamelContext           - Route: route1 is stopped, was consuming from: timer://foo
   2020-10-27 16:03:34,924 [main           ] INFO  AbstractCamelContext           - Route: route1 is shutdown and removed, was consuming from: timer://foo
   2020-10-27 16:03:34,926 [main           ] INFO  DefaultShutdownStrategy        - Starting to graceful shutdown 1 routes (timeout 45 seconds)
   2020-10-27 16:03:34,926 [ - ShutdownTask] INFO  DefaultShutdownStrategy        - Route: route2 shutdown complete, was consuming from: hazelcast-topic://foo
   2020-10-27 16:03:34,926 [main           ] INFO  DefaultShutdownStrategy        - Graceful shutdown of 1 routes completed in 0 seconds
   2020-10-27 16:03:34,936 [main           ] INFO  AbstractCamelContext           - Route: route2 is stopped, was consuming from: hazelcast-topic://foo
   2020-10-27 16:03:34,937 [main           ] INFO  AbstractCamelContext           - Route: route2 is shutdown and removed, was consuming from: hazelcast-topic://foo
   2020-10-27 16:03:34,944 [main           ] INFO  InternalRouteStartupManager    - Route: route1 started and consuming from: timer://foo
   2020-10-27 16:03:34,976 [main           ] INFO  InternalRouteStartupManager    - Route: route2 started and consuming from: hazelcast-topic://foo
   2020-10-27 16:03:34,988 [main           ] INFO  DefaultRoutesCollector         - No additional Camel XML routes discovered from: classpath:camel/*.xml
   2020-10-27 16:03:34,989 [main           ] INFO  DefaultRoutesCollector         - No additional Camel XML route templates discovered from: classpath:camel-template/*.xml
   2020-10-27 16:03:34,989 [main           ] INFO  DefaultRoutesCollector         - No additional Camel XML rests discovered from: classpath:camel-rest/*.xml
   2020-10-27 16:03:35,967 [3 - timer://foo] INFO  route1                         - Producer side: Sending data to Hazelcast topic..
   2020-10-27 16:03:35,997 [lient_1.event-3] INFO  route2                         - Consumer side: Detected following action: received
   2020-10-27 16:03:36,012 [lient_1.event-3] WARN  HazelcastTopicConsumer         - Error processing exchange for hazelcast consumer on object 'null' in cache 'foo'.. Exchange[]. Caused by: [java.util.concurrent.RejectedExecutionException - null]
   java.util.concurrent.RejectedExecutionException
       at org.apache.camel.processor.errorhandler.RedeliveryErrorHandler$SimpleTask.run(RedeliveryErrorHandler.java:381)
       at org.apache.camel.impl.engine.DefaultReactiveExecutor$Worker.schedule(DefaultReactiveExecutor.java:148)
       at org.apache.camel.impl.engine.DefaultReactiveExecutor.scheduleMain(DefaultReactiveExecutor.java:60)
       at org.apache.camel.processor.Pipeline.process(Pipeline.java:147)
       at org.apache.camel.impl.engine.CamelInternalProcessor.process(CamelInternalProcessor.java:312)
       at org.apache.camel.impl.engine.DefaultAsyncProcessorAwaitManager.process(DefaultAsyncProcessorAwaitManager.java:83)
       at org.apache.camel.support.AsyncProcessorSupport.process(AsyncProcessorSupport.java:41)
       at org.apache.camel.component.hazelcast.listener.CamelListener.sendExchange(CamelListener.java:48)
       at org.apache.camel.component.hazelcast.listener.CamelMessageListener.onMessage(CamelMessageListener.java:35)
       at com.hazelcast.client.impl.proxy.ClientTopicProxy$TopicItemHandler.handleTopicEvent(ClientTopicProxy.java:97)
       at com.hazelcast.client.impl.protocol.codec.TopicAddMessageListenerCodec$AbstractEventHandler.handle(TopicAddMessageListenerCodec.java:147)
       at com.hazelcast.client.impl.proxy.ClientTopicProxy$TopicItemHandler.handle(ClientTopicProxy.java:85)
       at com.hazelcast.client.impl.spi.impl.listener.ClientListenerServiceImpl.handleEventMessageOnCallingThread(ClientListenerServiceImpl.java:185)
       at com.hazelcast.client.impl.spi.impl.listener.ClientListenerServiceImpl$ClientEventProcessor.run(ClientListenerServiceImpl.java:354)
       at com.hazelcast.internal.util.executor.StripedExecutor$Worker.process(StripedExecutor.java:245)
       at com.hazelcast.internal.util.executor.StripedExecutor$Worker.run(StripedExecutor.java:228)
   ```


----------------------------------------------------------------
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.

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