You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@doris.apache.org by yi...@apache.org on 2023/04/26 10:27:53 UTC

[doris] branch master updated: Revert "[Enhancement](compaction) stop tablet compaction when table dropped (#18702)" (#19086)

This is an automated email from the ASF dual-hosted git repository.

yiguolei pushed a commit to branch master
in repository https://gitbox.apache.org/repos/asf/doris.git


The following commit(s) were added to refs/heads/master by this push:
     new a32fa219ec Revert "[Enhancement](compaction) stop tablet compaction when table dropped (#18702)" (#19086)
a32fa219ec is described below

commit a32fa219eca4f6b3725d1fcbad0f12a5e961a215
Author: caiconghui <55...@users.noreply.github.com>
AuthorDate: Wed Apr 26 18:27:46 2023 +0800

    Revert "[Enhancement](compaction) stop tablet compaction when table dropped (#18702)" (#19086)
    
    This reverts commit 296b0c92f702675b92eee3c8af219f3862802fb2.
    
    we can use drop table force stmt to fast drop tablets, no need to check tablet dropped state in every report
    
    Co-authored-by: caiconghui1 <ca...@jd.com>
---
 be/src/agent/task_worker_pool.cpp                  |  8 ---
 be/src/olap/tablet.cpp                             |  5 --
 be/src/olap/tablet_meta.cpp                        | 13 +----
 be/src/olap/tablet_meta.h                          | 14 -----
 be/test/olap/test_data/header_without_inc_rs.txt   |  3 +-
 .../apache/doris/catalog/CatalogRecycleBin.java    | 29 +---------
 .../main/java/org/apache/doris/catalog/Env.java    | 67 ----------------------
 .../apache/doris/catalog/TabletInvertedIndex.java  | 14 +----
 .../java/org/apache/doris/catalog/TabletMeta.java  | 17 ------
 .../org/apache/doris/master/ReportHandler.java     | 17 ------
 .../doris/task/UpdateTabletMetaInfoTask.java       | 21 -------
 gensrc/proto/olap_file.proto                       |  1 -
 gensrc/thrift/AgentService.thrift                  |  4 +-
 gensrc/thrift/MasterService.thrift                 |  1 -
 14 files changed, 7 insertions(+), 207 deletions(-)

diff --git a/be/src/agent/task_worker_pool.cpp b/be/src/agent/task_worker_pool.cpp
index b41e2b83e0..f93cee6a6b 100644
--- a/be/src/agent/task_worker_pool.cpp
+++ b/be/src/agent/task_worker_pool.cpp
@@ -1020,14 +1020,6 @@ void TaskWorkerPool::_update_tablet_meta_worker_thread_callback() {
                                 tablet_meta_info.is_in_memory);
                     }
                     break;
-                case TTabletMetaType::MARKDROP:
-                    if (tablet_meta_info.__isset.is_dropped) {
-                        tablet->tablet_meta()->set_is_dropped(tablet_meta_info.is_dropped);
-                        LOG_INFO("successfully set tablet is_dropped")
-                                .tag("tablet_id", tablet_meta_info.tablet_id)
-                                .tag("is_dropped", tablet_meta_info.is_dropped);
-                    }
-                    break;
                 }
             }
             tablet->save_meta();
diff --git a/be/src/olap/tablet.cpp b/be/src/olap/tablet.cpp
index 90a42401ae..96311c4c77 100644
--- a/be/src/olap/tablet.cpp
+++ b/be/src/olap/tablet.cpp
@@ -977,10 +977,6 @@ bool Tablet::can_do_compaction(size_t path_hash, CompactionType compaction_type)
         return false;
     }
 
