Trino Cannot Establish Connection to Thrift Server #22654
Unanswered
bpfinnerty
asked this question in
Q&A
Replies: 0 comments
Sign up for free
to join this conversation on GitHub.
Already have an account?
Sign in to comment
Uh oh!
There was an error while loading. Please reload this page.
Uh oh!
There was an error while loading. Please reload this page.
-
I've been trying to connect Trino to a thrift server I implemented using the TrinoThriftService. But when I try to query schemas I receive a failed connection. Currently, everything is running inside the same docker container, with my apache thrift server pointing to localhost:9090. I was able to implement a Thrift client to interface with my thrift server, but could not get Trino to do so. Any Advice?
.properties file:
connector.name=trino_thrift
trino.thrift.client.addresses=localhost:9090
Output
io.trino.spi.TrinoException: Error listing schemas for catalog thrift: Error communicating with remote Thrift server
at io.trino.metadata.MetadataListing.handleListingException(MetadataListing.java:358)
at io.trino.metadata.MetadataListing.listSchemas(MetadataListing.java:99)
at io.trino.metadata.MetadataListing.listSchemas(MetadataListing.java:90)
at io.trino.connector.informationschema.InformationSchemaPageSource.addSchemataRecords(InformationSchemaPageSource.java:331)
at io.trino.connector.informationschema.InformationSchemaPageSource.buildPages(InformationSchemaPageSource.java:227)
at io.trino.connector.informationschema.InformationSchemaPageSource.getNextPage(InformationSchemaPageSource.java:185)
at io.trino.operator.TableScanOperator.getOutput(TableScanOperator.java:268)
at io.trino.operator.Driver.processInternal(Driver.java:403)
at io.trino.operator.Driver.lambda$process$8(Driver.java:306)
at io.trino.operator.Driver.tryWithLock(Driver.java:709)
at io.trino.operator.Driver.process(Driver.java:298)
at io.trino.operator.Driver.processForDuration(Driver.java:269)
at io.trino.execution.SqlTaskExecution$DriverSplitRunner.processFor(SqlTaskExecution.java:890)
at io.trino.execution.executor.dedicated.SplitProcessor.run(SplitProcessor.java:77)
at io.trino.execution.executor.dedicated.TaskEntry$VersionEmbedderBridge.lambda$run$0(TaskEntry.java:191)
at io.trino.$gen.Trino_451____20240711_154950_2.run(Unknown Source)
at io.trino.execution.executor.dedicated.TaskEntry$VersionEmbedderBridge.run(TaskEntry.java:192)
at io.trino.execution.executor.scheduler.FairScheduler.runTask(FairScheduler.java:168)
at io.trino.execution.executor.scheduler.FairScheduler.lambda$submit$0(FairScheduler.java:155)
at java.base/java.util.concurrent.Executors$RunnableAdapter.call(Executors.java:572)
at com.google.common.util.concurrent.TrustedListenableFutureTask$TrustedFutureInterruptibleTask.runInterruptibly(TrustedListenableFutureTask.java:131)
at com.google.common.util.concurrent.InterruptibleTask.run(InterruptibleTask.java:76)
at com.google.common.util.concurrent.TrustedListenableFutureTask.run(TrustedListenableFutureTask.java:82)
at java.base/java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1144)
at java.base/java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:642)
at java.base/java.lang.Thread.run(Thread.java:1570)
Caused by: io.trino.spi.TrinoException: Error communicating with remote Thrift server
at io.trino.plugin.thrift.util.ThriftExceptions.toTrinoException(ThriftExceptions.java:44)
at io.trino.plugin.thrift.ThriftMetadata.listSchemaNames(ThriftMetadata.java:105)
at io.trino.tracing.TracingConnectorMetadata.listSchemaNames(TracingConnectorMetadata.java:132)
at io.trino.metadata.MetadataManager.listSchemaNames(MetadataManager.java:255)
at io.trino.tracing.TracingMetadata.listSchemaNames(TracingMetadata.java:172)
at io.trino.metadata.MetadataListing.doListSchemas(MetadataListing.java:105)
at io.trino.metadata.MetadataListing.listSchemas(MetadataListing.java:96)
... 24 more
Caused by: io.airlift.drift.protocol.TTransportException: Client was disconnected by server
at io.airlift.drift.transport.netty.client.ThriftClientHandler.channelInactive(ThriftClientHandler.java:206)
at io.netty.channel.AbstractChannelHandlerContext.invokeChannelInactive(AbstractChannelHandlerContext.java:303)
at io.netty.channel.AbstractChannelHandlerContext.invokeChannelInactive(AbstractChannelHandlerContext.java:281)
at io.netty.channel.AbstractChannelHandlerContext.fireChannelInactive(AbstractChannelHandlerContext.java:274)
at io.netty.handler.codec.ByteToMessageDecoder.channelInputClosed(ByteToMessageDecoder.java:412)
at io.netty.handler.codec.ByteToMessageDecoder.channelInactive(ByteToMessageDecoder.java:377)
at io.netty.channel.AbstractChannelHandlerContext.invokeChannelInactive(AbstractChannelHandlerContext.java:303)
at io.netty.channel.AbstractChannelHandlerContext.invokeChannelInactive(AbstractChannelHandlerContext.java:281)
at io.netty.channel.AbstractChannelHandlerContext.fireChannelInactive(AbstractChannelHandlerContext.java:274)
at io.netty.channel.DefaultChannelPipeline$HeadContext.channelInactive(DefaultChannelPipeline.java:1402)
at io.netty.channel.AbstractChannelHandlerContext.invokeChannelInactive(AbstractChannelHandlerContext.java:301)
at io.netty.channel.AbstractChannelHandlerContext.invokeChannelInactive(AbstractChannelHandlerContext.java:281)
at io.netty.channel.DefaultChannelPipeline.fireChannelInactive(DefaultChannelPipeline.java:900)
at io.netty.channel.AbstractChannel$AbstractUnsafe$7.run(AbstractChannel.java:811)
at io.netty.util.concurrent.AbstractEventExecutor.runTask(AbstractEventExecutor.java:173)
at io.netty.util.concurrent.AbstractEventExecutor.safeExecute(AbstractEventExecutor.java:166)
at io.netty.util.concurrent.SingleThreadEventExecutor.runAllTasks(SingleThreadEventExecutor.java:469)
at io.netty.channel.nio.NioEventLoop.run(NioEventLoop.java:566)
at io.netty.util.concurrent.SingleThreadEventExecutor$4.run(SingleThreadEventExecutor.java:994)
at io.netty.util.internal.ThreadExecutorMap$2.run(ThreadExecutorMap.java:74)
... 1 more
Suppressed: io.airlift.drift.client.RetriesFailedException: Max retry attempts (5) exceeded (invocationAttempts: 6, duration: 3.21s, failedConnections: 0, overloadedRejects: 0)
at io.airlift.drift.client.DriftMethodInvocation.fail(DriftMethodInvocation.java:330)
at io.airlift.drift.client.DriftMethodInvocation.handleFailure(DriftMethodInvocation.java:252)
at io.airlift.drift.client.DriftMethodInvocation$1.onFailure(DriftMethodInvocation.java:203)
at com.google.common.util.concurrent.Futures$CallbackListener.run(Futures.java:1122)
at com.google.common.util.concurrent.DirectExecutor.execute(DirectExecutor.java:31)
at com.google.common.util.concurrent.AbstractFuture.executeListener(AbstractFuture.java:1298)
at com.google.common.util.concurrent.AbstractFuture.complete(AbstractFuture.java:1059)
at com.google.common.util.concurrent.AbstractFuture.setFuture(AbstractFuture.java:852)
at com.google.common.util.concurrent.AbstractCatchingFuture.run(AbstractCatchingFuture.java:126)
at com.google.common.util.concurrent.DirectExecutor.execute(DirectExecutor.java:31)
at com.google.common.util.concurrent.AbstractFuture.executeListener(AbstractFuture.java:1298)
at com.google.common.util.concurrent.AbstractFuture.complete(AbstractFuture.java:1059)
at com.google.common.util.concurrent.AbstractFuture.setFuture(AbstractFuture.java:852)
at com.google.common.util.concurrent.TimeoutFuture$Fire.run(TimeoutFuture.java:121)
at com.google.common.util.concurrent.DirectExecutor.execute(DirectExecutor.java:31)
at com.google.common.util.concurrent.AbstractFuture.executeListener(AbstractFuture.java:1298)
at com.google.common.util.concurrent.AbstractFuture.complete(AbstractFuture.java:1059)
at com.google.common.util.concurrent.AbstractFuture.setException(AbstractFuture.java:809)
at io.airlift.drift.transport.netty.client.InvocationResponseFuture.fatalError(InvocationResponseFuture.java:174)
at io.airlift.drift.transport.netty.client.InvocationResponseFuture$1.onFailure(InvocationResponseFuture.java:127)
at com.google.common.util.concurrent.Futures$CallbackListener.run(Futures.java:1130)
at com.google.common.util.concurrent.DirectExecutor.execute(DirectExecutor.java:31)
at com.google.common.util.concurrent.AbstractFuture.executeListener(AbstractFuture.java:1298)
at com.google.common.util.concurrent.AbstractFuture.complete(AbstractFuture.java:1059)
at com.google.common.util.concurrent.AbstractFuture.setException(AbstractFuture.java:809)
at io.airlift.drift.transport.netty.client.ThriftClientHandler$ThriftRequest.failed(ThriftClientHandler.java:306)
at io.airlift.drift.transport.netty.client.ThriftClientHandler$RequestHandler.onChannelError(ThriftClientHandler.java:498)
at io.airlift.drift.transport.netty.client.ThriftClientHandler.lambda$onError$2(ThriftClientHandler.java:242)
at java.base/java.util.concurrent.ConcurrentHashMap.removeValueIf(ConcurrentHashMap.java:1661)
at java.base/java.util.concurrent.ConcurrentHashMap$ValuesView.removeIf(ConcurrentHashMap.java:4768)
at io.airlift.drift.transport.netty.client.ThriftClientHandler.onError(ThriftClientHandler.java:241)
... 21 more
Beta Was this translation helpful? Give feedback.
All reactions