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 2020/03/25 15:51:44 UTC

[GitHub] [pulsar] JKeyZ opened a new issue #6605: support prestosql not prestodb

JKeyZ opened a new issue #6605: support prestosql not prestodb
URL: https://github.com/apache/pulsar/issues/6605
 
 
   We use prestosql, not prestodb of facebook. What’s the plan for support it ?
   
   prestosql: https://prestosql.io/ 

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


With regards,
Apache Git Services

[GitHub] [pulsar] JKeyZ edited a comment on issue #6605: support prestosql not prestodb

Posted by GitBox <gi...@apache.org>.
JKeyZ edited a comment on issue #6605: support prestosql not prestodb
URL: https://github.com/apache/pulsar/issues/6605#issuecomment-606083697
 
 
   I copy the pulsar-presto-connector from binary package to my prestodb cluster, and config the properties according to guidelines of pulsar sql.But when I run the sql, it was failed.
   config file of presto-pulsar:
   `connector.name=pulsar
   
   pulsar.broker-service-url=http://pulsarserver3:18080
   
   pulsar.zookeeper-uri=pulsarserver3:2188
   
   #pulsar.entry-read-batch-size=100
   
   pulsar.target-num-splits=4`
   
   the sql:
   `select * from pulsar."public/default"."pulsar-string";`
   
   log info:
   `2020-03-30T23:09:45.529+0800	ERROR	Query-20200330_150942_00000_ycp8z-216	org.apache.pulsar.sql.presto.PulsarSplitManager	Failed to get splits
   java.io.IOException: Failed to initialize ledger manager factory
   	at org.apache.bookkeeper.client.BookKeeper.<init>(BookKeeper.java:520)
   	at org.apache.bookkeeper.client.BookKeeper.<init>(BookKeeper.java:368)
   	at org.apache.bookkeeper.mledger.impl.ManagedLedgerFactoryImpl$DefaultBkFactory.<init>(ManagedLedgerFactoryImpl.java:183)
   	at org.apache.bookkeeper.mledger.impl.ManagedLedgerFactoryImpl.<init>(ManagedLedgerFactoryImpl.java:122)
   	at org.apache.bookkeeper.mledger.impl.ManagedLedgerFactoryImpl.<init>(ManagedLedgerFactoryImpl.java:114)
   	at org.apache.pulsar.sql.presto.PulsarConnectorCache.initManagedLedgerFactory(PulsarConnectorCache.java:108)
   	at org.apache.pulsar.sql.presto.PulsarConnectorCache.<init>(PulsarConnectorCache.java:66)
   	at org.apache.pulsar.sql.presto.PulsarConnectorCache.getConnectorCache(PulsarConnectorCache.java:83)
   	at org.apache.pulsar.sql.presto.PulsarSplitManager.getSplitsNonPartitionedTopic(PulsarSplitManager.java:224)
   	at org.apache.pulsar.sql.presto.PulsarSplitManager.getSplits(PulsarSplitManager.java:126)
   	at com.facebook.presto.split.SplitManager.getSplits(SplitManager.java:64)
   	at com.facebook.presto.sql.planner.DistributedExecutionPlanner$Visitor.visitTableScan(DistributedExecutionPlanner.java:145)
   	at com.facebook.presto.sql.planner.DistributedExecutionPlanner$Visitor.visitTableScan(DistributedExecutionPlanner.java:121)
   	at com.facebook.presto.sql.planner.plan.TableScanNode.accept(TableScanNode.java:128)
   	at com.facebook.presto.sql.planner.DistributedExecutionPlanner.doPlan(DistributedExecutionPlanner.java:107)
   	at com.facebook.presto.sql.planner.DistributedExecutionPlanner.doPlan(DistributedExecutionPlanner.java:112)
   	at com.facebook.presto.sql.planner.DistributedExecutionPlanner.plan(DistributedExecutionPlanner.java:84)
   	at com.facebook.presto.execution.SqlQueryExecution.planDistribution(SqlQueryExecution.java:404)
   	at com.facebook.presto.execution.SqlQueryExecution.start(SqlQueryExecution.java:294)
   	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: org.apache.bookkeeper.meta.exceptions.MetadataException: Failed to initialized ledger manager factory
   	at org.apache.bookkeeper.meta.zk.ZKMetadataDriverBase.getLedgerManagerFactory(ZKMetadataDriverBase.java:243)
   	at org.apache.bookkeeper.client.BookKeeper.<init>(BookKeeper.java:518)
   	... 21 more
   Caused by: java.io.IOException: Empty Ledger Root Path.
   	at org.apache.bookkeeper.meta.AbstractZkLedgerManagerFactory.newLedgerManagerFactory(AbstractZkLedgerManagerFactory.java:158)
   	at org.apache.bookkeeper.meta.zk.ZKMetadataDriverBase.getLedgerManagerFactory(ZKMetadataDriverBase.java:239)
   	... 22 more
   
   
   2020-03-30T23:09:45.578+0800	INFO	query-execution-1	com.facebook.presto.event.query.QueryMonitor	TIMELINE: Query 20200330_150942_00000_ycp8z :: Transaction:[006300e8-da04-4cd6-b619-0f5b3b0ef810] :: elapsed 2840ms :: planning 1114ms :: scheduling 1726ms :: running 0ms :: finishing 1726ms :: begin 2020-03-30T23:09:42.692+08:00 :: end 2020-03-30T23:09:45.532+08:00`
   
   prestodb version is 0.210
   

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


