You are viewing a plain text version of this content. The canonical link for it is here.
Posted to notifications@iotdb.apache.org by "Yukun Zhou (Jira)" <ji...@apache.org> on 2022/11/24 09:09:00 UTC

[jira] [Assigned] (IOTDB-5038) [schema]create timeseries return 301 null occasionally

     [ https://issues.apache.org/jira/browse/IOTDB-5038?page=com.atlassian.jira.plugin.system.issuetabpanels:all-tabpanel ]

Yukun Zhou reassigned IOTDB-5038:
---------------------------------

    Assignee: Song Ziyang  (was: Jinrui Zhang)

> [schema]create timeseries return 301 null occasionally
> ------------------------------------------------------
>
>                 Key: IOTDB-5038
>                 URL: https://issues.apache.org/jira/browse/IOTDB-5038
>             Project: Apache IoTDB
>          Issue Type: Bug
>          Components: Core/Server
>    Affects Versions: 0.14.0-SNAPSHOT
>            Reporter: changxue
>            Assignee: Song Ziyang
>            Priority: Major
>         Attachments: image-2022-11-24-16-45-14-814.png
>
>
> [schema]create timeseries return 301 null occasionally
> environment:
> 3C3D cluster,  Nov.24 14:40 source codes
> reproduction:
> 1. restart computer
> 2. start iotdb cluster
> 3. run create timeseries quickly
>  !image-2022-11-24-16-45-14-814.png! 
>  
> It could not reproduce each time but I met this several times and I cut datanode logs of one of them.
> {code:java}
> 2022-11-24 14:53:29,533 [pool-25-IoTDB-ClientRPC-Processor-1$20221124_065323_00002_1.1.0] ERROR o.a.i.c.r.RatisConsensus:681 - org.apache.iotdb.consensus.ratis.RatisConsensus@6caa204e write request failed with exception {}
> org.apache.iotdb.consensus.exception.RatisRequestFailedException: Ratis request failed
>         at org.apache.iotdb.consensus.ratis.RatisConsensus.write(RatisConsensus.java:277)
>         at org.apache.iotdb.db.mpp.execution.executor.RegionWriteExecutor$WritePlanNodeExecutionVisitor.executePlanNodeInConsensusLayer(RegionWriteExecutor.java:152)
>         at org.apache.iotdb.db.mpp.execution.executor.RegionWriteExecutor$WritePlanNodeExecutionVisitor.visitPlan(RegionWriteExecutor.java:129)
>         at org.apache.iotdb.db.mpp.execution.executor.RegionWriteExecutor$WritePlanNodeExecutionVisitor.visitPlan(RegionWriteExecutor.java:119)
>         at org.apache.iotdb.db.mpp.plan.planner.plan.node.PlanVisitor.visitCreateTimeSeries(PlanVisitor.java:203)
>         at org.apache.iotdb.db.mpp.execution.executor.RegionWriteExecutor$WritePlanNodeExecutionVisitor.visitCreateTimeSeries(RegionWriteExecutor.java:279)
>         at org.apache.iotdb.db.mpp.execution.executor.RegionWriteExecutor$WritePlanNodeExecutionVisitor.visitCreateTimeSeries(RegionWriteExecutor.java:119)
>         at org.apache.iotdb.db.mpp.plan.planner.plan.node.metedata.write.CreateTimeSeriesNode.accept(CreateTimeSeriesNode.java:345)
>         at org.apache.iotdb.db.mpp.execution.executor.RegionWriteExecutor.execute(RegionWriteExecutor.java:85)
>         at org.apache.iotdb.db.mpp.plan.scheduler.FragmentInstanceDispatcherImpl.dispatchLocally(FragmentInstanceDispatcherImpl.java:232)
>         at org.apache.iotdb.db.mpp.plan.scheduler.FragmentInstanceDispatcherImpl.dispatchLocally(FragmentInstanceDispatcherImpl.java:232)
>         at org.apache.iotdb.db.mpp.plan.scheduler.FragmentInstanceDispatcherImpl.dispatchOneInstance(FragmentInstanceDispatcherImpl.java:137)
>         at org.apache.iotdb.db.mpp.plan.scheduler.FragmentInstanceDispatcherImpl.dispatchWriteSync(FragmentInstanceDispatcherImpl.java:119)
>         at org.apache.iotdb.db.mpp.plan.scheduler.FragmentInstanceDispatcherImpl.dispatch(FragmentInstanceDispatcherImpl.java:90)
>         at org.apache.iotdb.db.mpp.plan.scheduler.ClusterScheduler.start(ClusterScheduler.java:106)
>         at org.apache.iotdb.db.mpp.plan.execution.QueryExecution.schedule(QueryExecution.java:288)
>         at org.apache.iotdb.db.mpp.plan.execution.QueryExecution.start(QueryExecution.java:206)
>         at org.apache.iotdb.db.mpp.plan.Coordinator.execute(Coordinator.java:150)
>         at org.apache.iotdb.db.service.thrift.impl.ClientRPCServiceImpl.executeStatementInternal(ClientRPCServiceImpl.java:215)
>         at org.apache.iotdb.db.service.thrift.impl.ClientRPCServiceImpl.executeStatementV2(ClientRPCServiceImpl.java:390)
>         at org.apache.iotdb.service.rpc.thrift.IClientRPCService$Processor$executeStatementV2.getResult(IClientRPCService.java:3453)
>         at org.apache.iotdb.service.rpc.thrift.IClientRPCService$Processor$executeStatementV2.getResult(IClientRPCService.java:3433)
>         at org.apache.thrift.ProcessFunction.process(ProcessFunction.java:38)
>         at org.apache.iotdb.db.service.thrift.ProcessorWithMetrics.process(ProcessorWithMetrics.java:64)
>         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: org.apache.ratis.protocol.exceptions.LeaderSteppingDownException: 1@group-000200000000 is stepping down
>         at org.apache.ratis.server.impl.RaftServerImpl.checkLeaderState(RaftServerImpl.java:708)
>         at org.apache.ratis.server.impl.RaftServerImpl.submitClientRequestAsync(RaftServerImpl.java:832)
>         at org.apache.ratis.server.impl.RaftServerImpl.lambda$null$12(RaftServerImpl.java:815)
>         at org.apache.ratis.util.JavaUtils.callAsUnchecked(JavaUtils.java:117)
>         at org.apache.ratis.server.impl.RaftServerImpl.lambda$executeSubmitClientRequestAsync$13(RaftServerImpl.java:815)
>         at java.util.concurrent.CompletableFuture$AsyncSupply.run(CompletableFuture.java:1590)
>         ... 3 common frames omitted
> @        at java.util.concurrent.CompletableFuture$AsyncSupply.run(CompletableFuture.java:1590)
>         ... 3 common frames omitted
> 2022-11-24 14:53:29,534 [pool-25-IoTDB-ClientRPC-Processor-1$20221124_065323_00002_1.1.0] ERROR o.a.i.d.m.e.e.RegionWriteExecutor$WritePlanNodeExecutionVisitor:137 - Something wrong happened while calling consensus layer's write API.
> org.apache.iotdb.consensus.exception.RatisRequestFailedException: Ratis request failed
>         at org.apache.iotdb.consensus.ratis.RatisConsensus.write(RatisConsensus.java:277)
>         at org.apache.iotdb.db.mpp.execution.executor.RegionWriteExecutor$WritePlanNodeExecutionVisitor.executePlanNodeInConsensusLayer(RegionWriteExecutor.java:152)
>         at org.apache.iotdb.db.mpp.execution.executor.RegionWriteExecutor$WritePlanNodeExecutionVisitor.visitPlan(RegionWriteExecutor.java:129)
>         at org.apache.iotdb.db.mpp.execution.executor.RegionWriteExecutor$WritePlanNodeExecutionVisitor.visitPlan(RegionWriteExecutor.java:119)
>         at org.apache.iotdb.db.mpp.plan.planner.plan.node.PlanVisitor.visitCreateTimeSeries(PlanVisitor.java:203)
>         at org.apache.iotdb.db.mpp.execution.executor.RegionWriteExecutor$WritePlanNodeExecutionVisitor.visitCreateTimeSeries(RegionWriteExecutor.java:279)
>         at org.apache.iotdb.db.mpp.execution.executor.RegionWriteExecutor$WritePlanNodeExecutionVisitor.visitCreateTimeSeries(RegionWriteExecutor.java:119)
>         at org.apache.iotdb.db.mpp.plan.planner.plan.node.metedata.write.CreateTimeSeriesNode.accept(CreateTimeSeriesNode.java:345)
>         at org.apache.iotdb.db.mpp.execution.executor.RegionWriteExecutor.execute(RegionWriteExecutor.java:85)
>         at org.apache.iotdb.db.mpp.plan.scheduler.FragmentInstanceDispatcherImpl.dispatchLocally(FragmentInstanceDispatcherImpl.java:232)
>         at org.apache.iotdb.db.mpp.plan.scheduler.FragmentInstanceDispatcherImpl.dispatchOneInstance(FragmentInstanceDispatcherImpl.java:137)
>         at org.apache.iotdb.db.mpp.plan.scheduler.FragmentInstanceDispatcherImpl.dispatchWriteSync(FragmentInstanceDispatcherImpl.java:119)
>         at org.apache.iotdb.db.mpp.plan.scheduler.FragmentInstanceDispatcherImpl.dispatch(FragmentInstanceDispatcherImpl.java:90)
>         at org.apache.iotdb.db.mpp.plan.scheduler.ClusterScheduler.start(ClusterScheduler.java:106)
>         at org.apache.iotdb.db.mpp.plan.execution.QueryExecution.schedule(QueryExecution.java:288)
>         at org.apache.iotdb.db.mpp.plan.execution.QueryExecution.start(QueryExecution.java:206)
>         at org.apache.iotdb.db.mpp.plan.Coordinator.execute(Coordinator.java:150)
>         at org.apache.iotdb.db.service.thrift.impl.ClientRPCServiceImpl.executeStatementInternal(ClientRPCServiceImpl.java:215)
>         at org.apache.iotdb.db.service.thrift.impl.ClientRPCServiceImpl.executeStatementV2(ClientRPCServiceImpl.java:390)
>         at org.apache.iotdb.service.rpc.thrift.IClientRPCService$Processor$executeStatementV2.getResult(IClientRPCService.java:3453)
>         at org.apache.iotdb.service.rpc.thrift.IClientRPCService$Processor$executeStatementV2.getResult(IClientRPCService.java:3433)
>         at org.apache.thrift.ProcessFunction.process(ProcessFunction.java:38)
>         at org.apache.iotdb.db.service.thrift.ProcessorWithMetrics.process(ProcessorWithMetrics.java:64)
>         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: org.apache.ratis.protocol.exceptions.LeaderSteppingDownException: 1@group-000200000000 is stepping down
>         at org.apache.ratis.server.impl.RaftServerImpl.checkLeaderState(RaftServerImpl.java:708)
>         at org.apache.ratis.server.impl.RaftServerImpl.submitClientRequestAsync(RaftServerImpl.java:832)
>         at org.apache.ratis.server.impl.RaftServerImpl.lambda$null$12(RaftServerImpl.java:815)
>         at org.apache.ratis.util.JavaUtils.callAsUnchecked(JavaUtils.java:117)
>         at org.apache.ratis.server.impl.RaftServerImpl.lambda$executeSubmitClientRequestAsync$13(RaftServerImpl.java:815)
>         at java.util.concurrent.CompletableFuture$AsyncSupply.run(CompletableFuture.java:1590)
>         ... 3 common frames omitted
> 2022-11-24 14:53:29,535 [pool-25-IoTDB-ClientRPC-Processor-1$20221124_065323_00002_1.1.0] ERROR o.a.i.d.m.p.s.FragmentInstanceDispatcherImpl:234 - write locally failed. TSStatus: TSStatus(code:301), message: org.apache.iotdb.consensus.exception.RatisRequestFailedException: Ratis request failed
> {code}



--
This message was sent by Atlassian Jira
(v8.20.10#820010)