Coverage Report

Created: 2026-01-23 02:53

next uncovered line (L), next uncovered region (R), next uncovered branch (B)
/root/doris/be/src/vec/exprs/vexpr.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
#include <gen_cpp/Exprs_types.h>
21
#include <gen_cpp/Opcodes_types.h>
22
#include <gen_cpp/Types_types.h>
23
#include <glog/logging.h>
24
25
#include <cstddef>
26
#include <cstdint>
27
#include <memory>
28
#include <ostream>
29
#include <string>
30
#include <utility>
31
#include <vector>
32
33
#include "common/be_mock_util.h"
34
#include "common/status.h"
35
#include "olap/rowset/segment_v2/ann_index/ann_search_params.h"
36
#include "olap/rowset/segment_v2/index_reader.h"
37
#include "olap/rowset/segment_v2/inverted_index_reader.h"
38
#include "runtime/define_primitive_type.h"
39
#include "runtime/large_int_value.h"
40
#include "runtime/types.h"
41
#include "util/date_func.h"
42
#include "vec/aggregate_functions/aggregate_function.h"
43
#include "vec/columns/column.h"
44
#include "vec/core/block.h"
45
#include "vec/core/column_with_type_and_name.h"
46
#include "vec/core/extended_types.h"
47
#include "vec/core/types.h"
48
#include "vec/data_types/data_type.h"
49
#include "vec/data_types/data_type_ipv6.h"
50
#include "vec/exprs/function_context.h"
51
#include "vec/exprs/vexpr_context.h"
52
#include "vec/exprs/vexpr_fwd.h"
53
#include "vec/functions/cast/cast_to_string.h"
54
#include "vec/functions/function.h"
55
#include "vec/runtime/timestamptz_value.h"
56
57
namespace doris {
58
class BitmapFilterFuncBase;
59
class BloomFilterFuncBase;
60
class HybridSetBase;
61
class ObjectPool;
62
class RowDescriptor;
63
class RuntimeState;
64
65
namespace segment_v2 {
66
class IndexIterator;
67
class ColumnIterator;
68
struct AnnRangeSearchRuntime;
69
}; // namespace segment_v2
70
71
namespace vectorized {
72
#include "common/compile_check_begin.h"
73
#define RETURN_IF_ERROR_OR_PREPARED(stmt) \
74
258k
    if (_prepared) {                      \
75
0
        return Status::OK();              \
76
0
    }                                     \
77
258k
    _prepared = true;                     \
78
258k
    RETURN_IF_ERROR(stmt);
79
80
// VExpr should be used as shared pointer because it will be passed between classes
81
// like runtime filter to scan node, or from scannode to scanner. We could not make sure
82
// the relatioinship between threads and classes.
83
class VExpr {
84
public:
85
    // resize inserted param column to make sure column size equal to block.rows() and return param column index
86
    // keep return type same with block::columns()
87
0
    static uint32_t insert_param(Block* block, ColumnWithTypeAndName&& elem, size_t size) {
88
        // usually elem.column always is const column, so we just clone it.
89
0
        elem.column = elem.column->clone_resized(size);
90
0
        block->insert(std::move(elem));
91
        // just inserted. so no need to check underflow.
92
0
        return block->columns() - 1;
93
0
    }
94
95
    static bool is_acting_on_a_slot(const VExpr& expr);
96
97
    VExpr(const TExprNode& node);
98
    VExpr(const VExpr& vexpr);
99
    VExpr(DataTypePtr type, bool is_slotref);
100
    // only used for test
101
995
    VExpr() = default;
102
401k
    virtual ~VExpr() = default;
103
104
    virtual const std::string& expr_name() const = 0;
105
0
    virtual std::string expr_label() { return ""; }
106
107
    /// Initializes this expr instance for execution. This does not include initializing
108
    /// state in the VExprContext; 'context' should only be used to register a
109
    /// FunctionContext via RegisterFunctionContext().
110
    ///
111
    /// Subclasses overriding this function should call VExpr::Prepare() to recursively call
112
    /// Prepare() on the expr tree
113
    /// row_desc used in vslot_ref and some subclass to specify column
114
    virtual Status prepare(RuntimeState* state, const RowDescriptor& row_desc,
115
                           VExprContext* context);
116
117
    /// Initializes 'context' for execution. If scope if FRAGMENT_LOCAL, both fragment- and
118
    /// thread-local state should be initialized. Otherwise, if scope is THREAD_LOCAL, only
119
    /// thread-local state should be initialized.
120
    //
121
    /// Subclasses overriding this function should call VExpr::Open() to recursively call
122
    /// Open() on the expr tree
123
    virtual Status open(RuntimeState* state, VExprContext* context,
124
                        FunctionContext::FunctionStateScope scope);
125
126
    // before execute, check if expr has been parepared+opened.
127
0
    [[maybe_unused]] Status ready_status() const {
128
0
        if (_prepare_finished && _open_finished) {
129
0
            return Status::OK();
130
0
        }
131
0
        return Status::InternalError(expr_name() + " is not ready when execute");
132
0
    }
133
134
48
    virtual Status execute(VExprContext* context, Block* block, int* result_column_id) const {
135
48
        ColumnPtr result_column;
136
48
        RETURN_IF_ERROR(execute_column(context, block, block->rows(), result_column));
137
45
        *result_column_id = block->columns();
138
45
        block->insert({result_column, execute_type(block), expr_name()});
139
45
        return Status::OK();
140
48
    }
141
142
    // Execute the current expression and return the result column.
143
    // Note: the block will not be modified during execution.
144
    // We allow columns in the block to have different numbers of rows.
145
    // 'count' indicates the number of rows in the result column returned by this expression.
146
    // In the future this interface will add an additional parameter, Selector, which specifies
147
    // which rows in the block should be evaluated.
148
    // If expr is executing constant expressions, then block should be nullptr.
149
    virtual Status execute_column(VExprContext* context, const Block* block, size_t count,
150
                                  ColumnPtr& result_column) const = 0;
151
152
    // Currently, due to fe planning issues, for slot-ref expressions the type of the returned Column may not match data_type.
153
    // Therefore we need a function like this to return the actual type produced by execution.
154
79
    virtual DataTypePtr execute_type(const Block* block) const { return _data_type; }
155
156
    virtual Status execute_filter(VExprContext* context, const Block* block,
157
                                  uint8_t* __restrict result_filter_data, size_t rows,
158
                                  bool accept_null, bool* can_filter_all) const;
159
160
    // `is_blockable` means this expr will be blocked in `execute` (e.g. AI Function, Remote Function)
161
65.9k
    [[nodiscard]] virtual bool is_blockable() const {
162
65.9k
        return std::any_of(_children.begin(), _children.end(),
163
65.9k
                           [](VExprSPtr child) { return child->is_blockable(); });
164
65.9k
    }
165
166
    // execute current expr with inverted index to filter block. Given a roaring bitmap of match rows
167
0
    virtual Status evaluate_inverted_index(VExprContext* context, uint32_t segment_num_rows) {
168
0
        return Status::OK();
169
0
    }
170
171
    // Get analyzer key for inverted index queries (overridden by VMatchPredicate)
172
0
    [[nodiscard]] virtual const std::string& get_analyzer_key() const {
173
0
        static const std::string empty;
174
0
        return empty;
175
0
    }
176
177
    Status _evaluate_inverted_index(VExprContext* context, const FunctionBasePtr& function,
178
                                    uint32_t segment_num_rows);
179
180
    virtual size_t estimate_memory(const size_t rows);
181
182
    // Only the 4th parameter is used in the runtime filter. In and MinMax need overwrite the
183
    // interface
184
    virtual Status execute_runtime_filter(VExprContext* context, const Block* block, size_t count,
185
0
                                          ColumnPtr& result_column, ColumnPtr* arg_column) const {
186
0
        return execute_column(context, block, count, result_column);
187
0
    };
188
189
    /// Subclasses overriding this function should call VExpr::Close().
190
    //
191
    /// If scope if FRAGMENT_LOCAL, both fragment- and thread-local state should be torn
192
    /// down. Otherwise, if scope is THREAD_LOCAL, only thread-local state should be torn
193
    /// down.
194
    virtual void close(VExprContext* context, FunctionContext::FunctionStateScope scope);
195
196
843k
    DataTypePtr& data_type() { return _data_type; }
197
198
0
    const DataTypePtr& data_type() const { return _data_type; }
199
200
87
    bool is_slot_ref() const { return _node_type == TExprNodeType::SLOT_REF; }
201
202
0
    bool is_virtual_slot_ref() const { return _node_type == TExprNodeType::VIRTUAL_SLOT_REF; }
203
204
0
    bool is_column_ref() const { return _node_type == TExprNodeType::COLUMN_REF; }
205
206
101
    virtual bool is_literal() const { return false; }
207
208
5.03k
    virtual TExprNodeType::type node_type() const { return _node_type; }
209
210
129
    TExprOpcode::type op() const { return _opcode; }
211
212
556
    void add_child(const VExprSPtr& expr) { _children.push_back(expr); }
213
35
    VExprSPtr get_child(uint16_t i) const { return _children[i]; }
214
    // Expr's children number is restricted by org.apache.doris.common.Config#expr_children_limit, 10000 default. and strongly not recommend to change.
215
    // There's little to worry about it. uint16 is enough.
216
109
    uint16_t get_num_children() const { return static_cast<uint16_t>(_children.size()); }
217
218
1.43k
    virtual bool is_rf_wrapper() const {
219
1.43k
        return std::ranges::any_of(_children.begin(), _children.end(),
220
1.43k
                                   [](VExprSPtr child) { return child->is_rf_wrapper(); });
221
1.43k
    }
222
4
    virtual bool is_topn_filter() const { return false; }
223
224
    static Status create_expr_tree(const TExpr& texpr, VExprContextSPtr& ctx);
225
226
    static Status create_expr_trees(const std::vector<TExpr>& texprs, VExprContextSPtrs& ctxs);
227
228
    static Status prepare(const VExprContextSPtrs& ctxs, RuntimeState* state,
229
                          const RowDescriptor& row_desc);
230
231
    static Status open(const VExprContextSPtrs& ctxs, RuntimeState* state);
232
233
    static Status clone_if_not_exists(const VExprContextSPtrs& ctxs, RuntimeState* state,
234
                                      VExprContextSPtrs& new_ctxs);
235
236
96.2k
    static bool contains_blockable_function(const VExprContextSPtrs& ctxs) {
237
96.2k
        return std::any_of(ctxs.begin(), ctxs.end(),
238
96.2k
                           [](const VExprContextSPtr& ctx) { return ctx->root()->is_blockable(); });
239
96.2k
    }
240
241
47
    bool is_nullable() const { return _data_type->is_nullable(); }
242
243
0
    PrimitiveType result_type() const { return _data_type->get_primitive_type(); }
244
245
    static Status create_expr(const TExprNode& expr_node, VExprSPtr& expr);
246
247
    static Status create_tree_from_thrift(const std::vector<TExprNode>& nodes, int* node_idx,
248
                                          VExprSPtr& root_expr, VExprContextSPtr& ctx);
249
250
    static Status check_expr_output_type(const VExprContextSPtrs& ctxs,
251
                                         const RowDescriptor& output_row_desc);
252
5.03k
    virtual const VExprSPtrs& children() const { return _children; }
253
0
    void set_children(const VExprSPtrs& children) { _children = children; }
254
0
    void set_children(VExprSPtrs&& children) { _children = std::move(children); }
255
    virtual std::string debug_string() const;
256
    static std::string debug_string(const VExprSPtrs& exprs);
257
    static std::string debug_string(const VExprContextSPtrs& ctxs);
258
259
0
    bool is_and_expr() const { return _fn.name.function_name == "and"; }
260
0
    bool is_like_expr() const { return _fn.name.function_name == "like"; }
261
262
275
    const TFunction& fn() const { return _fn; }
263
264
    /// Returns true if expr doesn't contain slotrefs, i.e., can be evaluated
265
    /// with get_value(NULL). The default implementation returns true if all of
266
    /// the children are constant.
267
    virtual bool is_constant() const;
268
269
    /// If this expr is constant, evaluates the expr with no input row argument and returns
270
    /// the output. Returns nullptr if the argument is not constant. The returned ColumnPtr is
271
    /// owned by this expr. This should only be called after Open() has been called on this
272
    /// expr.
273
    MOCK_FUNCTION Status get_const_col(VExprContext* context,
274
                                       std::shared_ptr<ColumnPtrWrapper>* column_wrapper);
275
276
26
    int fn_context_index() const { return _fn_context_index; }
277
278
307
    static VExprSPtr expr_without_cast(const VExprSPtr& expr) {
279
307
        if (expr->node_type() == TExprNodeType::CAST_EXPR) {
280
5
            return expr_without_cast(expr->_children[0]);
281
5
        }
282
302
        return expr;
283
307
    }
284
285
    // If this expr is a RuntimeFilterWrapper, this method will return an underlying rf expression
286
0
    virtual VExprSPtr get_impl() const { return {}; }
287
288
    // If this expr is a BloomPredicate, this method will return a BloomFilterFunc
289
0
    virtual std::shared_ptr<BloomFilterFuncBase> get_bloom_filter_func() const {
290
0
        throw Exception(Status::FatalError(
291
0
                "Method 'get_bloom_filter_func()' is not supported in expression: {}",
292
0
                this->debug_string()));
293
0
    }
294
295
10
    virtual std::shared_ptr<HybridSetBase> get_set_func() const { return nullptr; }
296
297
    // If this expr is a BitmapPredicate, this method will return a BitmapFilterFunc
298
0
    virtual std::shared_ptr<BitmapFilterFuncBase> get_bitmap_filter_func() const {
299
0
        throw Exception(Status::FatalError(
300
0
                "Method 'get_bitmap_filter_func()' is not supported in expression: {}",
301
0
                this->debug_string()));
302
0
    }
303
304
    // fast_execute can direct copy expr filter result which build by apply index in segment_iterator
305
    bool fast_execute(VExprContext* context, ColumnPtr& result_column) const;
306
307
0
    virtual bool can_push_down_to_index() const { return false; }
308
    virtual bool equals(const VExpr& other);
309
0
    void set_index_unique_id(uint32_t index_unique_id) { _index_unique_id = index_unique_id; }
310
0
    uint32_t index_unique_id() const { return _index_unique_id; }
311
312
20
    virtual void collect_slot_column_ids(std::set<int>& column_ids) const {
313
24
        for (auto child : _children) {
314
24
            child->collect_slot_column_ids(column_ids);
315
24
        }
316
20
    }
317
318
#ifdef BE_TEST
319
4
    void set_node_type(TExprNodeType::type node_type) { _node_type = node_type; }
320
#endif
321
    virtual Status evaluate_ann_range_search(
322
            const segment_v2::AnnRangeSearchRuntime& runtime,
323
            const std::vector<std::unique_ptr<segment_v2::IndexIterator>>& cid_to_index_iterators,
324
            const std::vector<ColumnId>& idx_to_cid,
325
            const std::vector<std::unique_ptr<segment_v2::ColumnIterator>>& column_iterators,
326
            roaring::Roaring& row_bitmap, segment_v2::AnnIndexStats& ann_index_stats);
327
328
    // Prepare the runtime for ANN range search.
329
    // AnnRangeSearchRuntime is used to store the runtime information of ann range search.
330
    // suitable_for_ann_index is used to indicate whether the current expr can be used for ANN range search.
331
    // If suitable_for_ann_index is false, the we will do exhausted search.
332
    virtual void prepare_ann_range_search(const doris::VectorSearchUserParams& params,
333
                                          segment_v2::AnnRangeSearchRuntime& range_search_runtime,
334
                                          bool& suitable_for_ann_index);
335
336
    bool ann_range_search_executedd();
337
338
    bool ann_dist_is_fulfilled() const;
339
340
    virtual uint64_t get_digest(uint64_t seed) const;
341
342
protected:
343
    /// Simple debug string that provides no expr subclass-specific information
344
0
    std::string debug_string(const std::string& expr_name) const {
345
0
        std::stringstream out;
346
0
        out << expr_name << "(" << VExpr::debug_string() << ")";
347
0
        return out.str();
348
0
    }
349
350
    // used in expr name
351
94
    std::string get_child_names() {
352
94
        std::string res;
353
145
        for (auto child : _children) {
354
145
            if (!res.empty()) {
355
54
                res += ", ";
356
54
            }
357
145
            res += child->expr_name();
358
145
        }
359
94
        return res;
360
94
    }
361
362
    // only for errmsg now
363
0
    std::string get_child_type_names() {
364
0
        std::string res;
365
0
        for (auto child : _children) {
366
0
            if (!res.empty()) {
367
0
                res += ", ";
368
0
            }
369
0
            res += child->expr_name() + ": " + child->data_type()->get_name();
370
0
        }
371
0
        return res;
372
0
    }
373
374
18
    bool is_const_and_have_executed() const {
375
18
        return (is_constant() && (_constant_col != nullptr));
376
18
    }
377
378
    ColumnPtr get_result_from_const(size_t count) const;
379
380
    Status check_constant(const Block& block, ColumnNumbers arguments) const;
381
382
    /// Helper function that calls ctx->register(), sets fn_context_index_, and returns the
383
    /// registered FunctionContext
384
    void register_function_context(RuntimeState* state, VExprContext* context);
385
386
    /// Helper function to initialize function context, called in `open` phase of VExpr:
387
    /// 1. Set constant columns result of function arguments.
388
    /// 2. Call function's prepare() to initialize function state, fragment-local or
389
    /// thread-local according the input `FunctionStateScope` argument.
390
    Status init_function_context(RuntimeState* state, VExprContext* context,
391
                                 FunctionContext::FunctionStateScope scope,
392
                                 const FunctionBasePtr& function) const;
393
394
    /// Helper function to close function context, fragment-local or thread-local according
395
    /// the input `FunctionStateScope` argument. Called in `close` phase of VExpr.
396
    void close_function_context(VExprContext* context, FunctionContext::FunctionStateScope scope,
397
                                const FunctionBasePtr& function) const;
398
399
    TExprNodeType::type _node_type;
400
    // Used to check what opcode
401
    TExprOpcode::type _opcode;
402
    DataTypePtr _data_type;
403
    VExprSPtrs _children; // in few hundreds
404
    TFunction _fn;
405
406
    /// Index to pass to ExprContext::fn_context() to retrieve this expr's FunctionContext.
407
    /// Set in RegisterFunctionContext(). -1 if this expr does not need a FunctionContext and
408
    /// doesn't call RegisterFunctionContext().
409
    int _fn_context_index = -1;
410
411
    // If this expr is constant, this will store and cache the value generated by
412
    // get_const_col()
413
    std::shared_ptr<ColumnPtrWrapper> _constant_col;
414
    bool _prepared = false; // for base class VExpr
415
    // for concrete classes
416
    bool _prepare_finished = false;
417
    bool _open_finished = false;
418
419
    // ensuring uniqueness during index traversal
420
    uint32_t _index_unique_id = 0;
421
    bool _enable_inverted_index_query = true;
422
423
    // Indicates whether the expr row_bitmap has been updated.
424
    bool _has_been_executed = false;
425
    // Indicates whether the virtual column is fulfilled.
426
    // NOTE, if there is no virtual column in the expr tree, and expr
427
    // is evaluated by ann index, this flag is still true.
428
    bool _virtual_column_is_fulfilled = false;
429
};
430
431
} // namespace vectorized
432
433
// NOLINTBEGIN(readability-function-size)
434
template <PrimitiveType T>
435
Status create_texpr_literal_node(const void* data, TExprNode* node, int precision = 0,
436
40
                                 int scale = 0) {
437
40
    if constexpr (T == TYPE_BOOLEAN) {
438
1
        const auto* origin_value = reinterpret_cast<const bool*>(data);
439
1
        TBoolLiteral boolLiteral;
440
1
        (*node).__set_node_type(TExprNodeType::BOOL_LITERAL);
441
1
        boolLiteral.__set_value(*origin_value);
442
1
        (*node).__set_bool_literal(boolLiteral);
443
1
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_BOOLEAN));
444
1
    } else if constexpr (T == TYPE_TINYINT) {
445
0
        const auto* origin_value = reinterpret_cast<const int8_t*>(data);
446
0
        (*node).__set_node_type(TExprNodeType::INT_LITERAL);
447
0
        TIntLiteral intLiteral;
448
0
        intLiteral.__set_value(*origin_value);
449
0
        (*node).__set_int_literal(intLiteral);
450
0
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_TINYINT));
451
1
    } else if constexpr (T == TYPE_SMALLINT) {
452
1
        const auto* origin_value = reinterpret_cast<const int16_t*>(data);
453
1
        (*node).__set_node_type(TExprNodeType::INT_LITERAL);
454
1
        TIntLiteral intLiteral;
455
1
        intLiteral.__set_value(*origin_value);
456
1
        (*node).__set_int_literal(intLiteral);
457
1
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_SMALLINT));
458
6
    } else if constexpr (T == TYPE_INT) {
459
6
        const auto* origin_value = reinterpret_cast<const int32_t*>(data);
460
6
        (*node).__set_node_type(TExprNodeType::INT_LITERAL);
461
6
        TIntLiteral intLiteral;
462
6
        intLiteral.__set_value(*origin_value);
463
6
        (*node).__set_int_literal(intLiteral);
464
6
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_INT));
465
12
    } else if constexpr (T == TYPE_BIGINT) {
466
12
        const auto* origin_value = reinterpret_cast<const int64_t*>(data);
467
12
        (*node).__set_node_type(TExprNodeType::INT_LITERAL);
468
12
        TIntLiteral intLiteral;
469
12
        intLiteral.__set_value(*origin_value);
470
12
        (*node).__set_int_literal(intLiteral);
471
12
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_BIGINT));
472
12
    } else if constexpr (T == TYPE_LARGEINT) {
473
1
        const auto* origin_value = reinterpret_cast<const int128_t*>(data);
474
1
        (*node).__set_node_type(TExprNodeType::LARGE_INT_LITERAL);
475
1
        TLargeIntLiteral large_int_literal;
476
1
        large_int_literal.__set_value(LargeIntValue::to_string(*origin_value));
477
1
        (*node).__set_large_int_literal(large_int_literal);
478
1
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_LARGEINT));
479
2
    } else if constexpr ((T == TYPE_DATE) || (T == TYPE_DATETIME)) {
480
2
        const auto* origin_value = reinterpret_cast<const VecDateTimeValue*>(data);
481
2
        TDateLiteral date_literal;
482
2
        char convert_buffer[30];
483
2
        origin_value->to_string(convert_buffer);
484
2
        date_literal.__set_value(convert_buffer);
485
2
        (*node).__set_date_literal(date_literal);
486
2
        (*node).__set_node_type(TExprNodeType::DATE_LITERAL);
487
2
        if (origin_value->type() == TimeType::TIME_DATE) {
488
1
            (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DATE));
489
1
        } else if (origin_value->type() == TimeType::TIME_DATETIME) {
490
1
            (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DATETIME));
491
1
        }
492
2
    } else if constexpr (T == TYPE_DATEV2) {
493
1
        const auto* origin_value = reinterpret_cast<const DateV2Value<DateV2ValueType>*>(data);
494
1
        TDateLiteral date_literal;
495
1
        char convert_buffer[30];
496
1
        origin_value->to_string(convert_buffer);
497
1
        date_literal.__set_value(convert_buffer);
498
1
        (*node).__set_date_literal(date_literal);
499
1
        (*node).__set_node_type(TExprNodeType::DATE_LITERAL);
500
1
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DATEV2));
501
1
    } else if constexpr (T == TYPE_DATETIMEV2) {
502
1
        const auto* origin_value = reinterpret_cast<const DateV2Value<DateTimeV2ValueType>*>(data);
503
1
        TDateLiteral date_literal;
504
1
        char convert_buffer[30];
505
1
        origin_value->to_string(convert_buffer, scale);
506
1
        date_literal.__set_value(convert_buffer);
507
1
        (*node).__set_date_literal(date_literal);
508
1
        (*node).__set_node_type(TExprNodeType::DATE_LITERAL);
509
1
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DATETIMEV2, precision, scale));
510
2
    } else if constexpr (T == TYPE_TIMESTAMPTZ) {
511
2
        const auto* origin_value = reinterpret_cast<const TimestampTzValue*>(data);
512
2
        TDateLiteral date_literal;
513
2
        auto tz = cctz::utc_time_zone();
514
2
        auto tz_str = origin_value->to_string(tz, scale);
515
2
        date_literal.__set_value(tz_str);
516
2
        (*node).__set_date_literal(date_literal);
517
2
        (*node).__set_node_type(TExprNodeType::DATE_LITERAL);
518
2
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_TIMESTAMPTZ, precision, scale));
519
2
    } else if constexpr (T == TYPE_DECIMALV2) {
520
1
        const auto* origin_value = reinterpret_cast<const DecimalV2Value*>(data);
521
1
        (*node).__set_node_type(TExprNodeType::DECIMAL_LITERAL);
522
1
        TDecimalLiteral decimal_literal;
523
1
        decimal_literal.__set_value(origin_value->to_string());
524
1
        (*node).__set_decimal_literal(decimal_literal);
525
1
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DECIMALV2, precision, scale));
526
2
    } else if constexpr (T == TYPE_DECIMAL32) {
527
2
        const auto* origin_value = reinterpret_cast<const vectorized::Decimal<int32_t>*>(data);
528
2
        (*node).__set_node_type(TExprNodeType::DECIMAL_LITERAL);
529
2
        TDecimalLiteral decimal_literal;
530
2
        decimal_literal.__set_value(origin_value->to_string(precision, scale));
531
2
        (*node).__set_decimal_literal(decimal_literal);
532
2
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DECIMAL32, precision, scale));
533
2
    } else if constexpr (T == TYPE_DECIMAL64) {
534
2
        const auto* origin_value = reinterpret_cast<const vectorized::Decimal<int64_t>*>(data);
535
2
        (*node).__set_node_type(TExprNodeType::DECIMAL_LITERAL);
536
2
        TDecimalLiteral decimal_literal;
537
2
        decimal_literal.__set_value(origin_value->to_string(precision, scale));
538
2
        (*node).__set_decimal_literal(decimal_literal);
539
2
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DECIMAL64, precision, scale));
540
2
    } else if constexpr (T == TYPE_DECIMAL128I) {
541
2
        const auto* origin_value = reinterpret_cast<const vectorized::Decimal<int128_t>*>(data);
542
2
        (*node).__set_node_type(TExprNodeType::DECIMAL_LITERAL);
543
2
        TDecimalLiteral decimal_literal;
544
        // e.g. For a decimal(26,6) column, the initial value of the _min of the MinMax RF
545
        // on the RF producer side is an int128 value with 38 digits of 9, and this is the
546
        // final min value of the MinMax RF if the fragment instance has no data.
547
        // Need to truncate the value to the right precision and scale here, to avoid
548
        // error when casting string back to decimal later.
549
        // TODO: this is a temporary solution, the best solution is to produce the
550
        // right min max value at the producer side.
551
2
        decimal_literal.__set_value(origin_value->to_string(precision, scale));
552
2
        (*node).__set_decimal_literal(decimal_literal);
553
2
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DECIMAL128I, precision, scale));
554
2
    } else if constexpr (T == TYPE_DECIMAL256) {
555
2
        const auto* origin_value = reinterpret_cast<const vectorized::Decimal<wide::Int256>*>(data);
556
2
        (*node).__set_node_type(TExprNodeType::DECIMAL_LITERAL);
557
2
        TDecimalLiteral decimal_literal;
558
2
        decimal_literal.__set_value(origin_value->to_string(precision, scale));
559
2
        (*node).__set_decimal_literal(decimal_literal);
560
2
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DECIMAL256, precision, scale));
561
2
    } else if constexpr (T == TYPE_FLOAT) {
562
1
        const auto* origin_value = reinterpret_cast<const float*>(data);
563
1
        (*node).__set_node_type(TExprNodeType::FLOAT_LITERAL);
564
1
        TFloatLiteral float_literal;
565
1
        float_literal.__set_value(*origin_value);
566
1
        (*node).__set_float_literal(float_literal);
567
1
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_FLOAT));
568
1
    } else if constexpr (T == TYPE_DOUBLE) {
569
1
        const auto* origin_value = reinterpret_cast<const double*>(data);
570
1
        (*node).__set_node_type(TExprNodeType::FLOAT_LITERAL);
571
1
        TFloatLiteral float_literal;
572
1
        float_literal.__set_value(*origin_value);
573
1
        (*node).__set_float_literal(float_literal);
574
1
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DOUBLE));
575
1
    } else if constexpr ((T == TYPE_STRING) || (T == TYPE_CHAR) || (T == TYPE_VARCHAR)) {
576
1
        const auto* origin_value = reinterpret_cast<const std::string*>(data);
577
1
        (*node).__set_node_type(TExprNodeType::STRING_LITERAL);
578
1
        TStringLiteral string_literal;
579
1
        string_literal.__set_value(*origin_value);
580
1
        (*node).__set_string_literal(string_literal);
581
1
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_STRING));
582
1
    } else if constexpr (T == TYPE_IPV4) {
583
0
        const auto* origin_value = reinterpret_cast<const IPv4*>(data);
584
0
        (*node).__set_node_type(TExprNodeType::IPV4_LITERAL);
585
0
        TIPv4Literal literal;
586
0
        literal.__set_value(*origin_value);
587
0
        (*node).__set_ipv4_literal(literal);
588
0
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_IPV4));
589
0
    } else if constexpr (T == TYPE_IPV6) {
590
0
        const auto* origin_value = reinterpret_cast<const IPv6*>(data);
591
0
        (*node).__set_node_type(TExprNodeType::IPV6_LITERAL);
592
0
        TIPv6Literal literal;
593
0
        literal.__set_value(vectorized::CastToString::from_ip(*origin_value));
594
0
        (*node).__set_ipv6_literal(literal);
595
0
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_IPV6));
596
1
    } else if constexpr (T == TYPE_TIMEV2) {
597
        // the code use for runtime filter but we dont support timev2 as predicate now
598
        // so this part not used
599
1
        const auto* origin_value = reinterpret_cast<const double*>(data);
600
1
        TTimeV2Literal timev2_literal;
601
1
        timev2_literal.__set_value(*origin_value);
602
1
        (*node).__set_timev2_literal(timev2_literal);
603
1
        (*node).__set_node_type(TExprNodeType::TIMEV2_LITERAL);
604
1
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_TIMEV2, precision, scale));
605
1
    } else if constexpr (T == TYPE_VARBINARY) {
606
0
        const auto* origin_value = reinterpret_cast<const std::string*>(data);
607
0
        (*node).__set_node_type(TExprNodeType::VARBINARY_LITERAL);
608
0
        TVarBinaryLiteral varbinary_literal;
609
0
        varbinary_literal.__set_value(*origin_value);
610
0
        (*node).__set_varbinary_literal(varbinary_literal);
611
0
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_VARBINARY));
612
    } else {
613
        return Status::InvalidArgument("Invalid argument type!");
614
    }
