Branch: refs/heads/master Home: https://github.com/STEllAR-GROUP/hpx Commit: 1c87f51677defd26be942de52f58fac29ca4b442 https://github.com/STEllAR-GROUP/hpx/commit/1c87f51677defd26be942de52f58fac29ca4b442 Author: Hartmut Kaiser <hartmut.kai...@gmail.com> Date: 2025-07-01 (Tue, 01 Jul 2025)
Changed paths: M .circleci/config.yml R .github/bors.toml R .github/workflows/linux_bors.yml M .github/workflows/linux_crosscompile_arm_eve_sve_release.yml M .github/workflows/linux_debug.yml M .github/workflows/linux_debug_fetch_boost.yml M .github/workflows/linux_release_fetchcontent.yml M .github/workflows/linux_release_static.yml M .github/workflows/linux_sanitizers.yml M .github/workflows/linux_with_bench_test.yml M .github/workflows/linux_with_nanobench_test.yml R .github/workflows/windows_debug_vs2019.yml R .github/workflows/windows_release_2019.yml M .github/workflows/windows_release_gcc_mingw.yml M .jenkins/lsu/env-clang-16.sh M .jenkins/lsu/env-clang-17-apex.sh M .jenkins/lsu/env-clang-18.sh M .jenkins/lsu/env-clang-19.sh M .jenkins/lsu/env-clang-20.sh M .jenkins/lsu/env-gcc-12-cuda-12-dgx.sh M .jenkins/lsu/env-gcc-12-cuda-12.sh M .jenkins/lsu/env-gcc-13.sh M .jenkins/lsu/env-gcc-14.sh M .jenkins/lsu/env-gcc-15.sh M .jenkins/lsu/env-hipcc.sh M CMakeLists.txt M cmake/HPX_CheckCXXStandard.cmake M cmake/HPX_SetupDatapar.cmake M cmake/HPX_SetupStdexec.cmake M docs/sphinx/manual/building_hpx.rst M docs/sphinx/manual/troubleshooting.rst M tools/docker/Dockerfile Log Message: ----------- Removing support for C++17 - switch CIs to C++20 and C++23 - remove obsolete github builders Commit: 67b5da45d49f26f35337d323b000f491df8aa0ae https://github.com/STEllAR-GROUP/hpx/commit/67b5da45d49f26f35337d323b000f491df8aa0ae Author: Hartmut Kaiser <hartmut.kai...@gmail.com> Date: 2025-07-01 (Tue, 01 Jul 2025) Changed paths: M docs/sphinx/manual/prerequisites.rst M examples/interpolate1d/interpolate1d/dimension.cpp M examples/jacobi/jacobi_component/grid.hpp M examples/jacobi/jacobi_component/row.hpp M examples/jacobi/jacobi_component/row_range.hpp M examples/jacobi/jacobi_component/server/stencil_iterator.cpp M examples/jacobi/jacobi_component/stencil_iterator.hpp M examples/jacobi_smp/jacobi_hpx.cpp M examples/jacobi_smp/jacobi_nonuniform_hpx.cpp M examples/nqueen/nqueen_client.cpp M examples/quickstart/component_with_custom_heap.cpp M examples/quickstart/interest_calculator.cpp M examples/sheneos/sheneos/dimension.cpp M examples/sheneos/sheneos/interpolator.cpp M examples/sheneos/sheneos/server/configuration.cpp M examples/transpose/transpose_await.cpp M examples/transpose/transpose_block.cpp M examples/transpose/transpose_serial.cpp M examples/transpose/transpose_serial_block.cpp M examples/transpose/transpose_serial_vector.cpp M examples/transpose/transpose_smp.cpp M examples/transpose/transpose_smp_block.cpp M examples/tuplespace/small_big_object.hpp M libs/core/affinity/src/affinity_data.cpp M libs/core/affinity/src/parse_affinity_options.cpp M libs/core/algorithms/include/hpx/parallel/algorithms/detail/equal.hpp M libs/core/algorithms/include/hpx/parallel/algorithms/detail/find.hpp M libs/core/algorithms/include/hpx/parallel/algorithms/detail/is_sorted.hpp M libs/core/algorithms/include/hpx/parallel/algorithms/detail/reduce_deterministic.hpp M libs/core/algorithms/include/hpx/parallel/algorithms/detail/rfa.hpp M libs/core/algorithms/include/hpx/parallel/algorithms/detail/sample_sort.hpp M libs/core/algorithms/include/hpx/parallel/algorithms/detail/set_operation.hpp M libs/core/algorithms/include/hpx/parallel/algorithms/for_each.hpp M libs/core/algorithms/include/hpx/parallel/algorithms/lexicographical_compare.hpp M libs/core/algorithms/include/hpx/parallel/algorithms/mismatch.hpp M libs/core/algorithms/include/hpx/parallel/algorithms/partition.hpp M libs/core/algorithms/include/hpx/parallel/algorithms/reverse.hpp M libs/core/algorithms/include/hpx/parallel/algorithms/rotate.hpp M libs/core/algorithms/include/hpx/parallel/algorithms/set_difference.hpp M libs/core/algorithms/include/hpx/parallel/algorithms/set_intersection.hpp M libs/core/algorithms/include/hpx/parallel/algorithms/set_symmetric_difference.hpp M libs/core/algorithms/include/hpx/parallel/algorithms/shift_right.hpp M libs/core/algorithms/include/hpx/parallel/algorithms/sort.hpp M libs/core/algorithms/include/hpx/parallel/algorithms/stable_sort.hpp M libs/core/algorithms/include/hpx/parallel/algorithms/swap_ranges.hpp M libs/core/algorithms/include/hpx/parallel/algorithms/uninitialized_copy.hpp M libs/core/algorithms/include/hpx/parallel/algorithms/uninitialized_default_construct.hpp M libs/core/algorithms/include/hpx/parallel/algorithms/uninitialized_fill.hpp M libs/core/algorithms/include/hpx/parallel/algorithms/uninitialized_move.hpp M libs/core/algorithms/include/hpx/parallel/algorithms/uninitialized_relocate.hpp M libs/core/algorithms/include/hpx/parallel/algorithms/uninitialized_value_construct.hpp M libs/core/algorithms/include/hpx/parallel/container_algorithms/nth_element.hpp M libs/core/algorithms/include/hpx/parallel/container_algorithms/transform.hpp M libs/core/algorithms/include/hpx/parallel/datapar/generate.hpp M libs/core/algorithms/include/hpx/parallel/datapar/transform_loop.hpp M libs/core/algorithms/include/hpx/parallel/unseq/reduce_helpers.hpp M libs/core/algorithms/include/hpx/parallel/util/detail/chunk_size_iterator.hpp M libs/core/algorithms/include/hpx/parallel/util/loop.hpp M libs/core/algorithms/include/hpx/parallel/util/partitioner.hpp M libs/core/algorithms/include/hpx/parallel/util/result_types.hpp M libs/core/algorithms/include/hpx/parallel/util/transfer.hpp M libs/core/algorithms/include/hpx/parallel/util/transform_loop.hpp M libs/core/algorithms/tests/performance/benchmark_partition.cpp M libs/core/algorithms/tests/performance/benchmark_scan_algorithms.cpp M libs/core/algorithms/tests/regressions/set_operations_3442.cpp M libs/core/algorithms/tests/regressions/stable_merge_2964.cpp M libs/core/algorithms/tests/unit/algorithms/exclusive_scan_validate.cpp M libs/core/algorithms/tests/unit/algorithms/for_loop_reduction.cpp M libs/core/algorithms/tests/unit/algorithms/for_loop_reduction_async.cpp M libs/core/algorithms/tests/unit/algorithms/reduce_by_key.cpp M libs/core/algorithms/tests/unit/algorithms/rotate.cpp M libs/core/algorithms/tests/unit/algorithms/rotate_copy.cpp M libs/core/algorithms/tests/unit/algorithms/shift_left.cpp M libs/core/algorithms/tests/unit/algorithms/shift_right.cpp M libs/core/algorithms/tests/unit/algorithms/sort_tests.hpp M libs/core/algorithms/tests/unit/algorithms/stable_sort_tests.hpp M libs/core/algorithms/tests/unit/algorithms/uninitialized_relocate.cpp M libs/core/algorithms/tests/unit/algorithms/uninitialized_relocate_backward.cpp M libs/core/algorithms/tests/unit/algorithms/uninitialized_relocaten.cpp M libs/core/algorithms/tests/unit/block/spmd_block.cpp M libs/core/algorithms/tests/unit/block/task_group.cpp M libs/core/algorithms/tests/unit/container_algorithms/for_loop_reduction_async_range.cpp M libs/core/algorithms/tests/unit/container_algorithms/for_loop_reduction_range.cpp M libs/core/algorithms/tests/unit/container_algorithms/inplace_merge_range.cpp M libs/core/algorithms/tests/unit/container_algorithms/merge_range.cpp M libs/core/algorithms/tests/unit/container_algorithms/rotate_copy_range.cpp M libs/core/algorithms/tests/unit/container_algorithms/rotate_range.cpp M libs/core/algorithms/tests/unit/container_algorithms/shift_right_range.cpp M libs/core/algorithms/tests/unit/container_algorithms/sort_range_tests.hpp M libs/core/algorithms/tests/unit/container_algorithms/stable_sort_range_tests.hpp M libs/core/allocator_support/include/hpx/allocator_support/traits/is_allocator.hpp M libs/core/assertion/include/hpx/assertion/current_function.hpp M libs/core/async_cuda/include/hpx/async_cuda/cuda_future.hpp M libs/core/async_cuda/tests/unit/cublas_matmul.cpp M libs/core/async_cuda/tests/unit/cuda_future.cpp M libs/core/async_sycl/include/hpx/async_sycl/sycl_future.hpp M libs/core/async_sycl/tests/unit/sycl_vector_add_concurrent_executors.cpp M libs/core/batch_environments/src/slurm_environment.cpp M libs/core/cache/include/hpx/cache/local_cache.hpp M libs/core/command_line_handling_local/src/command_line_handling_local.cpp M libs/core/command_line_handling_local/src/parse_command_line_local.cpp M libs/core/compute_local/include/hpx/compute_local/host/numa_binding_allocator.hpp M libs/core/compute_local/src/get_host_targets.cpp M libs/core/compute_local/src/numa_domains.cpp M libs/core/compute_local/tests/regressions/parallel_fill_4132.cpp M libs/core/compute_local/tests/unit/allocator_binder_linear.hpp M libs/core/compute_local/tests/unit/allocator_binder_matrix.hpp M libs/core/concurrency/include/hpx/concurrency/stack.hpp M libs/core/concurrency/tests/unit/contiguous_index_queue.cpp M libs/core/concurrency/tests/unit/non_contiguous_index_queue.cpp M libs/core/datastructures/include/hpx/datastructures/detail/dynamic_bitset.hpp M libs/core/datastructures/include/hpx/datastructures/detail/optional.hpp M libs/core/datastructures/include/hpx/datastructures/detail/small_vector.hpp M libs/core/datastructures/tests/unit/bitset_test.hpp M libs/core/datastructures/tests/unit/dynamic_bitset4.cpp M libs/core/datastructures/tests/unit/small_big_object.hpp M libs/core/datastructures/tests/unit/small_vector.cpp M libs/core/datastructures/tests/unit/tuple.cpp M libs/core/debugging/src/print.cpp M libs/core/execution/include/hpx/execution/algorithms/detail/predicates.hpp M libs/core/execution/include/hpx/execution/algorithms/make_future.hpp M libs/core/execution/include/hpx/execution/executors/auto_chunk_size.hpp M libs/core/execution/include/hpx/execution/executors/execution.hpp M libs/core/execution/include/hpx/execution/executors/guided_chunk_size.hpp M libs/core/execution/include/hpx/execution/executors/num_cores.hpp M libs/core/execution/include/hpx/execution/executors/persistent_auto_chunk_size.hpp M libs/core/execution_base/include/hpx/execution_base/completion_signatures.hpp M libs/core/execution_base/tests/include/algorithm_test_utils.hpp M libs/core/execution_base/tests/include/coroutine_task.hpp M libs/core/execution_base/tests/unit/completion_signatures.cpp M libs/core/execution_base/tests/unit/coroutine_utils.cpp M libs/core/execution_base/tests/unit/execution_context.cpp M libs/core/executors/include/hpx/executors/detail/hierarchical_spawning.hpp M libs/core/executors/include/hpx/executors/detail/index_queue_spawning.hpp M libs/core/executors/include/hpx/executors/thread_pool_scheduler_bulk.hpp M libs/core/executors/tests/unit/created_executor.cpp M libs/core/executors/tests/unit/standalone_thread_pool_executor.cpp M libs/core/executors/tests/unit/thread_pool_scheduler.cpp M libs/core/format/src/format.cpp M libs/core/functional/include/hpx/functional/detail/basic_function.hpp M libs/core/functional/include/hpx/functional/function_ref.hpp M libs/core/functional/include/hpx/functional/mem_fn.hpp M libs/core/functional/tests/unit/function_args.cpp M libs/core/functional/tests/unit/function_object_size.cpp M libs/core/functional/tests/unit/is_invocable.cpp M libs/core/gasnet_base/src/gasnet_environment.cpp M libs/core/ini/src/ini.cpp M libs/core/init_runtime_local/src/init_runtime_local.cpp M libs/core/iterator_support/tests/unit/iterator_facade.cpp M libs/core/iterator_support/tests/unit/transform_iterator2.cpp M libs/core/lci_base/include/hpx/lci_base/lci_environment.hpp M libs/core/memory/tests/unit/intrusive_ptr_polymorphic.cpp M libs/core/memory/tests/unit/intrusive_ptr_polymorphic_nonintrusive.cpp M libs/core/memory/tests/unit/serialization_intrusive_ptr.cpp M libs/core/pack_traversal/include/hpx/pack_traversal/unwrap.hpp M libs/core/plugin/include/hpx/plugin/export_plugin.hpp M libs/core/plugin/include/hpx/plugin/virtual_constructor.hpp M libs/core/program_options/include/hpx/program_options/errors.hpp M libs/core/program_options/include/hpx/program_options/value_semantic.hpp M libs/core/program_options/src/cmdline.cpp M libs/core/program_options/src/options_description.cpp M libs/core/program_options/src/parsers.cpp M libs/core/program_options/src/split.cpp M libs/core/resiliency/include/hpx/resiliency/async_replicate.hpp M libs/core/resiliency/include/hpx/resiliency/replay_executor.hpp M libs/core/resiliency/include/hpx/resiliency/replicate_executor.hpp M libs/core/resource_partitioner/tests/unit/cross_pool_injection.cpp M libs/core/resource_partitioner/tests/unit/named_pool_executor.cpp M libs/core/resource_partitioner/tests/unit/resource_partitioner_info.cpp M libs/core/resource_partitioner/tests/unit/shutdown_suspended_pus.cpp M libs/core/resource_partitioner/tests/unit/suspend_disabled.cpp M libs/core/resource_partitioner/tests/unit/suspend_pool.cpp M libs/core/resource_partitioner/tests/unit/suspend_pool_external.cpp M libs/core/resource_partitioner/tests/unit/suspend_runtime.cpp M libs/core/resource_partitioner/tests/unit/suspend_thread.cpp M libs/core/resource_partitioner/tests/unit/suspend_thread_external.cpp M libs/core/resource_partitioner/tests/unit/suspend_thread_timed.cpp M libs/core/resource_partitioner/tests/unit/used_pus.cpp M libs/core/runtime_configuration/include/hpx/runtime_configuration/static_factory_data.hpp M libs/core/runtime_configuration/src/runtime_mode.cpp M libs/core/schedulers/include/hpx/schedulers/local_priority_queue_scheduler.hpp M libs/core/schedulers/include/hpx/schedulers/local_queue_scheduler.hpp M libs/core/schedulers/include/hpx/schedulers/queue_holder_numa.hpp M libs/core/schedulers/include/hpx/schedulers/shared_priority_queue_scheduler.hpp M libs/core/schedulers/include/hpx/schedulers/static_queue_scheduler.hpp M libs/core/schedulers/include/hpx/schedulers/thread_queue.hpp M libs/core/serialization/include/hpx/serialization/detail/pointer.hpp M libs/core/serialization/tests/regressions/buffer_overrun_2839.cpp M libs/core/serialization/tests/regressions/serialization_unsigned_buffer.cpp M libs/core/serialization/tests/unit/polymorphic/polymorphic_nonintrusive.cpp M libs/core/serialization/tests/unit/polymorphic/polymorphic_nonintrusive_abstract.cpp M libs/core/serialization/tests/unit/polymorphic/polymorphic_pointer.cpp M libs/core/serialization/tests/unit/polymorphic/polymorphic_reference.cpp M libs/core/serialization/tests/unit/polymorphic/polymorphic_semiintrusive_template.cpp M libs/core/serialization/tests/unit/polymorphic/polymorphic_template.cpp M libs/core/serialization/tests/unit/polymorphic/smart_ptr_polymorphic.cpp M libs/core/serialization/tests/unit/polymorphic/smart_ptr_polymorphic_nonintrusive.cpp M libs/core/serialization/tests/unit/serialization_array.cpp M libs/core/serialization/tests/unit/serialization_builtins.cpp M libs/core/serialization/tests/unit/serialization_complex.cpp M libs/core/serialization/tests/unit/serialization_custom_constructor.cpp M libs/core/serialization/tests/unit/serialization_deque.cpp M libs/core/serialization/tests/unit/serialization_list.cpp M libs/core/serialization/tests/unit/serialization_map.cpp M libs/core/serialization/tests/unit/serialization_set.cpp M libs/core/serialization/tests/unit/serialization_simple.cpp M libs/core/serialization/tests/unit/serialization_smart_ptr.cpp M libs/core/serialization/tests/unit/serialization_std_variant.cpp M libs/core/serialization/tests/unit/serialization_unordered_map.cpp M libs/core/serialization/tests/unit/serialization_valarray.cpp M libs/core/serialization/tests/unit/serialization_vector.cpp M libs/core/serialization/tests/unit/serialize_with_incompatible_signature.cpp M libs/core/serialization/tests/unit/small_big_object.hpp M libs/core/string_util/include/hpx/string_util/token_functions.hpp M libs/core/synchronization/src/detail/sliding_semaphore.cpp M libs/core/synchronization/src/stop_token.cpp M libs/core/tag_invoke/include/hpx/functional/detail/invoke.hpp M libs/core/tag_invoke/include/hpx/functional/invoke_result.hpp M libs/core/thread_pools/include/hpx/thread_pools/scheduled_thread_pool.hpp M libs/core/threading/tests/unit/condition_variable2.cpp M libs/core/threading/tests/unit/jthread1.cpp M libs/core/threading_base/src/scheduler_base.cpp M libs/core/threading_base/src/thread_pool_base.cpp M libs/core/threading_base/tests/regressions/thread_stacksize_current.cpp M libs/core/threadmanager/src/threadmanager.cpp M libs/core/timing/include/hpx/timing/high_resolution_clock.hpp M libs/core/timing/include/hpx/timing/high_resolution_timer.hpp M libs/core/topology/src/topology.cpp M libs/core/type_support/include/hpx/type_support/construct_at.hpp M libs/core/type_support/include/hpx/type_support/generator.hpp M libs/core/type_support/tests/unit/fail_relocate_at.cpp M libs/core/type_support/tests/unit/fail_uninitialized_relocate.cpp M libs/core/type_support/tests/unit/is_trivially_relocatable.cpp M libs/full/actions_base/include/hpx/actions_base/component_action.hpp M libs/full/agas_base/src/server/locality_namespace_server.cpp M libs/full/async_distributed/include/hpx/async_distributed/detail/post_implementations.hpp M libs/full/async_distributed/include/hpx/async_distributed/packaged_action.hpp M libs/full/async_distributed/tests/regressions/components/movable_objects.cpp M libs/full/async_distributed/tests/regressions/return_non_default_constructible_2847.cpp M libs/full/collectives/include/hpx/collectives/broadcast_direct.hpp M libs/full/collectives/include/hpx/collectives/reduce_direct.hpp M libs/full/collectives/include/hpx/collectives/spmd_block.hpp M libs/full/collectives/tests/performance/osu/broadcast.hpp M libs/full/collectives/tests/performance/osu/osu_coll.hpp M libs/full/collectives/tests/performance/osu/osu_multi_lat.cpp M libs/full/collectives/tests/unit/global_spmd_block.cpp M libs/full/command_line_handling/src/command_line_handling.cpp M libs/full/components_base/include/hpx/components_base/server/managed_component_base.hpp M libs/full/components_base/src/generate_unique_ids.cpp M libs/full/compute/include/hpx/compute/detail/target_distribution_policy.hpp M libs/full/distribution_policies/include/hpx/distribution_policies/container_distribution_policy.hpp M libs/full/distribution_policies/src/binpacking_distribution_policy.cpp M libs/full/init_runtime/src/hpx_init.cpp M libs/full/init_runtime/src/init_logging.cpp M libs/full/naming/src/credit_handling.cpp M libs/full/parcelport_lci/include/hpx/parcelport_lci/completion_manager_base.hpp M libs/full/parcelport_lci/src/parcelport_lci.cpp M libs/full/parcelport_tcp/src/connection_handler_tcp.cpp M libs/full/parcelset/include/hpx/parcelset/decode_parcels.hpp M libs/full/parcelset/include/hpx/parcelset/encode_parcels.hpp M libs/full/parcelset/tests/regressions/very_big_tchunk.cpp M libs/full/parcelset_base/include/hpx/parcelset_base/detail/gatherer.hpp M libs/full/performance_counters/include/hpx/performance_counters/counters.hpp M libs/full/performance_counters/include/hpx/performance_counters/counters_fwd.hpp M libs/full/performance_counters/src/locality_namespace_counters.cpp M libs/full/performance_counters/src/primary_namespace_counters.cpp M libs/full/performance_counters/src/registry.cpp M libs/full/performance_counters/src/server/arithmetics_counter_extended.cpp M libs/full/performance_counters/src/server/statistics_counter.cpp M libs/full/performance_counters/src/threadmanager_counter_types.cpp M libs/full/resiliency_distributed/include/hpx/resiliency_distributed/async_replicate_distributed.hpp M libs/full/runtime_distributed/src/big_boot_barrier.cpp M libs/full/segmented_algorithms/include/hpx/parallel/segmented_algorithms/count.hpp M libs/full/segmented_algorithms/include/hpx/parallel/segmented_algorithms/detail/scan.hpp M libs/full/segmented_algorithms/include/hpx/parallel/segmented_algorithms/exclusive_scan.hpp M libs/full/segmented_algorithms/include/hpx/parallel/segmented_algorithms/fill.hpp M libs/full/segmented_algorithms/include/hpx/parallel/segmented_algorithms/find.hpp M libs/full/segmented_algorithms/include/hpx/parallel/segmented_algorithms/generate.hpp M libs/full/segmented_algorithms/include/hpx/parallel/segmented_algorithms/inclusive_scan.hpp M libs/full/segmented_algorithms/include/hpx/parallel/segmented_algorithms/minmax.hpp M libs/full/segmented_algorithms/include/hpx/parallel/segmented_algorithms/reduce.hpp M libs/full/segmented_algorithms/include/hpx/parallel/segmented_algorithms/transform.hpp M libs/full/segmented_algorithms/include/hpx/parallel/segmented_algorithms/transform_reduce.hpp M libs/full/segmented_algorithms/tests/unit/partitioned_vector_iter.cpp M tests/performance/local/async_overheads.cpp M tests/performance/local/htts_v2/htts2_payload_precision.cpp M tests/performance/local/nonconcurrent_fifo_overhead.cpp M tests/performance/local/nonconcurrent_lifo_overhead.cpp M tests/performance/local/qthreads_homogeneous_timed_task_spawn.cpp M tests/performance/local/stream.cpp M tests/performance/local/stream_report.cpp M tests/performance/network/network_storage/network_storage.cpp M tests/performance/network/network_storage/simple_profiler.hpp Log Message: ----------- Reformat using clang-format-20 Commit: 646b6be8ca34eddd551840594dc4261c4e5f4a84 https://github.com/STEllAR-GROUP/hpx/commit/646b6be8ca34eddd551840594dc4261c4e5f4a84 Author: Hartmut Kaiser <hartmut.kai...@gmail.com> Date: 2025-07-04 (Fri, 04 Jul 2025) Changed paths: M .circleci/config.yml M .clang-tidy M .jenkins/lsu/entry.sh M .jenkins/lsu/env-hipcc.sh M components/containers/partitioned_vector/include/hpx/components/containers/coarray/coarray.hpp M components/containers/partitioned_vector/tests/unit/coarray.cpp M components/containers/partitioned_vector/tests/unit/coarray_all_reduce.cpp M components/iostreams/tests/regressions/lost_output_2236.cpp M components/parcel_plugins/coalescing/src/coalescing_message_handler.cpp M components/process/include/hpx/components/process/util/posix/initializers/set_cmd_line.hpp M examples/1d_stencil/1d_stencil_3.cpp M examples/1d_stencil/1d_stencil_3_omp.cpp M examples/1d_stencil/1d_stencil_4.cpp M examples/1d_stencil/1d_stencil_4_parallel.cpp M examples/1d_stencil/1d_stencil_4_repart.cpp M examples/1d_stencil/1d_stencil_4_throttle.cpp M examples/1d_stencil/1d_stencil_5.cpp M examples/1d_stencil/1d_stencil_6.cpp M examples/1d_stencil/1d_stencil_7.cpp M examples/1d_stencil/1d_stencil_8.cpp M examples/1d_stencil/print_time_results.hpp M examples/balancing/os_thread_num.cpp M examples/heartbeat/heartbeat.cpp M examples/jacobi/jacobi_component/row_range.hpp M examples/jacobi/jacobi_component/server/row.hpp M examples/jacobi_smp/jacobi_hpx.cpp M examples/performance_counters/sine/server/sine.cpp M examples/performance_counters/sine/sine.cpp M examples/quickstart/1d_wave_equation.cpp M examples/quickstart/component_with_custom_heap.cpp M examples/quickstart/data_actions.cpp M examples/quickstart/fibonacci_await.cpp M examples/quickstart/file_serialization.cpp M examples/quickstart/local_channel.cpp M examples/quickstart/partitioned_vector_spmd_foreach.cpp M examples/quickstart/pingpong.cpp M examples/quickstart/zerocopy_rdma.cpp M examples/throttle/throttle/server/throttle.cpp M examples/transpose/transpose_block.cpp M examples/transpose/transpose_serial.cpp M examples/transpose/transpose_serial_block.cpp M examples/transpose/transpose_serial_vector.cpp M examples/transpose/transpose_smp.cpp M examples/transpose/transpose_smp_block.cpp M libs/core/algorithms/include/hpx/parallel/algorithms/copy.hpp M libs/core/algorithms/include/hpx/parallel/algorithms/detail/dispatch.hpp M libs/core/algorithms/include/hpx/parallel/algorithms/detail/rfa.hpp M libs/core/algorithms/include/hpx/parallel/algorithms/detail/sample_sort.hpp M libs/core/algorithms/include/hpx/parallel/algorithms/generate.hpp M libs/core/algorithms/include/hpx/parallel/algorithms/is_partitioned.hpp M libs/core/algorithms/include/hpx/parallel/algorithms/merge.hpp M libs/core/algorithms/include/hpx/parallel/algorithms/minmax.hpp M libs/core/algorithms/include/hpx/parallel/algorithms/partition.hpp M libs/core/algorithms/include/hpx/parallel/algorithms/reverse.hpp M libs/core/algorithms/include/hpx/parallel/algorithms/unique.hpp M libs/core/algorithms/include/hpx/parallel/container_algorithms/adjacent_find.hpp M libs/core/algorithms/include/hpx/parallel/task_block.hpp M libs/core/algorithms/include/hpx/parallel/util/detail/algorithm_result.hpp M libs/core/algorithms/include/hpx/parallel/util/detail/sender_util.hpp M libs/core/algorithms/include/hpx/parallel/util/foreach_partitioner.hpp M libs/core/algorithms/include/hpx/parallel/util/partitioner.hpp M libs/core/algorithms/include/hpx/parallel/util/partitioner_with_cleanup.hpp M libs/core/algorithms/include/hpx/parallel/util/scan_partitioner.hpp M libs/core/algorithms/tests/performance/benchmark_inplace_merge.cpp M libs/core/algorithms/tests/performance/benchmark_is_heap.cpp M libs/core/algorithms/tests/performance/benchmark_is_heap_until.cpp M libs/core/algorithms/tests/performance/benchmark_merge.cpp M libs/core/algorithms/tests/performance/benchmark_nth_element.cpp M libs/core/algorithms/tests/performance/benchmark_nth_element_parallel.cpp M libs/core/algorithms/tests/performance/benchmark_partial_sort.cpp M libs/core/algorithms/tests/performance/benchmark_partial_sort_parallel.cpp M libs/core/algorithms/tests/performance/benchmark_partition.cpp M libs/core/algorithms/tests/performance/benchmark_partition_copy.cpp M libs/core/algorithms/tests/performance/benchmark_remove.cpp M libs/core/algorithms/tests/performance/benchmark_remove_if.cpp M libs/core/algorithms/tests/performance/benchmark_unique.cpp M libs/core/algorithms/tests/performance/benchmark_unique_copy.cpp M libs/core/algorithms/tests/performance/foreach_scaling.cpp M libs/core/algorithms/tests/performance/transform_reduce_scaling.cpp M libs/core/algorithms/tests/regressions/for_each_datapar.cpp M libs/core/algorithms/tests/regressions/set_operations_3442.cpp M libs/core/algorithms/tests/unit/algorithms/adjacentfind_binary_tests.hpp M libs/core/algorithms/tests/unit/algorithms/adjacentfind_tests.hpp M libs/core/algorithms/tests/unit/algorithms/copyif_forward.cpp M libs/core/algorithms/tests/unit/algorithms/copyif_random.cpp M libs/core/algorithms/tests/unit/algorithms/destroy.cpp M libs/core/algorithms/tests/unit/algorithms/destroy_tests.hpp M libs/core/algorithms/tests/unit/algorithms/destroyn.cpp M libs/core/algorithms/tests/unit/algorithms/equal_binary_tests.hpp M libs/core/algorithms/tests/unit/algorithms/equal_tests.hpp M libs/core/algorithms/tests/unit/algorithms/exclusive_scan_validate.cpp M libs/core/algorithms/tests/unit/algorithms/find_tests.hpp M libs/core/algorithms/tests/unit/algorithms/findend_tests.hpp M libs/core/algorithms/tests/unit/algorithms/findif_tests.hpp M libs/core/algorithms/tests/unit/algorithms/findifnot_tests.hpp M libs/core/algorithms/tests/unit/algorithms/for_loop_induction.cpp M libs/core/algorithms/tests/unit/algorithms/for_loop_induction_async.cpp M libs/core/algorithms/tests/unit/algorithms/for_loop_n.cpp M libs/core/algorithms/tests/unit/algorithms/for_loop_n_strided.cpp M libs/core/algorithms/tests/unit/algorithms/for_loop_reduction.cpp M libs/core/algorithms/tests/unit/algorithms/for_loop_reduction_async.cpp M libs/core/algorithms/tests/unit/algorithms/for_loop_strided.cpp M libs/core/algorithms/tests/unit/algorithms/foreach_scheduler.cpp M libs/core/algorithms/tests/unit/algorithms/foreach_tests.hpp M libs/core/algorithms/tests/unit/algorithms/foreachn_bad_alloc.cpp M libs/core/algorithms/tests/unit/algorithms/foreachn_exception.cpp M libs/core/algorithms/tests/unit/algorithms/includes.cpp M libs/core/algorithms/tests/unit/algorithms/includes_sender.cpp M libs/core/algorithms/tests/unit/algorithms/inplace_merge_tests.hpp M libs/core/algorithms/tests/unit/algorithms/is_heap_tests.hpp M libs/core/algorithms/tests/unit/algorithms/is_partitioned.cpp M libs/core/algorithms/tests/unit/algorithms/is_partitioned_sender.cpp M libs/core/algorithms/tests/unit/algorithms/is_sorted_tests.hpp M libs/core/algorithms/tests/unit/algorithms/is_sorted_until.cpp M libs/core/algorithms/tests/unit/algorithms/is_sorted_until_sender.cpp M libs/core/algorithms/tests/unit/algorithms/lexicographical_compare.cpp M libs/core/algorithms/tests/unit/algorithms/make_heap.cpp M libs/core/algorithms/tests/unit/algorithms/merge_tests.hpp M libs/core/algorithms/tests/unit/algorithms/mismatch_binary_tests.hpp M libs/core/algorithms/tests/unit/algorithms/mismatch_tests.hpp M libs/core/algorithms/tests/unit/algorithms/move.cpp M libs/core/algorithms/tests/unit/algorithms/move_sender.cpp M libs/core/algorithms/tests/unit/algorithms/nth_element.cpp M libs/core/algorithms/tests/unit/algorithms/parallel_sort.cpp M libs/core/algorithms/tests/unit/algorithms/partial_sort.cpp M libs/core/algorithms/tests/unit/algorithms/partial_sort_copy.cpp M libs/core/algorithms/tests/unit/algorithms/partition_copy_tests.hpp M libs/core/algorithms/tests/unit/algorithms/partition_tests.hpp M libs/core/algorithms/tests/unit/algorithms/reduce_by_key.cpp M libs/core/algorithms/tests/unit/algorithms/reduce_deterministic.cpp M libs/core/algorithms/tests/unit/algorithms/reduce_tests.hpp M libs/core/algorithms/tests/unit/algorithms/remove_copy.cpp M libs/core/algorithms/tests/unit/algorithms/remove_copy_if.cpp M libs/core/algorithms/tests/unit/algorithms/remove_tests.hpp M libs/core/algorithms/tests/unit/algorithms/search.cpp M libs/core/algorithms/tests/unit/algorithms/search_sender.cpp M libs/core/algorithms/tests/unit/algorithms/searchn.cpp M libs/core/algorithms/tests/unit/algorithms/shift_left.cpp M libs/core/algorithms/tests/unit/algorithms/shift_right.cpp M libs/core/algorithms/tests/unit/algorithms/sort_tests.hpp M libs/core/algorithms/tests/unit/algorithms/stable_sort_tests.hpp M libs/core/algorithms/tests/unit/algorithms/uninitialized_relocate.cpp M libs/core/algorithms/tests/unit/algorithms/uninitialized_relocate_backward.cpp M libs/core/algorithms/tests/unit/algorithms/uninitialized_relocaten.cpp M libs/core/algorithms/tests/unit/algorithms/unique_copy_tests.hpp M libs/core/algorithms/tests/unit/algorithms/util/test_simd_helpers.cpp M libs/core/algorithms/tests/unit/container_algorithms/adjacentdifference_range_sender.cpp M libs/core/algorithms/tests/unit/container_algorithms/adjacentfind_binary_projection_range.cpp M libs/core/algorithms/tests/unit/container_algorithms/adjacentfind_binary_range.cpp M libs/core/algorithms/tests/unit/container_algorithms/adjacentfind_range.cpp M libs/core/algorithms/tests/unit/container_algorithms/copyif_range.cpp M libs/core/algorithms/tests/unit/container_algorithms/destroy_range_tests.hpp M libs/core/algorithms/tests/unit/container_algorithms/destroyn_range.cpp M libs/core/algorithms/tests/unit/container_algorithms/equal_binary_range.cpp M libs/core/algorithms/tests/unit/container_algorithms/equal_range.cpp M libs/core/algorithms/tests/unit/container_algorithms/find_end_range.cpp M libs/core/algorithms/tests/unit/container_algorithms/find_end_range2.cpp M libs/core/algorithms/tests/unit/container_algorithms/find_if_not_range.cpp M libs/core/algorithms/tests/unit/container_algorithms/find_if_range.cpp M libs/core/algorithms/tests/unit/container_algorithms/find_range.cpp M libs/core/algorithms/tests/unit/container_algorithms/for_loop_induction_async_range.cpp M libs/core/algorithms/tests/unit/container_algorithms/for_loop_induction_range.cpp M libs/core/algorithms/tests/unit/container_algorithms/for_loop_range_generator.cpp M libs/core/algorithms/tests/unit/container_algorithms/for_loop_reduction_async_range.cpp M libs/core/algorithms/tests/unit/container_algorithms/for_loop_reduction_range.cpp M libs/core/algorithms/tests/unit/container_algorithms/for_loop_strided_range.cpp M libs/core/algorithms/tests/unit/container_algorithms/foreach_range_sender.cpp M libs/core/algorithms/tests/unit/container_algorithms/foreach_tests.hpp M libs/core/algorithms/tests/unit/container_algorithms/includes_range.cpp M libs/core/algorithms/tests/unit/container_algorithms/inplace_merge_range.cpp M libs/core/algorithms/tests/unit/container_algorithms/is_partitioned_async_range.cpp M libs/core/algorithms/tests/unit/container_algorithms/is_partitioned_projection_range.cpp M libs/core/algorithms/tests/unit/container_algorithms/is_partitioned_range.cpp M libs/core/algorithms/tests/unit/container_algorithms/is_sorted_range_tests.hpp M libs/core/algorithms/tests/unit/container_algorithms/is_sorted_range_tests2.hpp M libs/core/algorithms/tests/unit/container_algorithms/is_sorted_range_tests3.hpp M libs/core/algorithms/tests/unit/container_algorithms/is_sorted_range_tests_exception.hpp M libs/core/algorithms/tests/unit/container_algorithms/is_sorted_until_range.cpp M libs/core/algorithms/tests/unit/container_algorithms/is_sorted_until_range_exception.cpp M libs/core/algorithms/tests/unit/container_algorithms/make_heap_range.cpp M libs/core/algorithms/tests/unit/container_algorithms/merge_range.cpp M libs/core/algorithms/tests/unit/container_algorithms/mismatch_binary_range.cpp M libs/core/algorithms/tests/unit/container_algorithms/mismatch_range.cpp M libs/core/algorithms/tests/unit/container_algorithms/nth_element_range.cpp M libs/core/algorithms/tests/unit/container_algorithms/partial_sort_copy_range.cpp M libs/core/algorithms/tests/unit/container_algorithms/partial_sort_range.cpp M libs/core/algorithms/tests/unit/container_algorithms/reduce_range.cpp M libs/core/algorithms/tests/unit/container_algorithms/remove_range.cpp M libs/core/algorithms/tests/unit/container_algorithms/search_range.cpp M libs/core/algorithms/tests/unit/container_algorithms/searchn_range.cpp M libs/core/algorithms/tests/unit/container_algorithms/shift_left_range.cpp M libs/core/algorithms/tests/unit/container_algorithms/shift_right_range.cpp M libs/core/algorithms/tests/unit/container_algorithms/sort_range_tests.hpp M libs/core/algorithms/tests/unit/container_algorithms/stable_partition_range.cpp M libs/core/algorithms/tests/unit/container_algorithms/stable_sort_range_tests.hpp M libs/core/algorithms/tests/unit/container_algorithms/swap_ranges_range.cpp M libs/core/algorithms/tests/unit/container_algorithms/uninitialized_copy_n_range.cpp M libs/core/algorithms/tests/unit/container_algorithms/uninitialized_copy_range.cpp M libs/core/algorithms/tests/unit/container_algorithms/uninitialized_fill_range.cpp M libs/core/algorithms/tests/unit/container_algorithms/uninitialized_filln_range.cpp M libs/core/algorithms/tests/unit/container_algorithms/uninitialized_move_n_range.cpp M libs/core/algorithms/tests/unit/container_algorithms/uninitialized_move_range.cpp M libs/core/async_base/include/hpx/async_base/launch_policy.hpp M libs/core/async_base/include/hpx/async_base/scheduling_properties.hpp M libs/core/async_combinators/include/hpx/async_combinators/when_each.hpp M libs/core/batch_environments/src/pjm_environment.cpp M libs/core/cache/include/hpx/cache/entries/entry.hpp M libs/core/compute_local/include/hpx/compute_local/host/block_allocator.hpp M libs/core/compute_local/include/hpx/compute_local/host/block_executor.hpp M libs/core/compute_local/include/hpx/compute_local/host/numa_binding_allocator.hpp M libs/core/compute_local/tests/unit/allocator_binder_matrix.hpp M libs/core/compute_local/tests/unit/numa_allocator.cpp M libs/core/concurrency/include/hpx/concurrency/concurrentqueue.hpp M libs/core/concurrency/tests/unit/contiguous_index_queue.cpp M libs/core/concurrency/tests/unit/non_contiguous_index_queue.cpp M libs/core/config/include/hpx/config/compiler_specific.hpp M libs/core/coroutines/include/hpx/coroutines/detail/context_base.hpp M libs/core/coroutines/include/hpx/coroutines/detail/context_linux_x86.hpp M libs/core/datastructures/include/hpx/datastructures/any.hpp M libs/core/datastructures/include/hpx/datastructures/detail/dynamic_bitset.hpp M libs/core/datastructures/include/hpx/datastructures/detail/small_vector.hpp M libs/core/datastructures/include/hpx/datastructures/serialization/optional.hpp M libs/core/datastructures/include/hpx/datastructures/serialization/serializable_any.hpp M libs/core/datastructures/include/hpx/datastructures/tuple.hpp M libs/core/datastructures/tests/unit/dynamic_bitset2.cpp M libs/core/datastructures/tests/unit/dynamic_bitset4.cpp M libs/core/datastructures/tests/unit/small_vector.cpp M libs/core/debugging/src/backtrace.cpp M libs/core/errors/include/hpx/errors/exception_info.hpp M libs/core/execution/include/hpx/execution/algorithms/detail/inject_scheduler.hpp M libs/core/execution/include/hpx/execution/algorithms/detail/partial_algorithm.hpp M libs/core/execution/include/hpx/execution/algorithms/make_future.hpp M libs/core/execution/include/hpx/execution/algorithms/run_loop.hpp M libs/core/execution/include/hpx/execution/algorithms/when_all.hpp M libs/core/execution/include/hpx/execution/algorithms/when_all_vector.hpp M libs/core/execution/include/hpx/execution/executors/polymorphic_executor.hpp M libs/core/execution/tests/regressions/fibonacci_sr.cpp M libs/core/execution/tests/unit/algorithm_run_loop.cpp M libs/core/execution/tests/unit/algorithm_sync_wait.cpp M libs/core/execution/tests/unit/algorithm_sync_wait_with_variant.cpp M libs/core/execution/tests/unit/foreach_tests.hpp M libs/core/execution_base/src/this_thread.cpp M libs/core/execution_base/tests/include/algorithm_test_utils.hpp M libs/core/execution_base/tests/unit/execution_context.cpp M libs/core/executors/include/hpx/executors/detail/index_queue_spawning.hpp M libs/core/executors/include/hpx/executors/explicit_scheduler_executor.hpp M libs/core/executors/include/hpx/executors/fork_join_executor.hpp M libs/core/executors/include/hpx/executors/guided_pool_executor.hpp M libs/core/executors/include/hpx/executors/restricted_thread_pool_executor.hpp M libs/core/executors/include/hpx/executors/scheduler_executor.hpp M libs/core/executors/include/hpx/executors/service_executors.hpp M libs/core/executors/tests/unit/parallel_executor_parameters.cpp M libs/core/executors/tests/unit/thread_pool_scheduler.cpp M libs/core/format/src/format.cpp M libs/core/functional/include/hpx/functional/bind.hpp M libs/core/functional/include/hpx/functional/detail/basic_function.hpp M libs/core/functional/include/hpx/functional/detail/vtable/copyable_vtable.hpp M libs/core/functional/include/hpx/functional/invoke_fused.hpp M libs/core/functional/tests/unit/function_test.cpp M libs/core/functional/tests/unit/protect_test.cpp M libs/core/functional/tests/unit/scope.cpp M libs/core/futures/include/hpx/futures/detail/future_data.hpp M libs/core/futures/include/hpx/futures/future.hpp M libs/core/futures/include/hpx/futures/traits/acquire_shared_state.hpp M libs/core/futures/tests/unit/future.cpp M libs/core/hashing/include/hpx/hashing/jenkins_hash.hpp M libs/core/init_runtime_local/src/init_runtime_local.cpp M libs/core/iterator_support/include/hpx/iterator_support/iterator_adaptor.hpp M libs/core/iterator_support/include/hpx/iterator_support/iterator_facade.hpp M libs/core/iterator_support/include/hpx/iterator_support/zip_iterator.hpp M libs/core/iterator_support/tests/performance/stencil3_iterators.cpp M libs/core/iterator_support/tests/unit/counting_iterator.cpp M libs/core/iterator_support/tests/unit/zip_iterator.cpp M libs/core/lcos_local/tests/unit/channel_local.cpp M libs/core/logging/include/hpx/modules/logging.hpp M libs/core/pack_traversal/include/hpx/pack_traversal/detail/pack_traversal_impl.hpp M libs/core/pack_traversal/tests/unit/pack_traversal.cpp M libs/core/pack_traversal/tests/unit/pack_traversal_async.cpp M libs/core/prefix/src/find_prefix.cpp M libs/core/program_options/examples/options_hierarchy.cpp M libs/core/program_options/include/hpx/program_options/eof_iterator.hpp M libs/core/program_options/src/config_file.cpp M libs/core/program_options/src/options_description.cpp M libs/core/program_options/tests/unit/optional.cpp M libs/core/resiliency/examples/1d_stencil_replay_exception.cpp M libs/core/resiliency/examples/1d_stencil_replay_validate.cpp M libs/core/resiliency/include/hpx/resiliency/async_replicate_executor.hpp M libs/core/resiliency/include/hpx/resiliency/replay_executor.hpp M libs/core/resiliency/include/hpx/resiliency/replicate_executor.hpp M libs/core/resiliency/include/hpx/resiliency/resiliency_cpos.hpp M libs/core/resiliency/tests/performance/replay/1d_stencil.cpp M libs/core/resiliency/tests/performance/replay/1d_stencil_checksum.cpp M libs/core/resiliency/tests/performance/replay/1d_stencil_replay.cpp M libs/core/resiliency/tests/performance/replay/dataflow_replay.cpp M libs/core/resiliency/tests/performance/replay/dataflow_replay_validate.cpp M libs/core/resiliency/tests/performance/replay/pure_dataflow.cpp M libs/core/resiliency/tests/performance/replicate/1d_stencil_replicate.cpp M libs/core/resiliency/tests/performance/replicate/1d_stencil_replicate_checksum.cpp M libs/core/resource_partitioner/examples/guided_pool_test.cpp M libs/core/resource_partitioner/examples/oversubscribing_resource_partitioner.cpp M libs/core/resource_partitioner/examples/simple_resource_partitioner.cpp M libs/core/runtime_configuration/src/init_ini_data.cpp M libs/core/runtime_local/include/hpx/runtime_local/run_as_hpx_thread.hpp M libs/core/runtime_local/src/interval_timer.cpp M libs/core/runtime_local/src/pool_timer.cpp M libs/core/runtime_local/src/runtime_local.cpp M libs/core/runtime_local/src/serialize_exception.cpp M libs/core/schedulers/include/hpx/schedulers/queue_holder_thread.hpp M libs/core/serialization/include/hpx/serialization/basic_archive.hpp M libs/core/serialization/include/hpx/serialization/input_archive.hpp M libs/core/serialization/include/hpx/serialization/output_archive.hpp M libs/core/serialization/include/hpx/serialization/output_container.hpp M libs/core/serialization/include/hpx/serialization/serialization_chunk.hpp M libs/core/synchronization/include/hpx/synchronization/async_rw_mutex.hpp M libs/core/synchronization/include/hpx/synchronization/counting_semaphore.hpp M libs/core/synchronization/include/hpx/synchronization/sliding_semaphore.hpp M libs/core/tag_invoke/include/hpx/functional/detail/tag_fallback_invoke.hpp M libs/core/tag_invoke/include/hpx/functional/detail/tag_priority_invoke.hpp M libs/core/tag_invoke/include/hpx/functional/tag_invoke.hpp M libs/core/thread_pools/include/hpx/thread_pools/detail/scheduling_callbacks.hpp M libs/core/threading/src/thread.cpp M libs/core/threading/tests/unit/in_place_stop_token_cb1.cpp M libs/core/threading/tests/unit/stop_token_cb1.cpp M libs/core/threading_base/include/hpx/threading_base/execution_agent.hpp M libs/core/threading_base/include/hpx/threading_base/thread_helpers.hpp M libs/core/type_support/include/hpx/type_support/unwrap_ref.hpp M libs/core/type_support/tests/unit/generator.cpp M libs/core/util/include/hpx/util/max.hpp M libs/core/util/include/hpx/util/min.hpp M libs/full/actions/tests/performance/serialization_overhead.cpp M libs/full/actions_base/include/hpx/actions_base/basic_action.hpp M libs/full/agas/src/addressing_service.cpp M libs/full/agas/tests/regressions/register_with_basename_1804.cpp M libs/full/agas_base/src/server/primary_namespace_server.cpp M libs/full/async_distributed/include/hpx/async_distributed/bind_action.hpp M libs/full/async_distributed/include/hpx/async_distributed/detail/promise_lco.hpp M libs/full/async_distributed/include/hpx/async_distributed/set_lco_value_continuation.hpp M libs/full/async_distributed/tests/regressions/dataflow_791.cpp M libs/full/checkpoint/examples/1d_stencil_4_checkpoint.cpp M libs/full/checkpoint/examples/print_time_results.hpp M libs/full/checkpoint/include/hpx/checkpoint/checkpoint.hpp M libs/full/collectives/examples/distributed_pi.cpp M libs/full/collectives/include/hpx/collectives/broadcast_direct.hpp M libs/full/collectives/include/hpx/collectives/reduce_direct.hpp M libs/full/collectives/src/detail/barrier_node.cpp M libs/full/collectives/tests/performance/lcos/barrier_performance.cpp M libs/full/collectives/tests/performance/osu/osu_bibw.cpp M libs/full/collectives/tests/performance/osu/osu_bw.cpp M libs/full/collectives/tests/performance/osu/osu_multi_lat.cpp M libs/full/collectives/tests/unit/concurrent_collectives.cpp M libs/full/collectives/tests/unit/remote_latch.cpp M libs/full/components/include/hpx/components/client_base.hpp M libs/full/components/src/basename_registration.cpp M libs/full/components_base/include/hpx/components_base/server/abstract_component_base.hpp M libs/full/components_base/include/hpx/components_base/server/abstract_migration_support.hpp M libs/full/components_base/include/hpx/components_base/server/component_base.hpp M libs/full/components_base/include/hpx/components_base/server/fixed_component_base.hpp M libs/full/components_base/include/hpx/components_base/server/managed_component_base.hpp M libs/full/init_runtime/src/hpx_init.cpp M libs/full/lcos_distributed/tests/unit/channel.cpp M libs/full/naming/src/credit_handling.cpp M libs/full/naming_base/include/hpx/naming_base/gid_type.hpp M libs/full/naming_base/src/gid_type.cpp M libs/full/parcelport_gasnet/include/hpx/parcelport_gasnet/sender_connection.hpp M libs/full/parcelport_lci/src/putva/sender_connection_putva.cpp M libs/full/parcelport_lci/src/sendrecv/sender_connection_sendrecv.cpp M libs/full/parcelport_mpi/include/hpx/parcelport_mpi/sender_connection.hpp M libs/full/parcelport_tcp/include/hpx/parcelport_tcp/receiver.hpp M libs/full/parcelport_tcp/include/hpx/parcelport_tcp/sender.hpp M libs/full/parcelport_tcp/src/connection_handler_tcp.cpp M libs/full/parcelset/include/hpx/parcelset/encode_parcels.hpp M libs/full/parcelset/include/hpx/parcelset/parcelport_connection.hpp M libs/full/parcelset/include/hpx/parcelset/parcelport_impl.hpp M libs/full/parcelset/src/detail/parcel_await.cpp M libs/full/parcelset_base/src/parcelport.cpp M libs/full/performance_counters/include/hpx/performance_counters/base_performance_counter.hpp M libs/full/performance_counters/src/server/arithmetics_counter.cpp M libs/full/performance_counters/src/server/arithmetics_counter_extended.cpp M libs/full/performance_counters/tests/unit/all_counters.cpp M libs/full/resiliency_distributed/tests/performance/replay/1d_stencil_distributed.cpp M libs/full/resiliency_distributed/tests/performance/replay/1d_stencil_replay_distributed.cpp M libs/full/runtime_components/include/hpx/runtime_components/server/console_logging.hpp M libs/full/runtime_components/tests/unit/components/migrate_component.cpp M libs/full/runtime_components/tests/unit/components/migrate_polymorphic_component.cpp M libs/full/segmented_algorithms/include/hpx/parallel/segmented_algorithms/adjacent_find.hpp M libs/full/segmented_algorithms/include/hpx/parallel/segmented_algorithms/count.hpp M libs/full/segmented_algorithms/include/hpx/parallel/segmented_algorithms/detail/scan.hpp M libs/full/segmented_algorithms/include/hpx/parallel/segmented_algorithms/exclusive_scan.hpp M tests/performance/local/agas_cache_timings.cpp M tests/performance/local/async_overheads.cpp M tests/performance/local/future_overhead.cpp M tests/performance/local/future_overhead_report.cpp M tests/performance/local/hpx_heterogeneous_timed_task_spawn.cpp M tests/performance/local/htts_v2/htts2_hpx.cpp M tests/performance/local/partitioned_vector_foreach.cpp M tests/performance/local/spinlock_overhead1.cpp M tests/performance/local/spinlock_overhead2.cpp M tests/performance/local/stream.cpp M tests/performance/local/stream_report.cpp M tests/performance/local/transform_reduce_binary_scaling.cpp M tests/performance/local/wait_all_timings.cpp M tests/performance/network/network_storage/network_storage.cpp M tests/performance/network/network_storage/simple_profiler.hpp M tests/regressions/block_matrix/main.cpp M tests/regressions/block_matrix/matrix.cpp M tests/regressions/block_matrix/matrix.hpp M tests/regressions/block_matrix/tests.cpp M tests/regressions/lcos/sliding_semaphore_2338.cpp M tests/regressions/threads/block_os_threads_1036.cpp M tools/hpxdep/hpxdep.cpp M tools/inspect/ascii_check.cpp M tools/inspect/inspect.cpp M tools/inspect/link_check.cpp M tools/inspect/path_name_check.cpp Log Message: ----------- Suppress and fix clang-tidy warnings reported as errors Signed-off-by: Hartmut Kaiser <hartmut.kai...@gmail.com> Commit: d7e7522d00fd4447fc2da53cbb44e76cf7176176 https://github.com/STEllAR-GROUP/hpx/commit/d7e7522d00fd4447fc2da53cbb44e76cf7176176 Author: Hartmut Kaiser <hartmut.kai...@gmail.com> Date: 2025-07-05 (Sat, 05 Jul 2025) Changed paths: M cmake/HPX_AddConfigTest.cmake M cmake/HPX_PerformCxxFeatureTests.cmake A cmake/tests/cxx23_deprecated_std_aligned_storage.cpp M examples/quickstart/component_with_custom_heap.cpp M libs/core/datastructures/include/hpx/datastructures/detail/optional.hpp M libs/core/execution/include/hpx/execution/executors/polymorphic_executor.hpp M libs/core/execution/include/hpx/execution/traits/detail/eve/vector_pack_get_set.hpp M libs/core/execution_base/include/hpx/execution_base/any_sender.hpp M libs/core/functional/include/hpx/functional/detail/vtable/vtable.hpp M libs/core/futures/include/hpx/futures/detail/future_data.hpp M libs/core/serialization/include/hpx/serialization/detail/constructor_selector.hpp M libs/core/serialization/include/hpx/serialization/detail/polymorphic_nonintrusive_factory.hpp M libs/core/static_reinit/include/hpx/static_reinit/reinitializable_static.hpp M libs/core/type_support/CMakeLists.txt A libs/core/type_support/include/hpx/type_support/aligned_storage.hpp M libs/core/type_support/include/hpx/type_support/static.hpp M libs/full/components_base/include/hpx/components_base/server/wrapper_heap_list.hpp M libs/full/include/include/hpx/include/util.hpp Log Message: ----------- Adding hpx::aligned_storage_t Signed-off-by: Hartmut Kaiser <hartmut.kai...@gmail.com> Commit: 916b982fa04031f201fda358d31259a445139aa9 https://github.com/STEllAR-GROUP/hpx/commit/916b982fa04031f201fda358d31259a445139aa9 Author: Hartmut Kaiser <hartmut.kai...@gmail.com> Date: 2025-07-06 (Sun, 06 Jul 2025) Changed paths: M .circleci/config.yml M .clang-tidy R .github/bors.toml R .github/workflows/linux_bors.yml M .github/workflows/linux_crosscompile_arm_eve_sve_release.yml M .github/workflows/linux_debug.yml M .github/workflows/linux_debug_fetch_boost.yml M .github/workflows/linux_release_fetchcontent.yml M .github/workflows/linux_release_static.yml M .github/workflows/linux_sanitizers.yml M .github/workflows/linux_with_bench_test.yml M .github/workflows/linux_with_nanobench_test.yml R .github/workflows/windows_debug_vs2019.yml R .github/workflows/windows_release_2019.yml M .github/workflows/windows_release_gcc_mingw.yml M .jenkins/lsu/entry.sh M .jenkins/lsu/env-clang-16.sh M .jenkins/lsu/env-clang-17-apex.sh M .jenkins/lsu/env-clang-18.sh M .jenkins/lsu/env-clang-19.sh M .jenkins/lsu/env-clang-20.sh M .jenkins/lsu/env-gcc-12-cuda-12-dgx.sh M .jenkins/lsu/env-gcc-12-cuda-12.sh M .jenkins/lsu/env-gcc-13.sh M .jenkins/lsu/env-gcc-14.sh M .jenkins/lsu/env-gcc-15.sh M CMakeLists.txt M cmake/HPX_AddConfigTest.cmake M cmake/HPX_CheckCXXStandard.cmake M cmake/HPX_PerformCxxFeatureTests.cmake M cmake/HPX_SetupDatapar.cmake M cmake/HPX_SetupStdexec.cmake A cmake/tests/cxx23_deprecated_std_aligned_storage.cpp M components/containers/partitioned_vector/include/hpx/components/containers/coarray/coarray.hpp M components/containers/partitioned_vector/tests/unit/coarray.cpp M components/containers/partitioned_vector/tests/unit/coarray_all_reduce.cpp M components/iostreams/tests/regressions/lost_output_2236.cpp M components/parcel_plugins/coalescing/src/coalescing_message_handler.cpp M components/process/include/hpx/components/process/util/posix/initializers/set_cmd_line.hpp M docs/sphinx/manual/building_hpx.rst M docs/sphinx/manual/prerequisites.rst M docs/sphinx/manual/troubleshooting.rst M examples/1d_stencil/1d_stencil_3.cpp M examples/1d_stencil/1d_stencil_3_omp.cpp M examples/1d_stencil/1d_stencil_4.cpp M examples/1d_stencil/1d_stencil_4_parallel.cpp M examples/1d_stencil/1d_stencil_4_repart.cpp M examples/1d_stencil/1d_stencil_4_throttle.cpp M examples/1d_stencil/1d_stencil_5.cpp M examples/1d_stencil/1d_stencil_6.cpp M examples/1d_stencil/1d_stencil_7.cpp M examples/1d_stencil/1d_stencil_8.cpp M examples/1d_stencil/print_time_results.hpp M examples/balancing/os_thread_num.cpp M examples/heartbeat/heartbeat.cpp M examples/interpolate1d/interpolate1d/dimension.cpp M examples/jacobi/jacobi_component/grid.hpp M examples/jacobi/jacobi_component/row.hpp M examples/jacobi/jacobi_component/row_range.hpp M examples/jacobi/jacobi_component/server/row.hpp M examples/jacobi/jacobi_component/server/stencil_iterator.cpp M examples/jacobi/jacobi_component/stencil_iterator.hpp M examples/jacobi_smp/jacobi_hpx.cpp M examples/jacobi_smp/jacobi_nonuniform_hpx.cpp M examples/nqueen/nqueen_client.cpp M examples/performance_counters/sine/server/sine.cpp M examples/performance_counters/sine/sine.cpp M examples/quickstart/1d_wave_equation.cpp M examples/quickstart/component_with_custom_heap.cpp M examples/quickstart/data_actions.cpp M examples/quickstart/fibonacci_await.cpp M examples/quickstart/file_serialization.cpp M examples/quickstart/interest_calculator.cpp M examples/quickstart/local_channel.cpp M examples/quickstart/partitioned_vector_spmd_foreach.cpp M examples/quickstart/pingpong.cpp M examples/quickstart/zerocopy_rdma.cpp M examples/sheneos/sheneos/dimension.cpp M examples/sheneos/sheneos/interpolator.cpp M examples/sheneos/sheneos/server/configuration.cpp M examples/throttle/throttle/server/throttle.cpp M examples/transpose/transpose_await.cpp M examples/transpose/transpose_block.cpp M examples/transpose/transpose_serial.cpp M examples/transpose/transpose_serial_block.cpp M examples/transpose/transpose_serial_vector.cpp M examples/transpose/transpose_smp.cpp M examples/transpose/transpose_smp_block.cpp M examples/tuplespace/small_big_object.hpp M libs/core/affinity/src/affinity_data.cpp M libs/core/affinity/src/parse_affinity_options.cpp M libs/core/algorithms/include/hpx/parallel/algorithms/copy.hpp M libs/core/algorithms/include/hpx/parallel/algorithms/detail/dispatch.hpp M libs/core/algorithms/include/hpx/parallel/algorithms/detail/equal.hpp M libs/core/algorithms/include/hpx/parallel/algorithms/detail/find.hpp M libs/core/algorithms/include/hpx/parallel/algorithms/detail/is_sorted.hpp M libs/core/algorithms/include/hpx/parallel/algorithms/detail/reduce_deterministic.hpp M libs/core/algorithms/include/hpx/parallel/algorithms/detail/rfa.hpp M libs/core/algorithms/include/hpx/parallel/algorithms/detail/sample_sort.hpp M libs/core/algorithms/include/hpx/parallel/algorithms/detail/set_operation.hpp M libs/core/algorithms/include/hpx/parallel/algorithms/for_each.hpp M libs/core/algorithms/include/hpx/parallel/algorithms/generate.hpp M libs/core/algorithms/include/hpx/parallel/algorithms/is_partitioned.hpp M libs/core/algorithms/include/hpx/parallel/algorithms/lexicographical_compare.hpp M libs/core/algorithms/include/hpx/parallel/algorithms/merge.hpp M libs/core/algorithms/include/hpx/parallel/algorithms/minmax.hpp M libs/core/algorithms/include/hpx/parallel/algorithms/mismatch.hpp M libs/core/algorithms/include/hpx/parallel/algorithms/partition.hpp M libs/core/algorithms/include/hpx/parallel/algorithms/reverse.hpp M libs/core/algorithms/include/hpx/parallel/algorithms/rotate.hpp M libs/core/algorithms/include/hpx/parallel/algorithms/set_difference.hpp M libs/core/algorithms/include/hpx/parallel/algorithms/set_intersection.hpp M libs/core/algorithms/include/hpx/parallel/algorithms/set_symmetric_difference.hpp M libs/core/algorithms/include/hpx/parallel/algorithms/shift_right.hpp M libs/core/algorithms/include/hpx/parallel/algorithms/sort.hpp M libs/core/algorithms/include/hpx/parallel/algorithms/stable_sort.hpp M libs/core/algorithms/include/hpx/parallel/algorithms/swap_ranges.hpp M libs/core/algorithms/include/hpx/parallel/algorithms/uninitialized_copy.hpp M libs/core/algorithms/include/hpx/parallel/algorithms/uninitialized_default_construct.hpp M libs/core/algorithms/include/hpx/parallel/algorithms/uninitialized_fill.hpp M libs/core/algorithms/include/hpx/parallel/algorithms/uninitialized_move.hpp M libs/core/algorithms/include/hpx/parallel/algorithms/uninitialized_relocate.hpp M libs/core/algorithms/include/hpx/parallel/algorithms/uninitialized_value_construct.hpp M libs/core/algorithms/include/hpx/parallel/algorithms/unique.hpp M libs/core/algorithms/include/hpx/parallel/container_algorithms/adjacent_find.hpp M libs/core/algorithms/include/hpx/parallel/container_algorithms/nth_element.hpp M libs/core/algorithms/include/hpx/parallel/container_algorithms/transform.hpp M libs/core/algorithms/include/hpx/parallel/datapar/generate.hpp M libs/core/algorithms/include/hpx/parallel/datapar/transform_loop.hpp M libs/core/algorithms/include/hpx/parallel/task_block.hpp M libs/core/algorithms/include/hpx/parallel/unseq/reduce_helpers.hpp M libs/core/algorithms/include/hpx/parallel/util/detail/algorithm_result.hpp M libs/core/algorithms/include/hpx/parallel/util/detail/chunk_size_iterator.hpp M libs/core/algorithms/include/hpx/parallel/util/detail/sender_util.hpp M libs/core/algorithms/include/hpx/parallel/util/foreach_partitioner.hpp M libs/core/algorithms/include/hpx/parallel/util/loop.hpp M libs/core/algorithms/include/hpx/parallel/util/partitioner.hpp M libs/core/algorithms/include/hpx/parallel/util/partitioner_with_cleanup.hpp M libs/core/algorithms/include/hpx/parallel/util/result_types.hpp M libs/core/algorithms/include/hpx/parallel/util/scan_partitioner.hpp M libs/core/algorithms/include/hpx/parallel/util/transfer.hpp M libs/core/algorithms/include/hpx/parallel/util/transform_loop.hpp M libs/core/algorithms/tests/performance/benchmark_inplace_merge.cpp M libs/core/algorithms/tests/performance/benchmark_is_heap.cpp M libs/core/algorithms/tests/performance/benchmark_is_heap_until.cpp M libs/core/algorithms/tests/performance/benchmark_merge.cpp M libs/core/algorithms/tests/performance/benchmark_nth_element.cpp M libs/core/algorithms/tests/performance/benchmark_nth_element_parallel.cpp M libs/core/algorithms/tests/performance/benchmark_partial_sort.cpp M libs/core/algorithms/tests/performance/benchmark_partial_sort_parallel.cpp M libs/core/algorithms/tests/performance/benchmark_partition.cpp M libs/core/algorithms/tests/performance/benchmark_partition_copy.cpp M libs/core/algorithms/tests/performance/benchmark_remove.cpp M libs/core/algorithms/tests/performance/benchmark_remove_if.cpp M libs/core/algorithms/tests/performance/benchmark_scan_algorithms.cpp M libs/core/algorithms/tests/performance/benchmark_unique.cpp M libs/core/algorithms/tests/performance/benchmark_unique_copy.cpp M libs/core/algorithms/tests/performance/foreach_scaling.cpp M libs/core/algorithms/tests/performance/transform_reduce_scaling.cpp M libs/core/algorithms/tests/regressions/for_each_datapar.cpp M libs/core/algorithms/tests/regressions/set_operations_3442.cpp M libs/core/algorithms/tests/regressions/stable_merge_2964.cpp M libs/core/algorithms/tests/unit/algorithms/adjacentfind_binary_tests.hpp M libs/core/algorithms/tests/unit/algorithms/adjacentfind_tests.hpp M libs/core/algorithms/tests/unit/algorithms/copyif_forward.cpp M libs/core/algorithms/tests/unit/algorithms/copyif_random.cpp M libs/core/algorithms/tests/unit/algorithms/destroy.cpp M libs/core/algorithms/tests/unit/algorithms/destroy_tests.hpp M libs/core/algorithms/tests/unit/algorithms/destroyn.cpp M libs/core/algorithms/tests/unit/algorithms/equal_binary_tests.hpp M libs/core/algorithms/tests/unit/algorithms/equal_tests.hpp M libs/core/algorithms/tests/unit/algorithms/exclusive_scan_validate.cpp M libs/core/algorithms/tests/unit/algorithms/find_tests.hpp M libs/core/algorithms/tests/unit/algorithms/findend_tests.hpp M libs/core/algorithms/tests/unit/algorithms/findif_tests.hpp M libs/core/algorithms/tests/unit/algorithms/findifnot_tests.hpp M libs/core/algorithms/tests/unit/algorithms/for_loop_induction.cpp M libs/core/algorithms/tests/unit/algorithms/for_loop_induction_async.cpp M libs/core/algorithms/tests/unit/algorithms/for_loop_n.cpp M libs/core/algorithms/tests/unit/algorithms/for_loop_n_strided.cpp M libs/core/algorithms/tests/unit/algorithms/for_loop_reduction.cpp M libs/core/algorithms/tests/unit/algorithms/for_loop_reduction_async.cpp M libs/core/algorithms/tests/unit/algorithms/for_loop_strided.cpp M libs/core/algorithms/tests/unit/algorithms/foreach_scheduler.cpp M libs/core/algorithms/tests/unit/algorithms/foreach_tests.hpp M libs/core/algorithms/tests/unit/algorithms/foreachn_bad_alloc.cpp M libs/core/algorithms/tests/unit/algorithms/foreachn_exception.cpp M libs/core/algorithms/tests/unit/algorithms/includes.cpp M libs/core/algorithms/tests/unit/algorithms/includes_sender.cpp M libs/core/algorithms/tests/unit/algorithms/inplace_merge_tests.hpp M libs/core/algorithms/tests/unit/algorithms/is_heap_tests.hpp M libs/core/algorithms/tests/unit/algorithms/is_partitioned.cpp M libs/core/algorithms/tests/unit/algorithms/is_partitioned_sender.cpp M libs/core/algorithms/tests/unit/algorithms/is_sorted_tests.hpp M libs/core/algorithms/tests/unit/algorithms/is_sorted_until.cpp M libs/core/algorithms/tests/unit/algorithms/is_sorted_until_sender.cpp M libs/core/algorithms/tests/unit/algorithms/lexicographical_compare.cpp M libs/core/algorithms/tests/unit/algorithms/make_heap.cpp M libs/core/algorithms/tests/unit/algorithms/merge_tests.hpp M libs/core/algorithms/tests/unit/algorithms/mismatch_binary_tests.hpp M libs/core/algorithms/tests/unit/algorithms/mismatch_tests.hpp M libs/core/algorithms/tests/unit/algorithms/move.cpp M libs/core/algorithms/tests/unit/algorithms/move_sender.cpp M libs/core/algorithms/tests/unit/algorithms/nth_element.cpp M libs/core/algorithms/tests/unit/algorithms/parallel_sort.cpp M libs/core/algorithms/tests/unit/algorithms/partial_sort.cpp M libs/core/algorithms/tests/unit/algorithms/partial_sort_copy.cpp M libs/core/algorithms/tests/unit/algorithms/partition_copy_tests.hpp M libs/core/algorithms/tests/unit/algorithms/partition_tests.hpp M libs/core/algorithms/tests/unit/algorithms/reduce_by_key.cpp M libs/core/algorithms/tests/unit/algorithms/reduce_deterministic.cpp M libs/core/algorithms/tests/unit/algorithms/reduce_tests.hpp M libs/core/algorithms/tests/unit/algorithms/remove_copy.cpp M libs/core/algorithms/tests/unit/algorithms/remove_copy_if.cpp M libs/core/algorithms/tests/unit/algorithms/remove_tests.hpp M libs/core/algorithms/tests/unit/algorithms/rotate.cpp M libs/core/algorithms/tests/unit/algorithms/rotate_copy.cpp M libs/core/algorithms/tests/unit/algorithms/search.cpp M libs/core/algorithms/tests/unit/algorithms/search_sender.cpp M libs/core/algorithms/tests/unit/algorithms/searchn.cpp M libs/core/algorithms/tests/unit/algorithms/shift_left.cpp M libs/core/algorithms/tests/unit/algorithms/shift_right.cpp M libs/core/algorithms/tests/unit/algorithms/sort_tests.hpp M libs/core/algorithms/tests/unit/algorithms/stable_sort_tests.hpp M libs/core/algorithms/tests/unit/algorithms/uninitialized_relocate.cpp M libs/core/algorithms/tests/unit/algorithms/uninitialized_relocate_backward.cpp M libs/core/algorithms/tests/unit/algorithms/uninitialized_relocaten.cpp M libs/core/algorithms/tests/unit/algorithms/unique_copy_tests.hpp M libs/core/algorithms/tests/unit/algorithms/util/test_simd_helpers.cpp M libs/core/algorithms/tests/unit/block/spmd_block.cpp M libs/core/algorithms/tests/unit/block/task_group.cpp M libs/core/algorithms/tests/unit/container_algorithms/adjacentdifference_range_sender.cpp M libs/core/algorithms/tests/unit/container_algorithms/adjacentfind_binary_projection_range.cpp M libs/core/algorithms/tests/unit/container_algorithms/adjacentfind_binary_range.cpp M libs/core/algorithms/tests/unit/container_algorithms/adjacentfind_range.cpp M libs/core/algorithms/tests/unit/container_algorithms/copyif_range.cpp M libs/core/algorithms/tests/unit/container_algorithms/destroy_range_tests.hpp M libs/core/algorithms/tests/unit/container_algorithms/destroyn_range.cpp M libs/core/algorithms/tests/unit/container_algorithms/equal_binary_range.cpp M libs/core/algorithms/tests/unit/container_algorithms/equal_range.cpp M libs/core/algorithms/tests/unit/container_algorithms/find_end_range.cpp M libs/core/algorithms/tests/unit/container_algorithms/find_end_range2.cpp M libs/core/algorithms/tests/unit/container_algorithms/find_if_not_range.cpp M libs/core/algorithms/tests/unit/container_algorithms/find_if_range.cpp M libs/core/algorithms/tests/unit/container_algorithms/find_range.cpp M libs/core/algorithms/tests/unit/container_algorithms/for_loop_induction_async_range.cpp M libs/core/algorithms/tests/unit/container_algorithms/for_loop_induction_range.cpp M libs/core/algorithms/tests/unit/container_algorithms/for_loop_range_generator.cpp M libs/core/algorithms/tests/unit/container_algorithms/for_loop_reduction_async_range.cpp M libs/core/algorithms/tests/unit/container_algorithms/for_loop_reduction_range.cpp M libs/core/algorithms/tests/unit/container_algorithms/for_loop_strided_range.cpp M libs/core/algorithms/tests/unit/container_algorithms/foreach_range_sender.cpp M libs/core/algorithms/tests/unit/container_algorithms/foreach_tests.hpp M libs/core/algorithms/tests/unit/container_algorithms/includes_range.cpp M libs/core/algorithms/tests/unit/container_algorithms/inplace_merge_range.cpp M libs/core/algorithms/tests/unit/container_algorithms/is_partitioned_async_range.cpp M libs/core/algorithms/tests/unit/container_algorithms/is_partitioned_projection_range.cpp M libs/core/algorithms/tests/unit/container_algorithms/is_partitioned_range.cpp M libs/core/algorithms/tests/unit/container_algorithms/is_sorted_range_tests.hpp M libs/core/algorithms/tests/unit/container_algorithms/is_sorted_range_tests2.hpp M libs/core/algorithms/tests/unit/container_algorithms/is_sorted_range_tests3.hpp M libs/core/algorithms/tests/unit/container_algorithms/is_sorted_range_tests_exception.hpp M libs/core/algorithms/tests/unit/container_algorithms/is_sorted_until_range.cpp M libs/core/algorithms/tests/unit/container_algorithms/is_sorted_until_range_exception.cpp M libs/core/algorithms/tests/unit/container_algorithms/make_heap_range.cpp M libs/core/algorithms/tests/unit/container_algorithms/merge_range.cpp M libs/core/algorithms/tests/unit/container_algorithms/mismatch_binary_range.cpp M libs/core/algorithms/tests/unit/container_algorithms/mismatch_range.cpp M libs/core/algorithms/tests/unit/container_algorithms/nth_element_range.cpp M libs/core/algorithms/tests/unit/container_algorithms/partial_sort_copy_range.cpp M libs/core/algorithms/tests/unit/container_algorithms/partial_sort_range.cpp M libs/core/algorithms/tests/unit/container_algorithms/reduce_range.cpp M libs/core/algorithms/tests/unit/container_algorithms/remove_range.cpp M libs/core/algorithms/tests/unit/container_algorithms/rotate_copy_range.cpp M libs/core/algorithms/tests/unit/container_algorithms/rotate_range.cpp M libs/core/algorithms/tests/unit/container_algorithms/search_range.cpp M libs/core/algorithms/tests/unit/container_algorithms/searchn_range.cpp M libs/core/algorithms/tests/unit/container_algorithms/shift_left_range.cpp M libs/core/algorithms/tests/unit/container_algorithms/shift_right_range.cpp M libs/core/algorithms/tests/unit/container_algorithms/sort_range_tests.hpp M libs/core/algorithms/tests/unit/container_algorithms/stable_partition_range.cpp M libs/core/algorithms/tests/unit/container_algorithms/stable_sort_range_tests.hpp M libs/core/algorithms/tests/unit/container_algorithms/swap_ranges_range.cpp M libs/core/algorithms/tests/unit/container_algorithms/uninitialized_copy_n_range.cpp M libs/core/algorithms/tests/unit/container_algorithms/uninitialized_copy_range.cpp M libs/core/algorithms/tests/unit/container_algorithms/uninitialized_fill_range.cpp M libs/core/algorithms/tests/unit/container_algorithms/uninitialized_filln_range.cpp M libs/core/algorithms/tests/unit/container_algorithms/uninitialized_move_n_range.cpp M libs/core/algorithms/tests/unit/container_algorithms/uninitialized_move_range.cpp M libs/core/allocator_support/include/hpx/allocator_support/traits/is_allocator.hpp M libs/core/assertion/include/hpx/assertion/current_function.hpp M libs/core/async_base/include/hpx/async_base/launch_policy.hpp M libs/core/async_base/include/hpx/async_base/scheduling_properties.hpp M libs/core/async_combinators/include/hpx/async_combinators/when_each.hpp M libs/core/async_cuda/include/hpx/async_cuda/cuda_future.hpp M libs/core/async_cuda/tests/unit/cublas_matmul.cpp M libs/core/async_cuda/tests/unit/cuda_future.cpp M libs/core/async_sycl/include/hpx/async_sycl/sycl_future.hpp M libs/core/async_sycl/tests/unit/sycl_vector_add_concurrent_executors.cpp M libs/core/batch_environments/src/pjm_environment.cpp M libs/core/batch_environments/src/slurm_environment.cpp M libs/core/cache/include/hpx/cache/entries/entry.hpp M libs/core/cache/include/hpx/cache/local_cache.hpp M libs/core/command_line_handling_local/src/command_line_handling_local.cpp M libs/core/command_line_handling_local/src/parse_command_line_local.cpp M libs/core/compute_local/include/hpx/compute_local/host/block_allocator.hpp M libs/core/compute_local/include/hpx/compute_local/host/block_executor.hpp M libs/core/compute_local/include/hpx/compute_local/host/numa_binding_allocator.hpp M libs/core/compute_local/src/get_host_targets.cpp M libs/core/compute_local/src/numa_domains.cpp M libs/core/compute_local/tests/regressions/parallel_fill_4132.cpp M libs/core/compute_local/tests/unit/allocator_binder_linear.hpp M libs/core/compute_local/tests/unit/allocator_binder_matrix.hpp M libs/core/compute_local/tests/unit/numa_allocator.cpp M libs/core/concurrency/include/hpx/concurrency/concurrentqueue.hpp M libs/core/concurrency/include/hpx/concurrency/stack.hpp M libs/core/concurrency/tests/unit/contiguous_index_queue.cpp M libs/core/concurrency/tests/unit/non_contiguous_index_queue.cpp M libs/core/config/include/hpx/config/compiler_specific.hpp M libs/core/coroutines/include/hpx/coroutines/detail/context_base.hpp M libs/core/coroutines/include/hpx/coroutines/detail/context_linux_x86.hpp M libs/core/datastructures/include/hpx/datastructures/any.hpp M libs/core/datastructures/include/hpx/datastructures/detail/dynamic_bitset.hpp M libs/core/datastructures/include/hpx/datastructures/detail/optional.hpp M libs/core/datastructures/include/hpx/datastructures/detail/small_vector.hpp M libs/core/datastructures/include/hpx/datastructures/serialization/optional.hpp M libs/core/datastructures/include/hpx/datastructures/serialization/serializable_any.hpp M libs/core/datastructures/include/hpx/datastructures/tuple.hpp M libs/core/datastructures/tests/unit/bitset_test.hpp M libs/core/datastructures/tests/unit/dynamic_bitset2.cpp M libs/core/datastructures/tests/unit/dynamic_bitset4.cpp M libs/core/datastructures/tests/unit/small_big_object.hpp M libs/core/datastructures/tests/unit/small_vector.cpp M libs/core/datastructures/tests/unit/tuple.cpp M libs/core/debugging/src/backtrace.cpp M libs/core/debugging/src/print.cpp M libs/core/errors/include/hpx/errors/exception_info.hpp M libs/core/execution/include/hpx/execution/algorithms/detail/inject_scheduler.hpp M libs/core/execution/include/hpx/execution/algorithms/detail/partial_algorithm.hpp M libs/core/execution/include/hpx/execution/algorithms/detail/predicates.hpp M libs/core/execution/include/hpx/execution/algorithms/make_future.hpp M libs/core/execution/include/hpx/execution/algorithms/run_loop.hpp M libs/core/execution/include/hpx/execution/algorithms/when_all.hpp M libs/core/execution/include/hpx/execution/algorithms/when_all_vector.hpp M libs/core/execution/include/hpx/execution/executors/auto_chunk_size.hpp M libs/core/execution/include/hpx/execution/executors/execution.hpp M libs/core/execution/include/hpx/execution/executors/guided_chunk_size.hpp M libs/core/execution/include/hpx/execution/executors/num_cores.hpp M libs/core/execution/include/hpx/execution/executors/persistent_auto_chunk_size.hpp M libs/core/execution/include/hpx/execution/executors/polymorphic_executor.hpp M libs/core/execution/include/hpx/execution/traits/detail/eve/vector_pack_get_set.hpp M libs/core/execution/tests/regressions/fibonacci_sr.cpp M libs/core/execution/tests/unit/algorithm_run_loop.cpp M libs/core/execution/tests/unit/algorithm_sync_wait.cpp M libs/core/execution/tests/unit/algorithm_sync_wait_with_variant.cpp M libs/core/execution/tests/unit/foreach_tests.hpp M libs/core/execution_base/include/hpx/execution_base/any_sender.hpp M libs/core/execution_base/include/hpx/execution_base/completion_signatures.hpp M libs/core/execution_base/src/this_thread.cpp M libs/core/execution_base/tests/include/algorithm_test_utils.hpp M libs/core/execution_base/tests/include/coroutine_task.hpp M libs/core/execution_base/tests/unit/completion_signatures.cpp M libs/core/execution_base/tests/unit/coroutine_utils.cpp M libs/core/execution_base/tests/unit/execution_context.cpp M libs/core/executors/include/hpx/executors/detail/hierarchical_spawning.hpp M libs/core/executors/include/hpx/executors/detail/index_queue_spawning.hpp M libs/core/executors/include/hpx/executors/explicit_scheduler_executor.hpp M libs/core/executors/include/hpx/executors/fork_join_executor.hpp M libs/core/executors/include/hpx/executors/guided_pool_executor.hpp M libs/core/executors/include/hpx/executors/restricted_thread_pool_executor.hpp M libs/core/executors/include/hpx/executors/scheduler_executor.hpp M libs/core/executors/include/hpx/executors/service_executors.hpp M libs/core/executors/include/hpx/executors/thread_pool_scheduler_bulk.hpp M libs/core/executors/tests/unit/created_executor.cpp M libs/core/executors/tests/unit/parallel_executor_parameters.cpp M libs/core/executors/tests/unit/standalone_thread_pool_executor.cpp M libs/core/executors/tests/unit/thread_pool_scheduler.cpp M libs/core/format/src/format.cpp M libs/core/functional/include/hpx/functional/bind.hpp M libs/core/functional/include/hpx/functional/detail/basic_function.hpp M libs/core/functional/include/hpx/functional/detail/vtable/copyable_vtable.hpp M libs/core/functional/include/hpx/functional/detail/vtable/vtable.hpp M libs/core/functional/include/hpx/functional/function_ref.hpp M libs/core/functional/include/hpx/functional/invoke_fused.hpp M libs/core/functional/include/hpx/functional/mem_fn.hpp M libs/core/functional/tests/unit/function_args.cpp M libs/core/functional/tests/unit/function_object_size.cpp M libs/core/functional/tests/unit/function_test.cpp M libs/core/functional/tests/unit/is_invocable.cpp M libs/core/functional/tests/unit/protect_test.cpp M libs/core/functional/tests/unit/scope.cpp M libs/core/futures/include/hpx/futures/detail/future_data.hpp M libs/core/futures/include/hpx/futures/future.hpp M libs/core/futures/include/hpx/futures/traits/acquire_shared_state.hpp M libs/core/futures/tests/unit/future.cpp M libs/core/gasnet_base/src/gasnet_environment.cpp M libs/core/hashing/include/hpx/hashing/jenkins_hash.hpp M libs/core/ini/src/ini.cpp M libs/core/init_runtime_local/src/init_runtime_local.cpp M libs/core/iterator_support/include/hpx/iterator_support/iterator_adaptor.hpp M libs/core/iterator_support/include/hpx/iterator_support/iterator_facade.hpp M libs/core/iterator_support/include/hpx/iterator_support/zip_iterator.hpp M libs/core/iterator_support/tests/performance/stencil3_iterators.cpp M libs/core/iterator_support/tests/unit/counting_iterator.cpp M libs/core/iterator_support/tests/unit/iterator_facade.cpp M libs/core/iterator_support/tests/unit/transform_iterator2.cpp M libs/core/iterator_support/tests/unit/zip_iterator.cpp M libs/core/lci_base/include/hpx/lci_base/lci_environment.hpp M libs/core/lcos_local/tests/unit/channel_local.cpp M libs/core/logging/include/hpx/modules/logging.hpp M libs/core/memory/tests/unit/intrusive_ptr_polymorphic.cpp M libs/core/memory/tests/unit/intrusive_ptr_polymorphic_nonintrusive.cpp M libs/core/memory/tests/unit/serialization_intrusive_ptr.cpp M libs/core/pack_traversal/include/hpx/pack_traversal/detail/pack_traversal_impl.hpp M libs/core/pack_traversal/include/hpx/pack_traversal/unwrap.hpp M libs/core/pack_traversal/tests/unit/pack_traversal.cpp M libs/core/pack_traversal/tests/unit/pack_traversal_async.cpp M libs/core/plugin/include/hpx/plugin/export_plugin.hpp M libs/core/plugin/include/hpx/plugin/virtual_constructor.hpp M libs/core/prefix/src/find_prefix.cpp M libs/core/program_options/examples/options_hierarchy.cpp M libs/core/program_options/include/hpx/program_options/eof_iterator.hpp M libs/core/program_options/include/hpx/program_options/errors.hpp M libs/core/program_options/include/hpx/program_options/value_semantic.hpp M libs/core/program_options/src/cmdline.cpp M libs/core/program_options/src/config_file.cpp M libs/core/program_options/src/options_description.cpp M libs/core/program_options/src/parsers.cpp M libs/core/program_options/src/split.cpp M libs/core/program_options/tests/unit/optional.cpp M libs/core/resiliency/examples/1d_stencil_replay_exception.cpp M libs/core/resiliency/examples/1d_stencil_replay_validate.cpp M libs/core/resiliency/include/hpx/resiliency/async_replicate.hpp M libs/core/resiliency/include/hpx/resiliency/async_replicate_executor.hpp M libs/core/resiliency/include/hpx/resiliency/replay_executor.hpp M libs/core/resiliency/include/hpx/resiliency/replicate_executor.hpp M libs/core/resiliency/include/hpx/resiliency/resiliency_cpos.hpp M libs/core/resiliency/tests/performance/replay/1d_stencil.cpp M libs/core/resiliency/tests/performance/replay/1d_stencil_checksum.cpp M libs/core/resiliency/tests/performance/replay/1d_stencil_replay.cpp M libs/core/resiliency/tests/performance/replay/dataflow_replay.cpp M libs/core/resiliency/tests/performance/replay/dataflow_replay_validate.cpp M libs/core/resiliency/tests/performance/replay/pure_dataflow.cpp M libs/core/resiliency/tests/performance/replicate/1d_stencil_replicate.cpp M libs/core/resiliency/tests/performance/replicate/1d_stencil_replicate_checksum.cpp M libs/core/resource_partitioner/examples/guided_pool_test.cpp M libs/core/resource_partitioner/examples/oversubscribing_resource_partitioner.cpp M libs/core/resource_partitioner/examples/simple_resource_partitioner.cpp M libs/core/resource_partitioner/tests/unit/cross_pool_injection.cpp M libs/core/resource_partitioner/tests/unit/named_pool_executor.cpp M libs/core/resource_partitioner/tests/unit/resource_partitioner_info.cpp M libs/core/resource_partitioner/tests/unit/shutdown_suspended_pus.cpp M libs/core/resource_partitioner/tests/unit/suspend_disabled.cpp M libs/core/resource_partitioner/tests/unit/suspend_pool.cpp M libs/core/resource_partitioner/tests/unit/suspend_pool_external.cpp M libs/core/resource_partitioner/tests/unit/suspend_runtime.cpp M libs/core/resource_partitioner/tests/unit/suspend_thread.cpp M libs/core/resource_partitioner/tests/unit/suspend_thread_external.cpp M libs/core/resource_partitioner/tests/unit/suspend_thread_timed.cpp M libs/core/resource_partitioner/tests/unit/used_pus.cpp M libs/core/runtime_configuration/include/hpx/runtime_configuration/static_factory_data.hpp M libs/core/runtime_configuration/src/init_ini_data.cpp M libs/core/runtime_configuration/src/runtime_mode.cpp M libs/core/runtime_local/include/hpx/runtime_local/run_as_hpx_thread.hpp M libs/core/runtime_local/src/interval_timer.cpp M libs/core/runtime_local/src/pool_timer.cpp M libs/core/runtime_local/src/runtime_local.cpp M libs/core/runtime_local/src/serialize_exception.cpp M libs/core/schedulers/include/hpx/schedulers/local_priority_queue_scheduler.hpp M libs/core/schedulers/include/hpx/schedulers/local_queue_scheduler.hpp M libs/core/schedulers/include/hpx/schedulers/queue_holder_numa.hpp M libs/core/schedulers/include/hpx/schedulers/queue_holder_thread.hpp M libs/core/schedulers/include/hpx/schedulers/shared_priority_queue_scheduler.hpp M libs/core/schedulers/include/hpx/schedulers/static_queue_scheduler.hpp M libs/core/schedulers/include/hpx/schedulers/thread_queue.hpp M libs/core/serialization/include/hpx/serialization/basic_archive.hpp M libs/core/serialization/include/hpx/serialization/detail/constructor_selector.hpp M libs/core/serialization/include/hpx/serialization/detail/pointer.hpp M libs/core/serialization/include/hpx/serialization/detail/polymorphic_nonintrusive_factory.hpp M libs/core/serialization/include/hpx/serialization/input_archive.hpp M libs/core/serialization/include/hpx/serialization/output_archive.hpp M libs/core/serialization/include/hpx/serialization/output_container.hpp M libs/core/serialization/include/hpx/serialization/serialization_chunk.hpp M libs/core/serialization/tests/regressions/buffer_overrun_2839.cpp M libs/core/serialization/tests/regressions/serialization_unsigned_buffer.cpp M libs/core/serialization/tests/unit/polymorphic/polymorphic_nonintrusive.cpp M libs/core/serialization/tests/unit/polymorphic/polymorphic_nonintrusive_abstract.cpp M libs/core/serialization/tests/unit/polymorphic/polymorphic_pointer.cpp M libs/core/serialization/tests/unit/polymorphic/polymorphic_reference.cpp M libs/core/serialization/tests/unit/polymorphic/polymorphic_semiintrusive_template.cpp M libs/core/serialization/tests/unit/polymorphic/polymorphic_template.cpp M libs/core/serialization/tests/unit/polymorphic/smart_ptr_polymorphic.cpp M libs/core/serialization/tests/unit/polymorphic/smart_ptr_polymorphic_nonintrusive.cpp M libs/core/serialization/tests/unit/serialization_array.cpp M libs/core/serialization/tests/unit/serialization_builtins.cpp M libs/core/serialization/tests/unit/serialization_complex.cpp M libs/core/serialization/tests/unit/serialization_custom_constructor.cpp M libs/core/serialization/tests/unit/serialization_deque.cpp M libs/core/serialization/tests/unit/serialization_list.cpp M libs/core/serialization/tests/unit/serialization_map.cpp M libs/core/serialization/tests/unit/serialization_set.cpp M libs/core/serialization/tests/unit/serialization_simple.cpp M libs/core/serialization/tests/unit/serialization_smart_ptr.cpp M libs/core/serialization/tests/unit/serialization_std_variant.cpp M libs/core/serialization/tests/unit/serialization_unordered_map.cpp M libs/core/serialization/tests/unit/serialization_valarray.cpp M libs/core/serialization/tests/unit/serialization_vector.cpp M libs/core/serialization/tests/unit/serialize_with_incompatible_signature.cpp M libs/core/serialization/tests/unit/small_big_object.hpp M libs/core/static_reinit/include/hpx/static_reinit/reinitializable_static.hpp M libs/core/string_util/include/hpx/string_util/token_functions.hpp M libs/core/synchronization/include/hpx/synchronization/async_rw_mutex.hpp M libs/core/synchronization/include/hpx/synchronization/counting_semaphore.hpp M libs/core/synchronization/include/hpx/synchronization/sliding_semaphore.hpp M libs/core/synchronization/src/detail/sliding_semaphore.cpp M libs/core/synchronization/src/stop_token.cpp M libs/core/tag_invoke/include/hpx/functional/detail/invoke.hpp M libs/core/tag_invoke/include/hpx/functional/detail/tag_fallback_invoke.hpp M libs/core/tag_invoke/include/hpx/functional/detail/tag_priority_invoke.hpp M libs/core/tag_invoke/include/hpx/functional/invoke_result.hpp M libs/core/tag_invoke/include/hpx/functional/tag_invoke.hpp M libs/core/thread_pools/include/hpx/thread_pools/detail/scheduling_callbacks.hpp M libs/core/thread_pools/include/hpx/thread_pools/scheduled_thread_pool.hpp M libs/core/threading/src/thread.cpp M libs/core/threading/tests/unit/condition_variable2.cpp M libs/core/threading/tests/unit/in_place_stop_token_cb1.cpp M libs/core/threading/tests/unit/jthread1.cpp M libs/core/threading/tests/unit/stop_token_cb1.cpp M libs/core/threading_base/include/hpx/threading_base/execution_agent.hpp M libs/core/threading_base/include/hpx/threading_base/thread_helpers.hpp M libs/core/threading_base/src/scheduler_base.cpp M libs/core/threading_base/src/thread_pool_base.cpp M libs/core/threading_base/tests/regressions/thread_stacksize_current.cpp M libs/core/threadmanager/src/threadmanager.cpp M libs/core/timing/include/hpx/timing/high_resolution_clock.hpp M libs/core/timing/include/hpx/timing/high_resolution_timer.hpp M libs/core/topology/src/topology.cpp M libs/core/type_support/CMakeLists.txt A libs/core/type_support/include/hpx/type_support/aligned_storage.hpp M libs/core/type_support/include/hpx/type_support/construct_at.hpp M libs/core/type_support/include/hpx/type_support/generator.hpp M libs/core/type_support/include/hpx/type_support/static.hpp M libs/core/type_support/include/hpx/type_support/unwrap_ref.hpp M libs/core/type_support/tests/unit/fail_relocate_at.cpp M libs/core/type_support/tests/unit/fail_uninitialized_relocate.cpp M libs/core/type_support/tests/unit/generator.cpp M libs/core/type_support/tests/unit/is_trivially_relocatable.cpp M libs/core/util/include/hpx/util/max.hpp M libs/core/util/include/hpx/util/min.hpp M libs/full/actions/tests/performance/serialization_overhead.cpp M libs/full/actions_base/include/hpx/actions_base/basic_action.hpp M libs/full/actions_base/include/hpx/actions_base/component_action.hpp M libs/full/agas/src/addressing_service.cpp M libs/full/agas/tests/regressions/register_with_basename_1804.cpp M libs/full/agas_base/src/server/locality_namespace_server.cpp M libs/full/agas_base/src/server/primary_namespace_server.cpp M libs/full/async_distributed/include/hpx/async_distributed/bind_action.hpp M libs/full/async_distributed/include/hpx/async_distributed/detail/post_implementations.hpp M libs/full/async_distributed/include/hpx/async_distributed/detail/promise_lco.hpp M libs/full/async_distributed/include/hpx/async_distributed/packaged_action.hpp M libs/full/async_distributed/include/hpx/async_distributed/set_lco_value_continuation.hpp M libs/full/async_distributed/tests/regressions/components/movable_objects.cpp M libs/full/async_distributed/tests/regressions/dataflow_791.cpp M libs/full/async_distributed/tests/regressions/return_non_default_constructible_2847.cpp M libs/full/checkpoint/examples/1d_stencil_4_checkpoint.cpp M libs/full/checkpoint/examples/print_time_results.hpp M libs/full/checkpoint/include/hpx/checkpoint/checkpoint.hpp M libs/full/collectives/examples/distributed_pi.cpp M libs/full/collectives/include/hpx/collectives/broadcast_direct.hpp M libs/full/collectives/include/hpx/collectives/reduce_direct.hpp M libs/full/collectives/include/hpx/collectives/spmd_block.hpp M libs/full/collectives/src/detail/barrier_node.cpp M libs/full/collectives/tests/performance/lcos/barrier_performance.cpp M libs/full/collectives/tests/performance/osu/broadcast.hpp M libs/full/collectives/tests/performance/osu/osu_bibw.cpp M libs/full/collectives/tests/performance/osu/osu_bw.cpp M libs/full/collectives/tests/performance/osu/osu_coll.hpp M libs/full/collectives/tests/performance/osu/osu_multi_lat.cpp M libs/full/collectives/tests/unit/concurrent_collectives.cpp M libs/full/collectives/tests/unit/global_spmd_block.cpp M libs/full/collectives/tests/unit/remote_latch.cpp M libs/full/command_line_handling/src/command_line_handling.cpp M libs/full/components/include/hpx/components/client_base.hpp M libs/full/components/src/basename_registration.cpp M libs/full/components_base/include/hpx/components_base/server/abstract_component_base.hpp M libs/full/components_base/include/hpx/components_base/server/abstract_migration_support.hpp M libs/full/components_base/include/hpx/components_base/server/component_base.hpp M libs/full/components_base/include/hpx/components_base/server/fixed_component_base.hpp M libs/full/components_base/include/hpx/components_base/server/managed_component_base.hpp M libs/full/components_base/include/hpx/components_base/server/wrapper_heap_list.hpp M libs/full/components_base/src/generate_unique_ids.cpp M libs/full/compute/include/hpx/compute/detail/target_distribution_policy.hpp M libs/full/distribution_policies/include/hpx/distribution_policies/container_distribution_policy.hpp M libs/full/distribution_policies/src/binpacking_distribution_policy.cpp M libs/full/include/include/hpx/include/util.hpp M libs/full/init_runtime/src/hpx_init.cpp M libs/full/init_runtime/src/init_logging.cpp M libs/full/lcos_distributed/tests/unit/channel.cpp M libs/full/naming/src/credit_handling.cpp M libs/full/naming_base/include/hpx/naming_base/gid_type.hpp M libs/full/naming_base/src/gid_type.cpp M libs/full/parcelport_gasnet/include/hpx/parcelport_gasnet/sender_connection.hpp M libs/full/parcelport_lci/include/hpx/parcelport_lci/completion_manager_base.hpp M libs/full/parcelport_lci/src/parcelport_lci.cpp M libs/full/parcelport_lci/src/putva/sender_connection_putva.cpp M libs/full/parcelport_lci/src/sendrecv/sender_connection_sendrecv.cpp M libs/full/parcelport_mpi/include/hpx/parcelport_mpi/sender_connection.hpp M libs/full/parcelport_tcp/include/hpx/parcelport_tcp/receiver.hpp M libs/full/parcelport_tcp/include/hpx/parcelport_tcp/sender.hpp M libs/full/parcelport_tcp/src/connection_handler_tcp.cpp M libs/full/parcelset/include/hpx/parcelset/decode_parcels.hpp M libs/full/parcelset/include/hpx/parcelset/encode_parcels.hpp M libs/full/parcelset/include/hpx/parcelset/parcelport_connection.hpp M libs/full/parcelset/include/hpx/parcelset/parcelport_impl.hpp M libs/full/parcelset/src/detail/parcel_await.cpp M libs/full/parcelset/tests/regressions/very_big_tchunk.cpp M libs/full/parcelset_base/include/hpx/parcelset_base/detail/gatherer.hpp M libs/full/parcelset_base/src/parcelport.cpp M libs/full/performance_counters/include/hpx/performance_counters/base_performance_counter.hpp M libs/full/performance_counters/include/hpx/performance_counters/counters.hpp M libs/full/performance_counters/include/hpx/performance_counters/counters_fwd.hpp M libs/full/performance_counters/src/locality_namespace_counters.cpp M libs/full/performance_counters/src/primary_namespace_counters.cpp M libs/full/performance_counters/src/registry.cpp M libs/full/performance_counters/src/server/arithmetics_counter.cpp M libs/full/performance_counters/src/server/arithmetics_counter_extended.cpp M libs/full/performance_counters/src/server/statistics_counter.cpp M libs/full/performance_counters/src/threadmanager_counter_types.cpp M libs/full/performance_counters/tests/unit/all_counters.cpp M libs/full/resiliency_distributed/include/hpx/resiliency_distributed/async_replicate_distributed.hpp M libs/full/resiliency_distributed/tests/performance/replay/1d_stencil_distributed.cpp M libs/full/resiliency_distributed/tests/performance/replay/1d_stencil_replay_distributed.cpp M libs/full/runtime_components/include/hpx/runtime_components/server/console_logging.hpp M libs/full/runtime_components/tests/unit/components/migrate_component.cpp M libs/full/runtime_components/tests/unit/components/migrate_polymorphic_component.cpp M libs/full/runtime_distributed/src/big_boot_barrier.cpp M libs/full/segmented_algorithms/include/hpx/parallel/segmented_algorithms/adjacent_find.hpp M libs/full/segmented_algorithms/include/hpx/parallel/segmented_algorithms/count.hpp M libs/full/segmented_algorithms/include/hpx/parallel/segmented_algorithms/detail/scan.hpp M libs/full/segmented_algorithms/include/hpx/parallel/segmented_algorithms/exclusive_scan.hpp M libs/full/segmented_algorithms/include/hpx/parallel/segmented_algorithms/fill.hpp M libs/full/segmented_algorithms/include/hpx/parallel/segmented_algorithms/find.hpp M libs/full/segmented_algorithms/include/hpx/parallel/segmented_algorithms/generate.hpp M libs/full/segmented_algorithms/include/hpx/parallel/segmented_algorithms/inclusive_scan.hpp M libs/full/segmented_algorithms/include/hpx/parallel/segmented_algorithms/minmax.hpp M libs/full/segmented_algorithms/include/hpx/parallel/segmented_algorithms/reduce.hpp M libs/full/segmented_algorithms/include/hpx/parallel/segmented_algorithms/transform.hpp M libs/full/segmented_algorithms/include/hpx/parallel/segmented_algorithms/transform_reduce.hpp M libs/full/segmented_algorithms/tests/unit/partitioned_vector_iter.cpp M tests/performance/local/agas_cache_timings.cpp M tests/performance/local/async_overheads.cpp M tests/performance/local/future_overhead.cpp M tests/performance/local/future_overhead_report.cpp M tests/performance/local/hpx_heterogeneous_timed_task_spawn.cpp M tests/performance/local/htts_v2/htts2_hpx.cpp M tests/performance/local/htts_v2/htts2_payload_precision.cpp M tests/performance/local/nonconcurrent_fifo_overhead.cpp M tests/performance/local/nonconcurrent_lifo_overhead.cpp M tests/performance/local/partitioned_vector_foreach.cpp M tests/performance/local/qthreads_homogeneous_timed_task_spawn.cpp M tests/performance/local/spinlock_overhead1.cpp M tests/performance/local/spinlock_overhead2.cpp M tests/performance/local/stream.cpp M tests/performance/local/stream_report.cpp M tests/performance/local/transform_reduce_binary_scaling.cpp M tests/performance/local/wait_all_timings.cpp M tests/performance/network/network_storage/network_storage.cpp M tests/performance/network/network_storage/simple_profiler.hpp M tests/regressions/block_matrix/main.cpp M tests/regressions/block_matrix/matrix.cpp M tests/regressions/block_matrix/matrix.hpp M tests/regressions/block_matrix/tests.cpp M tests/regressions/lcos/sliding_semaphore_2338.cpp M tests/regressions/threads/block_os_threads_1036.cpp M tools/docker/Dockerfile M tools/hpxdep/hpxdep.cpp M tools/inspect/ascii_check.cpp M tools/inspect/inspect.cpp M tools/inspect/link_check.cpp M tools/inspect/path_name_check.cpp Log Message: ----------- Merge pull request #6732 from STEllAR-GROUP/c++20-ci Removing support for C++17 Compare: https://github.com/STEllAR-GROUP/hpx/compare/65a105690a52...916b982fa040 To unsubscribe from these emails, change your notification settings at https://github.com/STEllAR-GROUP/hpx/settings/notifications _______________________________________________ hpx-commits mailing list hpx-commits@mail.cct.lsu.edu https://mail.cct.lsu.edu/mailman/listinfo/hpx-commits