With regards,
Apache Git Services

[GitHub] [pulsar] sijie commented on issue #6605: support prestosql not prestodb

Posted by GitBox <gi...@apache.org>.
sijie commented on issue #6605: support prestosql not prestodb
URL: https://github.com/apache/pulsar/issues/6605#issuecomment-606226821
 
 
   Which version of pulsar-presto connector are you using?

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


With regards,
Apache Git Services

[GitHub] [pulsar] sijie commented on issue #6605: support prestosql not prestodb

Posted by GitBox <gi...@apache.org>.
sijie commented on issue #6605: support prestosql not prestodb
URL: https://github.com/apache/pulsar/issues/6605#issuecomment-604247313
 
 
   @JKeyZ they should be identical in terms of features, right? Is there any interface changes between these two features?

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


With regards,
Apache Git Services

[GitHub] [pulsar] JKeyZ commented on issue #6605: support prestosql not prestodb

Posted by GitBox <gi...@apache.org>.
JKeyZ commented on issue #6605: support prestosql not prestodb
URL: https://github.com/apache/pulsar/issues/6605#issuecomment-606384867
 
 
   pulsar version is 2.5.0

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


With regards,
Apache Git Services

[GitHub] [pulsar] JKeyZ commented on issue #6605: support prestosql not prestodb