615
40
    return Status::OK();
616
40
}
_ZN5doris25create_texpr_literal_nodeILNS_13PrimitiveTypeE2EEENS_6StatusEPKvPNS_9TExprNodeEii
Line
Count
Source
436
1
                                 int scale = 0) {
437
1
    if constexpr (T == TYPE_BOOLEAN) {
438
1
        const auto* origin_value = reinterpret_cast<const bool*>(data);
439
1
        TBoolLiteral boolLiteral;
440
1
        (*node).__set_node_type(TExprNodeType::BOOL_LITERAL);
441
1
        boolLiteral.__set_value(*origin_value);
442
1
        (*node).__set_bool_literal(boolLiteral);
443
1
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_BOOLEAN));
444
    } else if constexpr (T == TYPE_TINYINT) {
445
        const auto* origin_value = reinterpret_cast<const int8_t*>(data);
446
        (*node).__set_node_type(TExprNodeType::INT_LITERAL);
447
        TIntLiteral intLiteral;
448
        intLiteral.__set_value(*origin_value);
449
        (*node).__set_int_literal(intLiteral);
450
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_TINYINT));
451
    } else if constexpr (T == TYPE_SMALLINT) {
452
        const auto* origin_value = reinterpret_cast<const int16_t*>(data);
453
        (*node).__set_node_type(TExprNodeType::INT_LITERAL);
454
        TIntLiteral intLiteral;
455
        intLiteral.__set_value(*origin_value);
456
        (*node).__set_int_literal(intLiteral);
457
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_SMALLINT));
458
    } else if constexpr (T == TYPE_INT) {
459
        const auto* origin_value = reinterpret_cast<const int32_t*>(data);
460
        (*node).__set_node_type(TExprNodeType::INT_LITERAL);
461
        TIntLiteral intLiteral;
462
        intLiteral.__set_value(*origin_value);
463
        (*node).__set_int_literal(intLiteral);
464
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_INT));
465
    } else if constexpr (T == TYPE_BIGINT) {
466
        const auto* origin_value = reinterpret_cast<const int64_t*>(data);
467
        (*node).__set_node_type(TExprNodeType::INT_LITERAL);
468
        TIntLiteral intLiteral;
469
        intLiteral.__set_value(*origin_value);
470
        (*node).__set_int_literal(intLiteral);
471
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_BIGINT));
472
    } else if constexpr (T == TYPE_LARGEINT) {
473
        const auto* origin_value = reinterpret_cast<const int128_t*>(data);
474
        (*node).__set_node_type(TExprNodeType::LARGE_INT_LITERAL);
475
        TLargeIntLiteral large_int_literal;
476
        large_int_literal.__set_value(LargeIntValue::to_string(*origin_value));
477
        (*node).__set_large_int_literal(large_int_literal);
478
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_LARGEINT));
479
    } else if constexpr ((T == TYPE_DATE) || (T == TYPE_DATETIME)) {
480
        const auto* origin_value = reinterpret_cast<const VecDateTimeValue*>(data);
481
        TDateLiteral date_literal;
482
        char convert_buffer[30];
483
        origin_value->to_string(convert_buffer);
484
        date_literal.__set_value(convert_buffer);
485
        (*node).__set_date_literal(date_literal);
486
        (*node).__set_node_type(TExprNodeType::DATE_LITERAL);
487
        if (origin_value->type() == TimeType::TIME_DATE) {
488
            (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DATE));
489
        } else if (origin_value->type() == TimeType::TIME_DATETIME) {
490
            (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DATETIME));
491
        }
492
    } else if constexpr (T == TYPE_DATEV2) {
493
        const auto* origin_value = reinterpret_cast<const DateV2Value<DateV2ValueType>*>(data);
494
        TDateLiteral date_literal;
495
        char convert_buffer[30];
496
        origin_value->to_string(convert_buffer);
497
        date_literal.__set_value(convert_buffer);
498
        (*node).__set_date_literal(date_literal);
499
        (*node).__set_node_type(TExprNodeType::DATE_LITERAL);
500
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DATEV2));
501
    } else if constexpr (T == TYPE_DATETIMEV2) {
502
        const auto* origin_value = reinterpret_cast<const DateV2Value<DateTimeV2ValueType>*>(data);
503
        TDateLiteral date_literal;
504
        char convert_buffer[30];
505
        origin_value->to_string(convert_buffer, scale);
506
        date_literal.__set_value(convert_buffer);
507
        (*node).__set_date_literal(date_literal);
508
        (*node).__set_node_type(TExprNodeType::DATE_LITERAL);
509
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DATETIMEV2, precision, scale));
510
    } else if constexpr (T == TYPE_TIMESTAMPTZ) {
511
        const auto* origin_value = reinterpret_cast<const TimestampTzValue*>(data);
512
        TDateLiteral date_literal;
513
        auto tz = cctz::utc_time_zone();
514
        auto tz_str = origin_value->to_string(tz, scale);
515
        date_literal.__set_value(tz_str);
516
        (*node).__set_date_literal(date_literal);
517
        (*node).__set_node_type(TExprNodeType::DATE_LITERAL);
518
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_TIMESTAMPTZ, precision, scale));
519
    } else if constexpr (T == TYPE_DECIMALV2) {
520
        const auto* origin_value = reinterpret_cast<const DecimalV2Value*>(data);
521
        (*node).__set_node_type(TExprNodeType::DECIMAL_LITERAL);
522
        TDecimalLiteral decimal_literal;
523
        decimal_literal.__set_value(origin_value->to_string());
524
        (*node).__set_decimal_literal(decimal_literal);
525
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DECIMALV2, precision, scale));
526
    } else if constexpr (T == TYPE_DECIMAL32) {
527
        const auto* origin_value = reinterpret_cast<const vectorized::Decimal<int32_t>*>(data);
528
        (*node).__set_node_type(TExprNodeType::DECIMAL_LITERAL);
529
        TDecimalLiteral decimal_literal;
530
        decimal_literal.__set_value(origin_value->to_string(precision, scale));
531
        (*node).__set_decimal_literal(decimal_literal);
532
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DECIMAL32, precision, scale));
533
    } else if constexpr (T == TYPE_DECIMAL64) {
534
        const auto* origin_value = reinterpret_cast<const vectorized::Decimal<int64_t>*>(data);
535
        (*node).__set_node_type(TExprNodeType::DECIMAL_LITERAL);
536
        TDecimalLiteral decimal_literal;
537
        decimal_literal.__set_value(origin_value->to_string(precision, scale));
538
        (*node).__set_decimal_literal(decimal_literal);
539
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DECIMAL64, precision, scale));
540
    } else if constexpr (T == TYPE_DECIMAL128I) {
541
        const auto* origin_value = reinterpret_cast<const vectorized::Decimal<int128_t>*>(data);
542
        (*node).__set_node_type(TExprNodeType::DECIMAL_LITERAL);
543
        TDecimalLiteral decimal_literal;
544
        // e.g. For a decimal(26,6) column, the initial value of the _min of the MinMax RF
545
        // on the RF producer side is an int128 value with 38 digits of 9, and this is the
546
        // final min value of the MinMax RF if the fragment instance has no data.
547
        // Need to truncate the value to the right precision and scale here, to avoid
548
        // error when casting string back to decimal later.
549
        // TODO: this is a temporary solution, the best solution is to produce the
550
        // right min max value at the producer side.
551
        decimal_literal.__set_value(origin_value->to_string(precision, scale));
552
        (*node).__set_decimal_literal(decimal_literal);
553
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DECIMAL128I, precision, scale));
554
    } else if constexpr (T == TYPE_DECIMAL256) {
555
        const auto* origin_value = reinterpret_cast<const vectorized::Decimal<wide::Int256>*>(data);
556
        (*node).__set_node_type(TExprNodeType::DECIMAL_LITERAL);
557
        TDecimalLiteral decimal_literal;
558
        decimal_literal.__set_value(origin_value->to_string(precision, scale));
559
        (*node).__set_decimal_literal(decimal_literal);
560
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DECIMAL256, precision, scale));
561
    } else if constexpr (T == TYPE_FLOAT) {
562
        const auto* origin_value = reinterpret_cast<const float*>(data);
563
        (*node).__set_node_type(TExprNodeType::FLOAT_LITERAL);
564
        TFloatLiteral float_literal;
565
        float_literal.__set_value(*origin_value);
566
        (*node).__set_float_literal(float_literal);
567
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_FLOAT));
568
    } else if constexpr (T == TYPE_DOUBLE) {
569
        const auto* origin_value = reinterpret_cast<const double*>(data);
570
        (*node).__set_node_type(TExprNodeType::FLOAT_LITERAL);
571
        TFloatLiteral float_literal;
572
        float_literal.__set_value(*origin_value);
573
        (*node).__set_float_literal(float_literal);
574
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DOUBLE));
575
    } else if constexpr ((T == TYPE_STRING) || (T == TYPE_CHAR) || (T == TYPE_VARCHAR)) {
576
        const auto* origin_value = reinterpret_cast<const std::string*>(data);
577
        (*node).__set_node_type(TExprNodeType::STRING_LITERAL);
578
        TStringLiteral string_literal;
579
        string_literal.__set_value(*origin_value);
580
        (*node).__set_string_literal(string_literal);
581
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_STRING));
582
    } else if constexpr (T == TYPE_IPV4) {
583
        const auto* origin_value = reinterpret_cast<const IPv4*>(data);
584
        (*node).__set_node_type(TExprNodeType::IPV4_LITERAL);
585
        TIPv4Literal literal;
586
        literal.__set_value(*origin_value);
587
        (*node).__set_ipv4_literal(literal);
588
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_IPV4));
589
    } else if constexpr (T == TYPE_IPV6) {
590
        const auto* origin_value = reinterpret_cast<const IPv6*>(data);
591
        (*node).__set_node_type(TExprNodeType::IPV6_LITERAL);
592
        TIPv6Literal literal;
593
        literal.__set_value(vectorized::CastToString::from_ip(*origin_value));
594
        (*node).__set_ipv6_literal(literal);
595
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_IPV6));
596
    } else if constexpr (T == TYPE_TIMEV2) {
597
        // the code use for runtime filter but we dont support timev2 as predicate now
598
        // so this part not used
599
        const auto* origin_value = reinterpret_cast<const double*>(data);
600
        TTimeV2Literal timev2_literal;
601
        timev2_literal.__set_value(*origin_value);
602
        (*node).__set_timev2_literal(timev2_literal);
603
        (*node).__set_node_type(TExprNodeType::TIMEV2_LITERAL);
604
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_TIMEV2, precision, scale));
605
    } else if constexpr (T == TYPE_VARBINARY) {
606
        const auto* origin_value = reinterpret_cast<const std::string*>(data);
607
        (*node).__set_node_type(TExprNodeType::VARBINARY_LITERAL);
608
        TVarBinaryLiteral varbinary_literal;
609
        varbinary_literal.__set_value(*origin_value);
610
        (*node).__set_varbinary_literal(varbinary_literal);
611
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_VARBINARY));
612
    } else {
613
        return Status::InvalidArgument("Invalid argument type!");
614
    }
615
1
    return Status::OK();
616
1
}
Unexecuted instantiation: _ZN5doris25create_texpr_literal_nodeILNS_13PrimitiveTypeE3EEENS_6StatusEPKvPNS_9TExprNodeEii
_ZN5doris25create_texpr_literal_nodeILNS_13PrimitiveTypeE4EEENS_6StatusEPKvPNS_9TExprNodeEii
Line
Count
Source
436
1
                                 int scale = 0) {
437
    if constexpr (T == TYPE_BOOLEAN) {
438
        const auto* origin_value = reinterpret_cast<const bool*>(data);
439
        TBoolLiteral boolLiteral;
440
        (*node).__set_node_type(TExprNodeType::BOOL_LITERAL);
441
        boolLiteral.__set_value(*origin_value);
442
        (*node).__set_bool_literal(boolLiteral);
443
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_BOOLEAN));
444
    } else if constexpr (T == TYPE_TINYINT) {
445
        const auto* origin_value = reinterpret_cast<const int8_t*>(data);
446
        (*node).__set_node_type(TExprNodeType::INT_LITERAL);
447
        TIntLiteral intLiteral;
448
        intLiteral.__set_value(*origin_value);
449
        (*node).__set_int_literal(intLiteral);
450
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_TINYINT));
451
1
    } else if constexpr (T == TYPE_SMALLINT) {
452
1
        const auto* origin_value = reinterpret_cast<const int16_t*>(data);
453
1
        (*node).__set_node_type(TExprNodeType::INT_LITERAL);
454
1
        TIntLiteral intLiteral;
455
1
        intLiteral.__set_value(*origin_value);
456
1
        (*node).__set_int_literal(intLiteral);
457
1
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_SMALLINT));
458
    } else if constexpr (T == TYPE_INT) {
459
        const auto* origin_value = reinterpret_cast<const int32_t*>(data);
460
        (*node).__set_node_type(TExprNodeType::INT_LITERAL);
461
        TIntLiteral intLiteral;
462
        intLiteral.__set_value(*origin_value);
463
        (*node).__set_int_literal(intLiteral);
464
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_INT));
465
    } else if constexpr (T == TYPE_BIGINT) {
466
        const auto* origin_value = reinterpret_cast<const int64_t*>(data);
467
        (*node).__set_node_type(TExprNodeType::INT_LITERAL);
468
        TIntLiteral intLiteral;
469
        intLiteral.__set_value(*origin_value);
470
        (*node).__set_int_literal(intLiteral);
471
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_BIGINT));
472
    } else if constexpr (T == TYPE_LARGEINT) {
473
        const auto* origin_value = reinterpret_cast<const int128_t*>(data);
474
        (*node).__set_node_type(TExprNodeType::LARGE_INT_LITERAL);
475
        TLargeIntLiteral large_int_literal;
476
        large_int_literal.__set_value(LargeIntValue::to_string(*origin_value));
477
        (*node).__set_large_int_literal(large_int_literal);
478
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_LARGEINT));
479
    } else if constexpr ((T == TYPE_DATE) || (T == TYPE_DATETIME)) {
480
        const auto* origin_value = reinterpret_cast<const VecDateTimeValue*>(data);
481
        TDateLiteral date_literal;
482
        char convert_buffer[30];
483
        origin_value->to_string(convert_buffer);
484
        date_literal.__set_value(convert_buffer);
485
        (*node).__set_date_literal(date_literal);
486
        (*node).__set_node_type(TExprNodeType::DATE_LITERAL);
487
        if (origin_value->type() == TimeType::TIME_DATE) {
488
            (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DATE));
489
        } else if (origin_value->type() == TimeType::TIME_DATETIME) {
490
            (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DATETIME));
491
        }
492
    } else if constexpr (T == TYPE_DATEV2) {
493
        const auto* origin_value = reinterpret_cast<const DateV2Value<DateV2ValueType>*>(data);
494
        TDateLiteral date_literal;
495
        char convert_buffer[30];
496
        origin_value->to_string(convert_buffer);
497
        date_literal.__set_value(convert_buffer);
498
        (*node).__set_date_literal(date_literal);
499
        (*node).__set_node_type(TExprNodeType::DATE_LITERAL);
500
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DATEV2));
501
    } else if constexpr (T == TYPE_DATETIMEV2) {
502
        const auto* origin_value = reinterpret_cast<const DateV2Value<DateTimeV2ValueType>*>(data);
503
        TDateLiteral date_literal;
504
        char convert_buffer[30];
505
        origin_value->to_string(convert_buffer, scale);
506
        date_literal.__set_value(convert_buffer);
507
        (*node).__set_date_literal(date_literal);
508
        (*node).__set_node_type(TExprNodeType::DATE_LITERAL);
509
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DATETIMEV2, precision, scale));
510
    } else if constexpr (T == TYPE_TIMESTAMPTZ) {
511
        const auto* origin_value = reinterpret_cast<const TimestampTzValue*>(data);
512
        TDateLiteral date_literal;
513
        auto tz = cctz::utc_time_zone();
514
        auto tz_str = origin_value->to_string(tz, scale);
515
        date_literal.__set_value(tz_str);
516
        (*node).__set_date_literal(date_literal);
517
        (*node).__set_node_type(TExprNodeType::DATE_LITERAL);
518
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_TIMESTAMPTZ, precision, scale));
519
    } else if constexpr (T == TYPE_DECIMALV2) {
520
        const auto* origin_value = reinterpret_cast<const DecimalV2Value*>(data);
521
        (*node).__set_node_type(TExprNodeType::DECIMAL_LITERAL);
522
        TDecimalLiteral decimal_literal;
523
        decimal_literal.__set_value(origin_value->to_string());
524
        (*node).__set_decimal_literal(decimal_literal);
525
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DECIMALV2, precision, scale));
526
    } else if constexpr (T == TYPE_DECIMAL32) {
527
        const auto* origin_value = reinterpret_cast<const vectorized::Decimal<int32_t>*>(data);
528
        (*node).__set_node_type(TExprNodeType::DECIMAL_LITERAL);
529
        TDecimalLiteral decimal_literal;
530
        decimal_literal.__set_value(origin_value->to_string(precision, scale));
531
        (*node).__set_decimal_literal(decimal_literal);
532
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DECIMAL32, precision, scale));
533
    } else if constexpr (T == TYPE_DECIMAL64) {
534
        const auto* origin_value = reinterpret_cast<const vectorized::Decimal<int64_t>*>(data);
535
        (*node).__set_node_type(TExprNodeType::DECIMAL_LITERAL);
536
        TDecimalLiteral decimal_literal;
537
        decimal_literal.__set_value(origin_value->to_string(precision, scale));
538
        (*node).__set_decimal_literal(decimal_literal);
539
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DECIMAL64, precision, scale));
540
    } else if constexpr (T == TYPE_DECIMAL128I) {
541
        const auto* origin_value = reinterpret_cast<const vectorized::Decimal<int128_t>*>(data);
542
        (*node).__set_node_type(TExprNodeType::DECIMAL_LITERAL);
543
        TDecimalLiteral decimal_literal;
544
        // e.g. For a decimal(26,6) column, the initial value of the _min of the MinMax RF
545
        // on the RF producer side is an int128 value with 38 digits of 9, and this is the
546
        // final min value of the MinMax RF if the fragment instance has no data.
547
        // Need to truncate the value to the right precision and scale here, to avoid
548
        // error when casting string back to decimal later.
549
        // TODO: this is a temporary solution, the best solution is to produce the
550
        // right min max value at the producer side.
551
        decimal_literal.__set_value(origin_value->to_string(precision, scale));
552
        (*node).__set_decimal_literal(decimal_literal);
553
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DECIMAL128I, precision, scale));
554
    } else if constexpr (T == TYPE_DECIMAL256) {
555
        const auto* origin_value = reinterpret_cast<const vectorized::Decimal<wide::Int256>*>(data);
556
        (*node).__set_node_type(TExprNodeType::DECIMAL_LITERAL);
557
        TDecimalLiteral decimal_literal;
558
        decimal_literal.__set_value(origin_value->to_string(precision, scale));
559
        (*node).__set_decimal_literal(decimal_literal);
560
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DECIMAL256, precision, scale));
561
    } else if constexpr (T == TYPE_FLOAT) {
562
        const auto* origin_value = reinterpret_cast<const float*>(data);
563
        (*node).__set_node_type(TExprNodeType::FLOAT_LITERAL);
564
        TFloatLiteral float_literal;
565
        float_literal.__set_value(*origin_value);
566
        (*node).__set_float_literal(float_literal);
567
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_FLOAT));
568
    } else if constexpr (T == TYPE_DOUBLE) {
569
        const auto* origin_value = reinterpret_cast<const double*>(data);
570
        (*node).__set_node_type(TExprNodeType::FLOAT_LITERAL);
571
        TFloatLiteral float_literal;
572
        float_literal.__set_value(*origin_value);
573
        (*node).__set_float_literal(float_literal);
574
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DOUBLE));
575
    } else if constexpr ((T == TYPE_STRING) || (T == TYPE_CHAR) || (T == TYPE_VARCHAR)) {
576
        const auto* origin_value = reinterpret_cast<const std::string*>(data);
577
        (*node).__set_node_type(TExprNodeType::STRING_LITERAL);
578
        TStringLiteral string_literal;
579
        string_literal.__set_value(*origin_value);
580
        (*node).__set_string_literal(string_literal);
581
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_STRING));
582
    } else if constexpr (T == TYPE_IPV4) {
583
        const auto* origin_value = reinterpret_cast<const IPv4*>(data);
584
        (*node).__set_node_type(TExprNodeType::IPV4_LITERAL);
585
        TIPv4Literal literal;
586
        literal.__set_value(*origin_value);
587
        (*node).__set_ipv4_literal(literal);
588
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_IPV4));
589
    } else if constexpr (T == TYPE_IPV6) {
590
        const auto* origin_value = reinterpret_cast<const IPv6*>(data);
591
        (*node).__set_node_type(TExprNodeType::IPV6_LITERAL);
592
        TIPv6Literal literal;
593
        literal.__set_value(vectorized::CastToString::from_ip(*origin_value));
594
        (*node).__set_ipv6_literal(literal);
595
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_IPV6));
596
    } else if constexpr (T == TYPE_TIMEV2) {
597
        // the code use for runtime filter but we dont support timev2 as predicate now
598
        // so this part not used
599
        const auto* origin_value = reinterpret_cast<const double*>(data);
600
        TTimeV2Literal timev2_literal;
601
        timev2_literal.__set_value(*origin_value);
602
        (*node).__set_timev2_literal(timev2_literal);
603
        (*node).__set_node_type(TExprNodeType::TIMEV2_LITERAL);
604
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_TIMEV2, precision, scale));
605
    } else if constexpr (T == TYPE_VARBINARY) {
606
        const auto* origin_value = reinterpret_cast<const std::string*>(data);
607
        (*node).__set_node_type(TExprNodeType::VARBINARY_LITERAL);
608
        TVarBinaryLiteral varbinary_literal;
609
        varbinary_literal.__set_value(*origin_value);
610
        (*node).__set_varbinary_literal(varbinary_literal);
611
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_VARBINARY));
612
    } else {
613
        return Status::InvalidArgument("Invalid argument type!");
614
    }
615
1
    return Status::OK();
616
1
}
_ZN5doris25create_texpr_literal_nodeILNS_13PrimitiveTypeE5EEENS_6StatusEPKvPNS_9TExprNodeEii
Line
Count
Source
436
6
                                 int scale = 0) {
437
    if constexpr (T == TYPE_BOOLEAN) {
438
        const auto* origin_value = reinterpret_cast<const bool*>(data);
439
        TBoolLiteral boolLiteral;
440
        (*node).__set_node_type(TExprNodeType::BOOL_LITERAL);
441
        boolLiteral.__set_value(*origin_value);
442
        (*node).__set_bool_literal(boolLiteral);
443
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_BOOLEAN));
444
    } else if constexpr (T == TYPE_TINYINT) {
445
        const auto* origin_value = reinterpret_cast<const int8_t*>(data);
446
        (*node).__set_node_type(TExprNodeType::INT_LITERAL);
447
        TIntLiteral intLiteral;
448
        intLiteral.__set_value(*origin_value);
449
        (*node).__set_int_literal(intLiteral);
450
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_TINYINT));
451
    } else if constexpr (T == TYPE_SMALLINT) {
452
        const auto* origin_value = reinterpret_cast<const int16_t*>(data);
453
        (*node).__set_node_type(TExprNodeType::INT_LITERAL);
454
        TIntLiteral intLiteral;
455
        intLiteral.__set_value(*origin_value);
456
        (*node).__set_int_literal(intLiteral);
457
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_SMALLINT));
458
6
    } else if constexpr (T == TYPE_INT) {
459
6
        const auto* origin_value = reinterpret_cast<const int32_t*>(data);
460
6
        (*node).__set_node_type(TExprNodeType::INT_LITERAL);
461
6
        TIntLiteral intLiteral;
462
6
        intLiteral.__set_value(*origin_value);
463
6
        (*node).__set_int_literal(intLiteral);
464
6
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_INT));
465
    } else if constexpr (T == TYPE_BIGINT) {
466
        const auto* origin_value = reinterpret_cast<const int64_t*>(data);
467
        (*node).__set_node_type(TExprNodeType::INT_LITERAL);
468
        TIntLiteral intLiteral;
469
        intLiteral.__set_value(*origin_value);
470
        (*node).__set_int_literal(intLiteral);
471
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_BIGINT));
472
    } else if constexpr (T == TYPE_LARGEINT) {
473
        const auto* origin_value = reinterpret_cast<const int128_t*>(data);
474
        (*node).__set_node_type(TExprNodeType::LARGE_INT_LITERAL);
475
        TLargeIntLiteral large_int_literal;
476
        large_int_literal.__set_value(LargeIntValue::to_string(*origin_value));
477
        (*node).__set_large_int_literal(large_int_literal);
478
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_LARGEINT));
479
    } else if constexpr ((T == TYPE_DATE) || (T == TYPE_DATETIME)) {
480
        const auto* origin_value = reinterpret_cast<const VecDateTimeValue*>(data);
481
        TDateLiteral date_literal;
482
        char convert_buffer[30];
483
        origin_value->to_string(convert_buffer);
484
        date_literal.__set_value(convert_buffer);
485
        (*node).__set_date_literal(date_literal);
486
        (*node).__set_node_type(TExprNodeType::DATE_LITERAL);
487
        if (origin_value->type() == TimeType::TIME_DATE) {
488
            (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DATE));
489
        } else if (origin_value->type() == TimeType::TIME_DATETIME) {
490
            (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DATETIME));
491
        }
