Coverage Report

Created: 2026-01-20 09:12

next uncovered line (L), next uncovered region (R), next uncovered branch (B)
/root/doris/be/src/pipeline/dependency.h
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
#pragma once
19
20
#ifdef __APPLE__
21
#include <netinet/in.h>
22
#include <sys/_types/_u_int.h>
23
#endif
24
25
#include <concurrentqueue.h>
26
#include <sqltypes.h>
27
28
#include <atomic>
29
#include <functional>
30
#include <memory>
31
#include <mutex>
32
#include <thread>
33
#include <utility>
34
35
#include "common/config.h"
36
#include "common/logging.h"
37
#include "gen_cpp/internal_service.pb.h"
38
#include "pipeline/common/agg_utils.h"
39
#include "pipeline/common/join_utils.h"
40
#include "pipeline/common/set_utils.h"
41
#include "pipeline/exec/data_queue.h"
42
#include "pipeline/exec/join/process_hash_table_probe.h"
43
#include "util/brpc_closure.h"
44
#include "util/stack_util.h"
45
#include "vec/common/sort/partition_sorter.h"
46
#include "vec/common/sort/sorter.h"
47
#include "vec/core/block.h"
48
#include "vec/core/types.h"
49
#include "vec/spill/spill_stream.h"
50
51
namespace doris::vectorized {
52
class AggFnEvaluator;
53
class VSlotRef;
54
} // namespace doris::vectorized
55
56
namespace doris::pipeline {
57
#include "common/compile_check_begin.h"
58
class Dependency;
59
class PipelineTask;
60
struct BasicSharedState;
61
using DependencySPtr = std::shared_ptr<Dependency>;
62
class LocalExchangeSourceLocalState;
63
64
static constexpr auto SLOW_DEPENDENCY_THRESHOLD = 60 * 1000L * 1000L * 1000L;
65
static constexpr auto TIME_UNIT_DEPENDENCY_LOG = 30 * 1000L * 1000L * 1000L;
66
static_assert(TIME_UNIT_DEPENDENCY_LOG < SLOW_DEPENDENCY_THRESHOLD);
67
68
struct BasicSharedState {
69
    ENABLE_FACTORY_CREATOR(BasicSharedState)
70
71
    template <class TARGET>
72
2.06M
    TARGET* cast() {
73
18.4E
        DCHECK(dynamic_cast<TARGET*>(this))
74
18.4E
                << " Mismatch type! Current type is " << typeid(*this).name()
75
18.4E
                << " and expect type is" << typeid(TARGET).name();
76
2.06M
        return reinterpret_cast<TARGET*>(this);
77
2.06M
    }
_ZN5doris8pipeline16BasicSharedState4castINS0_19HashJoinSharedStateEEEPT_v
Line
Count
Source
72
171k
    TARGET* cast() {
73
18.4E
        DCHECK(dynamic_cast<TARGET*>(this))
74
18.4E
                << " Mismatch type! Current type is " << typeid(*this).name()
75
18.4E
                << " and expect type is" << typeid(TARGET).name();
76
171k
        return reinterpret_cast<TARGET*>(this);
77
171k
    }
_ZN5doris8pipeline16BasicSharedState4castINS0_30PartitionedHashJoinSharedStateEEEPT_v
Line
Count
Source
72
3
    TARGET* cast() {
73
3
        DCHECK(dynamic_cast<TARGET*>(this))
74
0
                << " Mismatch type! Current type is " << typeid(*this).name()
75
0
                << " and expect type is" << typeid(TARGET).name();
76
3
        return reinterpret_cast<TARGET*>(this);
77
3
    }
_ZN5doris8pipeline16BasicSharedState4castINS0_15SortSharedStateEEEPT_v
Line
Count
Source
72
283k
    TARGET* cast() {
73
18.4E
        DCHECK(dynamic_cast<TARGET*>(this))
74
18.4E
                << " Mismatch type! Current type is " << typeid(*this).name()
75
18.4E
                << " and expect type is" << typeid(TARGET).name();
76
283k
        return reinterpret_cast<TARGET*>(this);
77
283k
    }
_ZN5doris8pipeline16BasicSharedState4castINS0_20SpillSortSharedStateEEEPT_v
Line
Count
Source
72
61
    TARGET* cast() {
73
61
        DCHECK(dynamic_cast<TARGET*>(this))
74
0
                << " Mismatch type! Current type is " << typeid(*this).name()
75
0
                << " and expect type is" << typeid(TARGET).name();
76
61
        return reinterpret_cast<TARGET*>(this);
77
61
    }
_ZN5doris8pipeline16BasicSharedState4castINS0_25NestedLoopJoinSharedStateEEEPT_v
Line
Count
Source
72
10.1k
    TARGET* cast() {
73
18.4E
        DCHECK(dynamic_cast<TARGET*>(this))
74
18.4E
                << " Mismatch type! Current type is " << typeid(*this).name()
75
18.4E
                << " and expect type is" << typeid(TARGET).name();
76
10.1k
        return reinterpret_cast<TARGET*>(this);
77
10.1k
    }
_ZN5doris8pipeline16BasicSharedState4castINS0_19AnalyticSharedStateEEEPT_v
Line
Count
Source
72
13.3k
    TARGET* cast() {
73
18.4E
        DCHECK(dynamic_cast<TARGET*>(this))
74
18.4E
                << " Mismatch type! Current type is " << typeid(*this).name()
75
18.4E
                << " and expect type is" << typeid(TARGET).name();
76
13.3k
        return reinterpret_cast<TARGET*>(this);
77
13.3k
    }
_ZN5doris8pipeline16BasicSharedState4castINS0_14AggSharedStateEEEPT_v
Line
Count
Source
72
207k
    TARGET* cast() {
73
18.4E
        DCHECK(dynamic_cast<TARGET*>(this))
74
18.4E
                << " Mismatch type! Current type is " << typeid(*this).name()
75
18.4E
                << " and expect type is" << typeid(TARGET).name();
76
207k
        return reinterpret_cast<TARGET*>(this);
77
207k
    }
_ZN5doris8pipeline16BasicSharedState4castINS0_25PartitionedAggSharedStateEEEPT_v
Line
Count
Source
72
626
    TARGET* cast() {
73
626
        DCHECK(dynamic_cast<TARGET*>(this))
74
0
                << " Mismatch type! Current type is " << typeid(*this).name()
75
0
                << " and expect type is" << typeid(TARGET).name();
76
626
        return reinterpret_cast<TARGET*>(this);
77
626
    }
_ZN5doris8pipeline16BasicSharedState4castINS0_16UnionSharedStateEEEPT_v
Line
Count
Source
72
6.34k
    TARGET* cast() {
73
18.4E
        DCHECK(dynamic_cast<TARGET*>(this))
74
18.4E
                << " Mismatch type! Current type is " << typeid(*this).name()
75
18.4E
                << " and expect type is" << typeid(TARGET).name();
76
6.34k
        return reinterpret_cast<TARGET*>(this);
77
6.34k
    }
_ZN5doris8pipeline16BasicSharedState4castINS0_28PartitionSortNodeSharedStateEEEPT_v
Line
Count
Source
72
667
    TARGET* cast() {
73
18.4E
        DCHECK(dynamic_cast<TARGET*>(this))
74
18.4E
                << " Mismatch type! Current type is " << typeid(*this).name()
75
18.4E
                << " and expect type is" << typeid(TARGET).name();
76
667
        return reinterpret_cast<TARGET*>(this);
77
667
    }
_ZN5doris8pipeline16BasicSharedState4castINS0_20MultiCastSharedStateEEEPT_v
Line
Count
Source
72
7.12k
    TARGET* cast() {
73
18.4E
        DCHECK(dynamic_cast<TARGET*>(this))
74
18.4E
                << " Mismatch type! Current type is " << typeid(*this).name()
75
18.4E
                << " and expect type is" << typeid(TARGET).name();
76
7.12k
        return reinterpret_cast<TARGET*>(this);
77
7.12k
    }
_ZN5doris8pipeline16BasicSharedState4castINS0_14SetSharedStateEEEPT_v
Line
Count
Source
72
3.08k
    TARGET* cast() {
73
18.4E
        DCHECK(dynamic_cast<TARGET*>(this))
74
18.4E
                << " Mismatch type! Current type is " << typeid(*this).name()
75
18.4E
                << " and expect type is" << typeid(TARGET).name();
76
3.08k
        return reinterpret_cast<TARGET*>(this);
77
3.08k
    }
_ZN5doris8pipeline16BasicSharedState4castINS0_24LocalExchangeSharedStateEEEPT_v
Line
Count
Source
72
952k
    TARGET* cast() {
73
18.4E
        DCHECK(dynamic_cast<TARGET*>(this))
74
18.4E
                << " Mismatch type! Current type is " << typeid(*this).name()
75
18.4E
                << " and expect type is" << typeid(TARGET).name();
76
952k
        return reinterpret_cast<TARGET*>(this);
77
952k
    }
_ZN5doris8pipeline16BasicSharedState4castIS1_EEPT_v
Line
Count
Source
72
411k
    TARGET* cast() {
73
18.4E
        DCHECK(dynamic_cast<TARGET*>(this))
74
18.4E
                << " Mismatch type! Current type is " << typeid(*this).name()
75
18.4E
                << " and expect type is" << typeid(TARGET).name();
76
411k
        return reinterpret_cast<TARGET*>(this);
77
411k
    }
_ZN5doris8pipeline16BasicSharedState4castINS0_20DataQueueSharedStateEEEPT_v
Line
Count
Source
72
629
    TARGET* cast() {
73
18.4E
        DCHECK(dynamic_cast<TARGET*>(this))
74
18.4E
                << " Mismatch type! Current type is " << typeid(*this).name()
75
18.4E
                << " and expect type is" << typeid(TARGET).name();
76
629
        return reinterpret_cast<TARGET*>(this);
77
629
    }
_ZN5doris8pipeline16BasicSharedState4castINS0_17RecCTESharedStateEEEPT_v
Line
Count
Source
72
377
    TARGET* cast() {
73
377
        DCHECK(dynamic_cast<TARGET*>(this))
74
0
                << " Mismatch type! Current type is " << typeid(*this).name()
75
0
                << " and expect type is" << typeid(TARGET).name();
76
377
        return reinterpret_cast<TARGET*>(this);
77
377
    }
78
    template <class TARGET>
79
    const TARGET* cast() const {
80
        DCHECK(dynamic_cast<const TARGET*>(this))
81
                << " Mismatch type! Current type is " << typeid(*this).name()
82
                << " and expect type is" << typeid(TARGET).name();
83
        return reinterpret_cast<const TARGET*>(this);
84
    }
85
    std::vector<DependencySPtr> source_deps;
86
    std::vector<DependencySPtr> sink_deps;
87
    int id = 0;
88
    std::set<int> related_op_ids;
89
90
1.42M
    virtual ~BasicSharedState() = default;
91
92
    void create_source_dependencies(int num_sources, int operator_id, int node_id,
93
                                    const std::string& name);
94
    Dependency* create_source_dependency(int operator_id, int node_id, const std::string& name);
95
96
    Dependency* create_sink_dependency(int dest_id, int node_id, const std::string& name);
97
662k
    std::vector<DependencySPtr> get_dep_by_channel_id(int channel_id) {
98
662k
        DCHECK_LT(channel_id, source_deps.size());
99
662k
        return {source_deps[channel_id]};
100
662k
    }
101
};
102
103
class Dependency : public std::enable_shared_from_this<Dependency> {
104
public:
105
    ENABLE_FACTORY_CREATOR(Dependency);
106
    Dependency(int id, int node_id, std::string name, bool ready = false)
107
5.13M
            : _id(id), _node_id(node_id), _name(std::move(name)), _ready(ready) {}
108
5.18M
    virtual ~Dependency() = default;
109
110
0
    [[nodiscard]] int id() const { return _id; }
111
6.32M
    [[nodiscard]] virtual std::string name() const { return _name; }
112
323k
    BasicSharedState* shared_state() { return _shared_state; }
113
1.94M
    void set_shared_state(BasicSharedState* shared_state) { _shared_state = shared_state; }
114
    virtual std::string debug_string(int indentation_level = 0);
115
681M
    bool ready() const { return _ready; }
116
117
    // Start the watcher. We use it to count how long this dependency block the current pipeline task.
118
3.94M
    void start_watcher() { _watcher.start(); }
119
6.84M
    [[nodiscard]] int64_t watcher_elapse_time() { return _watcher.elapsed_time(); }
120
121
    // Which dependency current pipeline task is blocked by. `nullptr` if this dependency is ready.
122
    [[nodiscard]] Dependency* is_blocked_by(std::shared_ptr<PipelineTask> task = nullptr);
123
    // Notify downstream pipeline tasks this dependency is ready.
124
    void set_ready();
125
351k
    void set_ready_to_read(int channel_id = 0) {
126
351k
        DCHECK_LT(channel_id, _shared_state->source_deps.size()) << debug_string();
127
351k
        _shared_state->source_deps[channel_id]->set_ready();
128
351k
    }
129
1.16k
    void set_ready_to_write() {
130
1.16k
        DCHECK_EQ(_shared_state->sink_deps.size(), 1) << debug_string();
131
1.16k
        _shared_state->sink_deps.front()->set_ready();
132
1.16k
    }
133
134
    // Notify downstream pipeline tasks this dependency is blocked.
135
1.12M
    void block() {
136
1.12M
        if (_always_ready) {
137
210k
            return;
138
210k
        }
139
915k
        std::unique_lock<std::mutex> lc(_always_ready_lock);
140
915k
        if (_always_ready) {
141
4
            return;
142
4
        }
143
915k
        _ready = false;
144
915k
    }
145
146
3.52M
    void set_always_ready() {
147
3.52M
        if (_always_ready) {
148
1.62M
            return;
149
1.62M
        }
150
1.89M
        std::unique_lock<std::mutex> lc(_always_ready_lock);
151
1.89M
        if (_always_ready) {
152
0
            return;
153
0
        }
154
1.89M
        _always_ready = true;
155
1.89M
        set_ready();
156
1.89M
    }
157
158
protected:
159
    void _add_block_task(std::shared_ptr<PipelineTask> task);
160
161
    const int _id;
162
    const int _node_id;
163
    const std::string _name;
164
    std::atomic<bool> _ready;
165
166
    BasicSharedState* _shared_state = nullptr;
167
    MonotonicStopWatch _watcher;
168
169
    std::mutex _task_lock;
170
    std::vector<std::weak_ptr<PipelineTask>> _blocked_task;
171
172
    // If `_always_ready` is true, `block()` will never block tasks.
173
    std::atomic<bool> _always_ready = false;
174
    std::mutex _always_ready_lock;
175
};
176
177
struct FakeSharedState final : public BasicSharedState {
178
    ENABLE_FACTORY_CREATOR(FakeSharedState)
179
};
180
181
class CountedFinishDependency final : public Dependency {
182
public:
183
    using SharedState = FakeSharedState;
184
    CountedFinishDependency(int id, int node_id, std::string name)
185
135k
            : Dependency(id, node_id, std::move(name), true) {}
186
187
2.58k
    void add(uint32_t count = 1) {
188
2.58k
        std::unique_lock<std::mutex> l(_mtx);
189
2.58k
        if (!_counter) {
190
2.58k
            block();
191
2.58k
        }
192
2.58k
        _counter += count;
193
2.58k
    }
194
195
2.59k
    void sub() {
196
2.59k
        std::unique_lock<std::mutex> l(_mtx);
197
2.59k
        _counter--;
198
2.59k
        if (!_counter) {
199
2.59k
            set_ready();
200
2.59k
        }
201
2.59k
    }
202
203
    std::string debug_string(int indentation_level = 0) override;
204
205
private:
206
    std::mutex _mtx;
207
    uint32_t _counter = 0;
208
};
209
210
struct RuntimeFilterTimerQueue;
211
class RuntimeFilterTimer {
212
public:
213
    RuntimeFilterTimer(int64_t registration_time, int32_t wait_time_ms,
214
                       std::shared_ptr<Dependency> parent, bool force_wait_timeout = false)
215
14.8k
            : _parent(std::move(parent)),
216
14.8k
              _registration_time(registration_time),
217
14.8k
              _wait_time_ms(wait_time_ms),
218
14.8k
              _force_wait_timeout(force_wait_timeout) {}
219
220
    // Called by runtime filter producer.
221
    void call_ready();
222
223
    // Called by RuntimeFilterTimerQueue which is responsible for checking if this rf is timeout.
224
    void call_timeout();
225
226
2.65M
    int64_t registration_time() const { return _registration_time; }
227
2.65M
    int32_t wait_time_ms() const { return _wait_time_ms; }
228
229
    void set_local_runtime_filter_dependencies(
230
3.49k
            const std::vector<std::shared_ptr<Dependency>>& deps) {
231
3.49k
        _local_runtime_filter_dependencies = deps;
232
3.49k
    }
233
234
    bool should_be_check_timeout();
235
236
2.66M
    bool force_wait_timeout() { return _force_wait_timeout; }
237
238
private:
239
    friend struct RuntimeFilterTimerQueue;
240
    std::shared_ptr<Dependency> _parent = nullptr;
241
    std::vector<std::shared_ptr<Dependency>> _local_runtime_filter_dependencies;
242
    std::mutex _lock;
243
    int64_t _registration_time;
244
    const int32_t _wait_time_ms;
245
    // true only for group_commit_scan_operator
246
    bool _force_wait_timeout;
247
};
248
249
struct RuntimeFilterTimerQueue {
250
    constexpr static int64_t interval = 10;
251
8
    void run() { _thread.detach(); }
252
    void start();
253
254
3
    void stop() {
255
3
        _stop = true;
256
3
        cv.notify_all();
257
3
        wait_for_shutdown();
258
3
    }
259
260
3
    void wait_for_shutdown() const {
261
6
        while (!_shutdown) {
262
3
            std::this_thread::sleep_for(std::chrono::milliseconds(interval));
263
3
        }
264
3
    }
265
266
3
    ~RuntimeFilterTimerQueue() = default;
267
8
    RuntimeFilterTimerQueue() { _thread = std::thread(&RuntimeFilterTimerQueue::start, this); }
268
8.68k
    void push_filter_timer(std::vector<std::shared_ptr<pipeline::RuntimeFilterTimer>>&& filter) {
269
8.68k
        std::unique_lock<std::mutex> lc(_que_lock);
270
8.68k
        _que.insert(_que.end(), filter.begin(), filter.end());
271
8.68k
        cv.notify_all();
272
8.68k
    }
273
274
    std::thread _thread;
275
    std::condition_variable cv;
276
    std::mutex cv_m;
277
    std::mutex _que_lock;
278
    std::atomic_bool _stop = false;
279
    std::atomic_bool _shutdown = false;
280
    std::list<std::shared_ptr<pipeline::RuntimeFilterTimer>> _que;
281
};
282
283
struct AggSharedState : public BasicSharedState {
284
    ENABLE_FACTORY_CREATOR(AggSharedState)
285
public:
286
105k
    AggSharedState() { agg_data = std::make_unique<AggregatedDataVariants>(); }
287
105k
    ~AggSharedState() override {
288
105k
        if (!probe_expr_ctxs.empty()) {
289
38.1k
            _close_with_serialized_key();
290
67.2k
        } else {
291
67.2k
            _close_without_key();
292
67.2k
        }
293
105k
    }
294
295
    Status reset_hash_table();
296
297
    bool do_limit_filter(vectorized::Block* block, size_t num_rows,
298
                         const std::vector<int>* key_locs = nullptr);
299
    void build_limit_heap(size_t hash_table_size);
300
301
    // We should call this function only at 1st phase.
302
    // 1st phase: is_merge=true, only have one SlotRef.
303
    // 2nd phase: is_merge=false, maybe have multiple exprs.
304
    static int get_slot_column_id(const vectorized::AggFnEvaluator* evaluator);
305
306
    AggregatedDataVariantsUPtr agg_data = nullptr;
307
    std::unique_ptr<AggregateDataContainer> aggregate_data_container;
308
    std::vector<vectorized::AggFnEvaluator*> aggregate_evaluators;
309
    // group by k1,k2
310
    vectorized::VExprContextSPtrs probe_expr_ctxs;
311
    size_t input_num_rows = 0;
312
    std::vector<vectorized::AggregateDataPtr> values;
313
    /// The total size of the row from the aggregate functions.
314
    size_t total_size_of_aggregate_states = 0;
315
    size_t align_aggregate_states = 1;
316
    /// The offset to the n-th aggregate function in a row of aggregate functions.
317
    vectorized::Sizes offsets_of_aggregate_states;
318
    std::vector<size_t> make_nullable_keys;
319
320
    bool agg_data_created_without_key = false;
321
    bool enable_spill = false;
322
    bool reach_limit = false;
323
324
    int64_t limit = -1;
325
    bool do_sort_limit = false;
326
    vectorized::MutableColumns limit_columns;
327
    int limit_columns_min = -1;
328
    vectorized::PaddedPODArray<uint8_t> need_computes;
329
    std::vector<uint8_t> cmp_res;
330
    std::vector<int> order_directions;
331
    std::vector<int> null_directions;
332
333
    struct HeapLimitCursor {
334
        HeapLimitCursor(int row_id, vectorized::MutableColumns& limit_columns,
335
                        std::vector<int>& order_directions, std::vector<int>& null_directions)
336
4.90k
                : _row_id(row_id),
337
4.90k
                  _limit_columns(limit_columns),
338
4.90k
                  _order_directions(order_directions),
339
4.90k
                  _null_directions(null_directions) {}
340
341
        HeapLimitCursor(const HeapLimitCursor& other) = default;
342
343
        HeapLimitCursor(HeapLimitCursor&& other) noexcept
344
25.9k
                : _row_id(other._row_id),
345
25.9k
                  _limit_columns(other._limit_columns),
346
25.9k
                  _order_directions(other._order_directions),
347
25.9k
                  _null_directions(other._null_directions) {}
348
349
0
        HeapLimitCursor& operator=(const HeapLimitCursor& other) noexcept {
350
0
            _row_id = other._row_id;
351
0
            return *this;
352
0
        }
353
354
27.6k
        HeapLimitCursor& operator=(HeapLimitCursor&& other) noexcept {
355
27.6k
            _row_id = other._row_id;
356
27.6k
            return *this;
357
27.6k
        }
358
359
20.6k
        bool operator<(const HeapLimitCursor& rhs) const {
360
31.8k
            for (int i = 0; i < _limit_columns.size(); ++i) {
361
31.8k
                const auto& _limit_column = _limit_columns[i];
362
31.8k
                auto res = _limit_column->compare_at(_row_id, rhs._row_id, *_limit_column,
363
31.8k
                                                     _null_directions[i]) *
364
31.8k
                           _order_directions[i];
365
31.8k
                if (res < 0) {
366
11.4k
                    return true;
367
20.3k
                } else if (res > 0) {
368
9.24k
                    return false;
369
9.24k
                }
370
31.8k
            }
371
1
            return false;
372
20.6k
        }
373
374
        int _row_id;
375
        vectorized::MutableColumns& _limit_columns;
376
        std::vector<int>& _order_directions;
377
        std::vector<int>& _null_directions;
378
    };
379
380
    std::priority_queue<HeapLimitCursor> limit_heap;
381
382
    // Refresh the top limit heap with a new row
383
    void refresh_top_limit(size_t row_id, const vectorized::ColumnRawPtrs& key_columns);
384
385
    vectorized::Arena agg_arena_pool;
386
    vectorized::Arena agg_profile_arena;
387
388
private:
389
    vectorized::MutableColumns _get_keys_hash_table();
390
391
38.1k
    void _close_with_serialized_key() {
392
38.1k
        std::visit(
393
38.1k
                vectorized::Overload {[&](std::monostate& arg) -> void {
394
                                          // Do nothing
395
0
                                      },
396
38.1k
                                      [&](auto& agg_method) -> void {
397
38.1k
                                          auto& data = *agg_method.hash_table;
398
2.09M
                                          data.for_each_mapped([&](auto& mapped) {
399
2.09M
                                              if (mapped) {
400
2.09M
                                                  _destroy_agg_status(mapped);
401
2.09M
                                                  mapped = nullptr;
402
2.09M
                                              }
403
2.09M
                                          });
_ZZZN5doris8pipeline14AggSharedState26_close_with_serialized_keyEvENKUlRT_E_clINS_10vectorized15MethodKeysFixedI9PHHashMapIN4wide7integerILm256EjEEPc9HashCRC32ISB_EEEEEEvS3_ENKUlS3_E_clISC_EEDaS3_
Line
Count
Source
398
4.28k
                                          data.for_each_mapped([&](auto& mapped) {
399
4.28k
                                              if (mapped) {
400
4.28k
                                                  _destroy_agg_status(mapped);
401
4.28k
                                                  mapped = nullptr;
402
4.28k
                                              }
403
4.28k
                                          });
_ZZZN5doris8pipeline14AggSharedState26_close_with_serialized_keyEvENKUlRT_E_clINS_10vectorized15MethodKeysFixedI9PHHashMapINS6_7UInt136EPc9HashCRC32IS9_EEEEEEvS3_ENKUlS3_E_clISA_EEDaS3_
Line
Count
Source
398
1.90k
                                          data.for_each_mapped([&](auto& mapped) {
399
1.90k
                                              if (mapped) {
400
1.90k
                                                  _destroy_agg_status(mapped);
401
1.90k
                                                  mapped = nullptr;
402
1.90k
                                              }
403
1.90k
                                          });
_ZZZN5doris8pipeline14AggSharedState26_close_with_serialized_keyEvENKUlRT_E_clINS_10vectorized15MethodKeysFixedI9PHHashMapIN4wide7integerILm128EjEEPc9HashCRC32ISB_EEEEEEvS3_ENKUlS3_E_clISC_EEDaS3_
Line
Count
Source
398
24.6k
                                          data.for_each_mapped([&](auto& mapped) {
399
24.6k
                                              if (mapped) {
400
24.6k
                                                  _destroy_agg_status(mapped);
401
24.6k
                                                  mapped = nullptr;
402
24.6k
                                              }
403
24.6k
                                          });
_ZZZN5doris8pipeline14AggSharedState26_close_with_serialized_keyEvENKUlRT_E_clINS_10vectorized15MethodKeysFixedI9PHHashMapINS6_7UInt104EPc9HashCRC32IS9_EEEEEEvS3_ENKUlS3_E_clISA_EEDaS3_
Line
Count
Source
398
561
                                          data.for_each_mapped([&](auto& mapped) {
399
561
                                              if (mapped) {
400
561
                                                  _destroy_agg_status(mapped);
401
561
                                                  mapped = nullptr;
402
561
                                              }
403
561
                                          });
_ZZZN5doris8pipeline14AggSharedState26_close_with_serialized_keyEvENKUlRT_E_clINS_10vectorized15MethodKeysFixedI9PHHashMapINS6_6UInt96EPc9HashCRC32IS9_EEEEEEvS3_ENKUlS3_E_clISA_EEDaS3_
Line
Count
Source
398
8.92k
                                          data.for_each_mapped([&](auto& mapped) {
399
8.92k
                                              if (mapped) {
400
8.92k
                                                  _destroy_agg_status(mapped);
401
8.92k
                                                  mapped = nullptr;
402
8.92k
                                              }
403
8.92k
                                          });
_ZZZN5doris8pipeline14AggSharedState26_close_with_serialized_keyEvENKUlRT_E_clINS_10vectorized15MethodKeysFixedI9PHHashMapINS6_6UInt72EPc9HashCRC32IS9_EEEEEEvS3_ENKUlS3_E_clISA_EEDaS3_
Line
Count
Source
398
842
                                          data.for_each_mapped([&](auto& mapped) {
399
842
                                              if (mapped) {
400
842
                                                  _destroy_agg_status(mapped);
401
842
                                                  mapped = nullptr;
402
842
                                              }
403
842
                                          });
_ZZZN5doris8pipeline14AggSharedState26_close_with_serialized_keyEvENKUlRT_E_clINS_10vectorized15MethodKeysFixedI9PHHashMapImPc9HashCRC32ImEEEEEEvS3_ENKUlS3_E_clIS9_EEDaS3_
Line
Count
Source
398
224k
                                          data.for_each_mapped([&](auto& mapped) {
399
224k
                                              if (mapped) {
400
224k
                                                  _destroy_agg_status(mapped);
401
224k
                                                  mapped = nullptr;
402
224k
                                              }
403
224k
                                          });
_ZZZN5doris8pipeline14AggSharedState26_close_with_serialized_keyEvENKUlRT_E_clINS_10vectorized26MethodSingleNullableColumnINS6_19MethodStringNoCacheINS6_15DataWithNullKeyINS_13StringHashMapIPcNS_9AllocatorILb1ELb1ELb0ENS_22DefaultMemoryAllocatorELb1EEEEEEEEEEEEEvS3_ENKUlS3_E_clISB_EEDaS3_
Line
Count
Source
398
3.40k
                                          data.for_each_mapped([&](auto& mapped) {
399
3.40k
                                              if (mapped) {
400
3.40k
                                                  _destroy_agg_status(mapped);
401
3.40k
                                                  mapped = nullptr;
402
3.40k
                                              }
403
3.40k
                                          });
_ZZZN5doris8pipeline14AggSharedState26_close_with_serialized_keyEvENKUlRT_E_clINS_10vectorized26MethodSingleNullableColumnINS6_15MethodOneNumberIN4wide7integerILm256EjEENS6_15DataWithNullKeyI9PHHashMapISB_Pc9HashCRC32ISB_EEEEEEEEEEvS3_ENKUlS3_E_clISE_EEDaS3_
Line
Count
Source
398
9
                                          data.for_each_mapped([&](auto& mapped) {
399
9
                                              if (mapped) {
400
9
                                                  _destroy_agg_status(mapped);
401
9
                                                  mapped = nullptr;
402
9
                                              }
403
9
                                          });
_ZZZN5doris8pipeline14AggSharedState26_close_with_serialized_keyEvENKUlRT_E_clINS_10vectorized26MethodSingleNullableColumnINS6_15MethodOneNumberIN4wide7integerILm128EjEENS6_15DataWithNullKeyI9PHHashMapISB_Pc9HashCRC32ISB_EEEEEEEEEEvS3_ENKUlS3_E_clISE_EEDaS3_
Line
Count
Source
398
474
                                          data.for_each_mapped([&](auto& mapped) {
399
474
                                              if (mapped) {
400
474
                                                  _destroy_agg_status(mapped);
401
474
                                                  mapped = nullptr;
402
474
                                              }
403
474
                                          });
_ZZZN5doris8pipeline14AggSharedState26_close_with_serialized_keyEvENKUlRT_E_clINS_10vectorized26MethodSingleNullableColumnINS6_15MethodOneNumberImNS6_15DataWithNullKeyI9PHHashMapImPc14HashMixWrapperIm9HashCRC32ImEEEEEEEEEEEvS3_ENKUlS3_E_clISB_EEDaS3_
Line
Count
Source
398
42.2k
                                          data.for_each_mapped([&](auto& mapped) {
399
42.2k
                                              if (mapped) {
400
42.2k
                                                  _destroy_agg_status(mapped);
401
42.2k
                                                  mapped = nullptr;
402
42.2k
                                              }
403
42.2k
                                          });
_ZZZN5doris8pipeline14AggSharedState26_close_with_serialized_keyEvENKUlRT_E_clINS_10vectorized26MethodSingleNullableColumnINS6_15MethodOneNumberIjNS6_15DataWithNullKeyI9PHHashMapIjPc14HashMixWrapperIj9HashCRC32IjEEEEEEEEEEEvS3_ENKUlS3_E_clISB_EEDaS3_
Line
Count
Source
398
674k
                                          data.for_each_mapped([&](auto& mapped) {
399
674k
                                              if (mapped) {
400
674k
                                                  _destroy_agg_status(mapped);
401
674k
                                                  mapped = nullptr;
402
674k
                                              }
403
674k
                                          });
_ZZZN5doris8pipeline14AggSharedState26_close_with_serialized_keyEvENKUlRT_E_clINS_10vectorized26MethodSingleNullableColumnINS6_15MethodOneNumberImNS6_15DataWithNullKeyI9PHHashMapImPc9HashCRC32ImEEEEEEEEEEvS3_ENKUlS3_E_clISB_EEDaS3_
Line
Count
Source
398
1.15k
                                          data.for_each_mapped([&](auto& mapped) {
399
1.15k
                                              if (mapped) {
400
1.15k
                                                  _destroy_agg_status(mapped);
401
1.15k
                                                  mapped = nullptr;
402
1.15k
                                              }
403
1.15k
                                          });
_ZZZN5doris8pipeline14AggSharedState26_close_with_serialized_keyEvENKUlRT_E_clINS_10vectorized26MethodSingleNullableColumnINS6_15MethodOneNumberIjNS6_15DataWithNullKeyI9PHHashMapIjPc9HashCRC32IjEEEEEEEEEEvS3_ENKUlS3_E_clISB_EEDaS3_
Line
Count
Source
398
227k
                                          data.for_each_mapped([&](auto& mapped) {
399
227k
                                              if (mapped) {
400
227k
                                                  _destroy_agg_status(mapped);
401
227k
                                                  mapped = nullptr;
402
227k
                                              }
403
227k
                                          });
_ZZZN5doris8pipeline14AggSharedState26_close_with_serialized_keyEvENKUlRT_E_clINS_10vectorized26MethodSingleNullableColumnINS6_15MethodOneNumberItNS6_15DataWithNullKeyI9PHHashMapItPc9HashCRC32ItEEEEEEEEEEvS3_ENKUlS3_E_clISB_EEDaS3_
Line
Count
Source
398
705
                                          data.for_each_mapped([&](auto& mapped) {
399
705
                                              if (mapped) {
400
705
                                                  _destroy_agg_status(mapped);
401
705
                                                  mapped = nullptr;
402
705
                                              }
403
705
                                          });
_ZZZN5doris8pipeline14AggSharedState26_close_with_serialized_keyEvENKUlRT_E_clINS_10vectorized26MethodSingleNullableColumnINS6_15MethodOneNumberIhNS6_15DataWithNullKeyI9PHHashMapIhPc9HashCRC32IhEEEEEEEEEEvS3_ENKUlS3_E_clISB_EEDaS3_
Line
Count
Source
398
1.60k
                                          data.for_each_mapped([&](auto& mapped) {
399
1.60k
                                              if (mapped) {
400
1.60k
                                                  _destroy_agg_status(mapped);
401
1.60k
                                                  mapped = nullptr;
402
1.60k
                                              }
403
1.60k
                                          });
_ZZZN5doris8pipeline14AggSharedState26_close_with_serialized_keyEvENKUlRT_E_clINS_10vectorized15MethodOneNumberIm9PHHashMapImPc14HashMixWrapperIm9HashCRC32ImEEEEEEEvS3_ENKUlS3_E_clIS9_EEDaS3_
Line
Count
Source
398
20.1k
                                          data.for_each_mapped([&](auto& mapped) {
399
20.1k
                                              if (mapped) {
400
20.1k
                                                  _destroy_agg_status(mapped);
401
20.1k
                                                  mapped = nullptr;
402
20.1k
                                              }
403
20.1k
                                          });
_ZZZN5doris8pipeline14AggSharedState26_close_with_serialized_keyEvENKUlRT_E_clINS_10vectorized15MethodOneNumberIj9PHHashMapIjPc14HashMixWrapperIj9HashCRC32IjEEEEEEEvS3_ENKUlS3_E_clIS9_EEDaS3_
Line
Count
Source
398
782k
                                          data.for_each_mapped([&](auto& mapped) {
399
783k
                                              if (mapped) {
400
783k
                                                  _destroy_agg_status(mapped);
401
783k
                                                  mapped = nullptr;
402
783k
                                              }
403
782k
                                          });
Unexecuted instantiation: _ZZZN5doris8pipeline14AggSharedState26_close_with_serialized_keyEvENKUlRT_E_clINS_10vectorized15MethodOneNumberIN4wide7integerILm256EjEE9PHHashMapISA_Pc9HashCRC32ISA_EEEEEEvS3_ENKUlS3_E_clISC_EEDaS3_
_ZZZN5doris8pipeline14AggSharedState26_close_with_serialized_keyEvENKUlRT_E_clINS_10vectorized15MethodOneNumberIN4wide7integerILm128EjEE9PHHashMapISA_Pc9HashCRC32ISA_EEEEEEvS3_ENKUlS3_E_clISC_EEDaS3_
Line
Count
Source
398
138
                                          data.for_each_mapped([&](auto& mapped) {
399
138
                                              if (mapped) {
400
138
                                                  _destroy_agg_status(mapped);
401
138
                                                  mapped = nullptr;
402
138
                                              }
403
138
                                          });
_ZZZN5doris8pipeline14AggSharedState26_close_with_serialized_keyEvENKUlRT_E_clINS_10vectorized19MethodStringNoCacheINS_13StringHashMapIPcNS_9AllocatorILb1ELb1ELb0ENS_22DefaultMemoryAllocatorELb1EEEEEEEEEvS3_ENKUlS3_E_clIS9_EEDaS3_
Line
Count
Source
398
1.23k
                                          data.for_each_mapped([&](auto& mapped) {
399
1.23k
                                              if (mapped) {
400
1.23k
                                                  _destroy_agg_status(mapped);
401
1.23k
                                                  mapped = nullptr;
402
1.23k
                                              }
403
1.23k
                                          });
_ZZZN5doris8pipeline14AggSharedState26_close_with_serialized_keyEvENKUlRT_E_clINS_10vectorized15MethodOneNumberIm9PHHashMapImPc9HashCRC32ImEEEEEEvS3_ENKUlS3_E_clIS9_EEDaS3_
Line
Count
Source
398
8.46k
                                          data.for_each_mapped([&](auto& mapped) {
399
8.48k
                                              if (mapped) {
400
8.48k
                                                  _destroy_agg_status(mapped);
401
8.48k
                                                  mapped = nullptr;
402
8.48k
                                              }
403
8.46k
                                          });
_ZZZN5doris8pipeline14AggSharedState26_close_with_serialized_keyEvENKUlRT_E_clINS_10vectorized15MethodOneNumberIj9PHHashMapIjPc9HashCRC32IjEEEEEEvS3_ENKUlS3_E_clIS9_EEDaS3_
Line
Count
Source
398
8.19k
                                          data.for_each_mapped([&](auto& mapped) {
399
8.19k
                                              if (mapped) {
400
8.19k
                                                  _destroy_agg_status(mapped);
401
8.19k
                                                  mapped = nullptr;
402
8.19k
                                              }
403
8.19k
                                          });
_ZZZN5doris8pipeline14AggSharedState26_close_with_serialized_keyEvENKUlRT_E_clINS_10vectorized15MethodOneNumberIt9PHHashMapItPc9HashCRC32ItEEEEEEvS3_ENKUlS3_E_clIS9_EEDaS3_
Line
Count
Source
398
160
                                          data.for_each_mapped([&](auto& mapped) {
399
160
                                              if (mapped) {
400
160
                                                  _destroy_agg_status(mapped);
401
160
                                                  mapped = nullptr;
402
160
                                              }
403
160
                                          });
_ZZZN5doris8pipeline14AggSharedState26_close_with_serialized_keyEvENKUlRT_E_clINS_10vectorized15MethodOneNumberIh9PHHashMapIhPc9HashCRC32IhEEEEEEvS3_ENKUlS3_E_clIS9_EEDaS3_
Line
Count
Source
398
355
                                          data.for_each_mapped([&](auto& mapped) {
399
355
                                              if (mapped) {
400
355
                                                  _destroy_agg_status(mapped);
401
355
                                                  mapped = nullptr;
402
355
                                              }
403
355
                                          });
_ZZZN5doris8pipeline14AggSharedState26_close_with_serialized_keyEvENKUlRT_E_clINS_10vectorized16MethodSerializedI9PHHashMapINS_9StringRefEPc11DefaultHashIS9_vEEEEEEvS3_ENKUlS3_E_clISA_EEDaS3_
Line
Count
Source
398
56.0k
                                          data.for_each_mapped([&](auto& mapped) {
399
56.0k
                                              if (mapped) {
400
56.0k
                                                  _destroy_agg_status(mapped);
401
56.0k
                                                  mapped = nullptr;
402
56.0k
                                              }
403
56.0k
                                          });
404
38.1k
                                          if (data.has_null_key_data()) {
405
1.11k
                                              _destroy_agg_status(data.template get_null_key_data<
406
1.11k
                                                                  vectorized::AggregateDataPtr>());
407
1.11k
                                          }
408
38.1k
                                      }},
_ZZN5doris8pipeline14AggSharedState26_close_with_serialized_keyEvENKUlRT_E_clINS_10vectorized15MethodKeysFixedI9PHHashMapIN4wide7integerILm256EjEEPc9HashCRC32ISB_EEEEEEvS3_
Line
Count
Source
396
1.45k
                                      [&](auto& agg_method) -> void {
397
1.45k
                                          auto& data = *agg_method.hash_table;
398
1.45k
                                          data.for_each_mapped([&](auto& mapped) {
399
1.45k
                                              if (mapped) {
400
1.45k
                                                  _destroy_agg_status(mapped);
401
1.45k
                                                  mapped = nullptr;
402
1.45k
                                              }
403
1.45k
                                          });
404
1.45k
                                          if (data.has_null_key_data()) {
405
0
                                              _destroy_agg_status(data.template get_null_key_data<
406
0
                                                                  vectorized::AggregateDataPtr>());
407
0
                                          }
408
1.45k
                                      }},
_ZZN5doris8pipeline14AggSharedState26_close_with_serialized_keyEvENKUlRT_E_clINS_10vectorized15MethodKeysFixedI9PHHashMapINS6_7UInt136EPc9HashCRC32IS9_EEEEEEvS3_
Line
Count
Source
396
2.11k
                                      [&](auto& agg_method) -> void {
397
2.11k
                                          auto& data = *agg_method.hash_table;
398
2.11k
                                          data.for_each_mapped([&](auto& mapped) {
399
2.11k
                                              if (mapped) {
400
2.11k
                                                  _destroy_agg_status(mapped);
401
2.11k
                                                  mapped = nullptr;
402
2.11k
                                              }
403
2.11k
                                          });
404
2.11k
                                          if (data.has_null_key_data()) {
405
0
                                              _destroy_agg_status(data.template get_null_key_data<
406
0
                                                                  vectorized::AggregateDataPtr>());
407
0
                                          }
408
2.11k
                                      }},
_ZZN5doris8pipeline14AggSharedState26_close_with_serialized_keyEvENKUlRT_E_clINS_10vectorized15MethodKeysFixedI9PHHashMapIN4wide7integerILm128EjEEPc9HashCRC32ISB_EEEEEEvS3_
Line
Count
Source
396
80
                                      [&](auto& agg_method) -> void {
397
80
                                          auto& data = *agg_method.hash_table;
398
80
                                          data.for_each_mapped([&](auto& mapped) {
399
80
                                              if (mapped) {
400
80
                                                  _destroy_agg_status(mapped);
401
80
                                                  mapped = nullptr;
402
80
                                              }
403
80
                                          });
404
80
                                          if (data.has_null_key_data()) {
405
0
                                              _destroy_agg_status(data.template get_null_key_data<
406
0
                                                                  vectorized::AggregateDataPtr>());
407
0
                                          }
408
80
                                      }},
_ZZN5doris8pipeline14AggSharedState26_close_with_serialized_keyEvENKUlRT_E_clINS_10vectorized15MethodKeysFixedI9PHHashMapINS6_7UInt104EPc9HashCRC32IS9_EEEEEEvS3_
Line
Count
Source
396
633
                                      [&](auto& agg_method) -> void {
397
633
                                          auto& data = *agg_method.hash_table;
398
633
                                          data.for_each_mapped([&](auto& mapped) {
399
633
                                              if (mapped) {
400
633
                                                  _destroy_agg_status(mapped);
401
633
                                                  mapped = nullptr;
402
633
                                              }
403
633
                                          });
404
633
                                          if (data.has_null_key_data()) {
405
0
                                              _destroy_agg_status(data.template get_null_key_data<
406
0
                                                                  vectorized::AggregateDataPtr>());
407
0
                                          }
408
633
                                      }},
