LLVM OpenMP 20.0.0git
|
#include "kmp.h"
#include "kmp_affinity.h"
#include "kmp_atomic.h"
#include "kmp_environment.h"
#include "kmp_error.h"
#include "kmp_i18n.h"
#include "kmp_io.h"
#include "kmp_itt.h"
#include "kmp_settings.h"
#include "kmp_stats.h"
#include "kmp_str.h"
#include "kmp_wait_release.h"
#include "kmp_wrapper_getpid.h"
#include "kmp_dispatch.h"
#include "kmp_utils.h"
Go to the source code of this file.
Classes | |
struct | kmp_affinity_format_field_t |
Macros | |
#define | KMP_USE_PRCTL 0 |
#define | KMP_MIN(x, y) ((x) < (y) ? (x) : (y)) |
#define | MAX_MESSAGE 512 |
#define | propagateFPControl(x) ((void)0) |
#define | updateHWFPControl(x) ((void)0) |
#define | FAST_REDUCTION_ATOMIC_METHOD_GENERATED |
#define | FAST_REDUCTION_TREE_METHOD_GENERATED ((reduce_data) && (reduce_func)) |
Typedefs | |
typedef struct kmp_affinity_format_field_t | kmp_affinity_format_field_t |
Variables | |
char const | __kmp_version_omp_api [] |
kmp_info_t * | __kmp_thread_pool_insert_pt = NULL |
static const unsigned | __kmp_primes [] |
static long | __kmp_registration_flag = 0 |
static char * | __kmp_registration_str = NULL |
static const kmp_affinity_format_field_t | __kmp_affinity_format_table [] |
kmp_info_t ** | __kmp_hidden_helper_threads |
kmp_info_t * | __kmp_hidden_helper_main_thread |
std::atomic< kmp_int32 > | __kmp_unexecuted_hidden_helper_tasks |
kmp_int32 | __kmp_hidden_helper_threads_num = 0 |
kmp_int32 | __kmp_enable_hidden_helper = FALSE |
int | __kmp_omp_debug_struct_info = FALSE |
int | __kmp_debugging = FALSE |
#define FAST_REDUCTION_ATOMIC_METHOD_GENERATED |
#define FAST_REDUCTION_TREE_METHOD_GENERATED ((reduce_data) && (reduce_func)) |
#define KMP_MIN | ( | x, | |
y | |||
) | ((x) < (y) ? (x) : (y)) |
Definition at line 74 of file kmp_runtime.cpp.
#define KMP_USE_PRCTL 0 |
Definition at line 45 of file kmp_runtime.cpp.
#define MAX_MESSAGE 512 |
Definition at line 372 of file kmp_runtime.cpp.
#define propagateFPControl | ( | x | ) | ((void)0) |
Definition at line 1172 of file kmp_runtime.cpp.
#define updateHWFPControl | ( | x | ) | ((void)0) |
Definition at line 1173 of file kmp_runtime.cpp.
typedef struct kmp_affinity_format_field_t kmp_affinity_format_field_t |
Definition at line 458 of file kmp_runtime.cpp.
References __kmp_acquire_bootstrap_lock(), __kmp_debug_buf, __kmp_dump_debug_buffer(), __kmp_exit_lock, __kmp_global, __kmp_infinite_loop(), __kmp_release_bootstrap_lock(), and __kmp_unregister_library().
Referenced by __kmp_fatal().
Definition at line 492 of file kmp_runtime.cpp.
References __kmp_infinite_loop().
Referenced by __kmp_dist_barrier_gather(), __kmp_tasking_barrier(), and __kmp_wait_template().
void __kmp_add_threads_to_team | ( | kmp_team_t * | team, |
int | new_nthreads | ||
) |
Definition at line 9214 of file kmp_runtime.cpp.
References __kmp_dflt_blocktime, __kmp_resume_32(), count, f(), KMP_COMPARE_AND_STORE_ACQ32, KMP_DEBUG_ASSERT, KMP_MAX_BLOCKTIME, kmp_team::t, and void.
Referenced by __kmp_allocate_team(), __kmp_fork_in_teams(), __kmp_fork_team_threads(), and __kmp_set_num_threads().
|
static |
Definition at line 3195 of file kmp_runtime.cpp.
References __kmp_free, __kmp_page_allocate, __kmp_print_storage_map_gtid(), __kmp_storage_map, KA_TRACE, KMP_DEBUG_ASSERT, KMP_INLINE_ARGV_ENTRIES, KMP_MIN_MALLOC_ARGV_ENTRIES, and kmp_team::t.
Referenced by __kmp_allocate_team(), __kmp_fork_in_teams(), and __kmp_serial_fork_call().
kmp_team_t * __kmp_allocate_team | ( | kmp_root_t * | root, |
int | new_nproc, | ||
int | max_nproc, | ||
kmp_proc_bind_t | new_proc_bind, | ||
kmp_internal_control_t * | new_icvs, | ||
int argc | USE_NESTED_HOT_ARGkmp_info_t *master | ||
) |
Definition at line 5134 of file kmp_runtime.cpp.
References __kmp_add_threads_to_team(), __kmp_alloc_argv_entries(), __kmp_allocate, __kmp_allocate_team_arrays(), __kmp_allocate_thread(), __kmp_barrier_gather_pattern, __kmp_barrier_release_pattern, __kmp_dflt_team_nth_ub, __kmp_free_thread(), __kmp_gtid_from_tid(), __kmp_initialize_info(), __kmp_initialize_team(), __kmp_print_team_storage_map(), __kmp_push_current_task_to_thread(), __kmp_reallocate_team_arrays(), __kmp_reap_team(), __kmp_reinitialize_team(), __kmp_resize_dist_barrier(), __kmp_storage_map, __kmp_tasking_mode, __kmp_team_pool, __kmp_teams_master(), __ompt_team_assign_id(), distributedBarrier::allocate(), b, kmp_barrier_union::bb, bp_dist_bar, bs_forkjoin_barrier, bs_last_barrier, bs_plain_barrier, CCAST, f(), FALSE, KA_TRACE, KF_TRACE, KMP_BARRIER_PARENT_FLAG, KMP_BARRIER_SWITCH_TO_OWN_FLAG, KMP_CHECK_UPDATE, KMP_DEBUG_ASSERT, KMP_INIT_BARRIER_STATE, KMP_MB, KMP_TIME_DEVELOPER_PARTITIONED_BLOCK, level, proc_bind_default, proc_bind_spread, kmp_r_sched::sched, kmp_internal_control::sched, kmp_team::t, TRUE, and tskm_immediate_exec.
Referenced by __kmp_allocate_thread(), __kmp_fork_call(), __kmp_initialize_root(), __kmp_register_root(), and __kmp_serialized_parallel().
|
static |
Definition at line 3241 of file kmp_runtime.cpp.
References __kmp_allocate, __kmp_dispatch_num_buffers, i, and kmp_team::t.
Referenced by __kmp_allocate_team(), and __kmp_reallocate_team_arrays().
kmp_info_t * __kmp_allocate_thread | ( | kmp_root_t * | root, |
kmp_team_t * | team, | ||
int | new_tid | ||
) |
Definition at line 4423 of file kmp_runtime.cpp.
References __kmp_acquire_bootstrap_lock(), __kmp_adjust_gtid_mode, __kmp_all_nth, __kmp_allocate, __kmp_allocate_team(), __kmp_avail_proc, __kmp_barrier_gather_pattern, __kmp_create_worker(), __kmp_def_allocator, __kmp_env_blocktime, __kmp_get_gtid, __kmp_get_x_global_icvs(), __kmp_gtid_mode, __kmp_hidden_helper_threads_num, __kmp_init_hidden_helper_threads, __kmp_init_random(), __kmp_initialize_bget(), __kmp_initialize_info(), __kmp_lock_suspend_mx(), __kmp_monitor, __kmp_nth, __kmp_print_thread_storage_map(), __kmp_release_bootstrap_lock(), __kmp_stksize, __kmp_storage_map, __kmp_suspend_initialize_thread(), __kmp_thread_pool, __kmp_thread_pool_active_nth, __kmp_thread_pool_insert_pt, __kmp_threads, __kmp_threads_capacity, __kmp_tls_gtid_min, __kmp_unlock_suspend_mx(), b, kmp_barrier_union::bb, bp_dist_bar, bs_forkjoin_barrier, bs_last_barrier, CCAST, FALSE, flag_unset, if(), KA_TRACE, KF_TRACE, KMP_ASSERT, KMP_ATOMIC_DEC, KMP_BARRIER_NOT_WAITING, KMP_BARRIER_PARENT_FLAG, KMP_DEBUG_ASSERT, KMP_HIDDEN_HELPER_TEAM, KMP_INIT_BARRIER_STATE, KMP_MASTER_GTID, KMP_MB, KMP_YIELD, proc_bind_default, severity_fatal, kmp_team::t, TCR_4, TCR_PTR, TCW_4, TCW_PTR, TCW_SYNC_PTR, TRUE, and USE_NESTED_HOT_ARG.
Referenced by __kmp_allocate_team(), and __kmp_fork_team_threads().
size_t __kmp_aux_capture_affinity | ( | int | gtid, |
const char * | format, | ||
kmp_str_buf_t * | buffer | ||
) |
Definition at line 8801 of file kmp_runtime.cpp.
References __kmp_affinity_format, __kmp_aux_capture_affinity_field(), __kmp_str_buf_cat(), __kmp_str_buf_catbuf(), __kmp_str_buf_clear(), __kmp_str_buf_free(), __kmp_str_buf_init, __kmp_threads, and KMP_DEBUG_ASSERT.
Referenced by __kmp_aux_display_affinity(), FTN_CAPTURE_AFFINITY(), and ompc_capture_affinity().
|
static |
Definition at line 8632 of file kmp_runtime.cpp.
References __kmp_affinity_format_table, __kmp_aux_get_num_teams(), __kmp_aux_get_team_num(), __kmp_expand_host_name(), __kmp_get_ancestor_thread_num(), __kmp_str_buf_cat(), __kmp_str_buf_clear(), __kmp_str_buf_free(), __kmp_str_buf_init, __kmp_str_buf_print(), __kmp_tid_from_gtid(), buf, BUFFER_SIZE, kmp_affinity_format_field_t::field_format, i, KMP_ASSERT, KMP_DEBUG_ASSERT, KMP_STRLEN, length, kmp_affinity_format_field_t::long_name, kmp_affinity_format_field_t::short_name, SKIP_DIGITS, and SKIP_TOKEN.
Referenced by __kmp_aux_capture_affinity().
Definition at line 8844 of file kmp_runtime.cpp.
References __kmp_aux_capture_affinity(), __kmp_fprintf(), __kmp_str_buf_free(), __kmp_str_buf_init, buf, and kmp_out.
Referenced by __kmp_fork_barrier(), __kmp_serialized_parallel(), FTN_DISPLAY_AFFINITY(), and ompc_display_affinity().
int __kmp_aux_get_num_teams | ( | ) |
Definition at line 8564 of file kmp_runtime.cpp.
References __kmp_aux_get_team_info(), and kmp_team::t.
Referenced by __kmp_aux_capture_affinity_field(), and FTN_GET_NUM_TEAMS().
|
static |
Definition at line 8523 of file kmp_runtime.cpp.
References __kmp_entry_thread(), ii, KMP_DEBUG_ASSERT, level, and kmp_team::t.
Referenced by __kmp_aux_get_num_teams(), and __kmp_aux_get_team_num().
int __kmp_aux_get_team_num | ( | ) |
Definition at line 8551 of file kmp_runtime.cpp.
References __kmp_aux_get_team_info(), and kmp_team::t.
Referenced by __kmp_aux_capture_affinity_field(), and FTN_GET_TEAM_NUM().
void __kmp_aux_set_blocktime | ( | int | arg, |
kmp_info_t * | thread, | ||
int | tid | ||
) |
Definition at line 8853 of file kmp_runtime.cpp.
References __kmp_gtid_from_tid(), __kmp_save_internal_controls(), KF_TRACE, kmp_int8, KMP_MAX_BLOCKTIME, KMP_MIN_BLOCKTIME, set__blocktime_team, set__bt_set_team, and TRUE.
Referenced by __kmp_aux_env_initialize(), FTN_SET_BLOCKTIME(), and kmpc_set_blocktime().
Definition at line 8897 of file kmp_runtime.cpp.
References __kmp_display_env, __kmp_display_env_verbose, __kmp_env_initialize(), __kmp_env_print(), __kmp_init_serial, __kmp_serial_initialize(), and __kmp_settings.
Referenced by FTN_SET_DEFAULTS(), and kmpc_set_defaults().
void __kmp_aux_set_library | ( | enum library_type | arg | ) |
Definition at line 8501 of file kmp_runtime.cpp.
References __kmp_dflt_blocktime, __kmp_library, __kmp_use_yield, __kmp_use_yield_exp_set, KMP_DEFAULT_BLOCKTIME, KMP_FATAL, KMP_INFORM, KMP_MAX_BLOCKTIME, library_serial, library_throughput, and library_turnaround.
Referenced by __kmp_user_set_library().
void __kmp_aux_set_stacksize | ( | size_t | arg | ) |
Definition at line 8469 of file kmp_runtime.cpp.
References __kmp_acquire_bootstrap_lock(), __kmp_env_stksize, __kmp_init_parallel, __kmp_init_serial, __kmp_initz_lock, __kmp_release_bootstrap_lock(), __kmp_serial_initialize(), __kmp_stksize, __kmp_sys_min_stksize, KMP_MAX_STKSIZE, TCR_4, TRUE, and value.
Referenced by FTN_SET_STACKSIZE(), FTN_SET_STACKSIZE_S(), kmpc_set_stacksize(), and kmpc_set_stacksize_s().
void __kmp_check_stack_overlap | ( | kmp_info_t * | th | ) |
Definition at line 298 of file kmp_runtime.cpp.
References __kmp_env_checks, __kmp_fatal(), __kmp_gtid_from_thread(), __kmp_msg_null, __kmp_print_storage_map_gtid(), __kmp_storage_map, __kmp_threads, __kmp_threads_capacity, f(), KA_TRACE, KMP_GTID_MONITOR, KMP_HNT, KMP_MSG, KMP_UBER_GTID(), TCR_PTR, TCR_SYNC_PTR, and TRUE.
Referenced by __kmp_create_worker(), and __kmp_launch_worker().
Definition at line 8277 of file kmp_runtime.cpp.
References __kmp_affinity_format, __kmp_cleanup_hierarchy(), __kmp_cleanup_threadprivate_caches(), __kmp_cleanup_user_locks(), __kmp_free, __kmp_hier_scheds, __kmp_i18n_catclose(), __kmp_init_middle, __kmp_init_parallel, __kmp_init_serial, __kmp_nested_nth, __kmp_nested_proc_bind, __kmp_old_threads_list, __kmp_root, __kmp_runtime_destroy(), __kmp_stats_fini(), __kmp_threads, __kmp_threads_capacity, kmp_nested_proc_bind_t::bind_types, CCAST, kmp_hier_sched_env_t::deallocate(), f(), FALSE, KA_TRACE, KMP_INTERNAL_FREE, kmp_old_threads_list_t::next, kmp_nested_nthreads_t::nth, kmp_nested_nthreads_t::size, kmp_nested_proc_bind_t::size, TCR_4, TCW_4, kmp_old_threads_list_t::threads, kmp_nested_nthreads_t::used, and kmp_nested_proc_bind_t::used.
Referenced by __kmp_internal_end().
PACKED_REDUCTION_METHOD_T __kmp_determine_reduction_method | ( | ident_t * | loc, |
kmp_int32 | global_tid, | ||
kmp_int32 | num_vars, | ||
size_t | reduce_size, | ||
void * | reduce_data, | ||
void(*)(void *lhs_data, void *rhs_data) | reduce_func, | ||
kmp_critical_name * | lck | ||
) |
Definition at line 8912 of file kmp_runtime.cpp.
References __kmp_force_reduction_method, __kmp_get_team_num_threads, atomic_reduce_block, critical_reduce_block, empty_reduce_block, FAST_REDUCTION_ATOMIC_METHOD_GENERATED, FAST_REDUCTION_TREE_METHOD_GENERATED, KA_TRACE, KMP_ASSERT, KMP_DEBUG_ASSERT, KMP_WARNING, lck, reduction_method_not_defined, and tree_reduce_block.
Referenced by __kmpc_reduce(), and __kmpc_reduce_nowait().
Definition at line 7409 of file kmp_runtime.cpp.
References __kmp_avail_proc, __kmp_dflt_team_nth, __kmp_dflt_team_nth_ub, __kmp_do_serial_initialize(), __kmp_env_blocktime, __kmp_init_middle, __kmp_init_serial, __kmp_ncores, __kmp_need_register_serial, __kmp_nested_nth, __kmp_nesting_mode, __kmp_nth, __kmp_register_library_startup(), __kmp_set_nesting_mode_threads(), __kmp_sys_max_nth, __kmp_threads, __kmp_threads_capacity, __kmp_xproc, i, j, KA_TRACE, KMP_ASSERT, KMP_DEBUG_ASSERT, KMP_MIN_NTH, kmp_nested_nthreads_t::nth, set__nproc, TCW_SYNC_4, TRUE, UNLIKELY, and kmp_nested_nthreads_t::used.
Referenced by __kmp_middle_initialize(), and __kmp_parallel_initialize().
Definition at line 7091 of file kmp_runtime.cpp.
References __kmp_abort_delay, __kmp_all_nth, __kmp_allocate, __kmp_allThreadsSpecified, __kmp_atomic_lock, __kmp_atomic_lock_10r, __kmp_atomic_lock_16c, __kmp_atomic_lock_16r, __kmp_atomic_lock_1i, __kmp_atomic_lock_20c, __kmp_atomic_lock_2i, __kmp_atomic_lock_32c, __kmp_atomic_lock_4i, __kmp_atomic_lock_4r, __kmp_atomic_lock_8c, __kmp_atomic_lock_8i, __kmp_atomic_lock_8r, __kmp_barrier_gather_bb_dflt, __kmp_barrier_gather_branch_bits, __kmp_barrier_gather_pat_dflt, __kmp_barrier_gather_pattern, __kmp_barrier_release_bb_dflt, __kmp_barrier_release_branch_bits, __kmp_barrier_release_pat_dflt, __kmp_barrier_release_pattern, __kmp_cg_max_nth, __kmp_common_initialize(), __kmp_debug_lock, __kmp_default_tp_capacity(), __kmp_dflt_blocktime, __kmp_dflt_team_nth_ub, __kmp_dispatch_lock, __kmp_display_env, __kmp_display_env_verbose, __kmp_env_checks, __kmp_env_free(), __kmp_env_get(), __kmp_env_initialize(), __kmp_env_print(), __kmp_env_print_2(), __kmp_exit_lock, __kmp_fatal(), __kmp_foreign_tp, __kmp_forkjoin_lock, __kmp_global, __kmp_global_lock, __kmp_i18n_dump_catalog(), __kmp_init_allocator(), __kmp_init_atomic_lock(), __kmp_init_bootstrap_lock(), __kmp_init_counter, __kmp_init_lock(), __kmp_init_nesting_mode(), __kmp_init_queuing_lock(), __kmp_init_serial, __kmp_initial_threads_capacity(), __kmp_internal_end_atexit(), __kmp_library, __kmp_max_nth, __kmp_msg_null, __kmp_need_register_serial, __kmp_nth, __kmp_print_version_1(), __kmp_printf(), __kmp_register_atfork(), __kmp_register_library_startup(), __kmp_register_root(), __kmp_root, __kmp_runtime_initialize(), __kmp_settings, __kmp_static, __kmp_stats_init(), __kmp_str_buf_free(), __kmp_str_buf_init, __kmp_str_match_true(), __kmp_sys_max_nth, __kmp_team_pool, __kmp_teams_max_nth, __kmp_thread_pool, __kmp_thread_pool_insert_pt, __kmp_threads, __kmp_threads_capacity, __kmp_tp_cached_lock, __kmp_tp_capacity, __kmp_validate_locks(), __kmp_version, __kmp_xproc, bp_hierarchical_bar, bs_forkjoin_barrier, bs_last_barrier, bs_plain_barrier, bs_reduction_barrier, CACHE_LINE, dynamic_default, FALSE, i, KA_TRACE, KMP_ASSERT, KMP_DEBUG_ASSERT, KMP_DEFAULT_BLOCKTIME, KMP_ERR, KMP_INITIAL_GTID, KMP_MB, KMP_MIN_NTH, KMP_MSG, kmp_sch_static_balanced, KMP_UBER_GTID(), library_throughput, ompt_post_init(), ompt_pre_init(), size, kmp_str_buf::str, TCR_4, TCW_SYNC_4, TRUE, and val.
Referenced by __kmp_do_middle_initialize(), __kmp_get_global_thread_id_reg(), __kmp_omp_display_env(), and __kmp_serial_initialize().
Definition at line 699 of file kmp_runtime.cpp.
References __kmp_atomic_compare_store_acq(), __kmp_check_workshare(), __kmp_env_consistency_check, __kmp_init_parallel, __kmp_parallel_initialize(), __kmp_push_workshare(), __kmp_resume_if_soft_paused(), __kmp_threads, ct_psingle, KMP_MASTER_GTID, status, kmp_team::t, and TCR_4.
Referenced by __kmpc_single(), KMP_API_NAME_GOMP_SINGLE_COPY_START(), and KMP_API_NAME_GOMP_SINGLE_START().
Definition at line 752 of file kmp_runtime.cpp.
References __kmp_env_consistency_check, __kmp_pop_workshare(), and ct_psingle.
Referenced by __kmpc_end_single().
Definition at line 3709 of file kmp_runtime.cpp.
References __kmp_acquire_bootstrap_lock(), __kmp_allocate, __kmp_old_threads_list, __kmp_release_bootstrap_lock(), __kmp_root, __kmp_sys_max_nth, __kmp_threadprivate_resize_cache(), __kmp_threads, __kmp_threads_capacity, __kmp_tp_cached, __kmp_tp_cached_lock, __kmp_tp_capacity, CACHE_LINE, KMP_DEBUG_ASSERT, KMP_MEMCPY, kmp_old_threads_list_t::next, and kmp_old_threads_list_t::threads.
Referenced by __kmp_register_root(), and __kmp_reserve_threads().
|
static |
Definition at line 582 of file kmp_runtime.cpp.
References __kmp_fini_memkind().
Referenced by __kmp_internal_end_library().
Definition at line 2418 of file kmp_barrier.cpp.
References __kmp_aux_display_affinity(), __kmp_barrier_release_branch_bits, __kmp_barrier_release_pattern, __kmp_dflt_blocktime, __kmp_display_affinity, __kmp_dist_barrier_release(), __kmp_global, __kmp_gtid_from_thread(), __kmp_hierarchical_barrier_release(), __kmp_hyper_barrier_release(), __kmp_init_implicit_task(), __kmp_linear_barrier_release(), __kmp_task_team_setup(), __kmp_task_team_sync(), __kmp_tasking_mode, __kmp_threads, __kmp_tid_from_gtid(), __kmp_tree_barrier_release(), bp_dist_bar, bp_hierarchical_bar, bp_hyper_bar, bp_tree_bar, bs_forkjoin_barrier, copy_icvs(), ompt_callbacks_active_s::enabled, FALSE, i, if(), KA_TRACE, KMP_AFFINITY_SUPPORTED, KMP_ASSERT, KMP_BARRIER_SLEEP_STATE, KMP_BLOCKTIME_INTERVAL, KMP_CHECK_UPDATE, KMP_DEBUG_ASSERT, KMP_INIT_BARRIER_STATE, KMP_MASTER_TID, KMP_MAX_BLOCKTIME, KMP_MB, KMP_SET_THREAD_STATE_BLOCK, KMP_TIME_DEVELOPER_PARTITIONED_BLOCK, KMP_TIME_PARTITIONED_BLOCK, ompt_callbacks, ompt_enabled, proc_bind_false, proc_bind_intel, kmp_team::t, TCR_4, TCR_PTR, TRUE, tskm_immediate_exec, and USE_ITT_BUILD_ARG.
Referenced by __kmp_internal_fork(), and __kmp_launch_thread().
int __kmp_fork_call | ( | ident_t * | loc, |
int | gtid, | ||
enum fork_context_e | call_context, | ||
kmp_int32 | argc, | ||
microtask_t | microtask, | ||
launch_t | invoker, | ||
kmp_va_list | ap | ||
) |
Definition at line 1927 of file kmp_runtime.cpp.
References __kmp_acquire_bootstrap_lock(), __kmp_allocate, __kmp_allocate_team(), __kmp_assign_root_init_mask, __kmp_barrier_release_pattern, __kmp_fork_in_teams(), __kmp_fork_team_threads(), __kmp_forkjoin_lock, __kmp_init_parallel, __kmp_init_serial, __kmp_internal_fork(), __kmp_is_entering_teams(), __kmp_is_fork_in_teams(), __kmp_library, __kmp_nested_proc_bind, __kmp_override_nested_nth(), __kmp_parallel_initialize(), __kmp_release_bootstrap_lock(), __kmp_reserve_threads(), __kmp_resume_if_soft_paused(), __kmp_root, __kmp_serial_fork_call(), __kmp_setup_icv_copy(), __kmp_stkpadding, __kmp_teams_master(), __kmp_teams_proc_bind, __kmp_threads, __ompt_get_task_info_internal(), kmp_nested_proc_bind_t::bind_types, bp_dist_bar, bs_forkjoin_barrier, cancel_noreq, copy_icvs(), ompt_callbacks_active_s::enabled, fork_context_gnu, get__nproc_2, get__sched_2, i, if(), KA_TRACE, KC_TRACE, KF_TRACE, KMP_ALLOCA, KMP_ASSERT2, KMP_ATOMIC_INC, KMP_CHECK_UPDATE, KMP_CHECK_UPDATE_SYNC, KMP_COUNT_VALUE, KMP_DEBUG_ASSERT, KMP_DEBUG_ASSERT_TASKTEAM_INVARIANT, KMP_GET_THREAD_STATE, KMP_INTERNAL_FREE, KMP_MAX_STKPADDING, KMP_MB, KMP_SET_THREAD_STATE, KMP_TIME_DEVELOPER_PARTITIONED_BLOCK, kmp_va_deref, level, library_serial, loc, microtask(), kmp_internal_control::next, kmp_internal_control::nproc, kmp_nested_nthreads_t::nth, ompt_callbacks, ompt_enabled, OMPT_INVOKER, kmp_internal_control::proc_bind, proc_bind_default, proc_bind_false, propagateFPControl, kmp_r_sched::sched, short, kmp_team::t, TCR_4, TRUE, USE_NESTED_HOT_ARG, kmp_nested_nthreads_t::used, and kmp_nested_proc_bind_t::used.
Referenced by __kmp_GOMP_fork_call(), __kmp_teams_master(), __kmpc_fork_call(), and __kmpc_fork_teams().
|
inlinestatic |
Definition at line 1465 of file kmp_runtime.cpp.
References __kmp_add_threads_to_team(), __kmp_alloc_argv_entries(), __kmp_barrier_release_pattern, __kmp_debugging, __kmp_internal_fork(), __kmp_invoke_microtask(), __kmp_nested_proc_bind, __kmp_resize_dist_barrier(), __kmp_tid_from_gtid(), __kmpc_serialized_parallel(), __ompt_lw_taskteam_init(), __ompt_lw_taskteam_link(), __ompt_lw_taskteam_unlink(), kmp_nested_proc_bind_t::bind_types, bp_dist_bar, bs_forkjoin_barrier, ompt_callbacks_active_s::enabled, fork_context_gnu, ompt_task_info_t::frame, i, KA_TRACE, KF_TRACE, KMP_ASSERT2, KMP_ATOMIC_INC, KMP_CHECK_UPDATE, KMP_DEBUG_ASSERT, KMP_MB, KMP_SET_THREAD_STATE_BLOCK, KMP_TIME_PARTITIONED_BLOCK, kmp_va_deref, level, loc, microtask(), ompt_callbacks, ompt_enabled, OMPT_INVOKER, ompt_lw_taskteam_s::ompt_task_info, proc_bind_default, proc_bind_false, kmp_team::t, TRUE, and kmp_nested_proc_bind_t::used.
Referenced by __kmp_fork_call().
|
static |
Definition at line 959 of file kmp_runtime.cpp.
References __kmp_add_threads_to_team(), __kmp_allocate_thread(), __kmp_barrier_gather_pattern, __kmp_display_affinity, __kmp_get_gtid, __kmp_gtid_from_thread(), __kmp_gtid_from_tid(), __kmp_initialize_info(), __kmp_tasking_mode, __kmp_teams_master(), b, kmp_barrier_union::bb, bp_dist_bar, bs_forkjoin_barrier, bs_last_barrier, bs_plain_barrier, FALSE, i, KA_TRACE, KMP_BARRIER_PARENT_FLAG, KMP_CHECK_UPDATE, KMP_DEBUG_ASSERT, KMP_DEBUG_ASSERT_TASKTEAM_INVARIANT, KMP_MB, level, kmp_team::t, and tskm_immediate_exec.
Referenced by __kmp_fork_call().
void __kmp_free_team | ( | kmp_root_t * | root, |
kmp_team_t *team | USE_NESTED_HOT_ARGkmp_info_t *master | ||
) |
Definition at line 5660 of file kmp_runtime.cpp.
References __kmp_atomic_resume_64(), __kmp_barrier_gather_pattern, __kmp_dflt_blocktime, __kmp_free, __kmp_free_task_team(), __kmp_free_thread(), __kmp_get_gtid, __kmp_is_thread_alive(), __kmp_nested_nth, __kmp_null_resume_wrapper(), __kmp_tasking_mode, __kmp_team_pool, __kmp_teams_master(), bp_dist_bar, bs_forkjoin_barrier, CCAST, kmp_cg_root::cg_nthreads, distributedBarrier::deallocate(), f(), i, KA_TRACE, KMP_COMPARE_AND_STORE_ACQ32, KMP_CPU_PAUSE, KMP_DEBUG_ASSERT, KMP_INTERNAL_FREE, KMP_MAX_BLOCKTIME, KMP_MB, KMP_SAFE_TO_REAP, level, kmp_team::t, TCW_SYNC_PTR, tskm_immediate_exec, kmp_cg_root::up, and void.
Referenced by __kmp_join_call(), and __kmp_reset_root().
|
static |
Definition at line 3261 of file kmp_runtime.cpp.
References __kmp_dispatch_free_hierarchies(), __kmp_free, i, and kmp_team::t.
Referenced by __kmp_reap_team().
void __kmp_free_thread | ( | kmp_info_t * | this_th | ) |
Definition at line 5886 of file kmp_runtime.cpp.
References __kmp_avail_proc, __kmp_env_blocktime, __kmp_free, __kmp_free_implicit_task(), __kmp_get_gtid, __kmp_lock_suspend_mx(), __kmp_nth, __kmp_suspend_initialize_thread(), __kmp_thread_pool, __kmp_thread_pool_active_nth, __kmp_thread_pool_insert_pt, __kmp_unlock_suspend_mx(), b, kmp_barrier_union::bb, bs_last_barrier, CCAST, kmp_cg_root::cg_nthreads, kmp_cg_root::cg_root, FALSE, KA_TRACE, KMP_ATOMIC_INC, KMP_BARRIER_PARENT_FLAG, KMP_BARRIER_SWITCH_TO_OWN_FLAG, KMP_DEBUG_ASSERT, KMP_MB, KMP_SAFE_TO_REAP, TCW_4, TCW_PTR, TRUE, and kmp_cg_root::up.
Referenced by __kmp_allocate_team(), __kmp_free_team(), and __kmp_set_num_threads().
Definition at line 3049 of file kmp_runtime.cpp.
References __kmp_init_serial, __kmp_threads, __kmp_tid_from_gtid(), ii, KF_TRACE, KMP_DEBUG_ASSERT, level, and kmp_team::t.
Referenced by __kmp_aux_capture_affinity_field(), FTN_GET_ANCESTOR_THREAD_NUM(), and ompc_get_ancestor_thread_num().
|
static |
Definition at line 3297 of file kmp_runtime.cpp.
References __kmp_cg_max_nth, __kmp_default_device, __kmp_dflt_blocktime, __kmp_dflt_max_active_levels, __kmp_dflt_team_nth, __kmp_env_blocktime, __kmp_get_schedule_global(), __kmp_global, __kmp_nested_proc_bind, __kmp_task_max_nth, kmp_nested_proc_bind_t::bind_types, KMP_DEBUG_ASSERT, kmp_int8, and kmp_nested_proc_bind_t::used.
Referenced by __kmp_initialize_root(), and __kmp_register_root().
Definition at line 134 of file kmp_runtime.cpp.
References __kmp_all_nth, __kmp_gtid_get_specific(), __kmp_gtid_mode, __kmp_init_gtid, __kmp_nth, __kmp_print_storage_map_gtid(), __kmp_storage_map, __kmp_threads, __kmp_threads_capacity, i, if(), KA_TRACE, KMP_DEBUG_ASSERT, KMP_FATAL, KMP_GTID_DNE, TCR_4, TCR_PTR, TCR_SYNC_PTR, and TCW_PTR.
Referenced by __kmp_get_global_thread_id_reg().
Definition at line 255 of file kmp_runtime.cpp.
References __kmp_acquire_bootstrap_lock(), __kmp_do_serial_initialize(), __kmp_get_global_thread_id(), __kmp_gtid_get_specific(), __kmp_gtid_mode, __kmp_init_serial, __kmp_initz_lock, __kmp_register_root(), __kmp_release_bootstrap_lock(), FALSE, KA_TRACE, KMP_DEBUG_ASSERT, KMP_GTID_DNE, and TCR_4.
Definition at line 2912 of file kmp_runtime.cpp.
References __kmp_init_serial, __kmp_threads, KF_TRACE, and KMP_DEBUG_ASSERT.
Referenced by FTN_GET_MAX_ACTIVE_LEVELS().
Definition at line 2932 of file kmp_runtime.cpp.
References __kmp_nteams.
Referenced by FTN_GET_MAX_TEAMS().
unsigned short __kmp_get_random | ( | kmp_info_t * | thread | ) |
Definition at line 3650 of file kmp_runtime.cpp.
References KA_TRACE, r, and short.
Referenced by __kmp_execute_tasks_template(), and __kmp_reserve_threads().
Definition at line 9069 of file kmp_runtime.cpp.
References __kmp_entry_thread().
void __kmp_get_schedule | ( | int | gtid, |
kmp_sched_t * | kind, | ||
int * | chunk | ||
) |
Definition at line 3001 of file kmp_runtime.cpp.
References __kmp_init_serial, __kmp_sched_apply_mods_stdkind(), __kmp_threads, KF_TRACE, KMP_DEBUG_ASSERT, KMP_FATAL, kmp_sch_auto, kmp_sch_dynamic_chunked, kmp_sch_guided_analytical_chunked, kmp_sch_guided_chunked, kmp_sch_guided_iterative_chunked, kmp_sch_static, kmp_sch_static_balanced, kmp_sch_static_chunked, kmp_sch_static_greedy, kmp_sch_static_steal, kmp_sch_trapezoidal, kmp_sched_auto, kmp_sched_dynamic, kmp_sched_guided, kmp_sched_static, kmp_sched_trapezoidal, and SCHEDULE_WITHOUT_MODIFIERS.
Referenced by FTN_GET_SCHEDULE().
kmp_r_sched_t __kmp_get_schedule_global | ( | void | ) |
Definition at line 3159 of file kmp_runtime.cpp.
References __kmp_chunk, __kmp_guided, __kmp_sched, __kmp_static, kmp_r_sched::chunk, KMP_DEFAULT_CHUNK, kmp_sch_guided_chunked, kmp_sch_static, kmp_r_sched::r_sched_type, s, SCHEDULE_GET_MODIFIERS, SCHEDULE_SET_MODIFIERS, and SCHEDULE_WITHOUT_MODIFIERS.
Referenced by __kmp_get_global_icvs(), and __kmp_initialize_root().
Definition at line 3107 of file kmp_runtime.cpp.
References __kmp_init_serial, __kmp_threads, ii, KF_TRACE, KMP_DEBUG_ASSERT, level, and kmp_team::t.
Referenced by FTN_GET_TEAM_SIZE(), and ompc_get_team_size().
Definition at line 2938 of file kmp_runtime.cpp.
References __kmp_teams_thread_limit.
Referenced by FTN_GET_TEAMS_THREAD_LIMIT().
|
static |
Definition at line 3333 of file kmp_runtime.cpp.
References copy_icvs(), kmp_internal_control::next, kmp_internal_control::serial_nesting_level, and kmp_team::t.
Referenced by __kmp_allocate_thread().
void __kmp_hard_pause | ( | ) |
Definition at line 9079 of file kmp_runtime.cpp.
References __kmp_internal_end_thread(), __kmp_pause_status, and kmp_hard_paused.
Referenced by __kmp_pause_resource().
void __kmp_hidden_helper_initialize | ( | ) |
Definition at line 7602 of file kmp_runtime.cpp.
References __kmp_acquire_bootstrap_lock(), __kmp_do_initialize_hidden_helper_threads(), __kmp_hidden_helper_threads_initz_wait(), __kmp_init_hidden_helper, __kmp_init_hidden_helper_threads, __kmp_init_parallel, __kmp_initz_lock, __kmp_parallel_initialize(), __kmp_release_bootstrap_lock(), __kmp_unexecuted_hidden_helper_tasks, KMP_ATOMIC_ST_REL, TCR_4, TCW_SYNC_4, and TRUE.
Referenced by __kmp_task_alloc().
void __kmp_hidden_helper_threads_initz_routine | ( | ) |
Definition at line 9284 of file kmp_runtime.cpp.
References __kmp_hidden_helper_main_thread, __kmp_hidden_helper_threads, __kmp_hidden_helper_threads_deinitz_release(), __kmp_hidden_helper_threads_num, __kmp_init_hidden_helper, __kmp_register_root(), __kmp_threads, __kmpc_fork_call(), FALSE, KMP_ATOMIC_ST_REL, TCW_SYNC_4, and TRUE.
Definition at line 8380 of file kmp_runtime.cpp.
References __kmp_str_match_false(), FALSE, and TRUE.
Referenced by __kmpc_begin().
Definition at line 8391 of file kmp_runtime.cpp.
References __kmp_str_match_false(), FALSE, and TRUE.
Referenced by __kmpc_end().
Definition at line 364 of file kmp_runtime.cpp.
References FALSE, KMP_YIELD, and TRUE.
Referenced by __kmp_abort_process(), __kmp_abort_thread(), and __kmp_parallel_initialize().
|
static |
Definition at line 578 of file kmp_runtime.cpp.
References __kmp_init_memkind(), and __kmp_init_target_mem().
Referenced by __kmp_do_serial_initialize().
void __kmp_init_nesting_mode | ( | ) |
Definition at line 9319 of file kmp_runtime.cpp.
References __kmp_nested_nth, __kmp_nesting_mode_nlevels, __kmp_nesting_nth_level, i, KMP_HW_LAST, KMP_INTERNAL_MALLOC, KMP_INTERNAL_REALLOC, kmp_nested_nthreads_t::nth, and kmp_nested_nthreads_t::size.
Referenced by __kmp_do_serial_initialize().
void __kmp_init_random | ( | kmp_info_t * | thread | ) |
Definition at line 3663 of file kmp_runtime.cpp.
References __kmp_primes, and KA_TRACE.
Referenced by __kmp_allocate_thread(), and __kmp_register_root().
|
static |
Definition at line 4275 of file kmp_runtime.cpp.
References __kmp_allocate, __kmp_dispatch_num_buffers, __kmp_free, __kmp_init_implicit_task(), __kmp_print_storage_map_gtid(), __kmp_storage_map, __kmp_tasking_mode, kmp_cg_root::cg_nthreads, kmp_cg_root::cg_root, i, KA_TRACE, KD_TRACE, KF_TRACE, KMP_ASSERT, KMP_DEBUG_ASSERT, KMP_MB, KMP_NOT_SAFE_TO_REAP, KMP_SAFE_TO_REAP, proc_bind_default, kmp_team::t, TCW_SYNC_PTR, kmp_disp::th_deo_fcn, kmp_disp::th_disp_buffer, kmp_disp::th_disp_index, kmp_disp::th_dispatch_pr_current, kmp_disp::th_dispatch_sh_current, kmp_disp::th_doacross_buf_idx, kmp_disp::th_dxo_fcn, TRUE, and tskm_immediate_exec.
Referenced by __kmp_allocate_team(), __kmp_allocate_thread(), __kmp_fork_team_threads(), and __kmp_register_root().
|
static |
Definition at line 3344 of file kmp_runtime.cpp.
References __kmp_allocate_team(), __kmp_dflt_blocktime, __kmp_dflt_team_nth_ub, __kmp_get_global_icvs(), __kmp_get_schedule_global(), __kmp_init_lock(), __kmp_nested_nth, __kmp_nested_proc_bind, kmp_nested_proc_bind_t::bind_types, f(), FALSE, KA_TRACE, KF_TRACE, KMP_ASSERT, KMP_DEBUG_ASSERT, KMP_INIT_BARRIER_STATE, kmp_r_sched::sched, kmp_team::t, TCW_SYNC_PTR, and USE_NESTED_HOT_ARG.
Referenced by __kmp_register_root().
|
static |
Definition at line 4745 of file kmp_runtime.cpp.
References __kmp_reinitialize_team(), FALSE, KF_TRACE, KMP_DEBUG_ASSERT, KMP_MB, loc, kmp_r_sched::sched, kmp_internal_control::sched, kmp_team::t, and TCW_SYNC_PTR.
Referenced by __kmp_allocate_team().
Definition at line 8402 of file kmp_runtime.cpp.
References __kmp_acquire_lock(), __kmp_entry_gtid, __kmp_release_lock(), __kmp_threads, KMP_ASSERT, KMP_UBER_GTID(), and TRUE.
Referenced by __kmpc_begin().
Definition at line 6327 of file kmp_runtime.cpp.
References __kmp_acquire_bootstrap_lock(), __kmp_cleanup(), __kmp_global, __kmp_init_common, __kmp_init_gtid, __kmp_monitor, __kmp_reap_monitor(), __kmp_reap_task_teams(), __kmp_reap_team(), __kmp_reap_thread(), __kmp_release_bootstrap_lock(), __kmp_root, __kmp_team_pool, __kmp_thread_pool, __kmp_thread_pool_insert_pt, __kmp_threads, __kmp_threads_capacity, __kmp_unregister_library(), CCAST, FALSE, i, KA_TRACE, KMP_ASSERT, KMP_ATOMIC_LD_ACQ, KMP_CPU_PAUSE, KMP_DEBUG_ASSERT, KMP_MB, KMP_SAFE_TO_REAP, ompt_fini(), r, kmp_team::t, TCR_4, TCW_4, TCW_SYNC_4, and TRUE.
Referenced by __kmp_internal_end_library(), and __kmp_internal_end_thread().
Definition at line 6155 of file kmp_runtime.cpp.
References __kmp_close_console(), __kmp_internal_end_library(), and KA_TRACE.
Referenced by __kmp_do_serial_initialize(), and ompt_finalize_tool().
Definition at line 6133 of file kmp_runtime.cpp.
References __kmp_internal_end_thread(), __kmp_type_convert(), and KA_TRACE.
Referenced by __kmp_runtime_initialize().
Definition at line 6457 of file kmp_runtime.cpp.
References __kmp_acquire_bootstrap_lock(), __kmp_close_console(), __kmp_debug_buf, __kmp_dump_debug_buffer(), __kmp_fini_allocator(), __kmp_forkjoin_lock, __kmp_global, __kmp_gtid_get_specific(), __kmp_hidden_helper_main_thread_release(), __kmp_hidden_helper_team_done, __kmp_hidden_helper_threads_deinitz_wait(), __kmp_init_hidden_helper, __kmp_init_serial, __kmp_initz_lock, __kmp_internal_end(), __kmp_itthash_clean(), __kmp_release_bootstrap_lock(), __kmp_root, __kmp_threads, __kmp_unregister_library(), __kmp_unregister_root_current_thread(), KA_TRACE, KMP_GTID_DNE, KMP_GTID_MONITOR, KMP_GTID_SHUTDOWN, KMP_MB, KMP_UBER_GTID(), r, TCR_4, TCW_SYNC_4, and TRUE.
Referenced by __kmp_internal_end_atexit(), and __kmpc_end().
Definition at line 6578 of file kmp_runtime.cpp.
References __kmp_acquire_bootstrap_lock(), __kmp_debug_buf, __kmp_dump_debug_buffer(), __kmp_forkjoin_lock, __kmp_global, __kmp_gtid_get_specific(), __kmp_hidden_helper_main_thread_release(), __kmp_hidden_helper_team_done, __kmp_hidden_helper_threads_deinitz_wait(), __kmp_init_hidden_helper, __kmp_init_serial, __kmp_initz_lock, __kmp_internal_end(), __kmp_pause_status, __kmp_release_bootstrap_lock(), __kmp_root, __kmp_threads, __kmp_threads_capacity, __kmp_unregister_root_current_thread(), i, KA_TRACE, KMP_GTID_DNE, KMP_GTID_MONITOR, KMP_GTID_SHUTDOWN, kmp_hard_paused, KMP_MB, KMP_UBER_GTID(), r, TCR_4, TCW_SYNC_4, and TRUE.
Referenced by __kmp_hard_pause(), __kmp_internal_end_dest(), and __kmpc_end().
void __kmp_internal_fork | ( | ident_t * | id, |
int | gtid, | ||
kmp_team_t * | team | ||
) |
Definition at line 8059 of file kmp_runtime.cpp.
References __kmp_dispatch_num_buffers, __kmp_fork_barrier(), __kmp_threads, f(), i, KMP_ASSERT, KMP_DEBUG_ASSERT, KMP_MASTER_GTID, KMP_MB, and kmp_team::t.
Referenced by __kmp_fork_call(), and __kmp_fork_in_teams().
void __kmp_internal_join | ( | ident_t * | id, |
int | gtid, | ||
kmp_team_t * | team | ||
) |
Definition at line 8102 of file kmp_runtime.cpp.
References __kmp_join_barrier(), __kmp_print_structure(), __kmp_printf(), __kmp_threads, ompt_callbacks_active_s::enabled, KMP_ASSERT, KMP_DEBUG_ASSERT, KMP_MASTER_GTID, KMP_MASTER_TID, KMP_MB, ompt_callbacks, ompt_enabled, and kmp_team::t.
Referenced by __kmp_join_call().
Definition at line 7680 of file kmp_runtime.cpp.
References __kmp_invoke_microtask(), __kmp_run_after_invoked_task(), __kmp_run_before_invoked_task(), __kmp_threads, __kmp_tid_from_gtid(), ompt_callbacks_active_s::enabled, KMP_DEBUG_ASSERT, KMP_GET_THREAD_STATE, KMP_POP_PARTITIONED_TIMER, KMP_PUSH_PARTITIONED_TIMER, KMP_SET_THREAD_STATE, ompt_callbacks, ompt_enabled, kmp_team::t, and TCR_SYNC_PTR.
Referenced by __kmp_GOMP_fork_call(), __kmp_teams_master(), __kmpc_fork_call(), and __kmpc_invoke_task_func().
Definition at line 7823 of file kmp_runtime.cpp.
References __kmp_run_after_invoked_task(), __kmp_run_before_invoked_task(), __kmp_teams_master(), __kmp_threads, __kmp_tid_from_gtid(), KMP_DEBUG_ASSERT, ompt_callbacks, ompt_enabled, and kmp_team::t.
Referenced by __kmpc_fork_teams().
|
inlinestatic |
|
inlinestatic |
Definition at line 1446 of file kmp_runtime.cpp.
References __kmp_teams_master(), level, and microtask().
Referenced by __kmp_fork_call().
void __kmp_itt_fini_ittlib | ( | ) |
Definition at line 9398 of file kmp_runtime.cpp.
void __kmp_itt_init_ittlib | ( | ) |
Definition at line 9399 of file kmp_runtime.cpp.
|
static |
Definition at line 6302 of file kmp_runtime.cpp.
References __kmp_thread_free, and i.
Referenced by __kmp_internal_end_library().
Definition at line 2176 of file kmp_barrier.cpp.
References __kmp_barrier_gather_branch_bits, __kmp_barrier_gather_pattern, __kmp_dflt_blocktime, __kmp_display_affinity, __kmp_dist_barrier_gather(), __kmp_gtid_from_thread(), __kmp_hierarchical_barrier_gather(), __kmp_hyper_barrier_gather(), __kmp_linear_barrier_gather(), __kmp_null_resume_wrapper(), __kmp_print_structure(), __kmp_task_team_wait(), __kmp_tasking_barrier(), __kmp_tasking_mode, __kmp_threads, __kmp_tid_from_gtid(), __kmp_tree_barrier_gather(), bp_dist_bar, bp_hierarchical_bar, bp_hyper_bar, bp_tree_bar, bs_forkjoin_barrier, ompt_callbacks_active_s::enabled, i, KA_TRACE, KMP_ASSERT, KMP_BLOCKTIME_INTERVAL, KMP_CHECK_UPDATE, KMP_DEBUG_ASSERT, KMP_DEBUG_ASSERT_TASKTEAM_INVARIANT, KMP_MASTER_TID, KMP_MAX_BLOCKTIME, KMP_MB, KMP_SET_THREAD_STATE_BLOCK, KMP_TIME_PARTITIONED_BLOCK, loc, ompt_callbacks, ompt_enabled, kmp_team::t, TCR_PTR, tskm_extra_barrier, tskm_immediate_exec, and USE_ITT_BUILD_ARG.
Referenced by __kmp_internal_join(), and __kmp_launch_thread().
Definition at line 2436 of file kmp_runtime.cpp.
References __kmp_acquire_bootstrap_lock(), __kmp_forkjoin_lock, __kmp_free_team(), __kmp_gtid_from_thread(), __kmp_internal_join(), __kmp_pop_current_task_from_thread(), __kmp_release_bootstrap_lock(), __kmp_reset_root_init_mask(), __kmp_tasking_mode, __kmp_teams_master(), __kmp_threads, __kmpc_end_serialized_parallel(), __ompt_get_task_info_object(), __ompt_lw_taskteam_unlink(), b, kmp_barrier_union::bb, bs_last_barrier, ompt_callbacks_active_s::enabled, fork_context_gnu, ompt_task_info_t::frame, i, if(), KA_TRACE, KF_TRACE, KMP_ATOMIC_DEC, KMP_BARRIER_PARENT_FLAG, KMP_DEBUG_ASSERT, KMP_DEBUG_ASSERT_TASKTEAM_INVARIANT, KMP_MB, KMP_TIME_DEVELOPER_PARTITIONED_BLOCK, level, loc, ompt_callbacks, ompt_enabled, OMPT_INVOKER, kmp_team::t, ompt_task_info_t::task_data, tskm_immediate_exec, updateHWFPControl, and USE_NESTED_HOT_ARG.
Referenced by __kmp_teams_master(), __kmpc_fork_call(), __kmpc_fork_teams(), and KMP_API_NAME_GOMP_PARALLEL_END().
void * __kmp_launch_thread | ( | kmp_info_t * | this_thr | ) |
Definition at line 6007 of file kmp_runtime.cpp.
References __kmp_allocate_cons_stack(), __kmp_common_destroy_gtid(), __kmp_env_consistency_check, __kmp_fork_barrier(), __kmp_global, __kmp_join_barrier(), __kmp_threads, __kmp_tid_from_gtid(), __ompt_get_task_info_object(), ompt_callbacks_active_s::enabled, ompt_task_info_t::frame, KA_TRACE, KMP_ASSERT, KMP_DEBUG_ASSERT, KMP_GTID_DNE, KMP_MB, ompt_callbacks, ompt_enabled, OMPT_GET_FRAME_ADDRESS, TCR_4, TCR_SYNC_PTR, and updateHWFPControl.
Referenced by __kmp_launch_worker().
Definition at line 7516 of file kmp_runtime.cpp.
References __kmp_acquire_bootstrap_lock(), __kmp_do_middle_initialize(), __kmp_init_middle, __kmp_initz_lock, and __kmp_release_bootstrap_lock().
Referenced by __kmp_push_thread_limit(), __kmp_task_alloc(), __kmpc_begin(), FTN_CAPTURE_AFFINITY(), FTN_CREATE_AFFINITY_MASK(), FTN_DESTROY_AFFINITY_MASK(), FTN_DISPLAY_AFFINITY(), FTN_GET_AFFINITY(), FTN_GET_AFFINITY_MASK_PROC(), FTN_GET_AFFINITY_MAX_PROC(), FTN_GET_MAX_ACTIVE_LEVELS(), FTN_GET_MAX_THREADS(), FTN_GET_NUM_PLACES(), FTN_GET_NUM_PROCS(), FTN_GET_PARTITION_NUM_PLACES(), FTN_GET_PARTITION_PLACE_NUMS(), FTN_GET_PLACE_NUM(), FTN_GET_PLACE_NUM_PROCS(), FTN_GET_PLACE_PROC_IDS(), FTN_SET_AFFINITY(), FTN_SET_AFFINITY_MASK_PROC(), FTN_UNSET_AFFINITY_MASK_PROC(), kmpc_get_affinity_mask_proc(), kmpc_set_affinity_mask_proc(), kmpc_unset_affinity_mask_proc(), ompc_capture_affinity(), and ompc_display_affinity().
Definition at line 9150 of file kmp_runtime.cpp.
References __kmp_acquire_bootstrap_lock(), __kmp_display_env_impl(), __kmp_do_serial_initialize(), __kmp_init_serial, __kmp_initz_lock, and __kmp_release_bootstrap_lock().
Referenced by FTN_DISPLAY_ENV().
|
static |
Definition at line 116 of file kmp_runtime.cpp.
References i, j, KMP_INTERNAL_MALLOC, level, new_size, kmp_nested_nthreads_t::nth, kmp_nested_nthreads_t::size, and kmp_nested_nthreads_t::used.
Referenced by __kmp_fork_call().
Definition at line 647 of file kmp_runtime.cpp.
References __kmp_env_consistency_check, __kmp_push_sync(), __kmp_team_from_gtid(), __kmp_threads, __kmp_tid_from_gtid(), ct_ordered_in_parallel, KMP_EQ, KMP_MB, KMP_WAIT, and kmp_team::t.
Referenced by __kmpc_ordered().
Definition at line 672 of file kmp_runtime.cpp.
References __kmp_env_consistency_check, __kmp_pop_sync(), __kmp_team_from_gtid(), __kmp_threads, __kmp_tid_from_gtid(), ct_ordered_in_parallel, KMP_MB, and kmp_team::t.
Referenced by __kmpc_end_ordered().
Definition at line 7529 of file kmp_runtime.cpp.
References __kmp_acquire_bootstrap_lock(), __kmp_assign_root_init_mask, __kmp_do_middle_initialize(), __kmp_entry_gtid, __kmp_global, __kmp_infinite_loop(), __kmp_init_middle, __kmp_init_parallel, __kmp_initz_lock, __kmp_print_version_2(), __kmp_release_bootstrap_lock(), __kmp_resume_if_hard_paused(), __kmp_suspend_initialize(), __kmp_version, dynamic_default, dynamic_thread_limit, KA_TRACE, KMP_ASSERT, KMP_MB, KMP_UBER_GTID(), TCR_4, TCW_SYNC_4, and TRUE.
Referenced by __kmp_dispatch_init(), __kmp_dispatch_init_hierarchy(), __kmp_enter_single(), __kmp_fork_call(), __kmp_hidden_helper_initialize(), __kmp_serialized_parallel(), __kmpc_barrier(), __kmpc_barrier_master(), __kmpc_barrier_master_nowait(), __kmpc_end_serialized_parallel(), __kmpc_masked(), __kmpc_master(), __kmpc_ordered(), __kmpc_reduce(), __kmpc_reduce_nowait(), __kmpc_sections_init(), KMP_API_NAME_GOMP_SINGLE_COPY_START(), and KMP_API_NAME_GOMP_SINGLE_START().
int __kmp_pause_resource | ( | kmp_pause_status_t | level | ) |
Definition at line 9116 of file kmp_runtime.cpp.
References __kmp_hard_pause(), __kmp_pause_status, __kmp_soft_pause(), KMP_DEBUG_ASSERT, kmp_hard_paused, kmp_not_paused, kmp_soft_paused, kmp_stop_tool_paused, and level.
Referenced by __kmpc_pause_resource().
void __kmp_print_storage_map_gtid | ( | int | gtid, |
void * | p1, | ||
void * | p2, | ||
size_t | size, | ||
char const * | format, | ||
... | |||
) |
Definition at line 374 of file kmp_runtime.cpp.
References __kmp_acquire_bootstrap_lock(), __kmp_printf_no_lock(), __kmp_release_bootstrap_lock(), __kmp_stdio_lock, __kmp_storage_map_verbose, __kmp_vprintf(), FALSE, kmp_err, KMP_GET_PAGE_SIZE, KMP_I18N_STR, KMP_SNPRINTF, MAX_MESSAGE, and size.
Referenced by __kmp_alloc_argv_entries(), __kmp_check_stack_overlap(), __kmp_get_global_thread_id(), __kmp_initialize_info(), __kmp_print_team_storage_map(), and __kmp_print_thread_storage_map().
|
static |
Definition at line 536 of file kmp_runtime.cpp.
References __kmp_dispatch_num_buffers, __kmp_print_storage_map_gtid(), bs_forkjoin_barrier, bs_last_barrier, bs_plain_barrier, bs_reduction_barrier, and kmp_team::t.
Referenced by __kmp_allocate_team().
|
static |
Definition at line 501 of file kmp_runtime.cpp.
References __kmp_print_storage_map_gtid(), bs_forkjoin_barrier, bs_last_barrier, bs_plain_barrier, and bs_reduction_barrier.
Referenced by __kmp_allocate_thread(), and __kmp_register_root().
Definition at line 7961 of file kmp_runtime.cpp.
References __kmp_msg(), __kmp_msg_null, __kmp_nteams, __kmp_push_thread_limit(), __kmp_reserve_warn, __kmp_teams_max_nth, __kmp_threads, KMP_HNT, kmp_ms_warning, and KMP_MSG.
Referenced by __kmpc_fork_teams(), and __kmpc_push_num_teams().
void __kmp_push_num_teams_51 | ( | ident_t * | id, |
int | gtid, | ||
int | num_teams_lb, | ||
int | num_teams_ub, | ||
int | num_threads | ||
) |
Definition at line 7996 of file kmp_runtime.cpp.
References __kmp_fatal(), __kmp_msg(), __kmp_msg_null, __kmp_nteams, __kmp_push_thread_limit(), __kmp_reserve_warn, __kmp_teams_max_nth, __kmp_threads, KMP_DEBUG_ASSERT, KMP_HNT, kmp_ms_warning, and KMP_MSG.
Referenced by __kmpc_push_num_teams_51().
Definition at line 7856 of file kmp_runtime.cpp.
References __kmp_threads.
Referenced by __kmp_GOMP_fork_call(), __kmpc_push_num_threads(), and __kmpc_push_num_threads_strict().
void __kmp_push_num_threads_list | ( | ident_t * | id, |
int | gtid, | ||
kmp_uint32 | list_length, | ||
int * | num_threads_list | ||
) |
Definition at line 7863 of file kmp_runtime.cpp.
References __kmp_threads, i, KMP_DEBUG_ASSERT, and KMP_INTERNAL_MALLOC.
Referenced by __kmpc_push_num_threads_list(), and __kmpc_push_num_threads_list_strict().
void __kmp_push_proc_bind | ( | ident_t * | id, |
int | gtid, | ||
kmp_proc_bind_t | proc_bind | ||
) |
Definition at line 8052 of file kmp_runtime.cpp.
References __kmp_threads.
Referenced by __kmp_GOMP_fork_call(), and __kmpc_push_proc_bind().
|
static |
Definition at line 7896 of file kmp_runtime.cpp.
References __kmp_assign_root_init_mask, __kmp_avail_proc, __kmp_dflt_team_nth, __kmp_init_middle, __kmp_middle_initialize(), __kmp_msg(), __kmp_msg_null, __kmp_reserve_warn, __kmp_teams_max_nth, __kmp_teams_thread_limit, KMP_DEBUG_ASSERT, KMP_HNT, kmp_ms_warning, KMP_MSG, and TCR_4.
Referenced by __kmp_push_num_teams(), and __kmp_push_num_teams_51().
|
static |
Definition at line 3283 of file kmp_runtime.cpp.
References __kmp_allocate_team_arrays(), __kmp_free, KMP_MEMCPY, and kmp_team::t.
Referenced by __kmp_allocate_team().
kmp_team_t * __kmp_reap_team | ( | kmp_team_t * | team | ) |
Definition at line 5840 of file kmp_runtime.cpp.
References __kmp_free, __kmp_free_team_arrays(), KMP_DEBUG_ASSERT, KMP_MB, and kmp_team::t.
Referenced by __kmp_allocate_team(), __kmp_internal_end(), and __kmp_reap_thread().
|
static |
Definition at line 6186 of file kmp_runtime.cpp.
References __kmp_all_nth, __kmp_avail_proc, __kmp_barrier_gather_pattern, __kmp_dflt_blocktime, __kmp_env_blocktime, __kmp_env_consistency_check, __kmp_finalize_bget(), __kmp_free, __kmp_free_cons_stack(), __kmp_free_implicit_task(), __kmp_nth, __kmp_reap_team(), __kmp_reap_worker(), __kmp_release_64(), __kmp_resume_32(), __kmp_suspend_uninitialize_thread(), __kmp_thread_pool_active_nth, __kmp_threads, bp_dist_bar, bs_forkjoin_barrier, FALSE, flag, KA_TRACE, KMP_ATOMIC_DEC, KMP_COMPARE_AND_STORE_ACQ32, KMP_CPU_PAUSE, KMP_DEBUG_ASSERT, KMP_MAX_BLOCKTIME, KMP_MB, and TCW_SYNC_PTR.
Referenced by __kmp_internal_end(), and __kmp_reset_root().
|
inlinestatic |
Definition at line 6722 of file kmp_runtime.cpp.
References __kmp_str_format().
Referenced by __kmp_register_library_startup(), and __kmp_unregister_library().
Definition at line 6743 of file kmp_runtime.cpp.
References __kmp_detect_shm(), __kmp_detect_tmp(), __kmp_duplicate_library_ok, __kmp_env_get(), __kmp_env_set(), __kmp_env_unset(), __kmp_fatal(), __kmp_initialize_system_tick(), __kmp_is_address_mapped(), __kmp_msg_null, __kmp_read_system_time(), __kmp_reg_status_name(), __kmp_registration_flag, __kmp_registration_str, __kmp_str_format(), __kmp_str_match_true(), __kmp_str_split(), KA_TRACE, KMP_DEBUG_ASSERT, KMP_FALLTHROUGH, KMP_HNT, KMP_INTERNAL_FREE, KMP_MSG, KMP_SSCANF, KMP_STRCPY_S, KMP_WARNING, name, RCAST, tail, and value.
Referenced by __kmp_do_middle_initialize(), and __kmp_do_serial_initialize().
Definition at line 3803 of file kmp_runtime.cpp.
References __kmp_acquire_bootstrap_lock(), __kmp_adjust_gtid_mode, __kmp_all_nth, __kmp_allocate, __kmp_allocate_cons_stack(), __kmp_allocate_team(), __kmp_avail_proc, __kmp_cg_max_nth, __kmp_create_worker(), __kmp_def_allocator, __kmp_enable_hidden_helper, __kmp_env_blocktime, __kmp_env_consistency_check, __kmp_expand_threads(), __kmp_fatal(), __kmp_forkjoin_lock, __kmp_get_global_icvs(), __kmp_gtid_from_tid(), __kmp_gtid_get_specific(), __kmp_gtid_mode, __kmp_gtid_set_specific(), __kmp_hidden_helper_threads_num, __kmp_init_gtid, __kmp_init_hidden_helper_threads, __kmp_init_random(), __kmp_initialize_bget(), __kmp_initialize_info(), __kmp_initialize_root(), __kmp_msg_null, __kmp_nth, __kmp_print_thread_storage_map(), __kmp_release_bootstrap_lock(), __kmp_root, __kmp_root_counter, __kmp_stksize, __kmp_storage_map, __kmp_threads, __kmp_threads_capacity, __kmp_tls_gtid_min, __kmp_tp_cached, __kmp_tp_capacity, __ompt_get_task_info_internal(), __ompt_get_thread_data_internal(), b, bs_forkjoin_barrier, bs_last_barrier, kmp_cg_root::cg_nthreads, kmp_cg_root::cg_root, kmp_cg_root::cg_thread_limit, ompt_callbacks_active_s::enabled, KA_TRACE, KF_TRACE, KMP_ASSERT, KMP_DEBUG_ASSERT, KMP_HNT, KMP_INIT_BARRIER_STATE, KMP_INIT_PARTITIONED_TIMERS, KMP_MB, KMP_MSG, KMP_SET_THREAD_STATE, ompt_callbacks, ompt_enabled, proc_bind_default, TCR_4, TCR_PTR, TCW_4, TCW_SYNC_PTR, TRUE, kmp_cg_root::up, and USE_NESTED_HOT_ARG.
Referenced by __kmp_do_serial_initialize(), __kmp_get_global_thread_id_reg(), and __kmp_hidden_helper_threads_initz_routine().
|
static |
Definition at line 4724 of file kmp_runtime.cpp.
References __kmp_init_implicit_task(), __kmp_init_parallel, copy_icvs(), FALSE, KF_TRACE, KMP_CHECK_UPDATE, KMP_DEBUG_ASSERT, KMP_GEN_TEAM_ID, loc, kmp_internal_control::nproc, kmp_team::t, and TCR_4.
Referenced by __kmp_allocate_team(), and __kmp_initialize_team().
|
static |
Definition at line 766 of file kmp_runtime.cpp.
References __kmp_avail_proc, __kmp_enable_hidden_helper, __kmp_expand_threads(), __kmp_get_gtid, __kmp_get_random(), __kmp_global, __kmp_hidden_helper_threads_num, __kmp_init_hidden_helper_threads, __kmp_init_serial, __kmp_max_nth, __kmp_msg(), __kmp_msg_null, __kmp_nth, __kmp_reserve_warn, __kmp_threads, __kmp_threads_capacity, __kmp_tp_cached, __kmp_tp_capacity, __kmpc_error(), dynamic_random, dynamic_thread_limit, get__dynamic_2, KC_TRACE, KMP_ASSERT, KMP_DEBUG_ASSERT, KMP_HNT, kmp_ms_warning, KMP_MSG, kmp_team::t, TCR_4, and TCR_PTR.
Referenced by __kmp_fork_call().
|
static |
Definition at line 4096 of file kmp_runtime.cpp.
References __kmp_free, __kmp_free_handle(), __kmp_free_team(), __kmp_nth, __kmp_reap_thread(), __kmp_tasking_mode, __kmp_wait_to_unref_task_teams(), __ompt_get_task_info_internal(), FALSE, i, KA_TRACE, KMP_DEBUG_ASSERT, KMP_UINTPTR_SPEC, ompt_callbacks, ompt_enabled, kmp_team::t, TCW_4, tskm_immediate_exec, and USE_NESTED_HOT_ARG.
Referenced by __kmp_unregister_root_current_thread().
void __kmp_reset_stats | ( | ) |
Definition at line 9391 of file kmp_runtime.cpp.
void __kmp_resize_dist_barrier | ( | kmp_team_t * | team, |
int | old_nthreads, | ||
int | new_nthreads | ||
) |
Definition at line 9159 of file kmp_runtime.cpp.
References __kmp_atomic_resume_64(), __kmp_barrier_release_pattern, __kmp_dflt_blocktime, bp_dist_bar, bs_forkjoin_barrier, CCAST, count, f(), flag, KMP_CPU_PAUSE, KMP_DEBUG_ASSERT, KMP_MAX_BLOCKTIME, KMP_MFENCE, and kmp_team::t.
Referenced by __kmp_allocate_team(), __kmp_fork_in_teams(), and __kmp_set_num_threads().
void __kmp_resume_if_soft_paused | ( | ) |
Definition at line 9085 of file kmp_runtime.cpp.
References __kmp_pause_status, __kmp_threads, __kmp_threads_capacity, __kmp_try_suspend_mx(), __kmp_unlock_suspend_mx(), bs_forkjoin_barrier, kmp_flag_native< PtrType, FlagType, Sleepable >::is_sleeping(), kmp_not_paused, kmp_soft_paused, and kmp_flag_64< Cancellable, Sleepable >::resume().
Referenced by __kmp_dispatch_init(), __kmp_dispatch_init_hierarchy(), __kmp_enter_single(), __kmp_fork_call(), __kmp_serialized_parallel(), __kmpc_barrier(), __kmpc_barrier_master(), __kmpc_barrier_master_nowait(), __kmpc_end_serialized_parallel(), __kmpc_masked(), __kmpc_master(), __kmpc_ordered(), __kmpc_reduce(), __kmpc_reduce_nowait(), __kmpc_sections_init(), KMP_API_NAME_GOMP_SINGLE_COPY_START(), and KMP_API_NAME_GOMP_SINGLE_START().
void __kmp_run_after_invoked_task | ( | int | gtid, |
int | tid, | ||
kmp_info_t * | this_thr, | ||
kmp_team_t * | team | ||
) |
Definition at line 7672 of file kmp_runtime.cpp.
References __kmp_env_consistency_check, __kmp_finish_implicit_task(), __kmp_pop_parallel(), and kmp_team::t.
Referenced by __kmp_invoke_task_func(), __kmp_invoke_teams_master(), and KMP_API_NAME_GOMP_PARALLEL_END().
void __kmp_run_before_invoked_task | ( | int | gtid, |
int | tid, | ||
kmp_info_t * | this_thr, | ||
kmp_team_t * | team | ||
) |
Definition at line 7647 of file kmp_runtime.cpp.
References __kmp_env_consistency_check, __kmp_push_parallel(), bs_forkjoin_barrier, KMP_CACHE_PREFETCH, KMP_DEBUG_ASSERT, KMP_MB, kmp_team::t, TCR_PTR, kmp_disp::th_disp_index, and kmp_disp::th_doacross_buf_idx.
Referenced by __kmp_GOMP_fork_call(), __kmp_invoke_task_func(), and __kmp_invoke_teams_master().
void __kmp_save_internal_controls | ( | kmp_info_t * | thread | ) |
Definition at line 2759 of file kmp_runtime.cpp.
References __kmp_allocate, copy_icvs(), kmp_internal_control::next, and kmp_internal_control::serial_nesting_level.
Referenced by __kmp_aux_set_blocktime(), __kmp_set_max_active_levels(), __kmp_set_num_threads(), __kmp_set_schedule(), FTN_SET_DYNAMIC(), FTN_SET_NESTED(), ompc_set_dynamic(), and ompc_set_nested().
|
inlinestatic |
Definition at line 1702 of file kmp_runtime.cpp.
References __kmp_alloc_argv_entries(), __kmp_invoke_microtask(), __kmp_teams_master(), __kmp_tid_from_gtid(), __kmpc_serialized_parallel(), __ompt_lw_taskteam_init(), __ompt_lw_taskteam_link(), __ompt_lw_taskteam_unlink(), args, ompt_callbacks_active_s::enabled, FALSE, fork_context_gnu, fork_context_intel, fork_context_last, ompt_task_info_t::frame, i, KA_TRACE, KMP_ALLOCA, KMP_ASSERT2, KMP_DEBUG_ASSERT, KMP_MB, KMP_SET_THREAD_STATE_BLOCK, KMP_TIME_PARTITIONED_BLOCK, kmp_va_deref, loc, microtask(), ompt_callbacks, ompt_enabled, OMPT_INVOKER, ompt_lw_taskteam_s::ompt_task_info, kmp_team::t, ompt_task_info_t::task_data, and TRUE.
Referenced by __kmp_fork_call().
Definition at line 7396 of file kmp_runtime.cpp.
References __kmp_acquire_bootstrap_lock(), __kmp_do_serial_initialize(), __kmp_init_serial, __kmp_initz_lock, and __kmp_release_bootstrap_lock().
Referenced by __kmp_atfork_child(), __kmp_aux_set_defaults(), __kmp_aux_set_stacksize(), __kmp_runtime_initialize(), __kmpc_error(), __kmpc_get_target_offload(), __ompt_force_initialization(), FTN_GET_AFFINITY_FORMAT(), FTN_GET_CANCELLATION(), FTN_GET_LIBRARY(), FTN_GET_MAX_TASK_PRIORITY(), FTN_GET_MAX_TEAMS(), FTN_GET_NUM_KNOWN_THREADS(), FTN_GET_STACKSIZE(), FTN_GET_STACKSIZE_S(), FTN_GET_TEAMS_THREAD_LIMIT(), FTN_GET_THREAD_LIMIT(), FTN_GET_WTICK(), FTN_GET_WTIME(), FTN_SET_AFFINITY_FORMAT(), FTN_SET_NUM_TEAMS(), FTN_SET_TEAMS_THREAD_LIMIT(), ompc_get_affinity_format(), and ompc_set_affinity_format().
Definition at line 1181 of file kmp_runtime.cpp.
References __kmp_acquire_bootstrap_lock(), __kmp_allocate, __kmp_allocate_team(), __kmp_aux_display_affinity(), __kmp_display_affinity, __kmp_env_consistency_check, __kmp_forkjoin_lock, __kmp_init_parallel, __kmp_nested_nth, __kmp_nested_proc_bind, __kmp_parallel_initialize(), __kmp_push_current_task_to_thread(), __kmp_push_parallel(), __kmp_push_task_team_node(), __kmp_release_bootstrap_lock(), __kmp_resume_if_soft_paused(), __kmp_threads, __kmp_tid_from_gtid(), __ompt_lw_taskteam_init(), __ompt_lw_taskteam_link(), kmp_nested_proc_bind_t::bind_types, cancel_noreq, copy_icvs(), ompt_callbacks_active_s::enabled, id::flags, ompt_task_info_t::frame, KC_TRACE, KF_TRACE, KMP_ASSERT, KMP_CHECK_UPDATE, KMP_DEBUG_ASSERT, KMP_IDENT_AUTOPAR, KMP_MB, level, loc, kmp_nested_nthreads_t::nth, ompt_callbacks, ompt_enabled, OMPT_GET_FRAME_ADDRESS, proc_bind_default, proc_bind_false, propagateFPControl, kmp_team::t, ompt_task_info_t::task_data, TCR_4, USE_NESTED_HOT_ARG, kmp_nested_nthreads_t::used, and kmp_nested_proc_bind_t::used.
Referenced by __kmpc_serialized_parallel().
Definition at line 2867 of file kmp_runtime.cpp.
References __kmp_init_serial, __kmp_save_internal_controls(), __kmp_threads, KF_TRACE, KMP_DEBUG_ASSERT, KMP_MAX_ACTIVE_LEVELS_LIMIT, KMP_WARNING, and set__max_active_levels.
Referenced by FTN_SET_MAX_ACTIVE_LEVELS(), and ompc_set_max_active_levels().
void __kmp_set_nesting_mode_threads | ( | ) |
Definition at line 9333 of file kmp_runtime.cpp.
References __kmp_avail_proc, __kmp_entry_gtid, __kmp_nested_nth, __kmp_nesting_mode, __kmp_nesting_mode_nlevels, __kmp_nesting_nth_level, __kmp_threads, __kmp_topology, get__max_active_levels, kmp_topology_t::get_count(), kmp_topology_t::get_depth(), kmp_topology_t::get_level(), kmp_topology_t::get_ratio(), i, KMP_HW_CORE, KMP_MAX_ACTIVE_LEVELS_LIMIT, level, loc, kmp_nested_nthreads_t::nth, set__max_active_levels, set__nproc, and kmp_nested_nthreads_t::used.
Referenced by __kmp_do_middle_initialize().
Definition at line 2928 of file kmp_runtime.cpp.
References __kmp_nteams.
Referenced by FTN_SET_NUM_TEAMS().
Definition at line 2791 of file kmp_runtime.cpp.
References __kmp_acquire_bootstrap_lock(), __kmp_add_threads_to_team(), __kmp_barrier_release_pattern, __kmp_forkjoin_lock, __kmp_free_thread(), __kmp_init_parallel, __kmp_init_serial, __kmp_max_nth, __kmp_release_bootstrap_lock(), __kmp_resize_dist_barrier(), __kmp_save_internal_controls(), __kmp_tasking_mode, __kmp_threads, bp_dist_bar, bs_forkjoin_barrier, f(), KF_TRACE, KMP_COUNT_VALUE, KMP_DEBUG_ASSERT, KMP_NESTED_HOT_TEAMS, set__nproc, kmp_team::t, and tskm_immediate_exec.
Referenced by FTN_SET_NUM_THREADS(), and ompc_set_num_threads().
void __kmp_set_schedule | ( | int | gtid, |
kmp_sched_t | kind, | ||
int | chunk | ||
) |
Definition at line 2944 of file kmp_runtime.cpp.
References __kmp_init_serial, __kmp_msg(), __kmp_msg_null, __kmp_save_internal_controls(), __kmp_sch_map, __kmp_sched_apply_mods_intkind(), __kmp_sched_without_mods(), __kmp_threads, KF_TRACE, KMP_DEBUG_ASSERT, KMP_DEFAULT_CHUNK, KMP_HNT, kmp_ms_warning, KMP_MSG, kmp_sch_static, kmp_sched_auto, kmp_sched_default, kmp_sched_lower, kmp_sched_lower_ext, kmp_sched_static, kmp_sched_upper, and kmp_sched_upper_std.
Referenced by FTN_SET_SCHEDULE(), and ompc_set_schedule().
Definition at line 7878 of file kmp_runtime.cpp.
References __kmp_threads, loc, severity_fatal, and severity_warning.
Referenced by __kmpc_push_num_threads_list_strict(), and __kmpc_push_num_threads_strict().
Definition at line 2934 of file kmp_runtime.cpp.
References __kmp_teams_thread_limit.
Referenced by FTN_SET_TEAMS_THREAD_LIMIT().
void __kmp_setup_icv_copy | ( | kmp_team_t * | team, |
int | new_nproc, | ||
kmp_internal_control_t * | new_icvs, | ||
ident_t * | loc | ||
) |
Definition at line 2648 of file kmp_barrier.cpp.
References __kmp_init_implicit_task(), __kmp_init_parallel, bs_forkjoin_barrier, copy_icvs(), f(), FALSE, KF_TRACE, KMP_DEBUG_ASSERT, KMP_TIME_DEVELOPER_PARTITIONED_BLOCK, loc, ngo_load, ngo_store_icvs, ngo_sync, kmp_internal_control::nproc, kmp_team::t, and TCR_4.
Referenced by __kmp_fork_call().
void __kmp_soft_pause | ( | ) |
Definition at line 9075 of file kmp_runtime.cpp.
References __kmp_pause_status, and kmp_soft_paused.
Referenced by __kmp_pause_resource().
Definition at line 7775 of file kmp_runtime.cpp.
References __kmp_allocate, __kmp_fork_call(), __kmp_invoke_task_func(), __kmp_join_call(), __kmp_threads, __kmp_tid_from_gtid(), kmp_cg_root::cg_nthreads, kmp_cg_root::cg_root, kmp_cg_root::cg_thread_limit, fork_context_intel, KA_TRACE, KMP_DEBUG_ASSERT, loc, kmp_team::t, kmp_cg_root::up, and VOLATILE_CAST.
Referenced by __kmp_allocate_team(), __kmp_fork_call(), __kmp_fork_team_threads(), __kmp_free_team(), __kmp_hierarchical_barrier_release(), __kmp_invoke_teams_master(), __kmp_is_fork_in_teams(), __kmp_join_call(), __kmp_serial_fork_call(), and __kmpc_fork_teams().
Definition at line 6957 of file kmp_runtime.cpp.
References __kmp_env_get(), __kmp_env_unset(), __kmp_reg_status_name(), __kmp_registration_flag, __kmp_registration_str, __kmp_str_format(), KMP_DEBUG_ASSERT, KMP_INTERNAL_FREE, name, and value.
Referenced by __kmp_abort_process(), __kmp_internal_end(), and __kmp_internal_end_library().
Definition at line 4189 of file kmp_runtime.cpp.
References __kmp_acquire_bootstrap_lock(), __kmp_forkjoin_lock, __kmp_global, __kmp_init_serial, __kmp_release_bootstrap_lock(), __kmp_reset_root(), __kmp_root, __kmp_task_team_wait(), __kmp_threads, FALSE, KA_TRACE, KC_TRACE, KMP_ASSERT, KMP_DEBUG_ASSERT, KMP_MB, KMP_UBER_GTID(), TCR_4, kmp_task_team::tt, kmp_base_task_team::tt_found_proxy_tasks, kmp_base_task_team::tt_hidden_helper_task_encountered, and USE_ITT_BUILD_ARG.
Referenced by __kmp_internal_end_library(), and __kmp_internal_end_thread().
void __kmp_user_set_library | ( | enum library_type | arg | ) |
Definition at line 8427 of file kmp_runtime.cpp.
References __kmp_aux_set_library(), __kmp_dflt_team_nth, __kmp_dflt_team_nth_ub, __kmp_entry_gtid, __kmp_threads, KA_TRACE, KMP_FATAL, KMP_WARNING, library_serial, library_throughput, library_turnaround, and set__nproc.
Referenced by FTN_SET_LIBRARY(), FTN_SET_LIBRARY_SERIAL(), FTN_SET_LIBRARY_THROUGHPUT(), FTN_SET_LIBRARY_TURNAROUND(), and kmpc_set_library().
Definition at line 440 of file kmp_runtime.cpp.
References __kmp_acquire_bootstrap_lock(), __kmp_generate_warnings, __kmp_release_bootstrap_lock(), __kmp_stdio_lock, __kmp_vprintf(), kmp_err, KMP_SNPRINTF, kmp_warnings_off, and MAX_MESSAGE.
KMP_BUILD_ASSERT | ( | sizeof(enum sched_type) | = =sizeof(int) | ) |
KMP_BUILD_ASSERT | ( | sizeof(kmp_sched_t) | = =sizeof(int) | ) |
|
static |
Definition at line 8617 of file kmp_runtime.cpp.
Referenced by __kmp_aux_capture_affinity_field().
Definition at line 9395 of file kmp_runtime.cpp.
Referenced by __kmp_fork_in_teams().
Definition at line 9254 of file kmp_runtime.cpp.
Referenced by __kmp_initial_threads_capacity(), __kmp_register_root(), __kmp_reserve_threads(), __kmp_stg_parse_num_hidden_helper_threads(), __kmp_stg_parse_use_hidden_helper(), __kmp_stg_print_use_hidden_helper(), __kmp_task_alloc(), __kmp_task_reduction_fini(), __kmp_task_reduction_init(), __kmpc_omp_target_task_alloc(), and __kmpc_omp_taskwait_template().
kmp_info_t* __kmp_hidden_helper_main_thread |
Definition at line 9247 of file kmp_runtime.cpp.
Referenced by __kmp_hidden_helper_threads_initz_routine(), and __kmp_task_team_setup().
kmp_info_t** __kmp_hidden_helper_threads |
Definition at line 9246 of file kmp_runtime.cpp.
Referenced by __kmp_hidden_helper_threads_initz_routine(), and __kmp_task_team_setup().
kmp_int32 __kmp_hidden_helper_threads_num = 0 |
Definition at line 9253 of file kmp_runtime.cpp.
Referenced by __kmp_adjust_gtid_for_hidden_helpers(), __kmp_allocate_thread(), __kmp_hidden_helper_threads_initz_routine(), __kmp_initial_threads_capacity(), __kmp_register_root(), __kmp_reserve_threads(), __kmp_stg_parse_num_hidden_helper_threads(), __kmp_stg_print_num_hidden_helper_threads(), and get_num_hidden_helper_threads().
Definition at line 9394 of file kmp_runtime.cpp.
|
static |
Definition at line 3635 of file kmp_runtime.cpp.
Referenced by __kmp_init_random().
|
static |
Definition at line 6717 of file kmp_runtime.cpp.
Referenced by __kmp_register_library_startup(), and __kmp_unregister_library().
|
static |
Definition at line 6719 of file kmp_runtime.cpp.
Referenced by __kmp_register_library_startup(), and __kmp_unregister_library().
kmp_info_t* __kmp_thread_pool_insert_pt = NULL |
Definition at line 110 of file kmp_runtime.cpp.
Referenced by __kmp_allocate_thread(), __kmp_atfork_child(), __kmp_do_serial_initialize(), __kmp_free_thread(), and __kmp_internal_end().
std::atomic<kmp_int32> __kmp_unexecuted_hidden_helper_tasks |
Definition at line 9248 of file kmp_runtime.cpp.
Referenced by __kmp_hidden_helper_initialize(), __kmp_task_alloc(), __kmp_task_finish(), and __kmp_wait_template().
char const __kmp_version_omp_api[] |
Definition at line 66 of file kmp_runtime.cpp.
Referenced by __kmp_print_version_1().