Drop redundant else and fix namespace format #7073
GitHub Actions / Test Report
failed
Jun 3, 2024 in 0s
102505 tests run, 4008 skipped, 1 failed.
Annotations
Check failure on line 460 in io/trino/plugin/deltalake/TestDeltaLakeLocalConcurrentWritesTest
github-actions / Test Report
TestDeltaLakeLocalConcurrentWritesTest.testConcurrentInsertsSelectingFromMultipleNonoverlappingPartitionsOfSameTable
Failed to write Delta Lake transaction log entry
Raw output
io.trino.testing.QueryFailedException: Failed to write Delta Lake transaction log entry
at io.trino.testing.AbstractTestingTrinoClient.execute(AbstractTestingTrinoClient.java:133)
at io.trino.testing.DistributedQueryRunner.executeInternal(DistributedQueryRunner.java:554)
at io.trino.testing.DistributedQueryRunner.execute(DistributedQueryRunner.java:537)
at io.trino.testing.QueryRunner.execute(QueryRunner.java:82)
at io.trino.plugin.deltalake.TestDeltaLakeLocalConcurrentWritesTest.lambda$testConcurrentInsertsSelectingFromMultipleNonoverlappingPartitionsOfSameTable$23(TestDeltaLakeLocalConcurrentWritesTest.java:460)
at java.base/java.util.concurrent.FutureTask.run(FutureTask.java:317)
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)
Suppressed: java.lang.Exception: SQL: INSERT INTO test_concurrent_mixed_inserts_table_91pjfwetlp SELECT a + 1, part FROM test_concurrent_mixed_inserts_table_91pjfwetlp WHERE part IN (30, 40)
at io.trino.testing.DistributedQueryRunner.executeInternal(DistributedQueryRunner.java:561)
... 7 more
Caused by: io.trino.spi.TrinoException: Failed to write Delta Lake transaction log entry
at io.trino.plugin.deltalake.DeltaLakeMetadata.finishInsert(DeltaLakeMetadata.java:1999)
at io.trino.plugin.base.classloader.ClassLoaderSafeConnectorMetadata.finishInsert(ClassLoaderSafeConnectorMetadata.java:625)
at io.trino.tracing.TracingConnectorMetadata.finishInsert(TracingConnectorMetadata.java:709)
at io.trino.metadata.MetadataManager.finishInsert(MetadataManager.java:1186)
at io.trino.tracing.TracingMetadata.finishInsert(TracingMetadata.java:706)
at io.trino.sql.planner.LocalExecutionPlanner.lambda$createTableFinisher$4(LocalExecutionPlanner.java:4113)
at io.trino.operator.TableFinishOperator.getOutput(TableFinishOperator.java:319)
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_testversion____20240603_105101_477.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 reading statistics from cache
at io.trino.plugin.deltalake.statistics.CachingExtendedStatisticsAccess.readExtendedStatistics(CachingExtendedStatisticsAccess.java:67)
at io.trino.plugin.deltalake.DeltaLakeMetadata.updateTableStatistics(DeltaLakeMetadata.java:3588)
at io.trino.plugin.deltalake.DeltaLakeMetadata.finishInsert(DeltaLakeMetadata.java:1981)
... 25 more
Caused by: java.lang.IllegalArgumentException: Invalid JSON bytes for [simple type, class io.trino.plugin.deltalake.statistics.ExtendedStatistics]
at io.airlift.json.JsonCodec.fromJson(JsonCodec.java:202)
at io.trino.plugin.deltalake.statistics.MetaDirStatisticsAccess.readExtendedStatistics(MetaDirStatisticsAccess.java:75)
at io.trino.plugin.deltalake.statistics.MetaDirStatisticsAccess.readExtendedStatistics(MetaDirStatisticsAccess.java:65)
at io.trino.plugin.deltalake.statistics.CachingExtendedStatisticsAccess.lambda$readExtendedStatistics$0(CachingExtendedStatisticsAccess.java:63)
at com.google.common.cache.LocalCache$LocalManualCache$1.load(LocalCache.java:4938)
at com.google.common.cache.LocalCache$LoadingValueReference.loadFuture(LocalCache.java:3576)
at com.google.common.cache.LocalCache$Segment.loadSync(LocalCache.java:2318)
at com.google.common.cache.LocalCache$Segment.lockedGetOrLoad(LocalCache.java:2191)
at com.google.common.cache.LocalCache$Segment.get(LocalCache.java:2081)
at com.google.common.cache.LocalCache.get(LocalCache.java:4019)
at com.google.common.cache.LocalCache$LocalManualCache.get(LocalCache.java:4933)
at io.trino.cache.EvictableCache.get(EvictableCache.java:112)
at io.trino.cache.CacheUtils.uncheckedCacheGet(CacheUtils.java:37)
at io.trino.plugin.deltalake.statistics.CachingExtendedStatisticsAccess.readExtendedStatistics(CachingExtendedStatisticsAccess.java:63)
... 27 more
Caused by: com.fasterxml.jackson.databind.exc.MismatchedInputException: No content to map due to end-of-input
at [Source: REDACTED (`StreamReadFeature.INCLUDE_SOURCE_IN_LOCATION` disabled); line: 1]
at com.fasterxml.jackson.databind.exc.MismatchedInputException.from(MismatchedInputException.java:59)
at com.fasterxml.jackson.databind.DeserializationContext.reportInputMismatch(DeserializationContext.java:1767)
at com.fasterxml.jackson.databind.ObjectReader._initForReading(ObjectReader.java:360)
at com.fasterxml.jackson.databind.ObjectReader._bind(ObjectReader.java:2089)
at com.fasterxml.jackson.databind.ObjectReader.readValue(ObjectReader.java:1249)
at io.airlift.json.JsonCodec.fromJson(JsonCodec.java:197)
... 40 more
Loading