Skip to content

Instantly share code, notes, and snippets.

@nashley
Created January 27, 2022 01:23
Show Gist options
  • Save nashley/ca41d9965beffd1dcd4da9a779aeceb4 to your computer and use it in GitHub Desktop.
Save nashley/ca41d9965beffd1dcd4da9a779aeceb4 to your computer and use it in GitHub Desktop.
Glommio test errors (commit `fe33e30a2d893a19d4022f104335f10243398973` on `rustc 1.58.1 (db9d1b20b 2022-01-20)`)
running 368 tests
test channels::local_channel::test::producer_bounded_has_capacity ... FAILED
test channels::local_channel::test::producer_consumer ... FAILED
test channels::channel_mesh::tests::test_join_more_than_once - should panic ... ok
test channels::channel_mesh::tests::test_join_more_than_capacity - should panic ... ok
test channels::local_channel::test::multiple_task_receivers ... FAILED
test channels::local_channel::test::non_stream_receiver ... FAILED
test channels::local_channel::test::producer_bounded_previously_blocked_still_errors_out ... FAILED
test channels::local_channel::test::producer_bounded_ping_pong ... FAILED
test channels::channel_mesh::tests::test_channel_mesh ... FAILED
test channels::local_channel::test::producer_bounded_early_error ... FAILED
test channels::channel_mesh::tests::test_partial_mesh ... FAILED
test channels::channel_mesh::tests::test_peer_id_invariance ... FAILED
test channels::local_channel::test::producer_early_drop_receiver ... FAILED
test channels::local_channel::test::producer_parallel_consumer ... FAILED
test channels::local_channel::test::producer_receiver_serialized ... FAILED
test channels::shared_channel::test::consumer_never_connects ... FAILED
test channels::shared_channel::test::non_copy_shared ... FAILED
test channels::shared_channel::test::pass_function ... FAILED
test channels::shared_channel::test::consumer_sleeps_before_producer_produces ... FAILED
test channels::shared_channel::test::destroy_with_pending_wakers ... FAILED
test channels::shared_channel::test::close_sender_while_blocked_on_send ... FAILED
test channels::sharding::tests::test_send ... FAILED
test channels::shared_channel::test::copy_shared ... FAILED
test channels::shared_channel::test::producer_consumer ... FAILED
test channels::shared_channel::test::producer_never_connects ... FAILED
test channels::sharding::tests::test ... FAILED
test channels::shared_channel::test::producer_sleeps_before_consumer_consumes ... FAILED
test channels::shared_channel::test::shared_drop_cascade_drop_executor_reverse ... FAILED
test channels::sharding::tests::test_send_to ... FAILED
test channels::spsc_queue::tests::test_try_poll ... ok
test channels::spsc_queue::tests::test_try_push ... ok
test channels::spsc_queue::tests::test_wrap - should panic ... ok
test channels::shared_channel::test::shared_drop_gets_called_reversed ... FAILED
test controllers::deadline_queue::test::deadline_queue_behaves_well_if_we_process_too_much ... FAILED
test controllers::deadline_queue::test::deadline_queue_second_queued_item_increases_slope ... FAILED
test controllers::deadline_queue::test::deadline_queue_behaves_well_with_zero_total_units ... FAILED
test channels::shared_channel::test::shared_drop_cascade_drop_executor ... FAILED
test controllers::deadline_queue::test::deadline_queue_does_not_accept_non_monotonic_durations ... FAILED
test controllers::deadline_queue::test::deadline_queue_shares_increase_if_we_dont_process ... FAILED
test controllers::deadline_queue::test::deadline_queue_shares_ok_if_we_process_smoothly ... FAILED
test channels::shared_channel::test::shared_drop_gets_called ... FAILED
test error::test::composite_error_from_into ... ok
test error::test::enhance_error ... ok
test error::test::channel_closed_err_msg - should panic ... ok
test error::test::channel_wouldblock_err_msg - should panic ... ok
test controllers::deadline_queue::test::deadline_queue_successfully_drops_item_when_done ... FAILED
test error::test::enhance_error_converted ... ok
test error::test::extended_closed_file_err_msg - should panic ... ok
test error::test::extended_file_err_msg - should panic ... ok
test error::test::file_wouldblock_err_msg - should panic ... ok
test error::test::extended_file_err_msg_unwrap - should panic ... ok
test error::test::queue_not_found_err_msg - should panic ... ok
test error::test::queue_still_active_err_msg - should panic ... ok
test error::test::rwlock_closed_err_msg - should panic ... ok
test error::test::rwlock_wouldblock_err_msg - should panic ... ok
test error::test::semaphore_closed_err_msg - should panic ... ok
test error::test::semaphore_wouldblock_err_msg - should panic ... ok
test executor::placement::test::cpuset_difference ... ok
test executor::placement::test::cpuset_disjoint ... ok
test executor::placement::test::cpuset_iterate ... ok
test executor::placement::test::cpuset_intersection ... ok
test executor::placement::test::cpuset_subset_and_superset ... ok
test executor::placement::test::cpuset_symmetric_difference ... ok
test executor::placement::test::cpuset_union ... ok
test executor::placement::test::custom_placement ... ok
test channels::shared_channel::test::producer_stream_consumer ... FAILED
test executor::placement::test::cpu_set ... ok
test executor::placement::test::max_packer_with_topology_empty ... ok
test executor::placement::pq_tree::test::construct_pq_tree_pack ... ok
test executor::placement::pq_tree::test::construct_pq_tree_spread ... ok
test executor::placement::test::max_spreader_with_topology_empty ... ok
test executor::placement::test::max_spreader_with_topology_1 ... ok
test executor::placement::test::max_spreader_with_topology_0 ... ok
test executor::placement::test::placement_max_pack_clone ... ok
test executor::placement::test::max_spreader_with_topology_2 ... ok
test executor::placement::test::placement_fenced_clone ... ok
test executor::stall::test::executor_stall_detector ... FAILED
test executor::placement::test::placement_max_spread_clone ... ok
test executor::placement::test::placement_custom_clone ... ok
test executor::placement::test::placement_unbound_clone ... ok
test executor::test::bind_to_cpu_set_range ... ok
test executor::test::blocking_function ... FAILED
test executor::stall::test::stall_detector_correct_signal_handler ... FAILED
test executor::stall::test::stall_detector_multiple_signals ... FAILED
test executor::test::create_and_destroy_executor ... FAILED
test executor::test::blocking_pool_invalid_placement ... ok
test executor::test::create_and_bind ... FAILED
test executor::test::cross_executor_wake_by_ref ... FAILED
test executor::test::create_fail_to_bind ... ok
test executor::test::cross_executor_wake_early_drop ... FAILED
test executor::test::cross_executor_wake_hold_waker ... FAILED
test executor::test::cross_executor_wake_with_join_handle ... FAILED
test executor::test::current_task_queue_matches ... FAILED
test executor::test::executor_invalid_executor_count ... ok
test executor::test::executor_inception - should panic ... ok
test channels::shared_channel::test::send_to_full_channel ... FAILED
test executor::test::executor_pool_builder_return_values ... FAILED
test executor::placement::test::max_spreader_this_machine ... ok
test executor::test::cross_executor_wake_by_value ... FAILED
test channels::spsc_queue::tests::test_threaded ... ok
test executor::placement::test::max_packer_numa_in_pkg ... ok
test executor::placement::test::max_packer_with_topology_0 ... ok
test executor::placement::test::max_packer_this_machine ... ok
test executor::test::blocking_function_parallelism ... FAILED
test executor::test::invalid_task_queue ... FAILED
test executor::test::multiple_spawn ... FAILED
test executor::test::spawn_without_executor - should panic ... ok
test executor::test::panic_is_not_list - should panic ... FAILED
test executor::test::executor_pool_builder ... FAILED
test executor::test::scoped_task ... FAILED
test executor::test::ten_yielding_queues ... FAILED
test executor::test::task_optimized_for_throughput ... FAILED
test executor::test::task_with_latency_requirements ... FAILED
test executor::test::executor_pool_builder_placements ... FAILED
test executor::test::test_allocate_dma_buffer_global ... FAILED
test executor::test::test_allocate_dma_buffer ... FAILED
test executor::test::test_no_spin ... FAILED
test executor::test::test_detach ... FAILED
test executor::test::test_dynamic_shares ... FAILED
test executor::test::executor_pool_builder_thread_panic ... ok
test executor::test::wake_refcount_underflow_with_join_handle ... FAILED
test executor::test::test_spin ... FAILED
test executor::test::test_shares_high_disparity_fat_task ... FAILED
test executor::test::test_shares_low_disparity_fat_task ... FAILED
test executor::test::wake_refcount_underflow_with_sleep ... FAILED
test free_list::free_list_smoke_test ... ok
test executor::test::wake_by_ref_refcount_underflow_with_sleep ... FAILED
test executor::test::test_runtime_stats ... FAILED
test executor::test::wake_by_ref_refcount_underflow_with_join_handle ... FAILED
test io::buffered_file::test::file_create_close ... FAILED
test io::buffered_file::test::random_io ... FAILED
test io::buffered_file::test::file_open ... FAILED
test io::buffered_file::test::file_open_nonexistent ... FAILED
test io::buffered_file_stream::test::lines ... FAILED
test io::buffered_file_stream::test::mix_and_match_apis ... FAILED
test io::buffered_file::test::write_past_end ... FAILED
test io::buffered_file_stream::test::read_line ... FAILED
test io::buffered_file_stream::test::read_exact_part_of_file ... FAILED
test io::buffered_file_stream::test::nop_seek_write ... FAILED
test io::buffered_file_stream::test::read_slice ... FAILED
test io::buffered_file_stream::test::read_exact_empty_file ... FAILED
test io::buffered_file_stream::test::read_to_end_after_seek ... FAILED
test io::buffered_file_stream::test::read_until ... FAILED
test io::buffered_file_stream::test::read_to_end_from_start ... FAILED
test io::buffered_file_stream::test::read_until_eof ... FAILED
test io::buffered_file_stream::test::read_until_empty_file ... FAILED
test io::buffered_file_stream::test::split ... FAILED
test io::buffered_file_stream::test::seek_end_and_read_exact ... FAILED
test io::buffered_file_stream::test::seek_and_write ... FAILED
test io::buffered_file_stream::test::write_and_flush ... FAILED
test io::buffered_file_stream::test::seek_start_and_read_exact ... FAILED
test io::buffered_file_stream::test::write_simple ... FAILED
test io::bulk_io::tests::monotonic_iovec_merging ... FAILED
test io::bulk_io::tests::read_no_coalescing ... FAILED
test io::bulk_io::tests::large_input_passthrough ... FAILED
test io::bulk_io::tests::read_amplification_limit ... FAILED
test io::bulk_io::tests::nonmonotonic_iovec_merging ... FAILED
test io::dma_file::test::cancellation_doest_crash_futures_not_polled ... FAILED
test io::dma_file::test::cancellation_doest_crash_futures_polled ... FAILED
test io::dma_file::test::file_empty_read ... FAILED
test io::dma_file::test::file_fallocate_alocatee ... FAILED
test io::dma_file::test::file_many_reads_unaligned ... FAILED
test io::dma_file::test::file_invalid_readonly_write ... FAILED
test io::dma_file::test::file_create_close ... FAILED
test io::dma_file::test::file_many_reads_no_coalescing ... FAILED
test io::dma_file::test::file_many_reads ... FAILED
test io::dma_file::test::file_fallocate_zero ... FAILED
test io::dma_file::test::file_open ... FAILED
test io::dma_file::test::file_open_nonexistent ... FAILED
test io::dma_file::test::file_rename ... FAILED
test io::dma_file::test::file_path ... FAILED
test io::dma_file::test::file_rename_noop ... FAILED
test io::dma_file::test::is_same_file ... FAILED
test io::dma_file::test::file_simple_readwrite ... FAILED
test io::dma_file::test::per_queue_stats ... FAILED
test io::dma_file_stream::test::flushstate ... FAILED
test io::dma_file_stream::test::flushed_position_big_buffer ... FAILED
test io::dma_file_stream::test::flush_and_drop ... FAILED
test io::dma_file_stream::test::flushed_position_small_buffer ... FAILED
test io::dma_file_stream::test::read_exact_early_eof ... FAILED
test io::dma_file_stream::test::read_exact_empty_file ... FAILED
test io::dma_file_stream::test::poll_reader_repeatedly ... FAILED
test io::dma_file_stream::test::read_exact_crosses_buffer ... FAILED
test io::dma_file_stream::test::read_exact_late_start ... FAILED
test io::dma_file_stream::test::read_exact_skip ... FAILED
test io::dma_file_stream::test::read_exact_single_buffer ... FAILED
test io::dma_file_stream::test::read_exact_unaligned_file_size ... FAILED
test io::dma_file_stream::test::read_exact_zero_buffer ... FAILED
test io::dma_file_stream::test::read_get_buffer_aligned ... FAILED
test io::dma_file_stream::test::read_get_buffer_aligned_cross_boundaries ... FAILED
test io::dma_file_stream::test::read_get_buffer_aligned_zero_buffer ... FAILED
test io::dma_file_stream::test::read_get_buffer_aligned_past_the_end ... FAILED
test io::dma_file_stream::test::read_get_buffer_aligned_entire_buffer_at_once ... FAILED
test io::dma_file_stream::test::read_mixed_api ... FAILED
test io::dma_file_stream::test::read_simple ... FAILED
test io::dma_file_stream::test::read_to_end_after_skip ... FAILED
test io::dma_file_stream::test::read_to_end_buffer_crossing ... FAILED
test io::dma_file_stream::test::read_to_end_of_empty_file ... FAILED
test io::dma_file_stream::test::read_to_end_no_read_ahead ... FAILED
test io::dma_file_stream::test::read_wronly_file ... FAILED
test io::dma_file_stream::test::read_to_end_buffer_crossing_read_ahead ... FAILED
test io::dma_file_stream::test::sync_and_close ... FAILED
test io::dma_file_stream::test::write_close_twice ... FAILED
test io::dma_file_stream::test::read_to_end_single_buffer ... FAILED
test io::dma_file_stream::test::write_all ... FAILED
test io::dma_file_stream::test::write_more_than_write_behind ... FAILED
test io::dma_file_stream::test::write_no_write_behind ... FAILED
test io::dma_file_stream::test::write_multibuffer ... FAILED
test io::dma_file_stream::test::write_with_readable_file ... FAILED
test io::immutable_file::test::seal_and_stream ... FAILED
test io::immutable_file::test::seal_and_random ... FAILED
test io::read_result::tests::equal_struct_size ... ok
test io::immutable_file::test::seal_ready_many ... FAILED
test io::immutable_file::test::fail_reader_on_non_existent - should panic ... ok
test io::glommio_file::test::drop_closes_the_file ... FAILED
test io::immutable_file::test::fail_on_already_existent - should panic ... ok
test io::immutable_file::test::stream_pos ... FAILED
test io::dma_file_stream::test::write_zero_buffer ... FAILED
test io::sched::test::file_hard_link_dedup ... FAILED
test io::sched::test::file_sched_lifetime ... ok
test io::sched::test::file_sched_conflicts ... ok
test io::sched::test::file_sched_drop_orphan ... ok
test io::sched::test::file_opt_out_dedup ... FAILED
test io::sched::test::source_sched_lifetime ... ok
test io::sched::test::source_sched_drop_orphan ... ok
test io::sched::test::file_simple_dedup ... FAILED
test io::sched::test::file_offset_dedup ... FAILED
test io::sched::test::file_simple_dedup_concurrent ... FAILED
test iou::registrar::tests::double_register - should panic ... ok
test iou::registrar::tests::offset_out_of_bounds_update - should panic ... ok
test iou::registrar::tests::empty_unregister_err - should panic ... ok
test iou::registrar::tests::empty_update_err - should panic ... ok
test io::test::remove_nonexistent ... FAILED
test iou::registrar::tests::register_bad_fd - should panic ... ok
test io::sched::test::file_soft_link_dedup ... FAILED
test iou::registrar::tests::placeholder_update ... ok
test iou::registrar::tests::slice_len_out_of_bounds_update - should panic ... ok
test iou::registrar::tests::register_empty_slice - should panic ... ok
test iou::tests::test_resultify ... ok
test net::tcp_socket::tests::accepted_tcp_stream_peer_addr ... FAILED
test iou::registrar::tests::valid_fd_update ... ok
test net::tcp_socket::tests::connect_and_ping_pong ... FAILED
test net::tcp_socket::tests::multi_executor_bind_works ... FAILED
test net::tcp_socket::tests::overconsume ... FAILED
test net::tcp_socket::tests::connect_local_server ... FAILED
test net::tcp_socket::tests::repeated_fill_before_consume ... FAILED
test net::tcp_socket::tests::multibuf_fill ... FAILED
test net::tcp_socket::tests::parallel_accept ... FAILED
test net::tcp_socket::tests::tcp_connect_timeout ... FAILED
test net::tcp_socket::tests::multi_executor_accept ... FAILED
test net::tcp_socket::tests::peek ... FAILED
test net::tcp_socket::tests::tcp_connect_timeout_error ... FAILED
test net::tcp_socket::tests::stream_of_connections ... FAILED
test net::tcp_socket::tests::tcp_force_poll ... FAILED
test net::tcp_socket::tests::tcp_stream_ttl ... FAILED
test net::tcp_socket::tests::tcp_read_timeout ... FAILED
test net::tcp_socket::tests::tcp_listener_ttl ... FAILED
test net::tcp_socket::tests::tcp_invalid_timeout ... FAILED
test net::tcp_socket::tests::tcp_stream_nodelay ... FAILED
test net::tcp_socket::tests::test_lines ... FAILED
test net::udp_socket::tests::broadcast ... FAILED
test net::tcp_socket::tests::test_read_line ... FAILED
test net::tcp_socket::tests::test_read_until ... FAILED
test net::udp_socket::tests::peek ... FAILED
test net::udp_socket::tests::multicast_v4 ... FAILED
test net::udp_socket::tests::multi_executor_bind_works ... FAILED
test net::udp_socket::tests::multicast_v6 ... FAILED
test net::udp_socket::tests::peekfrom_blocking ... FAILED
test net::udp_socket::tests::recvfrom_blocking ... FAILED
test net::udp_socket::tests::recvfrom_non_blocking ... FAILED
test net::udp_socket::tests::sendto ... FAILED
test net::udp_socket::tests::peekfrom_non_blocking ... FAILED
test net::udp_socket::tests::sendto_blocking ... FAILED
test net::udp_socket::tests::set_multicast_ttl_v4 ... FAILED
test net::udp_socket::tests::set_multicast_loop_v6 ... FAILED
test net::udp_socket::tests::set_multicast_loop_v4 ... FAILED
test net::udp_socket::tests::udp_connect_peers ... FAILED
test net::udp_socket::tests::set_ttl ... FAILED
test net::udp_socket::tests::udp_connected_ping_pong ... FAILED
test net::udp_socket::tests::udp_unconnected_peek - should panic ... ok
test net::udp_socket::tests::udp_connected_recv_filter ... FAILED
test net::udp_socket::tests::zero_sized_send ... FAILED
test net::udp_socket::tests::udp_unconnected_recv - should panic ... ok
test net::udp_socket::tests::udp_unconnected_send - should panic ... ok
test net::unix::tests::connect_local_server ... FAILED
test net::unix::tests::datagram_connect_unbounded ... FAILED
test net::unix::tests::datagram_pair_ping_pong ... FAILED
test net::unix::tests::datagram_send_recv ... FAILED
test net::unix::tests::datagram_send_to_recv_from ... FAILED
test sync::gate::tests::test_future_close ... FAILED
test net::unix::tests::pair ... FAILED
test sync::gate::tests::test_immediate_close ... FAILED
test sync::rwlock::test::rwlock_overflow ... FAILED
test sync::gate::tests::test_dropped_task ... FAILED
test sync::rwlock::test::rwlock_reentrant ... FAILED
test net::unix::tests::read_until ... FAILED
test sync::rwlock::test::test_close_rr ... FAILED
test sync::rwlock::test::test_get_mut ... ok
test sync::rwlock::test::test_get_mut_close ... ok
test sync::rwlock::test::test_close_rw ... FAILED
test sync::rwlock::test::test_into_inner_close ... ok
test sync::rwlock::test::test_into_inner ... ok
test sync::rwlock::test::test_close_wr ... FAILED
test sync::rwlock::test::test_into_inner_drop ... ok
test sync::rwlock::test::test_frob ... FAILED
test sync::rwlock::test::test_close_ww ... FAILED
test sync::rwlock::test::test_global_lock ... FAILED
test executor::test::executor_pool_builder_shards_limit ... ok
test sync::rwlock::test::test_local_lock ... FAILED
test sync::rwlock::test::test_smoke ... FAILED
test sync::rwlock::test::test_try_read ... FAILED
test sync::rwlock::test::test_ping_pong ... FAILED
test sync::semaphore::test::broken_semaphore_if_acquire_happens_first - should panic ... ok
test sync::rwlock::test::test_try_write ... FAILED
test sync::semaphore::test::broken_semaphore_if_close_happens_first - should panic ... ok
test sync::semaphore::test::explicit_signal_unblocks_waiting_semaphore ... FAILED
test sync::semaphore::test::explicit_signal_unblocks_many_wakers ... FAILED
test sync::semaphore::test::broken_semaphore_returns_the_right_error ... FAILED
test sync::semaphore::test::try_acquire_insufficient_units ... ok
test sync::semaphore::test::try_acquire_permit_insufficient_units ... ok
test sync::semaphore::test::try_acquire_permit_semaphore_is_closed ... ok
test sync::semaphore::test::try_acquire_permit_sufficient_units ... ok
test sync::semaphore::test::permit_raii_works ... FAILED
test sync::semaphore::test::try_acquire_sufficient_units ... ok
test sync::semaphore::test::try_acquire_static_permit_insufficient_units ... ok
test sync::semaphore::test::try_acquire_semaphore_is_closed ... ok
test sync::semaphore::test::try_acquire_static_permit_sufficient_units ... ok
test sys::hardware_topology::test::check_topology_check - should panic ... ok
test sync::semaphore::test::semaphore_overflow ... FAILED
test sync::semaphore::test::semaphore_ensure_execution_order ... FAILED
test sync::semaphore::test::semaphore_acquisition_for_zero_unit_works ... FAILED
test sys::sysfs::test::range_iter ... ok
test sys::uring::tests::allocator_exhaustion ... ok
test sys::uring::tests::allocator ... ok
test sys::hardware_topology::test::machine_topology ... ok
test sys::sysfs::test::list_iterator ... ok
test sys::hardware_topology::test::topology_this_machine_unique_ids ... ok
test sys::sysfs::test::hex_bit_iterator ... ok
test sys::uring::tests::timeout_smoke_test ... FAILED
test sys::uring::tests::sqe_link_chain ... ok
test sys::uring::tests::unterminated_sqe_link_chain - should panic ... ok
test timer::timer_impl::test::basic_timer_action_cancel_fails_if_fired ... FAILED
test sys::uring::tests::sqe_link_chain_overflow - should panic ... ok
test timer::timer_impl::test::basic_timer_action_cancel_works ... FAILED
test timer::timer_impl::test::basic_timer_action_destroy_cancel_initiated_action ... FAILED
test timer::timer_impl::test::basic_timer_action_destroy_detached_spawn_survives ... FAILED
test timer::timer_impl::test::basic_timer_action_destroy_works ... FAILED
test timer::timer_impl::test::basic_timer_action_instant_works ... FAILED
2022-01-27T01:21:48.574925Z ERROR glommio::test_utils: Started tracing..
test timer::timer_impl::test::basic_timer_action_repeat_cancellation_works ... FAILED
test test_utils::test_tracing_init ... ok
test timer::timer_impl::test::basic_timer_action_join_reflects_cancel ... FAILED
test timer::timer_impl::test::basic_timer_action_instant_past_works ... FAILED
test sys::sysfs::test::list_and_mask_iterator_consistent_this_machine_sysfs ... ok
test timer::timer_impl::test::basic_timer_action_repeat_works ... FAILED
test timer::timer_impl::test::basic_timer_action_return_ok ... FAILED
test timer::timer_impl::test::basic_timer_action_works ... FAILED
test timer::timer_impl::test::basic_timer_action_repeat_destruction_works ... FAILED
test timer::timer_impl::test::basic_timer_rearm_executed_action_ok ... FAILED
test timer::timer_impl::test::basic_timer_rearm_future_timer_ok ... FAILED
test timer::timer_impl::test::timeout_does_not_expire ... FAILED
test timer::timer_impl::test::basic_timer_rearm_pending_timer_for_the_past_ok ... FAILED
test timer::timer_impl::test::timeout_expiration_cancels_future ... FAILED
test timer::timer_impl::test::basic_timer_works ... FAILED
test timer::timer_impl::test::test_memory_leak_unfinished_timer ... FAILED
test timer::timer_impl::test::timeout_expires ... FAILED
test executor::latch::test::ready ... ok
test executor::latch::test::cancel ... ok
test executor::test::executor_pool_builder_spawn_cancel ... ok
failures:
---- channels::local_channel::test::producer_bounded_has_capacity stdout ----
thread 'channels::local_channel::test::producer_bounded_has_capacity' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/channels/local_channel.rs:866:9
---- channels::local_channel::test::producer_consumer stdout ----
thread 'channels::local_channel::test::producer_consumer' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/channels/local_channel.rs:764:9
---- channels::local_channel::test::multiple_task_receivers stdout ----
thread 'channels::local_channel::test::multiple_task_receivers' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/channels/local_channel.rs:938:9
---- channels::local_channel::test::non_stream_receiver stdout ----
thread 'channels::local_channel::test::non_stream_receiver' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/channels/local_channel.rs:917:9
note: run with `RUST_BACKTRACE=1` environment variable to display a backtrace
---- channels::local_channel::test::producer_bounded_previously_blocked_still_errors_out stdout ----
thread 'channels::local_channel::test::producer_bounded_previously_blocked_still_errors_out' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/channels/local_channel.rs:896:9
---- channels::local_channel::test::producer_bounded_ping_pong stdout ----
thread 'channels::local_channel::test::producer_bounded_ping_pong' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/channels/local_channel.rs:877:9
---- channels::channel_mesh::tests::test_channel_mesh stdout ----
thread 'channels::channel_mesh::tests::test_channel_mesh' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/channels/channel_mesh.rs:548:32
---- channels::local_channel::test::producer_bounded_early_error stdout ----
thread 'channels::local_channel::test::producer_bounded_early_error' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/channels/local_channel.rs:856:9
---- channels::channel_mesh::tests::test_partial_mesh stdout ----
thread 'channels::channel_mesh::tests::test_partial_mesh' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/channels/channel_mesh.rs:587:32
---- channels::channel_mesh::tests::test_peer_id_invariance stdout ----
thread 'channels::channel_mesh::tests::test_peer_id_invariance' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/channels/channel_mesh.rs:498:32
---- channels::local_channel::test::producer_early_drop_receiver stdout ----
thread 'channels::local_channel::test::producer_early_drop_receiver' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/channels/local_channel.rs:832:9
---- channels::local_channel::test::producer_parallel_consumer stdout ----
thread 'channels::local_channel::test::producer_parallel_consumer' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/channels/local_channel.rs:785:9
---- channels::local_channel::test::producer_receiver_serialized stdout ----
thread 'channels::local_channel::test::producer_receiver_serialized' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/channels/local_channel.rs:812:9
---- channels::shared_channel::test::consumer_never_connects stdout ----
thread 'channels::shared_channel::test::consumer_never_connects' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/channels/shared_channel.rs:685:20
---- channels::shared_channel::test::non_copy_shared stdout ----
thread 'channels::shared_channel::test::non_copy_shared' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/channels/shared_channel.rs:770:20
---- channels::shared_channel::test::pass_function stdout ----
thread 'channels::shared_channel::test::pass_function' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/channels/shared_channel.rs:711:20
---- channels::shared_channel::test::consumer_sleeps_before_producer_produces stdout ----
thread 'channels::shared_channel::test::consumer_sleeps_before_producer_produces' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/channels/shared_channel.rs:581:20
---- channels::shared_channel::test::destroy_with_pending_wakers stdout ----
thread 'channels::shared_channel::test::destroy_with_pending_wakers' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/channels/shared_channel.rs:656:20
---- channels::shared_channel::test::close_sender_while_blocked_on_send stdout ----
thread 'channels::shared_channel::test::close_sender_while_blocked_on_send' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/channels/shared_channel.rs:1005:20
---- channels::sharding::tests::test_send stdout ----
thread 'channels::sharding::tests::test_send' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/channels/sharding.rs:236:31
---- channels::shared_channel::test::copy_shared stdout ----
thread 'channels::shared_channel::test::copy_shared' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/channels/shared_channel.rs:796:20
---- channels::shared_channel::test::producer_consumer stdout ----
thread 'channels::shared_channel::test::producer_consumer' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/channels/shared_channel.rs:527:20
---- channels::shared_channel::test::producer_never_connects stdout ----
thread 'channels::shared_channel::test::producer_never_connects' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/channels/shared_channel.rs:629:20
---- channels::sharding::tests::test stdout ----
thread 'channels::sharding::tests::test' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/channels/sharding.rs:316:31
---- channels::shared_channel::test::producer_sleeps_before_consumer_consumes stdout ----
thread 'channels::shared_channel::test::producer_sleeps_before_consumer_consumes' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/channels/shared_channel.rs:608:20
---- channels::shared_channel::test::shared_drop_cascade_drop_executor_reverse stdout ----
thread 'channels::shared_channel::test::shared_drop_cascade_drop_executor_reverse' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/channels/shared_channel.rs:947:20
---- channels::sharding::tests::test_send_to stdout ----
thread 'channels::sharding::tests::test_send_to' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/channels/sharding.rs:277:31
---- channels::shared_channel::test::shared_drop_gets_called_reversed stdout ----
thread 'channels::shared_channel::test::shared_drop_gets_called_reversed' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/channels/shared_channel.rs:876:20
---- controllers::deadline_queue::test::deadline_queue_behaves_well_if_we_process_too_much stdout ----
thread 'controllers::deadline_queue::test::deadline_queue_behaves_well_if_we_process_too_much' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/controllers/deadline_queue.rs:659:9
---- controllers::deadline_queue::test::deadline_queue_second_queued_item_increases_slope stdout ----
thread 'controllers::deadline_queue::test::deadline_queue_second_queued_item_increases_slope' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/controllers/deadline_queue.rs:738:9
---- controllers::deadline_queue::test::deadline_queue_behaves_well_with_zero_total_units stdout ----
thread 'controllers::deadline_queue::test::deadline_queue_behaves_well_with_zero_total_units' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/controllers/deadline_queue.rs:631:9
---- channels::shared_channel::test::shared_drop_cascade_drop_executor stdout ----
thread 'channels::shared_channel::test::shared_drop_cascade_drop_executor' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/channels/shared_channel.rs:909:20
---- controllers::deadline_queue::test::deadline_queue_does_not_accept_non_monotonic_durations stdout ----
thread 'controllers::deadline_queue::test::deadline_queue_does_not_accept_non_monotonic_durations' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/controllers/deadline_queue.rs:610:9
---- controllers::deadline_queue::test::deadline_queue_shares_increase_if_we_dont_process stdout ----
thread 'controllers::deadline_queue::test::deadline_queue_shares_increase_if_we_dont_process' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/controllers/deadline_queue.rs:681:9
---- controllers::deadline_queue::test::deadline_queue_shares_ok_if_we_process_smoothly stdout ----
thread 'controllers::deadline_queue::test::deadline_queue_shares_ok_if_we_process_smoothly' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/controllers/deadline_queue.rs:701:9
---- channels::shared_channel::test::shared_drop_gets_called stdout ----
thread 'channels::shared_channel::test::shared_drop_gets_called' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/channels/shared_channel.rs:839:20
---- controllers::deadline_queue::test::deadline_queue_successfully_drops_item_when_done stdout ----
thread 'controllers::deadline_queue::test::deadline_queue_successfully_drops_item_when_done' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/controllers/deadline_queue.rs:644:9
---- channels::shared_channel::test::producer_stream_consumer stdout ----
thread 'channels::shared_channel::test::producer_stream_consumer' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/channels/shared_channel.rs:555:20
---- executor::stall::test::executor_stall_detector stdout ----
thread 'executor::stall::test::executor_stall_detector' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/executor/stall.rs:358:14
---- executor::test::blocking_function stdout ----
thread 'executor::test::blocking_function' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/executor/mod.rs:1521:14
---- executor::stall::test::stall_detector_correct_signal_handler stdout ----
thread 'executor::stall::test::stall_detector_correct_signal_handler' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/executor/stall.rs:442:27
---- executor::stall::test::stall_detector_multiple_signals stdout ----
thread 'executor::stall::test::stall_detector_multiple_signals' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/executor/stall.rs:482:27
---- executor::test::create_and_destroy_executor stdout ----
thread 'executor::test::create_and_destroy_executor' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/executor/mod.rs:1521:14
---- executor::test::create_and_bind stdout ----
thread 'executor::test::create_and_bind' panicked at 'got error Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/executor/mod.rs:2705:13
---- executor::test::cross_executor_wake_by_ref stdout ----
thread 'executor::test::cross_executor_wake_by_ref' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/executor/mod.rs:3349:20
---- executor::test::cross_executor_wake_early_drop stdout ----
thread 'executor::test::cross_executor_wake_early_drop' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/executor/mod.rs:3443:20
---- executor::test::cross_executor_wake_hold_waker stdout ----
thread 'executor::test::cross_executor_wake_hold_waker' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/executor/mod.rs:3462:20
---- executor::test::cross_executor_wake_with_join_handle stdout ----
thread 'executor::test::cross_executor_wake_with_join_handle' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/executor/mod.rs:3411:20
---- executor::test::current_task_queue_matches stdout ----
thread 'executor::test::current_task_queue_matches' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/executor/mod.rs:1521:14
---- channels::shared_channel::test::send_to_full_channel stdout ----
thread 'channels::shared_channel::test::send_to_full_channel' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/channels/shared_channel.rs:742:20
---- executor::test::executor_pool_builder_return_values stdout ----
thread 'executor::test::executor_pool_builder_return_values' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', /rustc/db9d1b20bba1968c1ec1fc49616d4742c1725b4b/library/core/src/ops/function.rs:150:5
---- executor::test::cross_executor_wake_by_value stdout ----
thread 'executor::test::cross_executor_wake_by_value' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/executor/mod.rs:3379:20
---- executor::test::blocking_function_parallelism stdout ----
thread 'executor::test::blocking_function_parallelism' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/executor/mod.rs:3957:14
---- executor::test::invalid_task_queue stdout ----
thread 'executor::test::invalid_task_queue' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/executor/mod.rs:1521:14
---- executor::test::multiple_spawn stdout ----
thread 'executor::test::multiple_spawn' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/executor/mod.rs:1521:14
---- executor::test::panic_is_not_list stdout ----
thread 'executor::test::panic_is_not_list' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/executor/mod.rs:1521:14
note: panic did not contain expected string
panic message: `"called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: \"Incorrect source type!\" }"`,
expected substring: `"Message!"`
---- executor::test::executor_pool_builder stdout ----
thread 'executor::test::executor_pool_builder' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', /rustc/db9d1b20bba1968c1ec1fc49616d4742c1725b4b/library/core/src/ops/function.rs:150:5
---- executor::test::scoped_task stdout ----
thread 'executor::test::scoped_task' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/executor/mod.rs:1521:14
---- executor::test::ten_yielding_queues stdout ----
thread 'executor::test::ten_yielding_queues' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/executor/mod.rs:1521:14
---- executor::test::task_optimized_for_throughput stdout ----
thread 'executor::test::task_optimized_for_throughput' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/executor/mod.rs:1521:14
---- executor::test::task_with_latency_requirements stdout ----
thread 'executor::test::task_with_latency_requirements' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/executor/mod.rs:1521:14
---- executor::test::executor_pool_builder_placements stdout ----
thread 'executor::test::executor_pool_builder_placements' panicked at 'assertion failed: r.is_ok()', glommio/src/executor/mod.rs:3560:35
---- executor::test::test_allocate_dma_buffer_global stdout ----
thread 'executor::test::test_allocate_dma_buffer_global' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/executor/mod.rs:1521:14
---- executor::test::test_allocate_dma_buffer stdout ----
thread 'executor::test::test_allocate_dma_buffer' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/executor/mod.rs:1521:14
---- executor::test::test_no_spin stdout ----
thread 'executor::test::test_no_spin' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/executor/mod.rs:1521:14
---- executor::test::test_detach stdout ----
thread 'executor::test::test_detach' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/executor/mod.rs:1521:14
---- executor::test::test_dynamic_shares stdout ----
thread 'executor::test::test_dynamic_shares' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/executor/mod.rs:1521:14
---- executor::test::wake_refcount_underflow_with_join_handle stdout ----
thread 'executor::test::wake_refcount_underflow_with_join_handle' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/executor/mod.rs:1521:14
---- executor::test::test_spin stdout ----
thread 'executor::test::test_spin' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/executor/mod.rs:2996:58
---- executor::test::test_shares_high_disparity_fat_task stdout ----
thread 'executor::test::test_shares_high_disparity_fat_task' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/executor/mod.rs:1521:14
---- executor::test::test_shares_low_disparity_fat_task stdout ----
thread 'executor::test::test_shares_low_disparity_fat_task' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/executor/mod.rs:1521:14
---- executor::test::wake_refcount_underflow_with_sleep stdout ----
thread 'executor::test::wake_refcount_underflow_with_sleep' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/executor/mod.rs:1521:14
---- executor::test::wake_by_ref_refcount_underflow_with_sleep stdout ----
thread 'executor::test::wake_by_ref_refcount_underflow_with_sleep' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/executor/mod.rs:1521:14
---- executor::test::test_runtime_stats stdout ----
thread 'executor::test::test_runtime_stats' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/executor/mod.rs:3026:58
---- executor::test::wake_by_ref_refcount_underflow_with_join_handle stdout ----
thread 'executor::test::wake_by_ref_refcount_underflow_with_join_handle' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/executor/mod.rs:1521:14
---- io::buffered_file::test::file_create_close stdout ----
Glommio currently only supports NVMe-backed volumes formatted with XFS or EXT4. To run poll io-related tests, please set GLOMMIO_TEST_POLLIO_ROOTDIR to a NVMe-backed directory path in your environment.
Poll io tests will not run.
thread 'io::buffered_file::test::file_create_close' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/io/buffered_file.rs:275:5
---- io::buffered_file::test::random_io stdout ----
Glommio currently only supports NVMe-backed volumes formatted with XFS or EXT4. To run poll io-related tests, please set GLOMMIO_TEST_POLLIO_ROOTDIR to a NVMe-backed directory path in your environment.
Poll io tests will not run.
thread 'io::buffered_file::test::random_io' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/io/buffered_file.rs:308:5
---- io::buffered_file::test::file_open stdout ----
Glommio currently only supports NVMe-backed volumes formatted with XFS or EXT4. To run poll io-related tests, please set GLOMMIO_TEST_POLLIO_ROOTDIR to a NVMe-backed directory path in your environment.
Poll io tests will not run.
thread 'io::buffered_file::test::file_open' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/io/buffered_file.rs:283:5
---- io::buffered_file::test::file_open_nonexistent stdout ----
Glommio currently only supports NVMe-backed volumes formatted with XFS or EXT4. To run poll io-related tests, please set GLOMMIO_TEST_POLLIO_ROOTDIR to a NVMe-backed directory path in your environment.
Poll io tests will not run.
thread 'io::buffered_file::test::file_open_nonexistent' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/io/buffered_file.rs:301:5
---- io::buffered_file_stream::test::lines stdout ----
Glommio currently only supports NVMe-backed volumes formatted with XFS or EXT4. To run poll io-related tests, please set GLOMMIO_TEST_POLLIO_ROOTDIR to a NVMe-backed directory path in your environment.
Poll io tests will not run.
thread 'io::buffered_file_stream::test::lines' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/io/buffered_file_stream.rs:875:5
---- io::buffered_file_stream::test::mix_and_match_apis stdout ----
Glommio currently only supports NVMe-backed volumes formatted with XFS or EXT4. To run poll io-related tests, please set GLOMMIO_TEST_POLLIO_ROOTDIR to a NVMe-backed directory path in your environment.
Poll io tests will not run.
thread 'io::buffered_file_stream::test::mix_and_match_apis' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/io/buffered_file_stream.rs:905:5
---- io::buffered_file::test::write_past_end stdout ----
Glommio currently only supports NVMe-backed volumes formatted with XFS or EXT4. To run poll io-related tests, please set GLOMMIO_TEST_POLLIO_ROOTDIR to a NVMe-backed directory path in your environment.
Poll io tests will not run.
thread 'io::buffered_file::test::write_past_end' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/io/buffered_file.rs:342:5
---- io::buffered_file_stream::test::read_line stdout ----
Glommio currently only supports NVMe-backed volumes formatted with XFS or EXT4. To run poll io-related tests, please set GLOMMIO_TEST_POLLIO_ROOTDIR to a NVMe-backed directory path in your environment.
Poll io tests will not run.
thread 'io::buffered_file_stream::test::read_line' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/io/buffered_file_stream.rs:866:5
---- io::buffered_file_stream::test::read_exact_part_of_file stdout ----
Glommio currently only supports NVMe-backed volumes formatted with XFS or EXT4. To run poll io-related tests, please set GLOMMIO_TEST_POLLIO_ROOTDIR to a NVMe-backed directory path in your environment.
Poll io tests will not run.
thread 'io::buffered_file_stream::test::read_exact_part_of_file' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/io/buffered_file_stream.rs:768:5
---- io::buffered_file_stream::test::nop_seek_write stdout ----
Glommio currently only supports NVMe-backed volumes formatted with XFS or EXT4. To run poll io-related tests, please set GLOMMIO_TEST_POLLIO_ROOTDIR to a NVMe-backed directory path in your environment.
Poll io tests will not run.
thread 'io::buffered_file_stream::test::nop_seek_write' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/io/buffered_file_stream.rs:948:5
---- io::buffered_file_stream::test::read_slice stdout ----
Glommio currently only supports NVMe-backed volumes formatted with XFS or EXT4. To run poll io-related tests, please set GLOMMIO_TEST_POLLIO_ROOTDIR to a NVMe-backed directory path in your environment.
Poll io tests will not run.
thread 'io::buffered_file_stream::test::read_slice' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/io/buffered_file_stream.rs:810:5
---- io::buffered_file_stream::test::read_exact_empty_file stdout ----
Glommio currently only supports NVMe-backed volumes formatted with XFS or EXT4. To run poll io-related tests, please set GLOMMIO_TEST_POLLIO_ROOTDIR to a NVMe-backed directory path in your environment.
Poll io tests will not run.
thread 'io::buffered_file_stream::test::read_exact_empty_file' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/io/buffered_file_stream.rs:753:5
---- io::buffered_file_stream::test::read_to_end_after_seek stdout ----
Glommio currently only supports NVMe-backed volumes formatted with XFS or EXT4. To run poll io-related tests, please set GLOMMIO_TEST_POLLIO_ROOTDIR to a NVMe-backed directory path in your environment.
Poll io tests will not run.
thread 'io::buffered_file_stream::test::read_to_end_after_seek' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/io/buffered_file_stream.rs:823:5
---- io::buffered_file_stream::test::read_until stdout ----
Glommio currently only supports NVMe-backed volumes formatted with XFS or EXT4. To run poll io-related tests, please set GLOMMIO_TEST_POLLIO_ROOTDIR to a NVMe-backed directory path in your environment.
Poll io tests will not run.
thread 'io::buffered_file_stream::test::read_until' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/io/buffered_file_stream.rs:843:5
---- io::buffered_file_stream::test::read_to_end_from_start stdout ----
Glommio currently only supports NVMe-backed volumes formatted with XFS or EXT4. To run poll io-related tests, please set GLOMMIO_TEST_POLLIO_ROOTDIR to a NVMe-backed directory path in your environment.
Poll io tests will not run.
thread 'io::buffered_file_stream::test::read_to_end_from_start' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/io/buffered_file_stream.rs:800:5
---- io::buffered_file_stream::test::read_until_eof stdout ----
Glommio currently only supports NVMe-backed volumes formatted with XFS or EXT4. To run poll io-related tests, please set GLOMMIO_TEST_POLLIO_ROOTDIR to a NVMe-backed directory path in your environment.
Poll io tests will not run.
thread 'io::buffered_file_stream::test::read_until_eof' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/io/buffered_file_stream.rs:857:5
---- io::buffered_file_stream::test::read_until_empty_file stdout ----
Glommio currently only supports NVMe-backed volumes formatted with XFS or EXT4. To run poll io-related tests, please set GLOMMIO_TEST_POLLIO_ROOTDIR to a NVMe-backed directory path in your environment.
Poll io tests will not run.
thread 'io::buffered_file_stream::test::read_until_empty_file' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/io/buffered_file_stream.rs:834:5
---- io::buffered_file_stream::test::split stdout ----
Glommio currently only supports NVMe-backed volumes formatted with XFS or EXT4. To run poll io-related tests, please set GLOMMIO_TEST_POLLIO_ROOTDIR to a NVMe-backed directory path in your environment.
Poll io tests will not run.
thread 'io::buffered_file_stream::test::split' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/io/buffered_file_stream.rs:895:5
---- io::buffered_file_stream::test::seek_end_and_read_exact stdout ----
Glommio currently only supports NVMe-backed volumes formatted with XFS or EXT4. To run poll io-related tests, please set GLOMMIO_TEST_POLLIO_ROOTDIR to a NVMe-backed directory path in your environment.
Poll io tests will not run.
thread 'io::buffered_file_stream::test::seek_end_and_read_exact' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/io/buffered_file_stream.rs:789:5
---- io::buffered_file_stream::test::seek_and_write stdout ----
Glommio currently only supports NVMe-backed volumes formatted with XFS or EXT4. To run poll io-related tests, please set GLOMMIO_TEST_POLLIO_ROOTDIR to a NVMe-backed directory path in your environment.
Poll io tests will not run.
thread 'io::buffered_file_stream::test::seek_and_write' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/io/buffered_file_stream.rs:928:5
---- io::buffered_file_stream::test::write_and_flush stdout ----
Glommio currently only supports NVMe-backed volumes formatted with XFS or EXT4. To run poll io-related tests, please set GLOMMIO_TEST_POLLIO_ROOTDIR to a NVMe-backed directory path in your environment.
Poll io tests will not run.
thread 'io::buffered_file_stream::test::write_and_flush' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/io/buffered_file_stream.rs:967:5
---- io::buffered_file_stream::test::seek_start_and_read_exact stdout ----
Glommio currently only supports NVMe-backed volumes formatted with XFS or EXT4. To run poll io-related tests, please set GLOMMIO_TEST_POLLIO_ROOTDIR to a NVMe-backed directory path in your environment.
Poll io tests will not run.
thread 'io::buffered_file_stream::test::seek_start_and_read_exact' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/io/buffered_file_stream.rs:778:5
---- io::buffered_file_stream::test::write_simple stdout ----
Glommio currently only supports NVMe-backed volumes formatted with XFS or EXT4. To run poll io-related tests, please set GLOMMIO_TEST_POLLIO_ROOTDIR to a NVMe-backed directory path in your environment.
Poll io tests will not run.
thread 'io::buffered_file_stream::test::write_simple' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/io/buffered_file_stream.rs:917:5
---- io::bulk_io::tests::monotonic_iovec_merging stdout ----
thread 'io::bulk_io::tests::monotonic_iovec_merging' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/io/bulk_io.rs:544:9
---- io::bulk_io::tests::read_no_coalescing stdout ----
thread 'io::bulk_io::tests::read_no_coalescing' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/io/bulk_io.rs:692:9
---- io::bulk_io::tests::large_input_passthrough stdout ----
thread 'io::bulk_io::tests::large_input_passthrough' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/io/bulk_io.rs:570:9
---- io::bulk_io::tests::read_amplification_limit stdout ----
thread 'io::bulk_io::tests::read_amplification_limit' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/io/bulk_io.rs:639:9
---- io::bulk_io::tests::nonmonotonic_iovec_merging stdout ----
thread 'io::bulk_io::tests::nonmonotonic_iovec_merging' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/io/bulk_io.rs:615:9
---- io::dma_file::test::cancellation_doest_crash_futures_not_polled stdout ----
Glommio currently only supports NVMe-backed volumes formatted with XFS or EXT4. To run poll io-related tests, please set GLOMMIO_TEST_POLLIO_ROOTDIR to a NVMe-backed directory path in your environment.
Poll io tests will not run.
thread 'io::dma_file::test::cancellation_doest_crash_futures_not_polled' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/io/dma_file.rs:704:5
---- io::dma_file::test::cancellation_doest_crash_futures_polled stdout ----
Glommio currently only supports NVMe-backed volumes formatted with XFS or EXT4. To run poll io-related tests, please set GLOMMIO_TEST_POLLIO_ROOTDIR to a NVMe-backed directory path in your environment.
Poll io tests will not run.
thread 'io::dma_file::test::cancellation_doest_crash_futures_polled' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/io/dma_file.rs:734:5
---- io::dma_file::test::file_empty_read stdout ----
Glommio currently only supports NVMe-backed volumes formatted with XFS or EXT4. To run poll io-related tests, please set GLOMMIO_TEST_POLLIO_ROOTDIR to a NVMe-backed directory path in your environment.
Poll io tests will not run.
thread 'io::dma_file::test::file_empty_read' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/io/dma_file.rs:687:5
---- io::dma_file::test::file_fallocate_alocatee stdout ----
Glommio currently only supports NVMe-backed volumes formatted with XFS or EXT4. To run poll io-related tests, please set GLOMMIO_TEST_POLLIO_ROOTDIR to a NVMe-backed directory path in your environment.
Poll io tests will not run.
thread 'io::dma_file::test::file_fallocate_alocatee' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/io/dma_file.rs:563:5
---- io::dma_file::test::file_many_reads_unaligned stdout ----
Glommio currently only supports NVMe-backed volumes formatted with XFS or EXT4. To run poll io-related tests, please set GLOMMIO_TEST_POLLIO_ROOTDIR to a NVMe-backed directory path in your environment.
Poll io tests will not run.
thread 'io::dma_file::test::file_many_reads_unaligned' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/io/dma_file.rs:894:5
---- io::dma_file::test::file_invalid_readonly_write stdout ----
Glommio currently only supports NVMe-backed volumes formatted with XFS or EXT4. To run poll io-related tests, please set GLOMMIO_TEST_POLLIO_ROOTDIR to a NVMe-backed directory path in your environment.
Poll io tests will not run.
thread 'io::dma_file::test::file_invalid_readonly_write' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/io/dma_file.rs:657:5
---- io::dma_file::test::file_create_close stdout ----
Glommio currently only supports NVMe-backed volumes formatted with XFS or EXT4. To run poll io-related tests, please set GLOMMIO_TEST_POLLIO_ROOTDIR to a NVMe-backed directory path in your environment.
Poll io tests will not run.
thread 'io::dma_file::test::file_create_close' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/io/dma_file.rs:504:5
---- io::dma_file::test::file_many_reads_no_coalescing stdout ----
Glommio currently only supports NVMe-backed volumes formatted with XFS or EXT4. To run poll io-related tests, please set GLOMMIO_TEST_POLLIO_ROOTDIR to a NVMe-backed directory path in your environment.
Poll io tests will not run.
thread 'io::dma_file::test::file_many_reads_no_coalescing' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/io/dma_file.rs:929:5
---- io::dma_file::test::file_many_reads stdout ----
Glommio currently only supports NVMe-backed volumes formatted with XFS or EXT4. To run poll io-related tests, please set GLOMMIO_TEST_POLLIO_ROOTDIR to a NVMe-backed directory path in your environment.
Poll io tests will not run.
thread 'io::dma_file::test::file_many_reads' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/io/dma_file.rs:858:5
---- io::dma_file::test::file_fallocate_zero stdout ----
Glommio currently only supports NVMe-backed volumes formatted with XFS or EXT4. To run poll io-related tests, please set GLOMMIO_TEST_POLLIO_ROOTDIR to a NVMe-backed directory path in your environment.
Poll io tests will not run.
thread 'io::dma_file::test::file_fallocate_zero' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/io/dma_file.rs:597:5
---- io::dma_file::test::file_open stdout ----
Glommio currently only supports NVMe-backed volumes formatted with XFS or EXT4. To run poll io-related tests, please set GLOMMIO_TEST_POLLIO_ROOTDIR to a NVMe-backed directory path in your environment.
Poll io tests will not run.
thread 'io::dma_file::test::file_open' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/io/dma_file.rs:512:5
---- io::dma_file::test::file_open_nonexistent stdout ----
Glommio currently only supports NVMe-backed volumes formatted with XFS or EXT4. To run poll io-related tests, please set GLOMMIO_TEST_POLLIO_ROOTDIR to a NVMe-backed directory path in your environment.
Poll io tests will not run.
thread 'io::dma_file::test::file_open_nonexistent' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/io/dma_file.rs:526:5
---- io::dma_file::test::file_rename stdout ----
Glommio currently only supports NVMe-backed volumes formatted with XFS or EXT4. To run poll io-related tests, please set GLOMMIO_TEST_POLLIO_ROOTDIR to a NVMe-backed directory path in your environment.
Poll io tests will not run.
thread 'io::dma_file::test::file_rename' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/io/dma_file.rs:533:5
---- io::dma_file::test::file_path stdout ----
Glommio currently only supports NVMe-backed volumes formatted with XFS or EXT4. To run poll io-related tests, please set GLOMMIO_TEST_POLLIO_ROOTDIR to a NVMe-backed directory path in your environment.
Poll io tests will not run.
thread 'io::dma_file::test::file_path' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/io/dma_file.rs:609:5
---- io::dma_file::test::file_rename_noop stdout ----
Glommio currently only supports NVMe-backed volumes formatted with XFS or EXT4. To run poll io-related tests, please set GLOMMIO_TEST_POLLIO_ROOTDIR to a NVMe-backed directory path in your environment.
Poll io tests will not run.
thread 'io::dma_file::test::file_rename_noop' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/io/dma_file.rs:549:5
---- io::dma_file::test::is_same_file stdout ----
Glommio currently only supports NVMe-backed volumes formatted with XFS or EXT4. To run poll io-related tests, please set GLOMMIO_TEST_POLLIO_ROOTDIR to a NVMe-backed directory path in your environment.
Poll io tests will not run.
thread 'io::dma_file::test::is_same_file' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/io/dma_file.rs:764:5
---- io::dma_file::test::file_simple_readwrite stdout ----
Glommio currently only supports NVMe-backed volumes formatted with XFS or EXT4. To run poll io-related tests, please set GLOMMIO_TEST_POLLIO_ROOTDIR to a NVMe-backed directory path in your environment.
Poll io tests will not run.
thread 'io::dma_file::test::file_simple_readwrite' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/io/dma_file.rs:618:5
---- io::dma_file::test::per_queue_stats stdout ----
Glommio currently only supports NVMe-backed volumes formatted with XFS or EXT4. To run poll io-related tests, please set GLOMMIO_TEST_POLLIO_ROOTDIR to a NVMe-backed directory path in your environment.
Poll io tests will not run.
thread 'io::dma_file::test::per_queue_stats' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/io/dma_file.rs:818:5
---- io::dma_file_stream::test::flushstate stdout ----
thread 'io::dma_file_stream::test::flushstate' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/io/dma_file_stream.rs:2046:9
---- io::dma_file_stream::test::flushed_position_big_buffer stdout ----
Glommio currently only supports NVMe-backed volumes formatted with XFS or EXT4. To run poll io-related tests, please set GLOMMIO_TEST_POLLIO_ROOTDIR to a NVMe-backed directory path in your environment.
Poll io tests will not run.
thread 'io::dma_file_stream::test::flushed_position_big_buffer' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/io/dma_file_stream.rs:1989:5
---- io::dma_file_stream::test::flush_and_drop stdout ----
Glommio currently only supports NVMe-backed volumes formatted with XFS or EXT4. To run poll io-related tests, please set GLOMMIO_TEST_POLLIO_ROOTDIR to a NVMe-backed directory path in your environment.
Poll io tests will not run.
thread 'io::dma_file_stream::test::flush_and_drop' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/io/dma_file_stream.rs:2007:5
---- io::dma_file_stream::test::flushed_position_small_buffer stdout ----
Glommio currently only supports NVMe-backed volumes formatted with XFS or EXT4. To run poll io-related tests, please set GLOMMIO_TEST_POLLIO_ROOTDIR to a NVMe-backed directory path in your environment.
Poll io tests will not run.
thread 'io::dma_file_stream::test::flushed_position_small_buffer' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/io/dma_file_stream.rs:1974:5
---- io::dma_file_stream::test::read_exact_early_eof stdout ----
Glommio currently only supports NVMe-backed volumes formatted with XFS or EXT4. To run poll io-related tests, please set GLOMMIO_TEST_POLLIO_ROOTDIR to a NVMe-backed directory path in your environment.
Poll io tests will not run.
thread 'io::dma_file_stream::test::read_exact_early_eof' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/io/dma_file_stream.rs:1545:5
---- io::dma_file_stream::test::read_exact_empty_file stdout ----
Glommio currently only supports NVMe-backed volumes formatted with XFS or EXT4. To run poll io-related tests, please set GLOMMIO_TEST_POLLIO_ROOTDIR to a NVMe-backed directory path in your environment.
Poll io tests will not run.
thread 'io::dma_file_stream::test::read_exact_empty_file' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/io/dma_file_stream.rs:1448:5
---- io::dma_file_stream::test::poll_reader_repeatedly stdout ----
Glommio currently only supports NVMe-backed volumes formatted with XFS or EXT4. To run poll io-related tests, please set GLOMMIO_TEST_POLLIO_ROOTDIR to a NVMe-backed directory path in your environment.
Poll io tests will not run.
thread 'io::dma_file_stream::test::poll_reader_repeatedly' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/io/dma_file_stream.rs:1823:5
---- io::dma_file_stream::test::read_exact_crosses_buffer stdout ----
Glommio currently only supports NVMe-backed volumes formatted with XFS or EXT4. To run poll io-related tests, please set GLOMMIO_TEST_POLLIO_ROOTDIR to a NVMe-backed directory path in your environment.
Poll io tests will not run.
thread 'io::dma_file_stream::test::read_exact_crosses_buffer' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/io/dma_file_stream.rs:1504:5
---- io::dma_file_stream::test::read_exact_late_start stdout ----
Glommio currently only supports NVMe-backed volumes formatted with XFS or EXT4. To run poll io-related tests, please set GLOMMIO_TEST_POLLIO_ROOTDIR to a NVMe-backed directory path in your environment.
Poll io tests will not run.
thread 'io::dma_file_stream::test::read_exact_late_start' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/io/dma_file_stream.rs:1527:5
---- io::dma_file_stream::test::read_exact_skip stdout ----
Glommio currently only supports NVMe-backed volumes formatted with XFS or EXT4. To run poll io-related tests, please set GLOMMIO_TEST_POLLIO_ROOTDIR to a NVMe-backed directory path in your environment.
Poll io tests will not run.
thread 'io::dma_file_stream::test::read_exact_skip' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/io/dma_file_stream.rs:1515:5
---- io::dma_file_stream::test::read_exact_single_buffer stdout ----
Glommio currently only supports NVMe-backed volumes formatted with XFS or EXT4. To run poll io-related tests, please set GLOMMIO_TEST_POLLIO_ROOTDIR to a NVMe-backed directory path in your environment.
Poll io tests will not run.
thread 'io::dma_file_stream::test::read_exact_single_buffer' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/io/dma_file_stream.rs:1493:5
---- io::dma_file_stream::test::read_exact_unaligned_file_size stdout ----
Glommio currently only supports NVMe-backed volumes formatted with XFS or EXT4. To run poll io-related tests, please set GLOMMIO_TEST_POLLIO_ROOTDIR to a NVMe-backed directory path in your environment.
Poll io tests will not run.
thread 'io::dma_file_stream::test::read_exact_unaligned_file_size' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/io/dma_file_stream.rs:1564:5
---- io::dma_file_stream::test::read_exact_zero_buffer stdout ----
Glommio currently only supports NVMe-backed volumes formatted with XFS or EXT4. To run poll io-related tests, please set GLOMMIO_TEST_POLLIO_ROOTDIR to a NVMe-backed directory path in your environment.
Poll io tests will not run.
thread 'io::dma_file_stream::test::read_exact_zero_buffer' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/io/dma_file_stream.rs:1482:5
---- io::dma_file_stream::test::read_get_buffer_aligned stdout ----
Glommio currently only supports NVMe-backed volumes formatted with XFS or EXT4. To run poll io-related tests, please set GLOMMIO_TEST_POLLIO_ROOTDIR to a NVMe-backed directory path in your environment.
Poll io tests will not run.
thread 'io::dma_file_stream::test::read_get_buffer_aligned' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/io/dma_file_stream.rs:1667:5
---- io::dma_file_stream::test::read_get_buffer_aligned_cross_boundaries stdout ----
Glommio currently only supports NVMe-backed volumes formatted with XFS or EXT4. To run poll io-related tests, please set GLOMMIO_TEST_POLLIO_ROOTDIR to a NVMe-backed directory path in your environment.
Poll io tests will not run.
thread 'io::dma_file_stream::test::read_get_buffer_aligned_cross_boundaries' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/io/dma_file_stream.rs:1689:5
---- io::dma_file_stream::test::read_get_buffer_aligned_zero_buffer stdout ----
Glommio currently only supports NVMe-backed volumes formatted with XFS or EXT4. To run poll io-related tests, please set GLOMMIO_TEST_POLLIO_ROOTDIR to a NVMe-backed directory path in your environment.
Poll io tests will not run.
thread 'io::dma_file_stream::test::read_get_buffer_aligned_zero_buffer' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/io/dma_file_stream.rs:1732:5
---- io::dma_file_stream::test::read_get_buffer_aligned_past_the_end stdout ----
Glommio currently only supports NVMe-backed volumes formatted with XFS or EXT4. To run poll io-related tests, please set GLOMMIO_TEST_POLLIO_ROOTDIR to a NVMe-backed directory path in your environment.
Poll io tests will not run.
thread 'io::dma_file_stream::test::read_get_buffer_aligned_past_the_end' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/io/dma_file_stream.rs:1753:5
---- io::dma_file_stream::test::read_get_buffer_aligned_entire_buffer_at_once stdout ----
Glommio currently only supports NVMe-backed volumes formatted with XFS or EXT4. To run poll io-related tests, please set GLOMMIO_TEST_POLLIO_ROOTDIR to a NVMe-backed directory path in your environment.
Poll io tests will not run.
thread 'io::dma_file_stream::test::read_get_buffer_aligned_entire_buffer_at_once' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/io/dma_file_stream.rs:1742:5
---- io::dma_file_stream::test::read_mixed_api stdout ----
Glommio currently only supports NVMe-backed volumes formatted with XFS or EXT4. To run poll io-related tests, please set GLOMMIO_TEST_POLLIO_ROOTDIR to a NVMe-backed directory path in your environment.
Poll io tests will not run.
thread 'io::dma_file_stream::test::read_mixed_api' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/io/dma_file_stream.rs:1764:5
---- io::dma_file_stream::test::read_simple stdout ----
Glommio currently only supports NVMe-backed volumes formatted with XFS or EXT4. To run poll io-related tests, please set GLOMMIO_TEST_POLLIO_ROOTDIR to a NVMe-backed directory path in your environment.
Poll io tests will not run.
thread 'io::dma_file_stream::test::read_simple' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/io/dma_file_stream.rs:1649:5
---- io::dma_file_stream::test::read_to_end_after_skip stdout ----
Glommio currently only supports NVMe-backed volumes formatted with XFS or EXT4. To run poll io-related tests, please set GLOMMIO_TEST_POLLIO_ROOTDIR to a NVMe-backed directory path in your environment.
Poll io tests will not run.
thread 'io::dma_file_stream::test::read_to_end_after_skip' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/io/dma_file_stream.rs:1635:5
---- io::dma_file_stream::test::read_to_end_buffer_crossing stdout ----
Glommio currently only supports NVMe-backed volumes formatted with XFS or EXT4. To run poll io-related tests, please set GLOMMIO_TEST_POLLIO_ROOTDIR to a NVMe-backed directory path in your environment.
Poll io tests will not run.
thread 'io::dma_file_stream::test::read_to_end_buffer_crossing' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/io/dma_file_stream.rs:1610:5
---- io::dma_file_stream::test::read_to_end_of_empty_file stdout ----
Glommio currently only supports NVMe-backed volumes formatted with XFS or EXT4. To run poll io-related tests, please set GLOMMIO_TEST_POLLIO_ROOTDIR to a NVMe-backed directory path in your environment.
Poll io tests will not run.
thread 'io::dma_file_stream::test::read_to_end_of_empty_file' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/io/dma_file_stream.rs:1588:5
---- io::dma_file_stream::test::read_to_end_no_read_ahead stdout ----
Glommio currently only supports NVMe-backed volumes formatted with XFS or EXT4. To run poll io-related tests, please set GLOMMIO_TEST_POLLIO_ROOTDIR to a NVMe-backed directory path in your environment.
Poll io tests will not run.
thread 'io::dma_file_stream::test::read_to_end_no_read_ahead' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/io/dma_file_stream.rs:1575:5
---- io::dma_file_stream::test::read_wronly_file stdout ----
Glommio currently only supports NVMe-backed volumes formatted with XFS or EXT4. To run poll io-related tests, please set GLOMMIO_TEST_POLLIO_ROOTDIR to a NVMe-backed directory path in your environment.
Poll io tests will not run.
thread 'io::dma_file_stream::test::read_wronly_file' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/io/dma_file_stream.rs:1811:5
---- io::dma_file_stream::test::read_to_end_buffer_crossing_read_ahead stdout ----
Glommio currently only supports NVMe-backed volumes formatted with XFS or EXT4. To run poll io-related tests, please set GLOMMIO_TEST_POLLIO_ROOTDIR to a NVMe-backed directory path in your environment.
Poll io tests will not run.
thread 'io::dma_file_stream::test::read_to_end_buffer_crossing_read_ahead' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/io/dma_file_stream.rs:1622:5
---- io::dma_file_stream::test::sync_and_close stdout ----
Glommio currently only supports NVMe-backed volumes formatted with XFS or EXT4. To run poll io-related tests, please set GLOMMIO_TEST_POLLIO_ROOTDIR to a NVMe-backed directory path in your environment.
Poll io tests will not run.
thread 'io::dma_file_stream::test::sync_and_close' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/io/dma_file_stream.rs:2025:5
---- io::dma_file_stream::test::write_close_twice stdout ----
Glommio currently only supports NVMe-backed volumes formatted with XFS or EXT4. To run poll io-related tests, please set GLOMMIO_TEST_POLLIO_ROOTDIR to a NVMe-backed directory path in your environment.
Poll io tests will not run.
thread 'io::dma_file_stream::test::write_close_twice' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/io/dma_file_stream.rs:1888:5
---- io::dma_file_stream::test::read_to_end_single_buffer stdout ----
Glommio currently only supports NVMe-backed volumes formatted with XFS or EXT4. To run poll io-related tests, please set GLOMMIO_TEST_POLLIO_ROOTDIR to a NVMe-backed directory path in your environment.
Poll io tests will not run.
thread 'io::dma_file_stream::test::read_to_end_single_buffer' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/io/dma_file_stream.rs:1598:5
---- io::dma_file_stream::test::write_all stdout ----
Glommio currently only supports NVMe-backed volumes formatted with XFS or EXT4. To run poll io-related tests, please set GLOMMIO_TEST_POLLIO_ROOTDIR to a NVMe-backed directory path in your environment.
Poll io tests will not run.
thread 'io::dma_file_stream::test::write_all' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/io/dma_file_stream.rs:1837:5
---- io::dma_file_stream::test::write_more_than_write_behind stdout ----
Glommio currently only supports NVMe-backed volumes formatted with XFS or EXT4. To run poll io-related tests, please set GLOMMIO_TEST_POLLIO_ROOTDIR to a NVMe-backed directory path in your environment.
Poll io tests will not run.
thread 'io::dma_file_stream::test::write_more_than_write_behind' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/io/dma_file_stream.rs:1465:5
---- io::dma_file_stream::test::write_no_write_behind stdout ----
Glommio currently only supports NVMe-backed volumes formatted with XFS or EXT4. To run poll io-related tests, please set GLOMMIO_TEST_POLLIO_ROOTDIR to a NVMe-backed directory path in your environment.
Poll io tests will not run.
thread 'io::dma_file_stream::test::write_no_write_behind' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/io/dma_file_stream.rs:1901:5
---- io::dma_file_stream::test::write_multibuffer stdout ----
Glommio currently only supports NVMe-backed volumes formatted with XFS or EXT4. To run poll io-related tests, please set GLOMMIO_TEST_POLLIO_ROOTDIR to a NVMe-backed directory path in your environment.
Poll io tests will not run.
thread 'io::dma_file_stream::test::write_multibuffer' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/io/dma_file_stream.rs:1862:5
---- io::dma_file_stream::test::write_with_readable_file stdout ----
Glommio currently only supports NVMe-backed volumes formatted with XFS or EXT4. To run poll io-related tests, please set GLOMMIO_TEST_POLLIO_ROOTDIR to a NVMe-backed directory path in your environment.
Poll io tests will not run.
thread 'io::dma_file_stream::test::write_with_readable_file' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/io/dma_file_stream.rs:1955:5
---- io::immutable_file::test::seal_and_stream stdout ----
thread 'io::immutable_file::test::seal_and_stream' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/io/immutable_file.rs:495:5
---- io::immutable_file::test::seal_and_random stdout ----
thread 'io::immutable_file::test::seal_and_random' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/io/immutable_file.rs:533:5
---- io::immutable_file::test::seal_ready_many stdout ----
thread 'io::immutable_file::test::seal_ready_many' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/io/immutable_file.rs:557:5
---- io::glommio_file::test::drop_closes_the_file stdout ----
thread 'io::glommio_file::test::drop_closes_the_file' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/io/glommio_file.rs:301:9
---- io::immutable_file::test::stream_pos stdout ----
thread 'io::immutable_file::test::stream_pos' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/io/immutable_file.rs:510:5
---- io::dma_file_stream::test::write_zero_buffer stdout ----
Glommio currently only supports NVMe-backed volumes formatted with XFS or EXT4. To run poll io-related tests, please set GLOMMIO_TEST_POLLIO_ROOTDIR to a NVMe-backed directory path in your environment.
Poll io tests will not run.
thread 'io::dma_file_stream::test::write_zero_buffer' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/io/dma_file_stream.rs:1927:5
---- io::sched::test::file_hard_link_dedup stdout ----
Glommio currently only supports NVMe-backed volumes formatted with XFS or EXT4. To run poll io-related tests, please set GLOMMIO_TEST_POLLIO_ROOTDIR to a NVMe-backed directory path in your environment.
Poll io tests will not run.
thread 'io::sched::test::file_hard_link_dedup' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/io/sched.rs:550:5
---- io::sched::test::file_opt_out_dedup stdout ----
Glommio currently only supports NVMe-backed volumes formatted with XFS or EXT4. To run poll io-related tests, please set GLOMMIO_TEST_POLLIO_ROOTDIR to a NVMe-backed directory path in your environment.
Poll io tests will not run.
thread 'io::sched::test::file_opt_out_dedup' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/io/sched.rs:514:5
---- io::sched::test::file_simple_dedup stdout ----
Glommio currently only supports NVMe-backed volumes formatted with XFS or EXT4. To run poll io-related tests, please set GLOMMIO_TEST_POLLIO_ROOTDIR to a NVMe-backed directory path in your environment.
Poll io tests will not run.
thread 'io::sched::test::file_simple_dedup' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/io/sched.rs:374:5
---- io::sched::test::file_offset_dedup stdout ----
Glommio currently only supports NVMe-backed volumes formatted with XFS or EXT4. To run poll io-related tests, please set GLOMMIO_TEST_POLLIO_ROOTDIR to a NVMe-backed directory path in your environment.
Poll io tests will not run.
thread 'io::sched::test::file_offset_dedup' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/io/sched.rs:473:5
---- io::sched::test::file_simple_dedup_concurrent stdout ----
Glommio currently only supports NVMe-backed volumes formatted with XFS or EXT4. To run poll io-related tests, please set GLOMMIO_TEST_POLLIO_ROOTDIR to a NVMe-backed directory path in your environment.
Poll io tests will not run.
thread 'io::sched::test::file_simple_dedup_concurrent' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/io/sched.rs:433:5
---- io::test::remove_nonexistent stdout ----
thread 'io::test::remove_nonexistent' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/executor/mod.rs:1521:14
---- io::sched::test::file_soft_link_dedup stdout ----
Glommio currently only supports NVMe-backed volumes formatted with XFS or EXT4. To run poll io-related tests, please set GLOMMIO_TEST_POLLIO_ROOTDIR to a NVMe-backed directory path in your environment.
Poll io tests will not run.
thread 'io::sched::test::file_soft_link_dedup' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/io/sched.rs:602:5
---- net::tcp_socket::tests::accepted_tcp_stream_peer_addr stdout ----
thread 'net::tcp_socket::tests::accepted_tcp_stream_peer_addr' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/net/tcp_socket.rs:1268:9
---- net::tcp_socket::tests::connect_and_ping_pong stdout ----
thread 'net::tcp_socket::tests::connect_and_ping_pong' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/net/tcp_socket.rs:957:9
---- net::tcp_socket::tests::multi_executor_bind_works stdout ----
thread 'net::tcp_socket::tests::multi_executor_bind_works' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/net/tcp_socket.rs:804:9
---- net::tcp_socket::tests::overconsume stdout ----
thread 'net::tcp_socket::tests::overconsume' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/net/tcp_socket.rs:1084:9
---- net::tcp_socket::tests::connect_local_server stdout ----
thread 'net::tcp_socket::tests::connect_local_server' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/net/tcp_socket.rs:783:9
---- net::tcp_socket::tests::repeated_fill_before_consume stdout ----
thread 'net::tcp_socket::tests::repeated_fill_before_consume' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/net/tcp_socket.rs:1109:9
---- net::tcp_socket::tests::multibuf_fill stdout ----
thread 'net::tcp_socket::tests::multibuf_fill' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/net/tcp_socket.rs:1052:9
---- net::tcp_socket::tests::parallel_accept stdout ----
thread 'net::tcp_socket::tests::parallel_accept' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/net/tcp_socket.rs:920:9
---- net::tcp_socket::tests::tcp_connect_timeout stdout ----
thread 'net::tcp_socket::tests::tcp_connect_timeout' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/net/tcp_socket.rs:1163:9
---- net::tcp_socket::tests::multi_executor_accept stdout ----
thread 'net::tcp_socket::tests::multi_executor_accept' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/net/tcp_socket.rs:877:20
---- net::tcp_socket::tests::peek stdout ----
thread 'net::tcp_socket::tests::peek' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/net/tcp_socket.rs:1136:9
---- net::tcp_socket::tests::tcp_connect_timeout_error stdout ----
thread 'net::tcp_socket::tests::tcp_connect_timeout_error' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/net/tcp_socket.rs:1177:9
---- net::tcp_socket::tests::stream_of_connections stdout ----
thread 'net::tcp_socket::tests::stream_of_connections' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/net/tcp_socket.rs:885:9
---- net::tcp_socket::tests::tcp_force_poll stdout ----
thread 'net::tcp_socket::tests::tcp_force_poll' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/net/tcp_socket.rs:1217:9
---- net::tcp_socket::tests::tcp_stream_ttl stdout ----
thread 'net::tcp_socket::tests::tcp_stream_ttl' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/net/tcp_socket.rs:761:9
---- net::tcp_socket::tests::tcp_read_timeout stdout ----
thread 'net::tcp_socket::tests::tcp_read_timeout' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/net/tcp_socket.rs:1189:9
---- net::tcp_socket::tests::tcp_listener_ttl stdout ----
thread 'net::tcp_socket::tests::tcp_listener_ttl' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/net/tcp_socket.rs:752:9
---- net::tcp_socket::tests::tcp_invalid_timeout stdout ----
thread 'net::tcp_socket::tests::tcp_invalid_timeout' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/net/tcp_socket.rs:1244:9
---- net::tcp_socket::tests::tcp_stream_nodelay stdout ----
thread 'net::tcp_socket::tests::tcp_stream_nodelay' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/net/tcp_socket.rs:772:9
---- net::tcp_socket::tests::test_lines stdout ----
thread 'net::tcp_socket::tests::test_lines' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/net/tcp_socket.rs:1031:9
---- net::udp_socket::tests::broadcast stdout ----
thread 'net::udp_socket::tests::broadcast' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/net/udp_socket.rs:1003:9
---- net::tcp_socket::tests::test_read_line stdout ----
thread 'net::tcp_socket::tests::test_read_line' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/net/tcp_socket.rs:1009:9
---- net::tcp_socket::tests::test_read_until stdout ----
thread 'net::tcp_socket::tests::test_read_until' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/net/tcp_socket.rs:986:9
---- net::udp_socket::tests::peek stdout ----
thread 'net::udp_socket::tests::peek' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/net/udp_socket.rs:829:9
---- net::udp_socket::tests::multicast_v4 stdout ----
thread 'net::udp_socket::tests::multicast_v4' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/net/udp_socket.rs:1012:9
---- net::udp_socket::tests::multi_executor_bind_works stdout ----
thread 'net::udp_socket::tests::multi_executor_bind_works' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/net/udp_socket.rs:708:9
---- net::udp_socket::tests::multicast_v6 stdout ----
thread 'net::udp_socket::tests::multicast_v6' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/net/udp_socket.rs:1026:9
---- net::udp_socket::tests::peekfrom_blocking stdout ----
thread 'net::udp_socket::tests::peekfrom_blocking' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/net/udp_socket.rs:873:9
---- net::udp_socket::tests::recvfrom_blocking stdout ----
thread 'net::udp_socket::tests::recvfrom_blocking' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/net/udp_socket.rs:931:9
---- net::udp_socket::tests::recvfrom_non_blocking stdout ----
thread 'net::udp_socket::tests::recvfrom_non_blocking' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/net/udp_socket.rs:914:9
---- net::udp_socket::tests::sendto stdout ----
thread 'net::udp_socket::tests::sendto' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/net/udp_socket.rs:964:9
---- net::udp_socket::tests::peekfrom_non_blocking stdout ----
thread 'net::udp_socket::tests::peekfrom_non_blocking' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/net/udp_socket.rs:856:9
---- net::udp_socket::tests::sendto_blocking stdout ----
thread 'net::udp_socket::tests::sendto_blocking' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/net/udp_socket.rs:981:9
---- net::udp_socket::tests::set_multicast_ttl_v4 stdout ----
thread 'net::udp_socket::tests::set_multicast_ttl_v4' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/net/udp_socket.rs:1057:9
---- net::udp_socket::tests::set_multicast_loop_v6 stdout ----
thread 'net::udp_socket::tests::set_multicast_loop_v6' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/net/udp_socket.rs:1047:9
---- net::udp_socket::tests::set_multicast_loop_v4 stdout ----
thread 'net::udp_socket::tests::set_multicast_loop_v4' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/net/udp_socket.rs:1037:9
---- net::udp_socket::tests::udp_connect_peers stdout ----
thread 'net::udp_socket::tests::udp_connect_peers' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/net/udp_socket.rs:751:9
---- net::udp_socket::tests::set_ttl stdout ----
thread 'net::udp_socket::tests::set_ttl' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/net/udp_socket.rs:1067:9
---- net::udp_socket::tests::udp_connected_ping_pong stdout ----
thread 'net::udp_socket::tests::udp_connected_ping_pong' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/net/udp_socket.rs:770:9
---- net::udp_socket::tests::udp_connected_recv_filter stdout ----
thread 'net::udp_socket::tests::udp_connected_recv_filter' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/net/udp_socket.rs:787:9
---- net::udp_socket::tests::zero_sized_send stdout ----
thread 'net::udp_socket::tests::zero_sized_send' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/net/udp_socket.rs:809:9
---- net::unix::tests::connect_local_server stdout ----
thread 'net::unix::tests::connect_local_server' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/net/unix.rs:748:5
---- net::unix::tests::datagram_connect_unbounded stdout ----
thread 'net::unix::tests::datagram_connect_unbounded' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/net/unix.rs:840:5
---- net::unix::tests::datagram_pair_ping_pong stdout ----
thread 'net::unix::tests::datagram_pair_ping_pong' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/net/unix.rs:802:5
---- net::unix::tests::datagram_send_recv stdout ----
thread 'net::unix::tests::datagram_send_recv' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/net/unix.rs:812:5
---- net::unix::tests::datagram_send_to_recv_from stdout ----
thread 'net::unix::tests::datagram_send_to_recv_from' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/net/unix.rs:826:5
---- sync::gate::tests::test_future_close stdout ----
thread 'sync::gate::tests::test_future_close' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/executor/mod.rs:1521:14
---- net::unix::tests::pair stdout ----
thread 'net::unix::tests::pair' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/net/unix.rs:770:5
---- sync::gate::tests::test_immediate_close stdout ----
thread 'sync::gate::tests::test_immediate_close' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/executor/mod.rs:1521:14
---- sync::rwlock::test::rwlock_overflow stdout ----
thread 'sync::rwlock::test::rwlock_overflow' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/executor/mod.rs:1521:14
---- sync::gate::tests::test_dropped_task stdout ----
thread 'sync::gate::tests::test_dropped_task' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/executor/mod.rs:1521:14
---- sync::rwlock::test::rwlock_reentrant stdout ----
thread 'sync::rwlock::test::rwlock_reentrant' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/executor/mod.rs:1521:14
---- net::unix::tests::read_until stdout ----
thread 'net::unix::tests::read_until' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/net/unix.rs:780:5
---- sync::rwlock::test::test_close_rr stdout ----
thread 'sync::rwlock::test::test_close_rr' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/sync/rwlock.rs:1012:9
---- sync::rwlock::test::test_close_rw stdout ----
thread 'sync::rwlock::test::test_close_rw' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/sync/rwlock.rs:1028:9
---- sync::rwlock::test::test_close_wr stdout ----
thread 'sync::rwlock::test::test_close_wr' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/sync/rwlock.rs:980:9
---- sync::rwlock::test::test_frob stdout ----
thread 'sync::rwlock::test::test_frob' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/sync/rwlock.rs:951:9
---- sync::rwlock::test::test_close_ww stdout ----
thread 'sync::rwlock::test::test_close_ww' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/sync/rwlock.rs:996:9
---- sync::rwlock::test::test_global_lock stdout ----
thread 'sync::rwlock::test::test_global_lock' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/sync/rwlock.rs:1044:9
---- sync::rwlock::test::test_local_lock stdout ----
thread 'sync::rwlock::test::test_local_lock' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/sync/rwlock.rs:1086:9
---- sync::rwlock::test::test_smoke stdout ----
thread 'sync::rwlock::test::test_smoke' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/sync/rwlock.rs:939:9
---- sync::rwlock::test::test_try_read stdout ----
thread 'sync::rwlock::test::test_try_read' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/sync/rwlock.rs:1229:9
---- sync::rwlock::test::test_ping_pong stdout ----
thread 'sync::rwlock::test::test_ping_pong' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/sync/rwlock.rs:1128:9
---- sync::rwlock::test::test_try_write stdout ----
thread 'sync::rwlock::test::test_try_write' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/sync/rwlock.rs:1212:9
---- sync::semaphore::test::explicit_signal_unblocks_waiting_semaphore stdout ----
thread 'sync::semaphore::test::explicit_signal_unblocks_waiting_semaphore' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/sync/semaphore.rs:761:9
---- sync::semaphore::test::explicit_signal_unblocks_many_wakers stdout ----
thread 'sync::semaphore::test::explicit_signal_unblocks_many_wakers' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/sync/semaphore.rs:781:9
---- sync::semaphore::test::broken_semaphore_returns_the_right_error stdout ----
thread 'sync::semaphore::test::broken_semaphore_returns_the_right_error' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/sync/semaphore.rs:796:9
---- sync::semaphore::test::permit_raii_works stdout ----
thread 'sync::semaphore::test::permit_raii_works' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/sync/semaphore.rs:719:9
---- sync::semaphore::test::semaphore_overflow stdout ----
thread 'sync::semaphore::test::semaphore_overflow' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/executor/mod.rs:1521:14
---- sync::semaphore::test::semaphore_ensure_execution_order stdout ----
thread 'sync::semaphore::test::semaphore_ensure_execution_order' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/executor/mod.rs:1521:14
---- sync::semaphore::test::semaphore_acquisition_for_zero_unit_works stdout ----
thread 'sync::semaphore::test::semaphore_acquisition_for_zero_unit_works' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/sync/semaphore.rs:712:9
---- sys::uring::tests::timeout_smoke_test stdout ----
thread 'sys::uring::tests::timeout_smoke_test' panicked at 'called `Result::unwrap()` on an `Err` value: ReactorError { kind: 'MemLockLimit' }', glommio/src/sys/uring.rs:1928:81
---- timer::timer_impl::test::basic_timer_action_cancel_fails_if_fired stdout ----
thread 'timer::timer_impl::test::basic_timer_action_cancel_fails_if_fired' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/timer/timer_impl.rs:1099:9
---- timer::timer_impl::test::basic_timer_action_cancel_works stdout ----
thread 'timer::timer_impl::test::basic_timer_action_cancel_works' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/timer/timer_impl.rs:1011:9
---- timer::timer_impl::test::basic_timer_action_destroy_cancel_initiated_action stdout ----
thread 'timer::timer_impl::test::basic_timer_action_destroy_cancel_initiated_action' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/timer/timer_impl.rs:1047:9
---- timer::timer_impl::test::basic_timer_action_destroy_detached_spawn_survives stdout ----
thread 'timer::timer_impl::test::basic_timer_action_destroy_detached_spawn_survives' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/timer/timer_impl.rs:1070:9
---- timer::timer_impl::test::basic_timer_action_destroy_works stdout ----
thread 'timer::timer_impl::test::basic_timer_action_destroy_works' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/timer/timer_impl.rs:1029:9
---- timer::timer_impl::test::basic_timer_action_instant_works stdout ----
thread 'timer::timer_impl::test::basic_timer_action_instant_works' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/timer/timer_impl.rs:885:9
---- timer::timer_impl::test::basic_timer_action_repeat_cancellation_works stdout ----
thread 'timer::timer_impl::test::basic_timer_action_repeat_cancellation_works' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/timer/timer_impl.rs:1142:9
---- timer::timer_impl::test::basic_timer_action_join_reflects_cancel stdout ----
thread 'timer::timer_impl::test::basic_timer_action_join_reflects_cancel' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/timer/timer_impl.rs:995:9
---- timer::timer_impl::test::basic_timer_action_instant_past_works stdout ----
thread 'timer::timer_impl::test::basic_timer_action_instant_past_works' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/timer/timer_impl.rs:902:9
---- timer::timer_impl::test::basic_timer_action_repeat_works stdout ----
thread 'timer::timer_impl::test::basic_timer_action_repeat_works' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/timer/timer_impl.rs:1118:9
---- timer::timer_impl::test::basic_timer_action_return_ok stdout ----
thread 'timer::timer_impl::test::basic_timer_action_return_ok' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/timer/timer_impl.rs:982:9
---- timer::timer_impl::test::basic_timer_action_works stdout ----
thread 'timer::timer_impl::test::basic_timer_action_works' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/timer/timer_impl.rs:919:9
---- timer::timer_impl::test::basic_timer_action_repeat_destruction_works stdout ----
thread 'timer::timer_impl::test::basic_timer_action_repeat_destruction_works' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/timer/timer_impl.rs:1160:9
---- timer::timer_impl::test::basic_timer_rearm_executed_action_ok stdout ----
thread 'timer::timer_impl::test::basic_timer_rearm_executed_action_ok' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/timer/timer_impl.rs:949:9
---- timer::timer_impl::test::basic_timer_rearm_future_timer_ok stdout ----
thread 'timer::timer_impl::test::basic_timer_rearm_future_timer_ok' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/timer/timer_impl.rs:968:9
---- timer::timer_impl::test::timeout_does_not_expire stdout ----
thread 'timer::timer_impl::test::timeout_does_not_expire' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/timer/timer_impl.rs:798:9
---- timer::timer_impl::test::basic_timer_rearm_pending_timer_for_the_past_ok stdout ----
thread 'timer::timer_impl::test::basic_timer_rearm_pending_timer_for_the_past_ok' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/timer/timer_impl.rs:931:9
---- timer::timer_impl::test::timeout_expiration_cancels_future stdout ----
thread 'timer::timer_impl::test::timeout_expiration_cancels_future' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/timer/timer_impl.rs:842:9
---- timer::timer_impl::test::basic_timer_works stdout ----
thread 'timer::timer_impl::test::basic_timer_works' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/timer/timer_impl.rs:874:9
---- timer::timer_impl::test::test_memory_leak_unfinished_timer stdout ----
thread 'timer::timer_impl::test::test_memory_leak_unfinished_timer' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/timer/timer_impl.rs:1190:23
---- timer::timer_impl::test::timeout_expires stdout ----
thread 'timer::timer_impl::test::timeout_expires' panicked at 'called `Result::unwrap()` on an `Err` value: Custom { kind: InvalidData, error: "Incorrect source type!" }', glommio/src/timer/timer_impl.rs:818:9
failures:
channels::channel_mesh::tests::test_channel_mesh
channels::channel_mesh::tests::test_partial_mesh
channels::channel_mesh::tests::test_peer_id_invariance
channels::local_channel::test::multiple_task_receivers
channels::local_channel::test::non_stream_receiver
channels::local_channel::test::producer_bounded_early_error
channels::local_channel::test::producer_bounded_has_capacity
channels::local_channel::test::producer_bounded_ping_pong
channels::local_channel::test::producer_bounded_previously_blocked_still_errors_out
channels::local_channel::test::producer_consumer
channels::local_channel::test::producer_early_drop_receiver
channels::local_channel::test::producer_parallel_consumer
channels::local_channel::test::producer_receiver_serialized
channels::sharding::tests::test
channels::sharding::tests::test_send
channels::sharding::tests::test_send_to
channels::shared_channel::test::close_sender_while_blocked_on_send
channels::shared_channel::test::consumer_never_connects
channels::shared_channel::test::consumer_sleeps_before_producer_produces
channels::shared_channel::test::copy_shared
channels::shared_channel::test::destroy_with_pending_wakers
channels::shared_channel::test::non_copy_shared
channels::shared_channel::test::pass_function
channels::shared_channel::test::producer_consumer
channels::shared_channel::test::producer_never_connects
channels::shared_channel::test::producer_sleeps_before_consumer_consumes
channels::shared_channel::test::producer_stream_consumer
channels::shared_channel::test::send_to_full_channel
channels::shared_channel::test::shared_drop_cascade_drop_executor
channels::shared_channel::test::shared_drop_cascade_drop_executor_reverse
channels::shared_channel::test::shared_drop_gets_called
channels::shared_channel::test::shared_drop_gets_called_reversed
controllers::deadline_queue::test::deadline_queue_behaves_well_if_we_process_too_much
controllers::deadline_queue::test::deadline_queue_behaves_well_with_zero_total_units
controllers::deadline_queue::test::deadline_queue_does_not_accept_non_monotonic_durations
controllers::deadline_queue::test::deadline_queue_second_queued_item_increases_slope
controllers::deadline_queue::test::deadline_queue_shares_increase_if_we_dont_process
controllers::deadline_queue::test::deadline_queue_shares_ok_if_we_process_smoothly
controllers::deadline_queue::test::deadline_queue_successfully_drops_item_when_done
executor::stall::test::executor_stall_detector
executor::stall::test::stall_detector_correct_signal_handler
executor::stall::test::stall_detector_multiple_signals
executor::test::blocking_function
executor::test::blocking_function_parallelism
executor::test::create_and_bind
executor::test::create_and_destroy_executor
executor::test::cross_executor_wake_by_ref
executor::test::cross_executor_wake_by_value
executor::test::cross_executor_wake_early_drop
executor::test::cross_executor_wake_hold_waker
executor::test::cross_executor_wake_with_join_handle
executor::test::current_task_queue_matches
executor::test::executor_pool_builder
executor::test::executor_pool_builder_placements
executor::test::executor_pool_builder_return_values
executor::test::invalid_task_queue
executor::test::multiple_spawn
executor::test::panic_is_not_list
executor::test::scoped_task
executor::test::task_optimized_for_throughput
executor::test::task_with_latency_requirements
executor::test::ten_yielding_queues
executor::test::test_allocate_dma_buffer
executor::test::test_allocate_dma_buffer_global
executor::test::test_detach
executor::test::test_dynamic_shares
executor::test::test_no_spin
executor::test::test_runtime_stats
executor::test::test_shares_high_disparity_fat_task
executor::test::test_shares_low_disparity_fat_task
executor::test::test_spin
executor::test::wake_by_ref_refcount_underflow_with_join_handle
executor::test::wake_by_ref_refcount_underflow_with_sleep
executor::test::wake_refcount_underflow_with_join_handle
executor::test::wake_refcount_underflow_with_sleep
io::buffered_file::test::file_create_close
io::buffered_file::test::file_open
io::buffered_file::test::file_open_nonexistent
io::buffered_file::test::random_io
io::buffered_file::test::write_past_end
io::buffered_file_stream::test::lines
io::buffered_file_stream::test::mix_and_match_apis
io::buffered_file_stream::test::nop_seek_write
io::buffered_file_stream::test::read_exact_empty_file
io::buffered_file_stream::test::read_exact_part_of_file
io::buffered_file_stream::test::read_line
io::buffered_file_stream::test::read_slice
io::buffered_file_stream::test::read_to_end_after_seek
io::buffered_file_stream::test::read_to_end_from_start
io::buffered_file_stream::test::read_until
io::buffered_file_stream::test::read_until_empty_file
io::buffered_file_stream::test::read_until_eof
io::buffered_file_stream::test::seek_and_write
io::buffered_file_stream::test::seek_end_and_read_exact
io::buffered_file_stream::test::seek_start_and_read_exact
io::buffered_file_stream::test::split
io::buffered_file_stream::test::write_and_flush
io::buffered_file_stream::test::write_simple
io::bulk_io::tests::large_input_passthrough
io::bulk_io::tests::monotonic_iovec_merging
io::bulk_io::tests::nonmonotonic_iovec_merging
io::bulk_io::tests::read_amplification_limit
io::bulk_io::tests::read_no_coalescing
io::dma_file::test::cancellation_doest_crash_futures_not_polled
io::dma_file::test::cancellation_doest_crash_futures_polled
io::dma_file::test::file_create_close
io::dma_file::test::file_empty_read
io::dma_file::test::file_fallocate_alocatee
io::dma_file::test::file_fallocate_zero
io::dma_file::test::file_invalid_readonly_write
io::dma_file::test::file_many_reads
io::dma_file::test::file_many_reads_no_coalescing
io::dma_file::test::file_many_reads_unaligned
io::dma_file::test::file_open
io::dma_file::test::file_open_nonexistent
io::dma_file::test::file_path
io::dma_file::test::file_rename
io::dma_file::test::file_rename_noop
io::dma_file::test::file_simple_readwrite
io::dma_file::test::is_same_file
io::dma_file::test::per_queue_stats
io::dma_file_stream::test::flush_and_drop
io::dma_file_stream::test::flushed_position_big_buffer
io::dma_file_stream::test::flushed_position_small_buffer
io::dma_file_stream::test::flushstate
io::dma_file_stream::test::poll_reader_repeatedly
io::dma_file_stream::test::read_exact_crosses_buffer
io::dma_file_stream::test::read_exact_early_eof
io::dma_file_stream::test::read_exact_empty_file
io::dma_file_stream::test::read_exact_late_start
io::dma_file_stream::test::read_exact_single_buffer
io::dma_file_stream::test::read_exact_skip
io::dma_file_stream::test::read_exact_unaligned_file_size
io::dma_file_stream::test::read_exact_zero_buffer
io::dma_file_stream::test::read_get_buffer_aligned
io::dma_file_stream::test::read_get_buffer_aligned_cross_boundaries
io::dma_file_stream::test::read_get_buffer_aligned_entire_buffer_at_once
io::dma_file_stream::test::read_get_buffer_aligned_past_the_end
io::dma_file_stream::test::read_get_buffer_aligned_zero_buffer
io::dma_file_stream::test::read_mixed_api
io::dma_file_stream::test::read_simple
io::dma_file_stream::test::read_to_end_after_skip
io::dma_file_stream::test::read_to_end_buffer_crossing
io::dma_file_stream::test::read_to_end_buffer_crossing_read_ahead
io::dma_file_stream::test::read_to_end_no_read_ahead
io::dma_file_stream::test::read_to_end_of_empty_file
io::dma_file_stream::test::read_to_end_single_buffer
io::dma_file_stream::test::read_wronly_file
io::dma_file_stream::test::sync_and_close
io::dma_file_stream::test::write_all
io::dma_file_stream::test::write_close_twice
io::dma_file_stream::test::write_more_than_write_behind
io::dma_file_stream::test::write_multibuffer
io::dma_file_stream::test::write_no_write_behind
io::dma_file_stream::test::write_with_readable_file
io::dma_file_stream::test::write_zero_buffer
io::glommio_file::test::drop_closes_the_file
io::immutable_file::test::seal_and_random
io::immutable_file::test::seal_and_stream
io::immutable_file::test::seal_ready_many
io::immutable_file::test::stream_pos
io::sched::test::file_hard_link_dedup
io::sched::test::file_offset_dedup
io::sched::test::file_opt_out_dedup
io::sched::test::file_simple_dedup
io::sched::test::file_simple_dedup_concurrent
io::sched::test::file_soft_link_dedup
io::test::remove_nonexistent
net::tcp_socket::tests::accepted_tcp_stream_peer_addr
net::tcp_socket::tests::connect_and_ping_pong
net::tcp_socket::tests::connect_local_server
net::tcp_socket::tests::multi_executor_accept
net::tcp_socket::tests::multi_executor_bind_works
net::tcp_socket::tests::multibuf_fill
net::tcp_socket::tests::overconsume
net::tcp_socket::tests::parallel_accept
net::tcp_socket::tests::peek
net::tcp_socket::tests::repeated_fill_before_consume
net::tcp_socket::tests::stream_of_connections
net::tcp_socket::tests::tcp_connect_timeout
net::tcp_socket::tests::tcp_connect_timeout_error
net::tcp_socket::tests::tcp_force_poll
net::tcp_socket::tests::tcp_invalid_timeout
net::tcp_socket::tests::tcp_listener_ttl
net::tcp_socket::tests::tcp_read_timeout
net::tcp_socket::tests::tcp_stream_nodelay
net::tcp_socket::tests::tcp_stream_ttl
net::tcp_socket::tests::test_lines
net::tcp_socket::tests::test_read_line
net::tcp_socket::tests::test_read_until
net::udp_socket::tests::broadcast
net::udp_socket::tests::multi_executor_bind_works
net::udp_socket::tests::multicast_v4
net::udp_socket::tests::multicast_v6
net::udp_socket::tests::peek
net::udp_socket::tests::peekfrom_blocking
net::udp_socket::tests::peekfrom_non_blocking
net::udp_socket::tests::recvfrom_blocking
net::udp_socket::tests::recvfrom_non_blocking
net::udp_socket::tests::sendto
net::udp_socket::tests::sendto_blocking
net::udp_socket::tests::set_multicast_loop_v4
net::udp_socket::tests::set_multicast_loop_v6
net::udp_socket::tests::set_multicast_ttl_v4
net::udp_socket::tests::set_ttl
net::udp_socket::tests::udp_connect_peers
net::udp_socket::tests::udp_connected_ping_pong
net::udp_socket::tests::udp_connected_recv_filter
net::udp_socket::tests::zero_sized_send
net::unix::tests::connect_local_server
net::unix::tests::datagram_connect_unbounded
net::unix::tests::datagram_pair_ping_pong
net::unix::tests::datagram_send_recv
net::unix::tests::datagram_send_to_recv_from
net::unix::tests::pair
net::unix::tests::read_until
sync::gate::tests::test_dropped_task
sync::gate::tests::test_future_close
sync::gate::tests::test_immediate_close
sync::rwlock::test::rwlock_overflow
sync::rwlock::test::rwlock_reentrant
sync::rwlock::test::test_close_rr
sync::rwlock::test::test_close_rw
sync::rwlock::test::test_close_wr
sync::rwlock::test::test_close_ww
sync::rwlock::test::test_frob
sync::rwlock::test::test_global_lock
sync::rwlock::test::test_local_lock
sync::rwlock::test::test_ping_pong
sync::rwlock::test::test_smoke
sync::rwlock::test::test_try_read
sync::rwlock::test::test_try_write
sync::semaphore::test::broken_semaphore_returns_the_right_error
sync::semaphore::test::explicit_signal_unblocks_many_wakers
sync::semaphore::test::explicit_signal_unblocks_waiting_semaphore
sync::semaphore::test::permit_raii_works
sync::semaphore::test::semaphore_acquisition_for_zero_unit_works
sync::semaphore::test::semaphore_ensure_execution_order
sync::semaphore::test::semaphore_overflow
sys::uring::tests::timeout_smoke_test
timer::timer_impl::test::basic_timer_action_cancel_fails_if_fired
timer::timer_impl::test::basic_timer_action_cancel_works
timer::timer_impl::test::basic_timer_action_destroy_cancel_initiated_action
timer::timer_impl::test::basic_timer_action_destroy_detached_spawn_survives
timer::timer_impl::test::basic_timer_action_destroy_works
timer::timer_impl::test::basic_timer_action_instant_past_works
timer::timer_impl::test::basic_timer_action_instant_works
timer::timer_impl::test::basic_timer_action_join_reflects_cancel
timer::timer_impl::test::basic_timer_action_repeat_cancellation_works
timer::timer_impl::test::basic_timer_action_repeat_destruction_works
timer::timer_impl::test::basic_timer_action_repeat_works
timer::timer_impl::test::basic_timer_action_return_ok
timer::timer_impl::test::basic_timer_action_works
timer::timer_impl::test::basic_timer_rearm_executed_action_ok
timer::timer_impl::test::basic_timer_rearm_future_timer_ok
timer::timer_impl::test::basic_timer_rearm_pending_timer_for_the_past_ok
timer::timer_impl::test::basic_timer_works
timer::timer_impl::test::test_memory_leak_unfinished_timer
timer::timer_impl::test::timeout_does_not_expire
timer::timer_impl::test::timeout_expiration_cancels_future
timer::timer_impl::test::timeout_expires
test result: FAILED. 107 passed; 261 failed; 0 ignored; 0 measured; 0 filtered out; finished in 0.12s
@nashley
Copy link
Author

nashley commented Jan 27, 2022

This with ulimit -l of 64, so it's expected to fail, but I would've expected it to fail with a different error message.

Sign up for free to join this conversation on GitHub. Already have an account? Sign in to comment