-    if (_tablet_meta->is_dropped()) {
-        return false;
-    }
-
     if (tablet_state() == TABLET_NOTREADY) {
         // In TABLET_NOTREADY, we keep last 10 versions in new tablet so base tablet max_version
         // not merged in new tablet and then we can do compaction
@@ -1580,7 +1576,6 @@ void Tablet::build_tablet_report_info(TTabletInfo* tablet_info,
         // tablet may not have cooldowned data, but the storage policy is set
         tablet_info->__set_cooldown_term(_cooldown_term);
     }
-    tablet_info->__set_is_dropped(_tablet_meta->is_dropped());
 }
 
 // should use this method to get a copy of current tablet meta
diff --git a/be/src/olap/tablet_meta.cpp b/be/src/olap/tablet_meta.cpp
index 67de2b83ea..f5548e8061 100644
--- a/be/src/olap/tablet_meta.cpp
+++ b/be/src/olap/tablet_meta.cpp
@@ -253,8 +253,6 @@ TabletMeta::TabletMeta(int64_t table_id, int64_t partition_id, int64_t tablet_id
         schema->set_store_row_column(tablet_schema.store_row_column);
     }
 
-    tablet_meta_pb.set_is_dropped(false);
-
     init_from_pb(tablet_meta_pb);
 }
 
@@ -278,8 +276,7 @@ TabletMeta::TabletMeta(const TabletMeta& b)
           _storage_policy_id(b._storage_policy_id),
           _cooldown_meta_id(b._cooldown_meta_id),
           _enable_unique_key_merge_on_write(b._enable_unique_key_merge_on_write),
-          _delete_bitmap(b._delete_bitmap),
-          _is_dropped(b._is_dropped) {};
+          _delete_bitmap(b._delete_bitmap) {};
 
 void TabletMeta::init_column_from_tcolumn(uint32_t unique_id, const TColumn& tcolumn,
                                           ColumnPB* column) {
@@ -555,12 +552,6 @@ void TabletMeta::init_from_pb(const TabletMetaPB& tablet_meta_pb) {
             delete_bitmap().delete_bitmap[{rst_id, seg_id, ver}] = roaring::Roaring::read(bitmap);
         }
     }
-
-    if (tablet_meta_pb.has_is_dropped()) {
-        _is_dropped = tablet_meta_pb.is_dropped();
-    } else {
-        _is_dropped = false;
-    }
 }
 
 void TabletMeta::to_meta_pb(TabletMetaPB* tablet_meta_pb) {
@@ -634,8 +625,6 @@ void TabletMeta::to_meta_pb(TabletMetaPB* tablet_meta_pb) {
             *(delete_bitmap_pb->add_segment_delete_bitmaps()) = std::move(bitmap_data);
         }
     }
-
-    tablet_meta_pb->set_is_dropped(_is_dropped);
 }
 
 uint32_t TabletMeta::mem_size() const {
diff --git a/be/src/olap/tablet_meta.h b/be/src/olap/tablet_meta.h
index 0acf5ddaee..d2870a8dfe 100644
--- a/be/src/olap/tablet_meta.h
+++ b/be/src/olap/tablet_meta.h
@@ -217,9 +217,6 @@ public:
 
     bool enable_unique_key_merge_on_write() const { return _enable_unique_key_merge_on_write; }
 
-    bool is_dropped() const;
-    void set_is_dropped(bool is_dropped);
-
 private:
     Status _save_meta(DataDir* data_dir);
 
@@ -263,9 +260,6 @@ private:
     bool _enable_unique_key_merge_on_write = false;
     std::shared_ptr<DeleteBitmap> _delete_bitmap;
 
-    // _is_dropped is true means that the table has been dropped, and the tablet will not be compacted
-    bool _is_dropped = false;
-
     mutable std::shared_mutex _meta_lock;
 };
 
@@ -584,14 +578,6 @@ inline bool TabletMeta::all_beta() const {
     return true;
 }
 
-inline bool TabletMeta::is_dropped() const {
-    return _is_dropped;
-}
-
-inline void TabletMeta::set_is_dropped(bool is_dropped) {
-    _is_dropped = is_dropped;
-}
-
 // Only for unit test now.
 bool operator==(const TabletMeta& a, const TabletMeta& b);
 bool operator!=(const TabletMeta& a, const TabletMeta& b);
