You are viewing a plain text version of this content. The canonical link for it is here.
Posted to notifications@iotdb.apache.org by "刘珍 (Jira)" <ji...@apache.org> on 2022/03/21 01:53:00 UTC

[jira] [Created] (IOTDB-2773) [Query] java.io.IOException: overlapped data should be consumed first

刘珍 created IOTDB-2773:
-------------------------

             Summary: [Query] java.io.IOException: overlapped data should be consumed first
                 Key: IOTDB-2773
                 URL: https://issues.apache.org/jira/browse/IOTDB-2773
             Project: Apache IoTDB
          Issue Type: Bug
          Components: Core/Query
    Affects Versions: 0.13.0
            Reporter: 刘珍
         Attachments: image-2022-03-21-09-52-02-258.png

iotdb版本 0.13  rc1

问题描述:
    关合并0.12生成的数据,有乱序。拿到0.12.5 rc1 和0.13 rc1 上分别执行查询(查询的时候,iotdb也都关合并),0.12.5 rc1 查询正确。
    0.13 rc1 查询报错,报错信息为:
2022-03-21 09:17:57,026 [pool-13-IoTDB-RPC-Client-1] {color:#DE350B}*WARN  *{color}o.a.i.d.u.ErrorHandlingUtils:61 - Status code: INTERNAL_SERVER_ERROR(500), operation: "SELECT max_time(s_213) FROM root.test.g_6.d_26 WHERE time >= 1537372800000 AND time <= 1537422800000". executeStatement failed
java.util.concurrent.ExecutionException: java.io.IOException: overlapped data should be consumed first
        at java.util.concurrent.FutureTask.report(FutureTask.java:122)
        at java.util.concurrent.FutureTask.get(FutureTask.java:192)
        at org.apache.iotdb.db.service.thrift.impl.TSServiceImpl.submitQueryTask(TSServiceImpl.java:785)
        at org.apache.iotdb.db.service.thrift.impl.TSServiceImpl.executeStatement(TSServiceImpl.java:619)
        at org.apache.iotdb.service.rpc.thrift.TSIService$Processor$executeStatement.getResult(TSIService.java:2853)
        at org.apache.iotdb.service.rpc.thrift.TSIService$Processor$executeStatement.getResult(TSIService.java:2833)
        at org.apache.thrift.ProcessFunction.process(ProcessFunction.java:38)
        at org.apache.thrift.TBaseProcessor.process(TBaseProcessor.java:38)
        at org.apache.thrift.server.TThreadPoolServer$WorkerProcess.run(TThreadPoolServer.java:248)
        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.io.IOException: overlapped data should be consumed first
        at org.apache.iotdb.db.query.reader.series.SeriesReader.isPageOverlapped(SeriesReader.java:657)
        at org.apache.iotdb.db.query.reader.series.SeriesAggregateReader.canUseCurrentPageStatistics(SeriesAggregateReader.java:148)
        at org.apache.iotdb.db.query.executor.AggregationExecutor.aggregatePages(AggregationExecutor.java:528)
        at org.apache.iotdb.db.query.executor.AggregationExecutor.aggregateFromReader(AggregationExecutor.java:419)
        at org.apache.iotdb.db.query.executor.AggregationExecutor.aggregateOneSeries(AggregationExecutor.java:318)
        at org.apache.iotdb.db.query.executor.AggregationExecutor.aggregateOneSeries(AggregationExecutor.java:195)
        at org.apache.iotdb.db.query.executor.AggregationExecutor.executeWithoutValueFilter(AggregationExecutor.java:149)
        at org.apache.iotdb.db.query.executor.QueryRouter.aggregate(QueryRouter.java:123)
        at org.apache.iotdb.db.qp.executor.PlanExecutor.processDataQuery(PlanExecutor.java:630)
        at org.apache.iotdb.db.qp.executor.PlanExecutor.processQuery(PlanExecutor.java:258)
        at org.apache.iotdb.db.service.basic.ServiceProvider.createQueryDataSet(ServiceProvider.java:264)
        at org.apache.iotdb.db.service.thrift.impl.TSServiceImpl.executeQueryPlan(TSServiceImpl.java:821)
        at org.apache.iotdb.db.service.thrift.impl.TSServiceImpl.access$000(TSServiceImpl.java:163)
        at org.apache.iotdb.db.service.thrift.impl.TSServiceImpl$QueryTask.call(TSServiceImpl.java:221)
        at org.apache.iotdb.db.service.thrift.impl.TSServiceImpl$QueryTask.call(TSServiceImpl.java:165)
        at java.util.concurrent.FutureTask.run(FutureTask.java:266)
        ... 3 common frames omitted

0.12.5 rc1 执行结果是
 !image-2022-03-21-09-52-02-258.png! 

问题2,这个日志,应该是error级别,不应该是warn级别。

测试环境:
192.168.10.68
iotdb路径
/data/liuzhen_test/weekly_0127/13_rc1



--
This message was sent by Atlassian Jira
(v8.20.1#820001)