_ZZN5doris8pipeline14AggSharedState26_close_with_serialized_keyEvENKUlRT_E_clINS_10vectorized15MethodKeysFixedI9PHHashMapINS6_6UInt96EPc9HashCRC32IS9_EEEEEEvS3_
Line
Count
Source
396
701
                                      [&](auto& agg_method) -> void {
397
701
                                          auto& data = *agg_method.hash_table;
398
701
                                          data.for_each_mapped([&](auto& mapped) {
399
701
                                              if (mapped) {
400
701
                                                  _destroy_agg_status(mapped);
401
701
                                                  mapped = nullptr;
402
701
                                              }
403
701
                                          });
404
701
                                          if (data.has_null_key_data()) {
405
0
                                              _destroy_agg_status(data.template get_null_key_data<
406
0
                                                                  vectorized::AggregateDataPtr>());
407
0
                                          }
408
701
                                      }},
_ZZN5doris8pipeline14AggSharedState26_close_with_serialized_keyEvENKUlRT_E_clINS_10vectorized15MethodKeysFixedI9PHHashMapINS6_6UInt72EPc9HashCRC32IS9_EEEEEEvS3_
Line
Count
Source
396
919
                                      [&](auto& agg_method) -> void {
397
919
                                          auto& data = *agg_method.hash_table;
398
919
                                          data.for_each_mapped([&](auto& mapped) {
399
919
                                              if (mapped) {
400
919
                                                  _destroy_agg_status(mapped);
401
919
                                                  mapped = nullptr;
402
919
                                              }
403
919
                                          });
404
919
                                          if (data.has_null_key_data()) {
405
0
                                              _destroy_agg_status(data.template get_null_key_data<
406
0
                                                                  vectorized::AggregateDataPtr>());
407
0
                                          }
408
919
                                      }},