diff --git a/be/test/olap/test_data/header_without_inc_rs.txt b/be/test/olap/test_data/header_without_inc_rs.txt
index 1824da3ab8..e96b93e8cf 100644
--- a/be/test/olap/test_data/header_without_inc_rs.txt
+++ b/be/test/olap/test_data/header_without_inc_rs.txt
@@ -108,6 +108,5 @@
     "preferred_rowset_type": "BETA_ROWSET",
     "tablet_type": "TABLET_TYPE_DISK",
     "replica_id": 0,
-    "enable_unique_key_merge_on_write": false,
-    "is_dropped": false
+    "enable_unique_key_merge_on_write": false
 }
diff --git a/fe/fe-core/src/main/java/org/apache/doris/catalog/CatalogRecycleBin.java b/fe/fe-core/src/main/java/org/apache/doris/catalog/CatalogRecycleBin.java
index 04964f55bc..8fcab41cff 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/catalog/CatalogRecycleBin.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/catalog/CatalogRecycleBin.java
@@ -162,9 +162,6 @@ public class CatalogRecycleBin extends MasterDaemon implements Writable {
         }
         idToRecycleTime.put(table.getId(), recycleTime);
         idToTable.put(table.getId(), tableInfo);
-        if (!Env.isCheckpointThread()) {
-            Env.getCurrentEnv().markTableDropped(table);
-        }
         LOG.info("recycle table[{}-{}]", table.getId(), table.getName());
         return true;
     }
@@ -183,9 +180,6 @@ public class CatalogRecycleBin extends MasterDaemon implements Writable {
                 range, listPartitionItem, dataProperty, replicaAlloc, isInMemory, isMutable);
         idToRecycleTime.put(partition.getId(), System.currentTimeMillis());
         idToPartition.put(partition.getId(), partitionInfo);
-        if (!Env.isCheckpointThread()) {
-            Env.getCurrentEnv().markPartitionDropped(partition);
-        }
         LOG.info("recycle partition[{}-{}]", partition.getId(), partition.getName());
         return true;
     }
@@ -596,9 +590,6 @@ public class CatalogRecycleBin extends MasterDaemon implements Writable {
             iterator.remove();
             idToRecycleTime.remove(table.getId());
             tableNames.remove(table.getName());
-            if (!Env.isCheckpointThread()) {
-                Env.getCurrentEnv().unmarkTableDropped(table);
-            }
         }
 
         if (!tableNames.isEmpty()) {
@@ -701,10 +692,6 @@ public class CatalogRecycleBin extends MasterDaemon implements Writable {
                 RecoverInfo recoverInfo = new RecoverInfo(db.getId(), table.getId(), -1L, "", newTableName, "");
                 Env.getCurrentEnv().getEditLog().logRecoverTable(recoverInfo);
             }
-
-            if (!Env.isCheckpointThread()) {
-                Env.getCurrentEnv().unmarkTableDropped(table);
-            }
         } finally {
             table.writeUnlock();
         }
@@ -787,11 +774,6 @@ public class CatalogRecycleBin extends MasterDaemon implements Writable {
         // log
         RecoverInfo recoverInfo = new RecoverInfo(dbId, table.getId(), partitionId, "", "", newPartitionName);
         Env.getCurrentEnv().getEditLog().logRecoverPartition(recoverInfo);
-
-        if (!Env.isCheckpointThread()) {
-            Env.getCurrentEnv().unmarkPartitionDropped(recoverPartition);
-        }
-
         LOG.info("recover partition[{}]", partitionId);
     }
 
@@ -832,10 +814,6 @@ public class CatalogRecycleBin extends MasterDaemon implements Writable {
             iterator.remove();
             idToRecycleTime.remove(partitionId);
 
-            if (!Env.isCheckpointThread()) {
-                Env.getCurrentEnv().unmarkPartitionDropped(recyclePartitionInfo.getPartition());
-            }
-
             LOG.info("replay recover partition[{}]", partitionId);
             break;
         }
