Branch: refs/heads/c++20-ci Home: https://github.com/STEllAR-GROUP/hpx Commit: 0b9334eee31c7bc2759948dfc9484ded600d5116 https://github.com/STEllAR-GROUP/hpx/commit/0b9334eee31c7bc2759948dfc9484ded600d5116 Author: Hartmut Kaiser <hartmut.kai...@gmail.com> Date: 2025-07-03 (Thu, 03 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/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_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/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/sort_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/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/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/logging/include/hpx/modules/logging.hpp M libs/core/pack_traversal/include/hpx/pack_traversal/detail/pack_traversal_impl.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/src/config_file.cpp M libs/core/program_options/src/options_description.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/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_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/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/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/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 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> 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