_ZZN5doris8pipeline14AggSharedState26_close_with_serialized_keyEvENKUlRT_E_clINS_10vectorized15MethodKeysFixedI9PHHashMapImPc9HashCRC32ImEEEEEEvS3_
Line
Count
Source
396
1.21k
                                      [&](auto& agg_method) -> void {
397
1.21k
                                          auto& data = *agg_method.hash_table;
398
1.21k
                                          data.for_each_mapped([&](auto& mapped) {
399
1.21k
                                              if (mapped) {
400
1.21k
                                                  _destroy_agg_status(mapped);
401
1.21k
                                                  mapped = nullptr;
402
1.21k
                                              }
403
1.21k
                                          });
404
1.21k
                                          if (data.has_null_key_data()) {
405
0
                                              _destroy_agg_status(data.template get_null_key_data<
406
0
                                                                  vectorized::AggregateDataPtr>());
407
0
                                          }
408
1.21k
                                      }},
_ZZN5doris8pipeline14AggSharedState26_close_with_serialized_keyEvENKUlRT_E_clINS_10vectorized26MethodSingleNullableColumnINS6_19MethodStringNoCacheINS6_15DataWithNullKeyINS_13StringHashMapIPcNS_9AllocatorILb1ELb1ELb0ENS_22DefaultMemoryAllocatorELb1EEEEEEEEEEEEEvS3_
Line
Count
Source
396
2.91k
                                      [&](auto& agg_method) -> void {
397
2.91k
                                          auto& data = *agg_method.hash_table;
398
2.91k
                                          data.for_each_mapped([&](auto& mapped) {
399
2.91k
                                              if (mapped) {
400
2.91k
                                                  _destroy_agg_status(mapped);
401
2.91k
                                                  mapped = nullptr;
402
2.91k
                                              }
403
2.91k
                                          });
404
2.91k
                                          if (data.has_null_key_data()) {
405
204
                                              _destroy_agg_status(data.template get_null_key_data<
406
204
                                                                  vectorized::AggregateDataPtr>());
407
204
                                          }
408
2.91k
                                      }},