492
    } else if constexpr (T == TYPE_DATEV2) {
493
        const auto* origin_value = reinterpret_cast<const DateV2Value<DateV2ValueType>*>(data);
494
        TDateLiteral date_literal;
495
        char convert_buffer[30];
496
        origin_value->to_string(convert_buffer);
497
        date_literal.__set_value(convert_buffer);
498
        (*node).__set_date_literal(date_literal);
499
        (*node).__set_node_type(TExprNodeType::DATE_LITERAL);
500
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DATEV2));
501
    } else if constexpr (T == TYPE_DATETIMEV2) {
502
        const auto* origin_value = reinterpret_cast<const DateV2Value<DateTimeV2ValueType>*>(data);
503
        TDateLiteral date_literal;
504
        char convert_buffer[30];
505
        origin_value->to_string(convert_buffer, scale);
506
        date_literal.__set_value(convert_buffer);
507
        (*node).__set_date_literal(date_literal);
508
        (*node).__set_node_type(TExprNodeType::DATE_LITERAL);
509
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DATETIMEV2, precision, scale));
510
    } else if constexpr (T == TYPE_TIMESTAMPTZ) {
511
        const auto* origin_value = reinterpret_cast<const TimestampTzValue*>(data);
512
        TDateLiteral date_literal;
513
        auto tz = cctz::utc_time_zone();
514
        auto tz_str = origin_value->to_string(tz, scale);
515
        date_literal.__set_value(tz_str);
516
        (*node).__set_date_literal(date_literal);
517
        (*node).__set_node_type(TExprNodeType::DATE_LITERAL);
518
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_TIMESTAMPTZ, precision, scale));
519
    } else if constexpr (T == TYPE_DECIMALV2) {
520
        const auto* origin_value = reinterpret_cast<const DecimalV2Value*>(data);
521
        (*node).__set_node_type(TExprNodeType::DECIMAL_LITERAL);
522
        TDecimalLiteral decimal_literal;
523
        decimal_literal.__set_value(origin_value->to_string());
524
        (*node).__set_decimal_literal(decimal_literal);
525
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DECIMALV2, precision, scale));
526
    } else if constexpr (T == TYPE_DECIMAL32) {
527
        const auto* origin_value = reinterpret_cast<const vectorized::Decimal<int32_t>*>(data);
528
        (*node).__set_node_type(TExprNodeType::DECIMAL_LITERAL);
529
        TDecimalLiteral decimal_literal;
530
        decimal_literal.__set_value(origin_value->to_string(precision, scale));
531
        (*node).__set_decimal_literal(decimal_literal);
532
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DECIMAL32, precision, scale));
533
    } else if constexpr (T == TYPE_DECIMAL64) {
534
        const auto* origin_value = reinterpret_cast<const vectorized::Decimal<int64_t>*>(data);
535
        (*node).__set_node_type(TExprNodeType::DECIMAL_LITERAL);
536
        TDecimalLiteral decimal_literal;
537
        decimal_literal.__set_value(origin_value->to_string(precision, scale));
538
        (*node).__set_decimal_literal(decimal_literal);
539
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DECIMAL64, precision, scale));
540
    } else if constexpr (T == TYPE_DECIMAL128I) {
541
        const auto* origin_value = reinterpret_cast<const vectorized::Decimal<int128_t>*>(data);
542
        (*node).__set_node_type(TExprNodeType::DECIMAL_LITERAL);
543
        TDecimalLiteral decimal_literal;
544
        // e.g. For a decimal(26,6) column, the initial value of the _min of the MinMax RF
545
        // on the RF producer side is an int128 value with 38 digits of 9, and this is the
546
        // final min value of the MinMax RF if the fragment instance has no data.
547
        // Need to truncate the value to the right precision and scale here, to avoid
548
        // error when casting string back to decimal later.
549
        // TODO: this is a temporary solution, the best solution is to produce the
550
        // right min max value at the producer side.
551
        decimal_literal.__set_value(origin_value->to_string(precision, scale));
552
        (*node).__set_decimal_literal(decimal_literal);
553
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DECIMAL128I, precision, scale));
554
    } else if constexpr (T == TYPE_DECIMAL256) {
555
        const auto* origin_value = reinterpret_cast<const vectorized::Decimal<wide::Int256>*>(data);
556
        (*node).__set_node_type(TExprNodeType::DECIMAL_LITERAL);
557
        TDecimalLiteral decimal_literal;
558
        decimal_literal.__set_value(origin_value->to_string(precision, scale));
559
        (*node).__set_decimal_literal(decimal_literal);
560
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DECIMAL256, precision, scale));
561
    } else if constexpr (T == TYPE_FLOAT) {
562
        const auto* origin_value = reinterpret_cast<const float*>(data);
563
        (*node).__set_node_type(TExprNodeType::FLOAT_LITERAL);
564
        TFloatLiteral float_literal;
565
        float_literal.__set_value(*origin_value);
566
        (*node).__set_float_literal(float_literal);
567
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_FLOAT));
568
    } else if constexpr (T == TYPE_DOUBLE) {
569
        const auto* origin_value = reinterpret_cast<const double*>(data);
570
        (*node).__set_node_type(TExprNodeType::FLOAT_LITERAL);
571
        TFloatLiteral float_literal;
572
        float_literal.__set_value(*origin_value);
573
        (*node).__set_float_literal(float_literal);
574
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DOUBLE));
575
    } else if constexpr ((T == TYPE_STRING) || (T == TYPE_CHAR) || (T == TYPE_VARCHAR)) {
576
        const auto* origin_value = reinterpret_cast<const std::string*>(data);
577
        (*node).__set_node_type(TExprNodeType::STRING_LITERAL);
578
        TStringLiteral string_literal;
579
        string_literal.__set_value(*origin_value);
580
        (*node).__set_string_literal(string_literal);
581
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_STRING));
582
    } else if constexpr (T == TYPE_IPV4) {
583
        const auto* origin_value = reinterpret_cast<const IPv4*>(data);
584
        (*node).__set_node_type(TExprNodeType::IPV4_LITERAL);
585
        TIPv4Literal literal;
586
        literal.__set_value(*origin_value);
587
        (*node).__set_ipv4_literal(literal);
588
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_IPV4));
589
    } else if constexpr (T == TYPE_IPV6) {
590
        const auto* origin_value = reinterpret_cast<const IPv6*>(data);
591
        (*node).__set_node_type(TExprNodeType::IPV6_LITERAL);
592
        TIPv6Literal literal;
593
        literal.__set_value(vectorized::CastToString::from_ip(*origin_value));
594
        (*node).__set_ipv6_literal(literal);
595
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_IPV6));
596
    } else if constexpr (T == TYPE_TIMEV2) {
597
        // the code use for runtime filter but we dont support timev2 as predicate now
598
        // so this part not used
599
        const auto* origin_value = reinterpret_cast<const double*>(data);
600
        TTimeV2Literal timev2_literal;
601
        timev2_literal.__set_value(*origin_value);
602
        (*node).__set_timev2_literal(timev2_literal);
603
        (*node).__set_node_type(TExprNodeType::TIMEV2_LITERAL);
604
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_TIMEV2, precision, scale));
605
    } else if constexpr (T == TYPE_VARBINARY) {
606
        const auto* origin_value = reinterpret_cast<const std::string*>(data);
607
        (*node).__set_node_type(TExprNodeType::VARBINARY_LITERAL);
608
        TVarBinaryLiteral varbinary_literal;
609
        varbinary_literal.__set_value(*origin_value);
610
        (*node).__set_varbinary_literal(varbinary_literal);
611
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_VARBINARY));
612
    } else {
613
        return Status::InvalidArgument("Invalid argument type!");
614
    }
615
6
    return Status::OK();
616
6
}
_ZN5doris25create_texpr_literal_nodeILNS_13PrimitiveTypeE6EEENS_6StatusEPKvPNS_9TExprNodeEii
Line
Count
Source
436
12
                                 int scale = 0) {
437
    if constexpr (T == TYPE_BOOLEAN) {
438
        const auto* origin_value = reinterpret_cast<const bool*>(data);
439
        TBoolLiteral boolLiteral;
440
        (*node).__set_node_type(TExprNodeType::BOOL_LITERAL);
441
        boolLiteral.__set_value(*origin_value);
442
        (*node).__set_bool_literal(boolLiteral);
443
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_BOOLEAN));
444
    } else if constexpr (T == TYPE_TINYINT) {
445
        const auto* origin_value = reinterpret_cast<const int8_t*>(data);
446
        (*node).__set_node_type(TExprNodeType::INT_LITERAL);
447
        TIntLiteral intLiteral;
448
        intLiteral.__set_value(*origin_value);
449
        (*node).__set_int_literal(intLiteral);
450
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_TINYINT));
451
    } else if constexpr (T == TYPE_SMALLINT) {
452
        const auto* origin_value = reinterpret_cast<const int16_t*>(data);
453
        (*node).__set_node_type(TExprNodeType::INT_LITERAL);
454
        TIntLiteral intLiteral;
455
        intLiteral.__set_value(*origin_value);
456
        (*node).__set_int_literal(intLiteral);
457
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_SMALLINT));
458
    } else if constexpr (T == TYPE_INT) {
459
        const auto* origin_value = reinterpret_cast<const int32_t*>(data);
460
        (*node).__set_node_type(TExprNodeType::INT_LITERAL);
461
        TIntLiteral intLiteral;
462
        intLiteral.__set_value(*origin_value);
463
        (*node).__set_int_literal(intLiteral);
464
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_INT));
465
12
    } else if constexpr (T == TYPE_BIGINT) {
466
12
        const auto* origin_value = reinterpret_cast<const int64_t*>(data);
467
12
        (*node).__set_node_type(TExprNodeType::INT_LITERAL);
468
12
        TIntLiteral intLiteral;
469
12
        intLiteral.__set_value(*origin_value);
470
12
        (*node).__set_int_literal(intLiteral);
471
12
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_BIGINT));
472
    } else if constexpr (T == TYPE_LARGEINT) {
473
        const auto* origin_value = reinterpret_cast<const int128_t*>(data);
474
        (*node).__set_node_type(TExprNodeType::LARGE_INT_LITERAL);
475
        TLargeIntLiteral large_int_literal;
476
        large_int_literal.__set_value(LargeIntValue::to_string(*origin_value));
477
        (*node).__set_large_int_literal(large_int_literal);
478
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_LARGEINT));
479
    } else if constexpr ((T == TYPE_DATE) || (T == TYPE_DATETIME)) {
480
        const auto* origin_value = reinterpret_cast<const VecDateTimeValue*>(data);
481
        TDateLiteral date_literal;
482
        char convert_buffer[30];
483
        origin_value->to_string(convert_buffer);
484
        date_literal.__set_value(convert_buffer);
485
        (*node).__set_date_literal(date_literal);
486
        (*node).__set_node_type(TExprNodeType::DATE_LITERAL);
487
        if (origin_value->type() == TimeType::TIME_DATE) {
488
            (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DATE));
489
        } else if (origin_value->type() == TimeType::TIME_DATETIME) {
490
            (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DATETIME));
491
        }
492
    } else if constexpr (T == TYPE_DATEV2) {
493
        const auto* origin_value = reinterpret_cast<const DateV2Value<DateV2ValueType>*>(data);
494
        TDateLiteral date_literal;
495
        char convert_buffer[30];
496
        origin_value->to_string(convert_buffer);
497
        date_literal.__set_value(convert_buffer);
498
        (*node).__set_date_literal(date_literal);
499
        (*node).__set_node_type(TExprNodeType::DATE_LITERAL);
500
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DATEV2));
501
    } else if constexpr (T == TYPE_DATETIMEV2) {
502
        const auto* origin_value = reinterpret_cast<const DateV2Value<DateTimeV2ValueType>*>(data);
503
        TDateLiteral date_literal;
504
        char convert_buffer[30];
505
        origin_value->to_string(convert_buffer, scale);
506
        date_literal.__set_value(convert_buffer);
507
        (*node).__set_date_literal(date_literal);
508
        (*node).__set_node_type(TExprNodeType::DATE_LITERAL);
509
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DATETIMEV2, precision, scale));
510
    } else if constexpr (T == TYPE_TIMESTAMPTZ) {
511
        const auto* origin_value = reinterpret_cast<const TimestampTzValue*>(data);
512
        TDateLiteral date_literal;
513
        auto tz = cctz::utc_time_zone();
514
        auto tz_str = origin_value->to_string(tz, scale);
515
        date_literal.__set_value(tz_str);
516
        (*node).__set_date_literal(date_literal);
517
        (*node).__set_node_type(TExprNodeType::DATE_LITERAL);
518
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_TIMESTAMPTZ, precision, scale));
519
    } else if constexpr (T == TYPE_DECIMALV2) {
520
        const auto* origin_value = reinterpret_cast<const DecimalV2Value*>(data);
521
        (*node).__set_node_type(TExprNodeType::DECIMAL_LITERAL);
522
        TDecimalLiteral decimal_literal;
523
        decimal_literal.__set_value(origin_value->to_string());
524
        (*node).__set_decimal_literal(decimal_literal);
525
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DECIMALV2, precision, scale));
526
    } else if constexpr (T == TYPE_DECIMAL32) {
527
        const auto* origin_value = reinterpret_cast<const vectorized::Decimal<int32_t>*>(data);
528
        (*node).__set_node_type(TExprNodeType::DECIMAL_LITERAL);
529
        TDecimalLiteral decimal_literal;
530
        decimal_literal.__set_value(origin_value->to_string(precision, scale));
531
        (*node).__set_decimal_literal(decimal_literal);
532
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DECIMAL32, precision, scale));
533
    } else if constexpr (T == TYPE_DECIMAL64) {
534
        const auto* origin_value = reinterpret_cast<const vectorized::Decimal<int64_t>*>(data);
535
        (*node).__set_node_type(TExprNodeType::DECIMAL_LITERAL);
536
        TDecimalLiteral decimal_literal;
537
        decimal_literal.__set_value(origin_value->to_string(precision, scale));
538
        (*node).__set_decimal_literal(decimal_literal);
539
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DECIMAL64, precision, scale));
540
    } else if constexpr (T == TYPE_DECIMAL128I) {
541
        const auto* origin_value = reinterpret_cast<const vectorized::Decimal<int128_t>*>(data);
542
        (*node).__set_node_type(TExprNodeType::DECIMAL_LITERAL);
543
        TDecimalLiteral decimal_literal;
544
        // e.g. For a decimal(26,6) column, the initial value of the _min of the MinMax RF
545
        // on the RF producer side is an int128 value with 38 digits of 9, and this is the
546
        // final min value of the MinMax RF if the fragment instance has no data.
547
        // Need to truncate the value to the right precision and scale here, to avoid
548
        // error when casting string back to decimal later.
549
        // TODO: this is a temporary solution, the best solution is to produce the
550
        // right min max value at the producer side.
551
        decimal_literal.__set_value(origin_value->to_string(precision, scale));
552
        (*node).__set_decimal_literal(decimal_literal);
553
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DECIMAL128I, precision, scale));
554
    } else if constexpr (T == TYPE_DECIMAL256) {
555
        const auto* origin_value = reinterpret_cast<const vectorized::Decimal<wide::Int256>*>(data);
556
        (*node).__set_node_type(TExprNodeType::DECIMAL_LITERAL);
557
        TDecimalLiteral decimal_literal;
558
        decimal_literal.__set_value(origin_value->to_string(precision, scale));
559
        (*node).__set_decimal_literal(decimal_literal);
560
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DECIMAL256, precision, scale));
561
    } else if constexpr (T == TYPE_FLOAT) {
562
        const auto* origin_value = reinterpret_cast<const float*>(data);
563
        (*node).__set_node_type(TExprNodeType::FLOAT_LITERAL);
564
        TFloatLiteral float_literal;
565
        float_literal.__set_value(*origin_value);
566
        (*node).__set_float_literal(float_literal);
567
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_FLOAT));
568
    } else if constexpr (T == TYPE_DOUBLE) {
569
        const auto* origin_value = reinterpret_cast<const double*>(data);
570
        (*node).__set_node_type(TExprNodeType::FLOAT_LITERAL);
571
        TFloatLiteral float_literal;
572
        float_literal.__set_value(*origin_value);
573
        (*node).__set_float_literal(float_literal);
574
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DOUBLE));
575
    } else if constexpr ((T == TYPE_STRING) || (T == TYPE_CHAR) || (T == TYPE_VARCHAR)) {
576
        const auto* origin_value = reinterpret_cast<const std::string*>(data);
577
        (*node).__set_node_type(TExprNodeType::STRING_LITERAL);
578
        TStringLiteral string_literal;
579
        string_literal.__set_value(*origin_value);
580
        (*node).__set_string_literal(string_literal);
581
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_STRING));
582
    } else if constexpr (T == TYPE_IPV4) {
583
        const auto* origin_value = reinterpret_cast<const IPv4*>(data);
584
        (*node).__set_node_type(TExprNodeType::IPV4_LITERAL);
585
        TIPv4Literal literal;
586
        literal.__set_value(*origin_value);
587
        (*node).__set_ipv4_literal(literal);
588
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_IPV4));
589
    } else if constexpr (T == TYPE_IPV6) {
590
        const auto* origin_value = reinterpret_cast<const IPv6*>(data);
591
        (*node).__set_node_type(TExprNodeType::IPV6_LITERAL);
592
        TIPv6Literal literal;
593
        literal.__set_value(vectorized::CastToString::from_ip(*origin_value));
594
        (*node).__set_ipv6_literal(literal);
595
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_IPV6));
596
    } else if constexpr (T == TYPE_TIMEV2) {
597
        // the code use for runtime filter but we dont support timev2 as predicate now
598
        // so this part not used
599
        const auto* origin_value = reinterpret_cast<const double*>(data);
600
        TTimeV2Literal timev2_literal;
601
        timev2_literal.__set_value(*origin_value);
602
        (*node).__set_timev2_literal(timev2_literal);
603
        (*node).__set_node_type(TExprNodeType::TIMEV2_LITERAL);
604
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_TIMEV2, precision, scale));
605
    } else if constexpr (T == TYPE_VARBINARY) {
606
        const auto* origin_value = reinterpret_cast<const std::string*>(data);
607
        (*node).__set_node_type(TExprNodeType::VARBINARY_LITERAL);
608
        TVarBinaryLiteral varbinary_literal;
609
        varbinary_literal.__set_value(*origin_value);
610
        (*node).__set_varbinary_literal(varbinary_literal);
611
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_VARBINARY));
612
    } else {
613
        return Status::InvalidArgument("Invalid argument type!");
614
    }
615
12
    return Status::OK();
616
12
}
_ZN5doris25create_texpr_literal_nodeILNS_13PrimitiveTypeE7EEENS_6StatusEPKvPNS_9TExprNodeEii
Line
Count
Source
436
1
                                 int scale = 0) {
437
    if constexpr (T == TYPE_BOOLEAN) {
438
        const auto* origin_value = reinterpret_cast<const bool*>(data);
439
        TBoolLiteral boolLiteral;
440
        (*node).__set_node_type(TExprNodeType::BOOL_LITERAL);
441
        boolLiteral.__set_value(*origin_value);
442
        (*node).__set_bool_literal(boolLiteral);
443
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_BOOLEAN));
444
    } else if constexpr (T == TYPE_TINYINT) {
445
        const auto* origin_value = reinterpret_cast<const int8_t*>(data);
446
        (*node).__set_node_type(TExprNodeType::INT_LITERAL);
447
        TIntLiteral intLiteral;
448
        intLiteral.__set_value(*origin_value);
449
        (*node).__set_int_literal(intLiteral);
450
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_TINYINT));
451
    } else if constexpr (T == TYPE_SMALLINT) {
452
        const auto* origin_value = reinterpret_cast<const int16_t*>(data);
453
        (*node).__set_node_type(TExprNodeType::INT_LITERAL);
454
        TIntLiteral intLiteral;
455
        intLiteral.__set_value(*origin_value);
456
        (*node).__set_int_literal(intLiteral);
457
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_SMALLINT));
458
    } else if constexpr (T == TYPE_INT) {
459
        const auto* origin_value = reinterpret_cast<const int32_t*>(data);
460
        (*node).__set_node_type(TExprNodeType::INT_LITERAL);
461
        TIntLiteral intLiteral;
462
        intLiteral.__set_value(*origin_value);
463
        (*node).__set_int_literal(intLiteral);
464
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_INT));
465
    } else if constexpr (T == TYPE_BIGINT) {
466
        const auto* origin_value = reinterpret_cast<const int64_t*>(data);
467
        (*node).__set_node_type(TExprNodeType::INT_LITERAL);
468
        TIntLiteral intLiteral;
469
        intLiteral.__set_value(*origin_value);
470
        (*node).__set_int_literal(intLiteral);
471
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_BIGINT));
472
1
    } else if constexpr (T == TYPE_LARGEINT) {
473
1
        const auto* origin_value = reinterpret_cast<const int128_t*>(data);
474
1
        (*node).__set_node_type(TExprNodeType::LARGE_INT_LITERAL);
475
1
        TLargeIntLiteral large_int_literal;
476
1
        large_int_literal.__set_value(LargeIntValue::to_string(*origin_value));
477
1
        (*node).__set_large_int_literal(large_int_literal);
478
1
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_LARGEINT));
479
    } else if constexpr ((T == TYPE_DATE) || (T == TYPE_DATETIME)) {
480
        const auto* origin_value = reinterpret_cast<const VecDateTimeValue*>(data);
481
        TDateLiteral date_literal;
482
        char convert_buffer[30];
483
        origin_value->to_string(convert_buffer);
484
        date_literal.__set_value(convert_buffer);
485
        (*node).__set_date_literal(date_literal);
486
        (*node).__set_node_type(TExprNodeType::DATE_LITERAL);
487
        if (origin_value->type() == TimeType::TIME_DATE) {
488
            (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DATE));
489
        } else if (origin_value->type() == TimeType::TIME_DATETIME) {
490
            (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DATETIME));
491
        }
492
    } else if constexpr (T == TYPE_DATEV2) {
493
        const auto* origin_value = reinterpret_cast<const DateV2Value<DateV2ValueType>*>(data);
494
        TDateLiteral date_literal;
495
        char convert_buffer[30];
496
        origin_value->to_string(convert_buffer);
497
        date_literal.__set_value(convert_buffer);
498
        (*node).__set_date_literal(date_literal);
499
        (*node).__set_node_type(TExprNodeType::DATE_LITERAL);
500
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DATEV2));
501
    } else if constexpr (T == TYPE_DATETIMEV2) {
502
        const auto* origin_value = reinterpret_cast<const DateV2Value<DateTimeV2ValueType>*>(data);
503
        TDateLiteral date_literal;
504
        char convert_buffer[30];
505
        origin_value->to_string(convert_buffer, scale);
506
        date_literal.__set_value(convert_buffer);
507
        (*node).__set_date_literal(date_literal);
508
        (*node).__set_node_type(TExprNodeType::DATE_LITERAL);
509
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DATETIMEV2, precision, scale));
510
    } else if constexpr (T == TYPE_TIMESTAMPTZ) {
511
        const auto* origin_value = reinterpret_cast<const TimestampTzValue*>(data);
512
        TDateLiteral date_literal;
513
        auto tz = cctz::utc_time_zone();
514
        auto tz_str = origin_value->to_string(tz, scale);
515
        date_literal.__set_value(tz_str);
516
        (*node).__set_date_literal(date_literal);
517
        (*node).__set_node_type(TExprNodeType::DATE_LITERAL);
518
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_TIMESTAMPTZ, precision, scale));
519
    } else if constexpr (T == TYPE_DECIMALV2) {
520
        const auto* origin_value = reinterpret_cast<const DecimalV2Value*>(data);
521
        (*node).__set_node_type(TExprNodeType::DECIMAL_LITERAL);
522
        TDecimalLiteral decimal_literal;
523
        decimal_literal.__set_value(origin_value->to_string());
524
        (*node).__set_decimal_literal(decimal_literal);
525
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DECIMALV2, precision, scale));
526
    } else if constexpr (T == TYPE_DECIMAL32) {
527
        const auto* origin_value = reinterpret_cast<const vectorized::Decimal<int32_t>*>(data);
528
        (*node).__set_node_type(TExprNodeType::DECIMAL_LITERAL);
529
        TDecimalLiteral decimal_literal;
530
        decimal_literal.__set_value(origin_value->to_string(precision, scale));
531
        (*node).__set_decimal_literal(decimal_literal);
532
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DECIMAL32, precision, scale));
533
    } else if constexpr (T == TYPE_DECIMAL64) {
534
        const auto* origin_value = reinterpret_cast<const vectorized::Decimal<int64_t>*>(data);
535
        (*node).__set_node_type(TExprNodeType::DECIMAL_LITERAL);
536
        TDecimalLiteral decimal_literal;
537
        decimal_literal.__set_value(origin_value->to_string(precision, scale));
538
        (*node).__set_decimal_literal(decimal_literal);
539
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DECIMAL64, precision, scale));
540
    } else if constexpr (T == TYPE_DECIMAL128I) {
541
        const auto* origin_value = reinterpret_cast<const vectorized::Decimal<int128_t>*>(data);
542
        (*node).__set_node_type(TExprNodeType::DECIMAL_LITERAL);
543
        TDecimalLiteral decimal_literal;
544
        // e.g. For a decimal(26,6) column, the initial value of the _min of the MinMax RF
545
        // on the RF producer side is an int128 value with 38 digits of 9, and this is the
546
        // final min value of the MinMax RF if the fragment instance has no data.
547
        // Need to truncate the value to the right precision and scale here, to avoid
548
        // error when casting string back to decimal later.
549
        // TODO: this is a temporary solution, the best solution is to produce the
550
        // right min max value at the producer side.
551
        decimal_literal.__set_value(origin_value->to_string(precision, scale));
552
        (*node).__set_decimal_literal(decimal_literal);
553
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DECIMAL128I, precision, scale));
554
    } else if constexpr (T == TYPE_DECIMAL256) {
555
        const auto* origin_value = reinterpret_cast<const vectorized::Decimal<wide::Int256>*>(data);
556
        (*node).__set_node_type(TExprNodeType::DECIMAL_LITERAL);
557
        TDecimalLiteral decimal_literal;
558
        decimal_literal.__set_value(origin_value->to_string(precision, scale));
559
        (*node).__set_decimal_literal(decimal_literal);
560
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DECIMAL256, precision, scale));
561
    } else if constexpr (T == TYPE_FLOAT) {
562
        const auto* origin_value = reinterpret_cast<const float*>(data);
563
        (*node).__set_node_type(TExprNodeType::FLOAT_LITERAL);
564
        TFloatLiteral float_literal;
565
        float_literal.__set_value(*origin_value);
566
        (*node).__set_float_literal(float_literal);
567
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_FLOAT));
568
    } else if constexpr (T == TYPE_DOUBLE) {
569
        const auto* origin_value = reinterpret_cast<const double*>(data);
570
        (*node).__set_node_type(TExprNodeType::FLOAT_LITERAL);
571
        TFloatLiteral float_literal;
572
        float_literal.__set_value(*origin_value);
573
        (*node).__set_float_literal(float_literal);
574
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DOUBLE));
575
    } else if constexpr ((T == TYPE_STRING) || (T == TYPE_CHAR) || (T == TYPE_VARCHAR)) {
576
        const auto* origin_value = reinterpret_cast<const std::string*>(data);
577
        (*node).__set_node_type(TExprNodeType::STRING_LITERAL);
578
        TStringLiteral string_literal;
579
        string_literal.__set_value(*origin_value);
580
        (*node).__set_string_literal(string_literal);
581
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_STRING));
582
    } else if constexpr (T == TYPE_IPV4) {
583
        const auto* origin_value = reinterpret_cast<const IPv4*>(data);
584
        (*node).__set_node_type(TExprNodeType::IPV4_LITERAL);
585
        TIPv4Literal literal;
586
        literal.__set_value(*origin_value);
587
        (*node).__set_ipv4_literal(literal);
588
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_IPV4));
589
    } else if constexpr (T == TYPE_IPV6) {
590
        const auto* origin_value = reinterpret_cast<const IPv6*>(data);
591
        (*node).__set_node_type(TExprNodeType::IPV6_LITERAL);
592
        TIPv6Literal literal;
593
        literal.__set_value(vectorized::CastToString::from_ip(*origin_value));
594
        (*node).__set_ipv6_literal(literal);
595
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_IPV6));
596
    } else if constexpr (T == TYPE_TIMEV2) {
597
        // the code use for runtime filter but we dont support timev2 as predicate now
598
        // so this part not used
599
        const auto* origin_value = reinterpret_cast<const double*>(data);
600
        TTimeV2Literal timev2_literal;
601
        timev2_literal.__set_value(*origin_value);
602
        (*node).__set_timev2_literal(timev2_literal);
603
        (*node).__set_node_type(TExprNodeType::TIMEV2_LITERAL);
604
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_TIMEV2, precision, scale));
605
    } else if constexpr (T == TYPE_VARBINARY) {
606
        const auto* origin_value = reinterpret_cast<const std::string*>(data);
607
        (*node).__set_node_type(TExprNodeType::VARBINARY_LITERAL);
608
        TVarBinaryLiteral varbinary_literal;
609
        varbinary_literal.__set_value(*origin_value);
610
        (*node).__set_varbinary_literal(varbinary_literal);
611
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_VARBINARY));
612
    } else {
613
        return Status::InvalidArgument("Invalid argument type!");
614
    }
615
1
    return Status::OK();
616
1
}
_ZN5doris25create_texpr_literal_nodeILNS_13PrimitiveTypeE8EEENS_6StatusEPKvPNS_9TExprNodeEii
Line
Count
Source
436
1
                                 int scale = 0) {
437
    if constexpr (T == TYPE_BOOLEAN) {
438
        const auto* origin_value = reinterpret_cast<const bool*>(data);
439
        TBoolLiteral boolLiteral;
440
        (*node).__set_node_type(TExprNodeType::BOOL_LITERAL);
441
        boolLiteral.__set_value(*origin_value);
442
        (*node).__set_bool_literal(boolLiteral);
443
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_BOOLEAN));
444
    } else if constexpr (T == TYPE_TINYINT) {
445
        const auto* origin_value = reinterpret_cast<const int8_t*>(data);
446
        (*node).__set_node_type(TExprNodeType::INT_LITERAL);
447
        TIntLiteral intLiteral;
448
        intLiteral.__set_value(*origin_value);
449
        (*node).__set_int_literal(intLiteral);
450
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_TINYINT));
451
    } else if constexpr (T == TYPE_SMALLINT) {
452
        const auto* origin_value = reinterpret_cast<const int16_t*>(data);
453
        (*node).__set_node_type(TExprNodeType::INT_LITERAL);
454
        TIntLiteral intLiteral;
455
        intLiteral.__set_value(*origin_value);
456
        (*node).__set_int_literal(intLiteral);
457
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_SMALLINT));
458
    } else if constexpr (T == TYPE_INT) {
459
        const auto* origin_value = reinterpret_cast<const int32_t*>(data);
460
        (*node).__set_node_type(TExprNodeType::INT_LITERAL);
461
        TIntLiteral intLiteral;
462
        intLiteral.__set_value(*origin_value);
463
        (*node).__set_int_literal(intLiteral);
464
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_INT));
465
    } else if constexpr (T == TYPE_BIGINT) {
466
        const auto* origin_value = reinterpret_cast<const int64_t*>(data);
467
        (*node).__set_node_type(TExprNodeType::INT_LITERAL);
468
        TIntLiteral intLiteral;
469
        intLiteral.__set_value(*origin_value);
470
        (*node).__set_int_literal(intLiteral);
471
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_BIGINT));
472
    } else if constexpr (T == TYPE_LARGEINT) {
473
        const auto* origin_value = reinterpret_cast<const int128_t*>(data);
474
        (*node).__set_node_type(TExprNodeType::LARGE_INT_LITERAL);
475
        TLargeIntLiteral large_int_literal;
476
        large_int_literal.__set_value(LargeIntValue::to_string(*origin_value));
477
        (*node).__set_large_int_literal(large_int_literal);
478
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_LARGEINT));
479
    } else if constexpr ((T == TYPE_DATE) || (T == TYPE_DATETIME)) {
480
        const auto* origin_value = reinterpret_cast<const VecDateTimeValue*>(data);
481
        TDateLiteral date_literal;
482
        char convert_buffer[30];
483
        origin_value->to_string(convert_buffer);
484
        date_literal.__set_value(convert_buffer);
485
        (*node).__set_date_literal(date_literal);
486
        (*node).__set_node_type(TExprNodeType::DATE_LITERAL);
487
        if (origin_value->type() == TimeType::TIME_DATE) {
488
            (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DATE));
489
        } else if (origin_value->type() == TimeType::TIME_DATETIME) {
490
            (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DATETIME));
491
        }
