You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@pulsar.apache.org by GitBox <gi...@apache.org> on 2021/02/04 04:50:42 UTC

[GitHub] [pulsar] merlimat opened a new issue #9470: CI is broken on master failing on SQL integration test

merlimat opened a new issue #9470:
URL: https://github.com/apache/pulsar/issues/9470


   cc/ @hnail 
   
   After merging #8422 into master, the SQL integration tests are consistently failing now and are blocking all other changes. 
   
   Example:
   
   https://github.com/apache/pulsar/pull/9435/checks?check_run_id=1820086019
   
   The cause of the failure seems to be this exception: 
   
   ```
   2021-02-04T02:36:25.065Z	ERROR	remote-task-callback-9	io.prestosql.execution.StageStateMachine	Stage 20210204_023618_00011_x982w.2 failed
   java.lang.RuntimeException: java.util.concurrent.ExecutionException: org.apache.pulsar.client.admin.PulsarAdminException: java.util.concurrent.ExecutionException: org.apache.pulsar.client.admin.PulsarAdminException$GettingAuthenticationDataException: java.lang.ClassCastException: Cannot cast org.glassfish.jersey.inject.hk2.Hk2InjectionManagerFactory to org.glassfish.jersey.internal.inject.InjectionManagerFactory
   	at org.apache.pulsar.sql.presto.PulsarRecordCursor.advanceNextPosition(PulsarRecordCursor.java:448)
   	at io.prestosql.spi.connector.RecordPageSource.getNextPage(RecordPageSource.java:90)
   	at io.prestosql.operator.TableScanOperator.getOutput(TableScanOperator.java:302)
   	at io.prestosql.operator.Driver.processInternal(Driver.java:379)
   	at io.prestosql.operator.Driver.lambda$processFor$8(Driver.java:283)
   	at io.prestosql.operator.Driver.tryWithLock(Driver.java:675)
   	at io.prestosql.operator.Driver.processFor(Driver.java:276)
   	at io.prestosql.execution.SqlTaskExecution$DriverSplitRunner.processFor(SqlTaskExecution.java:1075)
   	at io.prestosql.execution.executor.PrioritizedSplitRunner.process(PrioritizedSplitRunner.java:163)
   	at io.prestosql.execution.executor.TaskExecutor$TaskRunner.run(TaskExecutor.java:484)
   	at io.prestosql.$gen.Presto_332__testversion____20210204_023425_2.run(Unknown Source)
   	at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
   	at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
   	at java.lang.Thread.run(Thread.java:748)
   Caused by: java.util.concurrent.ExecutionException: org.apache.pulsar.client.admin.PulsarAdminException: java.util.concurrent.ExecutionException: org.apache.pulsar.client.admin.PulsarAdminException$GettingAuthenticationDataException: java.lang.ClassCastException: Cannot cast org.glassfish.jersey.inject.hk2.Hk2InjectionManagerFactory to org.glassfish.jersey.internal.inject.InjectionManagerFactory
   	at java.util.concurrent.CompletableFuture.reportGet(CompletableFuture.java:357)
   	at java.util.concurrent.CompletableFuture.get(CompletableFuture.java:1908)
   	at org.apache.pulsar.sql.presto.PulsarRecordCursor.advanceNextPosition(PulsarRecordCursor.java:446)
   	... 13 more
   Caused by: org.apache.pulsar.client.admin.PulsarAdminException: java.util.concurrent.ExecutionException: org.apache.pulsar.client.admin.PulsarAdminException$GettingAuthenticationDataException: java.lang.ClassCastException: Cannot cast org.glassfish.jersey.inject.hk2.Hk2InjectionManagerFactory to org.glassfish.jersey.internal.inject.InjectionManagerFactory
   	at org.apache.pulsar.client.admin.internal.BaseResource.getApiException(BaseResource.java:229)
   	at org.apache.pulsar.client.admin.internal.SchemasImpl$3.failed(SchemasImpl.java:150)
   	at org.apache.pulsar.client.admin.internal.BaseResource.asyncGetRequest(BaseResource.java:166)
   	at org.apache.pulsar.client.admin.internal.SchemasImpl.getSchemaInfoAsync(SchemasImpl.java:141)
   	at org.apache.pulsar.client.admin.internal.SchemasImpl.getSchemaInfo(SchemasImpl.java:125)
   	at org.apache.pulsar.sql.presto.PulsarSqlSchemaInfoProvider.loadSchema(PulsarSqlSchemaInfoProvider.java:102)
   	at org.apache.pulsar.sql.presto.PulsarSqlSchemaInfoProvider.access$000(PulsarSqlSchemaInfoProvider.java:48)
   	at org.apache.pulsar.sql.presto.PulsarSqlSchemaInfoProvider$1.load(PulsarSqlSchemaInfoProvider.java:60)
   	at org.apache.pulsar.sql.presto.PulsarSqlSchemaInfoProvider$1.load(PulsarSqlSchemaInfoProvider.java:57)
   	at com.google.common.cache.LocalCache$LoadingValueReference.loadFuture(LocalCache.java:3529)
   	at com.google.common.cache.LocalCache$Segment.loadSync(LocalCache.java:2278)
   	at com.google.common.cache.LocalCache$Segment.lockedGetOrLoad(LocalCache.java:2155)
   	at com.google.common.cache.LocalCache$Segment.get(LocalCache.java:2045)
   	at com.google.common.cache.LocalCache.get(LocalCache.java:3951)
   	at com.google.common.cache.LocalCache.getOrLoad(LocalCache.java:3974)
   	at com.google.common.cache.LocalCache$LocalLoadingCache.get(LocalCache.java:4935)
   	at org.apache.pulsar.sql.presto.PulsarSqlSchemaInfoProvider.getSchemaByVersion(PulsarSqlSchemaInfoProvider.java:75)
   	... 14 more
   Caused by: java.util.concurrent.ExecutionException: org.apache.pulsar.client.admin.PulsarAdminException$GettingAuthenticationDataException: java.lang.ClassCastException: Cannot cast org.glassfish.jersey.inject.hk2.Hk2InjectionManagerFactory to org.glassfish.jersey.internal.inject.InjectionManagerFactory
   	at java.util.concurrent.CompletableFuture.reportGet(CompletableFuture.java:357)
   	at java.util.concurrent.CompletableFuture.get(CompletableFuture.java:1908)
   	at org.apache.pulsar.client.admin.internal.BaseResource.request(BaseResource.java:67)
   	at org.apache.pulsar.client.admin.internal.BaseResource.asyncGetRequest(BaseResource.java:164)
   	... 28 more
   Caused by: org.apache.pulsar.client.admin.PulsarAdminException.GettingAuthenticationDataException: java.lang.ClassCastException: Cannot cast org.glassfish.jersey.inject.hk2.Hk2InjectionManagerFactory to org.glassfish.jersey.internal.inject.InjectionManagerFactory
   	at org.apache.pulsar.client.admin.internal.BaseResource.lambda$requestAsync$1(BaseResource.java:106)
   	at java.util.concurrent.CompletableFuture.uniWhenComplete(CompletableFuture.java:774)
   	at java.util.concurrent.CompletableFuture.uniWhenCompleteStage(CompletableFuture.java:792)
   	at java.util.concurrent.CompletableFuture.whenComplete(CompletableFuture.java:2153)
   	at org.apache.pulsar.client.admin.internal.BaseResource.requestAsync(BaseResource.java:87)
   	... 30 more
   Caused by: java.lang.ClassCastException: Cannot cast org.glassfish.jersey.inject.hk2.Hk2InjectionManagerFactory to org.glassfish.jersey.internal.inject.InjectionManagerFactory
   	at java.lang.Class.cast(Class.java:3369)
   	at org.glassfish.jersey.internal.ServiceFinder$LazyObjectIterator.hasNext(ServiceFinder.java:690)
   	at org.glassfish.jersey.internal.inject.Injections.lookupService(Injections.java:88)
   	at org.glassfish.jersey.internal.inject.Injections.lookupInjectionManagerFactory(Injections.java:73)
   	at org.glassfish.jersey.internal.inject.Injections.createInjectionManager(Injections.java:44)
   	at org.glassfish.jersey.client.ClientConfig$State.initRuntime(ClientConfig.java:412)
   	at org.glassfish.jersey.internal.util.collection.Values$LazyValueImpl.get(Values.java:317)
   	at org.glassfish.jersey.client.ClientConfig.getRuntime(ClientConfig.java:807)
   	at org.glassfish.jersey.client.ClientRequest.getClientRuntime(ClientRequest.java:219)
   	at org.glassfish.jersey.client.ClientRequest.getInjectionManager(ClientRequest.java:610)
   	at org.glassfish.jersey.client.JerseyWebTarget.onBuilder(JerseyWebTarget.java:364)
   	at org.glassfish.jersey.client.JerseyWebTarget.request(JerseyWebTarget.java:199)
   	at org.glassfish.jersey.client.JerseyWebTarget.request(JerseyWebTarget.java:36)
   	at org.apache.pulsar.client.admin.internal.BaseResource.lambda$requestAsync$1(BaseResource.java:96)
   	... 34 more
   ```
   
   I'd suggest to revert the commit to unblock master while the tests can be fixed.


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