_ZZN5doris8pipeline14AggSharedState26_close_with_serialized_keyEvENKUlRT_E_clINS_10vectorized26MethodSingleNullableColumnINS6_15MethodOneNumberIN4wide7integerILm256EjEENS6_15DataWithNullKeyI9PHHashMapISB_Pc9HashCRC32ISB_EEEEEEEEEEvS3_
Line
Count
Source
396
14
                                      [&](auto& agg_method) -> void {
397
14
                                          auto& data = *agg_method.hash_table;
398
14
                                          data.for_each_mapped([&](auto& mapped) {
399
14
                                              if (mapped) {
400
14
                                                  _destroy_agg_status(mapped);
401
14
                                                  mapped = nullptr;
402
14
                                              }
403
14
                                          });
404
14
                                          if (data.has_null_key_data()) {
405
0
                                              _destroy_agg_status(data.template get_null_key_data<
406
0
                                                                  vectorized::AggregateDataPtr>());
407
0
                                          }
408
14
                                      }},
_ZZN5doris8pipeline14AggSharedState26_close_with_serialized_keyEvENKUlRT_E_clINS_10vectorized26MethodSingleNullableColumnINS6_15MethodOneNumberIN4wide7integerILm128EjEENS6_15DataWithNullKeyI9PHHashMapISB_Pc9HashCRC32ISB_EEEEEEEEEEvS3_
Line
Count
Source
396
228
                                      [&](auto& agg_method) -> void {
397
228
                                          auto& data = *agg_method.hash_table;
398
228
                                          data.for_each_mapped([&](auto& mapped) {
399
228
                                              if (mapped) {
400
228
                                                  _destroy_agg_status(mapped);
401
228
                                                  mapped = nullptr;
402
228
                                              }
403
228
                                          });
404
228
                                          if (data.has_null_key_data()) {
405
4
                                              _destroy_agg_status(data.template get_null_key_data<
406
4
                                                                  vectorized::AggregateDataPtr>());
407
4
                                          }
408
228
                                      }},
