PostgreSQL Source Code
git master
|
#include "postgres.h"
#include "common/hashfn.h"
#include "nodes/bitmapset.h"
#include "nodes/pg_list.h"
#include "port/pg_bitutils.h"
Go to the source code of this file.
Macros | |
#define | WORDNUM(x) ((x) / BITS_PER_BITMAPWORD) |
#define | BITNUM(x) ((x) % BITS_PER_BITMAPWORD) |
#define | BITMAPSET_SIZE(nwords) (offsetof(Bitmapset, words) + (nwords) * sizeof(bitmapword)) |
#define | RIGHTMOST_ONE(x) ((signedbitmapword) (x) & -((signedbitmapword) (x))) |
#define | HAS_MULTIPLE_ONES(x) ((bitmapword) RIGHTMOST_ONE(x) != (x)) |
#define | bmw_leftmost_one_pos(w) pg_leftmost_one_pos32(w) |
#define | bmw_rightmost_one_pos(w) pg_rightmost_one_pos32(w) |
#define | bmw_popcount(w) pg_popcount32(w) |
#define BITMAPSET_SIZE | ( | nwords | ) | (offsetof(Bitmapset, words) + (nwords) * sizeof(bitmapword)) |
Definition at line 32 of file bitmapset.c.
Referenced by bms_add_member(), bms_add_range(), bms_copy(), and bms_make_singleton().
#define BITNUM | ( | x | ) | ((x) % BITS_PER_BITMAPWORD) |
Definition at line 30 of file bitmapset.c.
Referenced by bms_add_member(), bms_add_range(), bms_del_member(), bms_is_member(), bms_make_singleton(), bms_member_index(), bms_next_member(), bms_overlap_list(), and bms_prev_member().
#define bmw_leftmost_one_pos | ( | w | ) | pg_leftmost_one_pos32(w) |
Definition at line 58 of file bitmapset.c.
Referenced by bms_prev_member().
#define bmw_popcount | ( | w | ) | pg_popcount32(w) |
Definition at line 60 of file bitmapset.c.
Referenced by bms_member_index(), and bms_num_members().
#define bmw_rightmost_one_pos | ( | w | ) | pg_rightmost_one_pos32(w) |
Definition at line 59 of file bitmapset.c.
Referenced by bms_first_member(), bms_get_singleton_member(), bms_next_member(), and bms_singleton_member().
#define HAS_MULTIPLE_ONES | ( | x | ) | ((bitmapword) RIGHTMOST_ONE(x) != (x)) |
Definition at line 54 of file bitmapset.c.
Referenced by bms_get_singleton_member(), bms_membership(), and bms_singleton_member().
#define RIGHTMOST_ONE | ( | x | ) | ((signedbitmapword) (x) & -((signedbitmapword) (x))) |
Definition at line 52 of file bitmapset.c.
Referenced by bms_first_member().
#define WORDNUM | ( | x | ) | ((x) / BITS_PER_BITMAPWORD) |
Definition at line 29 of file bitmapset.c.
Referenced by bms_add_member(), bms_add_range(), bms_del_member(), bms_is_member(), bms_make_singleton(), bms_member_index(), bms_next_member(), bms_overlap_list(), and bms_prev_member().
Definition at line 1177 of file bitmapset.c.
References Assert, and bms_hash_value().
Referenced by build_join_rel_hash().
int bitmap_match | ( | const void * | key1, |
const void * | key2, | ||
Size | keysize | ||
) |
Definition at line 1187 of file bitmapset.c.
References Assert, and bms_equal().
Referenced by build_join_rel_hash().
Definition at line 736 of file bitmapset.c.
References BITMAPSET_SIZE, BITNUM, bms_make_singleton(), elog, ERROR, i, Bitmapset::nwords, repalloc(), WORDNUM, and Bitmapset::words.
Referenced by _readBitmapset(), add_child_rel_equivalences(), adjust_appendrel_attrs_multilevel(), adjust_child_relids(), adjust_child_relids_multilevel(), adjust_relid_set(), adjust_view_column_set(), alias_relid_set(), apply_handle_update(), build_subplan(), check_functional_grouping(), check_index_only(), checkInsertTargets(), classify_index_clause_usage(), clauselist_apply_dependencies(), convert_EXISTS_sublink_to_join(), create_lateral_join_info(), DecodeTextArrayToBitmapset(), deparseColumnRef(), dependencies_clauselist_selectivity(), DiscreteKnapsack(), do_analyze_rel(), DoCopy(), estimate_multivariate_ndistinct(), EvalPlanQualBegin(), ExecFindInitialMatchingSubPlans(), ExecInitAgg(), ExecNestLoop(), ExecRecursiveUnion(), ExecReScanGather(), ExecReScanGatherMerge(), ExecReScanRecursiveUnion(), ExecReScanSetParamPlan(), ExecScanSubPlan(), ExecSetParamPlan(), execute_attr_map_cols(), ExplainPreScanNode(), ExplainSubPlans(), extract_rollup_sets(), extractRemainingColumns(), fetch_remote_table_info(), fetch_statentries_for_relation(), fill_extraUpdatedCols(), finalize_plan(), finalize_primnode(), find_childrel_parents(), find_cols(), find_cols_walker(), find_hash_columns(), find_matching_subplans_recurse(), findDefaultOnlyColumns(), fixup_inherited_columns(), fixup_whole_row_references(), func_get_detail(), gen_partprune_steps_internal(), generate_base_implied_equalities(), get_eclass_for_sort_expr(), get_matching_partitions(), get_primary_key_attnos(), get_relation_constraint_attnos(), get_relation_statistics(), get_relids_in_jointree(), HeapDetermineModifiedColumns(), infer_arbiter_indexes(), inheritance_planner(), load_enum_cache_data(), logicalrep_read_attrs(), make_datum_param(), make_modifytable(), make_one_rel(), make_partition_pruneinfo(), make_partitionedrel_pruneinfo(), make_row_comparison_op(), make_window_input_target(), makeDependencyGraphWalker(), markRTEForSelectPriv(), offset_relid_set(), preprocess_grouping_sets(), pull_exec_paramids_walker(), pull_up_sublinks_jointree_recurse(), pull_varattnos_walker(), pull_varnos_walker(), RelationGetIndexAttrBitmap(), remove_useless_groupby_columns(), remove_useless_results_recurse(), rewriteTargetListIU(), rewriteTargetView(), RI_Initial_Check(), set_join_column_names(), set_param_references(), SS_identify_outer_params(), statext_is_compatible_clause_internal(), statext_mcv_clauselist_selectivity(), statext_ndistinct_build(), statext_ndistinct_deserialize(), transformGroupClause(), transformGroupClauseList(), transformInsertStmt(), transformRangeTableFunc(), transformUpdateTargetList(), translate_col_privs(), use_physical_tlist(), and view_cols_are_auto_updatable().
Definition at line 793 of file bitmapset.c.
References bms_copy(), i, Bitmapset::nwords, pfree(), and Bitmapset::words.
Referenced by add_child_join_rel_equivalences(), add_child_rel_equivalences(), add_eq_member(), add_part_relids(), add_paths_to_joinrel(), add_placeholders_to_joinrel(), add_vars_to_targetlist(), build_index_paths(), check_outerjoin_delay(), choose_best_statistics(), choose_bitmap_and(), create_bitmap_and_path(), create_bitmap_or_path(), create_lateral_join_info(), deconstruct_recurse(), DiscreteKnapsack(), ExecCreatePartitionPruneState(), ExecFindInitialMatchingSubPlans(), ExecFindMatchingSubPlans(), ExecInitAgg(), expand_partitioned_rtentry(), ExplainPreScanNode(), finalize_plan(), find_nonnullable_rels_walker(), foreign_join_ok(), get_eclass_indexes_for_relids(), heap_update(), join_is_legal(), make_outerjoininfo(), perform_pruning_combine_step(), pull_varnos_walker(), reduce_outer_joins_pass1(), reduce_outer_joins_pass2(), transformOnConflictArbiter(), try_partitionwise_join(), and update_placeholder_eval_levels().
Definition at line 834 of file bitmapset.c.
References BITMAPSET_SIZE, BITNUM, BITS_PER_BITMAPWORD, elog, ERROR, i, Bitmapset::nwords, palloc0(), repalloc(), WORDNUM, and Bitmapset::words.
Referenced by ExecInitAppend(), ExecInitMergeAppend(), get_matching_hash_bounds(), get_matching_list_bounds(), get_matching_partitions(), get_matching_range_bounds(), logicalrep_rel_open(), make_partition_pruneinfo(), perform_pruning_combine_step(), and prune_append_rel_partitions().
Definition at line 147 of file bitmapset.c.
References bms_is_empty(), i, Min, Bitmapset::nwords, and Bitmapset::words.
Referenced by append_startup_cost_compare(), and append_total_cost_compare().
Definition at line 74 of file bitmapset.c.
References BITMAPSET_SIZE, Bitmapset::nwords, and palloc().
Referenced by adjust_child_relids(), adjust_relid_set(), bms_add_members(), bms_difference(), bms_intersect(), bms_union(), build_child_join_rel(), build_index_paths(), build_join_rel(), build_simple_rel(), calc_nestloop_required_outer(), check_equivalence_delay(), check_outerjoin_delay(), choose_bitmap_and(), create_lateral_join_info(), DiscreteKnapsack(), distribute_qual_to_rels(), ExecCreatePartitionPruneState(), ExecFindInitialMatchingSubPlans(), ExecFindMatchingSubPlans(), expand_single_inheritance_child(), fetch_upper_rel(), finalize_plan(), finalize_primnode(), find_hash_columns(), find_placeholder_info(), fixup_whole_row_references(), generate_base_implied_equalities_const(), generate_base_implied_equalities_no_const(), get_relation_statistics(), innerrel_is_unique(), join_is_legal(), load_enum_cache_data(), logicalrep_partition_open(), logicalrep_relmap_update(), make_outerjoininfo(), perform_pruning_combine_step(), process_implied_equality(), reconsider_full_join_clause(), reconsider_outer_join_clause(), RelationGetIndexAttrBitmap(), remove_rel_from_query(), and reparameterize_path_by_child().
Definition at line 773 of file bitmapset.c.
References BITNUM, elog, ERROR, WORDNUM, and Bitmapset::words.
Referenced by adjust_child_relids(), adjust_relid_set(), build_index_paths(), BuildParameterizedTidPaths(), dependencies_clauselist_selectivity(), DiscreteKnapsack(), finalize_plan(), finalize_primnode(), find_hash_columns(), findDefaultOnlyColumns(), fixup_whole_row_references(), get_matching_list_bounds(), logicalrep_rel_open(), postgresGetForeignPaths(), preprocess_rowmarks(), remove_rel_from_query(), substitute_phv_relids_walker(), and TopologicalSort().
Definition at line 928 of file bitmapset.c.
References i, Min, Bitmapset::nwords, and Bitmapset::words.
Referenced by build_join_rel(), calc_nestloop_required_outer(), check_index_only(), DiscreteKnapsack(), finalize_plan(), make_partition_pruneinfo(), and min_join_parameterization().
Definition at line 291 of file bitmapset.c.
References bms_copy(), i, Min, Bitmapset::nwords, and Bitmapset::words.
Referenced by add_child_join_rel_equivalences(), add_child_rel_equivalences(), add_paths_to_joinrel(), check_index_predicates(), consider_new_or_clause(), finalize_plan(), find_placeholder_info(), and remove_useless_groupby_columns().
Definition at line 94 of file bitmapset.c.
References bms_is_empty(), i, Bitmapset::nwords, and Bitmapset::words.
Referenced by add_path_precheck(), add_paths_to_append_rel(), adjust_appendrel_attrs_multilevel(), adjust_child_relids_multilevel(), bitmap_match(), bms_equal_any(), choose_bitmap_and(), create_append_path(), create_merge_append_path(), create_unique_path(), extract_rollup_sets(), fetch_upper_rel(), find_dependent_phvs_walker(), find_join_rel(), find_param_path_info(), generate_implied_equalities_for_column(), get_cheapest_parameterized_child_path(), get_eclass_for_sort_expr(), has_join_restriction(), infer_arbiter_indexes(), is_safe_restriction_clause_for(), join_is_legal(), make_one_rel(), make_partitionedrel_pruneinfo(), match_pathkeys_to_index(), populate_joinrel_with_paths(), and try_partitionwise_join().
int bms_first_member | ( | Bitmapset * | a | ) |
Definition at line 996 of file bitmapset.c.
References BITS_PER_BITMAPWORD, bmw_rightmost_one_pos, Bitmapset::nwords, RIGHTMOST_ONE, and Bitmapset::words.
Referenced by check_relation_privileges(), check_selective_binary_conversion(), convert_EXISTS_sublink_to_join(), find_hash_columns(), HeapDetermineModifiedColumns(), logicalrep_report_missing_attrs(), and make_row_comparison_op().
void bms_free | ( | Bitmapset * | a | ) |
Definition at line 208 of file bitmapset.c.
References pfree().
Referenced by adjust_child_relids_multilevel(), calc_nestloop_required_outer(), check_index_only(), check_outerjoin_delay(), choose_best_statistics(), clauselist_apply_dependencies(), convert_EXISTS_sublink_to_join(), create_foreignscan_plan(), create_nestloop_plan(), deparseColumnRef(), dependencies_clauselist_selectivity(), examine_variable(), ExecEndNode(), ExecFindInitialMatchingSubPlans(), ExecReScan(), ExecReScanAppend(), ExecReScanMergeAppend(), extract_rollup_sets(), ExtractReplicaIdentity(), finalize_plan(), find_hash_columns(), func_get_detail(), get_relation_statistics(), has_legal_joinclause(), heap_update(), index_unchanged_by_update(), load_enum_cache_data(), logicalrep_rel_open(), logicalrep_relmap_free_entry(), logicalrep_write_attrs(), make_join_rel(), NumRelids(), reduce_outer_joins_pass2(), RelationDestroyRelation(), RelationGetIndexAttrBitmap(), reparameterize_path_by_child(), statext_mcv_clauselist_selectivity(), try_hashjoin_path(), try_mergejoin_path(), try_nestloop_path(), and UpdateChangedParamSet().
Definition at line 615 of file bitmapset.c.
References BITS_PER_BITMAPWORD, bmw_rightmost_one_pos, HAS_MULTIPLE_ONES, Bitmapset::nwords, and Bitmapset::words.
Referenced by add_placeholders_to_base_rels(), create_lateral_join_info(), find_single_rel_for_clauses(), generate_base_implied_equalities_no_const(), get_common_eclass_indexes(), join_is_removable(), reduce_unique_semijoins(), and set_base_rel_consider_startup().
Definition at line 1154 of file bitmapset.c.
References DatumGetUInt32, hash_any(), Bitmapset::nwords, and Bitmapset::words.
Referenced by bitmap_hash().
Definition at line 902 of file bitmapset.c.
References i, Min, Bitmapset::nwords, pfree(), and Bitmapset::words.
Referenced by check_outerjoin_delay(), find_nonnullable_rels_walker(), find_placeholder_info(), get_common_eclass_indexes(), make_outerjoininfo(), make_row_comparison_op(), perform_pruning_combine_step(), and relation_is_updatable().
Definition at line 259 of file bitmapset.c.
References bms_copy(), i, Bitmapset::nwords, and Bitmapset::words.
Referenced by dependencies_clauselist_selectivity(), estimate_multivariate_ndistinct(), get_eclass_for_sort_expr(), get_matching_part_pairs(), make_outerjoininfo(), match_eclasses_to_foreign_key_col(), process_equivalence(), reconsider_full_join_clause(), reconsider_outer_join_clause(), set_param_references(), and UpdateChangedParamSet().
Definition at line 701 of file bitmapset.c.
References Bitmapset::nwords, and Bitmapset::words.
Referenced by add_eq_member(), add_vars_to_targetlist(), bms_compare(), bms_equal(), bms_is_subset(), bms_nonempty_difference(), bms_subset_compare(), build_index_paths(), build_join_rel(), calc_nestloop_required_outer(), check_index_predicates(), compute_semijoin_info(), consider_groupingsets_paths(), convert_ANY_sublink_to_join(), convert_EXISTS_sublink_to_join(), create_foreign_join_path(), create_foreign_upper_path(), create_lateral_join_info(), distribute_qual_to_rels(), eclass_useful_for_merging(), ExecCheckRTEPerms(), ExecCheckRTEPermsModified(), ExecFindInitialMatchingSubPlans(), ExecInitParallelPlan(), ExecParallelReinitialize(), ExecReScanSetParamPlan(), ExtractReplicaIdentity(), filter_event_trigger(), finalize_plan(), find_em_expr_for_rel(), find_nonnullable_rels_walker(), find_placeholder_info(), find_single_rel_for_clauses(), findDefaultOnlyColumns(), gen_partprune_steps_internal(), generate_join_implied_equalities(), generate_join_implied_equalities_for_ecs(), get_appendrel_parampathinfo(), get_baserel_parampathinfo(), get_cheapest_parallel_safe_total_inner(), get_joinrel_parampathinfo(), get_matching_list_bounds(), get_matching_range_bounds(), get_steps_using_prefix_recurse(), get_useful_ecs_for_relation(), GetParentedForeignKeyRefs(), hash_inner_and_outer(), is_pseudo_constant_clause_relids(), logicalrep_report_missing_attrs(), make_outerjoininfo(), make_partitionedrel_pruneinfo(), make_restrictinfo_internal(), match_clause_to_partition_key(), match_unsorted_outer(), min_join_parameterization(), postgresGetForeignJoinPaths(), postgresGetForeignPaths(), preprocess_grouping_sets(), process_equivalence(), process_implied_equality(), recurse_set_operations(), relation_has_unique_index_for(), relation_is_updatable(), remove_rel_from_query(), remove_result_refs(), rewriteTargetView(), sepgsql_dml_privileges(), set_subquery_pathlist(), sort_inner_and_outer(), substitute_phv_relids_walker(), TopologicalSort(), try_partial_hashjoin_path(), try_partial_mergejoin_path(), try_partial_nestloop_path(), UpdateChangedParamSet(), and use_physical_tlist().
Definition at line 427 of file bitmapset.c.
References BITNUM, elog, ERROR, Bitmapset::nwords, WORDNUM, and Bitmapset::words.
Referenced by adjust_child_relids(), adjust_relid_set(), adjust_rowcount_for_semijoins(), bms_is_subset_singleton(), bms_member_index(), check_redundant_nullability_qual(), check_relation_privileges(), checkInsertTargets(), clauselist_selectivity_ext(), clauselist_selectivity_or(), ComputePartitionAttrs(), consider_groupingsets_paths(), cost_incremental_sort(), create_foreignscan_plan(), create_lateral_join_info(), DefineIndex(), deparseFromExprForRel(), deparseLockingClause(), deparseRangeTblRef(), deparseTargetList(), deparseVar(), dependencies_clauselist_selectivity(), dependency_is_fully_matched(), do_analyze_rel(), enum_known_sorted(), estimate_multivariate_ndistinct(), examine_variable(), exec_check_rw_parameter(), ExecBuildSlotValueDescription(), ExecComputeStoredGenerated(), ExecEvalGroupingFunc(), ExecInitModifyTable(), execute_attr_map_cols(), expand_indexqual_rowcompare(), ExplainSubPlans(), extractRemainingColumns(), ExtractReplicaIdentity(), filter_event_trigger(), find_hash_columns(), fixup_whole_row_references(), foreign_expr_walker(), func_get_detail(), gen_partprune_steps_internal(), gen_prune_steps_from_opexps(), get_foreign_key_join_selectivity(), get_matching_hash_bounds(), get_tablefunc(), get_variable(), has_partition_attrs(), hashagg_spill_tuple(), identify_current_nestloop_params(), index_expression_changed_walker(), index_unchanged_by_update(), inheritance_planner(), InitPlan(), is_foreign_param(), is_pseudo_constant_for_index(), is_subquery_var(), IsBinaryTidClause(), IsTidEqualAnyClause(), join_clause_is_movable_to(), join_is_removable(), lo_manage(), logicalrep_rel_open(), logicalrep_write_attrs(), make_outerjoininfo(), make_window_input_target(), mark_invalid_subplans_as_finished(), match_opclause_to_indexcol(), match_rowcompare_to_indexcol(), match_saopclause_to_indexcol(), perform_pruning_base_step(), plpgsql_param_fetch(), postgresExplainForeignScan(), prepare_projection_slot(), preprocess_rowmarks(), process_subquery_nestloop_params(), pullup_replace_vars_callback(), remove_rel_from_query(), remove_unused_subquery_outputs(), remove_useless_groupby_columns(), replace_nestloop_params_mutator(), rewriteTargetListIU(), rewriteValuesRTE(), set_join_column_names(), set_rtable_names(), statext_is_compatible_clause(), statext_mcv_clauselist_selectivity(), substitute_phv_relids_walker(), tfuncLoadRows(), transformGroupClauseExpr(), translate_col_privs(), TriggerEnabled(), tsvector_update_trigger(), use_physical_tlist(), and view_cols_are_auto_updatable().
Definition at line 315 of file bitmapset.c.
References bms_is_empty(), i, Min, Bitmapset::nwords, and Bitmapset::words.
Referenced by add_child_rel_equivalences(), add_paths_to_joinrel(), add_placeholders_to_joinrel(), add_vars_to_targetlist(), check_functional_grouping(), check_index_only(), check_outerjoin_delay(), choose_best_statistics(), clause_sides_match_join(), compute_semijoin_info(), convert_ANY_sublink_to_join(), convert_EXISTS_sublink_to_join(), create_index_paths(), deconstruct_recurse(), distribute_qual_to_rels(), eclass_already_used(), eclass_useful_for_merging(), extract_rollup_sets(), final_cost_hashjoin(), finalize_plan(), find_ec_member_for_tle(), find_em_expr_for_rel(), find_em_expr_usable_for_sorting_rel(), foreign_join_ok(), generate_implied_equalities_for_column(), generate_join_implied_equalities_broken(), generate_join_implied_equalities_normal(), get_appendrel_parampathinfo(), get_baserel_parampathinfo(), get_cheapest_fractional_path_for_pathkeys(), get_cheapest_parameterized_child_path(), get_cheapest_path_for_pathkeys(), get_join_index_paths(), get_join_variables(), get_joinrel_parampathinfo(), get_switched_clauses(), has_join_restriction(), has_relevant_eclass_joinclause(), have_dangerous_phv(), have_join_order_restriction(), have_partkey_equi_join(), identify_current_nestloop_params(), initial_cost_mergejoin(), innerrel_is_unique(), is_simple_subquery(), join_clause_is_movable_into(), join_is_legal(), join_is_removable(), jointree_contains_lateral_outer_refs(), make_outerjoininfo(), populate_joinrel_with_paths(), prepare_sort_from_pathkeys(), process_implied_equality(), process_subquery_nestloop_params(), remove_rel_from_query(), reparameterize_path(), replace_nestloop_params_mutator(), statext_mcv_clauselist_selectivity(), subbuild_joinrel_joinlist(), subbuild_joinrel_restrictlist(), try_partial_nestloop_path(), update_placeholder_eval_levels(), and use_physical_tlist().
Definition at line 949 of file bitmapset.c.
References i, Bitmapset::nwords, pfree(), and Bitmapset::words.
Referenced by add_paths_to_joinrel(), alias_relid_set(), finalize_primnode(), find_nonnullable_rels_walker(), get_partkey_exec_paramids(), get_relids_in_jointree(), make_partition_pruneinfo(), process_equivalence(), pull_up_sublinks_jointree_recurse(), and UpdateChangedParamSet().
Bitmapset* bms_make_singleton | ( | int | x | ) |
Definition at line 186 of file bitmapset.c.
References BITMAPSET_SIZE, BITNUM, elog, ERROR, Bitmapset::nwords, palloc0(), WORDNUM, and Bitmapset::words.
Referenced by ATExecDropColumn(), ATPrepAlterColumnType(), bms_add_member(), build_base_rel_tlists(), build_simple_rel(), deconstruct_recurse(), deparseReturningList(), DiscreteKnapsack(), expand_inherited_rtentry(), extract_lateral_references(), find_dependent_phvs(), find_dependent_phvs_in_jointree(), find_nonnullable_rels_walker(), get_matching_hash_bounds(), get_matching_list_bounds(), get_matching_range_bounds(), get_relids_in_jointree(), inheritance_planner(), load_enum_cache_data(), pg_column_is_updatable(), pull_up_sublinks_jointree_recurse(), pullup_replace_vars_callback(), and reduce_outer_joins_pass1().
int bms_member_index | ( | Bitmapset * | a, |
int | x | ||
) |
Definition at line 453 of file bitmapset.c.
References BITNUM, bms_is_member(), bmw_popcount, i, WORDNUM, and Bitmapset::words.
Referenced by clauselist_apply_dependencies(), and mcv_get_match_bitmap().
BMS_Membership bms_membership | ( | const Bitmapset * | a | ) |
Definition at line 672 of file bitmapset.c.
References BMS_EMPTY_SET, BMS_MULTIPLE, BMS_SINGLETON, HAS_MULTIPLE_ONES, Bitmapset::nwords, and Bitmapset::words.
Referenced by add_child_join_rel_equivalences(), bms_is_subset_singleton(), clauselist_selectivity_ext(), deparseFromExpr(), deparseLockingClause(), deparseVar(), dependencies_clauselist_selectivity(), dependency_is_compatible_clause(), distribute_qual_to_rels(), distribute_restrictinfo_to_rels(), examine_variable(), find_join_input_rel(), find_nonnullable_rels_walker(), generate_base_implied_equalities(), generate_base_implied_equalities_broken(), generate_base_implied_equalities_const(), get_foreign_key_join_selectivity(), process_implied_equality(), remove_useless_groupby_columns(), set_rel_pathlist(), set_tablesample_rel_pathlist(), statext_is_compatible_clause(), statext_mcv_clauselist_selectivity(), and treat_as_join_clause().
int bms_next_member | ( | const Bitmapset * | a, |
int | prevbit | ||
) |
Definition at line 1043 of file bitmapset.c.
References BITNUM, BITS_PER_BITMAPWORD, bmw_rightmost_one_pos, Bitmapset::nwords, WORDNUM, and Bitmapset::words.
Referenced by add_child_join_rel_equivalences(), add_child_rel_equivalences(), add_join_clause_to_rels(), add_part_relids(), adjust_view_column_set(), alias_relid_set(), approximate_joinrel_size(), build_attnums_array(), choose_next_subplan_for_worker(), choose_next_subplan_locally(), clauselist_apply_dependencies(), ComputePartitionAttrs(), create_lateral_join_info(), deparseLockingClause(), EstimateParamExecSpace(), ExecCheckRTEPerms(), ExecCheckRTEPermsModified(), ExecFindInitialMatchingSubPlans(), ExecInitAgg(), ExecInitAppend(), ExecInitMergeAppend(), ExecMergeAppend(), ExecScanReScan(), ExecSetParamPlanMulti(), expand_partitioned_rtentry(), find_appinfos_by_relids(), find_dependent_phvs_in_jointree(), find_matching_subplans_recurse(), fixup_inherited_columns(), format_expr_params(), generate_base_implied_equalities(), generate_implied_equalities_for_column(), generate_join_implied_equalities(), generate_partitionwise_join_paths(), get_eclass_for_sort_expr(), get_eclass_indexes_for_relids(), get_loop_count(), get_matching_partitions(), has_relevant_eclass_joinclause(), have_relevant_eclass_joinclause(), inheritance_planner(), logicalrep_rel_open(), lookup_var_attr_stats(), make_partitionedrel_pruneinfo(), match_eclasses_to_foreign_key_col(), offset_relid_set(), outBitmapset(), pg_ndistinct_out(), postgresBeginForeignScan(), postgresExplainForeignScan(), postgresPlanDirectModify(), postgresPlanForeignModify(), remove_join_clause_from_rels(), remove_useless_results_recurse(), SerializeParamExecParams(), show_eval_params(), statext_is_compatible_clause(), and statext_ndistinct_serialize().
Definition at line 545 of file bitmapset.c.
References bms_is_empty(), i, Min, Bitmapset::nwords, and Bitmapset::words.
Referenced by add_placeholders_to_base_rels(), add_placeholders_to_joinrel(), allow_star_schema_join(), build_joinrel_tlist(), foreign_join_ok(), and use_physical_tlist().
int bms_num_members | ( | const Bitmapset * | a | ) |
Definition at line 646 of file bitmapset.c.
References bmw_popcount, Bitmapset::nwords, and Bitmapset::words.
Referenced by adjust_appendrel_attrs_multilevel(), build_attnums_array(), build_join_rel(), BuildRelationExtStatistics(), choose_best_statistics(), clauselist_apply_dependencies(), ComputeExtStatisticsRows(), estimate_multivariate_ndistinct(), ExecFindInitialMatchingSubPlans(), ExecInitAppend(), ExecInitMergeAppend(), expand_partitioned_rtentry(), find_appinfos_by_relids(), find_hash_columns(), find_strongest_dependency(), gen_partprune_steps_internal(), get_matching_hash_bounds(), get_matching_part_pairs(), get_steps_using_prefix_recurse(), lookup_var_attr_stats(), make_partition_pruneinfo(), mark_invalid_subplans_as_finished(), NumRelids(), SerializeParamExecParams(), statext_ndistinct_build(), and statext_ndistinct_serialize().
Definition at line 494 of file bitmapset.c.
References i, Min, Bitmapset::nwords, and Bitmapset::words.
Referenced by add_child_join_rel_equivalences(), add_child_rel_equivalences(), add_paths_to_joinrel(), adjust_child_relids_multilevel(), allow_star_schema_join(), calc_nestloop_required_outer(), calc_non_nestloop_required_outer(), check_outerjoin_delay(), choose_bitmap_and(), compute_semijoin_info(), create_nestloop_path(), distribute_qual_to_rels(), eclass_useful_for_merging(), ExecReScanAgg(), ExecReScanAppend(), ExecReScanFunctionScan(), ExecReScanMergeAppend(), ExecUpdateLockMode(), fill_extraUpdatedCols(), generate_implied_equalities_for_column(), generate_join_implied_equalities(), generate_join_implied_equalities_for_ecs(), get_appendrel_parampathinfo(), get_baserel_parampathinfo(), get_joinrel_parampathinfo(), get_useful_ecs_for_relation(), has_join_restriction(), has_legal_joinclause(), has_partition_attrs(), have_dangerous_phv(), have_join_order_restriction(), have_relevant_eclass_joinclause(), have_relevant_joinclause(), heap_update(), identify_current_nestloop_params(), join_clause_is_movable_into(), join_clause_is_movable_to(), join_is_legal(), join_is_removable(), join_search_one_level(), make_join_rel(), make_outerjoininfo(), make_rels_by_clause_joins(), make_rels_by_clauseless_joins(), make_restrictinfo_internal(), pullup_replace_vars_callback(), reduce_outer_joins_pass2(), reparameterize_path_by_child(), replace_nestloop_params_mutator(), select_outer_pathkeys_for_merge(), try_hashjoin_path(), try_mergejoin_path(), try_nestloop_path(), try_partitionwise_join(), and update_placeholder_eval_levels().
Definition at line 516 of file bitmapset.c.
References BITNUM, elog, ERROR, lfirst_int, NIL, WORDNUM, and Bitmapset::words.
Referenced by preprocess_grouping_sets().
int bms_prev_member | ( | const Bitmapset * | a, |
int | prevbit | ||
) |
Definition at line 1102 of file bitmapset.c.
References BITNUM, BITS_PER_BITMAPWORD, bmw_leftmost_one_pos, Bitmapset::nwords, WORDNUM, and Bitmapset::words.
Referenced by choose_next_subplan_locally().
int bms_singleton_member | ( | const Bitmapset * | a | ) |
Definition at line 577 of file bitmapset.c.
References BITS_PER_BITMAPWORD, bmw_rightmost_one_pos, elog, ERROR, HAS_MULTIPLE_ONES, Bitmapset::nwords, and Bitmapset::words.
Referenced by distribute_restrictinfo_to_rels(), examine_variable(), find_join_input_rel(), fix_append_rel_relids(), get_matching_part_pairs(), and remove_useless_joins().
BMS_Comparison bms_subset_compare | ( | const Bitmapset * | a, |
const Bitmapset * | b | ||
) |
Definition at line 352 of file bitmapset.c.
References BMS_DIFFERENT, BMS_EQUAL, bms_is_empty(), BMS_SUBSET1, BMS_SUBSET2, i, Min, Bitmapset::nwords, and Bitmapset::words.
Referenced by add_path(), consider_index_join_outer_rels(), estimate_multivariate_ndistinct(), remove_useless_groupby_columns(), and set_cheapest().
Definition at line 225 of file bitmapset.c.
References bms_copy(), i, Bitmapset::nwords, and Bitmapset::words.
Referenced by build_child_join_rel(), build_join_rel(), BuildParameterizedTidPaths(), calc_nestloop_required_outer(), calc_non_nestloop_required_outer(), check_index_predicates(), check_relation_privileges(), compute_semijoin_info(), consider_index_join_outer_rels(), create_join_clause(), create_nestloop_path(), create_nestloop_plan(), deconstruct_recurse(), ExecConstraints(), ExecGetAllUpdatedCols(), ExecPartitionCheckEmitError(), ExecWithCheckOptions(), finalize_plan(), find_hash_columns(), foreign_join_ok(), generate_base_implied_equalities_const(), generate_base_implied_equalities_no_const(), generate_join_implied_equalities(), generate_join_implied_equalities_for_ecs(), generate_nonunion_paths(), generate_recursion_path(), generate_union_paths(), get_baserel_parampathinfo(), get_joinrel_parampathinfo(), has_legal_joinclause(), index_unchanged_by_update(), join_is_removable(), make_join_rel(), make_outerjoininfo(), make_restrictinfo_internal(), min_join_parameterization(), postgresGetForeignPaths(), postgresPlanForeignModify(), pull_up_sublinks_jointree_recurse(), reduce_unique_semijoins(), remove_useless_joins(), resolve_special_varno(), substitute_phv_relids_walker(), and try_partitionwise_join().