[GitHub] [pulsar] hnail commented on issue #9470: CI is broken on master failing on SQL integration test

Posted by GitBox <gi...@apache.org>.
hnail commented on issue #9470:
URL: https://github.com/apache/pulsar/issues/9470#issuecomment-773103778


   That error looks same as [Pulsar SQL Fails Out of the Box with Default Docker Deployment v2.5.0 #6501](https://github.com/apache/pulsar/issues/6501) , are you sure this is caused by #8422 ? cc @gaoran10 


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



[GitHub] [pulsar] codelipenghui closed issue #9470: CI is broken on master failing on SQL integration test

Posted by GitBox <gi...@apache.org>.
codelipenghui closed issue #9470:
URL: https://github.com/apache/pulsar/issues/9470


   


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



[GitHub] [pulsar] codelipenghui closed issue #9470: CI is broken on master failing on SQL integration test

Posted by GitBox <gi...@apache.org>.
codelipenghui closed issue #9470:
URL: https://github.com/apache/pulsar/issues/9470


   


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



[GitHub] [pulsar] hnail edited a comment on issue #9470: CI is broken on master failing on SQL integration test

Posted by GitBox <gi...@apache.org>.
hnail edited a comment on issue #9470:
URL: https://github.com/apache/pulsar/issues/9470#issuecomment-773103778


   That error looks same as [Pulsar SQL Fails Out of the Box with Default Docker Deployment v2.5.0 #6501](https://github.com/apache/pulsar/issues/6501) , maybe this is not caused by #8422 ? cc @gaoran10 


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



[GitHub] [pulsar] hnail commented on issue #9470: CI is broken on master failing on SQL integration test

Posted by GitBox <gi...@apache.org>.
hnail commented on issue #9470:
URL: https://github.com/apache/pulsar/issues/9470#issuecomment-773103778


   That error looks same as [Pulsar SQL Fails Out of the Box with Default Docker Deployment v2.5.0 #6501](https://github.com/apache/pulsar/issues/6501) , are you sure this is caused by #8422 ? cc @gaoran10 


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



[GitHub] [pulsar] hnail edited a comment on issue #9470: CI is broken on master failing on SQL integration test

Posted by GitBox <gi...@apache.org>.
hnail edited a comment on issue #9470:
URL: https://github.com/apache/pulsar/issues/9470#issuecomment-773103778


   That error looks same as [Pulsar SQL Fails Out of the Box with Default Docker Deployment v2.5.0 #6501](https://github.com/apache/pulsar/issues/6501) , maybe this is not caused by #8422 ? cc @gaoran10 


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