_ZZN5doris8pipeline14AggSharedState26_close_with_serialized_keyEvENKUlRT_E_clINS_10vectorized26MethodSingleNullableColumnINS6_15MethodOneNumberImNS6_15DataWithNullKeyI9PHHashMapImPc14HashMixWrapperIm9HashCRC32ImEEEEEEEEEEEvS3_
Line
Count
Source
396
1.78k
                                      [&](auto& agg_method) -> void {
397
1.78k
                                          auto& data = *agg_method.hash_table;
398
1.78k
                                          data.for_each_mapped([&](auto& mapped) {
399
1.78k
                                              if (mapped) {
400
1.78k
                                                  _destroy_agg_status(mapped);
401
1.78k
                                                  mapped = nullptr;
402
1.78k
                                              }
403
1.78k
                                          });
404
1.78k
                                          if (data.has_null_key_data()) {
405
104
                                              _destroy_agg_status(data.template get_null_key_data<
406
104
                                                                  vectorized::AggregateDataPtr>());
407
104
                                          }
408
1.78k
                                      }},
_ZZN5doris8pipeline14AggSharedState26_close_with_serialized_keyEvENKUlRT_E_clINS_10vectorized26MethodSingleNullableColumnINS6_15MethodOneNumberIjNS6_15DataWithNullKeyI9PHHashMapIjPc14HashMixWrapperIj9HashCRC32IjEEEEEEEEEEEvS3_
Line
Count
Source
396
8.56k
                                      [&](auto& agg_method) -> void {
397
8.56k
                                          auto& data = *agg_method.hash_table;
398
8.56k
                                          data.for_each_mapped([&](auto& mapped) {
399
8.56k
                                              if (mapped) {
400
8.56k
                                                  _destroy_agg_status(mapped);
401
8.56k
                                                  mapped = nullptr;
402
8.56k
                                              }
403
8.56k
                                          });
404
8.56k
                                          if (data.has_null_key_data()) {
405
363
                                              _destroy_agg_status(data.template get_null_key_data<
406
363
                                                                  vectorized::AggregateDataPtr>());
407
363
                                          }
408
8.56k
                                      }},