492
    } else if constexpr (T == TYPE_DATEV2) {
493
        const auto* origin_value = reinterpret_cast<const DateV2Value<DateV2ValueType>*>(data);
494
        TDateLiteral date_literal;
495
        char convert_buffer[30];
496
        origin_value->to_string(convert_buffer);
497
        date_literal.__set_value(convert_buffer);
498
        (*node).__set_date_literal(date_literal);
499
        (*node).__set_node_type(TExprNodeType::DATE_LITERAL);
500
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DATEV2));
501
    } else if constexpr (T == TYPE_DATETIMEV2) {
502
        const auto* origin_value = reinterpret_cast<const DateV2Value<DateTimeV2ValueType>*>(data);
503
        TDateLiteral date_literal;
504
        char convert_buffer[30];
505
        origin_value->to_string(convert_buffer, scale);
506
        date_literal.__set_value(convert_buffer);
507
        (*node).__set_date_literal(date_literal);
508
        (*node).__set_node_type(TExprNodeType::DATE_LITERAL);
509
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DATETIMEV2, precision, scale));
510
    } else if constexpr (T == TYPE_TIMESTAMPTZ) {
511
        const auto* origin_value = reinterpret_cast<const TimestampTzValue*>(data);
512
        TDateLiteral date_literal;
513
        auto tz = cctz::utc_time_zone();
514
        auto tz_str = origin_value->to_string(tz, scale);
515
        date_literal.__set_value(tz_str);
516
        (*node).__set_date_literal(date_literal);
517
        (*node).__set_node_type(TExprNodeType::DATE_LITERAL);
518
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_TIMESTAMPTZ, precision, scale));
519
    } else if constexpr (T == TYPE_DECIMALV2) {
520
        const auto* origin_value = reinterpret_cast<const DecimalV2Value*>(data);
521
        (*node).__set_node_type(TExprNodeType::DECIMAL_LITERAL);
522
        TDecimalLiteral decimal_literal;
523
        decimal_literal.__set_value(origin_value->to_string());
524
        (*node).__set_decimal_literal(decimal_literal);
525
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DECIMALV2, precision, scale));
526
    } else if constexpr (T == TYPE_DECIMAL32) {
527
        const auto* origin_value = reinterpret_cast<const vectorized::Decimal<int32_t>*>(data);
528
        (*node).__set_node_type(TExprNodeType::DECIMAL_LITERAL);
529
        TDecimalLiteral decimal_literal;
530
        decimal_literal.__set_value(origin_value->to_string(precision, scale));
531
        (*node).__set_decimal_literal(decimal_literal);
532
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DECIMAL32, precision, scale));
533
    } else if constexpr (T == TYPE_DECIMAL64) {
534
        const auto* origin_value = reinterpret_cast<const vectorized::Decimal<int64_t>*>(data);
535
        (*node).__set_node_type(TExprNodeType::DECIMAL_LITERAL);
536
        TDecimalLiteral decimal_literal;
537
        decimal_literal.__set_value(origin_value->to_string(precision, scale));
538
        (*node).__set_decimal_literal(decimal_literal);
539
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DECIMAL64, precision, scale));
540
    } else if constexpr (T == TYPE_DECIMAL128I) {
541
        const auto* origin_value = reinterpret_cast<const vectorized::Decimal<int128_t>*>(data);
542
        (*node).__set_node_type(TExprNodeType::DECIMAL_LITERAL);
543
        TDecimalLiteral decimal_literal;
544
        // e.g. For a decimal(26,6) column, the initial value of the _min of the MinMax RF
545
        // on the RF producer side is an int128 value with 38 digits of 9, and this is the
546
        // final min value of the MinMax RF if the fragment instance has no data.
547
        // Need to truncate the value to the right precision and scale here, to avoid
548
        // error when casting string back to decimal later.
549
        // TODO: this is a temporary solution, the best solution is to produce the
550
        // right min max value at the producer side.
551
        decimal_literal.__set_value(origin_value->to_string(precision, scale));
552
        (*node).__set_decimal_literal(decimal_literal);
553
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DECIMAL128I, precision, scale));
554
    } else if constexpr (T == TYPE_DECIMAL256) {
555
        const auto* origin_value = reinterpret_cast<const vectorized::Decimal<wide::Int256>*>(data);
556
        (*node).__set_node_type(TExprNodeType::DECIMAL_LITERAL);
557
        TDecimalLiteral decimal_literal;
558
        decimal_literal.__set_value(origin_value->to_string(precision, scale));
559
        (*node).__set_decimal_literal(decimal_literal);
560
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DECIMAL256, precision, scale));
561
1
    } else if constexpr (T == TYPE_FLOAT) {
562
1
        const auto* origin_value = reinterpret_cast<const float*>(data);
563
1
        (*node).__set_node_type(TExprNodeType::FLOAT_LITERAL);
564
1
        TFloatLiteral float_literal;
565
1
        float_literal.__set_value(*origin_value);
566
1
        (*node).__set_float_literal(float_literal);
567
1
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_FLOAT));
568
    } else if constexpr (T == TYPE_DOUBLE) {
569
        const auto* origin_value = reinterpret_cast<const double*>(data);
570
        (*node).__set_node_type(TExprNodeType::FLOAT_LITERAL);
571
        TFloatLiteral float_literal;
572
        float_literal.__set_value(*origin_value);
573
        (*node).__set_float_literal(float_literal);
574
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DOUBLE));
575
    } else if constexpr ((T == TYPE_STRING) || (T == TYPE_CHAR) || (T == TYPE_VARCHAR)) {
576
        const auto* origin_value = reinterpret_cast<const std::string*>(data);
577
        (*node).__set_node_type(TExprNodeType::STRING_LITERAL);
578
        TStringLiteral string_literal;
579
        string_literal.__set_value(*origin_value);
580
        (*node).__set_string_literal(string_literal);
581
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_STRING));
582
    } else if constexpr (T == TYPE_IPV4) {
583
        const auto* origin_value = reinterpret_cast<const IPv4*>(data);
584
        (*node).__set_node_type(TExprNodeType::IPV4_LITERAL);
585
        TIPv4Literal literal;
586
        literal.__set_value(*origin_value);
587
        (*node).__set_ipv4_literal(literal);
588
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_IPV4));
589
    } else if constexpr (T == TYPE_IPV6) {
590
        const auto* origin_value = reinterpret_cast<const IPv6*>(data);
591
        (*node).__set_node_type(TExprNodeType::IPV6_LITERAL);
592
        TIPv6Literal literal;
593
        literal.__set_value(vectorized::CastToString::from_ip(*origin_value));
594
        (*node).__set_ipv6_literal(literal);
595
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_IPV6));
596
    } else if constexpr (T == TYPE_TIMEV2) {
597
        // the code use for runtime filter but we dont support timev2 as predicate now
598
        // so this part not used
599
        const auto* origin_value = reinterpret_cast<const double*>(data);
600
        TTimeV2Literal timev2_literal;
601
        timev2_literal.__set_value(*origin_value);
602
        (*node).__set_timev2_literal(timev2_literal);
603
        (*node).__set_node_type(TExprNodeType::TIMEV2_LITERAL);
604
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_TIMEV2, precision, scale));
605
    } else if constexpr (T == TYPE_VARBINARY) {
606
        const auto* origin_value = reinterpret_cast<const std::string*>(data);
607
        (*node).__set_node_type(TExprNodeType::VARBINARY_LITERAL);
608
        TVarBinaryLiteral varbinary_literal;
609
        varbinary_literal.__set_value(*origin_value);
610
        (*node).__set_varbinary_literal(varbinary_literal);
611
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_VARBINARY));
612
    } else {
613
        return Status::InvalidArgument("Invalid argument type!");
614
    }
615
1
    return Status::OK();
616
1
}
_ZN5doris25create_texpr_literal_nodeILNS_13PrimitiveTypeE9EEENS_6StatusEPKvPNS_9TExprNodeEii
Line
Count
Source
436
1
                                 int scale = 0) {
437
    if constexpr (T == TYPE_BOOLEAN) {
438
        const auto* origin_value = reinterpret_cast<const bool*>(data);
439
        TBoolLiteral boolLiteral;
440
        (*node).__set_node_type(TExprNodeType::BOOL_LITERAL);
441
        boolLiteral.__set_value(*origin_value);
442
        (*node).__set_bool_literal(boolLiteral);
443
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_BOOLEAN));
444
    } else if constexpr (T == TYPE_TINYINT) {
445
        const auto* origin_value = reinterpret_cast<const int8_t*>(data);
446
        (*node).__set_node_type(TExprNodeType::INT_LITERAL);
447
        TIntLiteral intLiteral;
448
        intLiteral.__set_value(*origin_value);
449
        (*node).__set_int_literal(intLiteral);
450
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_TINYINT));
451
    } else if constexpr (T == TYPE_SMALLINT) {
452
        const auto* origin_value = reinterpret_cast<const int16_t*>(data);
453
        (*node).__set_node_type(TExprNodeType::INT_LITERAL);
454
        TIntLiteral intLiteral;
455
        intLiteral.__set_value(*origin_value);
456
        (*node).__set_int_literal(intLiteral);
457
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_SMALLINT));
458
    } else if constexpr (T == TYPE_INT) {
459
        const auto* origin_value = reinterpret_cast<const int32_t*>(data);
460
        (*node).__set_node_type(TExprNodeType::INT_LITERAL);
461
        TIntLiteral intLiteral;
462
        intLiteral.__set_value(*origin_value);
463
        (*node).__set_int_literal(intLiteral);
464
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_INT));
465
    } else if constexpr (T == TYPE_BIGINT) {
466
        const auto* origin_value = reinterpret_cast<const int64_t*>(data);
467
        (*node).__set_node_type(TExprNodeType::INT_LITERAL);
468
        TIntLiteral intLiteral;
469
        intLiteral.__set_value(*origin_value);
470
        (*node).__set_int_literal(intLiteral);
471
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_BIGINT));
472
    } else if constexpr (T == TYPE_LARGEINT) {
473
        const auto* origin_value = reinterpret_cast<const int128_t*>(data);
474
        (*node).__set_node_type(TExprNodeType::LARGE_INT_LITERAL);
475
        TLargeIntLiteral large_int_literal;
476
        large_int_literal.__set_value(LargeIntValue::to_string(*origin_value));
477
        (*node).__set_large_int_literal(large_int_literal);
478
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_LARGEINT));
479
    } else if constexpr ((T == TYPE_DATE) || (T == TYPE_DATETIME)) {
480
        const auto* origin_value = reinterpret_cast<const VecDateTimeValue*>(data);
481
        TDateLiteral date_literal;
482
        char convert_buffer[30];
483
        origin_value->to_string(convert_buffer);
484
        date_literal.__set_value(convert_buffer);
485
        (*node).__set_date_literal(date_literal);
486
        (*node).__set_node_type(TExprNodeType::DATE_LITERAL);
487
        if (origin_value->type() == TimeType::TIME_DATE) {
488
            (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DATE));
489
        } else if (origin_value->type() == TimeType::TIME_DATETIME) {
490
            (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DATETIME));
491
        }
492
    } else if constexpr (T == TYPE_DATEV2) {
493
        const auto* origin_value = reinterpret_cast<const DateV2Value<DateV2ValueType>*>(data);
494
        TDateLiteral date_literal;
495
        char convert_buffer[30];
496
        origin_value->to_string(convert_buffer);
497
        date_literal.__set_value(convert_buffer);
498
        (*node).__set_date_literal(date_literal);
499
        (*node).__set_node_type(TExprNodeType::DATE_LITERAL);
500
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DATEV2));
501
    } else if constexpr (T == TYPE_DATETIMEV2) {
502
        const auto* origin_value = reinterpret_cast<const DateV2Value<DateTimeV2ValueType>*>(data);
503
        TDateLiteral date_literal;
504
        char convert_buffer[30];
505
        origin_value->to_string(convert_buffer, scale);
506
        date_literal.__set_value(convert_buffer);
507
        (*node).__set_date_literal(date_literal);
508
        (*node).__set_node_type(TExprNodeType::DATE_LITERAL);
509
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DATETIMEV2, precision, scale));
510
    } else if constexpr (T == TYPE_TIMESTAMPTZ) {
511
        const auto* origin_value = reinterpret_cast<const TimestampTzValue*>(data);
512
        TDateLiteral date_literal;
513
        auto tz = cctz::utc_time_zone();
514
        auto tz_str = origin_value->to_string(tz, scale);
515
        date_literal.__set_value(tz_str);
516
        (*node).__set_date_literal(date_literal);
517
        (*node).__set_node_type(TExprNodeType::DATE_LITERAL);
518
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_TIMESTAMPTZ, precision, scale));
519
    } else if constexpr (T == TYPE_DECIMALV2) {
520
        const auto* origin_value = reinterpret_cast<const DecimalV2Value*>(data);
521
        (*node).__set_node_type(TExprNodeType::DECIMAL_LITERAL);
522
        TDecimalLiteral decimal_literal;
523
        decimal_literal.__set_value(origin_value->to_string());
524
        (*node).__set_decimal_literal(decimal_literal);
525
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DECIMALV2, precision, scale));
526
    } else if constexpr (T == TYPE_DECIMAL32) {
527
        const auto* origin_value = reinterpret_cast<const vectorized::Decimal<int32_t>*>(data);
528
        (*node).__set_node_type(TExprNodeType::DECIMAL_LITERAL);
529
        TDecimalLiteral decimal_literal;
530
        decimal_literal.__set_value(origin_value->to_string(precision, scale));
531
        (*node).__set_decimal_literal(decimal_literal);
532
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DECIMAL32, precision, scale));
533
    } else if constexpr (T == TYPE_DECIMAL64) {
534
        const auto* origin_value = reinterpret_cast<const vectorized::Decimal<int64_t>*>(data);
535
        (*node).__set_node_type(TExprNodeType::DECIMAL_LITERAL);
536
        TDecimalLiteral decimal_literal;
537
        decimal_literal.__set_value(origin_value->to_string(precision, scale));
538
        (*node).__set_decimal_literal(decimal_literal);
539
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DECIMAL64, precision, scale));
540
    } else if constexpr (T == TYPE_DECIMAL128I) {
541
        const auto* origin_value = reinterpret_cast<const vectorized::Decimal<int128_t>*>(data);
542
        (*node).__set_node_type(TExprNodeType::DECIMAL_LITERAL);
543
        TDecimalLiteral decimal_literal;
544
        // e.g. For a decimal(26,6) column, the initial value of the _min of the MinMax RF
545
        // on the RF producer side is an int128 value with 38 digits of 9, and this is the
546
        // final min value of the MinMax RF if the fragment instance has no data.
547
        // Need to truncate the value to the right precision and scale here, to avoid
548
        // error when casting string back to decimal later.
549
        // TODO: this is a temporary solution, the best solution is to produce the
550
        // right min max value at the producer side.
551
        decimal_literal.__set_value(origin_value->to_string(precision, scale));
552
        (*node).__set_decimal_literal(decimal_literal);
553
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DECIMAL128I, precision, scale));
554
    } else if constexpr (T == TYPE_DECIMAL256) {
555
        const auto* origin_value = reinterpret_cast<const vectorized::Decimal<wide::Int256>*>(data);
556
        (*node).__set_node_type(TExprNodeType::DECIMAL_LITERAL);
557
        TDecimalLiteral decimal_literal;
558
        decimal_literal.__set_value(origin_value->to_string(precision, scale));
559
        (*node).__set_decimal_literal(decimal_literal);
560
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DECIMAL256, precision, scale));
561
    } else if constexpr (T == TYPE_FLOAT) {
562
        const auto* origin_value = reinterpret_cast<const float*>(data);
563
        (*node).__set_node_type(TExprNodeType::FLOAT_LITERAL);
564
        TFloatLiteral float_literal;
565
        float_literal.__set_value(*origin_value);
566
        (*node).__set_float_literal(float_literal);
567
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_FLOAT));
568
1
    } else if constexpr (T == TYPE_DOUBLE) {
569
1
        const auto* origin_value = reinterpret_cast<const double*>(data);
570
1
        (*node).__set_node_type(TExprNodeType::FLOAT_LITERAL);
571
1
        TFloatLiteral float_literal;
572
1
        float_literal.__set_value(*origin_value);
573
1
        (*node).__set_float_literal(float_literal);
574
1
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DOUBLE));
575
    } else if constexpr ((T == TYPE_STRING) || (T == TYPE_CHAR) || (T == TYPE_VARCHAR)) {
576
        const auto* origin_value = reinterpret_cast<const std::string*>(data);
577
        (*node).__set_node_type(TExprNodeType::STRING_LITERAL);
578
        TStringLiteral string_literal;
579
        string_literal.__set_value(*origin_value);
580
        (*node).__set_string_literal(string_literal);
581
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_STRING));
582
    } else if constexpr (T == TYPE_IPV4) {
583
        const auto* origin_value = reinterpret_cast<const IPv4*>(data);
584
        (*node).__set_node_type(TExprNodeType::IPV4_LITERAL);
585
        TIPv4Literal literal;
586
        literal.__set_value(*origin_value);
587
        (*node).__set_ipv4_literal(literal);
588
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_IPV4));
589
    } else if constexpr (T == TYPE_IPV6) {
590
        const auto* origin_value = reinterpret_cast<const IPv6*>(data);
591
        (*node).__set_node_type(TExprNodeType::IPV6_LITERAL);
592
        TIPv6Literal literal;
593
        literal.__set_value(vectorized::CastToString::from_ip(*origin_value));
594
        (*node).__set_ipv6_literal(literal);
595
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_IPV6));
596
    } else if constexpr (T == TYPE_TIMEV2) {
597
        // the code use for runtime filter but we dont support timev2 as predicate now
598
        // so this part not used
599
        const auto* origin_value = reinterpret_cast<const double*>(data);
600
        TTimeV2Literal timev2_literal;
601
        timev2_literal.__set_value(*origin_value);
602
        (*node).__set_timev2_literal(timev2_literal);
603
        (*node).__set_node_type(TExprNodeType::TIMEV2_LITERAL);
604
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_TIMEV2, precision, scale));
605
    } else if constexpr (T == TYPE_VARBINARY) {
606
        const auto* origin_value = reinterpret_cast<const std::string*>(data);
607
        (*node).__set_node_type(TExprNodeType::VARBINARY_LITERAL);
608
        TVarBinaryLiteral varbinary_literal;
609
        varbinary_literal.__set_value(*origin_value);
610
        (*node).__set_varbinary_literal(varbinary_literal);
611
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_VARBINARY));
612
    } else {
613
        return Status::InvalidArgument("Invalid argument type!");
614
    }
615
1
    return Status::OK();
616
1
}
_ZN5doris25create_texpr_literal_nodeILNS_13PrimitiveTypeE25EEENS_6StatusEPKvPNS_9TExprNodeEii
Line
Count
Source
436
1
                                 int scale = 0) {
437
    if constexpr (T == TYPE_BOOLEAN) {
438
        const auto* origin_value = reinterpret_cast<const bool*>(data);
439
        TBoolLiteral boolLiteral;
440
        (*node).__set_node_type(TExprNodeType::BOOL_LITERAL);
441
        boolLiteral.__set_value(*origin_value);
442
        (*node).__set_bool_literal(boolLiteral);
443
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_BOOLEAN));
444
    } else if constexpr (T == TYPE_TINYINT) {
445
        const auto* origin_value = reinterpret_cast<const int8_t*>(data);
446
        (*node).__set_node_type(TExprNodeType::INT_LITERAL);
447
        TIntLiteral intLiteral;
448
        intLiteral.__set_value(*origin_value);
449
        (*node).__set_int_literal(intLiteral);
450
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_TINYINT));
451
    } else if constexpr (T == TYPE_SMALLINT) {
452
        const auto* origin_value = reinterpret_cast<const int16_t*>(data);
453
        (*node).__set_node_type(TExprNodeType::INT_LITERAL);
454
        TIntLiteral intLiteral;
455
        intLiteral.__set_value(*origin_value);
456
        (*node).__set_int_literal(intLiteral);
457
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_SMALLINT));
458
    } else if constexpr (T == TYPE_INT) {
459
        const auto* origin_value = reinterpret_cast<const int32_t*>(data);
460
        (*node).__set_node_type(TExprNodeType::INT_LITERAL);
461
        TIntLiteral intLiteral;
462
        intLiteral.__set_value(*origin_value);
463
        (*node).__set_int_literal(intLiteral);
464
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_INT));
465
    } else if constexpr (T == TYPE_BIGINT) {
466
        const auto* origin_value = reinterpret_cast<const int64_t*>(data);
467
        (*node).__set_node_type(TExprNodeType::INT_LITERAL);
468
        TIntLiteral intLiteral;
469
        intLiteral.__set_value(*origin_value);
470
        (*node).__set_int_literal(intLiteral);
471
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_BIGINT));
472
    } else if constexpr (T == TYPE_LARGEINT) {
473
        const auto* origin_value = reinterpret_cast<const int128_t*>(data);
474
        (*node).__set_node_type(TExprNodeType::LARGE_INT_LITERAL);
475
        TLargeIntLiteral large_int_literal;
476
        large_int_literal.__set_value(LargeIntValue::to_string(*origin_value));
477
        (*node).__set_large_int_literal(large_int_literal);
478
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_LARGEINT));
479
    } else if constexpr ((T == TYPE_DATE) || (T == TYPE_DATETIME)) {
480
        const auto* origin_value = reinterpret_cast<const VecDateTimeValue*>(data);
481
        TDateLiteral date_literal;
482
        char convert_buffer[30];
483
        origin_value->to_string(convert_buffer);
484
        date_literal.__set_value(convert_buffer);
485
        (*node).__set_date_literal(date_literal);
486
        (*node).__set_node_type(TExprNodeType::DATE_LITERAL);
487
        if (origin_value->type() == TimeType::TIME_DATE) {
488
            (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DATE));
489
        } else if (origin_value->type() == TimeType::TIME_DATETIME) {
490
            (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DATETIME));
491
        }
492
1
    } else if constexpr (T == TYPE_DATEV2) {
493
1
        const auto* origin_value = reinterpret_cast<const DateV2Value<DateV2ValueType>*>(data);
494
1
        TDateLiteral date_literal;
495
1
        char convert_buffer[30];
496
1
        origin_value->to_string(convert_buffer);
497
1
        date_literal.__set_value(convert_buffer);
498
1
        (*node).__set_date_literal(date_literal);
499
1
        (*node).__set_node_type(TExprNodeType::DATE_LITERAL);
500
1
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DATEV2));
501
    } else if constexpr (T == TYPE_DATETIMEV2) {
502
        const auto* origin_value = reinterpret_cast<const DateV2Value<DateTimeV2ValueType>*>(data);
503
        TDateLiteral date_literal;
504
        char convert_buffer[30];
505
        origin_value->to_string(convert_buffer, scale);
506
        date_literal.__set_value(convert_buffer);
507
        (*node).__set_date_literal(date_literal);
508
        (*node).__set_node_type(TExprNodeType::DATE_LITERAL);
509
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DATETIMEV2, precision, scale));
510
    } else if constexpr (T == TYPE_TIMESTAMPTZ) {
511
        const auto* origin_value = reinterpret_cast<const TimestampTzValue*>(data);
512
        TDateLiteral date_literal;
513
        auto tz = cctz::utc_time_zone();
514
        auto tz_str = origin_value->to_string(tz, scale);
515
        date_literal.__set_value(tz_str);
516
        (*node).__set_date_literal(date_literal);
517
        (*node).__set_node_type(TExprNodeType::DATE_LITERAL);
518
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_TIMESTAMPTZ, precision, scale));
519
    } else if constexpr (T == TYPE_DECIMALV2) {
520
        const auto* origin_value = reinterpret_cast<const DecimalV2Value*>(data);
521
        (*node).__set_node_type(TExprNodeType::DECIMAL_LITERAL);
522
        TDecimalLiteral decimal_literal;
523
        decimal_literal.__set_value(origin_value->to_string());
524
        (*node).__set_decimal_literal(decimal_literal);
525
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DECIMALV2, precision, scale));
526
    } else if constexpr (T == TYPE_DECIMAL32) {
527
        const auto* origin_value = reinterpret_cast<const vectorized::Decimal<int32_t>*>(data);
528
        (*node).__set_node_type(TExprNodeType::DECIMAL_LITERAL);
529
        TDecimalLiteral decimal_literal;
530
        decimal_literal.__set_value(origin_value->to_string(precision, scale));
531
        (*node).__set_decimal_literal(decimal_literal);
532
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DECIMAL32, precision, scale));
533
    } else if constexpr (T == TYPE_DECIMAL64) {
534
        const auto* origin_value = reinterpret_cast<const vectorized::Decimal<int64_t>*>(data);
535
        (*node).__set_node_type(TExprNodeType::DECIMAL_LITERAL);
536
        TDecimalLiteral decimal_literal;
537
        decimal_literal.__set_value(origin_value->to_string(precision, scale));
538
        (*node).__set_decimal_literal(decimal_literal);
539
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DECIMAL64, precision, scale));
540
    } else if constexpr (T == TYPE_DECIMAL128I) {
541
        const auto* origin_value = reinterpret_cast<const vectorized::Decimal<int128_t>*>(data);
542
        (*node).__set_node_type(TExprNodeType::DECIMAL_LITERAL);
543
        TDecimalLiteral decimal_literal;
544
        // e.g. For a decimal(26,6) column, the initial value of the _min of the MinMax RF
545
        // on the RF producer side is an int128 value with 38 digits of 9, and this is the
546
        // final min value of the MinMax RF if the fragment instance has no data.
547
        // Need to truncate the value to the right precision and scale here, to avoid
548
        // error when casting string back to decimal later.
549
        // TODO: this is a temporary solution, the best solution is to produce the
550
        // right min max value at the producer side.
551
        decimal_literal.__set_value(origin_value->to_string(precision, scale));
552
        (*node).__set_decimal_literal(decimal_literal);
553
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DECIMAL128I, precision, scale));
554
    } else if constexpr (T == TYPE_DECIMAL256) {
555
        const auto* origin_value = reinterpret_cast<const vectorized::Decimal<wide::Int256>*>(data);
556
        (*node).__set_node_type(TExprNodeType::DECIMAL_LITERAL);
557
        TDecimalLiteral decimal_literal;
558
        decimal_literal.__set_value(origin_value->to_string(precision, scale));
559
        (*node).__set_decimal_literal(decimal_literal);
560
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DECIMAL256, precision, scale));
561
    } else if constexpr (T == TYPE_FLOAT) {
562
        const auto* origin_value = reinterpret_cast<const float*>(data);
563
        (*node).__set_node_type(TExprNodeType::FLOAT_LITERAL);
564
        TFloatLiteral float_literal;
565
        float_literal.__set_value(*origin_value);
566
        (*node).__set_float_literal(float_literal);
567
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_FLOAT));
568
    } else if constexpr (T == TYPE_DOUBLE) {
569
        const auto* origin_value = reinterpret_cast<const double*>(data);
570
        (*node).__set_node_type(TExprNodeType::FLOAT_LITERAL);
571
        TFloatLiteral float_literal;
572
        float_literal.__set_value(*origin_value);
573
        (*node).__set_float_literal(float_literal);
574
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DOUBLE));
575
    } else if constexpr ((T == TYPE_STRING) || (T == TYPE_CHAR) || (T == TYPE_VARCHAR)) {
576
        const auto* origin_value = reinterpret_cast<const std::string*>(data);
577
        (*node).__set_node_type(TExprNodeType::STRING_LITERAL);
578
        TStringLiteral string_literal;
579
        string_literal.__set_value(*origin_value);
580
        (*node).__set_string_literal(string_literal);
581
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_STRING));
582
    } else if constexpr (T == TYPE_IPV4) {
583
        const auto* origin_value = reinterpret_cast<const IPv4*>(data);
584
        (*node).__set_node_type(TExprNodeType::IPV4_LITERAL);
585
        TIPv4Literal literal;
586
        literal.__set_value(*origin_value);
587
        (*node).__set_ipv4_literal(literal);
588
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_IPV4));
589
    } else if constexpr (T == TYPE_IPV6) {
590
        const auto* origin_value = reinterpret_cast<const IPv6*>(data);
591
        (*node).__set_node_type(TExprNodeType::IPV6_LITERAL);
592
        TIPv6Literal literal;
593
        literal.__set_value(vectorized::CastToString::from_ip(*origin_value));
594
        (*node).__set_ipv6_literal(literal);
595
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_IPV6));
596
    } else if constexpr (T == TYPE_TIMEV2) {
597
        // the code use for runtime filter but we dont support timev2 as predicate now
598
        // so this part not used
599
        const auto* origin_value = reinterpret_cast<const double*>(data);
600
        TTimeV2Literal timev2_literal;
601
        timev2_literal.__set_value(*origin_value);
602
        (*node).__set_timev2_literal(timev2_literal);
603
        (*node).__set_node_type(TExprNodeType::TIMEV2_LITERAL);
604
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_TIMEV2, precision, scale));
605
    } else if constexpr (T == TYPE_VARBINARY) {
606
        const auto* origin_value = reinterpret_cast<const std::string*>(data);
607
        (*node).__set_node_type(TExprNodeType::VARBINARY_LITERAL);
608
        TVarBinaryLiteral varbinary_literal;
609
        varbinary_literal.__set_value(*origin_value);
610
        (*node).__set_varbinary_literal(varbinary_literal);
611
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_VARBINARY));
612
    } else {
613
        return Status::InvalidArgument("Invalid argument type!");
614
    }
615
1
    return Status::OK();
