Coverage Report

Created: 2026-01-20 23:45

next uncovered line (L), next uncovered region (R), next uncovered branch (B)
/root/doris/be/src/olap/memtable.cpp
Line
Count
Source
1
// Licensed to the Apache Software Foundation (ASF) under one
2
// or more contributor license agreements.  See the NOTICE file
3
// distributed with this work for additional information
4
// regarding copyright ownership.  The ASF licenses this file
5
// to you under the Apache License, Version 2.0 (the
6
// "License"); you may not use this file except in compliance
7
// with the License.  You may obtain a copy of the License at
8
//
9
//   http://www.apache.org/licenses/LICENSE-2.0
10
//
11
// Unless required by applicable law or agreed to in writing,
12
// software distributed under the License is distributed on an
13
// "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
14
// KIND, either express or implied.  See the License for the
15
// specific language governing permissions and limitations
16
// under the License.
17
18
#include "olap/memtable.h"
19
20
#include <fmt/format.h>
21
#include <gen_cpp/olap_file.pb.h>
22
#include <pdqsort.h>
23
24
#include <algorithm>
25
#include <limits>
26
#include <string>
27
#include <vector>
28
29
#include "bvar/bvar.h"
30
#include "common/config.h"
31
#include "olap/memtable_memory_limiter.h"
32
#include "olap/olap_define.h"
33
#include "olap/tablet_schema.h"
34
#include "runtime/descriptors.h"
35
#include "runtime/exec_env.h"
36
#include "runtime/thread_context.h"
37
#include "util/debug_points.h"
38
#include "util/runtime_profile.h"
39
#include "util/stopwatch.hpp"
40
#include "vec/aggregate_functions/aggregate_function_reader.h"
41
#include "vec/aggregate_functions/aggregate_function_simple_factory.h"
42
#include "vec/columns/column.h"
43
44
namespace doris {
45
#include "common/compile_check_begin.h"
46
47
bvar::Adder<int64_t> g_memtable_cnt("memtable_cnt");
48
bvar::Adder<uint64_t> g_flush_cuz_memtable_full("flush_cuz_memtable_full");
49
50
using namespace ErrorCode;
51
52
MemTable::MemTable(int64_t tablet_id, std::shared_ptr<TabletSchema> tablet_schema,
53
                   const std::vector<SlotDescriptor*>* slot_descs, TupleDescriptor* tuple_desc,
54
                   bool enable_unique_key_mow, PartialUpdateInfo* partial_update_info,
55
                   const std::shared_ptr<ResourceContext>& resource_ctx)
56
15
        : _mem_type(MemType::ACTIVE),
57
15
          _tablet_id(tablet_id),
58
15
          _enable_unique_key_mow(enable_unique_key_mow),
59
15
          _keys_type(tablet_schema->keys_type()),
60
15
          _tablet_schema(tablet_schema),
61
15
          _resource_ctx(resource_ctx),
62
15
          _is_first_insertion(true),
63
15
          _agg_functions(tablet_schema->num_columns()),
64
15
          _offsets_of_aggregate_states(tablet_schema->num_columns()),
65
15
          _total_size_of_aggregate_states(0) {
66
15
    g_memtable_cnt << 1;
67
15
    _mem_tracker = std::make_shared<MemTracker>();
68
15
    SCOPED_SWITCH_THREAD_MEM_TRACKER_LIMITER(
69
15
            _resource_ctx->memory_context()->mem_tracker()->write_tracker());
70
15
    SCOPED_CONSUME_MEM_TRACKER(_mem_tracker);
71
15
    _vec_row_comparator = std::make_shared<RowInBlockComparator>(_tablet_schema);
72
15
    if (partial_update_info != nullptr) {
73
15
        _partial_update_mode = partial_update_info->update_mode();
74
15
        if (_partial_update_mode == UniqueKeyUpdateModePB::UPDATE_FIXED_COLUMNS) {
75
0
            if (partial_update_info->is_schema_contains_auto_inc_column &&
76
0
                !partial_update_info->is_input_columns_contains_auto_inc_column) {
77
0
                _is_partial_update_and_auto_inc = true;
78
0
            }
79
0
        }
80
15
    }
81
15
    _init_columns_offset_by_slot_descs(slot_descs, tuple_desc);
82
    // TODO: Support ZOrderComparator in the future
83
15
    _row_in_blocks = std::make_unique<DorisVector<std::shared_ptr<RowInBlock>>>();
84
15
}
85
86
void MemTable::_init_columns_offset_by_slot_descs(const std::vector<SlotDescriptor*>* slot_descs,
87
15
                                                  const TupleDescriptor* tuple_desc) {
88
91
    for (auto slot_desc : *slot_descs) {
89
91
        const auto& slots = tuple_desc->slots();
90
630
        for (int j = 0; j < slots.size(); ++j) {
91
630
            if (slot_desc->id() == slots[j]->id()) {
92
91
                _column_offset.emplace_back(j);
93
91
                break;
94
91
            }
95
630
        }
96
91
    }
97
15
    if (_is_partial_update_and_auto_inc) {
98
0
        _column_offset.emplace_back(_column_offset.size());
99
0
    }
100
15
    _num_columns = _column_offset.size();
101
15
}
102
103
12
void MemTable::_init_agg_functions(const vectorized::Block* block) {
104
12
    if (_num_columns > _column_offset.size()) [[unlikely]] {
105
0
        throw doris::Exception(doris::ErrorCode::INTERNAL_ERROR,
106
0
                               "num_columns {} is greater than block columns {}", _num_columns,
107
0
                               _column_offset.size());
108
0
    }
109
42
    for (auto cid = _tablet_schema->num_key_columns(); cid < _num_columns; ++cid) {
110
30
        vectorized::AggregateFunctionPtr function;
111
30
        if (_keys_type == KeysType::UNIQUE_KEYS && _enable_unique_key_mow) {
112
            // In such table, non-key column's aggregation type is NONE, so we need to construct
113
            // the aggregate function manually.
114
9
            if (_skip_bitmap_col_idx != cid) {
115
9
                function = vectorized::AggregateFunctionSimpleFactory::instance().get(
116
9
                        "replace_load", {block->get_data_type(cid)}, block->get_data_type(cid),
117
9
                        block->get_data_type(cid)->is_nullable(),
118
9
                        BeExecVersionManager::get_newest_version());
119
9
            } else {
120
0
                function = vectorized::AggregateFunctionSimpleFactory::instance().get(
121
0
                        "bitmap_intersect", {block->get_data_type(cid)}, block->get_data_type(cid),
122
0
                        false, BeExecVersionManager::get_newest_version());
123
0
            }
124
21
        } else {
125
21
            function = _tablet_schema->column(cid).get_aggregate_function(
126
21
                    vectorized::AGG_LOAD_SUFFIX, _tablet_schema->column(cid).get_be_exec_version());
127
21
            if (function == nullptr) {
128
0
                LOG(WARNING) << "column get aggregate function failed, column="
129
0
                             << _tablet_schema->column(cid).name();
130
0
            }
131
21
        }
132
133
30
        DCHECK(function != nullptr);
134
30
        _agg_functions[cid] = function;
135
30
    }
136
137
42
    for (auto cid = _tablet_schema->num_key_columns(); cid < _num_columns; ++cid) {
138
30
        _offsets_of_aggregate_states[cid] = _total_size_of_aggregate_states;
139
30
        _total_size_of_aggregate_states += _agg_functions[cid]->size_of_data();
140
141
        // If not the last aggregate_state, we need pad it so that next aggregate_state will be aligned.
142
30
        if (cid + 1 < _num_columns) {
143
22
            size_t alignment_of_next_state = _agg_functions[cid + 1]->align_of_data();
144
145
            /// Extend total_size to next alignment requirement
146
            /// Add padding by rounding up 'total_size_of_aggregate_states' to be a multiplier of alignment_of_next_state.
147
22
            _total_size_of_aggregate_states =
148
22
                    (_total_size_of_aggregate_states + alignment_of_next_state - 1) /
149
22
                    alignment_of_next_state * alignment_of_next_state;
150
22
        }
151
30
    }
152
12
}
153
154
15
MemTable::~MemTable() {
155
15
    SCOPED_SWITCH_THREAD_MEM_TRACKER_LIMITER(
156
15
            _resource_ctx->memory_context()->mem_tracker()->write_tracker());
157
15
    {
158
15
        SCOPED_CONSUME_MEM_TRACKER(_mem_tracker);
159
15
        g_memtable_cnt << -1;
160
15
        if (_keys_type != KeysType::DUP_KEYS) {
161
35
            for (auto it = _row_in_blocks->begin(); it != _row_in_blocks->end(); it++) {
162
20
                if (!(*it)->has_init_agg()) {
163
20
                    continue;
164
20
                }
165
                // We should release agg_places here, because they are not released when a
166
                // load is canceled.
167
0
                for (size_t i = _tablet_schema->num_key_columns(); i < _num_columns; ++i) {
168
0
                    auto function = _agg_functions[i];
169
0
                    DCHECK(function != nullptr);
170
0
                    function->destroy((*it)->agg_places(i));
171
0
                }
172
0
            }
173
15
        }
174
175
15
        _arena.clear(true);
176
15
        _vec_row_comparator.reset();
177
15
        _row_in_blocks.reset();
178
15
        _agg_functions.clear();
179
15
        _input_mutable_block.clear();
180
15
        _output_mutable_block.clear();
181
15
    }
182
15
    if (_is_flush_success) {
183
        // If the memtable is flush success, then its memtracker's consumption should be 0
184
12
        if (_mem_tracker->consumption() != 0 && config::crash_in_memory_tracker_inaccurate) {
185
0
            LOG(FATAL) << "memtable flush success but cosumption is not 0, it is "
186
0
                       << _mem_tracker->consumption();
187
0
        }
188
12
    }
189
15
}
190
191
6
int RowInBlockComparator::operator()(const RowInBlock* left, const RowInBlock* right) const {
192
6
    return _pblock->compare_at(left->_row_pos, right->_row_pos, _tablet_schema->num_key_columns(),
193
6
                               *_pblock, -1);
194
6
}
195
196
Status MemTable::insert(const vectorized::Block* input_block,
197
20
                        const DorisVector<uint32_t>& row_idxs) {
198
20
    SCOPED_SWITCH_THREAD_MEM_TRACKER_LIMITER(
199
20
            _resource_ctx->memory_context()->mem_tracker()->write_tracker());
200
20
    SCOPED_CONSUME_MEM_TRACKER(_mem_tracker);
201
202
20
    if (_is_first_insertion) {
203
12
        _is_first_insertion = false;
204
12
        auto clone_block = input_block->clone_without_columns(&_column_offset);
205
12
        _input_mutable_block = vectorized::MutableBlock::build_mutable_block(&clone_block);
206
12
        _vec_row_comparator->set_block(&_input_mutable_block);
207
12
        _output_mutable_block = vectorized::MutableBlock::build_mutable_block(&clone_block);
208
12
        if (_tablet_schema->has_sequence_col()) {
209
7
            if (_partial_update_mode == UniqueKeyUpdateModePB::UPDATE_FIXED_COLUMNS) {
210
                // for unique key fixed partial update, sequence column index in block
211
                // may be different with the index in `_tablet_schema`
212
0
                for (int32_t i = 0; i < clone_block.columns(); i++) {
213
0
                    if (clone_block.get_by_position(i).name == SEQUENCE_COL) {
214
0
                        _seq_col_idx_in_block = i;
215
0
                        break;
216
0
                    }
217
0
                }
218
7
            } else {
219
7
                _seq_col_idx_in_block = _tablet_schema->sequence_col_idx();
220
7
            }
221
7
        }
222
12
        if (_partial_update_mode == UniqueKeyUpdateModePB::UPDATE_FLEXIBLE_COLUMNS &&
223
12
            _tablet_schema->has_skip_bitmap_col()) {
224
            // init of _skip_bitmap_col_idx and _delete_sign_col_idx must be before _init_agg_functions()
225
0
            _skip_bitmap_col_idx = _tablet_schema->skip_bitmap_col_idx();
226
0
            _delete_sign_col_idx = _tablet_schema->delete_sign_idx();
227
0
            _delete_sign_col_unique_id = _tablet_schema->column(_delete_sign_col_idx).unique_id();
228
0
            if (_seq_col_idx_in_block != -1) {
229
0
                _seq_col_unique_id = _tablet_schema->column(_seq_col_idx_in_block).unique_id();
230
0
            }
231
0
        }
232
12
        if (_keys_type != KeysType::DUP_KEYS) {
233
            // there may be additional intermediate columns in input_block
234
            // we only need columns indicated by column offset in the output
235
12
            RETURN_IF_CATCH_EXCEPTION(_init_agg_functions(&clone_block));
236
12
        }
237
12
    }
238
239
20
    auto num_rows = row_idxs.size();
240
20
    size_t cursor_in_mutableblock = _input_mutable_block.rows();
241
20
    RETURN_IF_ERROR(_input_mutable_block.add_rows(input_block, row_idxs.data(),
242
20
                                                  row_idxs.data() + num_rows, &_column_offset));
243
40
    for (int i = 0; i < num_rows; i++) {
244
20
        _row_in_blocks->emplace_back(std::make_shared<RowInBlock>(cursor_in_mutableblock + i));
245
20
    }
246
247
20
    _stat.raw_rows += num_rows;
248
20
    return Status::OK();
249
20
}
250
251
template <bool has_skip_bitmap_col>
252
void MemTable::_aggregate_two_row_in_block(vectorized::MutableBlock& mutable_block,
253
3
                                           RowInBlock* src_row, RowInBlock* dst_row) {
254
    // for flexible partial update, the caller must guarantees that either src_row and dst_row
255
    // both specify the sequence column, or src_row and dst_row both don't specify the
256
    // sequence column
257
3
    if (_tablet_schema->has_sequence_col() && _seq_col_idx_in_block >= 0) {
258
3
        DCHECK_LT(_seq_col_idx_in_block, mutable_block.columns());
259
3
        auto col_ptr = mutable_block.mutable_columns()[_seq_col_idx_in_block].get();
260
3
        auto res = col_ptr->compare_at(dst_row->_row_pos, src_row->_row_pos, *col_ptr, -1);
261
        // dst sequence column larger than src, don't need to update
262
3
        if (res > 0) {
263
3
            return;
264
3
        }
265
        // need to update the row pos in dst row to the src row pos when has
266
        // sequence column
267
0
        dst_row->_row_pos = src_row->_row_pos;
268
0
    }
269
    // dst is non-sequence row, or dst sequence is smaller
270
0
    if constexpr (!has_skip_bitmap_col) {
271
0
        DCHECK(_skip_bitmap_col_idx == -1);
272
0
        for (size_t cid = _tablet_schema->num_key_columns(); cid < _num_columns; ++cid) {
273
0
            auto* col_ptr = mutable_block.mutable_columns()[cid].get();
274
0
            _agg_functions[cid]->add(dst_row->agg_places(cid),
275
0
                                     const_cast<const doris::vectorized::IColumn**>(&col_ptr),
276
0
                                     src_row->_row_pos, _arena);
277
0
        }
278
0
    } else {
279
0
        DCHECK(_skip_bitmap_col_idx != -1);
280
0
        DCHECK_LT(_skip_bitmap_col_idx, mutable_block.columns());
281
0
        const BitmapValue& skip_bitmap =
282
0
                assert_cast<vectorized::ColumnBitmap*, TypeCheckOnRelease::DISABLE>(
283
0
                        mutable_block.mutable_columns()[_skip_bitmap_col_idx].get())
284
0
                        ->get_data()[src_row->_row_pos];
285
0
        for (size_t cid = _tablet_schema->num_key_columns(); cid < _num_columns; ++cid) {
286
0
            const auto& col = _tablet_schema->column(cid);
287
0
            if (cid != _skip_bitmap_col_idx && skip_bitmap.contains(col.unique_id())) {
288
0
                continue;
289
0
            }
290
0
            auto* col_ptr = mutable_block.mutable_columns()[cid].get();
291
0
            _agg_functions[cid]->add(dst_row->agg_places(cid),
292
0
                                     const_cast<const doris::vectorized::IColumn**>(&col_ptr),
293
0
                                     src_row->_row_pos, _arena);
294
0
        }
295
0
    }
296
0
}
_ZN5doris8MemTable27_aggregate_two_row_in_blockILb0EEEvRNS_10vectorized12MutableBlockEPNS_10RowInBlockES6_
Line
Count
Source
253
3
                                           RowInBlock* src_row, RowInBlock* dst_row) {
254
    // for flexible partial update, the caller must guarantees that either src_row and dst_row
255
    // both specify the sequence column, or src_row and dst_row both don't specify the
256
    // sequence column
257
3
    if (_tablet_schema->has_sequence_col() && _seq_col_idx_in_block >= 0) {
258
3
        DCHECK_LT(_seq_col_idx_in_block, mutable_block.columns());
259
3
        auto col_ptr = mutable_block.mutable_columns()[_seq_col_idx_in_block].get();
260
3
        auto res = col_ptr->compare_at(dst_row->_row_pos, src_row->_row_pos, *col_ptr, -1);
261
        // dst sequence column larger than src, don't need to update
262
3
        if (res > 0) {
263
3
            return;
264
3
        }
265
        // need to update the row pos in dst row to the src row pos when has
266
        // sequence column
267
0
        dst_row->_row_pos = src_row->_row_pos;
268
0
    }
269
    // dst is non-sequence row, or dst sequence is smaller
270
0
    if constexpr (!has_skip_bitmap_col) {
271
0
        DCHECK(_skip_bitmap_col_idx == -1);
272
0
        for (size_t cid = _tablet_schema->num_key_columns(); cid < _num_columns; ++cid) {
273
0
            auto* col_ptr = mutable_block.mutable_columns()[cid].get();
274
0
            _agg_functions[cid]->add(dst_row->agg_places(cid),
275
0
                                     const_cast<const doris::vectorized::IColumn**>(&col_ptr),
276
0
                                     src_row->_row_pos, _arena);
277
0
        }
278
    } else {
279
        DCHECK(_skip_bitmap_col_idx != -1);
280
        DCHECK_LT(_skip_bitmap_col_idx, mutable_block.columns());
281
        const BitmapValue& skip_bitmap =
282
                assert_cast<vectorized::ColumnBitmap*, TypeCheckOnRelease::DISABLE>(
283
                        mutable_block.mutable_columns()[_skip_bitmap_col_idx].get())
284
                        ->get_data()[src_row->_row_pos];
285
        for (size_t cid = _tablet_schema->num_key_columns(); cid < _num_columns; ++cid) {
286
            const auto& col = _tablet_schema->column(cid);
287
            if (cid != _skip_bitmap_col_idx && skip_bitmap.contains(col.unique_id())) {
288
                continue;
289
            }
290
            auto* col_ptr = mutable_block.mutable_columns()[cid].get();
291
            _agg_functions[cid]->add(dst_row->agg_places(cid),
292
                                     const_cast<const doris::vectorized::IColumn**>(&col_ptr),
293
                                     src_row->_row_pos, _arena);
294
        }
295
    }
296
0
}
Unexecuted instantiation: _ZN5doris8MemTable27_aggregate_two_row_in_blockILb1EEEvRNS_10vectorized12MutableBlockEPNS_10RowInBlockES6_
297
9
Status MemTable::_put_into_output(vectorized::Block& in_block) {
298
9
    SCOPED_RAW_TIMER(&_stat.put_into_output_ns);
299
9
    DorisVector<uint32_t> row_pos_vec;
300
9
    DCHECK(in_block.rows() <= std::numeric_limits<int>::max());
301
9
    row_pos_vec.reserve(in_block.rows());
302
20
    for (int i = 0; i < _row_in_blocks->size(); i++) {
303
11
        row_pos_vec.emplace_back((*_row_in_blocks)[i]->_row_pos);
304
11
    }
305
9
    return _output_mutable_block.add_rows(&in_block, row_pos_vec.data(),
306
9
                                          row_pos_vec.data() + in_block.rows());
307
9
}
308
309
12
size_t MemTable::_sort() {
310
12
    SCOPED_RAW_TIMER(&_stat.sort_ns);
311
12
    _stat.sort_times++;
312
12
    size_t same_keys_num = 0;
313
    // sort new rows
314
12
    Tie tie = Tie(_last_sorted_pos, _row_in_blocks->size());
315
43
    for (size_t i = 0; i < _tablet_schema->num_key_columns(); i++) {
316
31
        auto cmp = [&](RowInBlock* lhs, RowInBlock* rhs) -> int {
317
30
            return _input_mutable_block.compare_one_column(lhs->_row_pos, rhs->_row_pos, i, -1);
318
30
        };
319
31
        _sort_one_column(*_row_in_blocks, tie, cmp);
320
31
    }
321
12
    bool is_dup = (_keys_type == KeysType::DUP_KEYS);
322
    // sort extra round by _row_pos to make the sort stable
323
12
    auto iter = tie.iter();
324
15
    while (iter.next()) {
325
3
        pdqsort(std::next(_row_in_blocks->begin(), iter.left()),
326
3
                std::next(_row_in_blocks->begin(), iter.right()),
327
3
                [&is_dup](const std::shared_ptr<RowInBlock>& lhs,
328
3
                          const std::shared_ptr<RowInBlock>& rhs) -> bool {
329
3
                    return is_dup ? lhs->_row_pos > rhs->_row_pos : lhs->_row_pos < rhs->_row_pos;
330
3
                });
331
3
        same_keys_num += iter.right() - iter.left();
332
3
    }
333
    // merge new rows and old rows
334
12
    _vec_row_comparator->set_block(&_input_mutable_block);
335
12
    auto cmp_func = [this, is_dup, &same_keys_num](const std::shared_ptr<RowInBlock>& l,
336
12
                                                   const std::shared_ptr<RowInBlock>& r) -> bool {
337
0
        auto value = (*(this->_vec_row_comparator))(l.get(), r.get());
338
0
        if (value == 0) {
339
0
            same_keys_num++;
340
0
            return is_dup ? l->_row_pos > r->_row_pos : l->_row_pos < r->_row_pos;
341
0
        } else {
342
0
            return value < 0;
343
0
        }
344
0
    };
345
12
    auto new_row_it = std::next(_row_in_blocks->begin(), _last_sorted_pos);
346
12
    std::inplace_merge(_row_in_blocks->begin(), new_row_it, _row_in_blocks->end(), cmp_func);
347
12
    _last_sorted_pos = _row_in_blocks->size();
348
12
    return same_keys_num;
349
12
}
350
351
1
Status MemTable::_sort_by_cluster_keys() {
352
1
    SCOPED_RAW_TIMER(&_stat.sort_ns);
353
1
    _stat.sort_times++;
354
    // sort all rows
355
1
    vectorized::Block in_block = _output_mutable_block.to_block();
356
1
    vectorized::MutableBlock mutable_block =
357
1
            vectorized::MutableBlock::build_mutable_block(&in_block);
358
1
    auto clone_block = in_block.clone_without_columns();
359
1
    _output_mutable_block = vectorized::MutableBlock::build_mutable_block(&clone_block);
360
361
1
    DorisVector<std::shared_ptr<RowInBlock>> row_in_blocks;
362
1
    row_in_blocks.reserve(mutable_block.rows());
363
5
    for (size_t i = 0; i < mutable_block.rows(); i++) {
364
4
        row_in_blocks.emplace_back(std::make_shared<RowInBlock>(i));
365
4
    }
366
1
    Tie tie = Tie(0, mutable_block.rows());
367
368
2
    for (auto cid : _tablet_schema->cluster_key_uids()) {
369
2
        auto index = _tablet_schema->field_index(cid);
370
2
        if (index == -1) {
371
0
            return Status::InternalError("could not find cluster key column with unique_id=" +
372
0
                                         std::to_string(cid) + " in tablet schema");
373
0
        }
374
8
        auto cmp = [&](const RowInBlock* lhs, const RowInBlock* rhs) -> int {
375
8
            return mutable_block.compare_one_column(lhs->_row_pos, rhs->_row_pos, index, -1);
376
8
        };
377
2
        _sort_one_column(row_in_blocks, tie, cmp);
378
2
    }
379
380
    // sort extra round by _row_pos to make the sort stable
381
1
    auto iter = tie.iter();
382
1
    while (iter.next()) {
383
0
        pdqsort(std::next(row_in_blocks.begin(), iter.left()),
384
0
                std::next(row_in_blocks.begin(), iter.right()),
385
0
                [](const std::shared_ptr<RowInBlock>& lhs, const std::shared_ptr<RowInBlock>& rhs)
386
0
                        -> bool { return lhs->_row_pos < rhs->_row_pos; });
387
0
    }
388
389
1
    in_block = mutable_block.to_block();
390
1
    SCOPED_RAW_TIMER(&_stat.put_into_output_ns);
391
1
    DorisVector<uint32_t> row_pos_vec;
392
1
    DCHECK(in_block.rows() <= std::numeric_limits<int>::max());
393
1
    row_pos_vec.reserve(in_block.rows());
394
5
    for (int i = 0; i < row_in_blocks.size(); i++) {
395
4
        row_pos_vec.emplace_back(row_in_blocks[i]->_row_pos);
396
4
    }
397
1
    std::vector<int> column_offset;
398
6
    for (int i = 0; i < _column_offset.size(); ++i) {
399
5
        column_offset.emplace_back(i);
400
5
    }
401
1
    return _output_mutable_block.add_rows(&in_block, row_pos_vec.data(),
402
1
                                          row_pos_vec.data() + in_block.rows(), &column_offset);
403
1
}
404
405
void MemTable::_sort_one_column(DorisVector<std::shared_ptr<RowInBlock>>& row_in_blocks, Tie& tie,
406
33
                                std::function<int(RowInBlock*, RowInBlock*)> cmp) {
407
33
    auto iter = tie.iter();
408
43
    while (iter.next()) {
409
10
        pdqsort(std::next(row_in_blocks.begin(), static_cast<int>(iter.left())),
410
10
                std::next(row_in_blocks.begin(), static_cast<int>(iter.right())),
411
21
                [&cmp](auto lhs, auto rhs) -> bool { return cmp(lhs.get(), rhs.get()) < 0; });
412
10
        tie[iter.left()] = 0;
413
27
        for (auto i = iter.left() + 1; i < iter.right(); i++) {
414
17
            tie[i] = (cmp(row_in_blocks[i - 1].get(), row_in_blocks[i].get()) == 0);
415
17
        }
416
10
    }
417
33
}
418
419
template <bool is_final>
420
void MemTable::_finalize_one_row(RowInBlock* row,
421
                                 const vectorized::ColumnsWithTypeAndName& block_data,
422
6
                                 int row_pos) {
423
    // move key columns
424
18
    for (size_t i = 0; i < _tablet_schema->num_key_columns(); ++i) {
425
12
        _output_mutable_block.get_column_by_position(i)->insert_from(*block_data[i].column.get(),
426
12
                                                                     row->_row_pos);
427
12
    }
428
6
    if (row->has_init_agg()) {
429
        // get value columns from agg_places
430
12
        for (size_t i = _tablet_schema->num_key_columns(); i < _num_columns; ++i) {
431
9
            auto function = _agg_functions[i];
432
9
            auto* agg_place = row->agg_places(i);
433
9
            auto* col_ptr = _output_mutable_block.get_column_by_position(i).get();
434
9
            function->insert_result_into(agg_place, *col_ptr);
435
436
9
            if constexpr (is_final) {
437
9
                function->destroy(agg_place);
438
9
            } else {
439
0
                function->reset(agg_place);
440
0
            }
441
9
        }
442
443
3
        if constexpr (is_final) {
444
3
            row->remove_init_agg();
445
3
        } else {
446
0
            for (size_t i = _tablet_schema->num_key_columns(); i < _num_columns; ++i) {
447
0
                auto function = _agg_functions[i];
448
0
                auto* agg_place = row->agg_places(i);
449
0
                auto* col_ptr = _output_mutable_block.get_column_by_position(i).get();
450
0
                function->add(agg_place, const_cast<const doris::vectorized::IColumn**>(&col_ptr),
451
0
                              row_pos, _arena);
452
0
            }
453
0
        }
454
3
    } else {
455
        // move columns for rows do not need agg
456
12
        for (size_t i = _tablet_schema->num_key_columns(); i < _num_columns; ++i) {
457
9
            _output_mutable_block.get_column_by_position(i)->insert_from(
458
9
                    *block_data[i].column.get(), row->_row_pos);
459
9
        }
460
3
    }
461
6
    if constexpr (!is_final) {
462
0
        row->_row_pos = row_pos;
463
0
    }
464
6
}
Unexecuted instantiation: _ZN5doris8MemTable17_finalize_one_rowILb0EEEvPNS_10RowInBlockERKSt6vectorINS_10vectorized21ColumnWithTypeAndNameESaIS6_EEi
_ZN5doris8MemTable17_finalize_one_rowILb1EEEvPNS_10RowInBlockERKSt6vectorINS_10vectorized21ColumnWithTypeAndNameESaIS6_EEi
Line
Count
Source
422
6
                                 int row_pos) {
423
    // move key columns
424
18
    for (size_t i = 0; i < _tablet_schema->num_key_columns(); ++i) {
425
12
        _output_mutable_block.get_column_by_position(i)->insert_from(*block_data[i].column.get(),
426
12
                                                                     row->_row_pos);
427
12
    }
428
6
    if (row->has_init_agg()) {
429
        // get value columns from agg_places
430
12
        for (size_t i = _tablet_schema->num_key_columns(); i < _num_columns; ++i) {
431
9
            auto function = _agg_functions[i];
432
9
            auto* agg_place = row->agg_places(i);
433
9
            auto* col_ptr = _output_mutable_block.get_column_by_position(i).get();
434
9
            function->insert_result_into(agg_place, *col_ptr);
435
436
9
            if constexpr (is_final) {
437
9
                function->destroy(agg_place);
438
            } else {
439
                function->reset(agg_place);
440
            }
441
9
        }
442
443
3
        if constexpr (is_final) {
444
3
            row->remove_init_agg();
445
        } else {
446
            for (size_t i = _tablet_schema->num_key_columns(); i < _num_columns; ++i) {
447
                auto function = _agg_functions[i];
448
                auto* agg_place = row->agg_places(i);
449
                auto* col_ptr = _output_mutable_block.get_column_by_position(i).get();
450
                function->add(agg_place, const_cast<const doris::vectorized::IColumn**>(&col_ptr),
451
                              row_pos, _arena);
452
            }
453
        }
454
3
    } else {
455
        // move columns for rows do not need agg
456
12
        for (size_t i = _tablet_schema->num_key_columns(); i < _num_columns; ++i) {
457
9
            _output_mutable_block.get_column_by_position(i)->insert_from(
458
9
                    *block_data[i].column.get(), row->_row_pos);
459
9
        }
460
3
    }
461
    if constexpr (!is_final) {
462
        row->_row_pos = row_pos;
463
    }
464
6
}
465
466
3
void MemTable::_init_row_for_agg(RowInBlock* row, vectorized::MutableBlock& mutable_block) {
467
3
    row->init_agg_places(_arena.aligned_alloc(_total_size_of_aggregate_states, 16),
468
3
                         _offsets_of_aggregate_states.data());
469
12
    for (auto cid = _tablet_schema->num_key_columns(); cid < _num_columns; cid++) {
470
9
        auto* col_ptr = mutable_block.mutable_columns()[cid].get();
471
9
        auto* data = row->agg_places(cid);
472
9
        _agg_functions[cid]->create(data);
473
9
        _agg_functions[cid]->add(data, const_cast<const doris::vectorized::IColumn**>(&col_ptr),
474
9
                                 row->_row_pos, _arena);
475
9
    }
476
3
}
477
0
void MemTable::_clear_row_agg(RowInBlock* row) {
478
0
    if (row->has_init_agg()) {
479
0
        for (size_t i = _tablet_schema->num_key_columns(); i < _num_columns; ++i) {
480
0
            auto function = _agg_functions[i];
481
0
            auto* agg_place = row->agg_places(i);
482
0
            function->destroy(agg_place);
483
0
        }
484
0
        row->remove_init_agg();
485
0
    }
486
0
}
487
488
template <bool is_final, bool has_skip_bitmap_col>
489
3
void MemTable::_aggregate() {
490
3
    SCOPED_RAW_TIMER(&_stat.agg_ns);
491
3
    _stat.agg_times++;
492
3
    vectorized::Block in_block = _input_mutable_block.to_block();
493
3
    vectorized::MutableBlock mutable_block =
494
3
            vectorized::MutableBlock::build_mutable_block(&in_block);
495
3
    _vec_row_comparator->set_block(&mutable_block);
496
3
    auto& block_data = in_block.get_columns_with_type_and_name();
497
3
    DorisVector<std::shared_ptr<RowInBlock>> temp_row_in_blocks;
498
3
    temp_row_in_blocks.reserve(_last_sorted_pos);
499
    //only init agg if needed
500
501
3
    if constexpr (!has_skip_bitmap_col) {
502
3
        RowInBlock* prev_row = nullptr;
503
3
        int row_pos = -1;
504
9
        for (const auto& cur_row_ptr : *_row_in_blocks) {
505
9
            RowInBlock* cur_row = cur_row_ptr.get();
506
9
            if (!temp_row_in_blocks.empty() && (*_vec_row_comparator)(prev_row, cur_row) == 0) {
507
3
                if (!prev_row->has_init_agg()) {
508
3
                    _init_row_for_agg(prev_row, mutable_block);
509
3
                }
510
3
                _stat.merged_rows++;
511
3
                _aggregate_two_row_in_block<has_skip_bitmap_col>(mutable_block, cur_row, prev_row);
512
6
            } else {
513
6
                prev_row = cur_row;
514
6
                if (!temp_row_in_blocks.empty()) {
515
                    // no more rows to merge for prev row, finalize it
516
3
                    _finalize_one_row<is_final>(temp_row_in_blocks.back().get(), block_data,
517
3
                                                row_pos);
518
3
                }
519
6
                temp_row_in_blocks.push_back(cur_row_ptr);
520
6
                row_pos++;
521
6
            }
522
9
        }
523
3
        if (!temp_row_in_blocks.empty()) {
524
            // finalize the last low
525
3
            _finalize_one_row<is_final>(temp_row_in_blocks.back().get(), block_data, row_pos);
526
3
        }
527
3
    } else {
528
0
        DCHECK(_delete_sign_col_idx != -1);
529
0
        if (_seq_col_idx_in_block == -1) {
530
0
            _aggregate_for_flexible_partial_update_without_seq_col<is_final>(
531
0
                    block_data, mutable_block, temp_row_in_blocks);
532
0
        } else {
533
0
            _aggregate_for_flexible_partial_update_with_seq_col<is_final>(block_data, mutable_block,
534
0
                                                                          temp_row_in_blocks);
535
0
        }
536
0
    }
537
3
    if constexpr (!is_final) {
538
        // if is not final, we collect the agg results to input_block and then continue to insert
539
0
        _input_mutable_block.swap(_output_mutable_block);
540
        //TODO(weixang):opt here.
541
0
        std::unique_ptr<vectorized::Block> empty_input_block = in_block.create_same_struct_block(0);
542
0
        _output_mutable_block =
543
0
                vectorized::MutableBlock::build_mutable_block(empty_input_block.get());
544
0
        _output_mutable_block.clear_column_data();
545
0
        *_row_in_blocks = temp_row_in_blocks;
546
0
        _last_sorted_pos = _row_in_blocks->size();
547
0
    }
548
3
}
Unexecuted instantiation: _ZN5doris8MemTable10_aggregateILb0ELb0EEEvv
Unexecuted instantiation: _ZN5doris8MemTable10_aggregateILb0ELb1EEEvv
_ZN5doris8MemTable10_aggregateILb1ELb0EEEvv
Line
Count
Source
489
3
void MemTable::_aggregate() {
490
3
    SCOPED_RAW_TIMER(&_stat.agg_ns);
491
3
    _stat.agg_times++;
492
3
    vectorized::Block in_block = _input_mutable_block.to_block();
493
3
    vectorized::MutableBlock mutable_block =
494
3
            vectorized::MutableBlock::build_mutable_block(&in_block);
495
3
    _vec_row_comparator->set_block(&mutable_block);
496
3
    auto& block_data = in_block.get_columns_with_type_and_name();
497
3
    DorisVector<std::shared_ptr<RowInBlock>> temp_row_in_blocks;
498
3
    temp_row_in_blocks.reserve(_last_sorted_pos);
499
    //only init agg if needed
500
501
3
    if constexpr (!has_skip_bitmap_col) {
502
3
        RowInBlock* prev_row = nullptr;
503
3
        int row_pos = -1;
504
9
        for (const auto& cur_row_ptr : *_row_in_blocks) {
505
9
            RowInBlock* cur_row = cur_row_ptr.get();
506
9
            if (!temp_row_in_blocks.empty() && (*_vec_row_comparator)(prev_row, cur_row) == 0) {
507
3
                if (!prev_row->has_init_agg()) {
508
3
                    _init_row_for_agg(prev_row, mutable_block);
509
3
                }
510
3
                _stat.merged_rows++;
511
3
                _aggregate_two_row_in_block<has_skip_bitmap_col>(mutable_block, cur_row, prev_row);
512
6
            } else {
513
6
                prev_row = cur_row;
514
6
                if (!temp_row_in_blocks.empty()) {
515
                    // no more rows to merge for prev row, finalize it
516
3
                    _finalize_one_row<is_final>(temp_row_in_blocks.back().get(), block_data,
517
3
                                                row_pos);
518
3
                }
519
6
                temp_row_in_blocks.push_back(cur_row_ptr);
520
6
                row_pos++;
521
6
            }
522
9
        }
523
3
        if (!temp_row_in_blocks.empty()) {
524
            // finalize the last low
525
3
            _finalize_one_row<is_final>(temp_row_in_blocks.back().get(), block_data, row_pos);
526
3
        }
527
    } else {
528
        DCHECK(_delete_sign_col_idx != -1);
529
        if (_seq_col_idx_in_block == -1) {
530
            _aggregate_for_flexible_partial_update_without_seq_col<is_final>(
531
                    block_data, mutable_block, temp_row_in_blocks);
532
        } else {
533
            _aggregate_for_flexible_partial_update_with_seq_col<is_final>(block_data, mutable_block,
534
                                                                          temp_row_in_blocks);
535
        }
536
    }
537
    if constexpr (!is_final) {
538
        // if is not final, we collect the agg results to input_block and then continue to insert
539
        _input_mutable_block.swap(_output_mutable_block);
540
        //TODO(weixang):opt here.
541
        std::unique_ptr<vectorized::Block> empty_input_block = in_block.create_same_struct_block(0);
542
        _output_mutable_block =
543
                vectorized::MutableBlock::build_mutable_block(empty_input_block.get());
544
        _output_mutable_block.clear_column_data();
545
        *_row_in_blocks = temp_row_in_blocks;
546
        _last_sorted_pos = _row_in_blocks->size();
547
    }
548
3
}
Unexecuted instantiation: _ZN5doris8MemTable10_aggregateILb1ELb1EEEvv
549
550
template <bool is_final>
551
void MemTable::_aggregate_for_flexible_partial_update_without_seq_col(
552
        const vectorized::ColumnsWithTypeAndName& block_data,
553
        vectorized::MutableBlock& mutable_block,
554
0
        DorisVector<std::shared_ptr<RowInBlock>>& temp_row_in_blocks) {
555
0
    std::shared_ptr<RowInBlock> prev_row {nullptr};
556
0
    int row_pos = -1;
557
0
    auto& skip_bitmaps = assert_cast<vectorized::ColumnBitmap*>(
558
0
                                 mutable_block.mutable_columns()[_skip_bitmap_col_idx].get())
559
0
                                 ->get_data();
560
0
    auto& delete_signs = assert_cast<vectorized::ColumnInt8*>(
561
0
                                 mutable_block.mutable_columns()[_delete_sign_col_idx].get())
562
0
                                 ->get_data();
563
0
    std::shared_ptr<RowInBlock> row_with_delete_sign {nullptr};
564
0
    std::shared_ptr<RowInBlock> row_without_delete_sign {nullptr};
565
566
0
    auto finalize_rows = [&]() {
567
0
        if (row_with_delete_sign != nullptr) {
568
0
            temp_row_in_blocks.push_back(row_with_delete_sign);
569
0
            _finalize_one_row<is_final>(row_with_delete_sign.get(), block_data, ++row_pos);
570
0
            row_with_delete_sign = nullptr;
571
0
        }
572
0
        if (row_without_delete_sign != nullptr) {
573
0
            temp_row_in_blocks.push_back(row_without_delete_sign);
574
0
            _finalize_one_row<is_final>(row_without_delete_sign.get(), block_data, ++row_pos);
575
0
            row_without_delete_sign = nullptr;
576
0
        }
577
        // _arena.clear();
578
0
    };
Unexecuted instantiation: _ZZN5doris8MemTable54_aggregate_for_flexible_partial_update_without_seq_colILb0EEEvRKSt6vectorINS_10vectorized21ColumnWithTypeAndNameESaIS4_EERNS3_12MutableBlockERS2_ISt10shared_ptrINS_10RowInBlockEENS_18CustomStdAllocatorISD_NS_9AllocatorILb0ELb0ELb0ENS_22DefaultMemoryAllocatorELb1EEEEEEENKUlvE_clEv
Unexecuted instantiation: _ZZN5doris8MemTable54_aggregate_for_flexible_partial_update_without_seq_colILb1EEEvRKSt6vectorINS_10vectorized21ColumnWithTypeAndNameESaIS4_EERNS3_12MutableBlockERS2_ISt10shared_ptrINS_10RowInBlockEENS_18CustomStdAllocatorISD_NS_9AllocatorILb0ELb0ELb0ENS_22DefaultMemoryAllocatorELb1EEEEEEENKUlvE_clEv
579
580
0
    auto add_row = [&](std::shared_ptr<RowInBlock> row, bool with_delete_sign) {
581
0
        if (with_delete_sign) {
582
0
            row_with_delete_sign = std::move(row);
583
0
        } else {
584
0
            row_without_delete_sign = std::move(row);
585
0
        }
586
0
    };
Unexecuted instantiation: _ZZN5doris8MemTable54_aggregate_for_flexible_partial_update_without_seq_colILb0EEEvRKSt6vectorINS_10vectorized21ColumnWithTypeAndNameESaIS4_EERNS3_12MutableBlockERS2_ISt10shared_ptrINS_10RowInBlockEENS_18CustomStdAllocatorISD_NS_9AllocatorILb0ELb0ELb0ENS_22DefaultMemoryAllocatorELb1EEEEEEENKUlSD_bE_clESD_b
Unexecuted instantiation: _ZZN5doris8MemTable54_aggregate_for_flexible_partial_update_without_seq_colILb1EEEvRKSt6vectorINS_10vectorized21ColumnWithTypeAndNameESaIS4_EERNS3_12MutableBlockERS2_ISt10shared_ptrINS_10RowInBlockEENS_18CustomStdAllocatorISD_NS_9AllocatorILb0ELb0ELb0ENS_22DefaultMemoryAllocatorELb1EEEEEEENKUlSD_bE_clESD_b
587
0
    for (const auto& cur_row_ptr : *_row_in_blocks) {
588
0
        RowInBlock* cur_row = cur_row_ptr.get();
589
0
        const BitmapValue& skip_bitmap = skip_bitmaps[cur_row->_row_pos];
590
0
        bool cur_row_has_delete_sign = (!skip_bitmap.contains(_delete_sign_col_unique_id) &&
591
0
                                        delete_signs[cur_row->_row_pos] != 0);
592
0
        prev_row =
593
0
                (row_with_delete_sign == nullptr) ? row_without_delete_sign : row_with_delete_sign;
594
        // compare keys, the keys of row_with_delete_sign and row_without_delete_sign is the same,
595
        // choose any of them if it's valid
596
0
        if (prev_row != nullptr && (*_vec_row_comparator)(prev_row.get(), cur_row) == 0) {
597
0
            if (cur_row_has_delete_sign) {
598
0
                if (row_without_delete_sign != nullptr) {
599
                    // if there exits row without delete sign, remove it first
600
0
                    _clear_row_agg(row_without_delete_sign.get());
601
0
                    _stat.merged_rows++;
602
0
                    row_without_delete_sign = nullptr;
603
0
                }
604
                // and then unconditionally replace the previous row
605
0
                prev_row = row_with_delete_sign;
606
0
            } else {
607
0
                prev_row = row_without_delete_sign;
608
0
            }
609
610
0
            if (prev_row == nullptr) {
611
0
                add_row(cur_row_ptr, cur_row_has_delete_sign);
612
0
            } else {
613
0
                if (!prev_row->has_init_agg()) {
614
0
                    _init_row_for_agg(prev_row.get(), mutable_block);
615
0
                }
616
0
                _stat.merged_rows++;
617
0
                _aggregate_two_row_in_block<true>(mutable_block, cur_row, prev_row.get());
618
0
            }
619
0
        } else {
620
0
            finalize_rows();
621
0
            add_row(cur_row_ptr, cur_row_has_delete_sign);
622
0
        }
623
0
    }
624
    // finalize the last lows
625
0
    finalize_rows();
626
0
}
Unexecuted instantiation: _ZN5doris8MemTable54_aggregate_for_flexible_partial_update_without_seq_colILb0EEEvRKSt6vectorINS_10vectorized21ColumnWithTypeAndNameESaIS4_EERNS3_12MutableBlockERS2_ISt10shared_ptrINS_10RowInBlockEENS_18CustomStdAllocatorISD_NS_9AllocatorILb0ELb0ELb0ENS_22DefaultMemoryAllocatorELb1EEEEEE
Unexecuted instantiation: _ZN5doris8MemTable54_aggregate_for_flexible_partial_update_without_seq_colILb1EEEvRKSt6vectorINS_10vectorized21ColumnWithTypeAndNameESaIS4_EERNS3_12MutableBlockERS2_ISt10shared_ptrINS_10RowInBlockEENS_18CustomStdAllocatorISD_NS_9AllocatorILb0ELb0ELb0ENS_22DefaultMemoryAllocatorELb1EEEEEE
627
628
template <bool is_final>
629
void MemTable::_aggregate_for_flexible_partial_update_with_seq_col(
630
        const vectorized::ColumnsWithTypeAndName& block_data,
631
        vectorized::MutableBlock& mutable_block,
632
0
        DorisVector<std::shared_ptr<RowInBlock>>& temp_row_in_blocks) {
633
    // For flexible partial update, when table has sequence column, we don't do any aggregation
634
    // in memtable. These duplicate rows will be aggregated in VerticalSegmentWriter
635
0
    int row_pos = -1;
636
0
    for (const auto& row_ptr : *_row_in_blocks) {
637
0
        RowInBlock* row = row_ptr.get();
638
0
        temp_row_in_blocks.push_back(row_ptr);
639
0
        _finalize_one_row<is_final>(row, block_data, ++row_pos);
640
0
    }
641
0
}
Unexecuted instantiation: _ZN5doris8MemTable51_aggregate_for_flexible_partial_update_with_seq_colILb0EEEvRKSt6vectorINS_10vectorized21ColumnWithTypeAndNameESaIS4_EERNS3_12MutableBlockERS2_ISt10shared_ptrINS_10RowInBlockEENS_18CustomStdAllocatorISD_NS_9AllocatorILb0ELb0ELb0ENS_22DefaultMemoryAllocatorELb1EEEEEE
Unexecuted instantiation: _ZN5doris8MemTable51_aggregate_for_flexible_partial_update_with_seq_colILb1EEEvRKSt6vectorINS_10vectorized21ColumnWithTypeAndNameESaIS4_EERNS3_12MutableBlockERS2_ISt10shared_ptrINS_10RowInBlockEENS_18CustomStdAllocatorISD_NS_9AllocatorILb0ELb0ELb0ENS_22DefaultMemoryAllocatorELb1EEEEEE
642
643
0
void MemTable::shrink_memtable_by_agg() {
644
0
    SCOPED_SWITCH_THREAD_MEM_TRACKER_LIMITER(
645
0
            _resource_ctx->memory_context()->mem_tracker()->write_tracker());
646
0
    SCOPED_CONSUME_MEM_TRACKER(_mem_tracker);
647
0
    if (_keys_type == KeysType::DUP_KEYS) {
648
0
        return;
649
0
    }
650
0
    size_t same_keys_num = _sort();
651
0
    if (same_keys_num != 0) {
652
0
        (_skip_bitmap_col_idx == -1) ? _aggregate<false, false>() : _aggregate<false, true>();
653
0
    }
654
0
    _last_agg_pos = memory_usage();
655
0
}
656
657
20
bool MemTable::need_flush() const {
658
20
    DBUG_EXECUTE_IF("MemTable.need_flush", { return true; });
659
20
    auto max_size = config::write_buffer_size;
660
20
    if (_partial_update_mode == UniqueKeyUpdateModePB::UPDATE_FIXED_COLUMNS) {
661
0
        auto update_columns_size = _num_columns;
662
0
        auto min_buffer_size = config::min_write_buffer_size_for_partial_update;
663
0
        max_size = max_size * update_columns_size / _tablet_schema->num_columns();
664
0
        max_size = max_size > min_buffer_size ? max_size : min_buffer_size;
665
0
    }
666
667
20
    if (memory_usage() >= max_size) {
668
0
        g_flush_cuz_memtable_full << 1;
669
0
        return true;
670
0
    }
671
20
    return false;
672
20
}
673
674
20
bool MemTable::need_agg() const {
675
20
    if (_keys_type == KeysType::AGG_KEYS) {
676
5
        auto max_size = _last_agg_pos + config::write_buffer_size_for_agg;
677
5
        return memory_usage() >= max_size;
678
5
    }
679
15
    return false;
680
20
}
681
682
12
size_t MemTable::get_flush_reserve_memory_size() const {
683
12
    if (_keys_type == KeysType::DUP_KEYS && _tablet_schema->num_key_columns() == 0) {
684
0
        return 0; // no need to reserve
685
0
    }
686
12
    return static_cast<size_t>(static_cast<double>(_input_mutable_block.allocated_bytes()) * 1.2);
687
12
}
688
689
12
Status MemTable::_to_block(std::unique_ptr<vectorized::Block>* res) {
690
12
    size_t same_keys_num = _sort();
691
12
    if (_keys_type == KeysType::DUP_KEYS || same_keys_num == 0) {
692
9
        if (_keys_type == KeysType::DUP_KEYS && _tablet_schema->num_key_columns() == 0) {
693
0
            _output_mutable_block.swap(_input_mutable_block);
694
9
        } else {
695
9
            vectorized::Block in_block = _input_mutable_block.to_block();
696
9
            RETURN_IF_ERROR(_put_into_output(in_block));
697
9
        }
698
9
    } else {
699
3
        (_skip_bitmap_col_idx == -1) ? _aggregate<true, false>() : _aggregate<true, true>();
700
3
    }
701
12
    if (_keys_type == KeysType::UNIQUE_KEYS && _enable_unique_key_mow &&
702
12
        !_tablet_schema->cluster_key_uids().empty()) {
703
1
        if (_partial_update_mode != UniqueKeyUpdateModePB::UPSERT) {
704
0
            return Status::InternalError(
705
0
                    "Partial update for mow with cluster keys is not supported");
706
0
        }
707
1
        RETURN_IF_ERROR(_sort_by_cluster_keys());
708
1
    }
709
12
    _input_mutable_block.clear();
710
12
    *res = vectorized::Block::create_unique(_output_mutable_block.to_block());
711
12
    return Status::OK();
712
12
}
713
714
12
Status MemTable::to_block(std::unique_ptr<vectorized::Block>* res) {
715
12
    RETURN_IF_ERROR_OR_CATCH_EXCEPTION(_to_block(res));
716
12
    return Status::OK();
717
12
}
718
719
#include "common/compile_check_end.h"
720
} // namespace doris