_ZZN5doris8pipeline14AggSharedState26_close_with_serialized_keyEvENKUlRT_E_clINS_10vectorized26MethodSingleNullableColumnINS6_15MethodOneNumberImNS6_15DataWithNullKeyI9PHHashMapImPc9HashCRC32ImEEEEEEEEEEvS3_
Line
Count
Source
396
661
                                      [&](auto& agg_method) -> void {
397
661
                                          auto& data = *agg_method.hash_table;
398
661
                                          data.for_each_mapped([&](auto& mapped) {
399
661
                                              if (mapped) {
400
661
                                                  _destroy_agg_status(mapped);
401
661
                                                  mapped = nullptr;
402
661
                                              }
403
661
                                          });
404
661
                                          if (data.has_null_key_data()) {
405
44
                                              _destroy_agg_status(data.template get_null_key_data<
406
44
                                                                  vectorized::AggregateDataPtr>());
407
44
                                          }
408
661
                                      }},
_ZZN5doris8pipeline14AggSharedState26_close_with_serialized_keyEvENKUlRT_E_clINS_10vectorized26MethodSingleNullableColumnINS6_15MethodOneNumberIjNS6_15DataWithNullKeyI9PHHashMapIjPc9HashCRC32IjEEEEEEEEEEvS3_
Line
Count
Source
396
1.47k
                                      [&](auto& agg_method) -> void {
397
1.47k
                                          auto& data = *agg_method.hash_table;
398
1.47k
                                          data.for_each_mapped([&](auto& mapped) {
399
1.47k
                                              if (mapped) {
400
1.47k
                                                  _destroy_agg_status(mapped);
401
1.47k
                                                  mapped = nullptr;
402
1.47k
                                              }
403
1.47k
                                          });
404
1.47k
                                          if (data.has_null_key_data()) {
405
22
                                              _destroy_agg_status(data.template get_null_key_data<
406
22
                                                                  vectorized::AggregateDataPtr>());
407
22
                                          }
408
1.47k
                                      }},
_ZZN5doris8pipeline14AggSharedState26_close_with_serialized_keyEvENKUlRT_E_clINS_10vectorized26MethodSingleNullableColumnINS6_15MethodOneNumberItNS6_15DataWithNullKeyI9PHHashMapItPc9HashCRC32ItEEEEEEEEEEvS3_
Line
Count
Source
396
839
                                      [&](auto& agg_method) -> void {
397
839
                                          auto& data = *agg_method.hash_table;
398
839
                                          data.for_each_mapped([&](auto& mapped) {
399
839
                                              if (mapped) {
400
839
                                                  _destroy_agg_status(mapped);
401
839
                                                  mapped = nullptr;
402
839
                                              }
403
839
                                          });
404
839
                                          if (data.has_null_key_data()) {
405
20
                                              _destroy_agg_status(data.template get_null_key_data<
406
20
                                                                  vectorized::AggregateDataPtr>());
407
20
                                          }
408
839
                                      }},
_ZZN5doris8pipeline14AggSharedState26_close_with_serialized_keyEvENKUlRT_E_clINS_10vectorized26MethodSingleNullableColumnINS6_15MethodOneNumberIhNS6_15DataWithNullKeyI9PHHashMapIhPc9HashCRC32IhEEEEEEEEEEvS3_
Line
Count
Source
396
2.13k
                                      [&](auto& agg_method) -> void {
397
2.13k
                                          auto& data = *agg_method.hash_table;
398
2.13k
                                          data.for_each_mapped([&](auto& mapped) {
399
2.13k
                                              if (mapped) {
400
2.13k
                                                  _destroy_agg_status(mapped);
401
2.13k
                                                  mapped = nullptr;
402
2.13k
                                              }
403
2.13k
                                          });
404
2.13k
                                          if (data.has_null_key_data()) {
405
351
                                              _destroy_agg_status(data.template get_null_key_data<
406
351
                                                                  vectorized::AggregateDataPtr>());
407
351
                                          }
408
2.13k
                                      }},
_ZZN5doris8pipeline14AggSharedState26_close_with_serialized_keyEvENKUlRT_E_clINS_10vectorized15MethodOneNumberIm9PHHashMapImPc14HashMixWrapperIm9HashCRC32ImEEEEEEEvS3_
Line
Count
Source
396
639
                                      [&](auto& agg_method) -> void {
397
639
                                          auto& data = *agg_method.hash_table;
398
639
                                          data.for_each_mapped([&](auto& mapped) {
399
639
                                              if (mapped) {
400
639
                                                  _destroy_agg_status(mapped);
401
639
                                                  mapped = nullptr;
402
639
                                              }
403
639
                                          });
404
639
                                          if (data.has_null_key_data()) {
405
0
                                              _destroy_agg_status(data.template get_null_key_data<
406
0
                                                                  vectorized::AggregateDataPtr>());
407
0
                                          }
408
639
                                      }},
_ZZN5doris8pipeline14AggSharedState26_close_with_serialized_keyEvENKUlRT_E_clINS_10vectorized15MethodOneNumberIj9PHHashMapIjPc14HashMixWrapperIj9HashCRC32IjEEEEEEEvS3_
Line
Count
Source
396
2.56k
                                      [&](auto& agg_method) -> void {
397
2.56k
                                          auto& data = *agg_method.hash_table;
398
2.56k
                                          data.for_each_mapped([&](auto& mapped) {
399
2.56k
                                              if (mapped) {
400
2.56k
                                                  _destroy_agg_status(mapped);
401
2.56k
                                                  mapped = nullptr;
402
2.56k
                                              }
403
2.56k
                                          });
404
2.56k
                                          if (data.has_null_key_data()) {
405
0
                                              _destroy_agg_status(data.template get_null_key_data<
406
0
                                                                  vectorized::AggregateDataPtr>());
407
0
                                          }
408
2.56k
                                      }},
Unexecuted instantiation: _ZZN5doris8pipeline14AggSharedState26_close_with_serialized_keyEvENKUlRT_E_clINS_10vectorized15MethodOneNumberIN4wide7integerILm256EjEE9PHHashMapISA_Pc9HashCRC32ISA_EEEEEEvS3_
_ZZN5doris8pipeline14AggSharedState26_close_with_serialized_keyEvENKUlRT_E_clINS_10vectorized15MethodOneNumberIN4wide7integerILm128EjEE9PHHashMapISA_Pc9HashCRC32ISA_EEEEEEvS3_
Line
Count
Source
396
121
                                      [&](auto& agg_method) -> void {
397
121
                                          auto& data = *agg_method.hash_table;
398
121
                                          data.for_each_mapped([&](auto& mapped) {
399
121
                                              if (mapped) {
400
121
                                                  _destroy_agg_status(mapped);
401
121
                                                  mapped = nullptr;
402
121
                                              }
403
121
                                          });
404
121
                                          if (data.has_null_key_data()) {
405
0
                                              _destroy_agg_status(data.template get_null_key_data<
406
0
                                                                  vectorized::AggregateDataPtr>());
407
0
                                          }
408
121
                                      }},
_ZZN5doris8pipeline14AggSharedState26_close_with_serialized_keyEvENKUlRT_E_clINS_10vectorized19MethodStringNoCacheINS_13StringHashMapIPcNS_9AllocatorILb1ELb1ELb0ENS_22DefaultMemoryAllocatorELb1EEEEEEEEEvS3_
Line
Count
Source
396
1.21k
                                      [&](auto& agg_method) -> void {
397
1.21k
                                          auto& data = *agg_method.hash_table;
398
1.21k
                                          data.for_each_mapped([&](auto& mapped) {
399
1.21k
                                              if (mapped) {
400
1.21k
                                                  _destroy_agg_status(mapped);
401
1.21k
                                                  mapped = nullptr;
402
1.21k
                                              }
403
1.21k
                                          });
404
1.21k
                                          if (data.has_null_key_data()) {
405
0
                                              _destroy_agg_status(data.template get_null_key_data<
406
0
                                                                  vectorized::AggregateDataPtr>());
407
0
                                          }
408
1.21k
                                      }},
_ZZN5doris8pipeline14AggSharedState26_close_with_serialized_keyEvENKUlRT_E_clINS_10vectorized15MethodOneNumberIm9PHHashMapImPc9HashCRC32ImEEEEEEvS3_
Line
Count
Source
396
160
                                      [&](auto& agg_method) -> void {
397
160
                                          auto& data = *agg_method.hash_table;
398
160
                                          data.for_each_mapped([&](auto& mapped) {
399
160
                                              if (mapped) {
400
160
                                                  _destroy_agg_status(mapped);
401
160
                                                  mapped = nullptr;
402
160
                                              }
403
160
                                          });
404
160
                                          if (data.has_null_key_data()) {
405
0
                                              _destroy_agg_status(data.template get_null_key_data<
406
0
                                                                  vectorized::AggregateDataPtr>());
407
0
                                          }
408
160
                                      }},
_ZZN5doris8pipeline14AggSharedState26_close_with_serialized_keyEvENKUlRT_E_clINS_10vectorized15MethodOneNumberIj9PHHashMapIjPc9HashCRC32IjEEEEEEvS3_
Line
Count
Source
396
444
                                      [&](auto& agg_method) -> void {
397
444
                                          auto& data = *agg_method.hash_table;
398
444
                                          data.for_each_mapped([&](auto& mapped) {
399
444
                                              if (mapped) {
400
444
                                                  _destroy_agg_status(mapped);
401
444
                                                  mapped = nullptr;
402
444
                                              }
403
444
                                          });
404
444
                                          if (data.has_null_key_data()) {
405
0
                                              _destroy_agg_status(data.template get_null_key_data<
406
0
                                                                  vectorized::AggregateDataPtr>());
407
0
                                          }
408
444
                                      }},
_ZZN5doris8pipeline14AggSharedState26_close_with_serialized_keyEvENKUlRT_E_clINS_10vectorized15MethodOneNumberIt9PHHashMapItPc9HashCRC32ItEEEEEEvS3_
Line
Count
Source
396
44
                                      [&](auto& agg_method) -> void {
397
44
                                          auto& data = *agg_method.hash_table;
398
44
                                          data.for_each_mapped([&](auto& mapped) {
399
44
                                              if (mapped) {
400
44
                                                  _destroy_agg_status(mapped);
401
44
                                                  mapped = nullptr;
402
44
                                              }
403
44
                                          });
404
44
                                          if (data.has_null_key_data()) {
405
0
                                              _destroy_agg_status(data.template get_null_key_data<
406
0
                                                                  vectorized::AggregateDataPtr>());
407
0
                                          }
408
44
                                      }},
