Update all non-major dependencies #1
Loading…
Add table
Add a link
Reference in a new issue
No description provided.
Delete branch "renovate/all-minor-patch"
Deleting a branch is permanent. Although the deleted branch may continue to exist for a short time before it actually gets removed, it CANNOT be undone in most cases. Continue?
This PR contains the following updates:
2.33.3->2.34.00.4.14->0.4.280.28.0->0.35.00.10.2->0.12.00.9.0->0.10.01.12.0->1.48.0Release Notes
clap-rs/clap (clap)
v2.34.0Compare Source
v2.33.4Compare Source
Bug Fixes
panic: swallows broken pipe errors on error output (7a729bc4)rust-lang/log (log)
v0.4.28Compare Source
v0.4.27Compare Source
What's Changed
Full Changelog: https://github.com/rust-lang/log/compare/0.4.26...0.4.27
v0.4.26Compare Source
What's Changed
Full Changelog: https://github.com/rust-lang/log/compare/0.4.26...0.4.27
v0.4.25Compare Source
What's Changed
Cloneforkv::Valueby @SpriteOvO in #668spdlog-rslink to crate doc by @SpriteOvO in #669Full Changelog: https://github.com/rust-lang/log/compare/0.4.25...0.4.26
v0.4.24Compare Source
What's Changed
Full Changelog: https://github.com/rust-lang/log/compare/0.4.24...0.4.25
v0.4.23Compare Source
What's Changed
Full Changelog: https://github.com/rust-lang/log/compare/0.4.23...0.4.24
v0.4.22Compare Source
What's Changed
spdlog-rslink to README by @SpriteOvO in #639New Contributors
Full Changelog: https://github.com/rust-lang/log/compare/0.4.22...0.4.23
v0.4.21Compare Source
What's Changed
cologcrate by @chrivers in #621New Contributors
Full Changelog: https://github.com/rust-lang/log/compare/0.4.21...0.4.22
v0.4.20Compare Source
local_inner_macrosusage by @EFanZh in #570v0.4.19Compare Source
v0.4.18Compare Source
set_max_level_racyand gateset_max_levelby @djkoloski in #544v0.4.17kv_unstableinternal dependencies.v0.4.16Optionuse in macros.v0.4.15Compare Source
spin_loop_hint.set_max_levelcall.Logon some common wrapper types.log!macros.kv_unstableinternal dependencies, so they don't bump past their current alpha.kv_unstable.NonZero*integers as values in structured logginglibpnet/libpnet (pnet_packet)
v0.35.0Compare Source
What's Changed
New Contributors
Full Changelog: https://github.com/libpnet/libpnet/compare/v0.34.0...v0.35.0
v0.34.0Compare Source
What's Changed
typos. Addspell-checkCI job by @vvv in #621New Contributors
Full Changelog: https://github.com/libpnet/libpnet/compare/v0.33.0...v0.34.0
v0.33.0Compare Source
What's Changed
pnetdev dependency frompnet_datalinkcargo docwarning forpnet_macrosNew Contributors
Full Changelog: https://github.com/libpnet/libpnet/compare/v0.32.0...v0.33.0
v0.32.0Compare Source
What's Changed
#[repr(C)]attributes to structsstdfeature by default use--no-default-featuresfornostdsupportNew Contributors
Full Changelog: https://github.com/libpnet/libpnet/compare/v0.31.0...v0.32.0
v0.31.0Compare Source
What's Changed
c9bb42fNew Contributors
Full Changelog: https://github.com/libpnet/libpnet/compare/v0.30.0...v0.31.0
v0.30.0Compare Source
What's Changed
New Contributors
Full Changelog: https://github.com/libpnet/libpnet/compare/v0.29.0...v0.30.0
v0.29.0Compare Source
interface.mac_address(), useinterface.macinsteadpnet_datalink::Channelbe#[non_exhaustive]drakulix/simplelog.rs (simplelog)
v0.12.2Compare Source
v0.12.1Compare Source
v0.12.0Compare Source
ConfigBuilder::set_time_to_localis replaced byConfigBuilder::set_time_offset_to_local.local-offsetfeature.ConfigBuilder::set_time_offsetnow takes atime::UtcOffsetinstead of achrono::FixedOffset.ConfigBuilder::set_time_formathas been replaced by three new variantsConfigBuilder::set_time_format_rfc2822sets the time format to use the format described by rfc2822.ConfigBuilder::set_time_format_rfc3339sets the time format to use the format described by rfc3339.ConfigBuilder::set_time_format_customsets the time format to a custom time format best created usingtime::macros::format_description.v0.11.2Compare Source
v0.11.1Compare Source
v0.11.0Compare Source
ansi_term(PR #88, credits to @manio)pariscrate (PR #84, credits to @manio)codyps/rust-systemd (systemd)
v0.10.1Compare Source
v0.10.0Compare Source
v0.9.3Compare Source
v0.9.2Compare Source
v0.9.1Compare Source
tokio-rs/tokio (tokio)
v1.48.0: Tokio v1.48.0Compare Source
1.48.0 (October 14th, 2025)
The MSRV is increased to 1.71.
Added
File::max_buf_size(#7594)ChainofAsyncReadExt::chain(#7599)SocketAddr::as_abstract_name(#7491)TcpStream::quickackandTcpStream::set_quickack(#7490)AsRef<Self>forTcpStreamandUnixStream(#7573)LocalKey::try_get(#7666)Ordfortask::Id(#7530)Changed
max_buf_sizewhen cloning aFile(#7593)clippy::unwrap_in_resultin#[tokio::main](#7651)PollEventednoise from Debug formats (#7675)Command::spawn_withto useFnOnce(#7511)SetOnce(#7554)UnsafeCell::get_mutinMutex::get_mutandRwLock::get_mut(#7569)Timeout<T>::poll(#7535)Fixed
join!andtry_join!(#7638)wake_by_ref()even if already woken (#7622)broadcast::Senderinbroadcast::Sender::new()(#7629)RwLock::try_*methods (#7587)Unstable
--cfgflags fortaskdumpandio_uring(#7655, #7621)io_uringinfs::write(#7567)io_uringwithFile::open()(#7617)io_uringwithOpenOptions(#7321)localruntime flavor (#7375, #7597)Documented
AsyncRead::poll_read(#7580)AsyncFdreadiness guards (#7583)UCred::pid()on Cygwin (#7611)set_reuseport()andreuseport()(#7628)SO_REUSEADDRis only set on Unix (#7533)Handle::block_on(#7665)Builder::global_queue_interval()(#7605)tokio::sync::watch::Receiver(#7584)SetOnce::wait(#7506)parking_lotfeature flag (#7663)UnboundedSender::send(#7661)sync::watch(#7601)spawn_localmethods (#7669)poll_proceed(#7586)v1.47.2Compare Source
v1.47.1: Tokio v1.47.1Compare Source
1.47.1 (August 1st, 2025)
Fixed
asyncio.EventinSetOncedocs (#7485)v1.47.0: Tokio v1.47.0Compare Source
1.47.0 (July 25th, 2025)
This release adds
poll_proceedandcooperativeto thecoopmodule forcooperative scheduling, adds
SetOnceto thesyncmodule which providessimilar functionality to [
std::sync::OnceLock], and adds a new methodsync::Notify::notified_owned()which returns anOwnedNotifiedwithouta lifetime parameter.
Added
cooperativeandpoll_proceed(#7405)SetOnce(#7418)sync::Notify::notified_owned()(#7465)Changed
AtomicWaker::wakeperformance (#7450)Documented
Readiness<'_>(#7415)v1.46.1: Tokio v1.46.1Compare Source
1.46.1 (July 4th, 2025)
This release fixes incorrect spawn locations in runtime task hooks for tasks spawned using
tokio::spawnrather thanRuntime::spawn. This issue only effected the spawn location inTaskMeta::spawned_at, and did not effect task locations in Tracing events.Unstable
TaskMeta::spawn_locationtracking where a task was spawned (#7440)v1.46.0: Tokio v1.46.0Compare Source
1.46.0 (July 2nd, 2025)
Fixed
TcpStream::shutdownincorrectly returning an error on macOS (#7290)Added
mpsc::OwnedPermit::{same_channel, same_channel_as_sender}methods (#7389)biasedoption forjoin!andtry_join!, similar toselect!(#7307)pope::OpenOptions::read_writeon Android (#7426)Cloneimplementation fornet::unix::SocketAddr(#7422)Changed
queue::Local<T>(#7340)LocalSet::{poll,drop}(#7372)Unstable
TaskMeta::spawn_locationtracking where a task was spawned (#7417)LocalOptionsparameter toruntime::Builder::build_local(#7346)Documented
start_seekis not used (#7366)AsyncWriteExt::flush(#7364)recv_buffer_sizemethod (#7336)RawFdinTcpSocketdocs (#7416)AsRawFddoc link to current Rust stdlib location (#7429)on_*_task_pollis unstable (#7311)time::advance(#7394)v1.45.1: Tokio v1.45.1Compare Source
1.45.1 (May 24th, 2025)
This fixes a regression on the wasm32-unknown-unknown target, where code that previously did not panic due to calls to
Instant::now()started failing. This is due to the stabilization of the first time-based metric.Fixed
v1.45.0: Tokio v1.45.0Compare Source
Added
worker_total_busy_duration,worker_park_count, andworker_unpark_count(#6899, #7276)Command::spawn_with(#7249)Changed
Unpinfor some trait impls (#7204)runtime::Handleas unwind safe (#7230)Unstable
v1.44.2: Tokio v1.44.2Compare Source
This release fixes a soundness issue in the broadcast channel. The channel
accepts values that are
Sendbut!Sync. Previously, the channel calledclone()on these values without synchronizing. This release fixes the channelby synchronizing calls to
.clone()(Thanks Austin Bonander for finding andreporting the issue).
Fixed
clone()call in broadcast channel (#7232)v1.44.1: Tokio v1.44.1Compare Source
1.44.1 (March 13th, 2025)
Fixed
block_in_placecontext (#7216)v1.44.0: Tokio v1.44.0Compare Source
1.44.0 (March 7th, 2025)
This release changes the
from_stdmethod on sockets to panic if a blocking socket is provided. We determined this change is not a breaking change as Tokio is not intended to operate using blocking sockets. Doing so results in runtime hangs and should be considered a bug. Accidentally passing a blocking socket to Tokio is one of the most common user mistakes. If this change causes an issue for you, please comment on #7172.Added
task::coopmodule (#7116)Command::get_kill_on_drop()(#7086)broadcast::Sender::closed(#6685, #7090)broadcast::WeakSender(#7100)oneshot::Receiver::is_empty()(#7153)oneshot::Receiver::is_terminated()(#7152)Fixed
Fileshould not start a background read (#7139)start_killon exited child should not fail (#7160)CTRL_CLOSE,CTRL_LOGOFF,CTRL_SHUTDOWNon windows (#7122)Changes
select!budget-aware (#7164)from_std(#7166)Changes to unstable APIs
Documented
select!alternatives (#7110)send_to(#7146)Childstdout (#7141)Child::killbehavior (#7162)ChildStdinstruct doc comment (#7192)worker_threadsinstead ofcore_threads(#7186)v1.43.3Compare Source
v1.43.2: Tokio v1.43.2Compare Source
1.43.2 (August 1st, 2025)
Fixed
v1.43.1Compare Source
v1.43.0: Tokio v1.43.0Compare Source
1.43.0 (Jan 8th, 2025)
Added
UdpSocket::peekmethods (#7068)Command::into_std()(#7014)SignalKind::infoon illumos (#6995)Fixed
set_lenbefore initializing vector inBlocking(#7054)clippy::needless_returnin#[tokio::main](#6874)Changes
unsync_load(#7073)Buf::put_bytesinRepeatread impl (#7055)Changes to unstable APIs
Documented
ReadBuf::uninitallows initialized buffers as well (#7053)TcpStream::try_write_vectoreddocs (#7067)LocalRuntimedoc links (#7074)watch::Receiver::wait_for(#7038)OnceCelldocs (#7047)v1.42.1: Tokio v1.42.1Compare Source
This release fixes a soundness issue in the broadcast channel. The channel accepts values that are
Sendbut!Sync. Previously, the channel calledclone()on these values without synchronizing. This release fixes the channel by synchronizing calls to.clone()(Thanks Austin Bonander for finding and reporting the issue).Fixed
clone()call in broadcast channel (#7232)v1.42.0: Tokio v1.42.0Compare Source
1.42.0 (Dec 3rd, 2024)
Added
AsyncFd::{try_io, try_io_mut}(#6967)Fixed
ptr->ref->ptrroundtrip in RegistrationSet (#6929)yield_nowinsideblock_in_place(#6999)Changes
Documented
tokio::net::unix::{pid_t, gid_t, uid_t}(#6791)Instantdocs (#6982)v1.41.1: Tokio v1.41.1Compare Source
1.41.1 (Nov 7th, 2024)
Fixed
netrequirement fornet::UdpSocketin docs (#6938)TcpStreaminternal comment (#6944)v1.41.0: Tokio v1.41.0Compare Source
1.41.0 (Oct 22th, 2024)
Added
global_queue_depth(#6854, #6918)SocketAddr(#6868)watch::Sender::sender_count(#6836)mpsc::Receiver::blocking_recv_many(#6867)Idapis (#6793, #6891)Added (unstable)
LocalRuntime(#6808)Changed
#[must_use]toNotified(#6828)watchcooperative (#6846)broadcast::Receivercooperative (#6870)cfg_fsforwasitarget (#6822)Fixed
Documented
OwnedFdwithAsyncFd(#6821)AsyncFdmethods (#6890)joinandtry_join(#6814, #6841)TcpSocket::set_nodelayandTcpSocket::nodelay(#6840)v1.40.0: Tokio v1.40.0Compare Source
1.40.0 (August 30th, 2024)
Added
util::SimplexStream(#6589)Command::process_group(#6731){TrySendError,SendTimeoutError}::into_inner(#6755)JoinSet::join_all(#6784)Added (unstable)
Builder::{on_task_spawn, on_task_terminate}(#6742)Changed
write_all_bufwhen possible (#6724)UnwindSafe(#6783)SleepandBatchSemaphoreinstrumentation explicit roots (#6727)NonZeroU64fortask::Id(#6733)JoinError(#6753)#[must_use]toJoinHandle::abort_handle(#6762)Documented
[build]section doesn't go in Cargo.toml (#6728)select!(#6774)v1.39.3: Tokio v1.39.3Compare Source
1.39.3 (August 17th, 2024)
This release fixes a regression where the unix socket api stopped accepting the abstract socket namespace. (#6772)
v1.39.2: Tokio v1.39.2Compare Source
1.39.2 (July 27th, 2024)
This release fixes a regression where the
select!macro stopped accepting expressions that make use of temporary lifetime extension. (#6722)v1.39.1: Tokio v1.39.1Compare Source
1.39.1 (July 23rd, 2024)
This release reverts "time: avoid traversing entries in the time wheel twice" because it contains a bug. (#6715)
v1.39.0: Tokio v1.39.0Compare Source
1.39.0 (July 23rd, 2024)
Added
AsyncSeekforEmpty(#6663)num_alive_tasks(#6619, #6667)Command::as_std_mut(#6608)watch::Sender::same_channel(#6637){Receiver,UnboundedReceiver}::{sender_strong_count,sender_weak_count}(#6661)Defaultforwatch::Sender(#6626)CloneforAbortHandle(#6621)consume_budget(#6622)Changed
ReadBuf::put_slice()(#6629)copy_bidirectionalandcopy(#6532)num_cpuswithavailable_parallelism(#6709)block_on(#6692)IntoFuturewithtimeout(#6666)IntoFuturewithjoin!andselect!(#6710)Fixed
Interval(#6612)Added (unstable)
unhandled_panicbehavior for#[tokio::main]and#[tokio::test](#6593)spawned_tasks_count(#6114)worker_park_unpark_count(#6696)Documented
tokio::io::stdoutdocumentation (#6674)join.rsandtry_join.rs(#6641)unhandled_panic(#6660)JoinSet::try_join_nextwhen all tasks are running (#6671)v1.38.2: Tokio v1.38.2Compare Source
This release fixes a soundness issue in the broadcast channel. The channel accepts values that are
Sendbut!Sync. Previously, the channel calledclone()on these values without synchronizing. This release fixes the channel by synchronizing calls to.clone()(Thanks Austin Bonander for finding and reporting the issue).Fixed
clone()call in broadcast channel (#7232)v1.38.1: Tokio v1.38.1Compare Source
1.38.1 (July 16th, 2024)
This release fixes the bug identified as (#6682), which caused timers not
to fire when they should.
Fixed
wake_upwhile holding all the locks of sharded time wheels (#6683)v1.38.0: Tokio v1.38.0Compare Source
This release marks the beginning of stabilization for runtime metrics. It
stabilizes
RuntimeMetrics::worker_count. Future releases will continue tostabilize more metrics.
Added
File::create_new(#6573)copy_bidirectional_with_sizes(#6500)AsyncBufReadforJoin(#6449)CloneforNamedPipeInfo(#6586)Notify::notify_last(#6520)mpsc::Receiver::{capacity,max_capacity}(#6511)splitmethod to the semaphore permit (#6472, #6478)tokio::task::join_set::Builder::spawn_blocking(#6578)Changed
#[tokio::test]append#[test]at the end of the attribute list (#6497)blocking_threadscount (#6551)RuntimeMetrics::worker_count(#6556)lifo_slotinblock_in_place(#6596)global_queue_intervalis zero (#6445)Semaphorefor task dumps (#6499)LocalKey::getwork with Clone types (#6433)true_whenfield inTimerShared(#6563)Fixed
Interval::poll_tick(#6487)is_emptyon mpsc block boundaries (#6603)Documented
stdindocumentation (#6581)ReadHalf::unsplit()documentation (#6498)select!(#6468)NamedPipeServerexample (#6590)SemaphorePermit,OwnedSemaphorePermit(#6477)Barrier::waitis not cancel safe (#6494)watch::Sender::{subscribe,closed}(#6490)spawn_blockingtasks (#6571)LocalSet::run_until(#6599)v1.37.0: Tokio v1.37.0Compare Source
1.37.0 (March 28th, 2024)
Added
set_max_buf_sizetotokio::fs::File(#6411)try_newandtry_with_interesttoAsyncFd(#6345)forget_permitsmethod to semaphore (#6331)is_closed,is_empty, andlento mpsc receivers (#6348)rwlock()method to ownedRwLockguards (#6418)Cloneforwatch::Sender(#6388)TaskLocalFuture::take_value(#6340)FromIteratorforJoinSet(#6300)Changed
io::splituse a mutex instead of a spinlock (#6403)Fixed
Documented
AsyncBufReadExt::fill_buf(#6431)AsyncReadExt's primitive read functions (#6337)Runtimeto#[tokio::main](#6366)enterexample deterministic (#6351)mpsc::Sender::downgradewith#[must_use](#6326)const_newbeforenew_with(#6392)Changed (unstable)
Idin taskdumps (#6328)unhandled_panicis enabled when not supported (#6410)v1.36.0: Tokio v1.36.0Compare Source
1.36.0 (February 2nd, 2024)
Added
tokio::io::Join(#6220)AsyncWriteforEmpty(#6235)UnixSocket(#6290)TcpSocket(#6311){Receiver,UnboundedReceiver}::poll_recv_many(#6236)Sender::{try_,}reserve_many(#6205)watch::Receiver::mark_unchanged(#6252)JoinSet::try_join_next(#6280)Changed
copycooperative (#6265)repeatandsinkcooperative (#6254)Documented
clear_readydocs (#6304)*Fdtraits onTcpSocketare unix-only (#6294)tokio::sync::Mutex(#6279)v1.35.1: Tokio v1.35.1Compare Source
1.35.1 (December 19, 2023)
This is a forward part of a change that was backported to 1.25.3.
Fixed
tokio::runtime::io::registration::async_io(#6221)v1.35.0: Tokio v1.35.0Compare Source
1.35.0 (December 8th, 2023)
Added
Changed
Sizedrequirements fromAsyncReadExt.read_buf(#6169)Runtimeunwind safe (#6189)Fixed
--cfg docsrswork without net feature (#6166)unsync_loadon miri (#6179)Documented
AsyncWriteExtexamples (#6149)LocalSet::run_until(#6147)v1.34.0: Tokio v1.34.0Compare Source
Fixed
clear_readinessafter io driver shutdown (#6067)take(#6080)broadcast::channellink (#6100)Changed
::corequalified imports instead of::stdinsidetokio::testmacro (#5973)Added
fs::read_dirto includeaix(#6075)mpsc::Receiver::recv_many(#6010)v1.33.0: Tokio v1.33.0Compare Source
1.33.0 (October 9, 2023)
Fixed
Interest::addwith#[must_use](#6037)watch::Receiver::wait_for(#6021)spawn_localsource location (#5984)Changed
watch(#6018)Added
tokio::fs::File(#5958)Interest::removemethod (#5906)DuplexStream(#5985)?Sizedbound to{MutexGuard,OwnedMutexGuard}::map(#5997)watch::Receiver::mark_unseen(#5962, #6014, #6017)watch::Sender::new(#5998)OnceCell::from_value(#5903)Removed
statsfeature (#5952)Documented
Child::waitis cancel safe (#5977)Semaphore(#5939, #5956, #5978, #6031, #6032, #6050)broadcastcapacity is a lower bound (#6042)const_newis not instrumented (#6002)mpsc::Sender::send(#5947)watchchannel (#5954)Unstable
v1.32.1: Tokio v1.32.1Compare Source
1.32.1 (December 19, 2023)
This is a forward part of a change that was backported to 1.25.3.
Fixed
tokio::runtime::io::registration::async_io(#6221)v1.32.0: Tokio v1.32.0Compare Source
Fixed
broadcast::Receiver(#5925)Added
Command::raw_arg(#5930)Unstable
v1.31.0: Tokio v1.31.0Compare Source
Fixed
WriteHalf::poll_write_vectored(#5914)Unstable
v1.30.0: Tokio v1.30.0Compare Source
1.30.0 (August 9, 2023)
This release bumps the MSRV of Tokio to 1.63. (#5887)
Changed
--cfg mio_unsupported_force_poll_pollflag (#5881)const_newmethods always available (#5885)Added
broadcast::Sender::new(#5824)UCredfor espidf (#5868)File::options()(#5869)Interval(#5878){ChildStd*}::into_owned_{fd, handle}(#5899)Removed
tokio_*cfgs (#5890)Documented
broadcast::send(#5820)AsyncReadExt::read_exact(#5863)Sleepas!Unpinin docs (#5916)raw_argnot showing up in docs (#5865)Unstable
v1.29.1: Tokio v1.29.1Compare Source
Fixed
block_in_placewith ablock_onbetween (#5837)v1.29.0: Tokio v1.29.0Compare Source
Technically a breaking change, the
Sendimplementation is removed fromruntime::EnterGuard. This change fixes a bug and should not impact most users.Breaking
EnterGuardshould not beSend(#5766)Fixed
fs::read_dir(#5653)JoinSet(#5693)EnterGuarddropped incorrect order (#5772)File(#5803)Changed
Added
broadcast::Receiver::blocking_recv(#5690)raw_argmethod toCommand(#5704)JoinSet::poll_join_next(#5721)Unstable
v1.28.2: Tokio v1.28.2Compare Source
1.28.2 (May 28, 2023)
Forward ports 1.18.6 changes.
Fixed
v1.28.1: Tokio v1.28.1Compare Source
1.28.1 (May 10th, 2023)
This release fixes a mistake in the build script that makes
AsFdimplementations unavailable on Rust 1.63. (#5677)v1.28.0: Tokio v1.28.0Compare Source
1.28.0 (April 25th, 2023)
Added
AsyncFd::async_io(#5542)recv_bufforUdpSocketandUnixDatagram(#5583)OwnedSemaphorePermit::semaphore(#5618)same_channelto broadcast channel (#5607)watch::Receiver::wait_for(#5611)JoinSet::spawn_blockingandJoinSet::spawn_blocking_on(#5612)Changed
read_to_endnot grow unnecessarily (#5610)RwLock(#5647)Notify(#5503)Fixed
get_peer_credon AIX (#5065)broadcastwith custom wakers (#5578)Documented
Semaphore::MAX_PERMITS(#5645)tokio::sync::watch::Senderdocs (#5587)v1.27.0: Tokio v1.27.0Compare Source
1.27.0 (March 27th, 2023)
This release bumps the MSRV of Tokio to 1.56. (#5559)
Added
async_iohelper method to sockets (#5512)AsFd/AsHandle/AsSocket(#5514, #5540)UdpSocket::peek_sender()(#5520)RwLockWriteGuard::{downgrade_map, try_downgrade_map}(#5527)JoinHandle::abort_handle(#5543)Changed
memchrfromlibc(#5558)#[tokio::main](#5557)IntervalreturnsReady(#5553)Fixed
ReadDir(#5555)spawn_blockinglocation fields (#5573)Wheel::poll()(#5574)Documented
tokio::io::copy[_buf](#5575)ReaderStreamandStreamReaderin module docs (#5576)v1.26.0: Tokio v1.26.0Compare Source
Fixed
join!andtry_join!(https://github.com/tokio-rs/tokio/pull/5504)Added
fs::try_exists(https://github.com/tokio-rs/tokio/pull/4299)MappedOwnedMutexGuard(https://github.com/tokio-rs/tokio/pull/5474)Changed
#[clippy::has_significant_drop](https://github.com/tokio-rs/tokio/pull/5422)Instant::now()perf with test-util (https://github.com/tokio-rs/tokio/pull/5513)Internal Changes
poll_fnincopy_bidirectional(https://github.com/tokio-rs/tokio/pull/5486)notify_waiterscalls atomic (https://github.com/tokio-rs/tokio/pull/5458)Unstable
Documented
blocking_*methods (https://github.com/tokio-rs/tokio/pull/5448)process::Commanddocs (https://github.com/tokio-rs/tokio/pull/5413)v1.25.3: Tokio v1.25.3Compare Source
1.25.3 (December 17th, 2023)
Fixed
tokio::runtime::io::registration::async_io(#6221)v1.25.2: Tokio v1.25.2Compare Source
1.25.2 (September 22, 2023)
Forward ports 1.20.6 changes.
Changed
memchrfromlibc(#5960)v1.25.1: Tokio v1.25.1Compare Source
1.25.1 (May 28, 2023)
Forward ports 1.18.6 changes.
Fixed
v1.25.0: Tokio v1.25.01.25.0 (January 28, 2023)
Fixed
Added
broadcast::Sender::len(#5343)Changed
v1.24.1: Tokio v1.24.1Compare Source
This release fixes a compilation failure on targets without
AtomicU64when using rustc older than 1.63. (#5356)v1.24.0: Tokio v1.24.0Compare Source
The highlight of this release is the reduction of lock contention for all I/O operations (#5300). We have received reports of up to a 20% improvement in CPU utilization and increased throughput for real-world I/O heavy applications.
Fixed
AtomicU64support detection (#5284)Added
per tick (#5186)
threads per runtime instance (#4250)
Changed
read_dir()by chunking operations (#5309)ThreadIdimplementation (#5329)spawn_blockingtask is running (#5115)v1.23.1: Tokio v1.23.1Compare Source
This release forward ports changes from 1.18.4.
Fixed
pipe mode (#5336).
v1.23.0: Tokio v1.23.0Compare Source
Fixed
ChildStdin(#5216)async fn ready()false positive for OS-specific events (#5231)Changed
yield_nowdefers task until after driver poll (#5223)winapidependency withwindows-sys(#5204)v1.22.0: Tokio v1.22.0Compare Source
Added
Handle::runtime_flavor(#5138)Mutex::blocking_lock_owned(#5130)Semaphore::MAX_PERMITS(#5144)merge()to semaphore permits (#4948)mpsc::WeakUnboundedSender(#5189)Added (unstable)
Command::process_group(#5114)task::id()andtask::try_id()(#5171)Fixed
LocalOwnedTasks(#5099)mark_pendingcalled illegally (#5093)unsync_loadon atomic types (#5175)LocalSetdrop in thread local (#5179)CachePadded(#5106)Changed
tokio::io::copycontinue filling the buffer when writer stalls (#5066)coop::budgetfromLocalSet::run_until(#5155)Notifypanic safe (#5154)Documented
write_i8to use signed integers (#5040)set_tosmethods (#5073)UdpSocket::recvdocumentation (#5150)TryLockErrorforRwLock::try_write(#5160)timeout(#5118)timeoutchecks only before poll (#5126)oneshot::Receiverin docs (#5198)Internal changes
Mutex::newfor globals (#5061)Optionaroundmio::Eventsin io driver (#5078)io::handlerefs with scheduler:Handle (#5128)scheduler::Handle(#5135)runtime::contextmodule (#5140)driver.rs(#5141)runtime::contextto unify thread-locals (#5143)coopmod intoruntime(#5152)Runtimeinto its own file (#5159)Handle::enter(#5163)enterintocontext(#5167)CoreStagemethods toCore(#5182)v1.21.2: Tokio v1.21.2Compare Source
1.21.2 (September 27, 2022)
This release removes the dependency on the
once_cellcrate to restore the MSRV of 1.21.x, which is the latest minor version at the time of release. (#5048)v1.21.1: Tokio v1.21.1Compare Source
1.21.1 (September 13, 2022)
Fixed
LocalSetDrop (#4976)v1.21.0: Tokio v1.21.0Compare Source
1.21.0 (September 2, 2022)
This release is the first release of Tokio to intentionally support WASM. The
sync,macros,io-util,rt,timefeatures are stabilized on WASM. Additionally the wasm32-wasi target is given unstable support for thenetfeature.Added
deviceandbind_devicemethods to TCP/UDP sockets (#4882)tosandset_tosmethods to TCP and UDP sockets (#4877)ServerOptions(#4845)mpsc::Sender::max_capacitymethod (#4904)mpsc::Sender(#4595)LocalSet::enter(#4765)JoinSetandAbortHandle(#4920)track_callerto public APIs (#4805, #4848, #4852)wasm32-wasitarget (#4716)Fixed
linked_list::Linkimpls (#4841)#[must_use]to lock guards (#4886)recvon closed and reopened broadcast channel (#4867)Changed
File::start_seek(#4897)poll_read(#4840)SignalKindmethods const (#4956)Internal changes
basic_scheduler::Config(#4935)runtimemodule (#4942)Documented
AsyncSeekExt::rewinddocs (#4893)try_read()for zero-length buffers (#4937)Builder::worker_threads(#4849)watch::Sender::sendimproved (#4959)JoinHandle(#4901)spawn_blocking(#4811)Interval::tickhappens immediately (#4951)Unstable
Builder::spawn_on(#4953)task::Builder::spawn*methods fallible (#4823)v1.20.6: Tokio v1.20.6Compare Source
1.20.6 (September 22, 2023)
This is a backport of a change from 1.27.0.
Changed
memchrfromlibc(#5960)v1.20.5: Tokio v1.20.5Compare Source
1.20.5 (May 28, 2023)
Forward ports 1.18.6 changes.
Fixed
v1.20.4Compare Source
v1.20.3Compare Source
v1.20.2: Tokio v1.20.2Compare Source
1.20.2 (September 27, 2022)
This release removes the dependency on the
once_cellcrate to restore the MSRV of the 1.20.x LTS release. (#5048)v1.20.1: Tokio v1.20.1Compare Source
1.20.1 (July 25, 2022)
Fixed
v1.20.0: Tokio v1.20.0Compare Source
1.20.0 (July 12, 2022)
Added
has_changedmethod towatch::Ref(#4758)Changed
src/time/driver/wheel/stack.rs(#4766)Fixed
Documented
Unstable
join_onetojoin_next(#4755)v1.19.2: Tokio v1.19.2Compare Source
1.19.2 (June 6, 2022)
This release fixes another bug in
Notified::enable. (#4751)v1.19.1: Tokio v1.19.1Compare Source
1.19.1 (June 5, 2022)
This release fixes a bug in
Notified::enable. (#4747)v1.19.0: Tokio v1.19.0Compare Source
1.19.0 (June 3, 2022)
Added
is_finishedmethod forJoinHandleandAbortHandle(#4709)Notified::enable(#4705)watch::Sender::send_if_modified(#4591)take_errortoTcpSocketandTcpStream(#4739)Changed
Fixed
join!andtry_join!(#4624)Documented
block_on(#4729)MissedTickBehavior::Burst(#4713)Unstable
IoDriverMetrics(#4725)#[track_caller]toJoinSet/JoinMap(#4697)Builder::{spawn_on, spawn_local_on, spawn_blocking_on}(#4683)consume_budgetfor cooperative scheduling (#4498)join_set::Builderfor configuringJoinSettasks (#4687)JoinSet::join_one(#4726)v1.18.6: Tokio v1.18.6Compare Source
1.18.6 (May 28, 2023)
Fixed
v1.18.5Compare Source
v1.18.4Compare Source
v1.18.3: Tokio v1.18.3Compare Source
1.18.3 (September 27, 2022)
This release removes the dependency on the
once_cellcrate to restore the MSRV of the 1.18.x LTS release. (#5048)v1.18.2: Tokio v1.18.2Compare Source
1.18.2 (May 5, 2022)
Add missing features for the
winapidependency. (#4663)v1.18.1: Tokio v1.18.1Compare Source
1.18.1 (May 2, 2022)
The 1.18.0 release broke the build for targets without 64-bit atomics when building with
tokio_unstable. This release fixes that. (#4649)v1.18.0: Tokio v1.18.0Compare Source
1.18.0 (April 27, 2022)
This release adds a number of new APIs in
tokio::net,tokio::signal, andtokio::sync. In addition, it adds new unstable APIs totokio::task(Idsfor uniquely identifying a task, and
AbortHandlefor remotely cancelling atask), as well as a number of bugfixes.
Fixed
#[track_caller]forspawn_blocking(#4616)selectmacro to process 64 branches (#4519)try_iomethods not calling Mio'stry_iointernally (#4582)Added
UdpSocket::peer_addr(#4611)try_read_bufmethod for named pipes (#4626)SignalKindHash/Eqimpls andc_intconversion (#4540)SIGRTMAX(#4555)watch::Sender::send_modifymethod (#4310)broadcast::Receiver::lenmethod (#4542)watch::Receiver::same_channelmethod (#4581)CloneforRecvErrortypes (#4560)Changed
mioto 0.8.1 (#4582)tokio::select!'s internalutilmodule (#4543)Vec::with_capacitywhen building runtime (#4553)Documented
tokio_unstable(#4524)Handle::current's docs to mentionEnterGuard(#4567)Signal::recvis cancel-safe (#4634)UnboundedReceiverclose docs (#4548)Unstable
The following changes only apply when building with
--cfg tokio_unstable:task::Idtype (#4630)AbortHandletype for cancelling tasks in aJoinSet(#4530],[#4640)
doc(cfg(...))attributes forJoinSet(#4531)AbortHandleRustDoc (#4545)v1.17.0: Tokio v1.17.0Compare Source
1.17.0 (February 15, 2022)
This release updates the minimum supported Rust version (MSRV) to 1.49,
the
miodependency to v0.8, and the (optional)parking_lotdependency to v0.12. Additionally, it contains several bug fixes, as
well as internal refactoring and performance improvements.
Fixed
sleepwith large durations (#4495)Instantarithmetic on platformswhere
Instant::nowis not monotonic (#4461)DuplexStreamnot participating in cooperative yielding(#4478)
JoinHandle(#4430)Changed
parking_lotdependency to v0.12.0 (#4459)miodependency to v0.8 (#4449)(#4480)
std::future::Readyinstead of our ownReadyfuture(#4271)
atomic::spin_loop_hintwithhint::spin_loop(#4491)
Documented
tokio::process::ChildStdin(#4479)Unstable
The following changes only apply when building with
--cfg tokio_unstable:tracingspans generated byspawn_local(#4483)JoinSetfor managing sets of tasks (#4335)v1.16.1: Tokio v1.16.1Compare Source
1.16.1 (January 28, 2022)
This release fixes a bug in #4428 with the change #4437.
v1.16.0: Tokio v1.16.0Compare Source
Fixes a soundness bug in
io::Take(#4428). The unsoundness is exposed whenleaking memory in the given
AsyncReadimplementation and then overwriting thesupplied buffer:
Also, this release includes improvements to the multi-threaded scheduler that
can increase throughput by up to 20% in some cases (#4383).
Fixed
io::Takein edge case (#4428)File::writeresults in awritesyscall when the runtime shuts down (#4316)wait_with_output(#4315)Sendfromparking_lot::*Guard(#4359)Added
TcpSocket::linger()andset_linger()(#4324)UnwindSafefor socket types (#4384)UnwindSafeforJoinHandle(#4418)watch::Receiver::has_changed()(#4342)oneshot::Receiver::blocking_recv()(#4334)RwLockblocking operations (#4425)Unstable
The following changes only apply when building with
--cfg tokio_unstablev1.15.0: Tokio v1.15.0Compare Source
Fixed
io::empty()(#4300)Changed
Added
Interval::reset()(#4248)AsyncFdReadyGuard(#4267)Command::as_std()(#4295)Added (unstable)
tokio::synctypes (#4302)v1.14.1: Tokio v1.14.1Compare Source
This release backports a bug fix from 1.16.1
Fixes a soundness bug in
io::Take(#4428). The unsoundness is exposed whenleaking memory in the given
AsyncReadimplementation and then overwriting thesupplied buffer:
Fixed
io::Takein edge case (#4428)v1.14.0: Tokio v1.14.0Compare Source
1.14.0 (November 15, 2021)
Fixed
mutpatterns inselect!(#4211)oneshot::Sender::sendand awaiting aoneshot::Receiverwhen the oneshot has been closed (#4226)AtomicWakerpanic safe (#3689)(#4213)
Added
RuntimeStats::busy_duration_total(#4179, #4223)Changed
copybuffer size to matchstd::io::copy(#4209)Documented
v1.13.1: Tokio v1.13.1Compare Source
1.13.1 (November 15, 2021)
This release fixes a data race when sending and receiving on a
closed
oneshotchannel (RUSTSEC-2021-0124).Fixed
oneshot::Sender::sendand awaiting aoneshot::Receiverwhen the oneshot has been closed (#4226)v1.13.0: Tokio v1.13.0Compare Source
1.13.0 (October 29, 2021)
Fixed
Notifyto clone the waker before locking its waiter list (#4129)Added
poll_{recv,send}_readymethods toudpanduds_datagram(#4131)try_*,readable,writable,ready, andpeer_addrmethods to split halves (#4120)blocking_locktoMutex(#4130)watch::Sender::send_replace(#3962, #4195)DebugforMutex<T>impl to unsizedT(#4134)Changed
copy_bidirectionalthatpoll_writeis sensible (#4125)select!(#4192)block_onwakeups better (#4157)Documented
try_join!(#4133)tokio/src/lib.rs(#4132)Interval::tickcancel safety (#4152)Configuration
📅 Schedule: Branch creation - At any time (no schedule defined), Automerge - At any time (no schedule defined).
🚦 Automerge: Disabled by config. Please merge this manually once you are satisfied.
♻ Rebasing: Whenever PR becomes conflicted, or you tick the rebase/retry checkbox.
👻 Immortal: This PR will be recreated if closed unmerged. Get config help if that's undesired.
This PR has been generated by Renovate Bot.
14094b522bto7b5baea7c47b5baea7c4to952a3ff57f952a3ff57ftoc654ace384c654ace384to0d62f71d91View command line instructions
Checkout
From your project repository, check out a new branch and test the changes.Merge
Merge the changes and update on Forgejo.Warning: The "Autodetect manual merge" setting is not enabled for this repository, you will have to mark this pull request as manually merged afterwards.