616
1
}
_ZN5doris25create_texpr_literal_nodeILNS_13PrimitiveTypeE26EEENS_6StatusEPKvPNS_9TExprNodeEii
Line
Count
Source
436
1
                                 int scale = 0) {
437
    if constexpr (T == TYPE_BOOLEAN) {
438
        const auto* origin_value = reinterpret_cast<const bool*>(data);
439
        TBoolLiteral boolLiteral;
440
        (*node).__set_node_type(TExprNodeType::BOOL_LITERAL);
441
        boolLiteral.__set_value(*origin_value);
442
        (*node).__set_bool_literal(boolLiteral);
443
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_BOOLEAN));
444
    } else if constexpr (T == TYPE_TINYINT) {
445
        const auto* origin_value = reinterpret_cast<const int8_t*>(data);
446
        (*node).__set_node_type(TExprNodeType::INT_LITERAL);
447
        TIntLiteral intLiteral;
448
        intLiteral.__set_value(*origin_value);
449
        (*node).__set_int_literal(intLiteral);
450
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_TINYINT));
451
    } else if constexpr (T == TYPE_SMALLINT) {
452
        const auto* origin_value = reinterpret_cast<const int16_t*>(data);
453
        (*node).__set_node_type(TExprNodeType::INT_LITERAL);
454
        TIntLiteral intLiteral;
455
        intLiteral.__set_value(*origin_value);
456
        (*node).__set_int_literal(intLiteral);
457
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_SMALLINT));
458
    } else if constexpr (T == TYPE_INT) {
459
        const auto* origin_value = reinterpret_cast<const int32_t*>(data);
460
        (*node).__set_node_type(TExprNodeType::INT_LITERAL);
461
        TIntLiteral intLiteral;
462
        intLiteral.__set_value(*origin_value);
463
        (*node).__set_int_literal(intLiteral);
464
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_INT));
465
    } else if constexpr (T == TYPE_BIGINT) {
466
        const auto* origin_value = reinterpret_cast<const int64_t*>(data);
467
        (*node).__set_node_type(TExprNodeType::INT_LITERAL);
468
        TIntLiteral intLiteral;
469
        intLiteral.__set_value(*origin_value);
470
        (*node).__set_int_literal(intLiteral);
471
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_BIGINT));
472
    } else if constexpr (T == TYPE_LARGEINT) {
473
        const auto* origin_value = reinterpret_cast<const int128_t*>(data);
474
        (*node).__set_node_type(TExprNodeType::LARGE_INT_LITERAL);
475
        TLargeIntLiteral large_int_literal;
476
        large_int_literal.__set_value(LargeIntValue::to_string(*origin_value));
477
        (*node).__set_large_int_literal(large_int_literal);
478
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_LARGEINT));
479
    } else if constexpr ((T == TYPE_DATE) || (T == TYPE_DATETIME)) {
480
        const auto* origin_value = reinterpret_cast<const VecDateTimeValue*>(data);
481
        TDateLiteral date_literal;
482
        char convert_buffer[30];
483
        origin_value->to_string(convert_buffer);
484
        date_literal.__set_value(convert_buffer);
485
        (*node).__set_date_literal(date_literal);
486
        (*node).__set_node_type(TExprNodeType::DATE_LITERAL);
487
        if (origin_value->type() == TimeType::TIME_DATE) {
488
            (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DATE));
489
        } else if (origin_value->type() == TimeType::TIME_DATETIME) {
490
            (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DATETIME));
491
        }
492
    } else if constexpr (T == TYPE_DATEV2) {
493
        const auto* origin_value = reinterpret_cast<const DateV2Value<DateV2ValueType>*>(data);
494
        TDateLiteral date_literal;
495
        char convert_buffer[30];
496
        origin_value->to_string(convert_buffer);
497
        date_literal.__set_value(convert_buffer);
498
        (*node).__set_date_literal(date_literal);
499
        (*node).__set_node_type(TExprNodeType::DATE_LITERAL);
500
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DATEV2));
501
1
    } else if constexpr (T == TYPE_DATETIMEV2) {
502
1
        const auto* origin_value = reinterpret_cast<const DateV2Value<DateTimeV2ValueType>*>(data);
503
1
        TDateLiteral date_literal;
504
1
        char convert_buffer[30];
505
1
        origin_value->to_string(convert_buffer, scale);
506
1
        date_literal.__set_value(convert_buffer);
507
1
        (*node).__set_date_literal(date_literal);
508
1
        (*node).__set_node_type(TExprNodeType::DATE_LITERAL);
509
1
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DATETIMEV2, precision, scale));
510
    } else if constexpr (T == TYPE_TIMESTAMPTZ) {
511
        const auto* origin_value = reinterpret_cast<const TimestampTzValue*>(data);
512
        TDateLiteral date_literal;
513
        auto tz = cctz::utc_time_zone();
514
        auto tz_str = origin_value->to_string(tz, scale);
515
        date_literal.__set_value(tz_str);
516
        (*node).__set_date_literal(date_literal);
517
        (*node).__set_node_type(TExprNodeType::DATE_LITERAL);
518
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_TIMESTAMPTZ, precision, scale));
519
    } else if constexpr (T == TYPE_DECIMALV2) {
520
        const auto* origin_value = reinterpret_cast<const DecimalV2Value*>(data);
521
        (*node).__set_node_type(TExprNodeType::DECIMAL_LITERAL);
522
        TDecimalLiteral decimal_literal;
523
        decimal_literal.__set_value(origin_value->to_string());
524
        (*node).__set_decimal_literal(decimal_literal);
525
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DECIMALV2, precision, scale));
526
    } else if constexpr (T == TYPE_DECIMAL32) {
527
        const auto* origin_value = reinterpret_cast<const vectorized::Decimal<int32_t>*>(data);
528
        (*node).__set_node_type(TExprNodeType::DECIMAL_LITERAL);
529
        TDecimalLiteral decimal_literal;
530
        decimal_literal.__set_value(origin_value->to_string(precision, scale));
531
        (*node).__set_decimal_literal(decimal_literal);
532
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DECIMAL32, precision, scale));
533
    } else if constexpr (T == TYPE_DECIMAL64) {
534
        const auto* origin_value = reinterpret_cast<const vectorized::Decimal<int64_t>*>(data);
535
        (*node).__set_node_type(TExprNodeType::DECIMAL_LITERAL);
536
        TDecimalLiteral decimal_literal;
537
        decimal_literal.__set_value(origin_value->to_string(precision, scale));
538
        (*node).__set_decimal_literal(decimal_literal);
539
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DECIMAL64, precision, scale));
540
    } else if constexpr (T == TYPE_DECIMAL128I) {
541
        const auto* origin_value = reinterpret_cast<const vectorized::Decimal<int128_t>*>(data);
542
        (*node).__set_node_type(TExprNodeType::DECIMAL_LITERAL);
543
        TDecimalLiteral decimal_literal;
544
        // e.g. For a decimal(26,6) column, the initial value of the _min of the MinMax RF
545
        // on the RF producer side is an int128 value with 38 digits of 9, and this is the
546
        // final min value of the MinMax RF if the fragment instance has no data.
547
        // Need to truncate the value to the right precision and scale here, to avoid
548
        // error when casting string back to decimal later.
549
        // TODO: this is a temporary solution, the best solution is to produce the
550
        // right min max value at the producer side.
551
        decimal_literal.__set_value(origin_value->to_string(precision, scale));
552
        (*node).__set_decimal_literal(decimal_literal);
553
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DECIMAL128I, precision, scale));
554
    } else if constexpr (T == TYPE_DECIMAL256) {
555
        const auto* origin_value = reinterpret_cast<const vectorized::Decimal<wide::Int256>*>(data);
556
        (*node).__set_node_type(TExprNodeType::DECIMAL_LITERAL);
557
        TDecimalLiteral decimal_literal;
558
        decimal_literal.__set_value(origin_value->to_string(precision, scale));
559
        (*node).__set_decimal_literal(decimal_literal);
560
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DECIMAL256, precision, scale));
561
    } else if constexpr (T == TYPE_FLOAT) {
562
        const auto* origin_value = reinterpret_cast<const float*>(data);
563
        (*node).__set_node_type(TExprNodeType::FLOAT_LITERAL);
564
        TFloatLiteral float_literal;
565
        float_literal.__set_value(*origin_value);
566
        (*node).__set_float_literal(float_literal);
567
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_FLOAT));
568
    } else if constexpr (T == TYPE_DOUBLE) {
569
        const auto* origin_value = reinterpret_cast<const double*>(data);
570
        (*node).__set_node_type(TExprNodeType::FLOAT_LITERAL);
571
        TFloatLiteral float_literal;
572
        float_literal.__set_value(*origin_value);
573
        (*node).__set_float_literal(float_literal);
574
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DOUBLE));
575
    } else if constexpr ((T == TYPE_STRING) || (T == TYPE_CHAR) || (T == TYPE_VARCHAR)) {
576
        const auto* origin_value = reinterpret_cast<const std::string*>(data);
577
        (*node).__set_node_type(TExprNodeType::STRING_LITERAL);
578
        TStringLiteral string_literal;
579
        string_literal.__set_value(*origin_value);
580
        (*node).__set_string_literal(string_literal);
581
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_STRING));
582
    } else if constexpr (T == TYPE_IPV4) {
583
        const auto* origin_value = reinterpret_cast<const IPv4*>(data);
584
        (*node).__set_node_type(TExprNodeType::IPV4_LITERAL);
585
        TIPv4Literal literal;
586
        literal.__set_value(*origin_value);
587
        (*node).__set_ipv4_literal(literal);
588
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_IPV4));
589
    } else if constexpr (T == TYPE_IPV6) {
590
        const auto* origin_value = reinterpret_cast<const IPv6*>(data);
591
        (*node).__set_node_type(TExprNodeType::IPV6_LITERAL);
592
        TIPv6Literal literal;
593
        literal.__set_value(vectorized::CastToString::from_ip(*origin_value));
594
        (*node).__set_ipv6_literal(literal);
595
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_IPV6));
596
    } else if constexpr (T == TYPE_TIMEV2) {
597
        // the code use for runtime filter but we dont support timev2 as predicate now
598
        // so this part not used
599
        const auto* origin_value = reinterpret_cast<const double*>(data);
600
        TTimeV2Literal timev2_literal;
601
        timev2_literal.__set_value(*origin_value);
602
        (*node).__set_timev2_literal(timev2_literal);
603
        (*node).__set_node_type(TExprNodeType::TIMEV2_LITERAL);
604
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_TIMEV2, precision, scale));
605
    } else if constexpr (T == TYPE_VARBINARY) {
606
        const auto* origin_value = reinterpret_cast<const std::string*>(data);
607
        (*node).__set_node_type(TExprNodeType::VARBINARY_LITERAL);
608
        TVarBinaryLiteral varbinary_literal;
609
        varbinary_literal.__set_value(*origin_value);
610
        (*node).__set_varbinary_literal(varbinary_literal);
611
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_VARBINARY));
612
    } else {
613
        return Status::InvalidArgument("Invalid argument type!");
614
    }
615
1
    return Status::OK();
616
1
}
_ZN5doris25create_texpr_literal_nodeILNS_13PrimitiveTypeE11EEENS_6StatusEPKvPNS_9TExprNodeEii
Line
Count
Source
436
1
                                 int scale = 0) {
437
    if constexpr (T == TYPE_BOOLEAN) {
438
        const auto* origin_value = reinterpret_cast<const bool*>(data);
439
        TBoolLiteral boolLiteral;
440
        (*node).__set_node_type(TExprNodeType::BOOL_LITERAL);
441
        boolLiteral.__set_value(*origin_value);
442
        (*node).__set_bool_literal(boolLiteral);
443
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_BOOLEAN));
444
    } else if constexpr (T == TYPE_TINYINT) {
445
        const auto* origin_value = reinterpret_cast<const int8_t*>(data);
446
        (*node).__set_node_type(TExprNodeType::INT_LITERAL);
447
        TIntLiteral intLiteral;
448
        intLiteral.__set_value(*origin_value);
449
        (*node).__set_int_literal(intLiteral);
450
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_TINYINT));
451
    } else if constexpr (T == TYPE_SMALLINT) {
452
        const auto* origin_value = reinterpret_cast<const int16_t*>(data);
453
        (*node).__set_node_type(TExprNodeType::INT_LITERAL);
454
        TIntLiteral intLiteral;
455
        intLiteral.__set_value(*origin_value);
456
        (*node).__set_int_literal(intLiteral);
457
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_SMALLINT));
458
    } else if constexpr (T == TYPE_INT) {
459
        const auto* origin_value = reinterpret_cast<const int32_t*>(data);
460
        (*node).__set_node_type(TExprNodeType::INT_LITERAL);
461
        TIntLiteral intLiteral;
462
        intLiteral.__set_value(*origin_value);
463
        (*node).__set_int_literal(intLiteral);
464
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_INT));
465
    } else if constexpr (T == TYPE_BIGINT) {
466
        const auto* origin_value = reinterpret_cast<const int64_t*>(data);
467
        (*node).__set_node_type(TExprNodeType::INT_LITERAL);
468
        TIntLiteral intLiteral;
469
        intLiteral.__set_value(*origin_value);
470
        (*node).__set_int_literal(intLiteral);
471
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_BIGINT));
472
    } else if constexpr (T == TYPE_LARGEINT) {
473
        const auto* origin_value = reinterpret_cast<const int128_t*>(data);
474
        (*node).__set_node_type(TExprNodeType::LARGE_INT_LITERAL);
475
        TLargeIntLiteral large_int_literal;
476
        large_int_literal.__set_value(LargeIntValue::to_string(*origin_value));
477
        (*node).__set_large_int_literal(large_int_literal);
478
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_LARGEINT));
479
1
    } else if constexpr ((T == TYPE_DATE) || (T == TYPE_DATETIME)) {
480
1
        const auto* origin_value = reinterpret_cast<const VecDateTimeValue*>(data);
481
1
        TDateLiteral date_literal;
482
1
        char convert_buffer[30];
483
1
        origin_value->to_string(convert_buffer);
484
1
        date_literal.__set_value(convert_buffer);
485
1
        (*node).__set_date_literal(date_literal);
486
1
        (*node).__set_node_type(TExprNodeType::DATE_LITERAL);
487
1
        if (origin_value->type() == TimeType::TIME_DATE) {
488
1
            (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DATE));
489
1
        } else if (origin_value->type() == TimeType::TIME_DATETIME) {
490
0
            (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DATETIME));
491
0
        }
492
    } else if constexpr (T == TYPE_DATEV2) {
493
        const auto* origin_value = reinterpret_cast<const DateV2Value<DateV2ValueType>*>(data);
494
        TDateLiteral date_literal;
495
        char convert_buffer[30];
496
        origin_value->to_string(convert_buffer);
497
        date_literal.__set_value(convert_buffer);
498
        (*node).__set_date_literal(date_literal);
499
        (*node).__set_node_type(TExprNodeType::DATE_LITERAL);
500
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DATEV2));
501
    } else if constexpr (T == TYPE_DATETIMEV2) {
502
        const auto* origin_value = reinterpret_cast<const DateV2Value<DateTimeV2ValueType>*>(data);
503
        TDateLiteral date_literal;
504
        char convert_buffer[30];
505
        origin_value->to_string(convert_buffer, scale);
506
        date_literal.__set_value(convert_buffer);
507
        (*node).__set_date_literal(date_literal);
508
        (*node).__set_node_type(TExprNodeType::DATE_LITERAL);
509
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DATETIMEV2, precision, scale));
510
    } else if constexpr (T == TYPE_TIMESTAMPTZ) {
511
        const auto* origin_value = reinterpret_cast<const TimestampTzValue*>(data);
512
        TDateLiteral date_literal;
513
        auto tz = cctz::utc_time_zone();
514
        auto tz_str = origin_value->to_string(tz, scale);
515
        date_literal.__set_value(tz_str);
516
        (*node).__set_date_literal(date_literal);
517
        (*node).__set_node_type(TExprNodeType::DATE_LITERAL);
518
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_TIMESTAMPTZ, precision, scale));
519
    } else if constexpr (T == TYPE_DECIMALV2) {
520
        const auto* origin_value = reinterpret_cast<const DecimalV2Value*>(data);
521
        (*node).__set_node_type(TExprNodeType::DECIMAL_LITERAL);
522
        TDecimalLiteral decimal_literal;
523
        decimal_literal.__set_value(origin_value->to_string());
524
        (*node).__set_decimal_literal(decimal_literal);
525
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DECIMALV2, precision, scale));
526
    } else if constexpr (T == TYPE_DECIMAL32) {
527
        const auto* origin_value = reinterpret_cast<const vectorized::Decimal<int32_t>*>(data);
528
        (*node).__set_node_type(TExprNodeType::DECIMAL_LITERAL);
529
        TDecimalLiteral decimal_literal;
530
        decimal_literal.__set_value(origin_value->to_string(precision, scale));
531
        (*node).__set_decimal_literal(decimal_literal);
532
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DECIMAL32, precision, scale));
533
    } else if constexpr (T == TYPE_DECIMAL64) {
534
        const auto* origin_value = reinterpret_cast<const vectorized::Decimal<int64_t>*>(data);
535
        (*node).__set_node_type(TExprNodeType::DECIMAL_LITERAL);
536
        TDecimalLiteral decimal_literal;
537
        decimal_literal.__set_value(origin_value->to_string(precision, scale));
538
        (*node).__set_decimal_literal(decimal_literal);
539
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DECIMAL64, precision, scale));
540
    } else if constexpr (T == TYPE_DECIMAL128I) {
541
        const auto* origin_value = reinterpret_cast<const vectorized::Decimal<int128_t>*>(data);
542
        (*node).__set_node_type(TExprNodeType::DECIMAL_LITERAL);
543
        TDecimalLiteral decimal_literal;
544
        // e.g. For a decimal(26,6) column, the initial value of the _min of the MinMax RF
545
        // on the RF producer side is an int128 value with 38 digits of 9, and this is the
546
        // final min value of the MinMax RF if the fragment instance has no data.
547
        // Need to truncate the value to the right precision and scale here, to avoid
548
        // error when casting string back to decimal later.
549
        // TODO: this is a temporary solution, the best solution is to produce the
550
        // right min max value at the producer side.
551
        decimal_literal.__set_value(origin_value->to_string(precision, scale));
552
        (*node).__set_decimal_literal(decimal_literal);
553
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DECIMAL128I, precision, scale));
554
    } else if constexpr (T == TYPE_DECIMAL256) {
555
        const auto* origin_value = reinterpret_cast<const vectorized::Decimal<wide::Int256>*>(data);
556
        (*node).__set_node_type(TExprNodeType::DECIMAL_LITERAL);
557
        TDecimalLiteral decimal_literal;
558
        decimal_literal.__set_value(origin_value->to_string(precision, scale));
559
        (*node).__set_decimal_literal(decimal_literal);
560
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DECIMAL256, precision, scale));
561
    } else if constexpr (T == TYPE_FLOAT) {
562
        const auto* origin_value = reinterpret_cast<const float*>(data);
563
        (*node).__set_node_type(TExprNodeType::FLOAT_LITERAL);
564
        TFloatLiteral float_literal;
565
        float_literal.__set_value(*origin_value);
566
        (*node).__set_float_literal(float_literal);
567
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_FLOAT));
568
    } else if constexpr (T == TYPE_DOUBLE) {
569
        const auto* origin_value = reinterpret_cast<const double*>(data);
570
        (*node).__set_node_type(TExprNodeType::FLOAT_LITERAL);
571
        TFloatLiteral float_literal;
572
        float_literal.__set_value(*origin_value);
573
        (*node).__set_float_literal(float_literal);
574
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DOUBLE));
575
    } else if constexpr ((T == TYPE_STRING) || (T == TYPE_CHAR) || (T == TYPE_VARCHAR)) {
576
        const auto* origin_value = reinterpret_cast<const std::string*>(data);
577
        (*node).__set_node_type(TExprNodeType::STRING_LITERAL);
578
        TStringLiteral string_literal;
579
        string_literal.__set_value(*origin_value);
580
        (*node).__set_string_literal(string_literal);
581
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_STRING));
582
    } else if constexpr (T == TYPE_IPV4) {
583
        const auto* origin_value = reinterpret_cast<const IPv4*>(data);
584
        (*node).__set_node_type(TExprNodeType::IPV4_LITERAL);
585
        TIPv4Literal literal;
586
        literal.__set_value(*origin_value);
587
        (*node).__set_ipv4_literal(literal);
588
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_IPV4));
589
    } else if constexpr (T == TYPE_IPV6) {
590
        const auto* origin_value = reinterpret_cast<const IPv6*>(data);
591
        (*node).__set_node_type(TExprNodeType::IPV6_LITERAL);
592
        TIPv6Literal literal;
593
        literal.__set_value(vectorized::CastToString::from_ip(*origin_value));
594
        (*node).__set_ipv6_literal(literal);
595
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_IPV6));
596
    } else if constexpr (T == TYPE_TIMEV2) {
597
        // the code use for runtime filter but we dont support timev2 as predicate now
598
        // so this part not used
599
        const auto* origin_value = reinterpret_cast<const double*>(data);
600
        TTimeV2Literal timev2_literal;
601
        timev2_literal.__set_value(*origin_value);
602
        (*node).__set_timev2_literal(timev2_literal);
603
        (*node).__set_node_type(TExprNodeType::TIMEV2_LITERAL);
604
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_TIMEV2, precision, scale));
605
    } else if constexpr (T == TYPE_VARBINARY) {
606
        const auto* origin_value = reinterpret_cast<const std::string*>(data);
607
        (*node).__set_node_type(TExprNodeType::VARBINARY_LITERAL);
608
        TVarBinaryLiteral varbinary_literal;
609
        varbinary_literal.__set_value(*origin_value);
610
        (*node).__set_varbinary_literal(varbinary_literal);
611
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_VARBINARY));
612
    } else {
613
        return Status::InvalidArgument("Invalid argument type!");
614
    }
615
1
    return Status::OK();
616
1
}
_ZN5doris25create_texpr_literal_nodeILNS_13PrimitiveTypeE12EEENS_6StatusEPKvPNS_9TExprNodeEii
Line
Count
Source
436
1
                                 int scale = 0) {
437
    if constexpr (T == TYPE_BOOLEAN) {
438
        const auto* origin_value = reinterpret_cast<const bool*>(data);
439
        TBoolLiteral boolLiteral;
440
        (*node).__set_node_type(TExprNodeType::BOOL_LITERAL);
441
        boolLiteral.__set_value(*origin_value);
442
        (*node).__set_bool_literal(boolLiteral);
443
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_BOOLEAN));
444
    } else if constexpr (T == TYPE_TINYINT) {
445
        const auto* origin_value = reinterpret_cast<const int8_t*>(data);
446
        (*node).__set_node_type(TExprNodeType::INT_LITERAL);
447
        TIntLiteral intLiteral;
448
        intLiteral.__set_value(*origin_value);
449
        (*node).__set_int_literal(intLiteral);
450
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_TINYINT));
451
    } else if constexpr (T == TYPE_SMALLINT) {
452
        const auto* origin_value = reinterpret_cast<const int16_t*>(data);
453
        (*node).__set_node_type(TExprNodeType::INT_LITERAL);
454
        TIntLiteral intLiteral;
455
        intLiteral.__set_value(*origin_value);
456
        (*node).__set_int_literal(intLiteral);
457
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_SMALLINT));
458
    } else if constexpr (T == TYPE_INT) {
459
        const auto* origin_value = reinterpret_cast<const int32_t*>(data);
460
        (*node).__set_node_type(TExprNodeType::INT_LITERAL);
461
        TIntLiteral intLiteral;
462
        intLiteral.__set_value(*origin_value);
463
        (*node).__set_int_literal(intLiteral);
464
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_INT));
465
    } else if constexpr (T == TYPE_BIGINT) {
466
        const auto* origin_value = reinterpret_cast<const int64_t*>(data);
467
        (*node).__set_node_type(TExprNodeType::INT_LITERAL);
468
        TIntLiteral intLiteral;
469
        intLiteral.__set_value(*origin_value);
470
        (*node).__set_int_literal(intLiteral);
471
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_BIGINT));
472
    } else if constexpr (T == TYPE_LARGEINT) {
473
        const auto* origin_value = reinterpret_cast<const int128_t*>(data);
474
        (*node).__set_node_type(TExprNodeType::LARGE_INT_LITERAL);
475
        TLargeIntLiteral large_int_literal;
476
        large_int_literal.__set_value(LargeIntValue::to_string(*origin_value));
477
        (*node).__set_large_int_literal(large_int_literal);
478
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_LARGEINT));
479
1
    } else if constexpr ((T == TYPE_DATE) || (T == TYPE_DATETIME)) {
480
1
        const auto* origin_value = reinterpret_cast<const VecDateTimeValue*>(data);
481
1
        TDateLiteral date_literal;
482
1
        char convert_buffer[30];
483
1
        origin_value->to_string(convert_buffer);
484
1
        date_literal.__set_value(convert_buffer);
485
1
        (*node).__set_date_literal(date_literal);
486
1
        (*node).__set_node_type(TExprNodeType::DATE_LITERAL);
487
1
        if (origin_value->type() == TimeType::TIME_DATE) {
488
0
            (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DATE));
489
1
        } else if (origin_value->type() == TimeType::TIME_DATETIME) {
490
1
            (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DATETIME));
491
1
        }
492
    } else if constexpr (T == TYPE_DATEV2) {
493
        const auto* origin_value = reinterpret_cast<const DateV2Value<DateV2ValueType>*>(data);
494
        TDateLiteral date_literal;
495
        char convert_buffer[30];
496
        origin_value->to_string(convert_buffer);
497
        date_literal.__set_value(convert_buffer);
498
        (*node).__set_date_literal(date_literal);
499
        (*node).__set_node_type(TExprNodeType::DATE_LITERAL);
500
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DATEV2));
501
    } else if constexpr (T == TYPE_DATETIMEV2) {
502
        const auto* origin_value = reinterpret_cast<const DateV2Value<DateTimeV2ValueType>*>(data);
503
        TDateLiteral date_literal;
504
        char convert_buffer[30];
505
        origin_value->to_string(convert_buffer, scale);
506
        date_literal.__set_value(convert_buffer);
507
        (*node).__set_date_literal(date_literal);
508
        (*node).__set_node_type(TExprNodeType::DATE_LITERAL);
509
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DATETIMEV2, precision, scale));
510
    } else if constexpr (T == TYPE_TIMESTAMPTZ) {
511
        const auto* origin_value = reinterpret_cast<const TimestampTzValue*>(data);
512
        TDateLiteral date_literal;
513
        auto tz = cctz::utc_time_zone();
514
        auto tz_str = origin_value->to_string(tz, scale);
515
        date_literal.__set_value(tz_str);
516
        (*node).__set_date_literal(date_literal);
517
        (*node).__set_node_type(TExprNodeType::DATE_LITERAL);
518
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_TIMESTAMPTZ, precision, scale));
519
    } else if constexpr (T == TYPE_DECIMALV2) {
520
        const auto* origin_value = reinterpret_cast<const DecimalV2Value*>(data);
521
        (*node).__set_node_type(TExprNodeType::DECIMAL_LITERAL);
522
        TDecimalLiteral decimal_literal;
523
        decimal_literal.__set_value(origin_value->to_string());
524
        (*node).__set_decimal_literal(decimal_literal);
525
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DECIMALV2, precision, scale));
526
    } else if constexpr (T == TYPE_DECIMAL32) {
527
        const auto* origin_value = reinterpret_cast<const vectorized::Decimal<int32_t>*>(data);
528
        (*node).__set_node_type(TExprNodeType::DECIMAL_LITERAL);
529
        TDecimalLiteral decimal_literal;
530
        decimal_literal.__set_value(origin_value->to_string(precision, scale));
531
        (*node).__set_decimal_literal(decimal_literal);
532
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DECIMAL32, precision, scale));
533
    } else if constexpr (T == TYPE_DECIMAL64) {
534
        const auto* origin_value = reinterpret_cast<const vectorized::Decimal<int64_t>*>(data);
535
        (*node).__set_node_type(TExprNodeType::DECIMAL_LITERAL);
536
        TDecimalLiteral decimal_literal;
537
        decimal_literal.__set_value(origin_value->to_string(precision, scale));
538
        (*node).__set_decimal_literal(decimal_literal);
539
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DECIMAL64, precision, scale));
540
    } else if constexpr (T == TYPE_DECIMAL128I) {
541
        const auto* origin_value = reinterpret_cast<const vectorized::Decimal<int128_t>*>(data);
542
        (*node).__set_node_type(TExprNodeType::DECIMAL_LITERAL);
543
        TDecimalLiteral decimal_literal;
544
        // e.g. For a decimal(26,6) column, the initial value of the _min of the MinMax RF
545
        // on the RF producer side is an int128 value with 38 digits of 9, and this is the
546
        // final min value of the MinMax RF if the fragment instance has no data.
547
        // Need to truncate the value to the right precision and scale here, to avoid
548
        // error when casting string back to decimal later.
549
        // TODO: this is a temporary solution, the best solution is to produce the
550
        // right min max value at the producer side.
551
        decimal_literal.__set_value(origin_value->to_string(precision, scale));
552
        (*node).__set_decimal_literal(decimal_literal);
553
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DECIMAL128I, precision, scale));
554
    } else if constexpr (T == TYPE_DECIMAL256) {
555
        const auto* origin_value = reinterpret_cast<const vectorized::Decimal<wide::Int256>*>(data);
556
        (*node).__set_node_type(TExprNodeType::DECIMAL_LITERAL);
557
        TDecimalLiteral decimal_literal;
558
        decimal_literal.__set_value(origin_value->to_string(precision, scale));
559
        (*node).__set_decimal_literal(decimal_literal);
560
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DECIMAL256, precision, scale));
561
    } else if constexpr (T == TYPE_FLOAT) {
562
        const auto* origin_value = reinterpret_cast<const float*>(data);
563
        (*node).__set_node_type(TExprNodeType::FLOAT_LITERAL);
564
        TFloatLiteral float_literal;
565
        float_literal.__set_value(*origin_value);
566
        (*node).__set_float_literal(float_literal);
567
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_FLOAT));
568
    } else if constexpr (T == TYPE_DOUBLE) {
569
        const auto* origin_value = reinterpret_cast<const double*>(data);
570
        (*node).__set_node_type(TExprNodeType::FLOAT_LITERAL);
571
        TFloatLiteral float_literal;
572
        float_literal.__set_value(*origin_value);
573
        (*node).__set_float_literal(float_literal);
574
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DOUBLE));
575
    } else if constexpr ((T == TYPE_STRING) || (T == TYPE_CHAR) || (T == TYPE_VARCHAR)) {
576
        const auto* origin_value = reinterpret_cast<const std::string*>(data);
577
        (*node).__set_node_type(TExprNodeType::STRING_LITERAL);
578
        TStringLiteral string_literal;
579
        string_literal.__set_value(*origin_value);
580
        (*node).__set_string_literal(string_literal);
581
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_STRING));
582
    } else if constexpr (T == TYPE_IPV4) {
583
        const auto* origin_value = reinterpret_cast<const IPv4*>(data);
584
        (*node).__set_node_type(TExprNodeType::IPV4_LITERAL);
585
        TIPv4Literal literal;
586
        literal.__set_value(*origin_value);
587
        (*node).__set_ipv4_literal(literal);
588
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_IPV4));
589
    } else if constexpr (T == TYPE_IPV6) {
590
        const auto* origin_value = reinterpret_cast<const IPv6*>(data);
591
        (*node).__set_node_type(TExprNodeType::IPV6_LITERAL);
592
        TIPv6Literal literal;
593
        literal.__set_value(vectorized::CastToString::from_ip(*origin_value));
594
        (*node).__set_ipv6_literal(literal);
595
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_IPV6));
596
    } else if constexpr (T == TYPE_TIMEV2) {
597
        // the code use for runtime filter but we dont support timev2 as predicate now
598
        // so this part not used
599
        const auto* origin_value = reinterpret_cast<const double*>(data);
600
        TTimeV2Literal timev2_literal;
601
        timev2_literal.__set_value(*origin_value);
602
        (*node).__set_timev2_literal(timev2_literal);
603
        (*node).__set_node_type(TExprNodeType::TIMEV2_LITERAL);
604
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_TIMEV2, precision, scale));
605
    } else if constexpr (T == TYPE_VARBINARY) {
606
        const auto* origin_value = reinterpret_cast<const std::string*>(data);
607
        (*node).__set_node_type(TExprNodeType::VARBINARY_LITERAL);
608
        TVarBinaryLiteral varbinary_literal;
609
        varbinary_literal.__set_value(*origin_value);
610
        (*node).__set_varbinary_literal(varbinary_literal);
611
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_VARBINARY));
612
    } else {
613
        return Status::InvalidArgument("Invalid argument type!");
614
    }
