You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@camel.apache.org by "jamesnetherton (via GitHub)" <gi...@apache.org> on 2024/01/25 11:48:41 UTC

[I] Intermittent failure of DataSetTest [camel-quarkus]

jamesnetherton opened a new issue, #5679:
URL: https://github.com/apache/camel-quarkus/issues/5679

   ### Bug description
   
   Fails occasionally with:
   
   ```
   2024-01-25T10:09:04.6415358Z 2024-01-25 10:09:04,601 ERROR [org.apa.cam.com.moc.MockEndpoint] (executor-thread-1) Caught exception on dataset://simpleDataSetIndexStrictWithoutHeader?dataSetIndex=strict due to: No 'CamelDataSetIndex' header available of type: java.lang.Long. Exchange[0DCEAC181A3EE09-0000000000000078]: org.apache.camel.NoSuchHeaderException: No 'CamelDataSetIndex' header available of type: java.lang.Long. Exchange[0DCEAC181A3EE09-0000000000000078]
   2024-01-25T10:09:04.6419650Z 	at org.apache.camel.support.ExchangeHelper.getMandatoryHeader(ExchangeHelper.java:195)
   2024-01-25T10:09:04.6421676Z 	at org.apache.camel.component.dataset.DataSetEndpoint.assertMessageExpected(DataSetEndpoint.java:270)
   2024-01-25T10:09:04.6423301Z 	at org.apache.camel.component.dataset.DataSetEndpoint.performAssertions(DataSetEndpoint.java:258)
   2024-01-25T10:09:04.6458145Z 	at org.apache.camel.component.mock.MockEndpoint.onExchange(MockEndpoint.java:1604)
   2024-01-25T10:09:04.6459602Z 	at org.apache.camel.component.mock.MockEndpoint$1.process(MockEndpoint.java:305)
   2024-01-25T10:09:04.6460965Z 	at org.apache.camel.processor.SendProcessor.process(SendProcessor.java:172)
   2024-01-25T10:09:04.6462710Z 	at org.apache.camel.processor.errorhandler.RedeliveryErrorHandler$RedeliveryTask.doRun(RedeliveryErrorHandler.java:838)
   2024-01-25T10:09:04.6466242Z 	at org.apache.camel.processor.errorhandler.RedeliveryErrorHandler$RedeliveryTask.run(RedeliveryErrorHandler.java:746)
   2024-01-25T10:09:04.6468194Z 	at org.apache.camel.impl.engine.DefaultReactiveExecutor$Worker.doRun(DefaultReactiveExecutor.java:199)
   2024-01-25T10:09:04.6470084Z 	at org.apache.camel.impl.engine.DefaultReactiveExecutor$Worker.executeReactiveWork(DefaultReactiveExecutor.java:189)
   2024-01-25T10:09:04.6472133Z 	at org.apache.camel.impl.engine.DefaultReactiveExecutor$Worker.tryExecuteReactiveWork(DefaultReactiveExecutor.java:166)
   2024-01-25T10:09:04.6474051Z 	at org.apache.camel.impl.engine.DefaultReactiveExecutor$Worker.schedule(DefaultReactiveExecutor.java:148)
   2024-01-25T10:09:04.6475802Z 	at org.apache.camel.impl.engine.DefaultReactiveExecutor.scheduleMain(DefaultReactiveExecutor.java:59)
   2024-01-25T10:09:04.6477270Z 	at org.apache.camel.processor.Pipeline.process(Pipeline.java:163)
   2024-01-25T10:09:04.6483298Z 	at org.apache.camel.impl.engine.CamelInternalProcessor.processNonTransacted(CamelInternalProcessor.java:354)
   2024-01-25T10:09:04.6485170Z 	at org.apache.camel.impl.engine.CamelInternalProcessor.process(CamelInternalProcessor.java:330)
   2024-01-25T10:09:04.6486759Z 	at org.apache.camel.component.direct.DirectProducer.process(DirectProducer.java:96)
   2024-01-25T10:09:04.6489266Z 	at org.apache.camel.impl.engine.SharedCamelInternalProcessor.processNonTransacted(SharedCamelInternalProcessor.java:199)
   2024-01-25T10:09:04.6491287Z 	at org.apache.camel.impl.engine.SharedCamelInternalProcessor.process(SharedCamelInternalProcessor.java:173)
   2024-01-25T10:09:04.6493081Z 	at org.apache.camel.impl.engine.SharedCamelInternalProcessor$1.process(SharedCamelInternalProcessor.java:109)
   2024-01-25T10:09:04.6494963Z 	at org.apache.camel.impl.engine.DefaultAsyncProcessorAwaitManager.process(DefaultAsyncProcessorAwaitManager.java:81)
   2024-01-25T10:09:04.6496863Z 	at org.apache.camel.impl.engine.SharedCamelInternalProcessor.process(SharedCamelInternalProcessor.java:106)
   2024-01-25T10:09:04.6498547Z 	at org.apache.camel.support.cache.DefaultProducerCache.send(DefaultProducerCache.java:178)
   2024-01-25T10:09:04.6500069Z 	at org.apache.camel.impl.engine.DefaultProducerTemplate.send(DefaultProducerTemplate.java:176)
   2024-01-25T10:09:04.6501659Z 	at org.apache.camel.impl.engine.DefaultProducerTemplate.send(DefaultProducerTemplate.java:172)
   2024-01-25T10:09:04.6503243Z 	at org.apache.camel.impl.engine.DefaultProducerTemplate.send(DefaultProducerTemplate.java:153)
   2024-01-25T10:09:04.6504800Z 	at org.apache.camel.impl.engine.DefaultProducerTemplate.sendBody(DefaultProducerTemplate.java:187)
   2024-01-25T10:09:04.6506401Z 	at org.apache.camel.impl.engine.DefaultProducerTemplate.sendBody(DefaultProducerTemplate.java:195)
   2024-01-25T10:09:04.6508156Z 	at org.apache.camel.quarkus.component.dataset.it.DataSetResource.dataSetIndexStrict(DataSetResource.java:268)
   2024-01-25T10:09:04.6510018Z 	at org.apache.camel.quarkus.component.dataset.it.DataSetResource_ClientProxy.dataSetIndexStrict(Unknown Source)
   2024-01-25T10:09:04.6511859Z 	at java.base/jdk.internal.reflect.NativeMethodAccessorImpl.invoke0(Native Method)
   2024-01-25T10:09:04.6513311Z 	at java.base/jdk.internal.reflect.NativeMethodAccessorImpl.invoke(NativeMethodAccessorImpl.java:77)
   2024-01-25T10:09:04.6515199Z 	at java.base/jdk.internal.reflect.DelegatingMethodAccessorImpl.invoke(DelegatingMethodAccessorImpl.java:43)
   2024-01-25T10:09:04.6516492Z 	at java.base/java.lang.reflect.Method.invoke(Method.java:568)
   2024-01-25T10:09:04.6517520Z 	at org.jboss.resteasy.core.MethodInjectorImpl.invoke(MethodInjectorImpl.java:154)
   2024-01-25T10:09:04.6518741Z 	at org.jboss.resteasy.core.MethodInjectorImpl.invoke(MethodInjectorImpl.java:118)
   2024-01-25T10:09:04.6520219Z 	at org.jboss.resteasy.core.ResourceMethodInvoker.internalInvokeOnTarget(ResourceMethodInvoker.java:560)
   2024-01-25T10:09:04.6521998Z 	at org.jboss.resteasy.core.ResourceMethodInvoker.invokeOnTargetAfterFilter(ResourceMethodInvoker.java:452)
   2024-01-25T10:09:04.6523760Z 	at org.jboss.resteasy.core.ResourceMethodInvoker.lambda$invokeOnTarget$2(ResourceMethodInvoker.java:413)
   2024-01-25T10:09:04.6525951Z 	at org.jboss.resteasy.core.interception.jaxrs.PreMatchContainerRequestContext.filter(PreMatchContainerRequestContext.java:321)
   2024-01-25T10:09:04.6527805Z 	at org.jboss.resteasy.core.ResourceMethodInvoker.invokeOnTarget(ResourceMethodInvoker.java:415)
   2024-01-25T10:09:04.6529289Z 	at org.jboss.resteasy.core.ResourceMethodInvoker.invoke(ResourceMethodInvoker.java:378)
   2024-01-25T10:09:04.6530685Z 	at org.jboss.resteasy.core.ResourceMethodInvoker.invoke(ResourceMethodInvoker.java:356)
   2024-01-25T10:09:04.6532080Z 	at org.jboss.resteasy.core.ResourceMethodInvoker.invoke(ResourceMethodInvoker.java:70)
   2024-01-25T10:09:04.6533464Z 	at org.jboss.resteasy.core.SynchronousDispatcher.invoke(SynchronousDispatcher.java:429)
   2024-01-25T10:09:04.6534922Z 	at org.jboss.resteasy.core.SynchronousDispatcher.lambda$invoke$4(SynchronousDispatcher.java:240)
   2024-01-25T10:09:04.6536500Z 	at org.jboss.resteasy.core.SynchronousDispatcher.lambda$preprocess$0(SynchronousDispatcher.java:154)
   2024-01-25T10:09:04.6538373Z 	at org.jboss.resteasy.core.interception.jaxrs.PreMatchContainerRequestContext.filter(PreMatchContainerRequestContext.java:321)
   2024-01-25T10:09:04.6540209Z 	at org.jboss.resteasy.core.SynchronousDispatcher.preprocess(SynchronousDispatcher.java:157)
   2024-01-25T10:09:04.6541625Z 	at org.jboss.resteasy.core.SynchronousDispatcher.invoke(SynchronousDispatcher.java:229)
   2024-01-25T10:09:04.6543077Z 	at io.quarkus.resteasy.runtime.standalone.RequestDispatcher.service(RequestDispatcher.java:82)
   2024-01-25T10:09:04.6544671Z 	at io.quarkus.resteasy.runtime.standalone.VertxRequestHandler.dispatch(VertxRequestHandler.java:147)
   2024-01-25T10:09:04.6546238Z 	at io.quarkus.resteasy.runtime.standalone.VertxRequestHandler$1.run(VertxRequestHandler.java:93)
   2024-01-25T10:09:04.6547694Z 	at io.quarkus.vertx.core.runtime.VertxCoreRecorder$14.runWith(VertxCoreRecorder.java:582)
   2024-01-25T10:09:04.6549040Z 	at org.jboss.threads.EnhancedQueueExecutor$Task.run(EnhancedQueueExecutor.java:2513)
   2024-01-25T10:09:04.6550386Z 	at org.jboss.threads.EnhancedQueueExecutor$ThreadBody.run(EnhancedQueueExecutor.java:1538)
   2024-01-25T10:09:04.6551640Z 	at org.jboss.threads.DelegatingRunnable.run(DelegatingRunnable.java:29)
   2024-01-25T10:09:04.6552928Z 	at org.jboss.threads.ThreadLocalResettingRunnable.run(ThreadLocalResettingRunnable.java:29)
   2024-01-25T10:09:04.6554379Z 	at io.netty.util.concurrent.FastThreadLocalRunnable.run(FastThreadLocalRunnable.java:30)
   2024-01-25T10:09:04.6555457Z 	at java.base/java.lang.Thread.run(Thread.java:840)
   20
   ```


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

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