_ZZN5doris8pipeline14AggSharedState26_close_with_serialized_keyEvENKUlRT_E_clINS_10vectorized15MethodOneNumberIh9PHHashMapIhPc9HashCRC32IhEEEEEEvS3_
Line
Count
Source
396
717
                                      [&](auto& agg_method) -> void {
397
717
                                          auto& data = *agg_method.hash_table;
398
717
                                          data.for_each_mapped([&](auto& mapped) {
399
717
                                              if (mapped) {
400
717
                                                  _destroy_agg_status(mapped);
401
717
                                                  mapped = nullptr;
402
717
                                              }
403
717
                                          });
404
717
                                          if (data.has_null_key_data()) {
405
0
                                              _destroy_agg_status(data.template get_null_key_data<
406
0
                                                                  vectorized::AggregateDataPtr>());
407
0
                                          }
408
717
                                      }},
_ZZN5doris8pipeline14AggSharedState26_close_with_serialized_keyEvENKUlRT_E_clINS_10vectorized16MethodSerializedI9PHHashMapINS_9StringRefEPc11DefaultHashIS9_vEEEEEEvS3_
Line
Count
Source
396
6.52k
                                      [&](auto& agg_method) -> void {
397
6.52k
                                          auto& data = *agg_method.hash_table;
398
6.52k
                                          data.for_each_mapped([&](auto& mapped) {
399
6.52k
                                              if (mapped) {
400
6.52k
                                                  _destroy_agg_status(mapped);
401
6.52k
                                                  mapped = nullptr;
402
6.52k
                                              }
403
6.52k
                                          });
404
6.52k
                                          if (data.has_null_key_data()) {
405
0
                                              _destroy_agg_status(data.template get_null_key_data<
406
0
                                                                  vectorized::AggregateDataPtr>());
407
0
                                          }
408
6.52k
                                      }},
409
38.1k
                agg_data->method_variant);
410
38.1k
    }
411
412
67.2k
    void _close_without_key() {
413
        //because prepare maybe failed, and couldn't create agg data.
414
        //but finally call close to destory agg data, if agg data has bitmapValue
415
        //will be core dump, it's not initialized
416
67.3k
        if (agg_data_created_without_key) {
417
67.3k
            _destroy_agg_status(agg_data->without_key);
418
67.3k
            agg_data_created_without_key = false;
419
67.3k
        }
420
67.2k
    }
421
    void _destroy_agg_status(vectorized::AggregateDataPtr data);
422
};
423
424
struct BasicSpillSharedState {
425
2.28k
    virtual ~BasicSpillSharedState() = default;
426
427
    // These two counters are shared to spill source operators as the initial value
428
    // of 'SpillWriteFileCurrentBytes' and 'SpillWriteFileCurrentCount'.
429
    // Total bytes of spill data written to disk file(after serialized)
430
    RuntimeProfile::Counter* _spill_write_file_total_size = nullptr;
431
    RuntimeProfile::Counter* _spill_file_total_count = nullptr;
432
433
2.24k
    void setup_shared_profile(RuntimeProfile* sink_profile) {
434
2.24k
        _spill_file_total_count =
435
2.24k
                ADD_COUNTER_WITH_LEVEL(sink_profile, "SpillWriteFileTotalCount", TUnit::UNIT, 1);
436
2.24k
        _spill_write_file_total_size =
437
2.24k
                ADD_COUNTER_WITH_LEVEL(sink_profile, "SpillWriteFileBytes", TUnit::BYTES, 1);
438
2.24k
    }
439
440
    virtual void update_spill_stream_profiles(RuntimeProfile* source_profile) = 0;
441
};
442
443
struct AggSpillPartition;
444
struct PartitionedAggSharedState : public BasicSharedState,
445
                                   public BasicSpillSharedState,
446
                                   public std::enable_shared_from_this<PartitionedAggSharedState> {
447
    ENABLE_FACTORY_CREATOR(PartitionedAggSharedState)
448
449
317
    PartitionedAggSharedState() = default;
450
317
    ~PartitionedAggSharedState() override = default;
451
452
    void update_spill_stream_profiles(RuntimeProfile* source_profile) override;
453
454
    void init_spill_params(size_t spill_partition_count);
455
456
    void close();
457
458
    AggSharedState* in_mem_shared_state = nullptr;
459
    std::shared_ptr<BasicSharedState> in_mem_shared_state_sptr;
460
461
    size_t partition_count;
462
    size_t max_partition_index;
463
    bool is_spilled = false;
464
    std::atomic_bool is_closed = false;
465
    std::deque<std::shared_ptr<AggSpillPartition>> spill_partitions;
466
467
1.25M
    size_t get_partition_index(size_t hash_value) const { return hash_value % partition_count; }
468
};
469
470
struct AggSpillPartition {
471
    static constexpr int64_t AGG_SPILL_FILE_SIZE = 1024 * 1024 * 1024; // 1G
472
473
10.1k
    AggSpillPartition() = default;
474
475
    void close();
476
477
    Status get_spill_stream(RuntimeState* state, int node_id, RuntimeProfile* profile,
478
                            vectorized::SpillStreamSPtr& spilling_stream);
479
480
9.44k
    Status flush_if_full() {
481
9.44k
        DCHECK(spilling_stream_);
482
9.44k
        Status status;
483
        // avoid small spill files
484
9.44k
        if (spilling_stream_->get_written_bytes() >= AGG_SPILL_FILE_SIZE) {
485
0
            status = spilling_stream_->spill_eof();
486
0
            spilling_stream_.reset();
487
0
        }
488
9.44k
        return status;
489
9.44k
    }
490
491
32.1k
    Status finish_current_spilling(bool eos = false) {
492
32.1k
        if (spilling_stream_) {
493
17.9k
            if (eos || spilling_stream_->get_written_bytes() >= AGG_SPILL_FILE_SIZE) {
494
1.59k
                auto status = spilling_stream_->spill_eof();
495
1.59k
                spilling_stream_.reset();
496
1.59k
                return status;
497
1.59k
            }
498
17.9k
        }
499
30.5k
        return Status::OK();
500
32.1k
    }
501
502
    std::deque<vectorized::SpillStreamSPtr> spill_streams_;
503
    vectorized::SpillStreamSPtr spilling_stream_;
504
};
505
using AggSpillPartitionSPtr = std::shared_ptr<AggSpillPartition>;
506
struct SortSharedState : public BasicSharedState {
507
    ENABLE_FACTORY_CREATOR(SortSharedState)
508
public:
509
    std::shared_ptr<vectorized::Sorter> sorter;
510
};
511
512
struct SpillSortSharedState : public BasicSharedState,
513
                              public BasicSpillSharedState,
514
                              public std::enable_shared_from_this<SpillSortSharedState> {
515
    ENABLE_FACTORY_CREATOR(SpillSortSharedState)
516
517
34
    SpillSortSharedState() = default;
518
33
    ~SpillSortSharedState() override = default;
519
520
536
    void update_spill_block_batch_row_count(RuntimeState* state, const vectorized::Block* block) {
521
536
        auto rows = block->rows();
522
536
        if (rows > 0 && 0 == avg_row_bytes) {
523
14
            avg_row_bytes = std::max((std::size_t)1, block->bytes() / rows);
524
14
            spill_block_batch_row_count =
525
14
                    (state->spill_sort_batch_bytes() + avg_row_bytes - 1) / avg_row_bytes;
526
14
            LOG(INFO) << "spill sort block batch row count: " << spill_block_batch_row_count;
527
14
        }
528
536
    }
529
530
    void update_spill_stream_profiles(RuntimeProfile* source_profile) override;
531
532
    void close();
533
534
    SortSharedState* in_mem_shared_state = nullptr;
535
    bool enable_spill = false;
536
    bool is_spilled = false;
537
    int64_t limit = -1;
538
    int64_t offset = 0;
539
    std::atomic_bool is_closed = false;
540
    std::shared_ptr<BasicSharedState> in_mem_shared_state_sptr;
541
542
    std::deque<vectorized::SpillStreamSPtr> sorted_streams;
543
    size_t avg_row_bytes = 0;
544
    size_t spill_block_batch_row_count;
545
};
546
547
struct UnionSharedState : public BasicSharedState {
548
    ENABLE_FACTORY_CREATOR(UnionSharedState)
549
550
public:
551
2.03k
    UnionSharedState(int child_count = 1) : data_queue(child_count), _child_count(child_count) {};
552
0
    int child_count() const { return _child_count; }
553
    DataQueue data_queue;
554
    const int _child_count;
555
};
556
557
struct DataQueueSharedState : public BasicSharedState {
558
    ENABLE_FACTORY_CREATOR(DataQueueSharedState)
559
public:
560
    DataQueue data_queue;
561
};
562
563
class MultiCastDataStreamer;
564
565
struct MultiCastSharedState : public BasicSharedState,
566
                              public BasicSpillSharedState,
567
                              public std::enable_shared_from_this<MultiCastSharedState> {
568
    MultiCastSharedState(ObjectPool* pool, int cast_sender_count, int node_id);
569
    std::unique_ptr<pipeline::MultiCastDataStreamer> multi_cast_data_streamer;
570
571
    void update_spill_stream_profiles(RuntimeProfile* source_profile) override;
572
};
573
574
struct AnalyticSharedState : public BasicSharedState {
575
    ENABLE_FACTORY_CREATOR(AnalyticSharedState)
576
577
public:
578
6.72k
    AnalyticSharedState() = default;
579
    std::queue<vectorized::Block> blocks_buffer;
580
    std::mutex buffer_mutex;
581
    bool sink_eos = false;
582
    std::mutex sink_eos_lock;
583
    vectorized::Arena agg_arena_pool;
584
};
585
586
struct JoinSharedState : public BasicSharedState {
587
    // For some join case, we can apply a short circuit strategy
588
    // 1. _has_null_in_build_side = true
589
    // 2. build side rows is empty, Join op is: inner join/right outer join/left semi/right semi/right anti
590
    bool _has_null_in_build_side = false;
591
    bool short_circuit_for_probe = false;
592
    // for some join, when build side rows is empty, we could return directly by add some additional null data in probe table.
593
    bool empty_right_table_need_probe_dispose = false;
594
    JoinOpVariants join_op_variants;
595
};
596
597
struct HashJoinSharedState : public JoinSharedState {
598
    ENABLE_FACTORY_CREATOR(HashJoinSharedState)
599
94.9k
    HashJoinSharedState() {
600
94.9k
        hash_table_variant_vector.push_back(std::make_shared<JoinDataVariants>());
601
94.9k
    }
602
3.93k
    HashJoinSharedState(int num_instances) {
603
3.93k
        source_deps.resize(num_instances, nullptr);
604
3.93k
        hash_table_variant_vector.resize(num_instances, nullptr);
605
19.3k
        for (int i = 0; i < num_instances; i++) {
606
15.4k
            hash_table_variant_vector[i] = std::make_shared<JoinDataVariants>();
607
15.4k
        }
608
3.93k
    }
609
    std::shared_ptr<vectorized::Arena> arena = std::make_shared<vectorized::Arena>();
610
611
    const std::vector<TupleDescriptor*> build_side_child_desc;
612
    size_t build_exprs_size = 0;
613
    std::shared_ptr<vectorized::Block> build_block;
614
    std::shared_ptr<std::vector<uint32_t>> build_indexes_null;
615
616
    // Used by shared hash table
617
    // For probe operator, hash table in _hash_table_variants is read-only if visited flags is not
618
    // used. (visited flags will be used only in right / full outer join).
619
    //
620
    // For broadcast join, although hash table is read-only, some states in `_hash_table_variants`
621
    // are still could be written. For example, serialized keys will be written in a continuous
622
    // memory in `_hash_table_variants`. So before execution, we should use a local _hash_table_variants
623
    // which has a shared hash table in it.
624
    std::vector<std::shared_ptr<JoinDataVariants>> hash_table_variant_vector;
625
};
626
627
struct PartitionedHashJoinSharedState
628
        : public HashJoinSharedState,
