OmniSciDB  72c90bc290
 All Classes Namespaces Files Functions Variables Typedefs Enumerations Enumerator Friends Macros Groups Pages
RangeJoinHashTable Member List

This is the complete list of members for RangeJoinHashTable, including all inherited members.

approximateTupleCount(const std::vector< double > &inverse_bucket_sizes_for_dimension, std::vector< ColumnsForDevice > &columns_per_device, const size_t chosen_max_hashtable_size, const double chosen_bucket_threshold) overrideRangeJoinHashTableprotectedvirtual
auto_tuner_cache_BoundingBoxIntersectJoinHashTableprotectedstatic
BoundingBoxIntersectJoinHashTable(const std::shared_ptr< Analyzer::BinOper > condition, const JoinType join_type, const std::vector< InputTableInfo > &query_infos, const Data_Namespace::MemoryLevel memory_level, ColumnCacheMap &column_cache, Executor *executor, const std::vector< InnerOuter > &inner_outer_pairs, const int device_count, const RegisteredQueryHint &query_hints, const HashTableBuildDagMap &hashtable_build_dag_map, const TableIdToNodeMap &table_id_to_node_map)BoundingBoxIntersectJoinHashTableinline
bucket_threshold_RangeJoinHashTableprivate
calculateHashTableSize(size_t number_of_dimensions, size_t emitted_keys_count, size_t entry_count) const BoundingBoxIntersectJoinHashTableprotected
canAccessHashTable(bool allow_hash_table_recycling, bool invalid_cache_key, JoinType join_type)HashJoinstatic
checkHashJoinReplicationConstraint(const shared::TableKey &table_key, const size_t shard_count, const Executor *executor)HashJoinstatic
chosen_bbox_intersect_bucket_threshold_BoundingBoxIntersectJoinHashTableprotected
chosen_bbox_intersect_max_table_size_bytes_BoundingBoxIntersectJoinHashTableprotected
codegenColOrStringOper(const Analyzer::Expr *col_or_string_oper, const std::vector< StringOps_Namespace::StringOpInfo > &string_op_infos, CodeGenerator &code_generator, const CompilationOptions &co)HashJoinprotectedstatic
codegenHashTableLoad(const size_t table_idx, Executor *executor)HashJoinstatic
codegenKey(const CompilationOptions &co, llvm::Value *offset)RangeJoinHashTable
BoundingBoxIntersectJoinHashTable::codegenKey(const CompilationOptions &)BoundingBoxIntersectJoinHashTableprotected
codegenManyKey(const CompilationOptions &)BoundingBoxIntersectJoinHashTableprotected
codegenMatchingSet(const CompilationOptions &, const size_t) overrideBoundingBoxIntersectJoinHashTableprotectedvirtual
HashJoin::codegenMatchingSet(const std::vector< llvm::Value * > &hash_join_idx_args_in, const bool is_sharded, const bool col_is_nullable, const bool is_bw_eq, const int64_t sub_buff_size, Executor *executor, const bool is_bucketized=false)HashJoinstatic
codegenMatchingSetWithOffset(const CompilationOptions &, const size_t, llvm::Value *)RangeJoinHashTable
codegenSlot(const CompilationOptions &, const size_t) overrideBoundingBoxIntersectJoinHashTableinlineprotectedvirtual
collectFragmentIds(const std::vector< Fragmenter_Namespace::FragmentInfo > &fragments)HashJoinstatic
column_cache_BoundingBoxIntersectJoinHashTableprotected
composite_key_info_BoundingBoxIntersectJoinHashTableprotected
computeHashTableCounts(const size_t shard_count, const std::vector< double > &inverse_bucket_sizes_for_dimension, std::vector< ColumnsForDevice > &columns_per_device, const size_t chosen_max_hashtable_size, const double chosen_bucket_threshold)BoundingBoxIntersectJoinHashTableprotectedvirtual
computeRangeHashTableCounts(const size_t shard_count, std::vector< ColumnsForDevice > &columns_per_device)RangeJoinHashTableprotected
condition_BoundingBoxIntersectJoinHashTableprotected
countBufferOff() const noexceptoverrideBoundingBoxIntersectJoinHashTableinlineprotectedvirtual
cpu_hash_table_buff_mutex_BoundingBoxIntersectJoinHashTableprotected
device_count_BoundingBoxIntersectJoinHashTableprotected
effective_memory_level_RangeJoinHashTableprivate
executor_BoundingBoxIntersectJoinHashTableprotected
fetchColumnsForDevice(const std::vector< Fragmenter_Namespace::FragmentInfo > &fragments, const int device_id, DeviceAllocator *dev_buff_owner)BoundingBoxIntersectJoinHashTableprotected
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)HashJoin
freeHashBufferMemory()HashJoininline
generateCacheKey(const size_t max_hashtable_size, const double bucket_threshold, const std::vector< double > &bucket_sizes, std::vector< std::vector< Fragmenter_Namespace::FragmentInfo >> &fragments_per_device, int device_count)BoundingBoxIntersectJoinHashTableinlineprotected
generateTooManyHashEntriesErrMsg(size_t num_entries, size_t threshold, MemoryLevel memory_level)HashJoininlinestatic
getAlternativeCacheKey(AlternativeCacheKeyForBoundingBoxIntersection &info)BoundingBoxIntersectJoinHashTableinlineprotected
getApproximateTupleCountFromCache(QueryPlanHash key, CacheItemType item_type, DeviceIdentifier device_identifier)BoundingBoxIntersectJoinHashTableprotected
getBoundingBoxIntersectMetaInfo()BoundingBoxIntersectJoinHashTableinlineprotected
getBoundingBoxIntersectTuningParamCache()BoundingBoxIntersectJoinHashTableinlinestatic
getCacheKey(int device_id) const BoundingBoxIntersectJoinHashTableinlineprotected
getComponentBufferSize() const noexceptoverrideBoundingBoxIntersectJoinHashTableinlineprotectedvirtual
getCompositeKeyInfo(const std::vector< InnerOuter > &inner_outer_pairs, const Executor *executor, const std::vector< InnerOuterStringOpInfos > &inner_outer_string_op_infos_pairs={})HashJoinstatic
getDeviceCount() const noexceptoverrideBoundingBoxIntersectJoinHashTableinlineprotectedvirtual
getEffectiveMemoryLevel(const std::vector< InnerOuter > &inner_outer_pairs) const BoundingBoxIntersectJoinHashTableprotected
getEmittedKeysCount() const BoundingBoxIntersectJoinHashTableinlineprotected
getEntryCount() const BoundingBoxIntersectJoinHashTableinlineprotected
getHashJoinColumn(const Analyzer::Expr *expr)HashJoinstatic
getHashJoinType() const finalBoundingBoxIntersectJoinHashTableinlineprotectedvirtual
getHashTableCache()BoundingBoxIntersectJoinHashTableinlinestatic
getHashTableForDevice(const size_t device_id) const HashJoininline
getHashType() const noexceptoverrideRangeJoinHashTableinlineprotectedvirtual
getHashTypeString(HashType ht) noexceptHashJoininlinestatic
getInnerOuterPairs() const BoundingBoxIntersectJoinHashTableinlineprotected
getInnerTableId() const noexceptoverrideBoundingBoxIntersectJoinHashTableprotectedvirtual
HashJoin::getInnerTableId(const std::vector< InnerOuter > &inner_outer_pairs)HashJoininlinestatic
getInnerTableRteIdx() const noexceptoverrideBoundingBoxIntersectJoinHashTableinlineprotectedvirtual
getInstance(const std::shared_ptr< Analyzer::BinOper > condition, const Analyzer::RangeOper *range_expr, 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_hints, const TableIdToNodeMap &table_id_to_node_map)RangeJoinHashTablestatic
BoundingBoxIntersectJoinHashTable::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)BoundingBoxIntersectJoinHashTablestatic
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)HashJoinstatic
getJoinHashBuffer(const ExecutorDeviceType device_type, const int device_id) const HashJoininline
getJoinHashBufferSize(const ExecutorDeviceType device_type)HashJoininline
getJoinHashBufferSize(const ExecutorDeviceType device_type, const int device_id) const HashJoininline
getKeyBufferSize() const noexceptBoundingBoxIntersectJoinHashTableinlineprotected
getKeyComponentCount() const BoundingBoxIntersectJoinHashTableprotected
getKeyComponentWidth() const BoundingBoxIntersectJoinHashTableprotected
getMaximumNumHashEntriesCanHold(MemoryLevel memory_level, const Executor *executor, size_t rowid_size) noexceptHashJoinstatic
getMemoryLevel() const noexceptoverrideBoundingBoxIntersectJoinHashTableinlineprotectedvirtual
getRegisteredQueryHint()BoundingBoxIntersectJoinHashTableinlineprotected
getStrDictProxies(const InnerOuter &cols, const Executor *executor, const bool has_string_ops)HashJoinstatic
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)HashJoinstatic
getSyntheticInstance(const std::shared_ptr< Analyzer::BinOper > qual_bin_oper, const Data_Namespace::MemoryLevel memory_level, const HashType preferred_hash_type, const int device_count, ColumnCacheMap &column_cache, Executor *executor)HashJoinstatic
getSyntheticInstance(std::vector< std::shared_ptr< Analyzer::BinOper >>, const Data_Namespace::MemoryLevel memory_level, const HashType preferred_hash_type, const int device_count, ColumnCacheMap &column_cache, Executor *executor)HashJoinstatic
hash_table_cache_BoundingBoxIntersectJoinHashTableprotectedstatic
hash_tables_for_device_HashJoinprotected
hashtable_build_dag_map_BoundingBoxIntersectJoinHashTableprotected
hashtable_cache_key_BoundingBoxIntersectJoinHashTableprotected
hashtable_cache_meta_info_BoundingBoxIntersectJoinHashTableprotected
initHashTableOnCpu(const std::vector< JoinColumn > &join_columns, const std::vector< JoinColumnTypeInfo > &join_column_types, const std::vector< JoinBucketInfo > &join_bucket_info, const BaselineHashTableEntryInfo hash_table_entry_info)RangeJoinHashTableprotected
BoundingBoxIntersectJoinHashTable::initHashTableOnCpu(const std::vector< JoinColumn > &join_columns, const std::vector< JoinColumnTypeInfo > &join_column_types, const std::vector< JoinBucketInfo > &join_bucket_info, const BaselineHashTableEntryInfo hash_table_entry_info, const bool skip_hashtable_caching)BoundingBoxIntersectJoinHashTableprotected
initHashTableOnCpuFromCache(QueryPlanHash key, CacheItemType item_type, DeviceIdentifier device_identifier)BoundingBoxIntersectJoinHashTableprotected
inner_col_expr_RangeJoinHashTableprivate
inner_outer_pairs_BoundingBoxIntersectJoinHashTableprotected
invalidateCache()BoundingBoxIntersectJoinHashTableinlinestatic
inverse_bucket_sizes_for_dimension_BoundingBoxIntersectJoinHashTableprotected
isBitwiseEq() const overrideBoundingBoxIntersectJoinHashTableprotectedvirtual
isInnerColCompressed() const RangeJoinHashTableinlineprivate
isProbeCompressed() const RangeJoinHashTableinlineprivate
join_type_BoundingBoxIntersectJoinHashTableprotected
layout_override_BoundingBoxIntersectJoinHashTableprotected
layoutRequiresAdditionalBuffers(HashType layout) noexceptHashJoininlinestatic
markCachedItemAsDirty(size_t table_key)BoundingBoxIntersectJoinHashTableinlinestatic
max_hashtable_size_RangeJoinHashTableprivate
MAX_NUM_HASH_ENTRIESHashJoinstatic
memory_level_BoundingBoxIntersectJoinHashTableprotected
normalizeColumnPair(const Analyzer::Expr *lhs, const Analyzer::Expr *rhs, const TemporaryTables *temporary_tables, const bool is_bbox_intersect=false)HashJoinstatic
normalizeColumnPairs(const Analyzer::BinOper *condition, const TemporaryTables *temporary_tables)HashJoinstatic
offsetBufferOff() const noexceptoverrideBoundingBoxIntersectJoinHashTableinlineprotectedvirtual
payloadBufferOff() const noexceptoverrideBoundingBoxIntersectJoinHashTableinlineprotectedvirtual
putHashTableOnCpuToCache(QueryPlanHash key, CacheItemType item_type, std::shared_ptr< HashTable > hashtable_ptr, DeviceIdentifier device_identifier, size_t hashtable_building_time)BoundingBoxIntersectJoinHashTableprotected
query_hints_BoundingBoxIntersectJoinHashTableprotected
query_infos_BoundingBoxIntersectJoinHashTableprotected
query_plan_dag_BoundingBoxIntersectJoinHashTableprotected
range_expr_RangeJoinHashTableprivate
RangeJoinHashTable(const std::shared_ptr< Analyzer::BinOper > condition, const JoinType join_type, const Analyzer::RangeOper *range_expr, std::shared_ptr< Analyzer::ColumnVar > inner_col_expr, const std::vector< InputTableInfo > &query_infos, const Data_Namespace::MemoryLevel memory_level, ColumnCacheMap &column_cache, Executor *executor, const std::vector< InnerOuter > &inner_outer_pairs, const int device_count, const RegisteredQueryHint &query_hints, const HashTableBuildDagMap &hashtable_build_dag_map, const TableIdToNodeMap &table_id_to_node_map)RangeJoinHashTableinline
reify(const HashType preferred_layout)BoundingBoxIntersectJoinHashTableprotected
reifyForDevice(const ColumnsForDevice &columns_for_device, const HashType layout, const size_t entry_count, const size_t emitted_keys_count, const int device_id, const logger::ThreadLocalIds parent_thread_local_ids)RangeJoinHashTableprotected
BoundingBoxIntersectJoinHashTable::reifyForDevice(const ColumnsForDevice &columns_for_device, const HashType layout, const size_t entry_count, const size_t emitted_keys_count, const bool skip_hashtable_caching, const int device_id, const logger::ThreadLocalIds parent_thread_local_ids)BoundingBoxIntersectJoinHashTableprotected
reifyImpl(std::vector< ColumnsForDevice > &columns_per_device, const Fragmenter_Namespace::TableInfo &query_info, const HashType layout, const size_t shard_count, const size_t entry_count, const size_t emitted_keys_count, const bool skip_hashtable_caching, const size_t chosen_max_hashtable_size, const double chosen_bucket_threshold)BoundingBoxIntersectJoinHashTableprotectedvirtual
reifyWithLayout(const HashType layout) overrideRangeJoinHashTableprotectedvirtual
setBoundingBoxIntersectionMetaInfo(size_t max_table_size_bytes, double bucket_threshold, std::vector< double > &bucket_sizes)BoundingBoxIntersectJoinHashTableinlineprotected
setInverseBucketSizeInfo(const std::vector< double > &inverse_bucket_sizes, std::vector< ColumnsForDevice > &columns_per_device, const size_t device_count)BoundingBoxIntersectJoinHashTableprotected
shardCount() const BoundingBoxIntersectJoinHashTableinlineprotected
table_id_to_node_map_BoundingBoxIntersectJoinHashTableprotected
table_keys_BoundingBoxIntersectJoinHashTableprotected
toSet(const ExecutorDeviceType device_type, const int device_id) const overrideBoundingBoxIntersectJoinHashTableprotectedvirtual
toString(const ExecutorDeviceType device_type, const int device_id=0, bool raw=false) const overrideBoundingBoxIntersectJoinHashTableprotectedvirtual
toStringFlat32(const ExecutorDeviceType device_type, const int device_id) const HashJoinvirtual
toStringFlat64(const ExecutorDeviceType device_type, const int device_id) const HashJoinvirtual
translateCompositeStrDictProxies(const CompositeKeyInfo &composite_key_info, const std::vector< InnerOuterStringOpInfos > &string_op_infos_for_keys, const Executor *executor)HashJoinstatic
translateInnerToOuterStrDictProxies(const InnerOuter &cols, const InnerOuterStringOpInfos &inner_outer_string_op_infos, ExpressionRange &old_col_range, const Executor *executor)HashJoinstatic
~BoundingBoxIntersectJoinHashTable()BoundingBoxIntersectJoinHashTableinlinevirtual
~RangeJoinHashTable() override=defaultRangeJoinHashTable