Coverage Report

Created: 2025-03-29 15:49

/root/doris/be/src/vec/columns/column.h
Line
Count
Source (jump to first uncovered line)
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
// This file is copied from
18
// https://github.com/ClickHouse/ClickHouse/blob/master/src/Columns/IColumn.h
19
// and modified by Doris
20
21
#pragma once
22
23
#include <fmt/format.h>
24
#include <glog/logging.h>
25
#include <sys/types.h>
26
27
#include <cstdint>
28
#include <functional>
29
#include <ostream>
30
#include <string>
31
#include <type_traits>
32
#include <utility>
33
#include <vector>
34
35
#include "common/status.h"
36
#include "gutil/integral_types.h"
37
#include "olap/olap_common.h"
38
#include "runtime/define_primitive_type.h"
39
#include "vec/common/cow.h"
40
#include "vec/common/pod_array_fwd.h"
41
#include "vec/common/string_ref.h"
42
#include "vec/common/typeid_cast.h"
43
#include "vec/core/field.h"
44
#include "vec/core/types.h"
45
46
class SipHash;
47
48
#define DO_CRC_HASHES_FUNCTION_COLUMN_IMPL()                                         \
49
5
    if (null_data == nullptr) {                                                      \
50
0
        for (size_t i = 0; i < s; i++) {                                             \
51
0
            hashes[i] = HashUtil::zlib_crc_hash(&data[i], sizeof(T), hashes[i]);     \
52
0
        }                                                                            \
53
5
    } else {                                                                         \
54
10
        for (size_t i = 0; i < s; i++) {                                             \
55
5
            if (null_data[i] == 0)                                                   \
56
5
                hashes[i] = HashUtil::zlib_crc_hash(&data[i], sizeof(T), hashes[i]); \
57
5
        }                                                                            \
58
5
    }