629
          public BasicSpillSharedState,
630
          public std::enable_shared_from_this<PartitionedHashJoinSharedState> {
631
    ENABLE_FACTORY_CREATOR(PartitionedHashJoinSharedState)
632
633
0
    void update_spill_stream_profiles(RuntimeProfile* source_profile) override {
634
0
        for (auto& stream : spilled_streams) {
635
0
            if (stream) {
636
0
                stream->update_shared_profiles(source_profile);
637
0
            }
638
0
        }
639
0
    }
640
641
    std::unique_ptr<RuntimeState> inner_runtime_state;
642
    std::shared_ptr<HashJoinSharedState> inner_shared_state;
643
    std::vector<std::unique_ptr<vectorized::MutableBlock>> partitioned_build_blocks;
644
    std::vector<vectorized::SpillStreamSPtr> spilled_streams;
645
    bool is_spilled = false;
646
};
647
648
struct NestedLoopJoinSharedState : public JoinSharedState {
649
    ENABLE_FACTORY_CREATOR(NestedLoopJoinSharedState)
650
    // if true, left child has no more rows to process
651
    bool left_side_eos = false;
652
    // Visited flags for each row in build side.
653
    vectorized::MutableColumns build_side_visited_flags;
654
    // List of build blocks, constructed in prepare()
655
    vectorized::Blocks build_blocks;
656
};
657
658
struct PartitionSortNodeSharedState : public BasicSharedState {
659
    ENABLE_FACTORY_CREATOR(PartitionSortNodeSharedState)
660
public:
661
    std::queue<vectorized::Block> blocks_buffer;
662
    std::mutex buffer_mutex;
663
    std::vector<std::unique_ptr<vectorized::PartitionSorter>> partition_sorts;
664
    bool sink_eos = false;
665
    std::mutex sink_eos_lock;
666
    std::mutex prepared_finish_lock;
667
};
668
669
struct SetSharedState : public BasicSharedState {
670
    ENABLE_FACTORY_CREATOR(SetSharedState)
671
public:
672
    /// default init
673
    vectorized::Block build_block; // build to source
674
    //record element size in hashtable
675
    int64_t valid_element_in_hash_tbl = 0;
676
    //first: idx mapped to column types
677
    //second: column_id, could point to origin column or cast column
678
    std::unordered_map<int, int> build_col_idx;
679
680
    //// shared static states (shared, decided in prepare/open...)
681
682
    /// init in setup_local_state
683
    std::unique_ptr<SetDataVariants> hash_table_variants =
684
            std::make_unique<SetDataVariants>(); // the real data HERE.
685
    std::vector<bool> build_not_ignore_null;
686
687
    // The SET operator's child might have different nullable attributes.
688
    // If a calculation involves both nullable and non-nullable columns, the final output should be a nullable column
689
    Status update_build_not_ignore_null(const vectorized::VExprContextSPtrs& ctxs);
690
691
    size_t get_hash_table_size() const;
692
    /// init in both upstream side.
693
    //The i-th result expr list refers to the i-th child.
694
    std::vector<vectorized::VExprContextSPtrs> child_exprs_lists;
695
696
    /// init in build side
697
    size_t child_quantity;
698
    vectorized::VExprContextSPtrs build_child_exprs;
699
    std::vector<Dependency*> probe_finished_children_dependency;
700
701
    /// init in probe side
702
    std::vector<vectorized::VExprContextSPtrs> probe_child_exprs_lists;
703
704
    std::atomic<bool> ready_for_read = false;
705
706
    vectorized::Arena arena;
707
708
    /// called in setup_local_state
709
    Status hash_table_init();
710
};
711
712
enum class ExchangeType : uint8_t {
713
    NOOP = 0,
714
    // Shuffle data by Crc32CHashPartitioner
715
    HASH_SHUFFLE = 1,
716
    // Round-robin passthrough data blocks.
717
    PASSTHROUGH = 2,
718
    // Shuffle data by Crc32HashPartitioner<ShuffleChannelIds> (e.g. same as storage engine).
719
    BUCKET_HASH_SHUFFLE = 3,
720
    // Passthrough data blocks to all channels.
721
    BROADCAST = 4,
722
    // Passthrough data to channels evenly in an adaptive way.
723
    ADAPTIVE_PASSTHROUGH = 5,
724
    // Send all data to the first channel.
725
    PASS_TO_ONE = 6,
726
};
727
728
220k
inline std::string get_exchange_type_name(ExchangeType idx) {
729
220k
    switch (idx) {
730
14
    case ExchangeType::NOOP:
731
14
        return "NOOP";
732
56.3k
    case ExchangeType::HASH_SHUFFLE:
733
56.3k
        return "HASH_SHUFFLE";
734
157k
    case ExchangeType::PASSTHROUGH:
735
157k
        return "PASSTHROUGH";
736
960
    case ExchangeType::BUCKET_HASH_SHUFFLE:
737
960
        return "BUCKET_HASH_SHUFFLE";
738
534
    case ExchangeType::BROADCAST:
739
534
        return "BROADCAST";
740
1.83k
    case ExchangeType::ADAPTIVE_PASSTHROUGH:
741
1.83k
        return "ADAPTIVE_PASSTHROUGH";
742
3.56k
    case ExchangeType::PASS_TO_ONE:
743
3.56k
        return "PASS_TO_ONE";
744
220k
    }
745
0
    throw Exception(Status::FatalError("__builtin_unreachable"));
746
220k
}
747
748
struct DataDistribution {
749
2.05M
    DataDistribution(ExchangeType type) : distribution_type(type) {}
750
    DataDistribution(ExchangeType type, const std::vector<TExpr>& partition_exprs_)
751
267k
            : distribution_type(type), partition_exprs(partition_exprs_) {}
752
215k
    DataDistribution(const DataDistribution& other) = default;
753
666k
    bool need_local_exchange() const { return distribution_type != ExchangeType::NOOP; }
754
615k
    DataDistribution& operator=(const DataDistribution& other) = default;
755
    ExchangeType distribution_type;
756
    std::vector<TExpr> partition_exprs;
757
};
758
759
class ExchangerBase;
760
761
struct LocalExchangeSharedState : public BasicSharedState {
762
public:
763
    ENABLE_FACTORY_CREATOR(LocalExchangeSharedState);
764
    LocalExchangeSharedState(int num_instances);
765
    ~LocalExchangeSharedState() override;
766
    std::unique_ptr<ExchangerBase> exchanger {};
767
    std::vector<RuntimeProfile::Counter*> mem_counters;
768
    std::atomic<int64_t> mem_usage = 0;
769
    std::atomic<size_t> _buffer_mem_limit = config::local_exchange_buffer_mem_limit;
770
    // We need to make sure to add mem_usage first and then enqueue, otherwise sub mem_usage may cause negative mem_usage during concurrent dequeue.
771
    std::mutex le_lock;
772
    void sub_running_sink_operators();
773
    void sub_running_source_operators();
774
221k
    void _set_always_ready() {
775
1.32M
        for (auto& dep : source_deps) {
776
1.32M
            DCHECK(dep);
777
1.32M
            dep->set_always_ready();
778
1.32M
        }
779
221k
        for (auto& dep : sink_deps) {
780
221k
            DCHECK(dep);
781
221k
            dep->set_always_ready();
782
221k
        }
783
221k
    }
784
785
304k
    Dependency* get_sink_dep_by_channel_id(int channel_id) { return nullptr; }
786
787
203k
    void set_ready_to_read(int channel_id) {
788
203k
        auto& dep = source_deps[channel_id];
789
18.4E
        DCHECK(dep) << channel_id;
790
203k
        dep->set_ready();
791
203k
    }
792
793
204k
    void add_mem_usage(int channel_id, size_t delta) { mem_counters[channel_id]->update(delta); }
794
795
204k
    void sub_mem_usage(int channel_id, size_t delta) {
796
204k
        mem_counters[channel_id]->update(-(int64_t)delta);
797
204k
    }
798
799
174k
    void add_total_mem_usage(size_t delta) {
800
174k
        if (cast_set<int64_t>(mem_usage.fetch_add(delta) + delta) > _buffer_mem_limit) {
801
18
            sink_deps.front()->block();
802
18
        }
803
174k
    }
804
805
174k
    void sub_total_mem_usage(size_t delta) {
806
174k
        auto prev_usage = mem_usage.fetch_sub(delta);
807
174k
        DCHECK_GE(prev_usage - delta, 0) << "prev_usage: " << prev_usage << " delta: " << delta;
808
174k
        if (cast_set<int64_t>(prev_usage - delta) <= _buffer_mem_limit) {
809
174k
            sink_deps.front()->set_ready();
810
174k
        }
811
174k
    }
812
813
62
    void set_low_memory_mode(RuntimeState* state) {
814
62
        _buffer_mem_limit = std::min<int64_t>(config::local_exchange_buffer_mem_limit,
815
62
                                              state->low_memory_mode_buffer_limit());
816
62
    }
817
};
818
819
#include "common/compile_check_end.h"
820
} // namespace doris::pipeline