Posted by GitBox <gi...@apache.org>.
JKeyZ commented on issue #6605: support prestosql not prestodb
URL: https://github.com/apache/pulsar/issues/6605#issuecomment-606083697
 
 
   I copy the pulsar-presto-connector from binary package to my prestodb cluster, and config the properties according to guidelines of pulsar sql.But when I run the sql, it was failed.
   config file of presto-pulsar:
   `connector.name=pulsar
   pulsar.broker-service-url=http://pulsarserver3:18080
   pulsar.zookeeper-uri=pulsarserver3:2188
   #pulsar.entry-read-batch-size=100
   pulsar.target-num-splits=4`
   
   the sql:
   `select * from pulsar."public/default"."pulsar-string";`
   
   log info:
   `2020-03-30T23:09:45.529+0800	ERROR	Query-20200330_150942_00000_ycp8z-216	org.apache.pulsar.sql.presto.PulsarSplitManager	Failed to get splits
   java.io.IOException: Failed to initialize ledger manager factory
   	at org.apache.bookkeeper.client.BookKeeper.<init>(BookKeeper.java:520)
   	at org.apache.bookkeeper.client.BookKeeper.<init>(BookKeeper.java:368)
   	at org.apache.bookkeeper.mledger.impl.ManagedLedgerFactoryImpl$DefaultBkFactory.<init>(ManagedLedgerFactoryImpl.java:183)
   	at org.apache.bookkeeper.mledger.impl.ManagedLedgerFactoryImpl.<init>(ManagedLedgerFactoryImpl.java:122)
   	at org.apache.bookkeeper.mledger.impl.ManagedLedgerFactoryImpl.<init>(ManagedLedgerFactoryImpl.java:114)
   	at org.apache.pulsar.sql.presto.PulsarConnectorCache.initManagedLedgerFactory(PulsarConnectorCache.java:108)
   	at org.apache.pulsar.sql.presto.PulsarConnectorCache.<init>(PulsarConnectorCache.java:66)
   	at org.apache.pulsar.sql.presto.PulsarConnectorCache.getConnectorCache(PulsarConnectorCache.java:83)
   	at org.apache.pulsar.sql.presto.PulsarSplitManager.getSplitsNonPartitionedTopic(PulsarSplitManager.java:224)
   	at org.apache.pulsar.sql.presto.PulsarSplitManager.getSplits(PulsarSplitManager.java:126)
   	at com.facebook.presto.split.SplitManager.getSplits(SplitManager.java:64)
   	at com.facebook.presto.sql.planner.DistributedExecutionPlanner$Visitor.visitTableScan(DistributedExecutionPlanner.java:145)
   	at com.facebook.presto.sql.planner.DistributedExecutionPlanner$Visitor.visitTableScan(DistributedExecutionPlanner.java:121)
   	at com.facebook.presto.sql.planner.plan.TableScanNode.accept(TableScanNode.java:128)
   	at com.facebook.presto.sql.planner.DistributedExecutionPlanner.doPlan(DistributedExecutionPlanner.java:107)
   	at com.facebook.presto.sql.planner.DistributedExecutionPlanner.doPlan(DistributedExecutionPlanner.java:112)
   	at com.facebook.presto.sql.planner.DistributedExecutionPlanner.plan(DistributedExecutionPlanner.java:84)
   	at com.facebook.presto.execution.SqlQueryExecution.planDistribution(SqlQueryExecution.java:404)
   	at com.facebook.presto.execution.SqlQueryExecution.start(SqlQueryExecution.java:294)
   	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: org.apache.bookkeeper.meta.exceptions.MetadataException: Failed to initialized ledger manager factory
   	at org.apache.bookkeeper.meta.zk.ZKMetadataDriverBase.getLedgerManagerFactory(ZKMetadataDriverBase.java:243)
   	at org.apache.bookkeeper.client.BookKeeper.<init>(BookKeeper.java:518)
   	... 21 more
   Caused by: java.io.IOException: Empty Ledger Root Path.
   	at org.apache.bookkeeper.meta.AbstractZkLedgerManagerFactory.newLedgerManagerFactory(AbstractZkLedgerManagerFactory.java:158)
   	at org.apache.bookkeeper.meta.zk.ZKMetadataDriverBase.getLedgerManagerFactory(ZKMetadataDriverBase.java:239)
   	... 22 more
   
   
   2020-03-30T23:09:45.578+0800	INFO	query-execution-1	com.facebook.presto.event.query.QueryMonitor	TIMELINE: Query 20200330_150942_00000_ycp8z :: Transaction:[006300e8-da04-4cd6-b619-0f5b3b0ef810] :: elapsed 2840ms :: planning 1114ms :: scheduling 1726ms :: running 0ms :: finishing 1726ms :: begin 2020-03-30T23:09:42.692+08:00 :: end 2020-03-30T23:09:45.532+08:00`
   
   prestodb version is 0.210
   

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


With regards,
Apache Git Services

[GitHub] [pulsar] JKeyZ commented on issue #6605: support prestosql not prestodb

Posted by GitBox <gi...@apache.org>.
JKeyZ commented on issue #6605: support prestosql not prestodb
URL: https://github.com/apache/pulsar/issues/6605#issuecomment-606075213
 
 
   Sorry for replay to late. Prestosql was forked from prestodb by community. The first change was name of package which change it to io.prestosql . And optimize some feature.

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


With regards,
Apache Git Services

[GitHub] [pulsar] JKeyZ commented on issue #6605: support prestosql not prestodb

Posted by GitBox <gi...@apache.org>.
JKeyZ commented on issue #6605: support prestosql not prestodb
URL: https://github.com/apache/pulsar/issues/6605#issuecomment-609042329
 
 
   When I upgrade prestodb to 0.233.1, and run the sql was failed.
   error :
   Query 20200404_150253_00025_zyyqn failed: Internal error
   
   sql: select * from  "pulsar-string" limit 10;

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


With regards,
Apache Git Services