36 const std::vector<double>& inverse_bucket_sizes_for_dimension,
37 const std::vector<InnerOuter> inner_outer_pairs) {
43 const auto& inner_outer_pair = inner_outer_pairs[i];
44 const auto inner_col = inner_outer_pair.first;
45 const auto& ti = inner_col->get_type_info();
46 const auto elem_ti = ti.get_elem_type();
50 elem_ti.get_type() ==
kDOUBLE});
60 const std::vector<Fragmenter_Namespace::FragmentInfo>& fragment_info,
63 std::vector<std::shared_ptr<Chunk_NS::Chunk>>& chunks_owner,
65 std::vector<std::shared_ptr<void>>& malloc_owner,
68 static std::mutex fragment_fetch_mutex;
69 std::lock_guard<std::mutex> fragment_fetch_lock(fragment_fetch_mutex);
74 effective_memory_level,
82 CHECK(dev_buff_owner);
100 const int device_id) {
105 for (
size_t i = 0; i < memsz; ++i) {
117 const int device_id)
const {
118 return toStringFlat<int64_t>(
this, device_type, device_id);
122 const int device_id)
const {
123 return toStringFlat<int32_t>(
this, device_type, device_id);
129 for (
auto k : e.
key) {
172 os <<
"(" << inner_outer_string_op_infos.first <<
", "
173 << inner_outer_string_op_infos.second <<
")";
178 std::ostringstream os;
179 os << inner_outer_string_op_infos;
185 const std::vector<InnerOuterStringOpInfos>& inner_outer_string_op_infos_pairs) {
187 bool first_elem =
true;
188 for (
const auto& inner_outer_string_op_infos : inner_outer_string_op_infos_pairs) {
193 os << inner_outer_string_op_infos;
200 const std::vector<InnerOuterStringOpInfos>& inner_outer_string_op_infos_pairs) {
201 std::ostringstream os;
202 os << inner_outer_string_op_infos_pairs;
207 const std::vector<llvm::Value*>& hash_join_idx_args_in,
208 const bool is_sharded,
209 const bool col_is_nullable,
211 const int64_t sub_buff_size,
213 bool is_bucketized) {
215 using namespace std::string_literals;
217 std::string fname(is_bucketized ?
"bucketized_hash_join_idx"s :
"hash_join_idx"s);
225 if (!is_bw_eq && col_is_nullable) {
226 fname +=
"_nullable";
229 const auto slot_lv = executor->cgen_state_->emitCall(fname, hash_join_idx_args_in);
230 const auto slot_valid_lv = executor->cgen_state_->ir_builder_.CreateICmpSGE(
231 slot_lv, executor->cgen_state_->llInt(int64_t(0)));
233 auto pos_ptr = hash_join_idx_args_in[0];
236 auto count_ptr = executor->cgen_state_->ir_builder_.CreateAdd(
237 pos_ptr, executor->cgen_state_->llInt(sub_buff_size));
238 auto hash_join_idx_args = hash_join_idx_args_in;
239 hash_join_idx_args[0] = executor->cgen_state_->ir_builder_.CreatePtrToInt(
240 count_ptr, llvm::Type::getInt64Ty(executor->cgen_state_->context_));
242 const auto row_count_lv = executor->cgen_state_->ir_builder_.CreateSelect(
244 executor->cgen_state_->emitCall(fname, hash_join_idx_args),
245 executor->cgen_state_->llInt(int64_t(0)));
246 auto rowid_base_i32 = executor->cgen_state_->ir_builder_.CreateIntToPtr(
247 executor->cgen_state_->ir_builder_.CreateAdd(
248 pos_ptr, executor->cgen_state_->llInt(2 * sub_buff_size)),
249 llvm::Type::getInt32PtrTy(executor->cgen_state_->context_));
250 auto rowid_ptr_i32 = executor->cgen_state_->ir_builder_.CreateGEP(
251 rowid_base_i32->getType()->getScalarType()->getPointerElementType(),
254 return {rowid_ptr_i32, row_count_lv, slot_lv};
259 llvm::Value* hash_ptr =
nullptr;
260 const auto total_table_count =
261 executor->plan_state_->join_info_.join_hash_tables_.size();
262 CHECK_LT(table_idx, total_table_count);
263 if (total_table_count > 1) {
264 auto hash_tables_ptr =
268 ? executor->cgen_state_->ir_builder_.CreateGEP(
269 hash_tables_ptr->getType()->getScalarType()->getPointerElementType(),
271 executor->cgen_state_->llInt(static_cast<int64_t>(table_idx)))
273 hash_ptr = executor->cgen_state_->ir_builder_.CreateLoad(
274 hash_pptr->getType()->getPointerElementType(), hash_pptr);
276 hash_ptr =
get_arg_by_name(executor->cgen_state_->row_func_,
"join_hash_tables");
284 const std::shared_ptr<Analyzer::BinOper> qual_bin_oper,
285 const std::vector<InputTableInfo>& query_infos,
289 const int device_count,
296 std::shared_ptr<HashJoin> join_hash_table;
299 throw std::runtime_error(
300 "Overlaps hash join disabled, attempting to fall back to loop join");
302 if (qual_bin_oper->is_overlaps_oper()) {
303 VLOG(1) <<
"Trying to build geo hash table:";
311 hashtable_build_dag_map,
313 table_id_to_node_map);
314 }
else if (dynamic_cast<const Analyzer::ExpressionTuple*>(
315 qual_bin_oper->get_left_operand())) {
316 VLOG(1) <<
"Trying to build keyed hash table:";
325 hashtable_build_dag_map,
327 table_id_to_node_map);
330 VLOG(1) <<
"Trying to build perfect hash table:";
339 hashtable_build_dag_map,
341 table_id_to_node_map);
346 CHECK_EQ(join_quals.size(), size_t(1));
347 const auto join_qual =
349 VLOG(1) <<
"Trying to build keyed hash table after perfect hash table:";
358 hashtable_build_dag_map,
360 table_id_to_node_map);
363 CHECK(join_hash_table);
366 for (
int device_id = 0; device_id < join_hash_table->getDeviceCount();
370 VLOG(2) <<
"Built GPU hash table: "
376 VLOG(2) <<
"Built CPU hash table: "
381 return join_hash_table;
384 std::pair<const StringDictionaryProxy*, StringDictionaryProxy*>
386 const Executor* executor,
387 const bool has_string_ops) {
388 const auto inner_col = cols.first;
390 const auto inner_ti = inner_col->get_type_info();
392 std::pair<const StringDictionaryProxy*, StringDictionaryProxy*>
393 inner_outer_str_dict_proxies{
nullptr,
nullptr};
394 if (inner_ti.is_string() && outer_col) {
396 CHECK(outer_ti.is_string());
397 inner_outer_str_dict_proxies.first =
398 executor->getStringDictionaryProxy(inner_ti.getStringDictKey(),
true);
399 CHECK(inner_outer_str_dict_proxies.first);
400 inner_outer_str_dict_proxies.second =
401 executor->getStringDictionaryProxy(outer_ti.getStringDictKey(),
true);
402 CHECK(inner_outer_str_dict_proxies.second);
403 if (!has_string_ops &&
404 *inner_outer_str_dict_proxies.first == *inner_outer_str_dict_proxies.second) {
406 CHECK_EQ(inner_ti.getStringDictKey(), outer_ti.getStringDictKey());
407 inner_outer_str_dict_proxies.first =
nullptr;
408 inner_outer_str_dict_proxies.second =
nullptr;
411 return inner_outer_str_dict_proxies;
418 const Executor* executor) {
419 const bool has_string_ops = inner_outer_string_op_infos.first.
size() ||
420 inner_outer_string_op_infos.second.size();
421 const auto inner_outer_proxies =
423 const bool translate_dictionary =
424 inner_outer_proxies.first && inner_outer_proxies.second;
425 if (translate_dictionary) {
426 const auto& inner_dict_id = inner_outer_proxies.first->getDictKey();
427 const auto& outer_dict_id = inner_outer_proxies.second->getDictKey();
428 CHECK(has_string_ops || inner_dict_id != outer_dict_id);
429 const auto id_map = executor->getJoinIntersectionStringProxyTranslationMap(
430 inner_outer_proxies.first,
431 inner_outer_proxies.second,
432 inner_outer_string_op_infos.first,
433 inner_outer_string_op_infos.second,
434 executor->getRowSetMemoryOwner());
435 if (!inner_outer_string_op_infos.second.empty()) {
440 static_cast<int64_t
>(
441 inner_outer_proxies.second->transientEntryCount() + 1) *
453 const std::vector<Fragmenter_Namespace::FragmentInfo>& fragments) {
454 auto const fragment_id = [](
auto const& frag_info) {
return frag_info.fragmentId; };
455 std::vector<int> frag_ids(fragments.size());
456 std::transform(fragments.cbegin(), fragments.cend(), frag_ids.begin(), fragment_id);
457 std::sort(frag_ids.begin(), frag_ids.end());
462 const std::vector<InnerOuter>& inner_outer_pairs,
463 const Executor* executor,
464 const std::vector<InnerOuterStringOpInfos>& inner_outer_string_op_infos_pairs) {
466 std::vector<const void*> sd_inner_proxy_per_key;
467 std::vector<void*> sd_outer_proxy_per_key;
468 std::vector<ChunkKey> cache_key_chunks;
469 const bool has_string_op_infos = inner_outer_string_op_infos_pairs.size();
470 if (has_string_op_infos) {
471 CHECK_EQ(inner_outer_pairs.size(), inner_outer_string_op_infos_pairs.size());
473 size_t string_op_info_pairs_idx = 0;
474 for (
const auto& inner_outer_pair : inner_outer_pairs) {
475 const auto inner_col = inner_outer_pair.first;
476 const auto outer_col = inner_outer_pair.second;
477 const auto& inner_ti = inner_col->get_type_info();
478 const auto& outer_ti = outer_col->get_type_info();
479 const auto& inner_column_key = inner_col->getColumnKey();
480 ChunkKey cache_key_chunks_for_column{
481 inner_column_key.db_id, inner_column_key.table_id, inner_column_key.column_id};
482 if (inner_ti.is_string() &&
483 (!(inner_ti.get_comp_param() == outer_ti.get_comp_param()) ||
484 (has_string_op_infos &&
485 (inner_outer_string_op_infos_pairs[string_op_info_pairs_idx].first.size() ||
486 inner_outer_string_op_infos_pairs[string_op_info_pairs_idx].second.size())))) {
487 CHECK(outer_ti.is_string());
490 const auto sd_inner_proxy = executor->getStringDictionaryProxy(
491 inner_ti.getStringDictKey(), executor->getRowSetMemoryOwner(),
true);
492 auto sd_outer_proxy = executor->getStringDictionaryProxy(
493 outer_ti.getStringDictKey(), executor->getRowSetMemoryOwner(),
true);
494 CHECK(sd_inner_proxy && sd_outer_proxy);
495 sd_inner_proxy_per_key.push_back(sd_inner_proxy);
496 sd_outer_proxy_per_key.push_back(sd_outer_proxy);
497 cache_key_chunks_for_column.push_back(sd_outer_proxy->getGeneration());
499 sd_inner_proxy_per_key.emplace_back();
500 sd_outer_proxy_per_key.emplace_back();
502 cache_key_chunks.push_back(cache_key_chunks_for_column);
503 string_op_info_pairs_idx++;
505 return {sd_inner_proxy_per_key, sd_outer_proxy_per_key, cache_key_chunks};
508 std::vector<const StringDictionaryProxy::IdMap*>
511 const std::vector<InnerOuterStringOpInfos>& string_op_infos_for_keys,
512 const Executor* executor) {
515 const size_t num_proxies = inner_proxies.size();
516 CHECK_EQ(num_proxies, outer_proxies.size());
517 std::vector<const StringDictionaryProxy::IdMap*> proxy_translation_maps;
518 proxy_translation_maps.reserve(num_proxies);
519 for (
size_t proxy_pair_idx = 0; proxy_pair_idx < num_proxies; ++proxy_pair_idx) {
520 const bool translate_proxies =
521 inner_proxies[proxy_pair_idx] && outer_proxies[proxy_pair_idx];
522 if (translate_proxies) {
523 const auto inner_proxy =
530 CHECK_NE(inner_proxy->getDictKey(), outer_proxy->getDictKey());
531 proxy_translation_maps.emplace_back(
532 executor->getJoinIntersectionStringProxyTranslationMap(
535 string_op_infos_for_keys[proxy_pair_idx].first,
536 string_op_infos_for_keys[proxy_pair_idx].second,
537 executor->getRowSetMemoryOwner()));
539 proxy_translation_maps.emplace_back(
nullptr);
542 return proxy_translation_maps;
547 const std::vector<StringOps_Namespace::StringOpInfo>& string_op_infos,
550 if (!string_op_infos.empty()) {
551 const auto coerced_col_var =
553 CHECK(coerced_col_var);
554 std::vector<llvm::Value*> codegen_val_vec{
556 return codegen_val_vec[0];
558 return code_generator.
codegen(col_or_string_oper,
true, co)[0];
562 std::string_view table,
563 std::string_view column,
572 auto ti = cmeta->columnType;
574 if (ti.is_geometry() && ti.get_type() !=
kPOINT) {
576 switch (ti.get_type()) {
578 geoColumnId = cmeta->columnId + 2;
582 geoColumnId = cmeta->columnId + 3;
586 geoColumnId = cmeta->columnId + 4;
594 ti = cmeta->columnType;
597 auto cv = std::make_shared<Analyzer::ColumnVar>(
615 std::set<const Analyzer::ColumnVar*>
result;
616 for (
const auto& expr_component : expr_tuple->
getTuple()) {
617 const auto component_rte_set = visitor.
visit(expr_component.get());
618 result.insert(component_rte_set.begin(), component_rte_set.end());
624 const std::set<const Analyzer::ColumnVar*>& aggregate,
625 const std::set<const Analyzer::ColumnVar*>& next_result)
const override {
627 result.insert(next_result.begin(), next_result.end());
633 std::unordered_set<shared::TableKey> phys_table_ids;
634 for (
auto cv : cvs) {
635 phys_table_ids.insert(cv->getTableKey());
638 std::unordered_set<PhysicalInput> phys_inputs;
639 for (
auto cv : cvs) {
640 const auto& column_key = cv->getColumnKey();
645 executor->setupCaching(phys_inputs, phys_table_ids);
649 std::set<const Analyzer::ColumnVar*> cvs,
650 Executor* executor) {
651 std::unordered_set<shared::TableKey> phys_table_ids;
652 for (
auto cv : cvs) {
653 phys_table_ids.insert(cv->getTableKey());
659 std::vector<InputTableInfo> query_infos;
660 query_infos.reserve(phys_table_ids.size());
662 for (
const auto& table_key : phys_table_ids) {
665 query_infos.push_back({table_key, td->fragmenter->getFragmentsForQuery()});
674 std::string_view table1,
675 std::string_view column1,
677 std::string_view table2,
678 std::string_view column2,
682 const int device_count,
684 Executor* executor) {
688 auto qual_bin_oper = std::make_shared<Analyzer::BinOper>(
kBOOLEAN,
kEQ,
kONE, a1, a2);
690 std::set<const Analyzer::ColumnVar*> cvs =
712 const std::shared_ptr<Analyzer::BinOper> qual_bin_oper,
715 const int device_count,
717 Executor* executor) {
718 std::set<const Analyzer::ColumnVar*> cvs =
739 std::vector<std::shared_ptr<Analyzer::BinOper>> qual_bin_opers,
742 const int device_count,
744 Executor* executor) {
745 std::set<const Analyzer::ColumnVar*> cvs;
746 for (
auto& qual : qual_bin_opers) {
748 cvs.insert(cv.begin(), cv.end());
753 std::shared_ptr<HashJoin> hash_table;
754 std::string error_msg;
755 for (
auto& qual : qual_bin_opers) {
768 if (candidate_hash_table) {
769 hash_table = candidate_hash_table;
772 error_msg = e.what();
776 return std::make_pair(error_msg, hash_table);
780 const size_t shard_count,
781 const Executor* executor) {
795 template <
typename T>
797 auto* target_expr = expr;
798 if (
auto cast_expr = dynamic_cast<const Analyzer::UOper*>(expr)) {
799 target_expr = cast_expr->get_operand();
802 return dynamic_cast<const T*
>(target_expr);
809 const bool is_overlaps_join) {
812 if (!is_overlaps_join) {
814 throw HashJoinFail(
"Equijoin types must be identical, found: " +
819 throw HashJoinFail(
"Cannot apply hash join to inner column type " +
825 throw HashJoinFail(
"Equijoin with different decimal types");
831 if (lhs_ti.
is_string() && (
static_cast<bool>(lhs_cast) != static_cast<bool>(rhs_cast) ||
832 (lhs_cast && lhs_cast->get_optype() !=
kCAST) ||
833 (rhs_cast && rhs_cast->get_optype() !=
kCAST))) {
835 "Cannot use hash join for given expression (non-cast unary operator)");
838 if (lhs_ti.
is_decimal() && (lhs_cast || rhs_cast)) {
839 throw HashJoinFail(
"Cannot use hash join for given expression (cast to decimal)");
841 auto lhs_col = getHashJoinColumn<Analyzer::ColumnVar>(lhs);
842 auto rhs_col = getHashJoinColumn<Analyzer::ColumnVar>(rhs);
844 const auto lhs_string_oper = getHashJoinColumn<Analyzer::StringOper>(lhs);
845 const auto rhs_string_oper = getHashJoinColumn<Analyzer::StringOper>(rhs);
847 auto process_string_op_infos = [](
const auto& string_oper,
auto& col,
auto& ti) {
848 std::vector<StringOps_Namespace::StringOpInfo> string_op_infos;
860 "Hash joins involving string operators currently restricted to column inputs "
861 "(i.e. not case statements).");
863 ti = col->get_type_info();
864 CHECK(ti.is_dict_encoded_string());
865 const auto chained_string_op_exprs = string_oper->getChainedStringOpExprs();
866 CHECK_GT(chained_string_op_exprs.size(), 0UL);
867 for (
const auto& chained_string_op_expr : chained_string_op_exprs) {
868 auto chained_string_op =
870 CHECK(chained_string_op);
872 chained_string_op->get_kind(),
873 chained_string_op->get_type_info(),
874 chained_string_op->getLiteralArgs());
875 string_op_infos.emplace_back(string_op_info);
878 return string_op_infos;
881 auto outer_string_op_infos = process_string_op_infos(lhs_string_oper, lhs_col, lhs_ti);
882 auto inner_string_op_infos = process_string_op_infos(rhs_string_oper, rhs_col, rhs_ti);
884 if (!lhs_col && !rhs_col) {
886 "Cannot use hash join for given expression (both lhs and rhs are invalid)",
892 auto outer_ti = lhs_ti;
893 auto inner_ti = rhs_ti;
896 if (!lhs_col || (rhs_col && lhs_col->get_rte_idx() < rhs_col->get_rte_idx())) {
902 if (lhs_col && lhs_col->get_rte_idx() == 0) {
904 "Cannot use hash join for given expression (lhs' rte idx is zero)",
905 inner_qual_decision);
910 std::swap(outer_string_op_infos, inner_string_op_infos);
914 throw HashJoinFail(
"Cannot use hash join for given expression (invalid inner col)",
915 inner_qual_decision);
920 if (outer_constant_col) {
922 "Cannot use hash join for given expression: try to join with a constant "
924 inner_qual_decision);
927 int outer_rte_idx = rte_idx_visitor.
visit(outer_expr);
930 if (inner_col->get_rte_idx() <= outer_rte_idx) {
932 "Cannot use hash join for given expression (inner's rte <= outer's rte)",
933 inner_qual_decision);
938 const auto& column_key = inner_col->getColumnKey();
941 column_key.column_id, column_key.table_id, inner_col_cd, temporary_tables);
942 const auto& outer_col_ti =
944 ? outer_col->get_type_info()
947 if ((inner_col_real_ti.is_decimal() || outer_col_ti.is_decimal()) &&
948 (lhs_cast || rhs_cast)) {
949 throw HashJoinFail(
"Cannot use hash join for given expression (cast from decimal)");
951 if (is_overlaps_join) {
952 if (!inner_col_real_ti.is_array()) {
954 "Overlaps join only supported for inner columns with array type");
956 auto is_bounds_array = [](
const auto ti) {
957 return ti.is_fixlen_array() && ti.get_size() == 32;
959 if (!is_bounds_array(inner_col_real_ti)) {
961 "Overlaps join only supported for 4-element double fixed length arrays");
963 if (!(outer_col_ti.get_type() ==
kPOINT || is_bounds_array(outer_col_ti) ||
966 "Overlaps join only supported for geometry outer columns of type point, "
967 "geometry columns with bounds or constructed points");
970 if (!(inner_col_real_ti.is_integer() || inner_col_real_ti.is_time() ||
971 inner_col_real_ti.is_decimal() ||
972 (inner_col_real_ti.is_string() &&
975 "Can only apply hash join to integer-like types and dictionary encoded "
980 auto normalized_inner_col = inner_col;
981 auto normalized_outer_col = outer_col ? outer_col : outer_expr;
983 const auto& normalized_inner_ti = normalized_inner_col->get_type_info();
984 const auto& normalized_outer_ti = normalized_outer_col->get_type_info();
986 if (normalized_inner_ti.is_string() != normalized_outer_ti.is_string()) {
987 throw HashJoinFail(std::string(
"Could not build hash tables for incompatible types " +
988 normalized_inner_ti.get_type_name() +
" and " +
989 normalized_outer_ti.get_type_name()));
991 return std::make_pair(std::make_pair(normalized_inner_col, normalized_outer_col),
992 std::make_pair(inner_string_op_infos, outer_string_op_infos));
995 std::pair<std::vector<InnerOuter>, std::vector<InnerOuterStringOpInfos>>
998 std::pair<std::vector<InnerOuter>, std::vector<InnerOuterStringOpInfos>>
result;
999 const auto lhs_tuple_expr =
1001 const auto rhs_tuple_expr =
1004 CHECK_EQ(static_cast<bool>(lhs_tuple_expr), static_cast<bool>(rhs_tuple_expr));
1005 if (lhs_tuple_expr) {
1006 const auto& lhs_tuple = lhs_tuple_expr->getTuple();
1007 const auto& rhs_tuple = rhs_tuple_expr->getTuple();
1008 CHECK_EQ(lhs_tuple.size(), rhs_tuple.size());
1009 for (
size_t i = 0; i < lhs_tuple.size(); ++i) {
1014 result.first.emplace_back(col_pair.first);
1015 result.second.emplace_back(col_pair.second);
1018 CHECK(!lhs_tuple_expr && !rhs_tuple_expr);
1023 result.first.emplace_back(col_pair.first);
1024 result.second.emplace_back(col_pair.second);
1031 bool invalid_cache_key,
1049 const Executor* executor) {
1052 std::shared_ptr<Analyzer::BinOper> redirected_bin_oper;
1054 std::tie(inner_col, outer_col) =
1055 get_cols(join_condition, executor->getTemporaryTables());
1059 if (!inner_col || !outer_col) {
static std::vector< int > collectFragmentIds(const std::vector< Fragmenter_Namespace::FragmentInfo > &fragments)
static std::shared_ptr< HashJoin > getSyntheticInstance(std::string_view table1, std::string_view column1, const Catalog_Namespace::Catalog &catalog1, std::string_view table2, std::string_view column2, const Catalog_Namespace::Catalog &catalog2, const Data_Namespace::MemoryLevel memory_level, const HashType preferred_hash_type, const int device_count, ColumnCacheMap &column_cache, Executor *executor)
Make hash table from named tables and columns (such as for testing).
int64_t getIntMin() const
std::vector< int > ChunkKey
std::vector< InputTableInfo > getSyntheticInputTableInfo(std::set< const Analyzer::ColumnVar * > cvs, Executor *executor)
virtual HashJoinMatchingSet codegenMatchingSet(const CompilationOptions &, const size_t)=0
static llvm::Value * codegenHashTableLoad(const size_t table_idx, Executor *executor)
class for a per-database catalog. also includes metadata for the current database and the current use...
std::pair< const Analyzer::ColumnVar *, const Analyzer::Expr * > InnerOuter
std::string toStringFlat(const HashJoin *hash_table, const ExecutorDeviceType device_type, const int device_id)
static bool canAccessHashTable(bool allow_hash_table_recycling, bool invalid_cache_key, JoinType join_type)
std::vector< const void * > sd_inner_proxy_per_key
virtual std::string toStringFlat64(const ExecutorDeviceType device_type, const int device_id) const
std::list< std::shared_ptr< Analyzer::Expr > > coalesce_singleton_equi_join(const std::shared_ptr< Analyzer::BinOper > &join_qual)
static void checkHashJoinReplicationConstraint(const shared::TableKey &table_key, const size_t shard_count, const Executor *executor)
std::ostream & operator<<(std::ostream &os, const SessionInfo &session_info)
static JoinColumn makeJoinColumn(Executor *executor, const Analyzer::ColumnVar &hash_col, const std::vector< Fragmenter_Namespace::FragmentInfo > &fragments, const Data_Namespace::MemoryLevel effective_mem_lvl, const int device_id, DeviceAllocator *device_allocator, const size_t thread_idx, std::vector< std::shared_ptr< Chunk_NS::Chunk >> &chunks_owner, std::vector< std::shared_ptr< void >> &malloc_owner, ColumnCacheMap &column_cache)
Creates a JoinColumn struct containing an array of JoinChunk structs.
void setBucketInfo(const std::vector< double > &bucket_sizes_for_dimension, const std::vector< InnerOuter > inner_outer_pairs)
std::set< const Analyzer::ColumnVar * > aggregateResult(const std::set< const Analyzer::ColumnVar * > &aggregate, const std::set< const Analyzer::ColumnVar * > &next_result) const override
HOST DEVICE int get_scale() const
const Expr * get_right_operand() const
bool is_constructed_point(const Analyzer::Expr *expr)
JoinColumn fetchJoinColumn(const Analyzer::ColumnVar *hash_col, const std::vector< Fragmenter_Namespace::FragmentInfo > &fragment_info, const Data_Namespace::MemoryLevel effective_memory_level, const int device_id, std::vector< std::shared_ptr< Chunk_NS::Chunk >> &chunks_owner, DeviceAllocator *dev_buff_owner, std::vector< std::shared_ptr< void >> &malloc_owner, Executor *executor, ColumnCacheMap *column_cache)
static std::shared_ptr< OverlapsJoinHashTable > getInstance(const std::shared_ptr< Analyzer::BinOper > condition, const std::vector< InputTableInfo > &query_infos, const Data_Namespace::MemoryLevel memory_level, const JoinType join_type, const int device_count, ColumnCacheMap &column_cache, Executor *executor, const HashTableBuildDagMap &hashtable_build_dag_map, const RegisteredQueryHint &query_hint, const TableIdToNodeMap &table_id_to_node_map)
Make hash table from an in-flight SQL query's parse tree etc.
static std::pair< const StringDictionaryProxy *, StringDictionaryProxy * > getStrDictProxies(const InnerOuter &cols, const Executor *executor, const bool has_string_ops)
const TableDescriptor * get_metadata_for_table(const ::shared::TableKey &table_key, bool populate_fragmenter)
DEVICE void sort(ARGS &&...args)
const SQLTypeInfo get_column_type(const int col_id, const int table_id, const ColumnDescriptor *cd, const TemporaryTables *temporary_tables)
llvm::Value * codegenPseudoStringOper(const Analyzer::ColumnVar *, const std::vector< StringOps_Namespace::StringOpInfo > &string_op_infos, const CompilationOptions &)
virtual int8_t * alloc(const size_t num_bytes)=0
InnerOuter get_cols(const Analyzer::BinOper *qual_bin_oper, const TemporaryTables *temporary_tables)
T visit(const Analyzer::Expr *expr) const
HOST DEVICE SQLTypes get_type() const
static llvm::Value * codegenColOrStringOper(const Analyzer::Expr *col_or_string_oper, const std::vector< StringOps_Namespace::StringOpInfo > &string_op_infos, CodeGenerator &code_generator, const CompilationOptions &co)
bool g_enable_data_recycler
virtual std::string toStringFlat32(const ExecutorDeviceType device_type, const int device_id) const
bool g_enable_overlaps_hashjoin
const std::vector< JoinColumnTypeInfo > join_column_types
virtual void copyToDevice(void *device_dst, const void *host_src, const size_t num_bytes) const =0
size_t col_chunks_buff_sz
std::unordered_map< size_t, HashTableBuildDag > HashTableBuildDagMap
const std::vector< std::shared_ptr< Analyzer::Expr > > & getTuple() const
llvm::Value * get_arg_by_name(llvm::Function *func, const std::string &name)
std::vector< void * > sd_outer_proxy_per_key
const ColumnDescriptor * get_column_descriptor_maybe(const shared::ColumnKey &column_key)
const ColumnDescriptor * getMetadataForColumn(int tableId, const std::string &colName) const
int8_t * getJoinHashBuffer(const ExecutorDeviceType device_type, const int device_id) const
int getDatabaseId() const
static std::vector< const StringDictionaryProxy::IdMap * > translateCompositeStrDictProxies(const CompositeKeyInfo &composite_key_info, const std::vector< InnerOuterStringOpInfos > &string_op_infos_for_keys, const Executor *executor)
std::string toString(const ExecutorDeviceType &device_type)
OUTPUT transform(INPUT const &input, FUNC const &func)
const int8_t * col_chunks_buff
const SQLTypeInfo & get_type_info() const
int get_precision() const
static ExpressionRange makeIntRange(const int64_t int_min, const int64_t int_max, const int64_t bucket, const bool has_nulls)
static const StringDictionaryProxy::IdMap * translateInnerToOuterStrDictProxies(const InnerOuter &cols, const InnerOuterStringOpInfos &inner_outer_string_op_infos, ExpressionRange &old_col_range, const Executor *executor)
static std::pair< InnerOuter, InnerOuterStringOpInfos > normalizeColumnPair(const Analyzer::Expr *lhs, const Analyzer::Expr *rhs, const TemporaryTables *temporary_tables, const bool is_overlaps_join=false)
void setupSyntheticCaching(std::set< const Analyzer::ColumnVar * > cvs, Executor *executor)
std::unordered_map< shared::TableKey, const RelAlgNode * > TableIdToNodeMap
std::vector< llvm::Value * > codegen(const Analyzer::Expr *, const bool fetch_columns, const CompilationOptions &)
static RegisteredQueryHint defaults()
Expression class for string functions The "arg" constructor parameter must be an expression that reso...
size_t getJoinHashBufferSize(const ExecutorDeviceType device_type)
bool table_is_replicated(const TableDescriptor *td)
std::set< DecodedJoinHashBufferEntry > DecodedJoinHashBufferSet
std::set< const Analyzer::ColumnVar * > visitColumnVarTuple(const Analyzer::ExpressionTuple *expr_tuple) const override
static std::shared_ptr< BaselineJoinHashTable > getInstance(const std::shared_ptr< Analyzer::BinOper > condition, const std::vector< InputTableInfo > &query_infos, const Data_Namespace::MemoryLevel memory_level, const JoinType join_type, const HashType preferred_hash_type, const int device_count, ColumnCacheMap &column_cache, Executor *executor, const HashTableBuildDagMap &hashtable_build_dag_map, const RegisteredQueryHint &query_hints, const TableIdToNodeMap &table_id_to_node_map)
Make hash table from an in-flight SQL query's parse tree etc.
std::unordered_map< shared::TableKey, std::unordered_map< int, std::shared_ptr< const ColumnarResults >>> ColumnCacheMap
std::string get_type_name() const
static std::shared_ptr< PerfectJoinHashTable > getInstance(const std::shared_ptr< Analyzer::BinOper > qual_bin_oper, const std::vector< InputTableInfo > &query_infos, const Data_Namespace::MemoryLevel memory_level, const JoinType join_type, const HashType preferred_hash_type, const int device_count, ColumnCacheMap &column_cache, Executor *executor, const HashTableBuildDagMap &hashtable_build_dag_map, const RegisteredQueryHint &query_hints, const TableIdToNodeMap &table_id_to_node_map)
Make hash table from an in-flight SQL query's parse tree etc.
std::shared_ptr< Analyzer::ColumnVar > getSyntheticColumnVar(std::string_view table, std::string_view column, int rte_idx, const Catalog_Namespace::Catalog &catalog)
int64_t getIntMax() const
std::set< const Analyzer::ColumnVar * > visitColumnVar(const Analyzer::ColumnVar *column) const override
std::pair< std::vector< StringOps_Namespace::StringOpInfo >, std::vector< StringOps_Namespace::StringOpInfo >> InnerOuterStringOpInfos
std::set< int32_t > payload
#define DEBUG_TIMER(name)
static const T * getHashJoinColumn(const Analyzer::Expr *expr)
static std::pair< std::vector< InnerOuter >, std::vector< InnerOuterStringOpInfos > > normalizeColumnPairs(const Analyzer::BinOper *condition, const TemporaryTables *temporary_tables)
const Expr * get_left_operand() const
bool is_overlaps_oper() const
const TableDescriptor * getMetadataForTable(const std::string &tableName, const bool populateFragmenter=true) const
Returns a pointer to a const TableDescriptor struct matching the provided tableName.
std::vector< int64_t > key
std::vector< JoinBucketInfo > join_buckets
size_t get_shard_count(const Analyzer::BinOper *join_condition, const Executor *executor)
static std::shared_ptr< HashJoin > getInstance(const std::shared_ptr< Analyzer::BinOper > qual_bin_oper, const std::vector< InputTableInfo > &query_infos, const Data_Namespace::MemoryLevel memory_level, const JoinType join_type, const HashType preferred_hash_type, const int device_count, ColumnCacheMap &column_cache, Executor *executor, const HashTableBuildDagMap &hashtable_build_dag_map, const RegisteredQueryHint &query_hint, const TableIdToNodeMap &table_id_to_node_map)
Make hash table from an in-flight SQL query's parse tree etc.
DEVICE void swap(ARGS &&...args)
bool g_use_hashtable_cache
const std::vector< JoinColumn > join_columns
static CompositeKeyInfo getCompositeKeyInfo(const std::vector< InnerOuter > &inner_outer_pairs, const Executor *executor, const std::vector< InnerOuterStringOpInfos > &inner_outer_string_op_infos_pairs={})