OmniSciDB
a5dc49c757
|
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) override | RangeJoinHashTable | protectedvirtual |
auto_tuner_cache_ | BoundingBoxIntersectJoinHashTable | protectedstatic |
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) | BoundingBoxIntersectJoinHashTable | inline |
bucket_threshold_ | RangeJoinHashTable | private |
calculateHashTableSize(size_t number_of_dimensions, size_t emitted_keys_count, size_t entry_count) const | BoundingBoxIntersectJoinHashTable | protected |
canAccessHashTable(bool allow_hash_table_recycling, bool invalid_cache_key, JoinType join_type) | HashJoin | static |
checkHashJoinReplicationConstraint(const shared::TableKey &table_key, const size_t shard_count, const Executor *executor) | HashJoin | static |
chosen_bbox_intersect_bucket_threshold_ | BoundingBoxIntersectJoinHashTable | protected |
chosen_bbox_intersect_max_table_size_bytes_ | BoundingBoxIntersectJoinHashTable | protected |
codegenColOrStringOper(const Analyzer::Expr *col_or_string_oper, const std::vector< StringOps_Namespace::StringOpInfo > &string_op_infos, CodeGenerator &code_generator, const CompilationOptions &co) | HashJoin | protectedstatic |
codegenHashTableLoad(const size_t table_idx, Executor *executor) | HashJoin | static |
codegenKey(const CompilationOptions &co, llvm::Value *offset) | RangeJoinHashTable | |
BoundingBoxIntersectJoinHashTable::codegenKey(const CompilationOptions &) | BoundingBoxIntersectJoinHashTable | protected |
codegenManyKey(const CompilationOptions &) | BoundingBoxIntersectJoinHashTable | protected |
codegenMatchingSet(const CompilationOptions &, const size_t) override | BoundingBoxIntersectJoinHashTable | protectedvirtual |
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) | HashJoin | static |
codegenMatchingSetWithOffset(const CompilationOptions &, const size_t, llvm::Value *) | RangeJoinHashTable | |
codegenSlot(const CompilationOptions &, const size_t) override | BoundingBoxIntersectJoinHashTable | inlineprotectedvirtual |
collectFragmentIds(const std::vector< Fragmenter_Namespace::FragmentInfo > &fragments) | HashJoin | static |
column_cache_ | BoundingBoxIntersectJoinHashTable | protected |
composite_key_info_ | BoundingBoxIntersectJoinHashTable | protected |
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) | BoundingBoxIntersectJoinHashTable | protectedvirtual |
computeRangeHashTableCounts(const size_t shard_count, std::vector< ColumnsForDevice > &columns_per_device) | RangeJoinHashTable | protected |
condition_ | BoundingBoxIntersectJoinHashTable | protected |
countBufferOff() const noexceptoverride | BoundingBoxIntersectJoinHashTable | inlineprotectedvirtual |
cpu_hash_table_buff_mutex_ | BoundingBoxIntersectJoinHashTable | protected |
device_count_ | BoundingBoxIntersectJoinHashTable | protected |
effective_memory_level_ | RangeJoinHashTable | private |
executor_ | BoundingBoxIntersectJoinHashTable | protected |
fetchColumnsForDevice(const std::vector< Fragmenter_Namespace::FragmentInfo > &fragments, const int device_id, DeviceAllocator *dev_buff_owner) | BoundingBoxIntersectJoinHashTable | protected |
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() | HashJoin | inline |
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) | BoundingBoxIntersectJoinHashTable | inlineprotected |
generateTooManyHashEntriesErrMsg(size_t num_entries, size_t threshold, MemoryLevel memory_level) | HashJoin | inlinestatic |
getAlternativeCacheKey(AlternativeCacheKeyForBoundingBoxIntersection &info) | BoundingBoxIntersectJoinHashTable | inlineprotected |
getApproximateTupleCountFromCache(QueryPlanHash key, CacheItemType item_type, DeviceIdentifier device_identifier) | BoundingBoxIntersectJoinHashTable | protected |
getBoundingBoxIntersectMetaInfo() | BoundingBoxIntersectJoinHashTable | inlineprotected |
getBoundingBoxIntersectTuningParamCache() | BoundingBoxIntersectJoinHashTable | inlinestatic |
getCacheKey(int device_id) const | BoundingBoxIntersectJoinHashTable | inlineprotected |
getComponentBufferSize() const noexceptoverride | BoundingBoxIntersectJoinHashTable | inlineprotectedvirtual |
getCompositeKeyInfo(const std::vector< InnerOuter > &inner_outer_pairs, const Executor *executor, const std::vector< InnerOuterStringOpInfos > &inner_outer_string_op_infos_pairs={}) | HashJoin | static |
getDeviceCount() const noexceptoverride | BoundingBoxIntersectJoinHashTable | inlineprotectedvirtual |
getEffectiveMemoryLevel(const std::vector< InnerOuter > &inner_outer_pairs) const | BoundingBoxIntersectJoinHashTable | protected |
getEmittedKeysCount() const | BoundingBoxIntersectJoinHashTable | inlineprotected |
getEntryCount() const | BoundingBoxIntersectJoinHashTable | inlineprotected |
getHashJoinColumn(const Analyzer::Expr *expr) | HashJoin | static |
getHashJoinType() const final | BoundingBoxIntersectJoinHashTable | inlineprotectedvirtual |
getHashTableCache() | BoundingBoxIntersectJoinHashTable | inlinestatic |
getHashTableForDevice(const size_t device_id) const | HashJoin | inline |
getHashType() const noexceptoverride | RangeJoinHashTable | inlineprotectedvirtual |
getHashTypeString(HashType ht) noexcept | HashJoin | inlinestatic |
getInnerOuterPairs() const | BoundingBoxIntersectJoinHashTable | inlineprotected |
getInnerTableId() const noexceptoverride | BoundingBoxIntersectJoinHashTable | protectedvirtual |
HashJoin::getInnerTableId(const std::vector< InnerOuter > &inner_outer_pairs) | HashJoin | inlinestatic |
getInnerTableRteIdx() const noexceptoverride | BoundingBoxIntersectJoinHashTable | inlineprotectedvirtual |
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) | RangeJoinHashTable | static |
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) | BoundingBoxIntersectJoinHashTable | static |
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) | HashJoin | static |
getJoinHashBuffer(const ExecutorDeviceType device_type, const int device_id) const | HashJoin | inline |
getJoinHashBufferSize(const ExecutorDeviceType device_type) | HashJoin | inline |
getJoinHashBufferSize(const ExecutorDeviceType device_type, const int device_id) const | HashJoin | inline |
getKeyBufferSize() const noexcept | BoundingBoxIntersectJoinHashTable | inlineprotected |
getKeyComponentCount() const | BoundingBoxIntersectJoinHashTable | protected |
getKeyComponentWidth() const | BoundingBoxIntersectJoinHashTable | protected |
getMaximumNumHashEntriesCanHold(MemoryLevel memory_level, const Executor *executor, size_t rowid_size) noexcept | HashJoin | static |
getMemoryLevel() const noexceptoverride | BoundingBoxIntersectJoinHashTable | inlineprotectedvirtual |
getRegisteredQueryHint() | BoundingBoxIntersectJoinHashTable | inlineprotected |
getStrDictProxies(const InnerOuter &cols, const Executor *executor, const bool has_string_ops) | HashJoin | static |
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) | HashJoin | static |
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) | HashJoin | static |
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) | HashJoin | static |
hash_table_cache_ | BoundingBoxIntersectJoinHashTable | protectedstatic |
hash_tables_for_device_ | HashJoin | protected |
hashtable_build_dag_map_ | BoundingBoxIntersectJoinHashTable | protected |
hashtable_cache_key_ | BoundingBoxIntersectJoinHashTable | protected |
hashtable_cache_meta_info_ | BoundingBoxIntersectJoinHashTable | protected |
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) | RangeJoinHashTable | protected |
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) | BoundingBoxIntersectJoinHashTable | protected |
initHashTableOnCpuFromCache(QueryPlanHash key, CacheItemType item_type, DeviceIdentifier device_identifier) | BoundingBoxIntersectJoinHashTable | protected |
inner_col_expr_ | RangeJoinHashTable | private |
inner_outer_pairs_ | BoundingBoxIntersectJoinHashTable | protected |
invalidateCache() | BoundingBoxIntersectJoinHashTable | inlinestatic |
inverse_bucket_sizes_for_dimension_ | BoundingBoxIntersectJoinHashTable | protected |
isBitwiseEq() const override | BoundingBoxIntersectJoinHashTable | protectedvirtual |
isInnerColCompressed() const | RangeJoinHashTable | inlineprivate |
isProbeCompressed() const | RangeJoinHashTable | inlineprivate |
join_type_ | BoundingBoxIntersectJoinHashTable | protected |
layout_override_ | BoundingBoxIntersectJoinHashTable | protected |
layoutRequiresAdditionalBuffers(HashType layout) noexcept | HashJoin | inlinestatic |
markCachedItemAsDirty(size_t table_key) | BoundingBoxIntersectJoinHashTable | inlinestatic |
max_hashtable_size_ | RangeJoinHashTable | private |
MAX_NUM_HASH_ENTRIES | HashJoin | static |
memory_level_ | BoundingBoxIntersectJoinHashTable | protected |
normalizeColumnPair(const Analyzer::Expr *lhs, const Analyzer::Expr *rhs, const TemporaryTables *temporary_tables, const bool is_bbox_intersect=false) | HashJoin | static |
normalizeColumnPairs(const Analyzer::BinOper *condition, const TemporaryTables *temporary_tables) | HashJoin | static |
offsetBufferOff() const noexceptoverride | BoundingBoxIntersectJoinHashTable | inlineprotectedvirtual |
payloadBufferOff() const noexceptoverride | BoundingBoxIntersectJoinHashTable | inlineprotectedvirtual |
putHashTableOnCpuToCache(QueryPlanHash key, CacheItemType item_type, std::shared_ptr< HashTable > hashtable_ptr, DeviceIdentifier device_identifier, size_t hashtable_building_time) | BoundingBoxIntersectJoinHashTable | protected |
query_hints_ | BoundingBoxIntersectJoinHashTable | protected |
query_infos_ | BoundingBoxIntersectJoinHashTable | protected |
query_plan_dag_ | BoundingBoxIntersectJoinHashTable | protected |
range_expr_ | RangeJoinHashTable | private |
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) | RangeJoinHashTable | inline |
reify(const HashType preferred_layout) | BoundingBoxIntersectJoinHashTable | protected |
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) | RangeJoinHashTable | protected |
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) | BoundingBoxIntersectJoinHashTable | protected |
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) | BoundingBoxIntersectJoinHashTable | protectedvirtual |
reifyWithLayout(const HashType layout) override | RangeJoinHashTable | protectedvirtual |
setBoundingBoxIntersectionMetaInfo(size_t max_table_size_bytes, double bucket_threshold, std::vector< double > &bucket_sizes) | BoundingBoxIntersectJoinHashTable | inlineprotected |
setInverseBucketSizeInfo(const std::vector< double > &inverse_bucket_sizes, std::vector< ColumnsForDevice > &columns_per_device, const size_t device_count) | BoundingBoxIntersectJoinHashTable | protected |
shardCount() const | BoundingBoxIntersectJoinHashTable | inlineprotected |
table_id_to_node_map_ | BoundingBoxIntersectJoinHashTable | protected |
table_keys_ | BoundingBoxIntersectJoinHashTable | protected |
toSet(const ExecutorDeviceType device_type, const int device_id) const override | BoundingBoxIntersectJoinHashTable | protectedvirtual |
toString(const ExecutorDeviceType device_type, const int device_id=0, bool raw=false) const override | BoundingBoxIntersectJoinHashTable | protectedvirtual |
toStringFlat32(const ExecutorDeviceType device_type, const int device_id) const | HashJoin | virtual |
toStringFlat64(const ExecutorDeviceType device_type, const int device_id) const | HashJoin | virtual |
translateCompositeStrDictProxies(const CompositeKeyInfo &composite_key_info, const std::vector< InnerOuterStringOpInfos > &string_op_infos_for_keys, const Executor *executor) | HashJoin | static |
translateInnerToOuterStrDictProxies(const InnerOuter &cols, const InnerOuterStringOpInfos &inner_outer_string_op_infos, ExpressionRange &old_col_range, const Executor *executor) | HashJoin | static |
~BoundingBoxIntersectJoinHashTable() | BoundingBoxIntersectJoinHashTable | inlinevirtual |
~RangeJoinHashTable() override=default | RangeJoinHashTable |