You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@doris.apache.org by GitBox <gi...@apache.org> on 2022/06/24 09:34:56 UTC

[GitHub] [doris] SWJTU-ZhangLei opened a new issue, #10403: [Bug] [Fe] master fe wrong when add/drop table with expanding fe.

SWJTU-ZhangLei opened a new issue, #10403:
URL: https://github.com/apache/doris/issues/10403

   ### Search before asking
   
   - [X] I had searched in the [issues](https://github.com/apache/incubator-doris/issues?q=is%3Aissue) and found no similar issues.
   
   
   ### Version
   
   root@regtest-15-bj:/home/zhanglei/test#  ./output/be/lib/palo_be --version
   trunk RELEASE (build git://regtest-15-bj/home/zhanglei/incubator-doris/be/../@3370c105286ac9f2d590d0bf43f811a5cb52171e)
   Built on Fri, 24 Jun 2022 14:04:29 CST by root@regtest-15-bj
   
   ### What's Wrong?
   
   1497977 2022-06-24 16:00:47,909 INFO (Thread-51|119) [ReportHandler.taskReport():380] finished to handle task report from backend 10003, diff task num: 0. cost: 0 ms
   1497978 2022-06-24 16:00:47,909 INFO (thrift-server-pool-1|160) [ReportHandler.handleReport():181] receive report from be 10003. type: TASK, current queue size: 1
   1497979 2022-06-24 16:00:48,908 ERROR (doris-mysql-nio-pool-20|343) [BDBJEJournal.write():153] catch an exception when writing to database. sleep and retry. journal id 429895
   1497980 com.sleepycat.je.rep.InsufficientAcksException: (JE 18.3.12) Transaction: -430221  VLSN: 860,132, initiated at: 16:00:38.  Insufficient acks for policy:SIMPLE_MAJORITY. Need replica acks: 1. Missing replica acks: 1. Timeout: 10000ms. FeederS1497980 tate=172.21.16.15_19010_1656051618467(1)[MASTER]
   1497981 Current feeds:
   1497982  172.21.16.2_19010_1656057611486: feederVLSN=730,004 replicaTxnEndVLSN=658,450
   1497983 
   1497984         at com.sleepycat.je.rep.impl.node.DurabilityQuorum.ensureSufficientAcks(DurabilityQuorum.java:205) ~[je-18.3.12.jar:18.3.12]
   1497985         at com.sleepycat.je.rep.stream.FeederTxns.awaitReplicaAcks(FeederTxns.java:188) ~[je-18.3.12.jar:18.3.12]
   1497986         at com.sleepycat.je.rep.impl.RepImpl.postLogCommitHookInternal(RepImpl.java:1444) ~[je-18.3.12.jar:18.3.12]
   1497987         at com.sleepycat.je.rep.impl.RepImpl.postLogCommitHook(RepImpl.java:1403) ~[je-18.3.12.jar:18.3.12]
   1497988         at com.sleepycat.je.rep.txn.MasterTxn.postLogCommitHook(MasterTxn.java:228) ~[je-18.3.12.jar:18.3.12]
   1497989         at com.sleepycat.je.txn.Txn.commit(Txn.java:778) ~[je-18.3.12.jar:18.3.12]
   1497990         at com.sleepycat.je.txn.Txn.commit(Txn.java:631) ~[je-18.3.12.jar:18.3.12]
   1497991         at com.sleepycat.je.txn.Txn.operationEnd(Txn.java:1773) ~[je-18.3.12.jar:18.3.12]
   1497992         at com.sleepycat.je.Database.put(Database.java:1638) ~[je-18.3.12.jar:18.3.12]
   1497993         at com.sleepycat.je.Database.put(Database.java:1688) ~[je-18.3.12.jar:18.3.12]
   1497994         at org.apache.doris.journal.bdbje.BDBJEJournal.write(BDBJEJournal.java:144) ~[palo-fe.jar:1.0-SNAPSHOT]
   1497995         at org.apache.doris.persist.EditLog.logEdit(EditLog.java:911) ~[palo-fe.jar:1.0-SNAPSHOT]
   1497996         at org.apache.doris.persist.EditLog.logDropTable(EditLog.java:1018) ~[palo-fe.jar:1.0-SNAPSHOT]
   1497997         at org.apache.doris.datasource.InternalDataSource.dropTable(InternalDataSource.java:922) ~[palo-fe.jar:1.0-SNAPSHOT]
   1497998         at org.apache.doris.catalog.Catalog.dropTable(Catalog.java:3068) ~[palo-fe.jar:1.0-SNAPSHOT]
   1497999         at org.apache.doris.qe.DdlExecutor.execute(DdlExecutor.java:146) ~[palo-fe.jar:1.0-SNAPSHOT]
   1498000         at org.apache.doris.qe.StmtExecutor.handleDdlStmt(StmtExecutor.java:1535) ~[palo-fe.jar:1.0-SNAPSHOT]
   1498001         at org.apache.doris.qe.StmtExecutor.execute(StmtExecutor.java:440) ~[palo-fe.jar:1.0-SNAPSHOT]
   1498002         at org.apache.doris.qe.StmtExecutor.execute(StmtExecutor.java:307) ~[palo-fe.jar:1.0-SNAPSHOT]
   1498003         at org.apache.doris.qe.ConnectProcessor.handleQuery(ConnectProcessor.java:216) ~[palo-fe.jar:1.0-SNAPSHOT]
   1498004         at org.apache.doris.qe.ConnectProcessor.dispatch(ConnectProcessor.java:353) ~[palo-fe.jar:1.0-SNAPSHOT]
   1498005         at org.apache.doris.qe.ConnectProcessor.processOnce(ConnectProcessor.java:542) ~[palo-fe.jar:1.0-SNAPSHOT]
   1498006         at org.apache.doris.mysql.nio.ReadListener.lambda$handleEvent$0(ReadListener.java:52) ~[palo-fe.jar:1.0-SNAPSHOT]
   1498007         at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1128) ~[?:?]
   1498008         at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:628) ~[?:?]
   1498009         at java.lang.Thread.run(Thread.java:829) ~[?:?]
   1498010 2022-06-24 16:00:53,915 INFO (doris-mysql-nio-pool-20|343) [InternalDataSource.dropTable():926] finished dropping table: test1 from db: default_cluster:regression_test, is force: false
   
   ### What You Expected?
   
   master fe work well.
   
   ### How to Reproduce?
   
   **step1:  build a cluster with a fe and a be** 
    fe.conf set  metadata_checkpoint_memory_threshold = 0
   
   **step2: i write a regression test suite, like this:**
   suite("sql_action", "demo") {
     def testTable = "test1"
     while(true) {
       sql "DROP TABLE IF EXISTS ${testTable}"
   
       def result1 = sql """
                           CREATE TABLE IF NOT EXISTS ${testTable} (
                               id int,
                               id2 int,
                               id3 int,
                               id4 int,
                               id5 int,
                               id6 int,
                               id7 int,
                               id8 int
                           )
                           DISTRIBUTED BY HASH(id) BUCKETS 1
                           PROPERTIES (
                             "replication_num" = "1"
                           ) 
                          """
     sleep(10)
     }
   }
   step3:
   when fe/doris-meta/bdb size grows 5GB, add a fe follower.
   
   ### Anything Else?
   
   _No response_
   
   ### Are you willing to submit PR?
   
   - [ ] Yes I am willing to submit a PR!
   
   ### Code of Conduct
   
   - [X] I agree to follow this project's [Code of Conduct](https://www.apache.org/foundation/policies/conduct)
   


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

To unsubscribe, e-mail: commits-unsubscribe@doris.apache.org.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org


---------------------------------------------------------------------
To unsubscribe, e-mail: commits-unsubscribe@doris.apache.org
For additional commands, e-mail: commits-help@doris.apache.org


[GitHub] [doris] dataroaring closed issue #10403: [Bug] [Fe] master fe wrong when add/drop table with expanding fe.

Posted by GitBox <gi...@apache.org>.
dataroaring closed issue #10403: [Bug] [Fe] master fe wrong when add/drop table with expanding fe.
URL: https://github.com/apache/doris/issues/10403


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

To unsubscribe, e-mail: commits-unsubscribe@doris.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org


---------------------------------------------------------------------
To unsubscribe, e-mail: commits-unsubscribe@doris.apache.org
For additional commands, e-mail: commits-help@doris.apache.org