615
1
    return Status::OK();
616
1
}
_ZN5doris25create_texpr_literal_nodeILNS_13PrimitiveTypeE20EEENS_6StatusEPKvPNS_9TExprNodeEii
Line
Count
Source
436
1
                                 int scale = 0) {
437
    if constexpr (T == TYPE_BOOLEAN) {
438
        const auto* origin_value = reinterpret_cast<const bool*>(data);
439
        TBoolLiteral boolLiteral;
440
        (*node).__set_node_type(TExprNodeType::BOOL_LITERAL);
441
        boolLiteral.__set_value(*origin_value);
442
        (*node).__set_bool_literal(boolLiteral);
443
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_BOOLEAN));
444
    } else if constexpr (T == TYPE_TINYINT) {
445
        const auto* origin_value = reinterpret_cast<const int8_t*>(data);
446
        (*node).__set_node_type(TExprNodeType::INT_LITERAL);
447
        TIntLiteral intLiteral;
448
        intLiteral.__set_value(*origin_value);
449
        (*node).__set_int_literal(intLiteral);
450
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_TINYINT));
451
    } else if constexpr (T == TYPE_SMALLINT) {
452
        const auto* origin_value = reinterpret_cast<const int16_t*>(data);
453
        (*node).__set_node_type(TExprNodeType::INT_LITERAL);
454
        TIntLiteral intLiteral;
455
        intLiteral.__set_value(*origin_value);
456
        (*node).__set_int_literal(intLiteral);
457
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_SMALLINT));
458
    } else if constexpr (T == TYPE_INT) {
459
        const auto* origin_value = reinterpret_cast<const int32_t*>(data);
460
        (*node).__set_node_type(TExprNodeType::INT_LITERAL);
461
        TIntLiteral intLiteral;
462
        intLiteral.__set_value(*origin_value);
463
        (*node).__set_int_literal(intLiteral);
464
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_INT));
465
    } else if constexpr (T == TYPE_BIGINT) {
466
        const auto* origin_value = reinterpret_cast<const int64_t*>(data);
467
        (*node).__set_node_type(TExprNodeType::INT_LITERAL);
468
        TIntLiteral intLiteral;
469
        intLiteral.__set_value(*origin_value);
470
        (*node).__set_int_literal(intLiteral);
471
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_BIGINT));
472
    } else if constexpr (T == TYPE_LARGEINT) {
473
        const auto* origin_value = reinterpret_cast<const int128_t*>(data);
474
        (*node).__set_node_type(TExprNodeType::LARGE_INT_LITERAL);
475
        TLargeIntLiteral large_int_literal;
476
        large_int_literal.__set_value(LargeIntValue::to_string(*origin_value));
477
        (*node).__set_large_int_literal(large_int_literal);
478
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_LARGEINT));
479
    } else if constexpr ((T == TYPE_DATE) || (T == TYPE_DATETIME)) {
480
        const auto* origin_value = reinterpret_cast<const VecDateTimeValue*>(data);
481
        TDateLiteral date_literal;
482
        char convert_buffer[30];
483
        origin_value->to_string(convert_buffer);
484
        date_literal.__set_value(convert_buffer);
485
        (*node).__set_date_literal(date_literal);
486
        (*node).__set_node_type(TExprNodeType::DATE_LITERAL);
487
        if (origin_value->type() == TimeType::TIME_DATE) {
488
            (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DATE));
489
        } else if (origin_value->type() == TimeType::TIME_DATETIME) {
490
            (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DATETIME));
491
        }
492
    } else if constexpr (T == TYPE_DATEV2) {
493
        const auto* origin_value = reinterpret_cast<const DateV2Value<DateV2ValueType>*>(data);
494
        TDateLiteral date_literal;
495
        char convert_buffer[30];
496
        origin_value->to_string(convert_buffer);
497
        date_literal.__set_value(convert_buffer);
498
        (*node).__set_date_literal(date_literal);
499
        (*node).__set_node_type(TExprNodeType::DATE_LITERAL);
500
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DATEV2));
501
    } else if constexpr (T == TYPE_DATETIMEV2) {
502
        const auto* origin_value = reinterpret_cast<const DateV2Value<DateTimeV2ValueType>*>(data);
503
        TDateLiteral date_literal;
504
        char convert_buffer[30];
505
        origin_value->to_string(convert_buffer, scale);
506
        date_literal.__set_value(convert_buffer);
507
        (*node).__set_date_literal(date_literal);
508
        (*node).__set_node_type(TExprNodeType::DATE_LITERAL);
509
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DATETIMEV2, precision, scale));
510
    } else if constexpr (T == TYPE_TIMESTAMPTZ) {
511
        const auto* origin_value = reinterpret_cast<const TimestampTzValue*>(data);
512
        TDateLiteral date_literal;
513
        auto tz = cctz::utc_time_zone();
514
        auto tz_str = origin_value->to_string(tz, scale);
515
        date_literal.__set_value(tz_str);
516
        (*node).__set_date_literal(date_literal);
517
        (*node).__set_node_type(TExprNodeType::DATE_LITERAL);
518
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_TIMESTAMPTZ, precision, scale));
519
1
    } else if constexpr (T == TYPE_DECIMALV2) {
520
1
        const auto* origin_value = reinterpret_cast<const DecimalV2Value*>(data);
521
1
        (*node).__set_node_type(TExprNodeType::DECIMAL_LITERAL);
522
1
        TDecimalLiteral decimal_literal;
523
1
        decimal_literal.__set_value(origin_value->to_string());
524
1
        (*node).__set_decimal_literal(decimal_literal);
525
1
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DECIMALV2, precision, scale));
526
    } else if constexpr (T == TYPE_DECIMAL32) {
527
        const auto* origin_value = reinterpret_cast<const vectorized::Decimal<int32_t>*>(data);
528
        (*node).__set_node_type(TExprNodeType::DECIMAL_LITERAL);
529
        TDecimalLiteral decimal_literal;
530
        decimal_literal.__set_value(origin_value->to_string(precision, scale));
531
        (*node).__set_decimal_literal(decimal_literal);
532
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DECIMAL32, precision, scale));
533
    } else if constexpr (T == TYPE_DECIMAL64) {
534
        const auto* origin_value = reinterpret_cast<const vectorized::Decimal<int64_t>*>(data);
535
        (*node).__set_node_type(TExprNodeType::DECIMAL_LITERAL);
536
        TDecimalLiteral decimal_literal;
537
        decimal_literal.__set_value(origin_value->to_string(precision, scale));
538
        (*node).__set_decimal_literal(decimal_literal);
539
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DECIMAL64, precision, scale));
540
    } else if constexpr (T == TYPE_DECIMAL128I) {
541
        const auto* origin_value = reinterpret_cast<const vectorized::Decimal<int128_t>*>(data);
542
        (*node).__set_node_type(TExprNodeType::DECIMAL_LITERAL);
543
        TDecimalLiteral decimal_literal;
544
        // e.g. For a decimal(26,6) column, the initial value of the _min of the MinMax RF
545
        // on the RF producer side is an int128 value with 38 digits of 9, and this is the
546
        // final min value of the MinMax RF if the fragment instance has no data.
547
        // Need to truncate the value to the right precision and scale here, to avoid
548
        // error when casting string back to decimal later.
549
        // TODO: this is a temporary solution, the best solution is to produce the
550
        // right min max value at the producer side.
551
        decimal_literal.__set_value(origin_value->to_string(precision, scale));
552
        (*node).__set_decimal_literal(decimal_literal);
553
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DECIMAL128I, precision, scale));
554
    } else if constexpr (T == TYPE_DECIMAL256) {
555
        const auto* origin_value = reinterpret_cast<const vectorized::Decimal<wide::Int256>*>(data);
556
        (*node).__set_node_type(TExprNodeType::DECIMAL_LITERAL);
557
        TDecimalLiteral decimal_literal;
558
        decimal_literal.__set_value(origin_value->to_string(precision, scale));
559
        (*node).__set_decimal_literal(decimal_literal);
560
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DECIMAL256, precision, scale));
561
    } else if constexpr (T == TYPE_FLOAT) {
562
        const auto* origin_value = reinterpret_cast<const float*>(data);
563
        (*node).__set_node_type(TExprNodeType::FLOAT_LITERAL);
564
        TFloatLiteral float_literal;
565
        float_literal.__set_value(*origin_value);
566
        (*node).__set_float_literal(float_literal);
567
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_FLOAT));
568
    } else if constexpr (T == TYPE_DOUBLE) {
569
        const auto* origin_value = reinterpret_cast<const double*>(data);
570
        (*node).__set_node_type(TExprNodeType::FLOAT_LITERAL);
571
        TFloatLiteral float_literal;
572
        float_literal.__set_value(*origin_value);
573
        (*node).__set_float_literal(float_literal);
574
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DOUBLE));
575
    } else if constexpr ((T == TYPE_STRING) || (T == TYPE_CHAR) || (T == TYPE_VARCHAR)) {
576
        const auto* origin_value = reinterpret_cast<const std::string*>(data);
577
        (*node).__set_node_type(TExprNodeType::STRING_LITERAL);
578
        TStringLiteral string_literal;
579
        string_literal.__set_value(*origin_value);
580
        (*node).__set_string_literal(string_literal);
581
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_STRING));
582
    } else if constexpr (T == TYPE_IPV4) {
583
        const auto* origin_value = reinterpret_cast<const IPv4*>(data);
584
        (*node).__set_node_type(TExprNodeType::IPV4_LITERAL);
585
        TIPv4Literal literal;
586
        literal.__set_value(*origin_value);
587
        (*node).__set_ipv4_literal(literal);
588
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_IPV4));
589
    } else if constexpr (T == TYPE_IPV6) {
590
        const auto* origin_value = reinterpret_cast<const IPv6*>(data);
591
        (*node).__set_node_type(TExprNodeType::IPV6_LITERAL);
592
        TIPv6Literal literal;
593
        literal.__set_value(vectorized::CastToString::from_ip(*origin_value));
594
        (*node).__set_ipv6_literal(literal);
595
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_IPV6));
596
    } else if constexpr (T == TYPE_TIMEV2) {
597
        // the code use for runtime filter but we dont support timev2 as predicate now
598
        // so this part not used
599
        const auto* origin_value = reinterpret_cast<const double*>(data);
600
        TTimeV2Literal timev2_literal;
601
        timev2_literal.__set_value(*origin_value);
602
        (*node).__set_timev2_literal(timev2_literal);
603
        (*node).__set_node_type(TExprNodeType::TIMEV2_LITERAL);
604
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_TIMEV2, precision, scale));
605
    } else if constexpr (T == TYPE_VARBINARY) {
606
        const auto* origin_value = reinterpret_cast<const std::string*>(data);
607
        (*node).__set_node_type(TExprNodeType::VARBINARY_LITERAL);
608
        TVarBinaryLiteral varbinary_literal;
609
        varbinary_literal.__set_value(*origin_value);
610
        (*node).__set_varbinary_literal(varbinary_literal);
611
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_VARBINARY));
612
    } else {
613
        return Status::InvalidArgument("Invalid argument type!");
614
    }
615
1
    return Status::OK();
616
1
}
_ZN5doris25create_texpr_literal_nodeILNS_13PrimitiveTypeE28EEENS_6StatusEPKvPNS_9TExprNodeEii
Line
Count
Source
436
2
                                 int scale = 0) {
437
    if constexpr (T == TYPE_BOOLEAN) {
438
        const auto* origin_value = reinterpret_cast<const bool*>(data);
439
        TBoolLiteral boolLiteral;
440
        (*node).__set_node_type(TExprNodeType::BOOL_LITERAL);
441
        boolLiteral.__set_value(*origin_value);
442
        (*node).__set_bool_literal(boolLiteral);
443
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_BOOLEAN));
444
    } else if constexpr (T == TYPE_TINYINT) {
445
        const auto* origin_value = reinterpret_cast<const int8_t*>(data);
446
        (*node).__set_node_type(TExprNodeType::INT_LITERAL);
447
        TIntLiteral intLiteral;
448
        intLiteral.__set_value(*origin_value);
449
        (*node).__set_int_literal(intLiteral);
450
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_TINYINT));
451
    } else if constexpr (T == TYPE_SMALLINT) {
452
        const auto* origin_value = reinterpret_cast<const int16_t*>(data);
453
        (*node).__set_node_type(TExprNodeType::INT_LITERAL);
454
        TIntLiteral intLiteral;
455
        intLiteral.__set_value(*origin_value);
456
        (*node).__set_int_literal(intLiteral);
457
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_SMALLINT));
458
    } else if constexpr (T == TYPE_INT) {
459
        const auto* origin_value = reinterpret_cast<const int32_t*>(data);
460
        (*node).__set_node_type(TExprNodeType::INT_LITERAL);
461
        TIntLiteral intLiteral;
462
        intLiteral.__set_value(*origin_value);
463
        (*node).__set_int_literal(intLiteral);
464
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_INT));
465
    } else if constexpr (T == TYPE_BIGINT) {
466
        const auto* origin_value = reinterpret_cast<const int64_t*>(data);
467
        (*node).__set_node_type(TExprNodeType::INT_LITERAL);
468
        TIntLiteral intLiteral;
469
        intLiteral.__set_value(*origin_value);
470
        (*node).__set_int_literal(intLiteral);
471
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_BIGINT));
472
    } else if constexpr (T == TYPE_LARGEINT) {
473
        const auto* origin_value = reinterpret_cast<const int128_t*>(data);
474
        (*node).__set_node_type(TExprNodeType::LARGE_INT_LITERAL);
475
        TLargeIntLiteral large_int_literal;
476
        large_int_literal.__set_value(LargeIntValue::to_string(*origin_value));
477
        (*node).__set_large_int_literal(large_int_literal);
478
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_LARGEINT));
479
    } else if constexpr ((T == TYPE_DATE) || (T == TYPE_DATETIME)) {
480
        const auto* origin_value = reinterpret_cast<const VecDateTimeValue*>(data);
481
        TDateLiteral date_literal;
482
        char convert_buffer[30];
483
        origin_value->to_string(convert_buffer);
484
        date_literal.__set_value(convert_buffer);
485
        (*node).__set_date_literal(date_literal);
486
        (*node).__set_node_type(TExprNodeType::DATE_LITERAL);
487
        if (origin_value->type() == TimeType::TIME_DATE) {
488
            (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DATE));
489
        } else if (origin_value->type() == TimeType::TIME_DATETIME) {
490
            (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DATETIME));
491
        }
492
    } else if constexpr (T == TYPE_DATEV2) {
493
        const auto* origin_value = reinterpret_cast<const DateV2Value<DateV2ValueType>*>(data);
494
        TDateLiteral date_literal;
495
        char convert_buffer[30];
496
        origin_value->to_string(convert_buffer);
497
        date_literal.__set_value(convert_buffer);
498
        (*node).__set_date_literal(date_literal);
499
        (*node).__set_node_type(TExprNodeType::DATE_LITERAL);
500
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DATEV2));
501
    } else if constexpr (T == TYPE_DATETIMEV2) {
502
        const auto* origin_value = reinterpret_cast<const DateV2Value<DateTimeV2ValueType>*>(data);
503
        TDateLiteral date_literal;
504
        char convert_buffer[30];
505
        origin_value->to_string(convert_buffer, scale);
506
        date_literal.__set_value(convert_buffer);
507
        (*node).__set_date_literal(date_literal);
508
        (*node).__set_node_type(TExprNodeType::DATE_LITERAL);
509
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DATETIMEV2, precision, scale));
510
    } else if constexpr (T == TYPE_TIMESTAMPTZ) {
511
        const auto* origin_value = reinterpret_cast<const TimestampTzValue*>(data);
512
        TDateLiteral date_literal;
513
        auto tz = cctz::utc_time_zone();
514
        auto tz_str = origin_value->to_string(tz, scale);
515
        date_literal.__set_value(tz_str);
516
        (*node).__set_date_literal(date_literal);
517
        (*node).__set_node_type(TExprNodeType::DATE_LITERAL);
518
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_TIMESTAMPTZ, precision, scale));
519
    } else if constexpr (T == TYPE_DECIMALV2) {
520
        const auto* origin_value = reinterpret_cast<const DecimalV2Value*>(data);
521
        (*node).__set_node_type(TExprNodeType::DECIMAL_LITERAL);
522
        TDecimalLiteral decimal_literal;
523
        decimal_literal.__set_value(origin_value->to_string());
524
        (*node).__set_decimal_literal(decimal_literal);
525
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DECIMALV2, precision, scale));
526
2
    } else if constexpr (T == TYPE_DECIMAL32) {
527
2
        const auto* origin_value = reinterpret_cast<const vectorized::Decimal<int32_t>*>(data);
528
2
        (*node).__set_node_type(TExprNodeType::DECIMAL_LITERAL);
529
2
        TDecimalLiteral decimal_literal;
530
2
        decimal_literal.__set_value(origin_value->to_string(precision, scale));
531
2
        (*node).__set_decimal_literal(decimal_literal);
532
2
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DECIMAL32, precision, scale));
533
    } else if constexpr (T == TYPE_DECIMAL64) {
534
        const auto* origin_value = reinterpret_cast<const vectorized::Decimal<int64_t>*>(data);
535
        (*node).__set_node_type(TExprNodeType::DECIMAL_LITERAL);
536
        TDecimalLiteral decimal_literal;
537
        decimal_literal.__set_value(origin_value->to_string(precision, scale));
538
        (*node).__set_decimal_literal(decimal_literal);
539
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DECIMAL64, precision, scale));
540
    } else if constexpr (T == TYPE_DECIMAL128I) {
541
        const auto* origin_value = reinterpret_cast<const vectorized::Decimal<int128_t>*>(data);
542
        (*node).__set_node_type(TExprNodeType::DECIMAL_LITERAL);
543
        TDecimalLiteral decimal_literal;
544
        // e.g. For a decimal(26,6) column, the initial value of the _min of the MinMax RF
545
        // on the RF producer side is an int128 value with 38 digits of 9, and this is the
546
        // final min value of the MinMax RF if the fragment instance has no data.
547
        // Need to truncate the value to the right precision and scale here, to avoid
548
        // error when casting string back to decimal later.
549
        // TODO: this is a temporary solution, the best solution is to produce the
550
        // right min max value at the producer side.
551
        decimal_literal.__set_value(origin_value->to_string(precision, scale));
552
        (*node).__set_decimal_literal(decimal_literal);
553
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DECIMAL128I, precision, scale));
554
    } else if constexpr (T == TYPE_DECIMAL256) {
555
        const auto* origin_value = reinterpret_cast<const vectorized::Decimal<wide::Int256>*>(data);
556
        (*node).__set_node_type(TExprNodeType::DECIMAL_LITERAL);
557
        TDecimalLiteral decimal_literal;
558
        decimal_literal.__set_value(origin_value->to_string(precision, scale));
559
        (*node).__set_decimal_literal(decimal_literal);
560
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DECIMAL256, precision, scale));
561
    } else if constexpr (T == TYPE_FLOAT) {
562
        const auto* origin_value = reinterpret_cast<const float*>(data);
563
        (*node).__set_node_type(TExprNodeType::FLOAT_LITERAL);
564
        TFloatLiteral float_literal;
565
        float_literal.__set_value(*origin_value);
566
        (*node).__set_float_literal(float_literal);
567
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_FLOAT));
568
    } else if constexpr (T == TYPE_DOUBLE) {
569
        const auto* origin_value = reinterpret_cast<const double*>(data);
570
        (*node).__set_node_type(TExprNodeType::FLOAT_LITERAL);
571
        TFloatLiteral float_literal;
572
        float_literal.__set_value(*origin_value);
573
        (*node).__set_float_literal(float_literal);
574
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DOUBLE));
575
    } else if constexpr ((T == TYPE_STRING) || (T == TYPE_CHAR) || (T == TYPE_VARCHAR)) {
576
        const auto* origin_value = reinterpret_cast<const std::string*>(data);
577
        (*node).__set_node_type(TExprNodeType::STRING_LITERAL);
578
        TStringLiteral string_literal;
579
        string_literal.__set_value(*origin_value);
580
        (*node).__set_string_literal(string_literal);
581
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_STRING));
582
    } else if constexpr (T == TYPE_IPV4) {
583
        const auto* origin_value = reinterpret_cast<const IPv4*>(data);
584
        (*node).__set_node_type(TExprNodeType::IPV4_LITERAL);
585
        TIPv4Literal literal;
586
        literal.__set_value(*origin_value);
587
        (*node).__set_ipv4_literal(literal);
588
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_IPV4));
589
    } else if constexpr (T == TYPE_IPV6) {
590
        const auto* origin_value = reinterpret_cast<const IPv6*>(data);
591
        (*node).__set_node_type(TExprNodeType::IPV6_LITERAL);
592
        TIPv6Literal literal;
593
        literal.__set_value(vectorized::CastToString::from_ip(*origin_value));
594
        (*node).__set_ipv6_literal(literal);
595
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_IPV6));
596
    } else if constexpr (T == TYPE_TIMEV2) {
597
        // the code use for runtime filter but we dont support timev2 as predicate now
598
        // so this part not used
599
        const auto* origin_value = reinterpret_cast<const double*>(data);
600
        TTimeV2Literal timev2_literal;
601
        timev2_literal.__set_value(*origin_value);
602
        (*node).__set_timev2_literal(timev2_literal);
603
        (*node).__set_node_type(TExprNodeType::TIMEV2_LITERAL);
604
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_TIMEV2, precision, scale));
605
    } else if constexpr (T == TYPE_VARBINARY) {
606
        const auto* origin_value = reinterpret_cast<const std::string*>(data);
607
        (*node).__set_node_type(TExprNodeType::VARBINARY_LITERAL);
608
        TVarBinaryLiteral varbinary_literal;
609
        varbinary_literal.__set_value(*origin_value);
610
        (*node).__set_varbinary_literal(varbinary_literal);
611
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_VARBINARY));
612
    } else {
613
        return Status::InvalidArgument("Invalid argument type!");
614
    }
615
2
    return Status::OK();
616
2
}
_ZN5doris25create_texpr_literal_nodeILNS_13PrimitiveTypeE29EEENS_6StatusEPKvPNS_9TExprNodeEii
Line
Count
Source
436
2
                                 int scale = 0) {
437
    if constexpr (T == TYPE_BOOLEAN) {
438
        const auto* origin_value = reinterpret_cast<const bool*>(data);
439
        TBoolLiteral boolLiteral;
440
        (*node).__set_node_type(TExprNodeType::BOOL_LITERAL);
441
        boolLiteral.__set_value(*origin_value);
442
        (*node).__set_bool_literal(boolLiteral);
443
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_BOOLEAN));
444
    } else if constexpr (T == TYPE_TINYINT) {
445
        const auto* origin_value = reinterpret_cast<const int8_t*>(data);
446
        (*node).__set_node_type(TExprNodeType::INT_LITERAL);
447
        TIntLiteral intLiteral;
448
        intLiteral.__set_value(*origin_value);
449
        (*node).__set_int_literal(intLiteral);
450
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_TINYINT));
451
    } else if constexpr (T == TYPE_SMALLINT) {
452
        const auto* origin_value = reinterpret_cast<const int16_t*>(data);
453
        (*node).__set_node_type(TExprNodeType::INT_LITERAL);
454
        TIntLiteral intLiteral;
455
        intLiteral.__set_value(*origin_value);
456
        (*node).__set_int_literal(intLiteral);
457
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_SMALLINT));
458
    } else if constexpr (T == TYPE_INT) {
459
        const auto* origin_value = reinterpret_cast<const int32_t*>(data);
460
        (*node).__set_node_type(TExprNodeType::INT_LITERAL);
461
        TIntLiteral intLiteral;
462
        intLiteral.__set_value(*origin_value);
463
        (*node).__set_int_literal(intLiteral);
464
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_INT));
465
    } else if constexpr (T == TYPE_BIGINT) {
466
        const auto* origin_value = reinterpret_cast<const int64_t*>(data);
467
        (*node).__set_node_type(TExprNodeType::INT_LITERAL);
468
        TIntLiteral intLiteral;
469
        intLiteral.__set_value(*origin_value);
470
        (*node).__set_int_literal(intLiteral);
471
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_BIGINT));
472
    } else if constexpr (T == TYPE_LARGEINT) {
473
        const auto* origin_value = reinterpret_cast<const int128_t*>(data);
474
        (*node).__set_node_type(TExprNodeType::LARGE_INT_LITERAL);
475
        TLargeIntLiteral large_int_literal;
476
        large_int_literal.__set_value(LargeIntValue::to_string(*origin_value));
477
        (*node).__set_large_int_literal(large_int_literal);
478
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_LARGEINT));
479
    } else if constexpr ((T == TYPE_DATE) || (T == TYPE_DATETIME)) {
480
        const auto* origin_value = reinterpret_cast<const VecDateTimeValue*>(data);
481
        TDateLiteral date_literal;
482
        char convert_buffer[30];
483
        origin_value->to_string(convert_buffer);
484
        date_literal.__set_value(convert_buffer);
485
        (*node).__set_date_literal(date_literal);
486
        (*node).__set_node_type(TExprNodeType::DATE_LITERAL);
487
        if (origin_value->type() == TimeType::TIME_DATE) {
488
            (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DATE));
489
        } else if (origin_value->type() == TimeType::TIME_DATETIME) {
490
            (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DATETIME));
491
        }