Re: [I] Intermittent failure of DataSetTest [camel-quarkus]

Posted by "spatnity (via GitHub)" <gi...@apache.org>.
spatnity commented on issue #5679:
URL: https://github.com/apache/camel-quarkus/issues/5679#issuecomment-1914607925

   I'd want to work on this.
   


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


Re: [I] Intermittent failure of DataSetTest [camel-quarkus]

Posted by "jamesnetherton (via GitHub)" <gi...@apache.org>.
jamesnetherton commented on issue #5679:
URL: https://github.com/apache/camel-quarkus/issues/5679#issuecomment-1914756083

   Seems I totally misread the CI build logs. The actual failure was in `EipTest.throttle`:
   
   ```
   2024-01-25T10:09:30.7914371Z [ERROR] Tests run: 22, Failures: 0, Errors: 1, Skipped: 0, Time elapsed: 15.71 s <<< FAILURE! -- in org.apache.camel.quarkus.eip.it.EipTest
   2024-01-25T10:09:30.7917689Z [ERROR] org.apache.camel.quarkus.eip.it.EipTest.throttle -- Time elapsed: 10.12 s <<< ERROR!
   2024-01-25T10:09:30.7919831Z org.awaitility.core.ConditionTimeoutException: Condition with org.apache.camel.quarkus.eip.it.EipTest was not fulfilled within 10 seconds.
   2024-01-25T10:09:30.7921922Z 	at org.awaitility.core.ConditionAwaiter.await(ConditionAwaiter.java:167)
   2024-01-25T10:09:30.7923262Z 	at org.awaitility.core.CallableCondition.await(CallableCondition.java:78)
   2024-01-25T10:09:30.7924468Z 	at org.awaitility.core.CallableCondition.await(CallableCondition.java:26)
   2024-01-25T10:09:30.7925667Z 	at org.awaitility.core.ConditionFactory.until(ConditionFactory.java:985)
   2024-01-25T10:09:30.7929861Z 	at org.awaitility.core.ConditionFactory.until(ConditionFactory.java:954)
   2024-01-25T10:09:30.7931228Z 	at org.apache.camel.quarkus.eip.it.EipTest.throttle(EipTest.java:488)
   2024-01-25T10:09:30.7932375Z 	at java.base/java.lang.reflect.Method.invoke(Method.java:568)
   2024-01-25T10:09:30.7933750Z 	at io.quarkus.test.junit.QuarkusTestExtension.runExtensionMethod(QuarkusTestExtension.java:1013)
   2024-01-25T10:09:30.7935757Z 	at io.quarkus.test.junit.QuarkusTestExtension.interceptTestMethod(QuarkusTestExtension.java:827)
   2024-01-25T10:09:30.7937637Z 	at java.base/java.util.ArrayList.forEach(ArrayList.java:1511)
   2024-01-25T10:09:30.7938647Z 	at java.base/java.util.ArrayList.forEach(ArrayList.java:1511)
   ```
   
   Seems the mock endpoint expectation is not fulfilled in time.


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


Re: [I] Intermittent failure of EipTest.throttle [camel-quarkus]

Posted by "jamesnetherton (via GitHub)" <gi...@apache.org>.
jamesnetherton commented on issue #5679:
URL: https://github.com/apache/camel-quarkus/issues/5679#issuecomment-1915106960

   This failure just happened on the Quarkus Platform CI build too.


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