59
60
namespace doris::vectorized {
61
62
class Arena;
63
class ColumnSorter;
64
65
using EqualFlags = std::vector<uint8_t>;
66
using EqualRange = std::pair<int, int>;
67
68
/// Declares interface to store columns in memory.
69
class IColumn : public COW<IColumn> {
70
private:
71
    friend class COW<IColumn>;
72
73
    /// Creates the same column with the same data.
74
    /// This is internal method to use from COW.
75
    /// It performs shallow copy with copy-ctor and not useful from outside.
76
    /// If you want to copy column for modification, look at 'mutate' method.
77
    virtual MutablePtr clone() const = 0;
78
79
public:
80
    // 64bit offsets now only Array type used, so we make it protected
81
    // to avoid use IColumn::Offset64 directly.
82
    // please use ColumnArray::Offset64 instead if we need.
83
    using Offset64 = UInt64;
84
    using Offsets64 = PaddedPODArray<Offset64>;
85
86
    // 32bit offsets for string
87
    using Offset = UInt32;
88
    using Offsets = PaddedPODArray<Offset>;
89
90
    /// Name of a Column. It is used in info messages.
91
446
    virtual std::string get_name() const { return get_family_name(); }
92
93
    /// Name of a Column kind, without parameters (example: FixedString, Array).
94
    virtual const char* get_family_name() const = 0;
95
96
    /** If column isn't constant, returns nullptr (or itself).
97
      * If column is constant, transforms constant to full column (if column type allows such transform) and return it.
98
      */
99
18.1k
    virtual Ptr convert_to_full_column_if_const() const { return get_ptr(); }
100
101
    /** If in join. the StringColumn size may overflow uint32_t, we need convert to uint64_t to ColumnString64
102
  * The Column: ColumnString, ColumnNullable, ColumnArray, ColumnStruct need impl the code
103
  */
104
0
    virtual Ptr convert_column_if_overflow() { return get_ptr(); }
105
106
    /// If column isn't ColumnLowCardinality, return itself.
107
    /// If column is ColumnLowCardinality, transforms is to full column.
108
191
    virtual Ptr convert_to_full_column_if_low_cardinality() const { return get_ptr(); }
109
110
    /// If column isn't ColumnDictionary, return itself.
111
    /// If column is ColumnDictionary, transforms is to predicate column.
112
0
    virtual MutablePtr convert_to_predicate_column_if_dictionary() { return get_ptr(); }
113
114
    /// If column is ColumnDictionary, and is a range comparison predicate, convert dict encoding
115
4.05k
    virtual void convert_dict_codes_if_necessary() {}
116
117
    /// If column is ColumnDictionary, and is a bloom filter predicate, generate_hash_values
118
0
    virtual void initialize_hash_values_for_runtime_filter() {}
119
120
    /// Creates empty column with the same type.
121
138
    virtual MutablePtr clone_empty() const { return clone_resized(0); }
122
123
    /// Creates column with the same type and specified size.
124
    /// If size is less current size, then data is cut.
125
    /// If size is greater, than default values are appended.
126
0
    virtual MutablePtr clone_resized(size_t s) const {
127
0
        throw doris::Exception(ErrorCode::NOT_IMPLEMENTED_ERROR,
128
0
                               "Method clone_resized is not supported for " + get_name());
129
0
        return nullptr;
130
0
    }
131
132
    // shrink the end zeros for CHAR type or ARRAY<CHAR> type
133
0
    virtual MutablePtr get_shrinked_column() {
134
0
        throw doris::Exception(ErrorCode::NOT_IMPLEMENTED_ERROR,
135
0
                               "Method get_shrinked_column is not supported for " + get_name());
136
0
        return nullptr;
137
0
    }
138
139
    // check the column whether could shrinked
140
    // now support only in char type, or the nested type in complex type: array{char}, struct{char}, map{char}
141
0
    virtual bool could_shrinked_column() { return false; }
142
143
    /// Some columns may require finalization before using of other operations.
144
0
    virtual void finalize() {}
145
146
    // Only used on ColumnDictionary
147
347
    virtual void set_rowset_segment_id(std::pair<RowsetId, uint32_t> rowset_segment_id) {}
148
149
0
    virtual std::pair<RowsetId, uint32_t> get_rowset_segment_id() const { return {}; }
150
151
    /// Returns number of values in column.
152
    virtual size_t size() const = 0;
153
154
    /// There are no values in columns.
155
11.0k
    bool empty() const { return size() == 0; }
156
157
    /// Returns value of n-th element in universal Field representation.
158
    /// Is used in rare cases, since creation of Field instance is expensive usually.
159
    virtual Field operator[](size_t n) const = 0;
160
161
    /// Like the previous one, but avoids extra copying if Field is in a container, for example.
162
    virtual void get(size_t n, Field& res) const = 0;
163
164
    /// If possible, returns pointer to memory chunk which contains n-th element (if it isn't possible, throws an exception)
165
    /// Is used to optimize some computations (in aggregation, for example).
166
    virtual StringRef get_data_at(size_t n) const = 0;
167
168
    /// If column stores integers, it returns n-th element transformed to UInt64 using static_cast.
169
    /// If column stores floating point numbers, bits of n-th elements are copied to lower bits of UInt64, the remaining bits are zeros.
170
    /// Is used to optimize some computations (in aggregation, for example).
171
0
    virtual UInt64 get64(size_t /*n*/) const {
172
0
        LOG(FATAL) << "Method get64 is not supported for ";
173
0
        return 0;
174
0
    }
175
176
    /// If column stores native numeric type, it returns n-th element casted to Float64
177
    /// Is used in regression methods to cast each features into uniform type
178
0
    virtual Float64 get_float64(size_t /*n*/) const {
179
0
        LOG(FATAL) << "Method get_float64 is not supported for " << get_name();
180
0
        return 0;
181
0
    }
182
183
    /** If column is numeric, return value of n-th element, casted to UInt64.
184
      * For NULL values of Nullable column it is allowed to return arbitrary value.
185
      * Otherwise throw an exception.
186
      */
187
0
    virtual UInt64 get_uint(size_t /*n*/) const {
188
0
        LOG(FATAL) << "Method get_uint is not supported for " << get_name();
189
0
        return 0;
190
0
    }
191
192
0
    virtual Int64 get_int(size_t /*n*/) const {
193
0
        throw doris::Exception(ErrorCode::NOT_IMPLEMENTED_ERROR,
194
0
                               "Method get_int is not supported for " + get_name());
195
0
        return 0;
196
0
    }
197
198
0
    virtual bool is_default_at(size_t n) const { return get64(n) == 0; }
199
1.66k
    virtual bool is_null_at(size_t /*n*/) const { return false; }
200
201
    /** If column is numeric, return value of n-th element, casted to bool.
202
      * For NULL values of Nullable column returns false.
203
      * Otherwise throw an exception.
204
      */
205
0
    virtual bool get_bool(size_t /*n*/) const {
206
0
        throw doris::Exception(ErrorCode::NOT_IMPLEMENTED_ERROR,
207
0
                               "Method get_bool is not supported for " + get_name());
208
0
        return false;
209
0
    }
210
211
    /// Removes all elements outside of specified range.
212
    /// Is used in LIMIT operation, for example.
213
0
    virtual Ptr cut(size_t start, size_t length) const {
214
0
        MutablePtr res = clone_empty();
215
0
        res->insert_range_from(*this, start, length);
216
0
        return res;
217
0
    }
218
219
    /// Appends new value at the end of column (column's size is increased by 1).
220
    /// Is used to transform raw strings to Blocks (for example, inside input format parsers)
221
    virtual void insert(const Field& x) = 0;
222
223
    /// Appends n-th element from other column with the same type.
224
    /// Is used in merge-sort and merges. It could be implemented in inherited classes more optimally than default implementation.
225
    virtual void insert_from(const IColumn& src, size_t n);
226
227
    /// Appends range of elements from other column with the same type.
228
    /// Could be used to concatenate columns.
229
    /// TODO: we need `insert_range_from_const` for every column type.
230
    virtual void insert_range_from(const IColumn& src, size_t start, size_t length) = 0;
231
232
    /// Appends range of elements from other column with the same type.
233
    /// Do not need throw execption in ColumnString overflow uint32, only
234
    /// use in join
235
    virtual void insert_range_from_ignore_overflow(const IColumn& src, size_t start,
236
0
                                                   size_t length) {
237
0
        insert_range_from(src, start, length);
238
0
    }
239
240
    /// Appends one element from other column with the same type multiple times.
241
18
    virtual void insert_many_from(const IColumn& src, size_t position, size_t length) {
242
36
        for (size_t i = 0; i < length; ++i) {
243
18
            insert_from(src, position);
244
18
        }
245
18
    }
246
247
    virtual void insert_from_multi_column(const std::vector<const IColumn*>& srcs,
248
                                          std::vector<size_t> positions);
249
250
    /// Appends a batch elements from other column with the same type
251
    /// indices_begin + indices_end represent the row indices of column src
252
    virtual void insert_indices_from(const IColumn& src, const uint32_t* indices_begin,
253
                                     const uint32_t* indices_end) = 0;
254
255
    /// Appends data located in specified memory chunk if it is possible (throws an exception if it cannot be implemented).
256
    /// Is used to optimize some computations (in aggregation, for example).
257
    /// Parameter length could be ignored if column values have fixed size.
258
    /// All data will be inserted as single element
259
    virtual void insert_data(const char* pos, size_t length) = 0;
260
261
0
    virtual void insert_many_fix_len_data(const char* pos, size_t num) {
262
0
        throw doris::Exception(
263
0
                ErrorCode::NOT_IMPLEMENTED_ERROR,
264
0
                "Method insert_many_fix_len_data is not supported for " + get_name());
265
0
    }
266
267
    // todo(zeno) Use dict_args temp object to cover all arguments
268
    virtual void insert_many_dict_data(const int32_t* data_array, size_t start_index,
269
                                       const StringRef* dict, size_t data_num,
270
0
                                       uint32_t dict_num = 0) {
271
0
        throw doris::Exception(ErrorCode::NOT_IMPLEMENTED_ERROR,
272
0
                               "Method insert_many_dict_data is not supported for " + get_name());
273
0
    }
274
275
    virtual void insert_many_binary_data(char* data_array, uint32_t* len_array,
276
0
                                         uint32_t* start_offset_array, size_t num) {
277
0
        throw doris::Exception(ErrorCode::NOT_IMPLEMENTED_ERROR,
278
0
                               "Method insert_many_binary_data is not supported for " + get_name());
279
0
    }
280
281
    /// Insert binary data into column from a continuous buffer, the implementation maybe copy all binary data
282
    /// in one single time.
283
    virtual void insert_many_continuous_binary_data(const char* data, const uint32_t* offsets,
284
0
                                                    const size_t num) {
285
0
        throw doris::Exception(
286
0
                ErrorCode::NOT_IMPLEMENTED_ERROR,
287
0
                "Method insert_many_continuous_binary_data is not supported for " + get_name());
288
0
    }
289
290
0
    virtual void insert_many_strings(const StringRef* strings, size_t num) {
291
0
        throw doris::Exception(ErrorCode::NOT_IMPLEMENTED_ERROR,
292
0
                               "Method insert_many_strings is not supported for " + get_name());
293
0
    }
294
295
    virtual void insert_many_strings_overflow(const StringRef* strings, size_t num,
296
0
                                              size_t max_length) {
297
0
        throw doris::Exception(
298
0
                ErrorCode::NOT_IMPLEMENTED_ERROR,
299
0
                "Method insert_many_strings_overflow is not supported for " + get_name());
300
0
    }
301
302
    // Here `pos` points to the memory data type is the same as the data type of the column.
303
    // This function is used by `insert_keys_into_columns` in AggregationNode.
304
0
    virtual void insert_many_raw_data(const char* pos, size_t num) {
305
0
        throw doris::Exception(ErrorCode::NOT_IMPLEMENTED_ERROR,
306
0
                               "Method insert_many_raw_data is not supported for " + get_name());
307
0
    }
308
309
6
    void insert_many_data(const char* pos, size_t length, size_t data_num) {
310
12
        for (size_t i = 0; i < data_num; ++i) {
311
6
            insert_data(pos, length);
312
6
        }
313
6
    }
314
315
    /// Appends "default value".
316
    /// Is used when there are need to increase column size, but inserting value doesn't make sense.
317
    /// For example, ColumnNullable(Nested) absolutely ignores values of nested column if it is marked as NULL.
318
    virtual void insert_default() = 0;
319
320
    /// Appends "default value" multiple times.
321
3
    virtual void insert_many_defaults(size_t length) {
322
26
        for (size_t i = 0; i < length; ++i) {
323
23
            insert_default();
324
23
        }
325
3
    }
326
327
    /** Removes last n elements.
328
      * Is used to support exception-safety of several operations.
329
      *  For example, sometimes insertion should be reverted if we catch an exception during operation processing.
330
      * If column has less than n elements or n == 0 - undefined behavior.
331
      */
332
    virtual void pop_back(size_t n) = 0;
333
334
    /** Serializes n-th element. Serialized element should be placed continuously inside Arena's memory.
335
      * Serialized value can be deserialized to reconstruct original object. Is used in aggregation.
336
      * The method is similar to get_data_at(), but can work when element's value cannot be mapped to existing continuous memory chunk,
337
      *  For example, to obtain unambiguous representation of Array of strings, strings data should be interleaved with their sizes.
338
      * Parameter begin should be used with Arena::alloc_continue.
339
      */
340
    virtual StringRef serialize_value_into_arena(size_t n, Arena& arena,
341
                                                 char const*& begin) const = 0;
342
343
    /// Deserializes a value that was serialized using IColumn::serialize_value_into_arena method.
344
    /// Returns pointer to the position after the read data.
345
    virtual const char* deserialize_and_insert_from_arena(const char* pos) = 0;
346
347
    /// Return the size of largest row.
348
    /// This is for calculating the memory size for vectorized serialization of aggregation keys.
349
0
    virtual size_t get_max_row_byte_size() const {
350
0
        throw doris::Exception(ErrorCode::NOT_IMPLEMENTED_ERROR,
351
0
                               "Method get_max_row_byte_size is not supported for " + get_name());
352
0
        return 0;
353
0
    }
354
355
    virtual void serialize_vec(std::vector<StringRef>& keys, size_t num_rows,
356
0
                               size_t max_row_byte_size) const {
357
0
        throw doris::Exception(ErrorCode::NOT_IMPLEMENTED_ERROR,
358
0
                               "Method serialize_vec is not supported for " + get_name());
359
0
        __builtin_unreachable();
360
0
    }
361
362
    virtual void serialize_vec_with_null_map(std::vector<StringRef>& keys, size_t num_rows,
363
0
                                             const uint8_t* null_map) const {
364
0
        throw doris::Exception(
365
0
                ErrorCode::NOT_IMPLEMENTED_ERROR,
366
0
                "Method serialize_vec_with_null_map is not supported for " + get_name());
367
0
        __builtin_unreachable();
368
0
    }
369
370
    // This function deserializes group-by keys into column in the vectorized way.
371
0
    virtual void deserialize_vec(std::vector<StringRef>& keys, const size_t num_rows) {
372
0
        throw doris::Exception(ErrorCode::NOT_IMPLEMENTED_ERROR,
373
0
                               "Method deserialize_vec is not supported for " + get_name());
374
0
        __builtin_unreachable();
375
0
    }
376
377
    // Used in ColumnNullable::deserialize_vec
378
    virtual void deserialize_vec_with_null_map(std::vector<StringRef>& keys, const size_t num_rows,
379
0
                                               const uint8_t* null_map) {
380
0
        throw doris::Exception(
381
0
                ErrorCode::NOT_IMPLEMENTED_ERROR,
382
0
                "Method deserialize_vec_with_null_map is not supported for " + get_name());
383
0
        __builtin_unreachable();
384
0
    }
385
386
    /// TODO: SipHash is slower than city or xx hash, rethink we should have a new interface
387
    /// Update state of hash function with value of n-th element.
388
    /// On subsequent calls of this method for sequence of column values of arbitrary types,
389
    ///  passed bytes to hash must identify sequence of values unambiguously.
390
0
    virtual void update_hash_with_value(size_t n, SipHash& hash) const {
391
0
        throw doris::Exception(ErrorCode::NOT_IMPLEMENTED_ERROR,
392
0
                               "Method update_hash_with_value is not supported for " + get_name());
393
0
    }
394
395
    /// Update state of hash function with value of n elements to avoid the virtual function call
396
    /// null_data to mark whether need to do hash compute, null_data == nullptr
397
    /// means all element need to do hash function, else only *null_data != 0 need to do hash func
398
    /// do xxHash here, faster than other sip hash
399
    virtual void update_hashes_with_value(uint64_t* __restrict hashes,
400
0
                                          const uint8_t* __restrict null_data = nullptr) const {
401
0
        throw doris::Exception(
402
0
                ErrorCode::NOT_IMPLEMENTED_ERROR,
403
0
                "Method update_hashes_with_value is not supported for " + get_name());
404
0
    }
405
406
    // use range for one hash value to avoid virtual function call in loop
407
    virtual void update_xxHash_with_value(size_t start, size_t end, uint64_t& hash,
408
0
                                          const uint8_t* __restrict null_data) const {
409
0
        throw doris::Exception(
410
0
                ErrorCode::NOT_IMPLEMENTED_ERROR,
411
0
                "Method update_xxHash_with_value is not supported for " + get_name());
412
0
    }
413
414
    /// Update state of crc32 hash function with value of n elements to avoid the virtual function call
415
    /// null_data to mark whether need to do hash compute, null_data == nullptr
416
    /// means all element need to do hash function, else only *null_data != 0 need to do hash func
417
    virtual void update_crcs_with_value(uint32_t* __restrict hash, PrimitiveType type,
418
                                        uint32_t rows, uint32_t offset = 0,
419
0
                                        const uint8_t* __restrict null_data = nullptr) const {
420
0
        throw doris::Exception(ErrorCode::NOT_IMPLEMENTED_ERROR,
421
0
                               "Method update_crcs_with_value is not supported for " + get_name());
422
0
    }
423
424
    // use range for one hash value to avoid virtual function call in loop
425
    virtual void update_crc_with_value(size_t start, size_t end, uint32_t& hash,
426
0
                                       const uint8_t* __restrict null_data) const {
427
0
        throw doris::Exception(ErrorCode::NOT_IMPLEMENTED_ERROR,
428
0
                               "Method update_crc_with_value is not supported for " + get_name());
429
0
    }
430
431
    /** Removes elements that don't match the filter.
432
      * Is used in WHERE and HAVING operations.
433
      * If result_size_hint > 0, then makes advance reserve(result_size_hint) for the result column;
434
      *  if 0, then don't makes reserve(),
435
      *  otherwise (i.e. < 0), makes reserve() using size of source column.
436
      */
437
    using Filter = PaddedPODArray<UInt8>;
438
    virtual Ptr filter(const Filter& filt, ssize_t result_size_hint) const = 0;
439
440
    /// This function will modify the original table.
441
    /// Return rows number after filtered.
442
    virtual size_t filter(const Filter& filter) = 0;
443
444
    /**
445
     *  used by lazy materialization to filter column by selected rowids
446
     *  Q: Why use IColumn* as args type instead of MutablePtr or ImmutablePtr ?
447
     *  A: If use MutablePtr/ImmutablePtr as col_ptr's type, which means there could be many 
448
     *  convert(convert MutablePtr to ImmutablePtr or convert ImmutablePtr to MutablePtr)
449
     *  happends in filter_by_selector because of mem-reuse logic or ColumnNullable, I think this is meaningless;
450
     *  So using raw ptr directly here.
451
     *  NOTICE: only column_nullable and predict_column, column_dictionary now support filter_by_selector
452
     */
453
0
    virtual Status filter_by_selector(const uint16_t* sel, size_t sel_size, IColumn* col_ptr) {
454
0
        throw doris::Exception(ErrorCode::NOT_IMPLEMENTED_ERROR,
455
0
                               "Method filter_by_selector is not supported for {}, only "
456
0
                               "column_nullable, column_dictionary and predict_column support",
457
0
                               get_name());
458
0
        __builtin_unreachable();
459
0
    }
460
461
    /// Permutes elements using specified permutation. Is used in sortings.
462
    /// limit - if it isn't 0, puts only first limit elements in the result.
463
    using Permutation = PaddedPODArray<size_t>;
464
    virtual Ptr permute(const Permutation& perm, size_t limit) const = 0;
465
466
    /// Creates new column with values column[indexes[:limit]]. If limit is 0, all indexes are used.
467
    /// Indexes must be one of the ColumnUInt. For default implementation, see select_index_impl from ColumnsCommon.h
468
0
    virtual Ptr index(const IColumn& indexes, size_t limit) const {
469
0
        LOG(FATAL) << "column not support index";
470
0
        __builtin_unreachable();
471
0
    }
472
473
    /** Compares (*this)[n] and rhs[m]. Column rhs should have the same type.
474
      * Returns negative number, 0, or positive number (*this)[n] is less, equal, greater than rhs[m] respectively.
475
      * Is used in sortings.
476
      *
477
      * If one of element's value is NaN or NULLs, then:
478
      * - if nan_direction_hint == -1, NaN and NULLs are considered as least than everything other;
479
      * - if nan_direction_hint ==  1, NaN and NULLs are considered as greatest than everything other.
480
      * For example, if nan_direction_hint == -1 is used by descending sorting, NaNs will be at the end.
481
      *
482
      * For non Nullable and non floating point types, nan_direction_hint is ignored.
483
      * For array/map/struct types, we compare with nested column element and offsets size
484
      */
485
    virtual int compare_at(size_t n, size_t m, const IColumn& rhs,
486
                           int nan_direction_hint) const = 0;
487
488
    /**
489
     * To compare all rows in this column with another row (with row_id = rhs_row_id in column rhs)
490
     * @param nan_direction_hint and direction indicates the ordering.
491
     * @param cmp_res if we already has a comparison result for row i, e.g. cmp_res[i] = 1, we can skip row i
492
     * @param filter this stores comparison results for all rows. filter[i] = 1 means row i is less than row rhs_row_id in rhs
493
     */
494
    virtual void compare_internal(size_t rhs_row_id, const IColumn& rhs, int nan_direction_hint,
495
                                  int direction, std::vector<uint8>& cmp_res,
496
                                  uint8* __restrict filter) const;
497
498
    /** Returns a permutation that sorts elements of this column,
499
      *  i.e. perm[i]-th element of source column should be i-th element of sorted column.
500
      * reverse - reverse ordering (ascending).
501
      * limit - if isn't 0, then only first limit elements of the result column could be sorted.
502
      * nan_direction_hint - see above.
503
      */
504
    virtual void get_permutation(bool reverse, size_t limit, int nan_direction_hint,
505
                                 Permutation& res) const = 0;
506
507
    /** Copies each element according offsets parameter.
508
      * (i-th element should be copied offsets[i] - offsets[i - 1] times.)
509
      * It is necessary in ARRAY JOIN operation.
510
      */
511
    virtual Ptr replicate(const Offsets& offsets) const = 0;
512
513
    /// Appends one field multiple times. Can be optimized in inherited classes.
514
0
    virtual void insert_many(const Field& field, size_t length) {
515
0
        for (size_t i = 0; i < length; ++i) {
516
0
            insert(field);
517
0
        }
518
0
    }
519
    /// Returns indices of values in column, that not equal to default value of column.
520
    virtual void get_indices_of_non_default_rows(Offsets64& indices, size_t from,
521
0
                                                 size_t limit) const {
522
0
        LOG(FATAL) << "column not support get_indices_of_non_default_rows";
523
0
        __builtin_unreachable();
524
0
    }
525
526
    template <typename Derived>
527
    void get_indices_of_non_default_rows_impl(IColumn::Offsets64& indices, size_t from,
528
                                              size_t limit) const;
529
530
    /** Split column to smaller columns. Each value goes to column index, selected by corresponding element of 'selector'.
531
      * Selector must contain values from 0 to num_columns - 1.
532
      * For default implementation, see scatter_impl.
533
      */
534
    using ColumnIndex = UInt64;
535
    using Selector = PaddedPODArray<ColumnIndex>;
536
537
    virtual void append_data_by_selector(MutablePtr& res, const Selector& selector) const = 0;
538
539
    virtual void append_data_by_selector(MutablePtr& res, const Selector& selector, size_t begin,
540
                                         size_t end) const = 0;
541
542
    /// Insert data from several other columns according to source mask (used in vertical merge).
543
    /// For now it is a helper to de-virtualize calls to insert*() functions inside gather loop
544
    /// (descendants should call gatherer_stream.gather(*this) to implement this function.)
545
    /// TODO: interface decoupled from ColumnGathererStream that allows non-generic specializations.
546
    //    virtual void gather(ColumnGathererStream & gatherer_stream) = 0;
547
548
    /// Reserves memory for specified amount of elements. If reservation isn't possible, does nothing.
549
    /// It affects performance only (not correctness).
550
0
    virtual void reserve(size_t /*n*/) {}
551
552
    /// Resize memory for specified amount of elements. If reservation isn't possible, does nothing.
553
    /// It affects performance only (not correctness).
554
0
    virtual void resize(size_t /*n*/) {}
555
556
    /// Size of column data in memory (may be approximate) - for profiling. Zero, if could not be determined.
557
    virtual size_t byte_size() const = 0;
558
559
    /// Size of memory, allocated for column.
560
    /// This is greater or equals to byte_size due to memory reservation in containers.
561
    /// Zero, if could not be determined.
562
    virtual size_t allocated_bytes() const = 0;
563
564
    /// If the column contains subcolumns (such as Array, Nullable, etc), do callback on them.
565
    /// Shallow: doesn't do recursive calls; don't do call for itself.
566
    using ColumnCallback = std::function<void(WrappedPtr&)>;
567
    using ImutableColumnCallback = std::function<void(const IColumn&)>;
568
43.7k
    virtual void for_each_subcolumn(ColumnCallback) {}
569
570
    /// Columns have equal structure.
571
    /// If true - you can use "compare_at", "insert_from", etc. methods.
572
0
    virtual bool structure_equals(const IColumn&) const {
573
0
        throw doris::Exception(ErrorCode::NOT_IMPLEMENTED_ERROR,
574
0
                               "Method structure_equals is not supported for " + get_name());
575
0
        return false;
576
0
    }
577
578
45.2k
    MutablePtr mutate() const&& {
579
45.2k
        MutablePtr res = shallow_mutate();
580
45.2k
        res->for_each_subcolumn(
581
45.2k
                [](WrappedPtr& subcolumn) { subcolumn = std::move(*subcolumn).mutate(); });
582
45.2k
        return res;
583
45.2k
    }
584
585
0
    static MutablePtr mutate(Ptr ptr) {
586
0
        MutablePtr res = ptr->shallow_mutate(); /// Now use_count is 2.
587
0
        ptr.reset();                            /// Reset use_count to 1.
588
0
        res->for_each_subcolumn(
589
0
                [](WrappedPtr& subcolumn) { subcolumn = std::move(*subcolumn).mutate(); });
590
0
        return res;
591
0
    }
592
593
    /** Some columns can contain another columns inside.
594
      * So, we have a tree of columns. But not all combinations are possible.
595
      * There are the following rules:
596
      *
597
      * ColumnConst may be only at top. It cannot be inside any column.
598
      * ColumnNullable can contain only simple columns.
599
      */
600
601
    /// Various properties on behaviour of column type.
602
603
    /// True if column contains something nullable inside. It's true for ColumnNullable, can be true or false for ColumnConst, etc.
604
31.2k
    virtual bool is_nullable() const { return false; }
605
606
0
    virtual bool is_bitmap() const { return false; }
607
608
0
    virtual bool is_hll() const { return false; }
609
610
    // true if column has null element
611
0
    virtual bool has_null() const { return false; }
612
613
    // true if column has null element [0,size)
614
1.65k
    virtual bool has_null(size_t size) const { return false; }
615
616
6
    virtual bool is_exclusive() const { return use_count() == 1; }
617
618
    /// Clear data of column, just like vector clear
619
    virtual void clear() = 0;
620
621
    /** Memory layout properties.
622
      *
623
      * Each value of a column can be placed in memory contiguously or not.
624
      *
625
      * Example: simple columns like UInt64 or FixedString store their values contiguously in single memory buffer.
626
      *
627
      * Example: Tuple store values of each component in separate subcolumn, so the values of Tuples with at least two components are not contiguous.
628
      * Another example is Nullable. Each value have null flag, that is stored separately, so the value is not contiguous in memory.
629
      *
630
      * There are some important cases, when values are not stored contiguously, but for each value, you can get contiguous memory segment,
631
      *  that will unambiguously identify the value. In this case, methods get_data_at and insert_data are implemented.
632
      * Example: String column: bytes of strings are stored concatenated in one memory buffer
633
      *  and offsets to that buffer are stored in another buffer. The same is for Array of fixed-size contiguous elements.
634
      *
635
      * To avoid confusion between these cases, we don't have isContiguous method.
636
      */
637
638
    /// Values in column have fixed size (including the case when values span many memory segments).
639
0
    virtual bool values_have_fixed_size() const { return is_fixed_and_contiguous(); }
640
641
    /// Values in column are represented as continuous memory segment of fixed size. Implies values_have_fixed_size.
642
0
    virtual bool is_fixed_and_contiguous() const { return false; }
643
644
    /// If is_fixed_and_contiguous, returns the underlying data array, otherwise throws an exception.
645
0
    virtual StringRef get_raw_data() const {
646
0
        throw doris::Exception(ErrorCode::NOT_IMPLEMENTED_ERROR,
647
0
                               "Column {} is not a contiguous block of memory", get_name());
648
0
        return StringRef {};
649
0
    }
650
651
    /// If values_have_fixed_size, returns size of value, otherwise throw an exception.
652
0
    virtual size_t size_of_value_if_fixed() const {
653
0
        throw doris::Exception(ErrorCode::NOT_IMPLEMENTED_ERROR,
654
0
                               "Values of column {} are not fixed size.", get_name());
655
0
        return 0;
656
0
    }
657
658
    /// Returns ratio of values in column, that are equal to default value of column.
659
    /// Checks only @sample_ratio ratio of rows.
660
0
    virtual double get_ratio_of_default_rows(double sample_ratio = 1.0) const {
661
0
        LOG(FATAL) << fmt::format("get_ratio_of_default_rows of column {} are not implemented.",
662
0
                                  get_name());
663
0
        return 0.0;
664
0
    }
665
666
    /// Template is to devirtualize calls to 'isDefaultAt' method.
667
    template <typename Derived>
668
    double get_ratio_of_default_rows_impl(double sample_ratio) const;
669
670
    /// Column is ColumnVector of numbers or ColumnConst of it. Note that Nullable columns are not numeric.
671
    /// Implies is_fixed_and_contiguous.
672
0
    virtual bool is_numeric() const { return false; }
673
674
    // Column is ColumnString/ColumnArray/ColumnMap or other variable length column at every row
675
3
    virtual bool is_variable_length() const { return false; }
676
677
3
    virtual bool is_column_string() const { return false; }
678
679
0
    virtual bool is_column_string64() const { return false; }
680
681
0
    virtual bool is_column_decimal() const { return false; }
682
683
4.16k
    virtual bool is_column_dictionary() const { return false; }
684
685
0
    virtual bool is_column_array() const { return false; }
686
687
8
    virtual bool is_column_map() const { return false; }
688
689
0
    virtual bool is_column_struct() const { return false; }
690
691
    /// If the only value column can contain is NULL.
692
638
    virtual bool only_null() const { return false; }
693
694
    virtual void sort_column(const ColumnSorter* sorter, EqualFlags& flags,
695
                             IColumn::Permutation& perms, EqualRange& range,
696
                             bool last_column) const;
697
698
39.9k
    virtual ~IColumn() = default;
699
39.9k
    IColumn() = default;
700
5
    IColumn(const IColumn&) = default;
701
702
    /** Print column name, size, and recursively print all subcolumns.
703
      */
704
    String dump_structure() const;
705
706
    // only used in agg value replace
707
    // ColumnString should replace according to 0,1,2... ,size,0,1,2...
708
    virtual void replace_column_data(const IColumn&, size_t row, size_t self_row = 0) = 0;
709
710
    // only used in ColumnNullable replace_column_data
711
    virtual void replace_column_data_default(size_t self_row = 0) = 0;
712
713
0
    virtual void replace_column_null_data(const uint8_t* __restrict null_map) {}
714
715
500k
    virtual bool is_date_type() const { return is_date; }
716
500k
    virtual bool is_datetime_type() const { return is_date_time; }
717
718
138
    virtual void set_date_type() { is_date = true; }
719
280
    virtual void set_datetime_type() { is_date_time = true; }
720
721
54
    void copy_date_types(const IColumn& col) {
722
54
        if (col.is_date_type()) {
723
1
            set_date_type();
724
1
        }
725
54
        if (col.is_datetime_type()) {
726
4
            set_datetime_type();
727
4
        }
728
54
    }
729
730
    // todo(wb): a temporary implemention, need re-abstract here
731
    bool is_date = false;
732
    bool is_date_time = false;
733
734
protected:
735
    template <typename Derived>
736
    void append_data_by_selector_impl(MutablePtr& res, const Selector& selector) const;
737
    template <typename Derived>
738
    void append_data_by_selector_impl(MutablePtr& res, const Selector& selector, size_t begin,
739
                                      size_t end) const;
740
};
741
742
using ColumnPtr = IColumn::Ptr;
743
using MutableColumnPtr = IColumn::MutablePtr;
744
using Columns = std::vector<ColumnPtr>;
745
using MutableColumns = std::vector<MutableColumnPtr>;
746
using ColumnPtrs = std::vector<ColumnPtr>;
747
using ColumnRawPtrs = std::vector<const IColumn*>;
748
749
template <typename... Args>
750
struct IsMutableColumns;
751
752
template <typename Arg, typename... Args>
753
struct IsMutableColumns<Arg, Args...> {
754
    static const bool value =
755
            std::is_assignable<MutableColumnPtr&&, Arg>::value && IsMutableColumns<Args...>::value;
756
};
757
758
template <>
759
struct IsMutableColumns<> {
760
    static const bool value = true;
761
};
762
763
// prefer assert_cast than check_and_get
764
template <typename Type>
765
4.03k
const Type* check_and_get_column(const IColumn& column) {
766
4.03k
    return typeid_cast<const Type*>(&column);
767
4.03k
}
_ZN5doris10vectorized20check_and_get_columnINS0_11ColumnArrayEEEPKT_RKNS0_7IColumnE
Line
Count
Source
765
19
const Type* check_and_get_column(const IColumn& column) {
766
19
    return typeid_cast<const Type*>(&column);
767
19
}
_ZN5doris10vectorized20check_and_get_columnINS0_12ColumnVectorIjEEEEPKT_RKNS0_7IColumnE
Line
Count
Source
765
17
const Type* check_and_get_column(const IColumn& column) {
766
17
    return typeid_cast<const Type*>(&column);
767
17
}
Unexecuted instantiation: _ZN5doris10vectorized20check_and_get_columnINS0_12ColumnVectorIoEEEEPKT_RKNS0_7IColumnE
_ZN5doris10vectorized20check_and_get_columnINS0_12ColumnVectorIhEEEEPKT_RKNS0_7IColumnE
Line
Count
Source
765
71
const Type* check_and_get_column(const IColumn& column) {
766
71
    return typeid_cast<const Type*>(&column);
767
71
}
_ZN5doris10vectorized20check_and_get_columnINS0_12ColumnVectorIdEEEEPKT_RKNS0_7IColumnE
Line
Count
Source
765
7
const Type* check_and_get_column(const IColumn& column) {
766
7
    return typeid_cast<const Type*>(&column);
767
7
}
_ZN5doris10vectorized20check_and_get_columnINS0_14ColumnNullableEEEPKT_RKNS0_7IColumnE
Line
Count
Source
765
2.46k
const Type* check_and_get_column(const IColumn& column) {
766
2.46k
    return typeid_cast<const Type*>(&column);
767
2.46k
}
Unexecuted instantiation: _ZN5doris10vectorized20check_and_get_columnIKNS0_19PredicateColumnTypeILNS_13PrimitiveTypeE5EEEEEPKT_RKNS0_7IColumnE
Unexecuted instantiation: _ZN5doris10vectorized20check_and_get_columnINS0_19PredicateColumnTypeILNS_13PrimitiveTypeE5EEEEEPKT_RKNS0_7IColumnE
Unexecuted instantiation: _ZN5doris10vectorized20check_and_get_columnIKNS0_19PredicateColumnTypeILNS_13PrimitiveTypeE11EEEEEPKT_RKNS0_7IColumnE
Unexecuted instantiation: _ZN5doris10vectorized20check_and_get_columnINS0_19PredicateColumnTypeILNS_13PrimitiveTypeE11EEEEEPKT_RKNS0_7IColumnE
Unexecuted instantiation: _ZN5doris10vectorized20check_and_get_columnIKNS0_19PredicateColumnTypeILNS_13PrimitiveTypeE12EEEEEPKT_RKNS0_7IColumnE
Unexecuted instantiation: _ZN5doris10vectorized20check_and_get_columnINS0_19PredicateColumnTypeILNS_13PrimitiveTypeE12EEEEEPKT_RKNS0_7IColumnE
_ZN5doris10vectorized20check_and_get_columnINS0_12ColumnVectorIiEEEEPKT_RKNS0_7IColumnE
Line
Count
Source
765
93
const Type* check_and_get_column(const IColumn& column) {
766
93
    return typeid_cast<const Type*>(&column);
767
93
}
_ZN5doris10vectorized20check_and_get_columnINS0_12ColumnVectorIaEEEEPKT_RKNS0_7IColumnE
Line
Count
Source
765
35
const Type* check_and_get_column(const IColumn& column) {
766
35
    return typeid_cast<const Type*>(&column);
767
35
}
_ZN5doris10vectorized20check_and_get_columnINS0_12ColumnVectorIsEEEEPKT_RKNS0_7IColumnE
Line
Count
Source
765
30
const Type* check_and_get_column(const IColumn& column) {
766
30
    return typeid_cast<const Type*>(&column);
767
30
}
_ZN5doris10vectorized20check_and_get_columnINS0_12ColumnVectorIlEEEEPKT_RKNS0_7IColumnE
Line
Count
Source
765
37
const Type* check_and_get_column(const IColumn& column) {
766
37
    return typeid_cast<const Type*>(&column);
767
37
}
_ZN5doris10vectorized20check_and_get_columnINS0_12ColumnVectorInEEEEPKT_RKNS0_7IColumnE
Line
Count
Source
765
19
const Type* check_and_get_column(const IColumn& column) {
766
19
    return typeid_cast<const Type*>(&column);
767
19
}
_ZN5doris10vectorized20check_and_get_columnINS0_13ColumnDecimalINS0_7DecimalInEEEEEEPKT_RKNS0_7IColumnE
Line
Count
Source
765
10
const Type* check_and_get_column(const IColumn& column) {
766
10
    return typeid_cast<const Type*>(&column);
767
10
}
_ZN5doris10vectorized20check_and_get_columnINS0_12ColumnVectorIfEEEEPKT_RKNS0_7IColumnE
Line
Count
Source
765
10
const Type* check_and_get_column(const IColumn& column) {
766
10
    return typeid_cast<const Type*>(&column);
767
10
}
_ZN5doris10vectorized20check_and_get_columnINS0_12ColumnVectorImEEEEPKT_RKNS0_7IColumnE
Line
Count
Source
765
17
const Type* check_and_get_column(const IColumn& column) {
766
17
    return typeid_cast<const Type*>(&column);
767
17
}
_ZN5doris10vectorized20check_and_get_columnIKNS0_14ColumnNullableEEEPKT_RKNS0_7IColumnE
Line
Count
Source
765
27
const Type* check_and_get_column(const IColumn& column) {
766
27
    return typeid_cast<const Type*>(&column);
767
27
}
_ZN5doris10vectorized20check_and_get_columnINS0_11ColumnConstEEEPKT_RKNS0_7IColumnE
Line
Count
Source
765
1.11k
const Type* check_and_get_column(const IColumn& column) {
766
1.11k
    return typeid_cast<const Type*>(&column);
767
1.11k
}
_ZN5doris10vectorized20check_and_get_columnINS0_9ColumnStrIjEEEEPKT_RKNS0_7IColumnE
Line
Count
Source
765
60
const Type* check_and_get_column(const IColumn& column) {
766
60
    return typeid_cast<const Type*>(&column);
767
60
}
Unexecuted instantiation: _ZN5doris10vectorized20check_and_get_columnINS0_13ColumnDecimalINS0_7DecimalIiEEEEEEPKT_RKNS0_7IColumnE
Unexecuted instantiation: _ZN5doris10vectorized20check_and_get_columnINS0_13ColumnDecimalINS0_7DecimalIlEEEEEEPKT_RKNS0_7IColumnE
Unexecuted instantiation: _ZN5doris10vectorized20check_and_get_columnINS0_13ColumnDecimalINS0_12Decimal128V3EEEEEPKT_RKNS0_7IColumnE
Unexecuted instantiation: _ZN5doris10vectorized20check_and_get_columnIKNS0_11ColumnConstEEEPKT_RKNS0_7IColumnE
Unexecuted instantiation: _ZN5doris10vectorized20check_and_get_columnINS0_13ColumnDecimalINS0_7DecimalIN4wide7integerILm256EiEEEEEEEEPKT_RKNS0_7IColumnE
Unexecuted instantiation: _ZN5doris10vectorized20check_and_get_columnIKNS0_19PredicateColumnTypeILNS_13PrimitiveTypeE3EEEEEPKT_RKNS0_7IColumnE
Unexecuted instantiation: _ZN5doris10vectorized20check_and_get_columnINS0_19PredicateColumnTypeILNS_13PrimitiveTypeE3EEEEEPKT_RKNS0_7IColumnE
Unexecuted instantiation: _ZN5doris10vectorized20check_and_get_columnIKNS0_19PredicateColumnTypeILNS_13PrimitiveTypeE4EEEEEPKT_RKNS0_7IColumnE
Unexecuted instantiation: _ZN5doris10vectorized20check_and_get_columnINS0_19PredicateColumnTypeILNS_13PrimitiveTypeE4EEEEEPKT_RKNS0_7IColumnE
Unexecuted instantiation: _ZN5doris10vectorized20check_and_get_columnIKNS0_19PredicateColumnTypeILNS_13PrimitiveTypeE6EEEEEPKT_RKNS0_7IColumnE
Unexecuted instantiation: _ZN5doris10vectorized20check_and_get_columnINS0_19PredicateColumnTypeILNS_13PrimitiveTypeE6EEEEEPKT_RKNS0_7IColumnE
Unexecuted instantiation: _ZN5doris10vectorized20check_and_get_columnIKNS0_19PredicateColumnTypeILNS_13PrimitiveTypeE7EEEEEPKT_RKNS0_7IColumnE
Unexecuted instantiation: _ZN5doris10vectorized20check_and_get_columnINS0_19PredicateColumnTypeILNS_13PrimitiveTypeE7EEEEEPKT_RKNS0_7IColumnE
Unexecuted instantiation: _ZN5doris10vectorized20check_and_get_columnIKNS0_19PredicateColumnTypeILNS_13PrimitiveTypeE8EEEEEPKT_RKNS0_7IColumnE
Unexecuted instantiation: _ZN5doris10vectorized20check_and_get_columnINS0_19PredicateColumnTypeILNS_13PrimitiveTypeE8EEEEEPKT_RKNS0_7IColumnE
Unexecuted instantiation: _ZN5doris10vectorized20check_and_get_columnIKNS0_19PredicateColumnTypeILNS_13PrimitiveTypeE9EEEEEPKT_RKNS0_7IColumnE
Unexecuted instantiation: _ZN5doris10vectorized20check_and_get_columnINS0_19PredicateColumnTypeILNS_13PrimitiveTypeE9EEEEEPKT_RKNS0_7IColumnE
Unexecuted instantiation: _ZN5doris10vectorized20check_and_get_columnIKNS0_19PredicateColumnTypeILNS_13PrimitiveTypeE20EEEEEPKT_RKNS0_7IColumnE
Unexecuted instantiation: _ZN5doris10vectorized20check_and_get_columnINS0_19PredicateColumnTypeILNS_13PrimitiveTypeE20EEEEEPKT_RKNS0_7IColumnE
Unexecuted instantiation: _ZN5doris10vectorized20check_and_get_columnIKNS0_19PredicateColumnTypeILNS_13PrimitiveTypeE28EEEEEPKT_RKNS0_7IColumnE
Unexecuted instantiation: _ZN5doris10vectorized20check_and_get_columnINS0_19PredicateColumnTypeILNS_13PrimitiveTypeE28EEEEEPKT_RKNS0_7IColumnE
Unexecuted instantiation: _ZN5doris10vectorized20check_and_get_columnIKNS0_19PredicateColumnTypeILNS_13PrimitiveTypeE29EEEEEPKT_RKNS0_7IColumnE
Unexecuted instantiation: _ZN5doris10vectorized20check_and_get_columnINS0_19PredicateColumnTypeILNS_13PrimitiveTypeE29EEEEEPKT_RKNS0_7IColumnE
Unexecuted instantiation: _ZN5doris10vectorized20check_and_get_columnIKNS0_19PredicateColumnTypeILNS_13PrimitiveTypeE30EEEEEPKT_RKNS0_7IColumnE
Unexecuted instantiation: _ZN5doris10vectorized20check_and_get_columnINS0_19PredicateColumnTypeILNS_13PrimitiveTypeE30EEEEEPKT_RKNS0_7IColumnE
Unexecuted instantiation: _ZN5doris10vectorized20check_and_get_columnIKNS0_19PredicateColumnTypeILNS_13PrimitiveTypeE35EEEEEPKT_RKNS0_7IColumnE
Unexecuted instantiation: _ZN5doris10vectorized20check_and_get_columnINS0_19PredicateColumnTypeILNS_13PrimitiveTypeE35EEEEEPKT_RKNS0_7IColumnE
Unexecuted instantiation: _ZN5doris10vectorized20check_and_get_columnINS0_16ColumnDictionaryIiEEEEPKT_RKNS0_7IColumnE
Unexecuted instantiation: _ZN5doris10vectorized20check_and_get_columnIKNS0_19PredicateColumnTypeILNS_13PrimitiveTypeE15EEEEEPKT_RKNS0_7IColumnE
Unexecuted instantiation: _ZN5doris10vectorized20check_and_get_columnINS0_19PredicateColumnTypeILNS_13PrimitiveTypeE15EEEEEPKT_RKNS0_7IColumnE
Unexecuted instantiation: _ZN5doris10vectorized20check_and_get_columnIKNS0_19PredicateColumnTypeILNS_13PrimitiveTypeE23EEEEEPKT_RKNS0_7IColumnE
Unexecuted instantiation: _ZN5doris10vectorized20check_and_get_columnINS0_19PredicateColumnTypeILNS_13PrimitiveTypeE23EEEEEPKT_RKNS0_7IColumnE
Unexecuted instantiation: _ZN5doris10vectorized20check_and_get_columnIKNS0_19PredicateColumnTypeILNS_13PrimitiveTypeE25EEEEEPKT_RKNS0_7IColumnE
Unexecuted instantiation: _ZN5doris10vectorized20check_and_get_columnINS0_19PredicateColumnTypeILNS_13PrimitiveTypeE25EEEEEPKT_RKNS0_7IColumnE
Unexecuted instantiation: _ZN5doris10vectorized20check_and_get_columnIKNS0_19PredicateColumnTypeILNS_13PrimitiveTypeE26EEEEEPKT_RKNS0_7IColumnE
Unexecuted instantiation: _ZN5doris10vectorized20check_and_get_columnINS0_19PredicateColumnTypeILNS_13PrimitiveTypeE26EEEEEPKT_RKNS0_7IColumnE
Unexecuted instantiation: _ZN5doris10vectorized20check_and_get_columnIKNS0_19PredicateColumnTypeILNS_13PrimitiveTypeE2EEEEEPKT_RKNS0_7IColumnE
Unexecuted instantiation: _ZN5doris10vectorized20check_and_get_columnINS0_19PredicateColumnTypeILNS_13PrimitiveTypeE2EEEEEPKT_RKNS0_7IColumnE
Unexecuted instantiation: _ZN5doris10vectorized20check_and_get_columnIKNS0_19PredicateColumnTypeILNS_13PrimitiveTypeE36EEEEEPKT_RKNS0_7IColumnE
Unexecuted instantiation: _ZN5doris10vectorized20check_and_get_columnINS0_19PredicateColumnTypeILNS_13PrimitiveTypeE36EEEEEPKT_RKNS0_7IColumnE
Unexecuted instantiation: _ZN5doris10vectorized20check_and_get_columnIKNS0_19PredicateColumnTypeILNS_13PrimitiveTypeE37EEEEEPKT_RKNS0_7IColumnE
Unexecuted instantiation: _ZN5doris10vectorized20check_and_get_columnINS0_19PredicateColumnTypeILNS_13PrimitiveTypeE37EEEEEPKT_RKNS0_7IColumnE
Unexecuted instantiation: _ZN5doris10vectorized20check_and_get_columnINS0_9ColumnMapEEEPKT_RKNS0_7IColumnE
Unexecuted instantiation: _ZN5doris10vectorized20check_and_get_columnINS0_12ColumnStructEEEPKT_RKNS0_7IColumnE
Unexecuted instantiation: _ZN5doris10vectorized20check_and_get_columnINS0_12ColumnObjectEEEPKT_RKNS0_7IColumnE
Unexecuted instantiation: _ZN5doris10vectorized20check_and_get_columnINS0_12ColumnVectorItEEEEPKT_RKNS0_7IColumnE
Unexecuted instantiation: _ZN5doris10vectorized20check_and_get_columnINS0_12ColumnVectorINS0_7UInt128EEEEEPKT_RKNS0_7IColumnE
Unexecuted instantiation: _ZN5doris10vectorized20check_and_get_columnIKNS0_12ColumnVectorIhEEEEPKT_RKNS0_7IColumnE
768
769
template <typename Type>
770
30.1k
const Type* check_and_get_column(const IColumn* column) {
771
30.1k
    return typeid_cast<const Type*>(column);
772
30.1k
}
_ZN5doris10vectorized20check_and_get_columnINS0_14ColumnNullableEEEPKT_PKNS0_7IColumnE
Line
Count
Source
770
556
const Type* check_and_get_column(const IColumn* column) {
771
556
    return typeid_cast<const Type*>(column);
772
556
}
_ZN5doris10vectorized20check_and_get_columnINS0_19PredicateColumnTypeILNS_13PrimitiveTypeE5EEEEEPKT_PKNS0_7IColumnE
Line
Count
Source
770
4.07k
const Type* check_and_get_column(const IColumn* column) {
771
4.07k
    return typeid_cast<const Type*>(column);
772
4.07k
}
Unexecuted instantiation: _ZN5doris10vectorized20check_and_get_columnINS0_19PredicateColumnTypeILNS_13PrimitiveTypeE11EEEEEPKT_PKNS0_7IColumnE
Unexecuted instantiation: _ZN5doris10vectorized20check_and_get_columnINS0_19PredicateColumnTypeILNS_13PrimitiveTypeE12EEEEEPKT_PKNS0_7IColumnE
_ZN5doris10vectorized20check_and_get_columnINS0_9ColumnStrIjEEEEPKT_PKNS0_7IColumnE
Line
Count
Source
770
227
const Type* check_and_get_column(const IColumn* column) {
771
227
    return typeid_cast<const Type*>(column);
772
227
}
_ZN5doris10vectorized20check_and_get_columnINS0_11ColumnArrayEEEPKT_PKNS0_7IColumnE
Line
Count
Source
770
35
const Type* check_and_get_column(const IColumn* column) {
771
35
    return typeid_cast<const Type*>(column);
772
35
}
_ZN5doris10vectorized20check_and_get_columnINS0_12ColumnVectorIhEEEEPKT_PKNS0_7IColumnE
Line
Count
Source
770
56
const Type* check_and_get_column(const IColumn* column) {
771
56
    return typeid_cast<const Type*>(column);
772
56
}
_ZN5doris10vectorized20check_and_get_columnINS0_12ColumnVectorItEEEEPKT_PKNS0_7IColumnE
Line
Count
Source
770
21
const Type* check_and_get_column(const IColumn* column) {
771
21
    return typeid_cast<const Type*>(column);
772
21
}
_ZN5doris10vectorized20check_and_get_columnINS0_12ColumnVectorIjEEEEPKT_PKNS0_7IColumnE
Line
Count
Source
770
61
const Type* check_and_get_column(const IColumn* column) {
771
61
    return typeid_cast<const Type*>(column);
772
61
}
_ZN5doris10vectorized20check_and_get_columnINS0_12ColumnVectorImEEEEPKT_PKNS0_7IColumnE
Line
Count
Source
770
61
const Type* check_and_get_column(const IColumn* column) {
771
61
    return typeid_cast<const Type*>(column);
772
61
}
_ZN5doris10vectorized20check_and_get_columnINS0_12ColumnVectorIaEEEEPKT_PKNS0_7IColumnE
Line
Count
Source
770
58
const Type* check_and_get_column(const IColumn* column) {
771
58
    return typeid_cast<const Type*>(column);
772
58
}
_ZN5doris10vectorized20check_and_get_columnINS0_12ColumnVectorIsEEEEPKT_PKNS0_7IColumnE
Line
Count
Source
770
51
const Type* check_and_get_column(const IColumn* column) {
771
51
    return typeid_cast<const Type*>(column);
772
51
}
_ZN5doris10vectorized20check_and_get_columnINS0_12ColumnVectorIiEEEEPKT_PKNS0_7IColumnE
Line
Count
Source
770
68
const Type* check_and_get_column(const IColumn* column) {
771
68
    return typeid_cast<const Type*>(column);
772
68
}
_ZN5doris10vectorized20check_and_get_columnINS0_12ColumnVectorIlEEEEPKT_PKNS0_7IColumnE
Line
Count
Source
770
96
const Type* check_and_get_column(const IColumn* column) {
771
96
    return typeid_cast<const Type*>(column);
772
96
}
_ZN5doris10vectorized20check_and_get_columnINS0_12ColumnVectorInEEEEPKT_PKNS0_7IColumnE
Line
Count
Source
770
18
const Type* check_and_get_column(const IColumn* column) {
771
18
    return typeid_cast<const Type*>(column);
772
18
}
_ZN5doris10vectorized20check_and_get_columnINS0_12ColumnVectorIfEEEEPKT_PKNS0_7IColumnE
Line
Count
Source
770
13
const Type* check_and_get_column(const IColumn* column) {
771
13
    return typeid_cast<const Type*>(column);
772
13
}
_ZN5doris10vectorized20check_and_get_columnINS0_12ColumnVectorIdEEEEPKT_PKNS0_7IColumnE
Line
Count
Source
770
26
const Type* check_and_get_column(const IColumn* column) {
771
26
    return typeid_cast<const Type*>(column);
772
26
}
_ZN5doris10vectorized20check_and_get_columnINS0_13ColumnDecimalINS0_7DecimalIiEEEEEEPKT_PKNS0_7IColumnE
Line
Count
Source
770
1
const Type* check_and_get_column(const IColumn* column) {
771
1
    return typeid_cast<const Type*>(column);
772
1
}
Unexecuted instantiation: _ZN5doris10vectorized20check_and_get_columnINS0_13ColumnDecimalINS0_7DecimalIlEEEEEEPKT_PKNS0_7IColumnE
_ZN5doris10vectorized20check_and_get_columnINS0_13ColumnDecimalINS0_7DecimalInEEEEEEPKT_PKNS0_7IColumnE
Line
Count
Source
770
2
const Type* check_and_get_column(const IColumn* column) {
771
2
    return typeid_cast<const Type*>(column);
772
2
}
Unexecuted instantiation: _ZN5doris10vectorized20check_and_get_columnINS0_13ColumnDecimalINS0_12Decimal128V3EEEEEPKT_PKNS0_7IColumnE
Unexecuted instantiation: _ZN5doris10vectorized20check_and_get_columnINS0_13ColumnDecimalINS0_7DecimalIN4wide7integerILm256EiEEEEEEEEPKT_PKNS0_7IColumnE
Unexecuted instantiation: _ZN5doris10vectorized20check_and_get_columnINS0_19PredicateColumnTypeILNS_13PrimitiveTypeE3EEEEEPKT_PKNS0_7IColumnE
Unexecuted instantiation: _ZN5doris10vectorized20check_and_get_columnINS0_19PredicateColumnTypeILNS_13PrimitiveTypeE4EEEEEPKT_PKNS0_7IColumnE
Unexecuted instantiation: _ZN5doris10vectorized20check_and_get_columnINS0_19PredicateColumnTypeILNS_13PrimitiveTypeE6EEEEEPKT_PKNS0_7IColumnE
Unexecuted instantiation: _ZN5doris10vectorized20check_and_get_columnINS0_19PredicateColumnTypeILNS_13PrimitiveTypeE7EEEEEPKT_PKNS0_7IColumnE
Unexecuted instantiation: _ZN5doris10vectorized20check_and_get_columnINS0_19PredicateColumnTypeILNS_13PrimitiveTypeE8EEEEEPKT_PKNS0_7IColumnE
Unexecuted instantiation: _ZN5doris10vectorized20check_and_get_columnINS0_19PredicateColumnTypeILNS_13PrimitiveTypeE9EEEEEPKT_PKNS0_7IColumnE
Unexecuted instantiation: _ZN5doris10vectorized20check_and_get_columnINS0_19PredicateColumnTypeILNS_13PrimitiveTypeE20EEEEEPKT_PKNS0_7IColumnE
Unexecuted instantiation: _ZN5doris10vectorized20check_and_get_columnINS0_19PredicateColumnTypeILNS_13PrimitiveTypeE28EEEEEPKT_PKNS0_7IColumnE
Unexecuted instantiation: _ZN5doris10vectorized20check_and_get_columnINS0_19PredicateColumnTypeILNS_13PrimitiveTypeE29EEEEEPKT_PKNS0_7IColumnE
Unexecuted instantiation: _ZN5doris10vectorized20check_and_get_columnINS0_19PredicateColumnTypeILNS_13PrimitiveTypeE30EEEEEPKT_PKNS0_7IColumnE
Unexecuted instantiation: _ZN5doris10vectorized20check_and_get_columnINS0_19PredicateColumnTypeILNS_13PrimitiveTypeE35EEEEEPKT_PKNS0_7IColumnE
Unexecuted instantiation: _ZN5doris10vectorized20check_and_get_columnINS0_16ColumnDictionaryIiEEEEPKT_PKNS0_7IColumnE
Unexecuted instantiation: _ZN5doris10vectorized20check_and_get_columnINS0_19PredicateColumnTypeILNS_13PrimitiveTypeE15EEEEEPKT_PKNS0_7IColumnE
_ZN5doris10vectorized20check_and_get_columnINS0_19PredicateColumnTypeILNS_13PrimitiveTypeE23EEEEEPKT_PKNS0_7IColumnE
Line
Count
Source
770
20
const Type* check_and_get_column(const IColumn* column) {
771
20
    return typeid_cast<const Type*>(column);
772
20
}
Unexecuted instantiation: _ZN5doris10vectorized20check_and_get_columnINS0_19PredicateColumnTypeILNS_13PrimitiveTypeE25EEEEEPKT_PKNS0_7IColumnE
Unexecuted instantiation: _ZN5doris10vectorized20check_and_get_columnINS0_19PredicateColumnTypeILNS_13PrimitiveTypeE26EEEEEPKT_PKNS0_7IColumnE
Unexecuted instantiation: _ZN5doris10vectorized20check_and_get_columnINS0_19PredicateColumnTypeILNS_13PrimitiveTypeE2EEEEEPKT_PKNS0_7IColumnE
Unexecuted instantiation: _ZN5doris10vectorized20check_and_get_columnINS0_19PredicateColumnTypeILNS_13PrimitiveTypeE36EEEEEPKT_PKNS0_7IColumnE
Unexecuted instantiation: _ZN5doris10vectorized20check_and_get_columnINS0_19PredicateColumnTypeILNS_13PrimitiveTypeE37EEEEEPKT_PKNS0_7IColumnE
_ZN5doris10vectorized20check_and_get_columnINS0_11ColumnConstEEEPKT_PKNS0_7IColumnE
Line
Count
Source
770
24.6k
const Type* check_and_get_column(const IColumn* column) {
771
24.6k
    return typeid_cast<const Type*>(column);
772
24.6k
}
Unexecuted instantiation: _ZN5doris10vectorized20check_and_get_columnINS0_9ColumnMapEEEPKT_PKNS0_7IColumnE
_ZN5doris10vectorized20check_and_get_columnIKNS0_11ColumnArrayEEEPKT_PKNS0_7IColumnE
Line
Count
Source
770
70
const Type* check_and_get_column(const IColumn* column) {
771
70
    return typeid_cast<const Type*>(column);
772
70
}
_ZN5doris10vectorized20check_and_get_columnIKNS0_14ColumnNullableEEEPKT_PKNS0_7IColumnE
Line
Count
Source
770
12
const Type* check_and_get_column(const IColumn* column) {
771
12
    return typeid_cast<const Type*>(column);
772
12
}
_ZN5doris10vectorized20check_and_get_columnINS0_12ColumnVectorIoEEEEPKT_PKNS0_7IColumnE
Line
Count
Source
770
2
const Type* check_and_get_column(const IColumn* column) {
771
2
    return typeid_cast<const Type*>(column);
772
2
}
_ZN5doris10vectorized20check_and_get_columnINS0_17ColumnComplexTypeINS_11BitmapValueEEEEEPKT_PKNS0_7IColumnE
Line
Count
Source
770
8
const Type* check_and_get_column(const IColumn* column) {
771
8
    return typeid_cast<const Type*>(column);
772
8
}
Unexecuted instantiation: _ZN5doris10vectorized20check_and_get_columnINS0_12ColumnStructEEEPKT_PKNS0_7IColumnE
_ZN5doris10vectorized20check_and_get_columnIKNS0_12ColumnVectorIhEEEEPKT_PKNS0_7IColumnE
Line
Count
Source
770
4
const Type* check_and_get_column(const IColumn* column) {
771
4
    return typeid_cast<const Type*>(column);
772
4
}
_ZN5doris10vectorized20check_and_get_columnIKNS0_12ColumnVectorIaEEEEPKT_PKNS0_7IColumnE
Line
Count
Source
770
2
const Type* check_and_get_column(const IColumn* column) {
771
2
    return typeid_cast<const Type*>(column);
772
2
}
_ZN5doris10vectorized20check_and_get_columnIKNS0_12ColumnVectorIsEEEEPKT_PKNS0_7IColumnE
Line
Count
Source
770
2
const Type* check_and_get_column(const IColumn* column) {
771
2
    return typeid_cast<const Type*>(column);
772
2
}
_ZN5doris10vectorized20check_and_get_columnIKNS0_12ColumnVectorIiEEEEPKT_PKNS0_7IColumnE
Line
Count
Source
770
2
const Type* check_and_get_column(const IColumn* column) {
771
2
    return typeid_cast<const Type*>(column);
772
2
}
_ZN5doris10vectorized20check_and_get_columnIKNS0_12ColumnVectorIlEEEEPKT_PKNS0_7IColumnE
Line
Count
Source
770
2
const Type* check_and_get_column(const IColumn* column) {
771
2
    return typeid_cast<const Type*>(column);
772
2
}
Unexecuted instantiation: _ZN5doris10vectorized20check_and_get_columnIKNS0_12ColumnVectorInEEEEPKT_PKNS0_7IColumnE
_ZN5doris10vectorized20check_and_get_columnIKNS0_12ColumnVectorIdEEEEPKT_PKNS0_7IColumnE
Line
Count
Source
770
2
const Type* check_and_get_column(const IColumn* column) {
771
2
    return typeid_cast<const Type*>(column);
772
2
}
Unexecuted instantiation: _ZN5doris10vectorized20check_and_get_columnINS0_17ColumnComplexTypeINS_11HyperLogLogEEEEEPKT_PKNS0_7IColumnE
Unexecuted instantiation: _ZN5doris10vectorized20check_and_get_columnINS0_12ColumnObjectEEEPKT_PKNS0_7IColumnE
773
774
template <typename Type>
775
24.9k
bool check_column(const IColumn& column) {
776
24.9k
    return check_and_get_column<Type>(&column);
777
24.9k
}
_ZN5doris10vectorized12check_columnINS0_14ColumnNullableEEEbRKNS0_7IColumnE
Line
Count
Source
775
357
bool check_column(const IColumn& column) {
776
357
    return check_and_get_column<Type>(&column);
777
357
}
_ZN5doris10vectorized12check_columnINS0_11ColumnConstEEEbRKNS0_7IColumnE
Line
Count
Source
775
24.6k
bool check_column(const IColumn& column) {
776
24.6k
    return check_and_get_column<Type>(&column);
777
24.6k
}
Unexecuted instantiation: _ZN5doris10vectorized12check_columnINS0_12ColumnVectorIhEEEEbRKNS0_7IColumnE
_ZN5doris10vectorized12check_columnINS0_12ColumnVectorIaEEEEbRKNS0_7IColumnE
Line
Count
Source
775
2
bool check_column(const IColumn& column) {
776
2
    return check_and_get_column<Type>(&column);
777
2
}
Unexecuted instantiation: _ZN5doris10vectorized12check_columnINS0_12ColumnVectorIsEEEEbRKNS0_7IColumnE
_ZN5doris10vectorized12check_columnINS0_12ColumnVectorIiEEEEbRKNS0_7IColumnE
Line
Count
Source
775
3
bool check_column(const IColumn& column) {
776
3
    return check_and_get_column<Type>(&column);
777
3
}
_ZN5doris10vectorized12check_columnINS0_12ColumnVectorIlEEEEbRKNS0_7IColumnE
Line
Count
Source
775
5
bool check_column(const IColumn& column) {
776
5
    return check_and_get_column<Type>(&column);
777
5
}
_ZN5doris10vectorized12check_columnINS0_12ColumnVectorInEEEEbRKNS0_7IColumnE
Line
Count
Source
775
1
bool check_column(const IColumn& column) {
776
1
    return check_and_get_column<Type>(&column);
777
1
}
_ZN5doris10vectorized12check_columnINS0_12ColumnVectorIfEEEEbRKNS0_7IColumnE
Line
Count
Source
775
1
bool check_column(const IColumn& column) {
776
1
    return check_and_get_column<Type>(&column);
777
1
}
_ZN5doris10vectorized12check_columnINS0_12ColumnVectorIdEEEEbRKNS0_7IColumnE
Line
Count
Source
775
1
bool check_column(const IColumn& column) {
776
1
    return check_and_get_column<Type>(&column);
777
1
}
Unexecuted instantiation: _ZN5doris10vectorized12check_columnINS0_13ColumnDecimalINS0_7DecimalIiEEEEEEbRKNS0_7IColumnE
Unexecuted instantiation: _ZN5doris10vectorized12check_columnINS0_13ColumnDecimalINS0_7DecimalIlEEEEEEbRKNS0_7IColumnE
Unexecuted instantiation: _ZN5doris10vectorized12check_columnINS0_13ColumnDecimalINS0_12Decimal128V3EEEEEbRKNS0_7IColumnE
_ZN5doris10vectorized12check_columnINS0_13ColumnDecimalINS0_7DecimalInEEEEEEbRKNS0_7IColumnE
Line
Count
Source
775
2
bool check_column(const IColumn& column) {
776
2
    return check_and_get_column<Type>(&column);
777
2
}
Unexecuted instantiation: _ZN5doris10vectorized12check_columnINS0_13ColumnDecimalINS0_7DecimalIN4wide7integerILm256EiEEEEEEEEbRKNS0_7IColumnE
Unexecuted instantiation: _ZN5doris10vectorized12check_columnINS0_12ColumnVectorIjEEEEbRKNS0_7IColumnE
Unexecuted instantiation: _ZN5doris10vectorized12check_columnINS0_12ColumnVectorImEEEEbRKNS0_7IColumnE
Unexecuted instantiation: _ZN5doris10vectorized12check_columnINS0_9ColumnStrIjEEEEbRKNS0_7IColumnE
778
779
template <typename Type>
780
36
bool check_column(const IColumn* column) {
781
36
    return check_and_get_column<Type>(column);
782
36
}
_ZN5doris10vectorized12check_columnINS0_11ColumnArrayEEEbPKNS0_7IColumnE
Line
Count
Source
780
15
bool check_column(const IColumn* column) {
781
15
    return check_and_get_column<Type>(column);
782
15
}
Unexecuted instantiation: _ZN5doris10vectorized12check_columnINS0_9ColumnMapEEEbPKNS0_7IColumnE
_ZN5doris10vectorized12check_columnINS0_12ColumnVectorItEEEEbPKNS0_7IColumnE
Line
Count
Source
780
3
bool check_column(const IColumn* column) {
781
3
    return check_and_get_column<Type>(column);
782
3
}
_ZN5doris10vectorized12check_columnINS0_12ColumnVectorIjEEEEbPKNS0_7IColumnE
Line
Count
Source
780
3
bool check_column(const IColumn* column) {
781
3
    return check_and_get_column<Type>(column);
782
3
}
_ZN5doris10vectorized12check_columnINS0_12ColumnVectorImEEEEbPKNS0_7IColumnE
Line
Count
Source
780
3
bool check_column(const IColumn* column) {
781
3
    return check_and_get_column<Type>(column);
782
3
}
_ZN5doris10vectorized12check_columnINS0_12ColumnVectorIaEEEEbPKNS0_7IColumnE
Line
Count
Source
780
3
bool check_column(const IColumn* column) {
781
3
    return check_and_get_column<Type>(column);
782
3
}
_ZN5doris10vectorized12check_columnINS0_12ColumnVectorIsEEEEbPKNS0_7IColumnE
Line
Count
Source
780
3
bool check_column(const IColumn* column) {
781
3
    return check_and_get_column<Type>(column);
782
3
}
_ZN5doris10vectorized12check_columnINS0_12ColumnVectorIiEEEEbPKNS0_7IColumnE
Line
Count
Source
780
3
bool check_column(const IColumn* column) {
781
3
    return check_and_get_column<Type>(column);
782
3
}
Unexecuted instantiation: _ZN5doris10vectorized12check_columnINS0_12ColumnVectorIlEEEEbPKNS0_7IColumnE
Unexecuted instantiation: _ZN5doris10vectorized12check_columnINS0_12ColumnVectorInEEEEbPKNS0_7IColumnE
Unexecuted instantiation: _ZN5doris10vectorized12check_columnINS0_12ColumnVectorIoEEEEbPKNS0_7IColumnE
Unexecuted instantiation: _ZN5doris10vectorized12check_columnINS0_12ColumnVectorIfEEEEbPKNS0_7IColumnE
Unexecuted instantiation: _ZN5doris10vectorized12check_columnINS0_12ColumnVectorIdEEEEbPKNS0_7IColumnE
_ZN5doris10vectorized12check_columnINS0_12ColumnVectorIhEEEEbPKNS0_7IColumnE
Line
Count
Source
780
3
bool check_column(const IColumn* column) {
781
3
    return check_and_get_column<Type>(column);
782
3
}
Unexecuted instantiation: _ZN5doris10vectorized12check_columnINS0_13ColumnDecimalINS0_7DecimalIiEEEEEEbPKNS0_7IColumnE
Unexecuted instantiation: _ZN5doris10vectorized12check_columnINS0_13ColumnDecimalINS0_7DecimalIlEEEEEEbPKNS0_7IColumnE
Unexecuted instantiation: _ZN5doris10vectorized12check_columnINS0_13ColumnDecimalINS0_7DecimalInEEEEEEbPKNS0_7IColumnE
Unexecuted instantiation: _ZN5doris10vectorized12check_columnINS0_13ColumnDecimalINS0_12Decimal128V3EEEEEbPKNS0_7IColumnE
Unexecuted instantiation: _ZN5doris10vectorized12check_columnINS0_13ColumnDecimalINS0_7DecimalIN4wide7integerILm256EiEEEEEEEEbPKNS0_7IColumnE
Unexecuted instantiation: _ZN5doris10vectorized12check_columnINS0_9ColumnStrIjEEEEbPKNS0_7IColumnE
783
784
/// True if column's an ColumnConst instance. It's just a syntax sugar for type check.
785
bool is_column_const(const IColumn& column);
786
787
/// True if column's an ColumnNullable instance. It's just a syntax sugar for type check.
788
bool is_column_nullable(const IColumn& column);
789
} // namespace doris::vectorized
790
791
// Wrap `ColumnPtr` because `ColumnPtr` can't be used in forward declaration.
792
namespace doris {
793
struct ColumnPtrWrapper {
794
    vectorized::ColumnPtr column_ptr;
795
796
196
    ColumnPtrWrapper(vectorized::ColumnPtr col) : column_ptr(col) {}
797
};
798
} // namespace doris