492
    } else if constexpr (T == TYPE_DATEV2) {
493
        const auto* origin_value = reinterpret_cast<const DateV2Value<DateV2ValueType>*>(data);
494
        TDateLiteral date_literal;
495
        char convert_buffer[30];
496
        origin_value->to_string(convert_buffer);
497
        date_literal.__set_value(convert_buffer);
498
        (*node).__set_date_literal(date_literal);
499
        (*node).__set_node_type(TExprNodeType::DATE_LITERAL);
500
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DATEV2));
501
    } else if constexpr (T == TYPE_DATETIMEV2) {
502
        const auto* origin_value = reinterpret_cast<const DateV2Value<DateTimeV2ValueType>*>(data);
503
        TDateLiteral date_literal;
504
        char convert_buffer[30];
505
        origin_value->to_string(convert_buffer, scale);
506
        date_literal.__set_value(convert_buffer);
507
        (*node).__set_date_literal(date_literal);
508
        (*node).__set_node_type(TExprNodeType::DATE_LITERAL);
509
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DATETIMEV2, precision, scale));
510
    } else if constexpr (T == TYPE_TIMESTAMPTZ) {
511
        const auto* origin_value = reinterpret_cast<const TimestampTzValue*>(data);
512
        TDateLiteral date_literal;
513
        auto tz = cctz::utc_time_zone();
514
        auto tz_str = origin_value->to_string(tz, scale);
515
        date_literal.__set_value(tz_str);
516
        (*node).__set_date_literal(date_literal);
517
        (*node).__set_node_type(TExprNodeType::DATE_LITERAL);
518
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_TIMESTAMPTZ, precision, scale));
519
    } else if constexpr (T == TYPE_DECIMALV2) {
520
        const auto* origin_value = reinterpret_cast<const DecimalV2Value*>(data);
521
        (*node).__set_node_type(TExprNodeType::DECIMAL_LITERAL);
522
        TDecimalLiteral decimal_literal;
523
        decimal_literal.__set_value(origin_value->to_string());
524
        (*node).__set_decimal_literal(decimal_literal);
525
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DECIMALV2, precision, scale));
526
    } else if constexpr (T == TYPE_DECIMAL32) {
527
        const auto* origin_value = reinterpret_cast<const vectorized::Decimal<int32_t>*>(data);
528
        (*node).__set_node_type(TExprNodeType::DECIMAL_LITERAL);
529
        TDecimalLiteral decimal_literal;
530
        decimal_literal.__set_value(origin_value->to_string(precision, scale));
531
        (*node).__set_decimal_literal(decimal_literal);
532
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DECIMAL32, precision, scale));
533
2
    } else if constexpr (T == TYPE_DECIMAL64) {
534
2
        const auto* origin_value = reinterpret_cast<const vectorized::Decimal<int64_t>*>(data);
535
2
        (*node).__set_node_type(TExprNodeType::DECIMAL_LITERAL);
536
2
        TDecimalLiteral decimal_literal;
537
2
        decimal_literal.__set_value(origin_value->to_string(precision, scale));
538
2
        (*node).__set_decimal_literal(decimal_literal);
539
2
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DECIMAL64, precision, scale));
540
    } else if constexpr (T == TYPE_DECIMAL128I) {
541
        const auto* origin_value = reinterpret_cast<const vectorized::Decimal<int128_t>*>(data);
542
        (*node).__set_node_type(TExprNodeType::DECIMAL_LITERAL);
543
        TDecimalLiteral decimal_literal;
544
        // e.g. For a decimal(26,6) column, the initial value of the _min of the MinMax RF
545
        // on the RF producer side is an int128 value with 38 digits of 9, and this is the
546
        // final min value of the MinMax RF if the fragment instance has no data.
547
        // Need to truncate the value to the right precision and scale here, to avoid
548
        // error when casting string back to decimal later.
549
        // TODO: this is a temporary solution, the best solution is to produce the
550
        // right min max value at the producer side.
551
        decimal_literal.__set_value(origin_value->to_string(precision, scale));
552
        (*node).__set_decimal_literal(decimal_literal);
553
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DECIMAL128I, precision, scale));
554
    } else if constexpr (T == TYPE_DECIMAL256) {
555
        const auto* origin_value = reinterpret_cast<const vectorized::Decimal<wide::Int256>*>(data);
556
        (*node).__set_node_type(TExprNodeType::DECIMAL_LITERAL);
557
        TDecimalLiteral decimal_literal;
558
        decimal_literal.__set_value(origin_value->to_string(precision, scale));
559
        (*node).__set_decimal_literal(decimal_literal);
560
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DECIMAL256, precision, scale));
561
    } else if constexpr (T == TYPE_FLOAT) {
562
        const auto* origin_value = reinterpret_cast<const float*>(data);
563
        (*node).__set_node_type(TExprNodeType::FLOAT_LITERAL);
564
        TFloatLiteral float_literal;
565
        float_literal.__set_value(*origin_value);
566
        (*node).__set_float_literal(float_literal);
567
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_FLOAT));
568
    } else if constexpr (T == TYPE_DOUBLE) {
569
        const auto* origin_value = reinterpret_cast<const double*>(data);
570
        (*node).__set_node_type(TExprNodeType::FLOAT_LITERAL);
571
        TFloatLiteral float_literal;
572
        float_literal.__set_value(*origin_value);
573
        (*node).__set_float_literal(float_literal);
574
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DOUBLE));
575
    } else if constexpr ((T == TYPE_STRING) || (T == TYPE_CHAR) || (T == TYPE_VARCHAR)) {
576
        const auto* origin_value = reinterpret_cast<const std::string*>(data);
577
        (*node).__set_node_type(TExprNodeType::STRING_LITERAL);
578
        TStringLiteral string_literal;
579
        string_literal.__set_value(*origin_value);
580
        (*node).__set_string_literal(string_literal);
581
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_STRING));
582
    } else if constexpr (T == TYPE_IPV4) {
583
        const auto* origin_value = reinterpret_cast<const IPv4*>(data);
584
        (*node).__set_node_type(TExprNodeType::IPV4_LITERAL);
585
        TIPv4Literal literal;
586
        literal.__set_value(*origin_value);
587
        (*node).__set_ipv4_literal(literal);
588
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_IPV4));
589
    } else if constexpr (T == TYPE_IPV6) {
590
        const auto* origin_value = reinterpret_cast<const IPv6*>(data);
591
        (*node).__set_node_type(TExprNodeType::IPV6_LITERAL);
592
        TIPv6Literal literal;
593
        literal.__set_value(vectorized::CastToString::from_ip(*origin_value));
594
        (*node).__set_ipv6_literal(literal);
595
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_IPV6));
596
    } else if constexpr (T == TYPE_TIMEV2) {
597
        // the code use for runtime filter but we dont support timev2 as predicate now
598
        // so this part not used
599
        const auto* origin_value = reinterpret_cast<const double*>(data);
600
        TTimeV2Literal timev2_literal;
601
        timev2_literal.__set_value(*origin_value);
602
        (*node).__set_timev2_literal(timev2_literal);
603
        (*node).__set_node_type(TExprNodeType::TIMEV2_LITERAL);
604
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_TIMEV2, precision, scale));
605
    } else if constexpr (T == TYPE_VARBINARY) {
606
        const auto* origin_value = reinterpret_cast<const std::string*>(data);
607
        (*node).__set_node_type(TExprNodeType::VARBINARY_LITERAL);
608
        TVarBinaryLiteral varbinary_literal;
609
        varbinary_literal.__set_value(*origin_value);
610
        (*node).__set_varbinary_literal(varbinary_literal);
611
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_VARBINARY));
612
    } else {
613
        return Status::InvalidArgument("Invalid argument type!");
614
    }
615
2
    return Status::OK();
616
2
}
_ZN5doris25create_texpr_literal_nodeILNS_13PrimitiveTypeE30EEENS_6StatusEPKvPNS_9TExprNodeEii
Line
Count
Source
436
2
                                 int scale = 0) {
437
    if constexpr (T == TYPE_BOOLEAN) {
438
        const auto* origin_value = reinterpret_cast<const bool*>(data);
439
        TBoolLiteral boolLiteral;
440
        (*node).__set_node_type(TExprNodeType::BOOL_LITERAL);
441
        boolLiteral.__set_value(*origin_value);
442
        (*node).__set_bool_literal(boolLiteral);
443
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_BOOLEAN));
444
    } else if constexpr (T == TYPE_TINYINT) {
445
        const auto* origin_value = reinterpret_cast<const int8_t*>(data);
446
        (*node).__set_node_type(TExprNodeType::INT_LITERAL);
447
        TIntLiteral intLiteral;
448
        intLiteral.__set_value(*origin_value);
449
        (*node).__set_int_literal(intLiteral);
450
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_TINYINT));
451
    } else if constexpr (T == TYPE_SMALLINT) {
452
        const auto* origin_value = reinterpret_cast<const int16_t*>(data);
453
        (*node).__set_node_type(TExprNodeType::INT_LITERAL);
454
        TIntLiteral intLiteral;
455
        intLiteral.__set_value(*origin_value);
456
        (*node).__set_int_literal(intLiteral);
457
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_SMALLINT));
458
    } else if constexpr (T == TYPE_INT) {
459
        const auto* origin_value = reinterpret_cast<const int32_t*>(data);
460
        (*node).__set_node_type(TExprNodeType::INT_LITERAL);
461
        TIntLiteral intLiteral;
462
        intLiteral.__set_value(*origin_value);
463
        (*node).__set_int_literal(intLiteral);
464
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_INT));
465
    } else if constexpr (T == TYPE_BIGINT) {
466
        const auto* origin_value = reinterpret_cast<const int64_t*>(data);
467
        (*node).__set_node_type(TExprNodeType::INT_LITERAL);
468
        TIntLiteral intLiteral;
469
        intLiteral.__set_value(*origin_value);
470
        (*node).__set_int_literal(intLiteral);
471
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_BIGINT));
472
    } else if constexpr (T == TYPE_LARGEINT) {
473
        const auto* origin_value = reinterpret_cast<const int128_t*>(data);
474
        (*node).__set_node_type(TExprNodeType::LARGE_INT_LITERAL);
475
        TLargeIntLiteral large_int_literal;
476
        large_int_literal.__set_value(LargeIntValue::to_string(*origin_value));
477
        (*node).__set_large_int_literal(large_int_literal);
478
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_LARGEINT));
479
    } else if constexpr ((T == TYPE_DATE) || (T == TYPE_DATETIME)) {
480
        const auto* origin_value = reinterpret_cast<const VecDateTimeValue*>(data);
481
        TDateLiteral date_literal;
482
        char convert_buffer[30];
483
        origin_value->to_string(convert_buffer);
484
        date_literal.__set_value(convert_buffer);
485
        (*node).__set_date_literal(date_literal);
486
        (*node).__set_node_type(TExprNodeType::DATE_LITERAL);
487
        if (origin_value->type() == TimeType::TIME_DATE) {
488
            (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DATE));
489
        } else if (origin_value->type() == TimeType::TIME_DATETIME) {
490
            (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DATETIME));
491
        }
492
    } else if constexpr (T == TYPE_DATEV2) {
493
        const auto* origin_value = reinterpret_cast<const DateV2Value<DateV2ValueType>*>(data);
494
        TDateLiteral date_literal;
495
        char convert_buffer[30];
496
        origin_value->to_string(convert_buffer);
497
        date_literal.__set_value(convert_buffer);
498
        (*node).__set_date_literal(date_literal);
499
        (*node).__set_node_type(TExprNodeType::DATE_LITERAL);
500
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DATEV2));
501
    } else if constexpr (T == TYPE_DATETIMEV2) {
502
        const auto* origin_value = reinterpret_cast<const DateV2Value<DateTimeV2ValueType>*>(data);
503
        TDateLiteral date_literal;
504
        char convert_buffer[30];
505
        origin_value->to_string(convert_buffer, scale);
506
        date_literal.__set_value(convert_buffer);
507
        (*node).__set_date_literal(date_literal);
508
        (*node).__set_node_type(TExprNodeType::DATE_LITERAL);
509
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DATETIMEV2, precision, scale));
510
    } else if constexpr (T == TYPE_TIMESTAMPTZ) {
511
        const auto* origin_value = reinterpret_cast<const TimestampTzValue*>(data);
512
        TDateLiteral date_literal;
513
        auto tz = cctz::utc_time_zone();
514
        auto tz_str = origin_value->to_string(tz, scale);
515
        date_literal.__set_value(tz_str);
516
        (*node).__set_date_literal(date_literal);
517
        (*node).__set_node_type(TExprNodeType::DATE_LITERAL);
518
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_TIMESTAMPTZ, precision, scale));
519
    } else if constexpr (T == TYPE_DECIMALV2) {
520
        const auto* origin_value = reinterpret_cast<const DecimalV2Value*>(data);
521
        (*node).__set_node_type(TExprNodeType::DECIMAL_LITERAL);
522
        TDecimalLiteral decimal_literal;
523
        decimal_literal.__set_value(origin_value->to_string());
524
        (*node).__set_decimal_literal(decimal_literal);
525
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DECIMALV2, precision, scale));
526
    } else if constexpr (T == TYPE_DECIMAL32) {
527
        const auto* origin_value = reinterpret_cast<const vectorized::Decimal<int32_t>*>(data);
528
        (*node).__set_node_type(TExprNodeType::DECIMAL_LITERAL);
529
        TDecimalLiteral decimal_literal;
530
        decimal_literal.__set_value(origin_value->to_string(precision, scale));
531
        (*node).__set_decimal_literal(decimal_literal);
532
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DECIMAL32, precision, scale));
533
    } else if constexpr (T == TYPE_DECIMAL64) {
534
        const auto* origin_value = reinterpret_cast<const vectorized::Decimal<int64_t>*>(data);
535
        (*node).__set_node_type(TExprNodeType::DECIMAL_LITERAL);
536
        TDecimalLiteral decimal_literal;
537
        decimal_literal.__set_value(origin_value->to_string(precision, scale));
538
        (*node).__set_decimal_literal(decimal_literal);
539
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DECIMAL64, precision, scale));
540
2
    } else if constexpr (T == TYPE_DECIMAL128I) {
541
2
        const auto* origin_value = reinterpret_cast<const vectorized::Decimal<int128_t>*>(data);
542
2
        (*node).__set_node_type(TExprNodeType::DECIMAL_LITERAL);
543
2
        TDecimalLiteral decimal_literal;
544
        // e.g. For a decimal(26,6) column, the initial value of the _min of the MinMax RF
545
        // on the RF producer side is an int128 value with 38 digits of 9, and this is the
546
        // final min value of the MinMax RF if the fragment instance has no data.
547
        // Need to truncate the value to the right precision and scale here, to avoid
548
        // error when casting string back to decimal later.
549
        // TODO: this is a temporary solution, the best solution is to produce the
550
        // right min max value at the producer side.
551
2
        decimal_literal.__set_value(origin_value->to_string(precision, scale));
552
2
        (*node).__set_decimal_literal(decimal_literal);
553
2
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DECIMAL128I, precision, scale));
554
    } else if constexpr (T == TYPE_DECIMAL256) {
555
        const auto* origin_value = reinterpret_cast<const vectorized::Decimal<wide::Int256>*>(data);
556
        (*node).__set_node_type(TExprNodeType::DECIMAL_LITERAL);
557
        TDecimalLiteral decimal_literal;
558
        decimal_literal.__set_value(origin_value->to_string(precision, scale));
559
        (*node).__set_decimal_literal(decimal_literal);
560
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DECIMAL256, precision, scale));
561
    } else if constexpr (T == TYPE_FLOAT) {
562
        const auto* origin_value = reinterpret_cast<const float*>(data);
563
        (*node).__set_node_type(TExprNodeType::FLOAT_LITERAL);
564
        TFloatLiteral float_literal;
565
        float_literal.__set_value(*origin_value);
566
        (*node).__set_float_literal(float_literal);
567
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_FLOAT));
568
    } else if constexpr (T == TYPE_DOUBLE) {
569
        const auto* origin_value = reinterpret_cast<const double*>(data);
570
        (*node).__set_node_type(TExprNodeType::FLOAT_LITERAL);
571
        TFloatLiteral float_literal;
572
        float_literal.__set_value(*origin_value);
573
        (*node).__set_float_literal(float_literal);
574
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DOUBLE));
575
    } else if constexpr ((T == TYPE_STRING) || (T == TYPE_CHAR) || (T == TYPE_VARCHAR)) {
576
        const auto* origin_value = reinterpret_cast<const std::string*>(data);
577
        (*node).__set_node_type(TExprNodeType::STRING_LITERAL);
578
        TStringLiteral string_literal;
579
        string_literal.__set_value(*origin_value);
580
        (*node).__set_string_literal(string_literal);
581
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_STRING));
582
    } else if constexpr (T == TYPE_IPV4) {
583
        const auto* origin_value = reinterpret_cast<const IPv4*>(data);
584
        (*node).__set_node_type(TExprNodeType::IPV4_LITERAL);
585
        TIPv4Literal literal;
586
        literal.__set_value(*origin_value);
587
        (*node).__set_ipv4_literal(literal);
588
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_IPV4));
589
    } else if constexpr (T == TYPE_IPV6) {
590
        const auto* origin_value = reinterpret_cast<const IPv6*>(data);
591
        (*node).__set_node_type(TExprNodeType::IPV6_LITERAL);
592
        TIPv6Literal literal;
593
        literal.__set_value(vectorized::CastToString::from_ip(*origin_value));
594
        (*node).__set_ipv6_literal(literal);
595
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_IPV6));
596
    } else if constexpr (T == TYPE_TIMEV2) {
597
        // the code use for runtime filter but we dont support timev2 as predicate now
598
        // so this part not used
599
        const auto* origin_value = reinterpret_cast<const double*>(data);
600
        TTimeV2Literal timev2_literal;
601
        timev2_literal.__set_value(*origin_value);
602
        (*node).__set_timev2_literal(timev2_literal);
603
        (*node).__set_node_type(TExprNodeType::TIMEV2_LITERAL);
604
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_TIMEV2, precision, scale));
605
    } else if constexpr (T == TYPE_VARBINARY) {
606
        const auto* origin_value = reinterpret_cast<const std::string*>(data);
607
        (*node).__set_node_type(TExprNodeType::VARBINARY_LITERAL);
608
        TVarBinaryLiteral varbinary_literal;
609
        varbinary_literal.__set_value(*origin_value);
610
        (*node).__set_varbinary_literal(varbinary_literal);
611
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_VARBINARY));
612
    } else {
613
        return Status::InvalidArgument("Invalid argument type!");
614
    }
615
2
    return Status::OK();
616
2
}
_ZN5doris25create_texpr_literal_nodeILNS_13PrimitiveTypeE35EEENS_6StatusEPKvPNS_9TExprNodeEii
Line
Count
Source
436
2
                                 int scale = 0) {
437
    if constexpr (T == TYPE_BOOLEAN) {
438
        const auto* origin_value = reinterpret_cast<const bool*>(data);
439
        TBoolLiteral boolLiteral;
440
        (*node).__set_node_type(TExprNodeType::BOOL_LITERAL);
441
        boolLiteral.__set_value(*origin_value);
442
        (*node).__set_bool_literal(boolLiteral);
443
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_BOOLEAN));
444
    } else if constexpr (T == TYPE_TINYINT) {
445
        const auto* origin_value = reinterpret_cast<const int8_t*>(data);
446
        (*node).__set_node_type(TExprNodeType::INT_LITERAL);
447
        TIntLiteral intLiteral;
448
        intLiteral.__set_value(*origin_value);
449
        (*node).__set_int_literal(intLiteral);
450
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_TINYINT));
451
    } else if constexpr (T == TYPE_SMALLINT) {
452
        const auto* origin_value = reinterpret_cast<const int16_t*>(data);
453
        (*node).__set_node_type(TExprNodeType::INT_LITERAL);
454
        TIntLiteral intLiteral;
455
        intLiteral.__set_value(*origin_value);
456
        (*node).__set_int_literal(intLiteral);
457
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_SMALLINT));
458
    } else if constexpr (T == TYPE_INT) {
459
        const auto* origin_value = reinterpret_cast<const int32_t*>(data);
460
        (*node).__set_node_type(TExprNodeType::INT_LITERAL);
461
        TIntLiteral intLiteral;
462
        intLiteral.__set_value(*origin_value);
463
        (*node).__set_int_literal(intLiteral);
464
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_INT));
465
    } else if constexpr (T == TYPE_BIGINT) {
466
        const auto* origin_value = reinterpret_cast<const int64_t*>(data);
467
        (*node).__set_node_type(TExprNodeType::INT_LITERAL);
468
        TIntLiteral intLiteral;
469
        intLiteral.__set_value(*origin_value);
470
        (*node).__set_int_literal(intLiteral);
471
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_BIGINT));
472
    } else if constexpr (T == TYPE_LARGEINT) {
473
        const auto* origin_value = reinterpret_cast<const int128_t*>(data);
474
        (*node).__set_node_type(TExprNodeType::LARGE_INT_LITERAL);
475
        TLargeIntLiteral large_int_literal;
476
        large_int_literal.__set_value(LargeIntValue::to_string(*origin_value));
477
        (*node).__set_large_int_literal(large_int_literal);
478
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_LARGEINT));
479
    } else if constexpr ((T == TYPE_DATE) || (T == TYPE_DATETIME)) {
480
        const auto* origin_value = reinterpret_cast<const VecDateTimeValue*>(data);
481
        TDateLiteral date_literal;
482
        char convert_buffer[30];
483
        origin_value->to_string(convert_buffer);
484
        date_literal.__set_value(convert_buffer);
485
        (*node).__set_date_literal(date_literal);
486
        (*node).__set_node_type(TExprNodeType::DATE_LITERAL);
487
        if (origin_value->type() == TimeType::TIME_DATE) {
488
            (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DATE));
489
        } else if (origin_value->type() == TimeType::TIME_DATETIME) {
490
            (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DATETIME));
491
        }
492
    } else if constexpr (T == TYPE_DATEV2) {
493
        const auto* origin_value = reinterpret_cast<const DateV2Value<DateV2ValueType>*>(data);
494
        TDateLiteral date_literal;
495
        char convert_buffer[30];
496
        origin_value->to_string(convert_buffer);
497
        date_literal.__set_value(convert_buffer);
498
        (*node).__set_date_literal(date_literal);
499
        (*node).__set_node_type(TExprNodeType::DATE_LITERAL);
500
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DATEV2));
501
    } else if constexpr (T == TYPE_DATETIMEV2) {
502
        const auto* origin_value = reinterpret_cast<const DateV2Value<DateTimeV2ValueType>*>(data);
503
        TDateLiteral date_literal;
504
        char convert_buffer[30];
505
        origin_value->to_string(convert_buffer, scale);
506
        date_literal.__set_value(convert_buffer);
507
        (*node).__set_date_literal(date_literal);
508
        (*node).__set_node_type(TExprNodeType::DATE_LITERAL);
509
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DATETIMEV2, precision, scale));
510
    } else if constexpr (T == TYPE_TIMESTAMPTZ) {
511
        const auto* origin_value = reinterpret_cast<const TimestampTzValue*>(data);
512
        TDateLiteral date_literal;
513
        auto tz = cctz::utc_time_zone();
514
        auto tz_str = origin_value->to_string(tz, scale);
515
        date_literal.__set_value(tz_str);
516
        (*node).__set_date_literal(date_literal);
517
        (*node).__set_node_type(TExprNodeType::DATE_LITERAL);
518
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_TIMESTAMPTZ, precision, scale));
519
    } else if constexpr (T == TYPE_DECIMALV2) {
520
        const auto* origin_value = reinterpret_cast<const DecimalV2Value*>(data);
521
        (*node).__set_node_type(TExprNodeType::DECIMAL_LITERAL);
522
        TDecimalLiteral decimal_literal;
523
        decimal_literal.__set_value(origin_value->to_string());
524
        (*node).__set_decimal_literal(decimal_literal);
525
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DECIMALV2, precision, scale));
526
    } else if constexpr (T == TYPE_DECIMAL32) {
527
        const auto* origin_value = reinterpret_cast<const vectorized::Decimal<int32_t>*>(data);
528
        (*node).__set_node_type(TExprNodeType::DECIMAL_LITERAL);
529
        TDecimalLiteral decimal_literal;
530
        decimal_literal.__set_value(origin_value->to_string(precision, scale));
531
        (*node).__set_decimal_literal(decimal_literal);
532
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DECIMAL32, precision, scale));
533
    } else if constexpr (T == TYPE_DECIMAL64) {
534
        const auto* origin_value = reinterpret_cast<const vectorized::Decimal<int64_t>*>(data);
535
        (*node).__set_node_type(TExprNodeType::DECIMAL_LITERAL);
536
        TDecimalLiteral decimal_literal;
537
        decimal_literal.__set_value(origin_value->to_string(precision, scale));
538
        (*node).__set_decimal_literal(decimal_literal);
539
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DECIMAL64, precision, scale));
540
    } else if constexpr (T == TYPE_DECIMAL128I) {
541
        const auto* origin_value = reinterpret_cast<const vectorized::Decimal<int128_t>*>(data);
542
        (*node).__set_node_type(TExprNodeType::DECIMAL_LITERAL);
543
        TDecimalLiteral decimal_literal;
544
        // e.g. For a decimal(26,6) column, the initial value of the _min of the MinMax RF
545
        // on the RF producer side is an int128 value with 38 digits of 9, and this is the
546
        // final min value of the MinMax RF if the fragment instance has no data.
547
        // Need to truncate the value to the right precision and scale here, to avoid
548
        // error when casting string back to decimal later.
549
        // TODO: this is a temporary solution, the best solution is to produce the
550
        // right min max value at the producer side.
551
        decimal_literal.__set_value(origin_value->to_string(precision, scale));
552
        (*node).__set_decimal_literal(decimal_literal);
553
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DECIMAL128I, precision, scale));
554
2
    } else if constexpr (T == TYPE_DECIMAL256) {
555
2
        const auto* origin_value = reinterpret_cast<const vectorized::Decimal<wide::Int256>*>(data);
556
2
        (*node).__set_node_type(TExprNodeType::DECIMAL_LITERAL);
557
2
        TDecimalLiteral decimal_literal;
558
2
        decimal_literal.__set_value(origin_value->to_string(precision, scale));
559
2
        (*node).__set_decimal_literal(decimal_literal);
560
2
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DECIMAL256, precision, scale));
561
    } else if constexpr (T == TYPE_FLOAT) {
562
        const auto* origin_value = reinterpret_cast<const float*>(data);
563
        (*node).__set_node_type(TExprNodeType::FLOAT_LITERAL);
564
        TFloatLiteral float_literal;
565
        float_literal.__set_value(*origin_value);
566
        (*node).__set_float_literal(float_literal);
567
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_FLOAT));
568
    } else if constexpr (T == TYPE_DOUBLE) {
569
        const auto* origin_value = reinterpret_cast<const double*>(data);
570
        (*node).__set_node_type(TExprNodeType::FLOAT_LITERAL);
571
        TFloatLiteral float_literal;
572
        float_literal.__set_value(*origin_value);
573
        (*node).__set_float_literal(float_literal);
574
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DOUBLE));
575
    } else if constexpr ((T == TYPE_STRING) || (T == TYPE_CHAR) || (T == TYPE_VARCHAR)) {
576
        const auto* origin_value = reinterpret_cast<const std::string*>(data);
577
        (*node).__set_node_type(TExprNodeType::STRING_LITERAL);
578
        TStringLiteral string_literal;
579
        string_literal.__set_value(*origin_value);
580
        (*node).__set_string_literal(string_literal);
581
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_STRING));
582
    } else if constexpr (T == TYPE_IPV4) {
583
        const auto* origin_value = reinterpret_cast<const IPv4*>(data);
584
        (*node).__set_node_type(TExprNodeType::IPV4_LITERAL);
585
        TIPv4Literal literal;
586
        literal.__set_value(*origin_value);
587
        (*node).__set_ipv4_literal(literal);
588
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_IPV4));
589
    } else if constexpr (T == TYPE_IPV6) {
590
        const auto* origin_value = reinterpret_cast<const IPv6*>(data);
591
        (*node).__set_node_type(TExprNodeType::IPV6_LITERAL);
592
        TIPv6Literal literal;
593
        literal.__set_value(vectorized::CastToString::from_ip(*origin_value));
594
        (*node).__set_ipv6_literal(literal);
595
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_IPV6));
596
    } else if constexpr (T == TYPE_TIMEV2) {
597
        // the code use for runtime filter but we dont support timev2 as predicate now
598
        // so this part not used
599
        const auto* origin_value = reinterpret_cast<const double*>(data);
600
        TTimeV2Literal timev2_literal;
601
        timev2_literal.__set_value(*origin_value);
602
        (*node).__set_timev2_literal(timev2_literal);
603
        (*node).__set_node_type(TExprNodeType::TIMEV2_LITERAL);
604
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_TIMEV2, precision, scale));
605
    } else if constexpr (T == TYPE_VARBINARY) {
606
        const auto* origin_value = reinterpret_cast<const std::string*>(data);
607
        (*node).__set_node_type(TExprNodeType::VARBINARY_LITERAL);
608
        TVarBinaryLiteral varbinary_literal;
609
        varbinary_literal.__set_value(*origin_value);
610
        (*node).__set_varbinary_literal(varbinary_literal);
611
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_VARBINARY));
612
    } else {
613
        return Status::InvalidArgument("Invalid argument type!");
614
    }
615
2
    return Status::OK();
616
2
}
Unexecuted instantiation: _ZN5doris25create_texpr_literal_nodeILNS_13PrimitiveTypeE15EEENS_6StatusEPKvPNS_9TExprNodeEii
Unexecuted instantiation: _ZN5doris25create_texpr_literal_nodeILNS_13PrimitiveTypeE10EEENS_6StatusEPKvPNS_9TExprNodeEii
_ZN5doris25create_texpr_literal_nodeILNS_13PrimitiveTypeE23EEENS_6StatusEPKvPNS_9TExprNodeEii
Line
Count
Source
436
1
                                 int scale = 0) {
437
    if constexpr (T == TYPE_BOOLEAN) {
438
        const auto* origin_value = reinterpret_cast<const bool*>(data);
439
        TBoolLiteral boolLiteral;
440
        (*node).__set_node_type(TExprNodeType::BOOL_LITERAL);
441
        boolLiteral.__set_value(*origin_value);
442
        (*node).__set_bool_literal(boolLiteral);
443
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_BOOLEAN));
444
    } else if constexpr (T == TYPE_TINYINT) {
445
        const auto* origin_value = reinterpret_cast<const int8_t*>(data);
446
        (*node).__set_node_type(TExprNodeType::INT_LITERAL);
447
        TIntLiteral intLiteral;
448
        intLiteral.__set_value(*origin_value);
449
        (*node).__set_int_literal(intLiteral);
450
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_TINYINT));
451
    } else if constexpr (T == TYPE_SMALLINT) {
452
        const auto* origin_value = reinterpret_cast<const int16_t*>(data);
453
        (*node).__set_node_type(TExprNodeType::INT_LITERAL);
454
        TIntLiteral intLiteral;
455
        intLiteral.__set_value(*origin_value);
456
        (*node).__set_int_literal(intLiteral);
457
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_SMALLINT));
458
    } else if constexpr (T == TYPE_INT) {
459
        const auto* origin_value = reinterpret_cast<const int32_t*>(data);
460
        (*node).__set_node_type(TExprNodeType::INT_LITERAL);
461
        TIntLiteral intLiteral;
462
        intLiteral.__set_value(*origin_value);
463
        (*node).__set_int_literal(intLiteral);
464
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_INT));
465
    } else if constexpr (T == TYPE_BIGINT) {
466
        const auto* origin_value = reinterpret_cast<const int64_t*>(data);
467
        (*node).__set_node_type(TExprNodeType::INT_LITERAL);
468
        TIntLiteral intLiteral;
469
        intLiteral.__set_value(*origin_value);
470
        (*node).__set_int_literal(intLiteral);
471
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_BIGINT));
472
    } else if constexpr (T == TYPE_LARGEINT) {
473
        const auto* origin_value = reinterpret_cast<const int128_t*>(data);
474
        (*node).__set_node_type(TExprNodeType::LARGE_INT_LITERAL);
475
        TLargeIntLiteral large_int_literal;
476
        large_int_literal.__set_value(LargeIntValue::to_string(*origin_value));
477
        (*node).__set_large_int_literal(large_int_literal);
478
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_LARGEINT));
479
    } else if constexpr ((T == TYPE_DATE) || (T == TYPE_DATETIME)) {
480
        const auto* origin_value = reinterpret_cast<const VecDateTimeValue*>(data);
481
        TDateLiteral date_literal;
482
        char convert_buffer[30];
483
        origin_value->to_string(convert_buffer);
484
        date_literal.__set_value(convert_buffer);
485
        (*node).__set_date_literal(date_literal);
486
        (*node).__set_node_type(TExprNodeType::DATE_LITERAL);
487
        if (origin_value->type() == TimeType::TIME_DATE) {
488
            (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DATE));
489
        } else if (origin_value->type() == TimeType::TIME_DATETIME) {
490
            (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DATETIME));
491
        }