@@ -864,9 +842,7 @@ public class CatalogRecycleBin extends MasterDaemon implements Writable {
                     long indexId = index.getId();
                     int schemaHash = olapTable.getSchemaHashByIndexId(indexId);
                     for (Tablet tablet : index.getTablets()) {
-                        // all tablets in RecycleBin are dropped
-                        TabletMeta tabletMeta = new TabletMeta(dbId, tableId, partitionId, indexId, schemaHash, medium,
-                                                                true);
+                        TabletMeta tabletMeta = new TabletMeta(dbId, tableId, partitionId, indexId, schemaHash, medium);
                         long tabletId = tablet.getId();
                         invertedIndex.addTablet(tabletId, tabletMeta);
                         for (Replica replica : tablet.getReplicas()) {
@@ -918,8 +894,7 @@ public class CatalogRecycleBin extends MasterDaemon implements Writable {
                 long indexId = index.getId();
                 int schemaHash = olapTable.getSchemaHashByIndexId(indexId);
                 for (Tablet tablet : index.getTablets()) {
-                    TabletMeta tabletMeta = new TabletMeta(dbId, tableId, partitionId, indexId, schemaHash, medium,
-                                                            true);
+                    TabletMeta tabletMeta = new TabletMeta(dbId, tableId, partitionId, indexId, schemaHash, medium);
                     long tabletId = tablet.getId();
                     invertedIndex.addTablet(tabletId, tabletMeta);
                     for (Replica replica : tablet.getReplicas()) {
diff --git a/fe/fe-core/src/main/java/org/apache/doris/catalog/Env.java b/fe/fe-core/src/main/java/org/apache/doris/catalog/Env.java
index dff19b31af..7509de1db0 100755
--- a/fe/fe-core/src/main/java/org/apache/doris/catalog/Env.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/catalog/Env.java
@@ -5352,73 +5352,6 @@ public class Env {
         return analysisManager.taskScheduler;
     }
 
-    /**
-     * mark all tablets of the table as dropped
-     */
-    public void markTableDropped(Table table) {
-        if (table.getType() != TableType.OLAP) {
-            return;
-        }
-
-        OlapTable olapTable = (OlapTable) table;
-        for (Partition partition : olapTable.getAllPartitions()) {
-            innerMarkPartitionDropped(partition, true);
-        }
-
-        LOG.info("mark all tablets of table: {} as dropped", table.getName());
-    }
-
-    /**
-     * mark all tablets of the table as undropped
-     */
-    public void unmarkTableDropped(Table table) {
-        if (table.getType() != TableType.OLAP) {
-            return;
-        }
-
-        OlapTable olapTable = (OlapTable) table;
-        for (Partition partition : olapTable.getAllPartitions()) {
-            innerMarkPartitionDropped(partition, false);
-        }
-
-        LOG.info("mark all tablets of table: {} as undropped", table.getName());
-    }
-
-    /**
-     * mark all tablets of the partition as dropped
-     */
-    public void markPartitionDropped(Partition partition) {
-        innerMarkPartitionDropped(partition, true);
-        LOG.info("mark all tablets of partition: {} as dropped", partition.getName());
-    }
-
-    /**
-     * mark all tablets of the partition as undropped
-     */
-    public void unmarkPartitionDropped(Partition partition) {
-        innerMarkPartitionDropped(partition, false);
-        LOG.info("mark all tablets of partition: {} as undropped", partition.getName());
-    }
-
-    private void innerMarkPartitionDropped(Partition partition, boolean isDropped) {
-        TabletInvertedIndex invertedIndex = Env.getCurrentInvertedIndex();
-        List<MaterializedIndex> allIndices = partition.getMaterializedIndices(IndexExtState.ALL);
-        for (MaterializedIndex materializedIndex : allIndices) {
-            for (Tablet tablet : materializedIndex.getTablets()) {
-                TabletMeta tabletMeta = invertedIndex.getTabletMeta(tablet.getId());
-                if (tabletMeta == null) {
-                    LOG.warn("cannot find tabletMeta of tabletId={}", tablet.getId());
-                    continue;
-                }
-                if (tabletMeta.getIsDropped() == isDropped) {
-                    continue;
-                }
-
-                tabletMeta.setIsDropped(isDropped);
-            } // end for tablets
-        } // end for indices
-    }
-
     // TODO:
     //  1. handle partition level analysis statement properly
     //  2. support sample job
diff --git a/fe/fe-core/src/main/java/org/apache/doris/catalog/TabletInvertedIndex.java b/fe/fe-core/src/main/java/org/apache/doris/catalog/TabletInvertedIndex.java
index 23eed25a84..52c7ca8786 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/catalog/TabletInvertedIndex.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/catalog/TabletInvertedIndex.java
@@ -128,7 +128,6 @@ public class TabletInvertedIndex {
                              ListMultimap<Long, Long> transactionsToClear,
                              ListMultimap<Long, Long> tabletRecoveryMap,
                              List<Triple<Long, Integer, Boolean>> tabletToInMemory,
-                             List<Triple<Long, Integer, Boolean>> tabletToIsDropped,
                              List<CooldownConf> cooldownConfToPush,
                              List<CooldownConf> cooldownConfToUpdate) {
         long stamp = readLock();
@@ -156,15 +155,6 @@ public class TabletInvertedIndex {
                                             backendTabletInfo.getSchemaHash(), !backendTabletInfo.isIsInMemory()));
                                 }
                             }
-
-                            if (tabletMeta.getIsDropped() != backendTabletInfo.isIsDropped()) {
-                                synchronized (tabletToIsDropped) {
-                                    tabletToIsDropped.add(
-                                            new ImmutableTriple<>(tabletId, backendTabletInfo.getSchemaHash(),
-                                                    tabletMeta.getIsDropped()));
-                                }
-                            }
-
                             // 1. (intersection)
                             if (needSync(replica, backendTabletInfo)) {
                                 // need sync
@@ -329,10 +319,10 @@ public class TabletInvertedIndex {
         LOG.info("finished to do tablet diff with backend[{}]. sync: {}."
                         + " metaDel: {}. foundInMeta: {}. migration: {}. "
                         + "found invalid transactions {}. found republish transactions {}. tabletInMemorySync: {}."
-                        + " need recovery: {}. tabletToIsDropped: {}. cost: {} ms", backendId, tabletSyncMap.size(),
+                        + " need recovery: {}. cost: {} ms", backendId, tabletSyncMap.size(),
                 tabletDeleteFromMeta.size(), tabletFoundInMeta.size(), tabletMigrationMap.size(),
                 transactionsToClear.size(), transactionsToPublish.size(), tabletToInMemory.size(),
-                tabletRecoveryMap.size(), tabletToIsDropped.size(), (end - start));
+                tabletRecoveryMap.size(), (end - start));
     }
 
     public Long getTabletIdByReplica(long replicaId) {
diff --git a/fe/fe-core/src/main/java/org/apache/doris/catalog/TabletMeta.java b/fe/fe-core/src/main/java/org/apache/doris/catalog/TabletMeta.java
index 616889725b..be291d93ec 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/catalog/TabletMeta.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/catalog/TabletMeta.java
@@ -35,15 +35,8 @@ public class TabletMeta {
 
     private TStorageMedium storageMedium;
 
-    private boolean isDropped;
-
     public TabletMeta(long dbId, long tableId, long partitionId, long indexId, int schemaHash,
             TStorageMedium storageMedium) {
-        this(dbId, tableId, partitionId, indexId, schemaHash, storageMedium, false);
-    }
-
-    public TabletMeta(long dbId, long tableId, long partitionId, long indexId, int schemaHash,
-            TStorageMedium storageMedium, boolean isDropped) {
         this.dbId = dbId;
         this.tableId = tableId;
         this.partitionId = partitionId;
@@ -53,7 +46,6 @@ public class TabletMeta {
         this.newSchemaHash = -1;
 
         this.storageMedium = storageMedium;
-        this.isDropped = isDropped;
     }
 
     public long getDbId() {
@@ -84,14 +76,6 @@ public class TabletMeta {
         return this.oldSchemaHash;
     }
 
-    public boolean getIsDropped() {
-        return isDropped;
-    }
-
-    public void setIsDropped(boolean isDropped) {
-        this.isDropped = isDropped;
-    }
-
     @Override
     public String toString() {
         StringBuilder sb = new StringBuilder();
@@ -104,5 +88,4 @@ public class TabletMeta {
 
         return sb.toString();
     }
-
 }
diff --git a/fe/fe-core/src/main/java/org/apache/doris/master/ReportHandler.java b/fe/fe-core/src/main/java/org/apache/doris/master/ReportHandler.java
index d986773db0..d6dd0070ff 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/master/ReportHandler.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/master/ReportHandler.java
@@ -422,9 +422,6 @@ public class ReportHandler extends Daemon {
 
         List<Triple<Long, Integer, Boolean>> tabletToInMemory = Lists.newArrayList();
 
-        // <tablet id, tablet schema hash, tablet is dropped>
-        List<Triple<Long, Integer, Boolean>> tabletToIsDropped = Lists.newArrayList();
-
         List<CooldownConf> cooldownConfToPush = new LinkedList<>();
         List<CooldownConf> cooldownConfToUpdate = new LinkedList<>();
 
@@ -438,7 +435,6 @@ public class ReportHandler extends Daemon {
                 transactionsToClear,
                 tabletRecoveryMap,
                 tabletToInMemory,
-                tabletToIsDropped,
                 cooldownConfToPush,
                 cooldownConfToUpdate);
 
@@ -483,11 +479,6 @@ public class ReportHandler extends Daemon {
             handleSetTabletInMemory(backendId, tabletToInMemory);
         }
 
-        // 10. send mark tablet isDropped to be
-        if (!tabletToIsDropped.isEmpty()) {
-            handleMarkTabletIsDropped(backendId, tabletToIsDropped);
-        }
-
         // handle cooldown conf
         if (!cooldownConfToPush.isEmpty()) {
             handlePushCooldownConf(backendId, cooldownConfToPush);
@@ -1048,14 +1039,6 @@ public class ReportHandler extends Daemon {
         AgentTaskExecutor.submit(batchTask);
     }
 
-    private static void handleMarkTabletIsDropped(long backendId,
-            List<Triple<Long, Integer, Boolean>> tabletToIsDropped) {
-        AgentBatchTask batchTask = new AgentBatchTask();
-        UpdateTabletMetaInfoTask task = new UpdateTabletMetaInfoTask(tabletToIsDropped, backendId);
-        batchTask.addTask(task);
-        AgentTaskExecutor.submit(batchTask);
-    }
-
     private static void handleClearTransactions(ListMultimap<Long, Long> transactionsToClear, long backendId) {
         AgentBatchTask batchTask = new AgentBatchTask();
         for (Long transactionId : transactionsToClear.keySet()) {
diff --git a/fe/fe-core/src/main/java/org/apache/doris/task/UpdateTabletMetaInfoTask.java b/fe/fe-core/src/main/java/org/apache/doris/task/UpdateTabletMetaInfoTask.java
index ac40776878..a39197f5ad 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/task/UpdateTabletMetaInfoTask.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/task/UpdateTabletMetaInfoTask.java
@@ -51,9 +51,6 @@ public class UpdateTabletMetaInfoTask extends AgentTask {
     // <tablet id, tablet schema hash, tablet in memory>
     private List<Triple<Long, Integer, Boolean>> tabletToInMemory;
 
-    // <tablet id, tablet schema hash, tablet is dropped>
-    private List<Triple<Long, Integer, Boolean>> tabletToIsDropped;
-
     public UpdateTabletMetaInfoTask(long backendId, Set<Pair<Long, Integer>> tableIdWithSchemaHash,
                                     TTabletMetaType metaType) {
         super(null, backendId, TTaskType.UPDATE_TABLET_META_INFO,
@@ -80,13 +77,6 @@ public class UpdateTabletMetaInfoTask extends AgentTask {
         this.tabletToInMemory = tabletToInMemory;
     }
 
-    public UpdateTabletMetaInfoTask(List<Triple<Long, Integer, Boolean>> tabletToIsDropped, long backendId) {
-        super(null, backendId, TTaskType.UPDATE_TABLET_META_INFO,
-                -1L, -1L, -1L, -1L, -1L, tabletToIsDropped.hashCode());
-        this.metaType = TTabletMetaType.MARKDROP;
-        this.tabletToIsDropped = tabletToIsDropped;
-    }
-
     public void countDownLatch(long backendId, Set<Pair<Long, Integer>> tablets) {
         if (this.latch != null) {
             if (latch.markedCountDown(backendId, tablets)) {
@@ -164,17 +154,6 @@ public class UpdateTabletMetaInfoTask extends AgentTask {
                 }
                 break;
             }
-            case MARKDROP: {
-                for (Triple<Long, Integer, Boolean> triple : tabletToIsDropped) {
-                    TTabletMetaInfo metaInfo = new TTabletMetaInfo();
-                    metaInfo.setTabletId(triple.getLeft());
-                    metaInfo.setSchemaHash(triple.getMiddle());
-                    metaInfo.setIsDropped(triple.getRight());
-                    metaInfo.setMetaType(metaType);
-                    metaInfos.add(metaInfo);
-                }
-                break;
-            }
             default:
                 break;
         }
diff --git a/gensrc/proto/olap_file.proto b/gensrc/proto/olap_file.proto
index a3c238924d..4d9c05b369 100644
--- a/gensrc/proto/olap_file.proto
+++ b/gensrc/proto/olap_file.proto
@@ -298,7 +298,6 @@ message TabletMetaPB {
     optional bool enable_unique_key_merge_on_write = 24 [default = false];
     optional int64 storage_policy_id = 25;
     optional PUniqueId cooldown_meta_id = 26;
-    optional bool is_dropped = 27;
 }
 
 message OLAPRawDeltaHeaderMessage {
diff --git a/gensrc/thrift/AgentService.thrift b/gensrc/thrift/AgentService.thrift
index 11d5a5f024..91b2927705 100644
--- a/gensrc/thrift/AgentService.thrift
+++ b/gensrc/thrift/AgentService.thrift
@@ -355,8 +355,7 @@ struct TRecoverTabletReq {
 
 enum TTabletMetaType {
     PARTITIONID,
-    INMEMORY,
-    MARKDROP
+    INMEMORY
 }
 
 struct TTabletMetaInfo {
@@ -367,7 +366,6 @@ struct TTabletMetaInfo {
     5: optional bool is_in_memory
     // 6: optional string storage_policy;
     7: optional i64 storage_policy_id
-    8: optional bool is_dropped
 }
 
 struct TUpdateTabletMetaInfoReq {
diff --git a/gensrc/thrift/MasterService.thrift b/gensrc/thrift/MasterService.thrift
index 446ed1cec8..893bb0171a 100644
--- a/gensrc/thrift/MasterService.thrift
+++ b/gensrc/thrift/MasterService.thrift
@@ -46,7 +46,6 @@ struct TTabletInfo {
     // 18: optional bool is_cooldown
     19: optional i64 cooldown_term
     20: optional Types.TUniqueId cooldown_meta_id
-    21: optional bool is_dropped
 }
 
 struct TFinishTaskRequest {


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