492
    } else if constexpr (T == TYPE_DATEV2) {
493
        const auto* origin_value = reinterpret_cast<const DateV2Value<DateV2ValueType>*>(data);
494
        TDateLiteral date_literal;
495
        char convert_buffer[30];
496
        origin_value->to_string(convert_buffer);
497
        date_literal.__set_value(convert_buffer);
498
        (*node).__set_date_literal(date_literal);
499
        (*node).__set_node_type(TExprNodeType::DATE_LITERAL);
500
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DATEV2));
501
    } else if constexpr (T == TYPE_DATETIMEV2) {
502
        const auto* origin_value = reinterpret_cast<const DateV2Value<DateTimeV2ValueType>*>(data);
503
        TDateLiteral date_literal;
504
        char convert_buffer[30];
505
        origin_value->to_string(convert_buffer, scale);
506
        date_literal.__set_value(convert_buffer);
507
        (*node).__set_date_literal(date_literal);
508
        (*node).__set_node_type(TExprNodeType::DATE_LITERAL);
509
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DATETIMEV2, precision, scale));
510
    } else if constexpr (T == TYPE_TIMESTAMPTZ) {
511
        const auto* origin_value = reinterpret_cast<const TimestampTzValue*>(data);
512
        TDateLiteral date_literal;
513
        auto tz = cctz::utc_time_zone();
514
        auto tz_str = origin_value->to_string(tz, scale);
515
        date_literal.__set_value(tz_str);
516
        (*node).__set_date_literal(date_literal);
517
        (*node).__set_node_type(TExprNodeType::DATE_LITERAL);
518
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_TIMESTAMPTZ, precision, scale));
519
    } else if constexpr (T == TYPE_DECIMALV2) {
520
        const auto* origin_value = reinterpret_cast<const DecimalV2Value*>(data);
521
        (*node).__set_node_type(TExprNodeType::DECIMAL_LITERAL);
522
        TDecimalLiteral decimal_literal;
523
        decimal_literal.__set_value(origin_value->to_string());
524
        (*node).__set_decimal_literal(decimal_literal);
525
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DECIMALV2, precision, scale));
526
    } else if constexpr (T == TYPE_DECIMAL32) {
527
        const auto* origin_value = reinterpret_cast<const vectorized::Decimal<int32_t>*>(data);
528
        (*node).__set_node_type(TExprNodeType::DECIMAL_LITERAL);
529
        TDecimalLiteral decimal_literal;
530
        decimal_literal.__set_value(origin_value->to_string(precision, scale));
531
        (*node).__set_decimal_literal(decimal_literal);
532
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DECIMAL32, precision, scale));
533
    } else if constexpr (T == TYPE_DECIMAL64) {
534
        const auto* origin_value = reinterpret_cast<const vectorized::Decimal<int64_t>*>(data);
535
        (*node).__set_node_type(TExprNodeType::DECIMAL_LITERAL);
536
        TDecimalLiteral decimal_literal;
537
        decimal_literal.__set_value(origin_value->to_string(precision, scale));
538
        (*node).__set_decimal_literal(decimal_literal);
539
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DECIMAL64, precision, scale));
540
    } else if constexpr (T == TYPE_DECIMAL128I) {
541
        const auto* origin_value = reinterpret_cast<const vectorized::Decimal<int128_t>*>(data);
542
        (*node).__set_node_type(TExprNodeType::DECIMAL_LITERAL);
543
        TDecimalLiteral decimal_literal;
544
        // e.g. For a decimal(26,6) column, the initial value of the _min of the MinMax RF
545
        // on the RF producer side is an int128 value with 38 digits of 9, and this is the
546
        // final min value of the MinMax RF if the fragment instance has no data.
547
        // Need to truncate the value to the right precision and scale here, to avoid
548
        // error when casting string back to decimal later.
549
        // TODO: this is a temporary solution, the best solution is to produce the
550
        // right min max value at the producer side.
551
        decimal_literal.__set_value(origin_value->to_string(precision, scale));
552
        (*node).__set_decimal_literal(decimal_literal);
553
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DECIMAL128I, precision, scale));
554
    } else if constexpr (T == TYPE_DECIMAL256) {
555
        const auto* origin_value = reinterpret_cast<const vectorized::Decimal<wide::Int256>*>(data);
556
        (*node).__set_node_type(TExprNodeType::DECIMAL_LITERAL);
557
        TDecimalLiteral decimal_literal;
558
        decimal_literal.__set_value(origin_value->to_string(precision, scale));
559
        (*node).__set_decimal_literal(decimal_literal);
560
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DECIMAL256, precision, scale));
561
    } else if constexpr (T == TYPE_FLOAT) {
562
        const auto* origin_value = reinterpret_cast<const float*>(data);
563
        (*node).__set_node_type(TExprNodeType::FLOAT_LITERAL);
564
        TFloatLiteral float_literal;
565
        float_literal.__set_value(*origin_value);
566
        (*node).__set_float_literal(float_literal);
567
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_FLOAT));
568
    } else if constexpr (T == TYPE_DOUBLE) {
569
        const auto* origin_value = reinterpret_cast<const double*>(data);
570
        (*node).__set_node_type(TExprNodeType::FLOAT_LITERAL);
571
        TFloatLiteral float_literal;
572
        float_literal.__set_value(*origin_value);
573
        (*node).__set_float_literal(float_literal);
574
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DOUBLE));
575
1
    } else if constexpr ((T == TYPE_STRING) || (T == TYPE_CHAR) || (T == TYPE_VARCHAR)) {
576
1
        const auto* origin_value = reinterpret_cast<const std::string*>(data);
577
1
        (*node).__set_node_type(TExprNodeType::STRING_LITERAL);
578
1
        TStringLiteral string_literal;
579
1
        string_literal.__set_value(*origin_value);
580
1
        (*node).__set_string_literal(string_literal);
581
1
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_STRING));
582
    } else if constexpr (T == TYPE_IPV4) {
583
        const auto* origin_value = reinterpret_cast<const IPv4*>(data);
584
        (*node).__set_node_type(TExprNodeType::IPV4_LITERAL);
585
        TIPv4Literal literal;
586
        literal.__set_value(*origin_value);
587
        (*node).__set_ipv4_literal(literal);
588
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_IPV4));
589
    } else if constexpr (T == TYPE_IPV6) {
590
        const auto* origin_value = reinterpret_cast<const IPv6*>(data);
591
        (*node).__set_node_type(TExprNodeType::IPV6_LITERAL);
592
        TIPv6Literal literal;
593
        literal.__set_value(vectorized::CastToString::from_ip(*origin_value));
594
        (*node).__set_ipv6_literal(literal);
595
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_IPV6));
596
    } else if constexpr (T == TYPE_TIMEV2) {
597
        // the code use for runtime filter but we dont support timev2 as predicate now
598
        // so this part not used
599
        const auto* origin_value = reinterpret_cast<const double*>(data);
600
        TTimeV2Literal timev2_literal;
601
        timev2_literal.__set_value(*origin_value);
602
        (*node).__set_timev2_literal(timev2_literal);
603
        (*node).__set_node_type(TExprNodeType::TIMEV2_LITERAL);
604
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_TIMEV2, precision, scale));
605
    } else if constexpr (T == TYPE_VARBINARY) {
606
        const auto* origin_value = reinterpret_cast<const std::string*>(data);
607
        (*node).__set_node_type(TExprNodeType::VARBINARY_LITERAL);
608
        TVarBinaryLiteral varbinary_literal;
609
        varbinary_literal.__set_value(*origin_value);
610
        (*node).__set_varbinary_literal(varbinary_literal);
611
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_VARBINARY));
612
    } else {
613
        return Status::InvalidArgument("Invalid argument type!");
614
    }
615
1
    return Status::OK();
616
1
}
Unexecuted instantiation: _ZN5doris25create_texpr_literal_nodeILNS_13PrimitiveTypeE36EEENS_6StatusEPKvPNS_9TExprNodeEii
Unexecuted instantiation: _ZN5doris25create_texpr_literal_nodeILNS_13PrimitiveTypeE37EEENS_6StatusEPKvPNS_9TExprNodeEii
_ZN5doris25create_texpr_literal_nodeILNS_13PrimitiveTypeE27EEENS_6StatusEPKvPNS_9TExprNodeEii
Line
Count
Source
436
1
                                 int scale = 0) {
437
    if constexpr (T == TYPE_BOOLEAN) {
438
        const auto* origin_value = reinterpret_cast<const bool*>(data);
439
        TBoolLiteral boolLiteral;
440
        (*node).__set_node_type(TExprNodeType::BOOL_LITERAL);
441
        boolLiteral.__set_value(*origin_value);
442
        (*node).__set_bool_literal(boolLiteral);
443
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_BOOLEAN));
444
    } else if constexpr (T == TYPE_TINYINT) {
445
        const auto* origin_value = reinterpret_cast<const int8_t*>(data);
446
        (*node).__set_node_type(TExprNodeType::INT_LITERAL);
447
        TIntLiteral intLiteral;
448
        intLiteral.__set_value(*origin_value);
449
        (*node).__set_int_literal(intLiteral);
450
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_TINYINT));
451
    } else if constexpr (T == TYPE_SMALLINT) {
452
        const auto* origin_value = reinterpret_cast<const int16_t*>(data);
453
        (*node).__set_node_type(TExprNodeType::INT_LITERAL);
454
        TIntLiteral intLiteral;
455
        intLiteral.__set_value(*origin_value);
456
        (*node).__set_int_literal(intLiteral);
457
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_SMALLINT));
458
    } else if constexpr (T == TYPE_INT) {
459
        const auto* origin_value = reinterpret_cast<const int32_t*>(data);
460
        (*node).__set_node_type(TExprNodeType::INT_LITERAL);
461
        TIntLiteral intLiteral;
462
        intLiteral.__set_value(*origin_value);
463
        (*node).__set_int_literal(intLiteral);
464
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_INT));
465
    } else if constexpr (T == TYPE_BIGINT) {
466
        const auto* origin_value = reinterpret_cast<const int64_t*>(data);
467
        (*node).__set_node_type(TExprNodeType::INT_LITERAL);
468
        TIntLiteral intLiteral;
469
        intLiteral.__set_value(*origin_value);
470
        (*node).__set_int_literal(intLiteral);
471
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_BIGINT));
472
    } else if constexpr (T == TYPE_LARGEINT) {
473
        const auto* origin_value = reinterpret_cast<const int128_t*>(data);
474
        (*node).__set_node_type(TExprNodeType::LARGE_INT_LITERAL);
475
        TLargeIntLiteral large_int_literal;
476
        large_int_literal.__set_value(LargeIntValue::to_string(*origin_value));
477
        (*node).__set_large_int_literal(large_int_literal);
478
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_LARGEINT));
479
    } else if constexpr ((T == TYPE_DATE) || (T == TYPE_DATETIME)) {
480
        const auto* origin_value = reinterpret_cast<const VecDateTimeValue*>(data);
481
        TDateLiteral date_literal;
482
        char convert_buffer[30];
483
        origin_value->to_string(convert_buffer);
484
        date_literal.__set_value(convert_buffer);
485
        (*node).__set_date_literal(date_literal);
486
        (*node).__set_node_type(TExprNodeType::DATE_LITERAL);
487
        if (origin_value->type() == TimeType::TIME_DATE) {
488
            (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DATE));
489
        } else if (origin_value->type() == TimeType::TIME_DATETIME) {
490
            (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DATETIME));
491
        }
492
    } else if constexpr (T == TYPE_DATEV2) {
493
        const auto* origin_value = reinterpret_cast<const DateV2Value<DateV2ValueType>*>(data);
494
        TDateLiteral date_literal;
495
        char convert_buffer[30];
496
        origin_value->to_string(convert_buffer);
497
        date_literal.__set_value(convert_buffer);
498
        (*node).__set_date_literal(date_literal);
499
        (*node).__set_node_type(TExprNodeType::DATE_LITERAL);
500
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DATEV2));
501
    } else if constexpr (T == TYPE_DATETIMEV2) {
502
        const auto* origin_value = reinterpret_cast<const DateV2Value<DateTimeV2ValueType>*>(data);
503
        TDateLiteral date_literal;
504
        char convert_buffer[30];
505
        origin_value->to_string(convert_buffer, scale);
506
        date_literal.__set_value(convert_buffer);
507
        (*node).__set_date_literal(date_literal);
508
        (*node).__set_node_type(TExprNodeType::DATE_LITERAL);
509
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DATETIMEV2, precision, scale));
510
    } else if constexpr (T == TYPE_TIMESTAMPTZ) {
511
        const auto* origin_value = reinterpret_cast<const TimestampTzValue*>(data);
512
        TDateLiteral date_literal;
513
        auto tz = cctz::utc_time_zone();
514
        auto tz_str = origin_value->to_string(tz, scale);
515
        date_literal.__set_value(tz_str);
516
        (*node).__set_date_literal(date_literal);
517
        (*node).__set_node_type(TExprNodeType::DATE_LITERAL);
518
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_TIMESTAMPTZ, precision, scale));
519
    } else if constexpr (T == TYPE_DECIMALV2) {
520
        const auto* origin_value = reinterpret_cast<const DecimalV2Value*>(data);
521
        (*node).__set_node_type(TExprNodeType::DECIMAL_LITERAL);
522
        TDecimalLiteral decimal_literal;
523
        decimal_literal.__set_value(origin_value->to_string());
524
        (*node).__set_decimal_literal(decimal_literal);
525
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DECIMALV2, precision, scale));
526
    } else if constexpr (T == TYPE_DECIMAL32) {
527
        const auto* origin_value = reinterpret_cast<const vectorized::Decimal<int32_t>*>(data);
528
        (*node).__set_node_type(TExprNodeType::DECIMAL_LITERAL);
529
        TDecimalLiteral decimal_literal;
530
        decimal_literal.__set_value(origin_value->to_string(precision, scale));
531
        (*node).__set_decimal_literal(decimal_literal);
532
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DECIMAL32, precision, scale));
533
    } else if constexpr (T == TYPE_DECIMAL64) {
534
        const auto* origin_value = reinterpret_cast<const vectorized::Decimal<int64_t>*>(data);
535
        (*node).__set_node_type(TExprNodeType::DECIMAL_LITERAL);
536
        TDecimalLiteral decimal_literal;
537
        decimal_literal.__set_value(origin_value->to_string(precision, scale));
538
        (*node).__set_decimal_literal(decimal_literal);
539
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DECIMAL64, precision, scale));
540
    } else if constexpr (T == TYPE_DECIMAL128I) {
541
        const auto* origin_value = reinterpret_cast<const vectorized::Decimal<int128_t>*>(data);
542
        (*node).__set_node_type(TExprNodeType::DECIMAL_LITERAL);
543
        TDecimalLiteral decimal_literal;
544
        // e.g. For a decimal(26,6) column, the initial value of the _min of the MinMax RF
545
        // on the RF producer side is an int128 value with 38 digits of 9, and this is the
546
        // final min value of the MinMax RF if the fragment instance has no data.
547
        // Need to truncate the value to the right precision and scale here, to avoid
548
        // error when casting string back to decimal later.
549
        // TODO: this is a temporary solution, the best solution is to produce the
550
        // right min max value at the producer side.
551
        decimal_literal.__set_value(origin_value->to_string(precision, scale));
552
        (*node).__set_decimal_literal(decimal_literal);
553
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DECIMAL128I, precision, scale));
554
    } else if constexpr (T == TYPE_DECIMAL256) {
555
        const auto* origin_value = reinterpret_cast<const vectorized::Decimal<wide::Int256>*>(data);
556
        (*node).__set_node_type(TExprNodeType::DECIMAL_LITERAL);
557
        TDecimalLiteral decimal_literal;
558
        decimal_literal.__set_value(origin_value->to_string(precision, scale));
559
        (*node).__set_decimal_literal(decimal_literal);
560
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DECIMAL256, precision, scale));
561
    } else if constexpr (T == TYPE_FLOAT) {
562
        const auto* origin_value = reinterpret_cast<const float*>(data);
563
        (*node).__set_node_type(TExprNodeType::FLOAT_LITERAL);
564
        TFloatLiteral float_literal;
565
        float_literal.__set_value(*origin_value);
566
        (*node).__set_float_literal(float_literal);
567
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_FLOAT));
568
    } else if constexpr (T == TYPE_DOUBLE) {
569
        const auto* origin_value = reinterpret_cast<const double*>(data);
570
        (*node).__set_node_type(TExprNodeType::FLOAT_LITERAL);
571
        TFloatLiteral float_literal;
572
        float_literal.__set_value(*origin_value);
573
        (*node).__set_float_literal(float_literal);
574
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DOUBLE));
575
    } else if constexpr ((T == TYPE_STRING) || (T == TYPE_CHAR) || (T == TYPE_VARCHAR)) {
576
        const auto* origin_value = reinterpret_cast<const std::string*>(data);
577
        (*node).__set_node_type(TExprNodeType::STRING_LITERAL);
578
        TStringLiteral string_literal;
579
        string_literal.__set_value(*origin_value);
580
        (*node).__set_string_literal(string_literal);
581
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_STRING));
582
    } else if constexpr (T == TYPE_IPV4) {
583
        const auto* origin_value = reinterpret_cast<const IPv4*>(data);
584
        (*node).__set_node_type(TExprNodeType::IPV4_LITERAL);
585
        TIPv4Literal literal;
586
        literal.__set_value(*origin_value);
587
        (*node).__set_ipv4_literal(literal);
588
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_IPV4));
589
    } else if constexpr (T == TYPE_IPV6) {
590
        const auto* origin_value = reinterpret_cast<const IPv6*>(data);
591
        (*node).__set_node_type(TExprNodeType::IPV6_LITERAL);
592
        TIPv6Literal literal;
593
        literal.__set_value(vectorized::CastToString::from_ip(*origin_value));
594
        (*node).__set_ipv6_literal(literal);
595
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_IPV6));
596
1
    } else if constexpr (T == TYPE_TIMEV2) {
597
        // the code use for runtime filter but we dont support timev2 as predicate now
598
        // so this part not used
599
1
        const auto* origin_value = reinterpret_cast<const double*>(data);
600
1
        TTimeV2Literal timev2_literal;
601
1
        timev2_literal.__set_value(*origin_value);
602
1
        (*node).__set_timev2_literal(timev2_literal);
603
1
        (*node).__set_node_type(TExprNodeType::TIMEV2_LITERAL);
604
1
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_TIMEV2, precision, scale));
605
    } else if constexpr (T == TYPE_VARBINARY) {
606
        const auto* origin_value = reinterpret_cast<const std::string*>(data);
607
        (*node).__set_node_type(TExprNodeType::VARBINARY_LITERAL);
608
        TVarBinaryLiteral varbinary_literal;
609
        varbinary_literal.__set_value(*origin_value);
610
        (*node).__set_varbinary_literal(varbinary_literal);
611
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_VARBINARY));
612
    } else {
613
        return Status::InvalidArgument("Invalid argument type!");
614
    }
615
1
    return Status::OK();
616
1
}
_ZN5doris25create_texpr_literal_nodeILNS_13PrimitiveTypeE42EEENS_6StatusEPKvPNS_9TExprNodeEii
Line
Count
Source
436
2
                                 int scale = 0) {
437
    if constexpr (T == TYPE_BOOLEAN) {
438
        const auto* origin_value = reinterpret_cast<const bool*>(data);
439
        TBoolLiteral boolLiteral;
440
        (*node).__set_node_type(TExprNodeType::BOOL_LITERAL);
441
        boolLiteral.__set_value(*origin_value);
442
        (*node).__set_bool_literal(boolLiteral);
443
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_BOOLEAN));
444
    } else if constexpr (T == TYPE_TINYINT) {
445
        const auto* origin_value = reinterpret_cast<const int8_t*>(data);
446
        (*node).__set_node_type(TExprNodeType::INT_LITERAL);
447
        TIntLiteral intLiteral;
448
        intLiteral.__set_value(*origin_value);
449
        (*node).__set_int_literal(intLiteral);
450
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_TINYINT));
451
    } else if constexpr (T == TYPE_SMALLINT) {
452
        const auto* origin_value = reinterpret_cast<const int16_t*>(data);
453
        (*node).__set_node_type(TExprNodeType::INT_LITERAL);
454
        TIntLiteral intLiteral;
455
        intLiteral.__set_value(*origin_value);
456
        (*node).__set_int_literal(intLiteral);
457
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_SMALLINT));
458
    } else if constexpr (T == TYPE_INT) {
459
        const auto* origin_value = reinterpret_cast<const int32_t*>(data);
460
        (*node).__set_node_type(TExprNodeType::INT_LITERAL);
461
        TIntLiteral intLiteral;
462
        intLiteral.__set_value(*origin_value);
463
        (*node).__set_int_literal(intLiteral);
464
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_INT));
465
    } else if constexpr (T == TYPE_BIGINT) {
466
        const auto* origin_value = reinterpret_cast<const int64_t*>(data);
467
        (*node).__set_node_type(TExprNodeType::INT_LITERAL);
468
        TIntLiteral intLiteral;
469
        intLiteral.__set_value(*origin_value);
470
        (*node).__set_int_literal(intLiteral);
471
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_BIGINT));
472
    } else if constexpr (T == TYPE_LARGEINT) {
473
        const auto* origin_value = reinterpret_cast<const int128_t*>(data);
474
        (*node).__set_node_type(TExprNodeType::LARGE_INT_LITERAL);
475
        TLargeIntLiteral large_int_literal;
476
        large_int_literal.__set_value(LargeIntValue::to_string(*origin_value));
477
        (*node).__set_large_int_literal(large_int_literal);
478
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_LARGEINT));
479
    } else if constexpr ((T == TYPE_DATE) || (T == TYPE_DATETIME)) {
480
        const auto* origin_value = reinterpret_cast<const VecDateTimeValue*>(data);
481
        TDateLiteral date_literal;
482
        char convert_buffer[30];
483
        origin_value->to_string(convert_buffer);
484
        date_literal.__set_value(convert_buffer);
485
        (*node).__set_date_literal(date_literal);
486
        (*node).__set_node_type(TExprNodeType::DATE_LITERAL);
487
        if (origin_value->type() == TimeType::TIME_DATE) {
488
            (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DATE));
489
        } else if (origin_value->type() == TimeType::TIME_DATETIME) {
490
            (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DATETIME));
491
        }
492
    } else if constexpr (T == TYPE_DATEV2) {
493
        const auto* origin_value = reinterpret_cast<const DateV2Value<DateV2ValueType>*>(data);
494
        TDateLiteral date_literal;
495
        char convert_buffer[30];
496
        origin_value->to_string(convert_buffer);
497
        date_literal.__set_value(convert_buffer);
498
        (*node).__set_date_literal(date_literal);
499
        (*node).__set_node_type(TExprNodeType::DATE_LITERAL);
500
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DATEV2));
501
    } else if constexpr (T == TYPE_DATETIMEV2) {
502
        const auto* origin_value = reinterpret_cast<const DateV2Value<DateTimeV2ValueType>*>(data);
503
        TDateLiteral date_literal;
504
        char convert_buffer[30];
505
        origin_value->to_string(convert_buffer, scale);
506
        date_literal.__set_value(convert_buffer);
507
        (*node).__set_date_literal(date_literal);
508
        (*node).__set_node_type(TExprNodeType::DATE_LITERAL);
509
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DATETIMEV2, precision, scale));
510
2
    } else if constexpr (T == TYPE_TIMESTAMPTZ) {
511
2
        const auto* origin_value = reinterpret_cast<const TimestampTzValue*>(data);
512
2
        TDateLiteral date_literal;
513
2
        auto tz = cctz::utc_time_zone();
514
2
        auto tz_str = origin_value->to_string(tz, scale);
515
2
        date_literal.__set_value(tz_str);
516
2
        (*node).__set_date_literal(date_literal);
517
2
        (*node).__set_node_type(TExprNodeType::DATE_LITERAL);
518
2
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_TIMESTAMPTZ, precision, scale));
519
    } else if constexpr (T == TYPE_DECIMALV2) {
520
        const auto* origin_value = reinterpret_cast<const DecimalV2Value*>(data);
521
        (*node).__set_node_type(TExprNodeType::DECIMAL_LITERAL);
522
        TDecimalLiteral decimal_literal;
523
        decimal_literal.__set_value(origin_value->to_string());
524
        (*node).__set_decimal_literal(decimal_literal);
525
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DECIMALV2, precision, scale));
526
    } else if constexpr (T == TYPE_DECIMAL32) {
527
        const auto* origin_value = reinterpret_cast<const vectorized::Decimal<int32_t>*>(data);
528
        (*node).__set_node_type(TExprNodeType::DECIMAL_LITERAL);
529
        TDecimalLiteral decimal_literal;
530
        decimal_literal.__set_value(origin_value->to_string(precision, scale));
531
        (*node).__set_decimal_literal(decimal_literal);
532
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DECIMAL32, precision, scale));
533
    } else if constexpr (T == TYPE_DECIMAL64) {
534
        const auto* origin_value = reinterpret_cast<const vectorized::Decimal<int64_t>*>(data);
535
        (*node).__set_node_type(TExprNodeType::DECIMAL_LITERAL);
536
        TDecimalLiteral decimal_literal;
537
        decimal_literal.__set_value(origin_value->to_string(precision, scale));
538
        (*node).__set_decimal_literal(decimal_literal);
539
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DECIMAL64, precision, scale));
540
    } else if constexpr (T == TYPE_DECIMAL128I) {
541
        const auto* origin_value = reinterpret_cast<const vectorized::Decimal<int128_t>*>(data);
542
        (*node).__set_node_type(TExprNodeType::DECIMAL_LITERAL);
543
        TDecimalLiteral decimal_literal;
544
        // e.g. For a decimal(26,6) column, the initial value of the _min of the MinMax RF
545
        // on the RF producer side is an int128 value with 38 digits of 9, and this is the
546
        // final min value of the MinMax RF if the fragment instance has no data.
547
        // Need to truncate the value to the right precision and scale here, to avoid
548
        // error when casting string back to decimal later.
549
        // TODO: this is a temporary solution, the best solution is to produce the
550
        // right min max value at the producer side.
551
        decimal_literal.__set_value(origin_value->to_string(precision, scale));
552
        (*node).__set_decimal_literal(decimal_literal);
553
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DECIMAL128I, precision, scale));
554
    } else if constexpr (T == TYPE_DECIMAL256) {
555
        const auto* origin_value = reinterpret_cast<const vectorized::Decimal<wide::Int256>*>(data);
556
        (*node).__set_node_type(TExprNodeType::DECIMAL_LITERAL);
557
        TDecimalLiteral decimal_literal;
558
        decimal_literal.__set_value(origin_value->to_string(precision, scale));
559
        (*node).__set_decimal_literal(decimal_literal);
560
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DECIMAL256, precision, scale));
561
    } else if constexpr (T == TYPE_FLOAT) {
562
        const auto* origin_value = reinterpret_cast<const float*>(data);
563
        (*node).__set_node_type(TExprNodeType::FLOAT_LITERAL);
564
        TFloatLiteral float_literal;
565
        float_literal.__set_value(*origin_value);
566
        (*node).__set_float_literal(float_literal);
567
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_FLOAT));
568
    } else if constexpr (T == TYPE_DOUBLE) {
569
        const auto* origin_value = reinterpret_cast<const double*>(data);
570
        (*node).__set_node_type(TExprNodeType::FLOAT_LITERAL);
571
        TFloatLiteral float_literal;
572
        float_literal.__set_value(*origin_value);
573
        (*node).__set_float_literal(float_literal);
574
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_DOUBLE));
575
    } else if constexpr ((T == TYPE_STRING) || (T == TYPE_CHAR) || (T == TYPE_VARCHAR)) {
576
        const auto* origin_value = reinterpret_cast<const std::string*>(data);
577
        (*node).__set_node_type(TExprNodeType::STRING_LITERAL);
578
        TStringLiteral string_literal;
579
        string_literal.__set_value(*origin_value);
580
        (*node).__set_string_literal(string_literal);
581
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_STRING));
582
    } else if constexpr (T == TYPE_IPV4) {
583
        const auto* origin_value = reinterpret_cast<const IPv4*>(data);
584
        (*node).__set_node_type(TExprNodeType::IPV4_LITERAL);
585
        TIPv4Literal literal;
586
        literal.__set_value(*origin_value);
587
        (*node).__set_ipv4_literal(literal);
588
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_IPV4));
589
    } else if constexpr (T == TYPE_IPV6) {
590
        const auto* origin_value = reinterpret_cast<const IPv6*>(data);
591
        (*node).__set_node_type(TExprNodeType::IPV6_LITERAL);
592
        TIPv6Literal literal;
593
        literal.__set_value(vectorized::CastToString::from_ip(*origin_value));
594
        (*node).__set_ipv6_literal(literal);
595
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_IPV6));
596
    } else if constexpr (T == TYPE_TIMEV2) {
597
        // the code use for runtime filter but we dont support timev2 as predicate now
598
        // so this part not used
599
        const auto* origin_value = reinterpret_cast<const double*>(data);
600
        TTimeV2Literal timev2_literal;
601
        timev2_literal.__set_value(*origin_value);
602
        (*node).__set_timev2_literal(timev2_literal);
603
        (*node).__set_node_type(TExprNodeType::TIMEV2_LITERAL);
604
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_TIMEV2, precision, scale));
605
    } else if constexpr (T == TYPE_VARBINARY) {
606
        const auto* origin_value = reinterpret_cast<const std::string*>(data);
607
        (*node).__set_node_type(TExprNodeType::VARBINARY_LITERAL);
608
        TVarBinaryLiteral varbinary_literal;
609
        varbinary_literal.__set_value(*origin_value);
610
        (*node).__set_varbinary_literal(varbinary_literal);
611
        (*node).__set_type(create_type_desc(PrimitiveType::TYPE_VARBINARY));
612
    } else {
613
        return Status::InvalidArgument("Invalid argument type!");
614
    }
615
2
    return Status::OK();
616
2
}
Unexecuted instantiation: _ZN5doris25create_texpr_literal_nodeILNS_13PrimitiveTypeE41EEENS_6StatusEPKvPNS_9TExprNodeEii
617
// NOLINTEND(readability-function-size)
618
619
TExprNode create_texpr_node_from(const void* data, const PrimitiveType& type, int precision = 0,
620
                                 int scale = 0);
621
622
TExprNode create_texpr_node_from(const vectorized::Field& field, const PrimitiveType& type,
623
                                 int precision, int scale);
624
625
#include "common/compile_check_end.h"
626
} // namespace doris