fix(deps): update all dependencies #1

Open
kjuulh wants to merge 1 commits from renovate/all into main
Owner

This PR contains the following updates:

Package Type Update Change
cfg-if workspace.dependencies patch 1.0.0 -> 1.0.4
http workspace.dependencies minor 1.2.0 -> 1.4.0
leptos (source) workspace.dependencies minor 0.7.4 -> 0.8.0
leptos_axum workspace.dependencies minor 0.7.4 -> 0.8.0
leptos_meta workspace.dependencies minor 0.7.4 -> 0.8.0
leptos_router workspace.dependencies minor 0.7.4 -> 0.8.0
log workspace.dependencies patch 0.4.25 -> 0.4.29
reqwest dependencies patch 0.12.12 -> 0.12.24
serde_json dependencies patch 1.0.136 -> 1.0.145
server_fn workspace.dependencies minor 0.7.4 -> 0.8.0
simple_logger workspace.dependencies minor 5.0.0 -> 5.1.0
thiserror workspace.dependencies patch 2.0.11 -> 2.0.17
tokio (source) workspace.dependencies minor 1.43.0 -> 1.48.0
tower-http workspace.dependencies patch 0.6.2 -> 0.6.7
uuid workspace.dependencies minor 1.12.0 -> 1.19.0
wasm-bindgen (source) workspace.dependencies patch =0.2.100 -> =0.2.106
web-sys (source) dependencies patch 0.3.77 -> 0.3.83

Release Notes

rust-lang/cfg-if (cfg-if)

v1.0.4

Compare Source

  • Support cfg(true) and cfg(false) (#​99)
  • Set and test a MSRV of 1.32
  • Have a single top-level rule

v1.0.3

Compare Source

  • Revert "Remove @__identity rule."

v1.0.2

Compare Source

  • Remove @__identity rule.

v1.0.1

Compare Source

  • Remove compiler-builtins from rustc-dep-of-std dependencies
  • Remove redundant configuration from Cargo.toml
  • More readable formatting and identifier names. (#​39)
  • Add expanded example to readme (#​38)
hyperium/http (http)

v1.4.0

Compare Source

  • Add StatusCode::EARLY_HINTS constant for 103 Early Hints.
  • Make StatusCode::from_u16 now a const fn.
  • Make Authority::from_static now a const fn.
  • Make PathAndQuery::from_static now a const fn.
  • MSRV increased to 1.57 (allows legible const fn panic messages).

v1.3.1

Compare Source

  • Fix validation that all characters are UTF-8 in URI path and query.

v1.3.0

Compare Source

  • Allow most UTF-8 characters in URI path and query.
  • Fix HeaderMap::reserve() to allocate sufficient capacity.
leptos-rs/leptos (leptos)

v0.8.14

Compare Source

What's Changed

Full Changelog: https://github.com/leptos-rs/leptos/compare/v0.8.13...v0.8.14

v0.8.13

Compare Source

What's Changed

New Contributors

Full Changelog: https://github.com/leptos-rs/leptos/compare/v0.8.12...v0.8.13

v0.8.12

Compare Source

What's Changed

Full Changelog: https://github.com/leptos-rs/leptos/compare/v0.8.11...v0.8.12

v0.8.11

Compare Source

What's Changed

New Contributors

Full Changelog: https://github.com/leptos-rs/leptos/compare/v0.8.10...v0.8.11

v0.8.10

Compare Source

What's Changed

New Contributors

Full Changelog: https://github.com/leptos-rs/leptos/compare/v0.8.9...v0.8.10

v0.8.9

Compare Source

This includes patch releases to the reactive_graph, tachys, wasm_split_macros, server_fn, leptos, and router crates.

What's Changed

Full Changelog: https://github.com/leptos-rs/leptos/compare/v0.8.8...v0.8.9

v0.8.8

What's Changed

New Contributors

Full Changelog: https://github.com/leptos-rs/leptos/compare/v0.8.6...v0.8.8

v0.8.6

Compare Source

Just a patch release, mostly to support #[server] #[lazy] for lazy server functions.

Going forward, patch releases for various crates will have version numbers that are not coupled to one another, and will only be bumped when they've actually changed; so this release is 0.8.6 for leptos, leptos_macro, and server_fn_macro, but does not arbitrarily bump other packages that haven't changed.

See 0.8.5 for notes on WASM splitting.

What's Changed

Full Changelog: https://github.com/leptos-rs/leptos/compare/v0.8.5...v0.8.6

v0.8.5: : WASM code splitting released!

Compare Source

This release includes WASM code-splitting/lazy-loading support, in tandem with the latest cargo-leptos release.

You can use the lazy_routes example to understand what this means!

Essentially, though, there are two patterns:

  1. Use the #[lazy] macro to make any given function lazy
  2. Use the #[lazy_route] to designate a route with a lazy-loaded view, which is loaded concurrently with the route's data

#[lazy] converts a (sync or async) function into a lazy-loaded async function


#[lazy]
fn deserialize_comments(data: &str) -> Vec<Comment> {
    serde_json::from_str(data).unwrap()
}

#[lazy_route] lets you split routes into a "data" half and a "view" half, which will be concurrently loaded by the router. This works with nested routing: so if you have ViewD and ViewE, then the router will concurrently load D's data, D's (lazy) view, E's data, and E's (lazy) view, before navigating to the page.

struct ViewD {
    data: Resource<Result<Vec<i32>, ServerFnError>>,
}

#[lazy_route]
impl LazyRoute for ViewD {
    fn data() -> Self {
        Self {
            data: Resource::new(|| (), |_| d_data()),
        }
    }

    fn view(this: Self) -> AnyView {
        let items = move || {
            Suspend::new(async move {
                this.data
                    .await
                    .unwrap_or_default()
                    .into_iter()
                    .map(|item| view! { <li>{item}</li> })
                    .collect::<Vec<_>>()
            })
        };
        view! {
            <p id="page">"View D"</p>
            <hr/>
            <Suspense fallback=|| view! { <p id="loading">"Loading..."</p> }>
                <ul>{items}</ul>
            </Suspense>
            <Outlet/>
        }
        .into_any()
    }
}

#[server]
async fn d_data() -> Result<Vec<i32>, ServerFnError> {
    tokio::time::sleep(std::time::Duration::from_millis(250)).await;
    Ok(vec![1, 1, 2, 3, 5, 8, 13])
}

Our whole July stream was dedicated to the topic, if you want more in depth discussion.

What's Changed

Full Changelog: https://github.com/leptos-rs/leptos/compare/v0.8.4...v0.8.5

v0.8.4

Compare Source

There are some small bugfixes in here, as well as improvements to the hot-reloading code. This is mostly intended to be a sort of "last patch" before merging the code-splitting changes in #​3988, so that there is a patch people can pin to in case those inadvertently introduce any regressions.

What's Changed

New Contributors

Full Changelog: https://github.com/leptos-rs/leptos/compare/v0.8.3...v0.8.4

v0.8.3

Compare Source

This is a minor patch release. It does include a significant re-write of how ownership/context work with nested routes (#​4091). This should close a number of bugs. However, it's always possible that changes like this introduce regressions. Please test to see whether you have any issues with context and nested routing, and let me know. (We have a new regression example set up to add e2e regression tests for issues going forward.)

What's Changed
New Contributors

Full Changelog: https://github.com/leptos-rs/leptos/compare/v0.8.2...v0.8.3

v0.8.2

Compare Source

For 0.8 release notes in general, see 0.8.0. This patch release mostly addresses a bad issue with hydrating <Stylesheet/> and other meta components. (See #​3945 #​3946)

What's Changed

Full Changelog: https://github.com/leptos-rs/leptos/compare/v0.8.1...v0.8.2

v0.8.1

Compare Source

For 0.8 release notes in general, see 0.8.0. This patch release is mostly just a bunch of bugfixes for issues raised or fixed since then.

What's Changed
New Contributors

Full Changelog: https://github.com/leptos-rs/leptos/compare/v0.8.0...v0.8.1

v0.8.0

Compare Source

*Changelog relative to 0.7.8. *

0.8 has been planned for a while, primarily to accommodate small changes that arose during the course of testing and adopting 0.7, most of which are technically semver-breaking but should not meaningfully affect user code. I think it's a significant QOL and user DX upgrade and I'm excited to properly release it.

Noteworthy features:

  • Axum 0.8 support. (This alone required a major version bump, as we reexport some Axum types.) (thanks to @​sabify for the migration work here)
  • Significant improvements to compile times when using --cfg=erase_components, which is useful as a dev-mode optimization (thanks to @​zakstucke) This is the default setting for cargo-leptos with its latest release, and can be set up manually for use with Trunk. (See docs here.)
  • Support for the new islands-router features that allow a client-side routing experience while using islands (see the islands_router example) (this one was me)
  • Improved server function error handling by allowing you to use any type that implements FromServerFnError rather than being constrained to use ServerFnError (see #​3274). (Note: This will require changes if you're using a custom error type, but should be a better experience.) (thanks to @​ryo33)
  • Support for creating WebSockets via server fns (thanks to @​ealmloff)
  • Changes to make custom errors significantly more ergonomic when using server functions
  • LocalResource no longer exposes a SendWrapper in the API for the types it returns. (Breaking change: this will require removing some .as_deref() and so on when using LocalResource, but ends up with a much better API.)
  • Significantly improved DX/bugfixes for thread-local Actions.

As you can see this was a real team effort and, as always, I'm grateful for the contributions of everyone named above, and all those who made commits below.

WebSocket Example

The WebSocket support is particularly exciting, as it allows you to call server functions using the default Rust Stream trait from the futures crate, and have those streams send messages over websockets without you needing to know anything about that process. The API landed in a place that feels like a great extension of the "server function" abstraction in which you can make HTTP requests as if they were ordinary async calls. The websocket stuff doesn't integrate directly with Resources/SSR (which make more sense for one-shot things) but is really easy to use:

use server_fn::{codec::JsonEncoding, BoxedStream, ServerFnError, Websocket};

// The websocket protocol can be used on any server function that accepts and returns a [`BoxedStream`]
// with items that can be encoded by the input and output encoding generics.
//
// In this case, the input and output encodings are [`Json`] and [`Json`], respectively which requires
// the items to implement [`Serialize`] and [`Deserialize`].

#[server(protocol = Websocket<JsonEncoding, JsonEncoding>)]
async fn echo_websocket(
    input: BoxedStream<String, ServerFnError>,
) -> Result<BoxedStream<String, ServerFnError>, ServerFnError> {
    use futures::channel::mpsc;
    use futures::{SinkExt, StreamExt};
    let mut input = input; // FIXME :-) server fn fields should pass mut through to destructure

    // create a channel of outgoing websocket messages 
    // we'll return rx, so sending a message to tx will send a message to the client via the websocket
    let (mut tx, rx) = mpsc::channel(1);

    // spawn a task to listen to the input stream of messages coming in over the websocket 
    tokio::spawn(async move {
        while let Some(msg) = input.next().await {
            // do some work on each message, and then send our responses 
            tx.send(msg.map(|msg| msg.to_ascii_uppercase())).await;
        }
    });

    Ok(rx.into())
}

#[component]
pub fn App() -> impl IntoView {
    use futures::channel::mpsc;
    use futures::StreamExt;
    let (mut tx, rx) = mpsc::channel(1);
    let latest = RwSignal::new(None);

    // we'll only listen for websocket messages on the client
    if cfg!(feature = "hydrate") {
        spawn_local(async move {
            match echo_websocket(rx.into()).await {
                Ok(mut messages) => {
                    while let Some(msg) = messages.next().await {
                        latest.set(Some(msg));
                    }
                }
                Err(e) => leptos::logging::warn!("{e}"),
            }
        });
    }

    view! {
        <input type="text" on:input:target=move |ev| {
            tx.try_send(Ok(ev.target().value()));
        }/>
        <p>{latest}</p>
    }
}
What's Changed
New Contributors

Full Changelog: https://github.com/leptos-rs/leptos/compare/v0.7.8...v0.8.0

v0.7.8

Compare Source

A minor release with some quality of life improvements and bugfixes

What's Changed
New Contributors

Full Changelog: https://github.com/leptos-rs/leptos/compare/v0.7.7...v0.7.8

v0.7.7

If you're migrating from 0.6 to 0.7, please see the 0.7.0 release notes here.

This is a small patch release including primarily bugfixes, and some small ergonomic improvements.

What's Changed
New Contributors

Full Changelog: https://github.com/leptos-rs/leptos/compare/v0.7.5...v0.7.7

v0.7.5

Compare Source

If you're migrating from 0.6 to 0.7, please see the 0.7.0 release notes here.

This is a small patch release including primarily bugfixes.

What's Changed
New Contributors

Full Changelog: https://github.com/leptos-rs/leptos/compare/v0.7.4...v0.7.5

rust-lang/log (log)

v0.4.29

Compare Source

v0.4.28

Compare Source

v0.4.27

Compare Source

What's Changed

Full Changelog: https://github.com/rust-lang/log/compare/0.4.26...0.4.27

v0.4.26

Compare Source

What's Changed

Full Changelog: https://github.com/rust-lang/log/compare/0.4.25...0.4.26

seanmonstar/reqwest (reqwest)

v0.12.24

Compare Source

  • Refactor cookie handling to an internal middleware.
  • Refactor internal random generator.
  • Refactor base64 encoding to reduce a copy.
  • Documentation updates.

v0.12.23

Compare Source

  • Add ClientBuilder::unix_socket(path) option that will force all requests over that Unix Domain Socket.
  • Add ClientBuilder::retry(policy) and reqwest::retry::Builder to configure automatic retries.
  • Add ClientBuilder::dns_resolver2() with more ergonomic argument bounds, allowing more resolver implementations.
  • Add http3_* options to blocking::ClientBuilder.
  • Fix default TCP timeout values to enabled and faster.
  • Fix SOCKS proxies to default to port 1080
  • (wasm) Add cache methods to RequestBuilder.

v0.12.22

Compare Source

  • Fix socks proxies when resolving IPv6 destinations.

v0.12.21

Compare Source

  • Fix socks proxy to use socks4a:// instead of socks4h://.
  • Fix Error::is_timeout() to check for hyper and IO timeouts too.
  • Fix request Error to again include URLs when possible.
  • Fix socks connect error to include more context.
  • (wasm) implement Default for Body.

v0.12.20

Compare Source

  • Add ClientBuilder::tcp_user_timeout(Duration) option to set TCP_USER_TIMEOUT.
  • Fix proxy headers only using the first matched proxy.
  • (wasm) Fix re-adding Error::is_status().

v0.12.19

Compare Source

  • Fix redirect that changes the method to GET should remove payload headers.
  • Fix redirect to only check the next scheme if the policy action is to follow.
  • (wasm) Fix compilation error if cookies feature is enabled (by the way, it's a noop feature in wasm).

v0.12.18

Compare Source

  • Fix compilation when socks enabled without TLS.

v0.12.17

Compare Source

  • Fix compilation on macOS.

v0.12.16

Compare Source

  • Add ClientBuilder::http3_congestion_bbr() to enable BBR congestion control.
  • Add ClientBuilder::http3_send_grease() to configure whether to send use QUIC grease.
  • Add ClientBuilder::http3_max_field_section_size() to configure the maximum response headers.
  • Add ClientBuilder::tcp_keepalive_interval() to configure TCP probe interval.
  • Add ClientBuilder::tcp_keepalive_retries() to configure TCP probe count.
  • Add Proxy::headers() to add extra headers that should be sent to a proxy.
  • Fix redirect::Policy::limit() which had an off-by-1 error, allowing 1 more redirect than specified.
  • Fix HTTP/3 to support streaming request bodies.
  • (wasm) Fix null bodies when calling Response::bytes_stream().

v0.12.15

Compare Source

  • Fix Windows to support both ProxyOverride and NO_PROXY.
  • Fix http3 to support streaming response bodies.
  • Fix http3 dependency from public API misuse.

v0.12.14

Compare Source

  • Fix missing fetch_mode_no_cors(), marking as deprecated when not on WASM.

v0.12.13

Compare Source

  • Add Form::into_reader() for blocking multipart forms.
  • Add Form::into_stream() for async multipart forms.
  • Add support for SOCKS4a proxies.
  • Fix decoding responses with multiple zstd frames.
  • Fix RequestBuilder::form() from overwriting a previously set Content-Type header, like the other builder methods.
  • Fix cloning of request timeout in blocking::Request.
  • Fix http3 synchronization of connection creation, reducing unneccesary extra connections.
  • Fix Windows system proxy to use ProxyOverride as a NO_PROXY value.
  • Fix blocking read to correctly reserve and zero read buffer.
  • (wasm) Add support for request timeouts.
  • (wasm) Fix Error::is_timeout() to return true when from a request timeout.
serde-rs/json (serde_json)

v1.0.145

Compare Source

  • Raise serde version requirement to >=1.0.220

v1.0.144

Compare Source

  • Switch serde dependency to serde_core (#​1285)

v1.0.143

Compare Source

v1.0.142

Compare Source

v1.0.141

Compare Source

v1.0.140

Compare Source

  • Documentation improvements

v1.0.139

Compare Source

  • Documentation improvements

v1.0.138

Compare Source

  • Documentation improvements

v1.0.137

Compare Source

  • Turn on "float_roundtrip" and "unbounded_depth" features for serde_json in play.rust-lang.org (#​1231)
borntyping/rust-simple_logger (simple_logger)

v5.1.0

Compare Source

  • Added documentation and an example for init_with_env (closes #​96).
  • Updated minimum versions of dependencies (closes #​74).

Full Changelog: https://github.com/borntyping/rust-simple_logger/compare/v5.0.0...v5.1.0

dtolnay/thiserror (thiserror)

v2.0.17

Compare Source

  • Use differently named __private module per patch release (#​434)

v2.0.16

Compare Source

  • Add to "no-std" crates.io category (#​429)

v2.0.15

Compare Source

  • Prevent Error::provide API becoming unavailable from a future new compiler lint (#​427)

v2.0.14

Compare Source

  • Allow build-script cleanup failure with NFSv3 output directory to be non-fatal (#​426)

v2.0.13

Compare Source

  • Documentation improvements

v2.0.12

Compare Source

  • Prevent elidable_lifetime_names pedantic clippy lint in generated impl (#​413)
tokio-rs/tokio (tokio)

v1.48.0: Tokio v1.48.0

Compare Source

1.48.0 (October 14th, 2025)

The MSRV is increased to 1.71.

Added
  • fs: add File::max_buf_size (#​7594)
  • io: export Chain of AsyncReadExt::chain (#​7599)
  • net: add SocketAddr::as_abstract_name (#​7491)
  • net: add TcpStream::quickack and TcpStream::set_quickack (#​7490)
  • net: implement AsRef<Self> for TcpStream and UnixStream (#​7573)
  • task: add LocalKey::try_get (#​7666)
  • task: implement Ord for task::Id (#​7530)
Changed
  • deps: bump windows-sys to version 0.61 (#​7645)
  • fs: preserve max_buf_size when cloning a File (#​7593)
  • macros: suppress clippy::unwrap_in_result in #[tokio::main] (#​7651)
  • net: remove PollEvented noise from Debug formats (#​7675)
  • process: upgrade Command::spawn_with to use FnOnce (#​7511)
  • sync: remove inner mutex in SetOnce (#​7554)
  • sync: use UnsafeCell::get_mut in Mutex::get_mut and RwLock::get_mut (#​7569)
  • time: reduce the generated code size of Timeout<T>::poll (#​7535)
Fixed
  • macros: fix hygiene issue in join! and try_join! (#​7638)
  • net: fix copy/paste errors in udp peek methods (#​7604)
  • process: fix error when runtime is shut down on nightly-2025-10-12 (#​7672)
  • runtime: use release ordering in wake_by_ref() even if already woken (#​7622)
  • sync: close the broadcast::Sender in broadcast::Sender::new() (#​7629)
  • sync: fix implementation of unused RwLock::try_* methods (#​7587)
Unstable
  • tokio: use cargo features instead of --cfg flags for taskdump and io_uring (#​7655, #​7621)
  • fs: support io_uring in fs::write (#​7567)
  • fs: support io_uring with File::open() (#​7617)
  • fs: support io_uring with OpenOptions (#​7321)
  • macros: add local runtime flavor (#​7375, #​7597)
Documented
  • io: clarify the zero capacity case of AsyncRead::poll_read (#​7580)
  • io: fix typos in the docs of AsyncFd readiness guards (#​7583)
  • net: clarify socket gets closed on drop (#​7526)
  • net: clarify the behavior of UCred::pid() on Cygwin (#​7611)
  • net: clarify the supported platform of set_reuseport() and reuseport() (#​7628)
  • net: qualify that SO_REUSEADDR is only set on Unix (#​7533)
  • runtime: add guide for choosing between runtime types (#​7635)
  • runtime: clarify the behavior of Handle::block_on (#​7665)
  • runtime: clarify the edge case of Builder::global_queue_interval() (#​7605)
  • sync: clarify bounded channel panic behavior (#​7641)
  • sync: clarify the behavior of tokio::sync::watch::Receiver (#​7584)
  • sync: document cancel safety on SetOnce::wait (#​7506)
  • sync: fix the docs of parking_lot feature flag (#​7663)
  • sync: improve the docs of UnboundedSender::send (#​7661)
  • sync: improve the docs of sync::watch (#​7601)
  • sync: reword allocation failure paragraph in broadcast docs (#​7595)
  • task: clarify the behavior of several spawn_local methods (#​7669)
  • task: clarify the task ID reuse guarantees (#​7577)
  • task: improve the example of poll_proceed (#​7586)

v1.47.2

Compare Source

v1.47.1: Tokio v1.47.1

Compare Source

1.47.1 (August 1st, 2025)

Fixed
  • process: fix panic from spurious pidfd wakeup (#​7494)
  • sync: fix broken link of Python asyncio.Event in SetOnce docs (#​7485)

v1.47.0: Tokio v1.47.0

Compare Source

1.47.0 (July 25th, 2025)

This release adds poll_proceed and cooperative to the coop module for
cooperative scheduling, adds SetOnce to the sync module which provides
similar functionality to [std::sync::OnceLock], and adds a new method
sync::Notify::notified_owned() which returns an OwnedNotified without
a lifetime parameter.

Added

  • coop: add cooperative and poll_proceed (#​7405)
  • sync: add SetOnce (#​7418)
  • sync: add sync::Notify::notified_owned() (#​7465)

Changed

  • deps: upgrade windows-sys 0.52 → 0.59 ([#​7117])
  • deps: update to socket2 v0.6 ([#​7443])
  • sync: improve AtomicWaker::wake performance (#​7450)

Documented

  • metrics: fix listed feature requirements for some metrics (#​7449)
  • runtime: improve safety comments of Readiness<'_> (#​7415)

v1.46.1: Tokio v1.46.1

Compare Source

1.46.1 (July 4th, 2025)

This release fixes incorrect spawn locations in runtime task hooks for tasks spawned using tokio::spawn rather than Runtime::spawn. This issue only effected the spawn location in TaskMeta::spawned_at, and did not effect task locations in Tracing events.

Unstable

  • runtime: add TaskMeta::spawn_location tracking where a task was spawned (#​7440)

v1.46.0: Tokio v1.46.0

Compare Source

1.46.0 (July 2nd, 2025)

Fixed
  • net: fixed TcpStream::shutdown incorrectly returning an error on macOS (#​7290)

Added

  • sync: mpsc::OwnedPermit::{same_channel, same_channel_as_sender} methods (#​7389)
  • macros: biased option for join! and try_join!, similar to select! (#​7307)
  • net: support for cygwin (#​7393)
  • net: support pope::OpenOptions::read_write on Android (#​7426)
  • net: add Clone implementation for net::unix::SocketAddr (#​7422)

Changed

  • runtime: eliminate unnecessary lfence while operating on queue::Local<T> (#​7340)
  • task: disallow blocking in LocalSet::{poll,drop} (#​7372)

Unstable

  • runtime: add TaskMeta::spawn_location tracking where a task was spawned (#​7417)
  • runtime: removed borrow from LocalOptions parameter to runtime::Builder::build_local (#​7346)

Documented

  • io: clarify behavior of seeking when start_seek is not used (#​7366)
  • io: document cancellation safety of AsyncWriteExt::flush (#​7364)
  • net: fix docs for recv_buffer_size method (#​7336)
  • net: fix broken link of RawFd in TcpSocket docs (#​7416)
  • net: update AsRawFd doc link to current Rust stdlib location (#​7429)
  • readme: fix double period in reactor description (#​7363)
  • runtime: add doc note that on_*_task_poll is unstable (#​7311)
  • sync: update broadcast docs on allocation failure (#​7352)
  • time: add a missing panic scenario of time::advance (#​7394)

v1.45.1: Tokio v1.45.1

Compare 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
  • Disable time-based metrics on wasm32-unknown-unknown (#​7322)

v1.45.0: Tokio v1.45.0

Compare Source

Added
  • metrics: stabilize worker_total_busy_duration, worker_park_count, and worker_unpark_count (#​6899, #​7276)
  • process: add Command::spawn_with (#​7249)
Changed
  • io: do not require Unpin for some trait impls (#​7204)
  • rt: mark runtime::Handle as unwind safe (#​7230)
  • time: revert internal sharding implementation (#​7226)
Unstable
  • rt: remove alt multi-threaded runtime (#​7275)

v1.44.2: Tokio v1.44.2

Compare Source

This release fixes a soundness issue in the broadcast channel. The channel
accepts values that are Send but !Sync. Previously, the channel called
clone() 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
  • sync: synchronize clone() call in broadcast channel (#​7232)

v1.44.1: Tokio v1.44.1

Compare Source

1.44.1 (March 13th, 2025)

Fixed
  • rt: skip defer queue in block_in_place context (#​7216)

v1.44.0: Tokio v1.44.0

Compare Source

1.44.0 (March 7th, 2025)

This release changes the from_std method 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
  • coop: add task::coop module (#​7116)
  • process: add Command::get_kill_on_drop() (#​7086)
  • sync: add broadcast::Sender::closed (#​6685, #​7090)
  • sync: add broadcast::WeakSender (#​7100)
  • sync: add oneshot::Receiver::is_empty() (#​7153)
  • sync: add oneshot::Receiver::is_terminated() (#​7152)
Fixed
  • fs: empty reads on File should not start a background read (#​7139)
  • process: calling start_kill on exited child should not fail (#​7160)
  • signal: fix CTRL_CLOSE, CTRL_LOGOFF, CTRL_SHUTDOWN on windows (#​7122)
  • sync: properly handle panic during mpsc drop (#​7094)
Changes
  • runtime: clean up magic number in registration set (#​7112)
  • coop: make coop yield using waker defer strategy (#​7185)
  • macros: make select! budget-aware (#​7164)
  • net: panic when passing a blocking socket to from_std (#​7166)
  • io: clean up buffer casts (#​7142)
Changes to unstable APIs
  • rt: add before and after task poll callbacks (#​7120)
  • tracing: make the task tracing API unstable public (#​6972)
Documented
  • docs: fix nesting of sections in top-level docs (#​7159)
  • fs: rename symlink and hardlink parameter names (#​7143)
  • io: swap reader/writer in simplex doc test (#​7176)
  • macros: docs about select! alternatives (#​7110)
  • net: rename the argument for send_to (#​7146)
  • process: add example for reading Child stdout (#​7141)
  • process: clarify Child::kill behavior (#​7162)
  • process: fix grammar of the ChildStdin struct doc comment (#​7192)
  • runtime: consistently use worker_threads instead of core_threads (#​7186)

v1.43.3

Compare Source

v1.43.2: Tokio v1.43.2

Compare Source

1.43.2 (August 1st, 2025)

Fixed
  • process: fix panic from spurious pidfd wakeup (#​7494)

v1.43.1

Compare Source

tower-rs/tower-http (tower-http)

v0.6.7

Compare Source

Added

  • TimeoutLayer::with_status_code(status) to define the status code returned
    when timeout is reached. (#​599)

Deprecated

  • auth::require_authorization is too basic for real-world. (#​591)
  • TimeoutLayer::new() should be replaced with
    TimeoutLayer::with_status_code(). (Previously was
    StatusCode::REQUEST_TIMEOUT) (#​599)

Fixed

  • on_eos is now called even for successful responses. (#​580)
  • ServeDir: call fallback when filename is invalid (#​586)
  • decompression will not fail when body is empty (#​618)

New Contributors

Full Changelog: https://github.com/tower-rs/tower-http/compare/tower-http-0.6.6...tower-http-0.6.7

v0.6.6

Compare Source

Fixed

  • compression: fix panic when looking in vary header (#​578)

New Contributors

Full Changelog: https://github.com/tower-rs/tower-http/compare/tower-http-0.6.5...tower-http-0.6.6

v0.6.5

Compare Source

Added

  • normalize_path: add append_trailing_slash() mode (#​547)

Fixed

  • redirect: remove payload headers if redirect changes method to GET (#​575)
  • compression: avoid setting vary: accept-encoding if already set (#​572)

New Contributors

Full Changelog: https://github.com/tower-rs/tower-http/compare/tower-http-0.6.4...tower-http-0.6.5

v0.6.4: tower-http 0.6.4

Compare Source

Added

  • decompression: Support HTTP responses containing multiple ZSTD frames (#​548)
  • The ServiceExt trait for chaining layers onto an arbitrary http service just
    like ServiceBuilderExt allows for ServiceBuilder (#​563)

Fixed

  • Remove unnecessary trait bounds on S::Error for Service impls of
    RequestBodyTimeout<S> and ResponseBodyTimeout<S> (#​533)
  • compression: Respect is_end_stream (#​535)
  • Fix a rare panic in fs::ServeDir (#​553)
  • Fix invalid content-lenght of 1 in response to range requests to empty
    files (#​556)
  • In AsyncRequireAuthorization, use the original inner service after it is
    ready, instead of using a clone (#​561)

v0.6.3: tower-http 0.6.3

Compare Source

This release was yanked because its definition of ServiceExt was quite unhelpful, in a way that's very unlikely that anybody would start depending on within the small timeframe before this was yanked, but that was technically breaking to change.

uuid-rs/uuid (uuid)

v1.19.0

Compare Source

What's Changed

Full Changelog: https://github.com/uuid-rs/uuid/compare/v1.18.1...v1.19.0

v1.18.1

Compare Source

What's Changed

Full Changelog: https://github.com/uuid-rs/uuid/compare/v1.18.0...v1.18.1

v1.18.0

Compare Source

What's Changed

New Contributors

Full Changelog: https://github.com/uuid-rs/uuid/compare/v1.17.0...v1.18.0

v1.17.0

Compare Source

What's Changed

New Contributors

Full Changelog: https://github.com/uuid-rs/uuid/compare/v1.16.0...v1.17.0

v1.16.0

Compare Source

What's Changed

New Contributors

Full Changelog: https://github.com/uuid-rs/uuid/compare/v1.15.1...v1.16.0

v1.15.1

Compare Source

What's Changed

Full Changelog: https://github.com/uuid-rs/uuid/compare/v1.15.0...v1.15.1

v1.15.0

Compare Source

What's Changed

New Contributors

Full Changelog: https://github.com/uuid-rs/uuid/compare/v1.14.0...v1.15.0

v1.14.0

Compare Source

What's Changed

New Contributors

Full Changelog: https://github.com/uuid-rs/uuid/compare/v1.13.2...v1.14.0

v1.13.2

Compare Source

What's Changed

Full Changelog: https://github.com/uuid-rs/uuid/compare/1.13.1...v1.13.2

v1.13.1

Compare Source

What's Changed

New Contributors

Full Changelog: https://github.com/uuid-rs/uuid/compare/1.13.0...1.13.1

v1.13.0

Compare Source

⚠️ Potential Breakage

This release updates our version of getrandom to 0.3 and rand to 0.9. It is a potentially breaking change for the following users:

no-std users who enable the rng feature

uuid still uses getrandom by default on these platforms. Upgrade your version of getrandom and follow its new docs on configuring a custom backend.

wasm32-unknown-unknown users who enable the rng feature without the js feature

Upgrade your version of getrandom and follow its new docs on configuring a backend.

You'll also need to enable the rng-getrandom or rng-rand feature of uuid to force it to use getrandom as its backend:

[dependencies.uuid]
version = "1.13.0"
- features = ["v4"]
+ features = ["v4", "rng-getrandom"]

[dependencies.getrandom]
version = "0.3"

If you're on wasm32-unknown-unknown and using the js feature of uuid you shouldn't see any breakage. We've kept this behavior by vendoring in getrandom's web-based backend when the js feature is enabled.

What's Changed

Full Changelog: https://github.com/uuid-rs/uuid/compare/1.12.1...1.13.0

v1.12.1

Compare Source

What's Changed

New Contributors

Full Changelog: https://github.com/uuid-rs/uuid/compare/1.12.0...1.12.1

wasm-bindgen/wasm-bindgen (wasm-bindgen)

v0.2.106

Compare Source

Added
  • New MSRV policy, and bump of the MSRV fo 1.71.
    #​4801

  • Added typed this support in the first argument in free function exports via
    a new #[wasm_bindgen(this)] attribute.
    #​4757

  • Added reexport attribute for imports to support re-exporting imported types,
    with optional renaming.
    #​4759

  • Added js_namespace attribute on exported types, mirroring the import
    semantics to enable arbitrarily nested exported interface objects.
    #​4744

  • Added 'container' attribute to ScrollIntoViewOptions
    #​4806

  • Updated and refactored output generation to use alphabetical ordering
    of declarations.
    #​4813

  • Added benchmark support to wasm-bindgen-test.
    #​4812
    #​4823

Fixed
  • Fixed node test harness getting stuck after tests completed.
    #​4776

  • Quote names containing colons in generated .d.ts.
    #​4488

  • Fixes TryFromJsValue for structs JsValue stack corruption on failure.
    #​4786

  • Fixed wasm-bindgen-test-runner outputting empty line when using the --list option. In particular, cargo-nextest now works correctly.
    #​4803

  • It now works to build with -Cpanic=unwind.
    #​4796
    #​4783
    #​4782

  • Fixed duplicate symbols caused by enabling v0 mangling.
    #​4822

  • Fixed a multithreaded wasm32+atomics race where Atomics.waitAsync promise callbacks could call run without waking first, causing sporadic panics.
    #​4821

Removed

v0.2.105

Compare Source

Added
  • Added Math::PI binding to js_sys, exposing the ECMAScript Math.PI constant.
    #​4748

  • Added ability to use --keep-lld-exports in wasm-bindgen-test-runner by setting the WASM_BINDGEN_KEEP_LLD_EXPORTS environment variable.
    #​4736

  • Added CookieStore API.
    #​4706

  • Added run_cli_with_args library functions to all wasm_bindgen_cli entrypoints.
    #​4710

  • Added get_raw and set_raw for WebAssembly.Table.
    #​4701

  • Added new_with_value and grow_with_value for WebAssembly.Table.
    #​4698

  • Added better support for async stack traces when building in debug mode.
    #​4711

  • Extended support for TryFromJsValue trait implementations.
    #​4714

  • New JsValue.is_null_or_undefined() method and intrinsic.
    #​4751

  • Support for Option<JsValue> in function arguments and return.
    #​4752

  • Support for WASM_BINDGEN_KEEP_TEST_BUILD=1 environment variable
    to retain build files when using the test runner.
    #​4758

Fixed
  • Fixed multithreading JS output for targets bundler, deno and module.
    #​4685

  • Fixed TextDe/Encoder detection for audio worklet use-cases.
    #​4703

  • Fixed post-processing failures in case Std has debug assertions enabled.
    #​4705

  • Fixed JS memory leak in wasm_bindgen::Closure.
    #​4709

  • Fixed warning when using #[wasm_bindgen(wasm_bindgen=xxx)] on struct.
    #​4715

Removed
  • Internal crate wasm-bindgen-backend will no longer be published.
    #​4696

v0.2.104

Compare Source

Added
  • Added bindings for WeakRef.
    #​4659

  • Support Symbol.dispose methods by default, when it is supported in the environment.
    #​4666

  • Added aarch64-unknown-linux-musl release artifacts.
    #​4668

Changed
  • Unconditionally use the global TextEncoder/TextDecoder for string encoding/decoding. The Node.js output now requires a minimum of Node.js v11.
    #​4670

  • Deprecate the msrv crate feature. MSRV detection is now always on.
    #​4675

Fixed
  • Fixed wasm-bindgen-cli's encode_into argument not working.
    #​4663

  • Fixed a bug in --experimental-reset-state-function support for heap reset.
    #​4665

  • Fixed compilation failures on Rust v1.82 and v1.83.
    #​4675


v0.2.103

Compare Source

Fixed
  • Fixed incorrect function mapping during post-processing.
    #​4656

v0.2.102

Compare Source

Added
  • Added DocumentOrShadowRoot.adoptedStyleSheets.
    #​4625

  • Added support for arguments with spaces using shell-style quoting in webdriver *_ARGS
    environment variables to wasm-bindgen-test.
    #​4433

  • Added ability to determine WebDriver JSON config location via
    WASM_BINDGEN_TEST_WEBDRIVER_JSON environment variable to
    wasm-bindgen-test.
    #​4434

  • Generate DWARF for tests by default. See the guide on debug information for more details.
    #​4635

  • New --target=module target for outputting source phase imports.
    #​4638

Changed
  • Hidden deprecated options from the wasm-bindgen --help docs.
    #​4646
Fixed
  • Fixed wrong method names for GestureEvent bindings.
    #​4615

  • Fix crash caused by allocations during TypedArray interactions.
    #​4622


v0.2.101

Compare Source

Added
  • Added format and colorSpace support to VideoFrameCopyToOptions
    #​4543

  • Added support for the onbeforeinput attribute.
    #​4544

  • TypedArray::new_from_slice(&[T]) constructor that allows to create a
    JS-owned TypedArray from a Rust slice.
    #​4555

  • Added Function::call4 and Function::bind4 through Function::call9 Function::bind9 methods for calling and binding JavaScript functions with 4-9 arguments.
    #​4572

  • Added isPointInFill and isPointInStroke methods for the SVGGeometryElement idl.
    #​4509

  • Added unstable bindings for GestureEvent.
    #​4589

  • Stricter checks for module, raw_module and inline_js attributes applied to inapplicable items.
    #​4522

  • Add bindings for PictureInPicture.
    #​4593

  • Added bytes method for the Blob idl
    #​4506

  • Add error message when export symbol is not found
    #​4594

Changed
  • Deprecate async constructors.
    #​4402

  • The size argument to GPUCommandEncoder.copyBufferToBuffer is now optional.
    #​4508

  • MSRV of CLI tools bumped to v1.82. This does not affect libraries like wasm-bindgen, js-sys and web-sys!
    #​4608

Fixed
  • Detect more failure scenarios when retrieving the Wasm module.
    #​4556

  • Add a workaround for TextDecoder failing in older version of Safari when too many bytes are decoded through it over its lifetime.
    #​4472

  • TypedArray::from(&[T]) now works reliably across memory reallocations.
    #​4555

  • Fix incorrect memory loading and storing assertions during post-processing.
    #​4554

  • Fix test --exact option not working as expected.
    #​4549

  • Fix tables being removed even though they are used by stack closures.
    #​4119

  • Skip __wasm_call_ctors which we don't want to interpret.
    #​4562

  • Fix infinite recursion caused by the lack of proc-macro hygiene.
    #​4601

  • Fix running coverage with no_modules.
    #​4604

  • Fix proc-macro hygiene with core.
    #​4606

Removed
  • Crates intended purely for internal consumption by the wasm-bindgen CLI will no longer be published:
    #​4608

    • wasm-bindgen-externref-xform
    • wasm-bindgen-multi-value-xform
    • wasm-bindgen-threads-xform
    • wasm-bindgen-wasm-conventions
    • wasm-bindgen-wasm-interpreter


Configuration

📅 Schedule: Branch creation - At any time (no schedule defined), Automerge - At any time (no schedule defined).

🚦 Automerge: Enabled.

Rebasing: Whenever PR is behind base branch, or you tick the rebase/retry checkbox.

👻 Immortal: This PR will be recreated if closed unmerged. Get config help if that's undesired.


  • If you want to rebase/retry this PR, check this box

This PR has been generated by Renovate Bot.

This PR contains the following updates: | Package | Type | Update | Change | |---|---|---|---| | [cfg-if](https://github.com/rust-lang/cfg-if) | workspace.dependencies | patch | `1.0.0` -> `1.0.4` | | [http](https://github.com/hyperium/http) | workspace.dependencies | minor | `1.2.0` -> `1.4.0` | | [leptos](https://leptos.dev/) ([source](https://github.com/leptos-rs/leptos)) | workspace.dependencies | minor | `0.7.4` -> `0.8.0` | | [leptos_axum](https://github.com/leptos-rs/leptos) | workspace.dependencies | minor | `0.7.4` -> `0.8.0` | | [leptos_meta](https://github.com/leptos-rs/leptos) | workspace.dependencies | minor | `0.7.4` -> `0.8.0` | | [leptos_router](https://github.com/leptos-rs/leptos) | workspace.dependencies | minor | `0.7.4` -> `0.8.0` | | [log](https://github.com/rust-lang/log) | workspace.dependencies | patch | `0.4.25` -> `0.4.29` | | [reqwest](https://github.com/seanmonstar/reqwest) | dependencies | patch | `0.12.12` -> `0.12.24` | | [serde_json](https://github.com/serde-rs/json) | dependencies | patch | `1.0.136` -> `1.0.145` | | [server_fn](https://github.com/leptos-rs/leptos) | workspace.dependencies | minor | `0.7.4` -> `0.8.0` | | [simple_logger](https://github.com/borntyping/rust-simple_logger) | workspace.dependencies | minor | `5.0.0` -> `5.1.0` | | [thiserror](https://github.com/dtolnay/thiserror) | workspace.dependencies | patch | `2.0.11` -> `2.0.17` | | [tokio](https://tokio.rs) ([source](https://github.com/tokio-rs/tokio)) | workspace.dependencies | minor | `1.43.0` -> `1.48.0` | | [tower-http](https://github.com/tower-rs/tower-http) | workspace.dependencies | patch | `0.6.2` -> `0.6.7` | | [uuid](https://github.com/uuid-rs/uuid) | workspace.dependencies | minor | `1.12.0` -> `1.19.0` | | [wasm-bindgen](https://wasm-bindgen.github.io/wasm-bindgen) ([source](https://github.com/wasm-bindgen/wasm-bindgen)) | workspace.dependencies | patch | `=0.2.100` -> `=0.2.106` | | [web-sys](https://wasm-bindgen.github.io/wasm-bindgen/web-sys/index.html) ([source](https://github.com/wasm-bindgen/wasm-bindgen/tree/HEAD/crates/web-sys)) | dependencies | patch | `0.3.77` -> `0.3.83` | --- ### Release Notes <details> <summary>rust-lang/cfg-if (cfg-if)</summary> ### [`v1.0.4`](https://github.com/rust-lang/cfg-if/blob/HEAD/CHANGELOG.md#104---2025-10-15) [Compare Source](https://github.com/rust-lang/cfg-if/compare/v1.0.3...v1.0.4) - Support `cfg(true)` and `cfg(false)` ([#&#8203;99](https://github.com/rust-lang/cfg-if/pull/99)) - Set and test a MSRV of 1.32 - Have a single top-level rule ### [`v1.0.3`](https://github.com/rust-lang/cfg-if/blob/HEAD/CHANGELOG.md#103---2025-08-19) [Compare Source](https://github.com/rust-lang/cfg-if/compare/v1.0.2...v1.0.3) - Revert "Remove `@__identity` rule." ### [`v1.0.2`](https://github.com/rust-lang/cfg-if/blob/HEAD/CHANGELOG.md#102---2025-08-19) [Compare Source](https://github.com/rust-lang/cfg-if/compare/v1.0.1...v1.0.2) - Remove `@__identity` rule. ### [`v1.0.1`](https://github.com/rust-lang/cfg-if/blob/HEAD/CHANGELOG.md#101---2025-06-09) [Compare Source](https://github.com/rust-lang/cfg-if/compare/1.0.0...v1.0.1) - Remove `compiler-builtins` from `rustc-dep-of-std` dependencies - Remove redundant configuration from Cargo.toml - More readable formatting and identifier names. ([#&#8203;39](https://github.com/rust-lang/cfg-if/pull/39)) - Add expanded example to readme ([#&#8203;38](https://github.com/rust-lang/cfg-if/pull/38)) </details> <details> <summary>hyperium/http (http)</summary> ### [`v1.4.0`](https://github.com/hyperium/http/blob/HEAD/CHANGELOG.md#140-November-24-2025) [Compare Source](https://github.com/hyperium/http/compare/v1.3.1...v1.4.0) - Add `StatusCode::EARLY_HINTS` constant for 103 Early Hints. - Make `StatusCode::from_u16` now a `const fn`. - Make `Authority::from_static` now a `const fn`. - Make `PathAndQuery::from_static` now a `const fn`. - MSRV increased to 1.57 (allows legible const fn panic messages). ### [`v1.3.1`](https://github.com/hyperium/http/blob/HEAD/CHANGELOG.md#131-March-11-2025) [Compare Source](https://github.com/hyperium/http/compare/v1.3.0...v1.3.1) - Fix validation that all characters are UTF-8 in URI path and query. ### [`v1.3.0`](https://github.com/hyperium/http/blob/HEAD/CHANGELOG.md#130-March-11-2025) [Compare Source](https://github.com/hyperium/http/compare/v1.2.0...v1.3.0) - Allow most UTF-8 characters in URI path and query. - Fix `HeaderMap::reserve()` to allocate sufficient capacity. </details> <details> <summary>leptos-rs/leptos (leptos)</summary> ### [`v0.8.14`](https://github.com/leptos-rs/leptos/releases/tag/v0.8.14) [Compare Source](https://github.com/leptos-rs/leptos/compare/v0.8.13...v0.8.14) #### What's Changed - Resupport `From<Fn() -> T> for Signal<T>`, `ArcSignal<T>`, `Callback<T, _>` and similar by [@&#8203;zakstucke](https://github.com/zakstucke) in https://github.com/leptos-rs/leptos/pull/4273 - chore: bump versions after recent release by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/4462 **Full Changelog**: https://github.com/leptos-rs/leptos/compare/v0.8.13...v0.8.14 ### [`v0.8.13`](https://github.com/leptos-rs/leptos/releases/tag/v0.8.13) [Compare Source](https://github.com/leptos-rs/leptos/compare/v0.8.12...v0.8.13) #### What's Changed - add homepage to leptos cargo metadata by [@&#8203;tswast](https://github.com/tswast) in https://github.com/leptos-rs/leptos/pull/4417 - examples: clarify behavior of upload-with-progress demo (closes [#&#8203;4397](https://github.com/leptos-rs/leptos/issues/4397)) by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/4420 - Force cleanup even if there are other references to the root owner by [@&#8203;zakstucke](https://github.com/zakstucke) in https://github.com/leptos-rs/leptos/pull/4427 - fix: check custom element tag name when rebuilding by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/4413 - Relax `Debug` trait bound on tuples `PossibleRouteMatch` implementation by [@&#8203;alexisfontaine](https://github.com/alexisfontaine) in https://github.com/leptos-rs/leptos/pull/4428 - fix: remove possibility of view-related `SendWrapper` errors on server (closes [#&#8203;4432](https://github.com/leptos-rs/leptos/issues/4432), [#&#8203;4402](https://github.com/leptos-rs/leptos/issues/4402)) by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/4433 - Add split to run command by [@&#8203;marcokuoni](https://github.com/marcokuoni) in https://github.com/leptos-rs/leptos/pull/4440 - Clean up warning behavior for resources that depend on other resources by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/4415 - (wip) track resources in Suspense that are read conditionally behind other resource reads (see [#&#8203;4430](https://github.com/leptos-rs/leptos/issues/4430)) by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/4444 - fix: improve marker-node filtering when using islands router (closes [#&#8203;4443](https://github.com/leptos-rs/leptos/issues/4443)) by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/4446 - Removed duplicate cargo member oco by [@&#8203;agirorn](https://github.com/agirorn) in https://github.com/leptos-rs/leptos/pull/4445 - fix: do not unescape query and hash in URLs when clicking links (closes [#&#8203;4453](https://github.com/leptos-rs/leptos/issues/4453), closes [#&#8203;4232](https://github.com/leptos-rs/leptos/issues/4232)) by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/4454 - fix: Fixed to Add response headers for leptos_axum static files [#&#8203;4377](https://github.com/leptos-rs/leptos/issues/4377) by [@&#8203;tqq1994516](https://github.com/tqq1994516) in https://github.com/leptos-rs/leptos/pull/4394 - fix: make class attribute overwrite behavior consistent between SSR and CSR by [@&#8203;taearls](https://github.com/taearls) in https://github.com/leptos-rs/leptos/pull/4439 #### New Contributors - [@&#8203;tswast](https://github.com/tswast) made their first contribution in https://github.com/leptos-rs/leptos/pull/4417 - [@&#8203;marcokuoni](https://github.com/marcokuoni) made their first contribution in https://github.com/leptos-rs/leptos/pull/4440 - [@&#8203;tqq1994516](https://github.com/tqq1994516) made their first contribution in https://github.com/leptos-rs/leptos/pull/4394 - [@&#8203;taearls](https://github.com/taearls) made their first contribution in https://github.com/leptos-rs/leptos/pull/4439 **Full Changelog**: https://github.com/leptos-rs/leptos/compare/v0.8.12...v0.8.13 ### [`v0.8.12`](https://github.com/leptos-rs/leptos/releases/tag/v0.8.12) [Compare Source](https://github.com/leptos-rs/leptos/compare/v0.8.11...v0.8.12) #### What's Changed - Replace vendored wasm-split with out-of-repository version by [@&#8203;WorldSEnder](https://github.com/WorldSEnder) in https://github.com/leptos-rs/leptos/pull/4369 **Full Changelog**: https://github.com/leptos-rs/leptos/compare/v0.8.11...v0.8.12 ### [`v0.8.11`](https://github.com/leptos-rs/leptos/releases/tag/v0.8.11) [Compare Source](https://github.com/leptos-rs/leptos/compare/v0.8.10...v0.8.11) #### What's Changed - Removed excess bound on `MaybeProp` `ReadUntracked` implementation. by [@&#8203;Buzzec](https://github.com/Buzzec) in https://github.com/leptos-rs/leptos/pull/4360 - add `scrollend` event to view macro by [@&#8203;adoyle0](https://github.com/adoyle0) in https://github.com/leptos-rs/leptos/pull/4379 - chore(deps): bump the rust-dependencies group with 43 updates by [@&#8203;dependabot](https://github.com/dependabot)\[bot] in https://github.com/leptos-rs/leptos/pull/4368 - fix: allow setting `NodeRef` by implementing `IsDisposed` by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/4367 - chore: re-export `debug_log` and `debug_error` in logging module by [@&#8203;mahdi739](https://github.com/mahdi739) in https://github.com/leptos-rs/leptos/pull/4335 - Allow more types to be converted to throw_error::Error by [@&#8203;abusch](https://github.com/abusch) in https://github.com/leptos-rs/leptos/pull/4359 - feat: `effect::immediate::batch` by [@&#8203;QuartzLibrary](https://github.com/QuartzLibrary) in https://github.com/leptos-rs/leptos/pull/4344 - Clean up window router events on unmount by [@&#8203;Innominus](https://github.com/Innominus) in https://github.com/leptos-rs/leptos/pull/4357 - fix: use correct/full type names for matched routes to fix islands-router issues (closes [#&#8203;4378](https://github.com/leptos-rs/leptos/issues/4378)) by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/4380 - fix: patching keyed store fields (closes [#&#8203;3957](https://github.com/leptos-rs/leptos/issues/3957)) by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/4383 - `server_fn` feature propagation by [@&#8203;arpadav](https://github.com/arpadav) in https://github.com/leptos-rs/leptos/pull/4375 - fix: correctly track ancestors for `AtIndex` (closes [#&#8203;4385](https://github.com/leptos-rs/leptos/issues/4385)) by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/4389 - leptos_actix-v0.8.6 by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/4396 - fix: adding missing `dry_resolve()` call on `Suspend` (closes [#&#8203;4402](https://github.com/leptos-rs/leptos/issues/4402)) by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/4404 - chore(deps): bump actions/setup-node from 5 to 6 by [@&#8203;dependabot](https://github.com/dependabot)\[bot] in https://github.com/leptos-rs/leptos/pull/4398 - chore(deps): bump playwright from 1.44.1 to 1.56.1 in /projects/hexagonal-architecture/end2end in the npm_and_yarn group across 1 directory by [@&#8203;dependabot](https://github.com/dependabot)\[bot] in https://github.com/leptos-rs/leptos/pull/4399 - Adding `bitcode` encoding/decoding to server fn IO by [@&#8203;arpadav](https://github.com/arpadav) in https://github.com/leptos-rs/leptos/pull/4376 #### New Contributors - [@&#8203;arpadav](https://github.com/arpadav) made their first contribution in https://github.com/leptos-rs/leptos/pull/4375 **Full Changelog**: https://github.com/leptos-rs/leptos/compare/v0.8.10...v0.8.11 ### [`v0.8.10`](https://github.com/leptos-rs/leptos/releases/tag/v0.8.10) [Compare Source](https://github.com/leptos-rs/leptos/compare/v0.8.9...v0.8.10) #### What's Changed - Locking dependencies in cargo-leptos install example by [@&#8203;agirorn](https://github.com/agirorn) in https://github.com/leptos-rs/leptos/pull/4295 - Add minimal support for `subsecond` and an example by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/4307 - chore(deps): bump actions/setup-node from 4 to 5 by [@&#8203;dependabot](https://github.com/dependabot)\[bot] in https://github.com/leptos-rs/leptos/pull/4283 - chore(deps): bump tj-actions/changed-files from 46 to 47 by [@&#8203;dependabot](https://github.com/dependabot)\[bot] in https://github.com/leptos-rs/leptos/pull/4297 - chore: specify Tailwind version in Trunk.toml (closes [#&#8203;4315](https://github.com/leptos-rs/leptos/issues/4315)) by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/4317 - fix: remove event listeners correctly when dropping handles (closes [#&#8203;4313](https://github.com/leptos-rs/leptos/issues/4313)) by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/4314 - fix: preload correct `__wasm_split.*.js` file (closes [#&#8203;4322](https://github.com/leptos-rs/leptos/issues/4322)) by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/4327 - chore(deps): bump the rust-dependencies group across 1 directory with 11 updates by [@&#8203;dependabot](https://github.com/dependabot)\[bot] in https://github.com/leptos-rs/leptos/pull/4319 - fix: correctly import scoped slots (closes [#&#8203;4311](https://github.com/leptos-rs/leptos/issues/4311)) by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/4318 - Allow accessing a parent owner from a child by [@&#8203;zakstucke](https://github.com/zakstucke) in https://github.com/leptos-rs/leptos/pull/4325 - chore: add missing attributes by [@&#8203;adoyle0](https://github.com/adoyle0) in https://github.com/leptos-rs/leptos/pull/4308 - Correctly manage path stack during back navigation by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/4334 - fix: correctly poll all out-of-order streaming chunks (closes [#&#8203;4326](https://github.com/leptos-rs/leptos/issues/4326)) by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/4333 #### New Contributors - [@&#8203;agirorn](https://github.com/agirorn) made their first contribution in https://github.com/leptos-rs/leptos/pull/4295 **Full Changelog**: https://github.com/leptos-rs/leptos/compare/v0.8.9...v0.8.10 ### [`v0.8.9`](https://github.com/leptos-rs/leptos/releases/tag/v0.8.9) [Compare Source](https://github.com/leptos-rs/leptos/compare/v0.8.8...v0.8.9) This includes patch releases to the `reactive_graph`, `tachys`, `wasm_split_macros`, `server_fn`, `leptos`, and `router` crates. #### What's Changed - fix: use wss for live reload if on https by [@&#8203;veigaribo](https://github.com/veigaribo) in https://github.com/leptos-rs/leptos/pull/4257 - fix: when navigating, only add new URL to history stack if it's different from current URL (closes [#&#8203;4251](https://github.com/leptos-rs/leptos/issues/4251)) by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/4252 - Preserve owner in Actions and event listeners by [@&#8203;zakstucke](https://github.com/zakstucke) in https://github.com/leptos-rs/leptos/pull/4267 - fix: Set content type header for server function errors by [@&#8203;spencewenski](https://github.com/spencewenski) in https://github.com/leptos-rs/leptos/pull/4215 - From\<View<C>> for ViewFn where View<C>: Clone by [@&#8203;zakstucke](https://github.com/zakstucke) in https://github.com/leptos-rs/leptos/pull/4266 - chore(deps): bump the rust-dependencies group across 1 directory with 33 updates by [@&#8203;dependabot](https://github.com/dependabot)\[bot] in https://github.com/leptos-rs/leptos/pull/4262 - impl From\<RwSignal/ReadSignal/Memo> for ArcSignal by [@&#8203;zakstucke](https://github.com/zakstucke) in https://github.com/leptos-rs/leptos/pull/4258 - fix: revert changes to raw text parsing (closes [#&#8203;4271](https://github.com/leptos-rs/leptos/issues/4271)) by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/4272 - Standardize ScopedFuture::new_untracked like untrack() and untrack_with_diagnostics() by [@&#8203;zakstucke](https://github.com/zakstucke) in https://github.com/leptos-rs/leptos/pull/4269 - fix: clear old attributes when replacing a `Vec<AnyAttribute>` (closes [#&#8203;4268](https://github.com/leptos-rs/leptos/issues/4268)) by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/4270 - fix: correctly propagate visibility on lazy functions (closes [#&#8203;4256](https://github.com/leptos-rs/leptos/issues/4256)) by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/4259 - docs: fix broken links in suspense by [@&#8203;rpfontana](https://github.com/rpfontana) in https://github.com/leptos-rs/leptos/pull/4276 - docs: add missing docs for some features by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/4281 - fix: prevent double-rebuild and correctly navigate multiple times to same lazy route (closes [#&#8203;4285](https://github.com/leptos-rs/leptos/issues/4285)) by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/4294 - chore: add `referrerpolicy` attribute to `a` element by [@&#8203;adoyle0](https://github.com/adoyle0) in https://github.com/leptos-rs/leptos/pull/4299 - fix: support const generic static strs on nightly versions with conflicting feature names (closes [#&#8203;4300](https://github.com/leptos-rs/leptos/issues/4300)) by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/4301 **Full Changelog**: https://github.com/leptos-rs/leptos/compare/v0.8.8...v0.8.9 ### [`v0.8.8`](https://github.com/leptos-rs/leptos/releases/tag/v0.8.8) #### What's Changed - Fixes [#&#8203;4193](https://github.com/leptos-rs/leptos/issues/4193): Adding `command` and `commandfor` attributes for button by [@&#8203;mskorkowski](https://github.com/mskorkowski) in https://github.com/leptos-rs/leptos/pull/4194 - docs: fix typo by [@&#8203;rpfontana](https://github.com/rpfontana) in https://github.com/leptos-rs/leptos/pull/4202 - fix: only continue navigating to most recent page (closes [#&#8203;4195](https://github.com/leptos-rs/leptos/issues/4195)) by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/4198 - Add name attribute to details element by [@&#8203;adoyle0](https://github.com/adoyle0) in https://github.com/leptos-rs/leptos/pull/4190 - Fixes [#&#8203;4163](https://github.com/leptos-rs/leptos/issues/4163): Derive `Patch` for a struct with generic arguments by [@&#8203;mskorkowski](https://github.com/mskorkowski) in https://github.com/leptos-rs/leptos/pull/4175 - make is_server and is_browser public by [@&#8203;Alxandr](https://github.com/Alxandr) in https://github.com/leptos-rs/leptos/pull/4204 - fix: ensure `task::spawn` maintains reactive ownership (closes [#&#8203;4203](https://github.com/leptos-rs/leptos/issues/4203)) by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/4206 - perf: use a set instead of `Vec<_>` to optimize large subscriber sets (see [#&#8203;4138](https://github.com/leptos-rs/leptos/issues/4138)) by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/4201 - feat: improving the bump script by [@&#8203;sabify](https://github.com/sabify) in https://github.com/leptos-rs/leptos/pull/4187 - feat: implement IntoProperty for Oco by [@&#8203;veigaribo](https://github.com/veigaribo) in https://github.com/leptos-rs/leptos/pull/4174 - fix: pass `hydrate_async` through `OwnedView` properly (closes [#&#8203;4219](https://github.com/leptos-rs/leptos/issues/4219)) by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/4220 - fix: support islands routing in 404 routes by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/4218 - chore(deps): bump the rust-dependencies group with 32 updates by [@&#8203;dependabot](https://github.com/dependabot)\[bot] in https://github.com/leptos-rs/leptos/pull/4222 - chore(deps): bump actions/checkout from 4 to 5 by [@&#8203;dependabot](https://github.com/dependabot)\[bot] in https://github.com/leptos-rs/leptos/pull/4221 - fix: allow `non_snake_case` and `dead_code` lints to run within component functions by [@&#8203;yescallop](https://github.com/yescallop) in https://github.com/leptos-rs/leptos/pull/3198 - chore: remove lockfiles accidentally included in repo by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/4234 - `<ShowLet>` component similar to `<Show>` but for `Option` by [@&#8203;maccesch](https://github.com/maccesch) in https://github.com/leptos-rs/leptos/pull/4227 - fix: correctly parse unquoted text with punctuation in stable (closes [#&#8203;4137](https://github.com/leptos-rs/leptos/issues/4137)) by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/4238 - Fixes for two server function issues by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/4242 - feat: add default "auto" live reload protocol option by [@&#8203;veigaribo](https://github.com/veigaribo) in https://github.com/leptos-rs/leptos/pull/4224 - Special-case `value` property to support quirky `<select>` behavior by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/4235 - made `<Show>` accept signals in addition to closures by [@&#8203;maccesch](https://github.com/maccesch) in https://github.com/leptos-rs/leptos/pull/4236 - docs: correctly document additional serialization features for `leptos_server` by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/4250 - Revert recent broken changes by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/4255 #### New Contributors - [@&#8203;rpfontana](https://github.com/rpfontana) made their first contribution in https://github.com/leptos-rs/leptos/pull/4202 - [@&#8203;adoyle0](https://github.com/adoyle0) made their first contribution in https://github.com/leptos-rs/leptos/pull/4190 - [@&#8203;Alxandr](https://github.com/Alxandr) made their first contribution in https://github.com/leptos-rs/leptos/pull/4204 - [@&#8203;yescallop](https://github.com/yescallop) made their first contribution in https://github.com/leptos-rs/leptos/pull/3198 **Full Changelog**: https://github.com/leptos-rs/leptos/compare/v0.8.6...v0.8.8 ### [`v0.8.6`](https://github.com/leptos-rs/leptos/releases/tag/v0.8.6) [Compare Source](https://github.com/leptos-rs/leptos/compare/v0.8.5...v0.8.6) Just a patch release, mostly to support `#[server] #[lazy]` for lazy server functions. Going forward, patch releases for various crates will have version numbers that are not coupled to one another, and will only be bumped when they've actually changed; so this release is 0.8.6 for `leptos`, `leptos_macro`, and `server_fn_macro`, but does not arbitrarily bump other packages that haven't changed. See [0.8.5](https://github.com/leptos-rs/leptos/releases/tag/v0.8.5) for notes on WASM splitting. ##### What's Changed - fix(CI): remove autofix CI timeout by [@&#8203;sabify](https://github.com/sabify) in https://github.com/leptos-rs/leptos/pull/4173 - chore: bump wasm-split version numbers by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/4170 - chore(deps): bump redox_syscall from 0.5.14 to 0.5.15 in the rust-dependencies group by [@&#8203;dependabot](https://github.com/dependabot)\[bot] in https://github.com/leptos-rs/leptos/pull/4171 - feat: allow lazy server functions by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/4169 - fix: support file hashing when using lazy loading by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/4182 - Enhancing members’ versioning by [@&#8203;sabify](https://github.com/sabify) in https://github.com/leptos-rs/leptos/pull/4172 - A few pieces of lazy island clean-up by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/4186 **Full Changelog**: https://github.com/leptos-rs/leptos/compare/v0.8.5...v0.8.6 ### [`v0.8.5`](https://github.com/leptos-rs/leptos/releases/tag/v0.8.5): : WASM code splitting released! [Compare Source](https://github.com/leptos-rs/leptos/compare/v0.8.4...v0.8.5) This release includes WASM code-splitting/lazy-loading support, in tandem with the latest `cargo-leptos` release. You can use the [`lazy_routes`](https://github.com/leptos-rs/leptos/tree/main/examples/lazy_routes) example to understand what this means! Essentially, though, there are two patterns: 1. Use the `#[lazy]` macro to make any given function lazy 2. Use the `#[lazy_route]` to designate a route with a lazy-loaded view, which is loaded concurrently with the route's data `#[lazy]` converts a (sync or async) function into a lazy-loaded async function ```rust #[lazy] fn deserialize_comments(data: &str) -> Vec<Comment> { serde_json::from_str(data).unwrap() } ``` `#[lazy_route]` lets you split routes into a "data" half and a "view" half, which will be concurrently loaded by the router. This works with nested routing: so if you have ViewD and ViewE, then the router will concurrently load D's data, D's (lazy) view, E's data, and E's (lazy) view, before navigating to the page. ```rust struct ViewD { data: Resource<Result<Vec<i32>, ServerFnError>>, } #[lazy_route] impl LazyRoute for ViewD { fn data() -> Self { Self { data: Resource::new(|| (), |_| d_data()), } } fn view(this: Self) -> AnyView { let items = move || { Suspend::new(async move { this.data .await .unwrap_or_default() .into_iter() .map(|item| view! { <li>{item}</li> }) .collect::<Vec<_>>() }) }; view! { <p id="page">"View D"</p> <hr/> <Suspense fallback=|| view! { <p id="loading">"Loading..."</p> }> <ul>{items}</ul> </Suspense> <Outlet/> } .into_any() } } #[server] async fn d_data() -> Result<Vec<i32>, ServerFnError> { tokio::time::sleep(std::time::Duration::from_millis(250)).await; Ok(vec![1, 1, 2, 3, 5, 8, 13]) } ``` Our whole [July stream](https://www.youtube.com/watch?v=2RhDIKfm7VI) was dedicated to the topic, if you want more in depth discussion. #### What's Changed - Preparing to publish oco_ref 0.2.1 by [@&#8203;martinfrances107](https://github.com/martinfrances107) in https://github.com/leptos-rs/leptos/pull/4168 - feat: wasm-splitting library support for future cargo-leptos integration by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/3988 **Full Changelog**: https://github.com/leptos-rs/leptos/compare/v0.8.4...v0.8.5 ### [`v0.8.4`](https://github.com/leptos-rs/leptos/releases/tag/v0.8.4) [Compare Source](https://github.com/leptos-rs/leptos/compare/v0.8.3...v0.8.4) There are some small bugfixes in here, as well as improvements to the hot-reloading code. This is mostly intended to be a sort of "last patch" before merging the code-splitting changes in [#&#8203;3988](https://github.com/leptos-rs/leptos/issues/3988), so that there is a patch people can pin to in case those inadvertently introduce any regressions. #### What's Changed - fix: bump workspace dependency versions (closes [#&#8203;4146](https://github.com/leptos-rs/leptos/issues/4146)) by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/4149 - Version updates + stable hot-reloading by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/4161 - feat: support conversion from signals and optional get extension for TextProp by [@&#8203;mahdi739](https://github.com/mahdi739) in https://github.com/leptos-rs/leptos/pull/4159 - docs: add warning for reading hash on the server by [@&#8203;TERRORW0LF](https://github.com/TERRORW0LF) in https://github.com/leptos-rs/leptos/pull/4158 - fix: three hot-reloading bugs ( closes [#&#8203;3191](https://github.com/leptos-rs/leptos/issues/3191) ) by [@&#8203;shadr](https://github.com/shadr) in https://github.com/leptos-rs/leptos/pull/4154 - chore(deps): bump the rust-dependencies group across 1 directory with 15 updates by [@&#8203;dependabot](https://github.com/dependabot)\[bot] in https://github.com/leptos-rs/leptos/pull/4152 - We're kinda prod-ready by [@&#8203;rakshith-ravi](https://github.com/rakshith-ravi) in https://github.com/leptos-rs/leptos/pull/4148 - chore: examples - bumped version numbers for sqlx and this error. by [@&#8203;martinfrances107](https://github.com/martinfrances107) in https://github.com/leptos-rs/leptos/pull/4126 - fix(CI): check latest commit for version release instead of version tag by [@&#8203;sabify](https://github.com/sabify) in https://github.com/leptos-rs/leptos/pull/4150 - Disable default features for Actix by [@&#8203;dbanty](https://github.com/dbanty) in https://github.com/leptos-rs/leptos/pull/3921 - feat: add `debug_log!`, `debug_error!`, `console_debug_log` and `console_debug_error` by [@&#8203;mahdi739](https://github.com/mahdi739) in https://github.com/leptos-rs/leptos/pull/4160 - fix(hot-reload): implement Myers diffing algorithm by [@&#8203;shadr](https://github.com/shadr) in https://github.com/leptos-rs/leptos/pull/4162 - fix(hot-reload): hot-reload stops working when number of views changes in a file + small fixes by [@&#8203;shadr](https://github.com/shadr) in https://github.com/leptos-rs/leptos/pull/4167 #### New Contributors - [@&#8203;shadr](https://github.com/shadr) made their first contribution in https://github.com/leptos-rs/leptos/pull/4154 - [@&#8203;dbanty](https://github.com/dbanty) made their first contribution in https://github.com/leptos-rs/leptos/pull/3921 **Full Changelog**: https://github.com/leptos-rs/leptos/compare/v0.8.3...v0.8.4 ### [`v0.8.3`](https://github.com/leptos-rs/leptos/releases/tag/v0.8.3) [Compare Source](https://github.com/leptos-rs/leptos/compare/v0.8.2...v0.8.3) This is a minor patch release. It does include a significant re-write of how ownership/context work with nested routes ([#&#8203;4091](https://github.com/leptos-rs/leptos/issues/4091)). This should close a number of bugs. However, it's always possible that changes like this introduce regressions. Please test to see whether you have any issues with context and nested routing, and let me know. (We have a new `regression` example set up to add e2e regression tests for issues going forward.) ##### What's Changed - Remove unnecessary "crate::" prefix in a documentation example. by [@&#8203;eroman-code](https://github.com/eroman-code) in https://github.com/leptos-rs/leptos/pull/3952 - Fix deprecated parameters js warning by [@&#8203;matchish](https://github.com/matchish) in https://github.com/leptos-rs/leptos/pull/3956 - fix: correct doc comment for `SsrMode::PartiallyBlocked` (closes [#&#8203;3963](https://github.com/leptos-rs/leptos/issues/3963)) by [@&#8203;marcuswhybrow](https://github.com/marcuswhybrow) in https://github.com/leptos-rs/leptos/pull/3964 - fix: add namespace to g in svg portals (closes [#&#8203;3958](https://github.com/leptos-rs/leptos/issues/3958)) by [@&#8203;uber5001](https://github.com/uber5001) in https://github.com/leptos-rs/leptos/pull/3960 - fix: allow rebuilding `Vec<_>` before it is mounted (closes [#&#8203;3962](https://github.com/leptos-rs/leptos/issues/3962)) by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/3966 - chore: unify all deps with min occurrences of 2 by [@&#8203;sabify](https://github.com/sabify) in https://github.com/leptos-rs/leptos/pull/3854 - chore: upgrade rand and getrandom by [@&#8203;sabify](https://github.com/sabify) in https://github.com/leptos-rs/leptos/pull/3840 - fix: render identical branch structure for out-of-order and async streaming of Suspense (closes [#&#8203;3970](https://github.com/leptos-rs/leptos/issues/3970)) by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/3977 - fix: remove non-existent feature dep in leptos_macro by [@&#8203;sabify](https://github.com/sabify) in https://github.com/leptos-rs/leptos/pull/3985 - feat: add missing `Resource::write()` and similar functions (see [#&#8203;3959](https://github.com/leptos-rs/leptos/issues/3959)) by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/3984 - Fix spelling typos. by [@&#8203;eroman-code](https://github.com/eroman-code) in https://github.com/leptos-rs/leptos/pull/3965 - fix: meta tags not properly rendered inside synchronously-available Suspend (closes [#&#8203;3976](https://github.com/leptos-rs/leptos/issues/3976)) by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/3991 - fix: smooshed static segments no longer matches the path [#&#8203;3968](https://github.com/leptos-rs/leptos/issues/3968) by [@&#8203;mskorkowski](https://github.com/mskorkowski) in https://github.com/leptos-rs/leptos/pull/3973 - Provide error message if file hashing is enabled but no hash file is … by [@&#8203;Bytekeeper](https://github.com/Bytekeeper) in https://github.com/leptos-rs/leptos/pull/3990 - fix: forward missing lint attributes passed to `#[component]` macro by [@&#8203;mondeja](https://github.com/mondeja) in https://github.com/leptos-rs/leptos/pull/3989 - fix: don't use `Arc::ptr_eq` for string comparison (closes [#&#8203;3983](https://github.com/leptos-rs/leptos/issues/3983)) by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/3994 - docs: document `#[prop(default = ...)]` and `#[prop(name = ...)]` by [@&#8203;mondeja](https://github.com/mondeja) in https://github.com/leptos-rs/leptos/pull/4003 - Make handle_response_inner public to be used in custom file_and_error (see [#&#8203;3996](https://github.com/leptos-rs/leptos/issues/3996)) by [@&#8203;NCura](https://github.com/NCura) in https://github.com/leptos-rs/leptos/pull/3998 - Fix context issues with nesting routing by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/4015 - Implement AttributeValue for Cow<'\_, str> by [@&#8203;sgued](https://github.com/sgued) in https://github.com/leptos-rs/leptos/pull/4013 - fix: fix `<select>` value by ensuring HTML children are mounted before setting attributes (closes [#&#8203;4005](https://github.com/leptos-rs/leptos/issues/4005)) by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/4008 - Minor: bump rkyv to 0.8.10. by [@&#8203;martinfrances107](https://github.com/martinfrances107) in https://github.com/leptos-rs/leptos/pull/4018 - remove unnecessary where-clauses by [@&#8203;lcnr](https://github.com/lcnr) in https://github.com/leptos-rs/leptos/pull/4023 - Fix typo by [@&#8203;saikatdas0790](https://github.com/saikatdas0790) in https://github.com/leptos-rs/leptos/pull/4025 - Update `session_auth_axum` example by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/4033 - fix: allow multiple `#[middleware]` macros (closes [#&#8203;4029](https://github.com/leptos-rs/leptos/issues/4029)) by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/4048 - fix: suppress false-positive warning when adding children to a `<For/>` that is not currently mounted (closes [#&#8203;3385](https://github.com/leptos-rs/leptos/issues/3385)) by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/4050 - fix: allow nested untracked reads without false positives (closes [#&#8203;4032](https://github.com/leptos-rs/leptos/issues/4032)) by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/4049 - chore: Fix issue template check boxes by [@&#8203;JosiahParry](https://github.com/JosiahParry) in https://github.com/leptos-rs/leptos/pull/4031 - fix: do not track anything inside the `async` block of a `Resource` (closes [#&#8203;4060](https://github.com/leptos-rs/leptos/issues/4060)) by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/4061 - Tests for [#&#8203;4061](https://github.com/leptos-rs/leptos/issues/4061) by [@&#8203;metatoaster](https://github.com/metatoaster) in https://github.com/leptos-rs/leptos/pull/4064 - fix: hygiene on `view` macro. by [@&#8203;metatoaster](https://github.com/metatoaster) in https://github.com/leptos-rs/leptos/pull/4071 - fix: memory leak introduced by [#&#8203;4015](https://github.com/leptos-rs/leptos/issues/4015) by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/4065 - docs: update Tauri project to Leptos v0.8.2 by [@&#8203;mondeja](https://github.com/mondeja) in https://github.com/leptos-rs/leptos/pull/4020 - feat(CI): add checking minimal-versions on release by [@&#8203;sabify](https://github.com/sabify) in https://github.com/leptos-rs/leptos/pull/3987 - Bugfixes to `reactive_stores` by [@&#8203;elias098](https://github.com/elias098) in https://github.com/leptos-rs/leptos/pull/4056 - Fix unresolved path in server side redirect by [@&#8203;TERRORW0LF](https://github.com/TERRORW0LF) in https://github.com/leptos-rs/leptos/pull/4074 - feat: allow dereferencing `LocalResource` to an `AsyncDerived` (closes [#&#8203;4063](https://github.com/leptos-rs/leptos/issues/4063)) by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/4077 - Fix updates to static class names by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/4078 - fix: don't render a comment node for `()` attributes in `template` (closes [#&#8203;4079](https://github.com/leptos-rs/leptos/issues/4079)) by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/4080 - Remove unnecessary Option wrapping by [@&#8203;mohe2015](https://github.com/mohe2015) in https://github.com/leptos-rs/leptos/pull/4035 - Removed crate once_cell by [@&#8203;martinfrances107](https://github.com/martinfrances107) in https://github.com/leptos-rs/leptos/pull/4083 - Fix compilation because of concurrent conflicting change by [@&#8203;mohe2015](https://github.com/mohe2015) in https://github.com/leptos-rs/leptos/pull/4090 - Use remove_event_listener_with_callback_and_bool when capturing listener by [@&#8203;foldedwave](https://github.com/foldedwave) in https://github.com/leptos-rs/leptos/pull/4082 - feat: impl `IntoFragment` for `AnyView` by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/4087 - docs: add document on adding `class` and other attributes to `<A/>` component by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/4086 - Add template cache for dom. by [@&#8203;bicarlsen](https://github.com/bicarlsen) in https://github.com/leptos-rs/leptos/pull/4099 - Add inert svg elements. by [@&#8203;bicarlsen](https://github.com/bicarlsen) in https://github.com/leptos-rs/leptos/pull/4085 - chore(deps): bump autofix-ci/action from 1.3.1 to 1.3.2 by [@&#8203;dependabot](https://github.com/dependabot)\[bot] in https://github.com/leptos-rs/leptos/pull/4072 - enhance: handle ../ in aria-current for A tags by [@&#8203;TERRORW0LF](https://github.com/TERRORW0LF) in https://github.com/leptos-rs/leptos/pull/4051 - \[fix] Update `svg::InertElement` for `dom` cache. by [@&#8203;bicarlsen](https://github.com/bicarlsen) in https://github.com/leptos-rs/leptos/pull/4100 - Create `svg::InertElement` templates in SVG namespace. by [@&#8203;bicarlsen](https://github.com/bicarlsen) in https://github.com/leptos-rs/leptos/pull/4104 - feat: add method `take` for BrowserFormData by [@&#8203;veigaribo](https://github.com/veigaribo) in https://github.com/leptos-rs/leptos/pull/4102 - fix: correctly provide context via nested outlets (closes [#&#8203;4088](https://github.com/leptos-rs/leptos/issues/4088)) by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/4091 - chore: remove now-unused `join_contexts` API by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/4113 - A place to put e2e tests for regression, plus reporting issue caused by [#&#8203;4091](https://github.com/leptos-rs/leptos/issues/4091). by [@&#8203;metatoaster](https://github.com/metatoaster) in https://github.com/leptos-rs/leptos/pull/4114 - chore bump syn and tokio-tungsenite. by [@&#8203;martinfrances107](https://github.com/martinfrances107) in https://github.com/leptos-rs/leptos/pull/4117 - Use inert_element for top level <svg> elements. by [@&#8203;bicarlsen](https://github.com/bicarlsen) in https://github.com/leptos-rs/leptos/pull/4109 - chore(deps): bump the rust-dependencies group across 1 directory with 18 updates by [@&#8203;dependabot](https://github.com/dependabot)\[bot] in https://github.com/leptos-rs/leptos/pull/4110 - fix: disable InertElement when global class is provided (closes [#&#8203;4116](https://github.com/leptos-rs/leptos/issues/4116)) by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/4119 - chore: Respond to updated clippy rules by [@&#8203;martinfrances107](https://github.com/martinfrances107) in https://github.com/leptos-rs/leptos/pull/4120 - Add an example to show server_fn is capable to serve on Cloudflare Workers by [@&#8203;ryo33](https://github.com/ryo33) in https://github.com/leptos-rs/leptos/pull/4052 - Clean up nested routing ownership and add regression tests by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/4115 - fix(examples): remove redundant cf-worker example by [@&#8203;sabify](https://github.com/sabify) in https://github.com/leptos-rs/leptos/pull/4140 - Fixes [#&#8203;4136](https://github.com/leptos-rs/leptos/issues/4136): Compile time errors while deriving store by [@&#8203;mskorkowski](https://github.com/mskorkowski) in https://github.com/leptos-rs/leptos/pull/4142 ##### New Contributors - [@&#8203;matchish](https://github.com/matchish) made their first contribution in https://github.com/leptos-rs/leptos/pull/3956 - [@&#8203;uber5001](https://github.com/uber5001) made their first contribution in https://github.com/leptos-rs/leptos/pull/3960 - [@&#8203;mskorkowski](https://github.com/mskorkowski) made their first contribution in https://github.com/leptos-rs/leptos/pull/3973 - [@&#8203;Bytekeeper](https://github.com/Bytekeeper) made their first contribution in https://github.com/leptos-rs/leptos/pull/3990 - [@&#8203;lcnr](https://github.com/lcnr) made their first contribution in https://github.com/leptos-rs/leptos/pull/4023 - [@&#8203;JosiahParry](https://github.com/JosiahParry) made their first contribution in https://github.com/leptos-rs/leptos/pull/4031 - [@&#8203;elias098](https://github.com/elias098) made their first contribution in https://github.com/leptos-rs/leptos/pull/4056 - [@&#8203;mohe2015](https://github.com/mohe2015) made their first contribution in https://github.com/leptos-rs/leptos/pull/4035 - [@&#8203;foldedwave](https://github.com/foldedwave) made their first contribution in https://github.com/leptos-rs/leptos/pull/4082 **Full Changelog**: https://github.com/leptos-rs/leptos/compare/v0.8.2...v0.8.3 ### [`v0.8.2`](https://github.com/leptos-rs/leptos/releases/tag/v0.8.2) [Compare Source](https://github.com/leptos-rs/leptos/compare/v0.8.1...v0.8.2) For 0.8 release notes in general, see [`0.8.0`](https://github.com/leptos-rs/leptos/releases/tag/v0.8.0). This patch release mostly addresses a bad issue with hydrating `<Stylesheet/>` and other meta components. (See [#&#8203;3945](https://github.com/leptos-rs/leptos/issues/3945) [#&#8203;3946](https://github.com/leptos-rs/leptos/issues/3946)) ##### What's Changed - fix: correct order of meta content relative to surrounding tags (closes [#&#8203;3945](https://github.com/leptos-rs/leptos/issues/3945)) by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/3950 - Fix cargo-leptos stylesheet caching ([#&#8203;3927](https://github.com/leptos-rs/leptos/issues/3927)) by [@&#8203;luxalpa](https://github.com/luxalpa) in https://github.com/leptos-rs/leptos/pull/3947 **Full Changelog**: https://github.com/leptos-rs/leptos/compare/v0.8.1...v0.8.2 ### [`v0.8.1`](https://github.com/leptos-rs/leptos/releases/tag/v0.8.1) [Compare Source](https://github.com/leptos-rs/leptos/compare/v0.8.0...v0.8.1) For 0.8 release notes in general, see [`0.8.0`](https://github.com/leptos-rs/leptos/releases/tag/v0.8.0). This patch release is mostly just a bunch of bugfixes for issues raised or fixed since then. ##### What's Changed - fix(docs): correct panic message in copied example code by [@&#8203;LeoniePhiline](https://github.com/LeoniePhiline) in https://github.com/leptos-rs/leptos/pull/3911 - fix: allow nested Suspense > ErrorBoundary > Suspense (closes [#&#8203;3908](https://github.com/leptos-rs/leptos/issues/3908)) by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/3913 - fix: correct issues with `StaticVec::rebuild()` by aligning implementation with `Vec::rebuild()` (closes [#&#8203;3906](https://github.com/leptos-rs/leptos/issues/3906)) by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/3920 - fix: clear and re-throw errors in correct order by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/3923 - fix(CI): prevent regreession from nightly clippy in autofix by [@&#8203;sabify](https://github.com/sabify) in https://github.com/leptos-rs/leptos/pull/3917 - Fix some typos in the documentation/examples for reactive store. by [@&#8203;eroman-code](https://github.com/eroman-code) in https://github.com/leptos-rs/leptos/pull/3924 - feat: check the `counter_isomorphic` release build with the leptos_debuginfo by [@&#8203;sabify](https://github.com/sabify) in https://github.com/leptos-rs/leptos/pull/3918 - fix: ensure that nested children of a `RenderEffect` are dropped while dropped a `RenderEffect` (closes [#&#8203;3922](https://github.com/leptos-rs/leptos/issues/3922)) by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/3926 - fix: correctly provide context through islands to children (closes [#&#8203;3928](https://github.com/leptos-rs/leptos/issues/3928)) by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/3933 - reactive_stores: implement PartialEq and Eq for Store by [@&#8203;wrl](https://github.com/wrl) in https://github.com/leptos-rs/leptos/pull/3915 - fix: use a runtime check rather than an unnecessary `Either` to determine how to render islands (see [#&#8203;3896](https://github.com/leptos-rs/leptos/issues/3896); closes [#&#8203;3929](https://github.com/leptos-rs/leptos/issues/3929)) by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/3938 - fix: remove extra marker node after text node when marking a branch (closes [#&#8203;3936](https://github.com/leptos-rs/leptos/issues/3936)) by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/3940 - feat: add `.map()` and `.and_then()` on `LocalResource` by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/3941 - Some `islands_router` improvements by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/3942 ##### New Contributors - [@&#8203;LeoniePhiline](https://github.com/LeoniePhiline) made their first contribution in https://github.com/leptos-rs/leptos/pull/3911 - [@&#8203;eroman-code](https://github.com/eroman-code) made their first contribution in https://github.com/leptos-rs/leptos/pull/3924 - [@&#8203;wrl](https://github.com/wrl) made their first contribution in https://github.com/leptos-rs/leptos/pull/3915 **Full Changelog**: https://github.com/leptos-rs/leptos/compare/v0.8.0...v0.8.1 ### [`v0.8.0`](https://github.com/leptos-rs/leptos/releases/tag/v0.8.0) [Compare Source](https://github.com/leptos-rs/leptos/compare/v0.7.8...v0.8.0) \*Changelog relative to `0.7.8`. \* 0.8 has been planned for a while, primarily to accommodate small changes that arose during the course of testing and adopting 0.7, most of which are technically semver-breaking but should not meaningfully affect user code. I think it's a significant QOL and user DX upgrade and I'm excited to properly release it. Noteworthy features: - Axum 0.8 support. (This alone required a major version bump, as we reexport some Axum types.) (thanks to [@&#8203;sabify](https://github.com/sabify) for the migration work here) - Significant improvements to compile times when using `--cfg=erase_components`, which is useful as a dev-mode optimization (thanks to [@&#8203;zakstucke](https://github.com/zakstucke)) This is the default setting for `cargo-leptos` with its latest release, and can be set up manually for use with Trunk. (See docs [here](https://book.leptos.dev/getting_started/leptos_dx.html#4-use---cfgerase_components-during-development).) - Support for the new `islands-router` features that allow a client-side routing experience while using islands (see the [`islands_router`](https://github.com/leptos-rs/leptos/tree/main/examples/islands_router) example) (this one was me) - Improved server function error handling by allowing you to use any type that implements `FromServerFnError` rather than being constrained to use `ServerFnError` (see [#&#8203;3274](https://github.com/leptos-rs/leptos/issues/3274)). (Note: This will require changes if you're using a custom error type, but should be a better experience.) (thanks to [@&#8203;ryo33](https://github.com/ryo33)) - Support for creating WebSockets via server fns (thanks to [@&#8203;ealmloff](https://github.com/ealmloff)) - Changes to make custom errors significantly more ergonomic when using server functions - `LocalResource` no longer exposes a `SendWrapper` in the API for the types it returns. (**Breaking change**: this will require removing some `.as_deref()` and so on when using `LocalResource`, but ends up with a much better API.) - Significantly improved DX/bugfixes for thread-local Actions. As you can see this was a real team effort and, as always, I'm grateful for the contributions of everyone named above, and all those who made commits below. ##### WebSocket Example The WebSocket support is particularly exciting, as it allows you to call server functions using the default Rust `Stream` trait from the `futures` crate, and have those streams send messages over websockets without you needing to know anything about that process. The API landed in a place that feels like a great extension of the "server function" abstraction in which you can make HTTP requests as if they were ordinary async calls. The websocket stuff doesn't integrate directly with Resources/SSR (which make more sense for one-shot things) but is really easy to use: ```rust use server_fn::{codec::JsonEncoding, BoxedStream, ServerFnError, Websocket}; // The websocket protocol can be used on any server function that accepts and returns a [`BoxedStream`] // with items that can be encoded by the input and output encoding generics. // // In this case, the input and output encodings are [`Json`] and [`Json`], respectively which requires // the items to implement [`Serialize`] and [`Deserialize`]. #[server(protocol = Websocket<JsonEncoding, JsonEncoding>)] async fn echo_websocket( input: BoxedStream<String, ServerFnError>, ) -> Result<BoxedStream<String, ServerFnError>, ServerFnError> { use futures::channel::mpsc; use futures::{SinkExt, StreamExt}; let mut input = input; // FIXME :-) server fn fields should pass mut through to destructure // create a channel of outgoing websocket messages // we'll return rx, so sending a message to tx will send a message to the client via the websocket let (mut tx, rx) = mpsc::channel(1); // spawn a task to listen to the input stream of messages coming in over the websocket tokio::spawn(async move { while let Some(msg) = input.next().await { // do some work on each message, and then send our responses tx.send(msg.map(|msg| msg.to_ascii_uppercase())).await; } }); Ok(rx.into()) } #[component] pub fn App() -> impl IntoView { use futures::channel::mpsc; use futures::StreamExt; let (mut tx, rx) = mpsc::channel(1); let latest = RwSignal::new(None); // we'll only listen for websocket messages on the client if cfg!(feature = "hydrate") { spawn_local(async move { match echo_websocket(rx.into()).await { Ok(mut messages) => { while let Some(msg) = messages.next().await { latest.set(Some(msg)); } } Err(e) => leptos::logging::warn!("{e}"), } }); } view! { <input type="text" on:input:target=move |ev| { tx.try_send(Ok(ev.target().value())); }/> <p>{latest}</p> } } ``` ##### What's Changed - Allow any type that implements FromServerFnError as a replacement of the ServerFnError in server_fn by [@&#8203;ryo33](https://github.com/ryo33) in https://github.com/leptos-rs/leptos/pull/3274 - impl Dispose for Callback types and add try_run to the Callable trait by [@&#8203;basro](https://github.com/basro) in https://github.com/leptos-rs/leptos/pull/3371 - feat(breaking): allow make `PossibleRouteMatch` dyn-safe by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/3421 - chore: upgrade `axum` to `v0.8` by [@&#8203;sabify](https://github.com/sabify) in https://github.com/leptos-rs/leptos/pull/3439 - feat: Add more options for generating server fn routes by [@&#8203;spencewenski](https://github.com/spencewenski) in https://github.com/leptos-rs/leptos/pull/3438 - change: allow `IntoFuture` for `Suspend::new()` (closes [#&#8203;3509](https://github.com/leptos-rs/leptos/issues/3509)) by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/3532 - fix: remove `Default` impl for `LeptosOptions` and `ConfFile` by [@&#8203;chrisp60](https://github.com/chrisp60) in https://github.com/leptos-rs/leptos/pull/3522 - Fixing closing brace by [@&#8203;thestarmaker](https://github.com/thestarmaker) in https://github.com/leptos-rs/leptos/pull/3539 - AddAnyAttr for AnyView for non-erased by [@&#8203;zakstucke](https://github.com/zakstucke) in https://github.com/leptos-rs/leptos/pull/3553 - "Update axum paths to 0.8 syntax" by [@&#8203;zakstucke](https://github.com/zakstucke) in https://github.com/leptos-rs/leptos/pull/3555 - Keep `AddAnyAttr` logic contained by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/3562 - fix: Actix stream error handling with 0.8 error types by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/3574 - RenderHtml::into_owned by [@&#8203;zakstucke](https://github.com/zakstucke) in https://github.com/leptos-rs/leptos/pull/3580 - Binary size wins by [@&#8203;zakstucke](https://github.com/zakstucke) in https://github.com/leptos-rs/leptos/pull/3566 - Internally erase html elements by [@&#8203;zakstucke](https://github.com/zakstucke) in https://github.com/leptos-rs/leptos/pull/3614 - feat: support `Option<_>` in `style:` (closes [#&#8203;3568](https://github.com/leptos-rs/leptos/issues/3568)) by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/3618 - Erased routing, codegen opts by [@&#8203;zakstucke](https://github.com/zakstucke) in https://github.com/leptos-rs/leptos/pull/3623 - change: remove unused `Result` alias by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/3543 - feat: support `IntoSplitSignal` for `(Signal<T>, SignalSetter<T>)` (closes [#&#8203;3634](https://github.com/leptos-rs/leptos/issues/3634)) by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/3643 - fix: avoid hydration issues with `HashedStylesheet` (closes [#&#8203;3633](https://github.com/leptos-rs/leptos/issues/3633)) by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/3654 - Islands router by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/3502 - Erased mode in CI by [@&#8203;zakstucke](https://github.com/zakstucke) in https://github.com/leptos-rs/leptos/pull/3640 - fix: tweak bounds on For for backwards-compat by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/3663 - Implement several into traits for store fields (0.8) by [@&#8203;mahdi739](https://github.com/mahdi739) in https://github.com/leptos-rs/leptos/pull/3658 - Implement `IntoClass` for store fields by [@&#8203;mahdi739](https://github.com/mahdi739) in https://github.com/leptos-rs/leptos/pull/3670 - fix: Ensure reactive functions passed to `TextProp` are kept reactive (closes: [#&#8203;3689](https://github.com/leptos-rs/leptos/issues/3689)) by [@&#8203;mahdi739](https://github.com/mahdi739) in https://github.com/leptos-rs/leptos/pull/3690 - Add websocket support for server functions by [@&#8203;ealmloff](https://github.com/ealmloff) in https://github.com/leptos-rs/leptos/pull/3656 - fix: broken type inference for `Action::new_unsync` (closes [#&#8203;3328](https://github.com/leptos-rs/leptos/issues/3328)) by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/3705 - feat(reactive_stores): Replace `AsRef` bound of `StoreFieldIterator` blanket impl with `Len` bound by [@&#8203;DanikVitek](https://github.com/DanikVitek) in https://github.com/leptos-rs/leptos/pull/3701 - refactor: make `shell` parameter in `file_and_error_handler*` generic by [@&#8203;tversteeg](https://github.com/tversteeg) in https://github.com/leptos-rs/leptos/pull/3711 - view!{} macro optimisation: don't wrap string types in closures when passing to ToChildren by [@&#8203;zakstucke](https://github.com/zakstucke) in https://github.com/leptos-rs/leptos/pull/3716 - Remove SendWrapper from the external interface of LocalResource by [@&#8203;zakstucke](https://github.com/zakstucke) in https://github.com/leptos-rs/leptos/pull/3715 - More flexible server fn macro api by [@&#8203;ealmloff](https://github.com/ealmloff) in https://github.com/leptos-rs/leptos/pull/3725 - fix(CI): switch to stable in semver for most compatibility by [@&#8203;sabify](https://github.com/sabify) in https://github.com/leptos-rs/leptos/pull/3737 - fix(CI): cancel in-group inflight and pending jobs on new pushes in pull requests by [@&#8203;sabify](https://github.com/sabify) in https://github.com/leptos-rs/leptos/pull/3739 - fix(CI): free-up disk, properly gate nightly feature and pre-install deps by [@&#8203;sabify](https://github.com/sabify) in https://github.com/leptos-rs/leptos/pull/3735 - ArcLocalResource fix (0.8) by [@&#8203;zakstucke](https://github.com/zakstucke) in https://github.com/leptos-rs/leptos/pull/3741 - ArcLocalResource fix (0.7) by [@&#8203;zakstucke](https://github.com/zakstucke) in https://github.com/leptos-rs/leptos/pull/3740 - fix(CI): cleanup the directory no matter of the results by [@&#8203;sabify](https://github.com/sabify) in https://github.com/leptos-rs/leptos/pull/3743 - fix(CI): sermver job name by [@&#8203;sabify](https://github.com/sabify) in https://github.com/leptos-rs/leptos/pull/3748 - chore: no need to filter out "nightly" feature as of [#&#8203;3735](https://github.com/leptos-rs/leptos/issues/3735) by [@&#8203;sabify](https://github.com/sabify) in https://github.com/leptos-rs/leptos/pull/3747 - fix: use signals rather than `Action::new_local()` (closes [#&#8203;3746](https://github.com/leptos-rs/leptos/issues/3746)) by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/3749 - feat: switch `extract()` helper to use `ServerFnErrorErr` (closes [#&#8203;3745](https://github.com/leptos-rs/leptos/issues/3745)) by [@&#8203;ilyvion](https://github.com/ilyvion) in https://github.com/leptos-rs/leptos/pull/3750 - docs(`Effect::watch`): refer to `dependency_fn` and `handler` args by [@&#8203;jmevel](https://github.com/jmevel) in https://github.com/leptos-rs/leptos/pull/3731 - Leptos 0.8 by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/3529 - chore: ensure WASM target is installed for examples with provided `rust-toolchain.toml` (closes [#&#8203;3717](https://github.com/leptos-rs/leptos/issues/3717)) by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/3752 - Make trailing comma optional for either macro by [@&#8203;NCura](https://github.com/NCura) in https://github.com/leptos-rs/leptos/pull/3736 - chore: add `SignalSetter` to prelude (closes [#&#8203;3547](https://github.com/leptos-rs/leptos/issues/3547)) by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/3753 - fix: properly feature gating ui macro tests (Closes [#&#8203;3742](https://github.com/leptos-rs/leptos/issues/3742)) by [@&#8203;sabify](https://github.com/sabify) in https://github.com/leptos-rs/leptos/pull/3756 - fix(CI): optimize CI workflow by [@&#8203;sabify](https://github.com/sabify) in https://github.com/leptos-rs/leptos/pull/3758 - fix(CI): remove duplicate semver ci, [#&#8203;3758](https://github.com/leptos-rs/leptos/issues/3758) follow-up by [@&#8203;sabify](https://github.com/sabify) in https://github.com/leptos-rs/leptos/pull/3764 - fix(CI): install deps only if needed, speeds up CI by [@&#8203;sabify](https://github.com/sabify) in https://github.com/leptos-rs/leptos/pull/3768 - fix: support `IntoFragment` for single element (closes [#&#8203;3757](https://github.com/leptos-rs/leptos/issues/3757)) by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/3759 - fix: clippy errors by [@&#8203;sabify](https://github.com/sabify) in https://github.com/leptos-rs/leptos/pull/3772 - fix(CI): install deno only if needed, [#&#8203;3768](https://github.com/leptos-rs/leptos/issues/3768) follow-up by [@&#8203;sabify](https://github.com/sabify) in https://github.com/leptos-rs/leptos/pull/3773 - fix(CI): remove caching by [@&#8203;sabify](https://github.com/sabify) in https://github.com/leptos-rs/leptos/pull/3776 - fix(CI): conditional executions of only changed examples by [@&#8203;sabify](https://github.com/sabify) in https://github.com/leptos-rs/leptos/pull/3777 - Make docs match reality by [@&#8203;ilyvion](https://github.com/ilyvion) in https://github.com/leptos-rs/leptos/pull/3775 - fix(CI): toolchain will be determined and test against by CI by [@&#8203;sabify](https://github.com/sabify) in https://github.com/leptos-rs/leptos/pull/3778 - Reduce use local signals for `Action::new_local` and similar primitives by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/3762 - Tweaks to `MaybeSendWrapperOption<_>` by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/3781 - fix: correctly handle optional parameters in `ParentRoute` by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/3784 - fix: router example build process by [@&#8203;sabify](https://github.com/sabify) in https://github.com/leptos-rs/leptos/pull/3779 - fix(CI): run only the exact examples on the only examples change by [@&#8203;sabify](https://github.com/sabify) in https://github.com/leptos-rs/leptos/pull/3782 - Re-export the codee crate by [@&#8203;zakstucke](https://github.com/zakstucke) in https://github.com/leptos-rs/leptos/pull/3761 - fix: allow repeated `class=` for all tuples, not only static ones (closes [#&#8203;3794](https://github.com/leptos-rs/leptos/issues/3794)) by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/3801 - Fix Store notification order for nested keyed fields by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/3799 - Improved handling of `<Title/>` by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/3793 - derive_local for ArcSignal\<T, LocalStorage> by [@&#8203;zakstucke](https://github.com/zakstucke) in https://github.com/leptos-rs/leptos/pull/3798 - fix: portal example by [@&#8203;sabify](https://github.com/sabify) in https://github.com/leptos-rs/leptos/pull/3785 - feat: add support for more HTTP methods in server fn codecs by [@&#8203;ChosunOne](https://github.com/ChosunOne) in https://github.com/leptos-rs/leptos/pull/3797 - Store test fixes by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/3803 - Add track_caller to store field methods by [@&#8203;jvdwrf](https://github.com/jvdwrf) in https://github.com/leptos-rs/leptos/pull/3805 - fix: allow custom status codes or redirects for route fallbacks by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/3808 - fix: Move several Into\* trait impls for store fields out of stable module for wider use by [@&#8203;mahdi739](https://github.com/mahdi739) in https://github.com/leptos-rs/leptos/pull/3807 - fix: remove `SendOption` from public API of actions by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/3812 - feat: support aliased `Result` return types for `server_fn` by [@&#8203;ifiokjr](https://github.com/ifiokjr) in https://github.com/leptos-rs/leptos/pull/3755 - Migrate from Tailwind 3 to Tailwind 4 for the axum example. by [@&#8203;pico-bolero](https://github.com/pico-bolero) in https://github.com/leptos-rs/leptos/pull/3804 - pass key reference to `Selector::selected` by [@&#8203;flisky](https://github.com/flisky) in https://github.com/leptos-rs/leptos/pull/3694 - fix: correctly establish root ownership for static site generation (closes [#&#8203;3822](https://github.com/leptos-rs/leptos/issues/3822)) by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/3824 - fix: do not match static segment with last character missing before slash (closes [#&#8203;3817](https://github.com/leptos-rs/leptos/issues/3817)) by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/3823 - fix: prevent race condition in executor initialization + docs, optimization and tests by [@&#8203;sabify](https://github.com/sabify) in https://github.com/leptos-rs/leptos/pull/3802 - chore: missing Copy/Clone impls for MappedSignal by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/3827 - Revert "Remove getrandom ([#&#8203;3589](https://github.com/leptos-rs/leptos/issues/3589))" by [@&#8203;ilyvion](https://github.com/ilyvion) in https://github.com/leptos-rs/leptos/pull/3830 - Introducing `cargo all-features clippy|nextest` part of build process by [@&#8203;sabify](https://github.com/sabify) in https://github.com/leptos-rs/leptos/pull/3767 - feat: allow using different error types for req/resp with WebSockets, closes [#&#8203;3724](https://github.com/leptos-rs/leptos/issues/3724) by [@&#8203;myypo](https://github.com/myypo) in https://github.com/leptos-rs/leptos/pull/3766 - feat: enhancing server_fn errors by [@&#8203;sabify](https://github.com/sabify) in https://github.com/leptos-rs/leptos/pull/3811 - fix: call `additional_context` after providing other server context in all cases by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/3841 - fix: correctly decode base64-encoded server action error messages stored in URL by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/3842 - fix: don't try to move keyed elements within the DOM if they're not yet mounted (closes [#&#8203;3844](https://github.com/leptos-rs/leptos/issues/3844)) by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/3846 - chore(nightly): update proc-macro span file name method name by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/3852 - fix: reactive_graph keymap impl and clippy warnings by [@&#8203;sabify](https://github.com/sabify) in https://github.com/leptos-rs/leptos/pull/3843 - chore: ran cargo outdated. by [@&#8203;martinfrances107](https://github.com/martinfrances107) in https://github.com/leptos-rs/leptos/pull/3722 - fix: close Actix websocket stream when browser disconnects (closes [#&#8203;3865](https://github.com/leptos-rs/leptos/issues/3865)) by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/3866 - Error boundary fixes by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/3870 - Forward lint attributes used with #\[component] macro by [@&#8203;sathish-pv](https://github.com/sathish-pv) in https://github.com/leptos-rs/leptos/pull/3864 - Complete the migration of examples to Tailwind 4 by [@&#8203;nnmm](https://github.com/nnmm) in https://github.com/leptos-rs/leptos/pull/3861 - fix: Use stabilized ClipboardEvent by [@&#8203;feathecutie](https://github.com/feathecutie) in https://github.com/leptos-rs/leptos/pull/3849 - Added header generation method to BrowserResponse by [@&#8203;rakshith-ravi](https://github.com/rakshith-ravi) in https://github.com/leptos-rs/leptos/pull/3873 - Prevent ScopedFuture stopping owner cleanup by [@&#8203;zakstucke](https://github.com/zakstucke) in https://github.com/leptos-rs/leptos/pull/3863 - feat: enhancing `ByteStream` error handling by [@&#8203;sabify](https://github.com/sabify) in https://github.com/leptos-rs/leptos/pull/3869 - fix: send/receive websocket data by [@&#8203;sabify](https://github.com/sabify) in https://github.com/leptos-rs/leptos/pull/3848 - feat(examples): add WebSocket example by [@&#8203;sabify](https://github.com/sabify) in https://github.com/leptos-rs/leptos/pull/3853 - chore: put `TextProp` in the prelude (closes [#&#8203;3877](https://github.com/leptos-rs/leptos/issues/3877)) by [@&#8203;huuff](https://github.com/huuff) in https://github.com/leptos-rs/leptos/pull/3879 - fix(examples): websocket example tests fail on latency by [@&#8203;sabify](https://github.com/sabify) in https://github.com/leptos-rs/leptos/pull/3880 - fix: correctly calculate starting index for first new key (closes [#&#8203;3828](https://github.com/leptos-rs/leptos/issues/3828)) by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/3878 - fix: remove event listeners from Suspense fallback during SSR (closes [#&#8203;3871](https://github.com/leptos-rs/leptos/issues/3871)) by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/3882 - fix(examples): broken favicons in hackernews examples (closes [#&#8203;3890](https://github.com/leptos-rs/leptos/issues/3890)) by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/3891 - docs: add note about file hashing in `Stylesheet` docs by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/3898 - fix(examples): incorrect routes in hackernews example (closes [#&#8203;3892](https://github.com/leptos-rs/leptos/issues/3892)) by [@&#8203;nickburlett](https://github.com/nickburlett) in https://github.com/leptos-rs/leptos/pull/3894 - Fix some island-routing issues by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/3901 - fix: prevent sibling context leakage in islands (closes [#&#8203;3902](https://github.com/leptos-rs/leptos/issues/3902)) by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/3903 - fix: correct hydration for elements after island `children` (closes [#&#8203;3904](https://github.com/leptos-rs/leptos/issues/3904)) by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/3905 - Fix leptos_debuginfo by [@&#8203;zakstucke](https://github.com/zakstucke) in https://github.com/leptos-rs/leptos/pull/3899 - fix(examples): websocket tests fail (occasionally) second attemp by [@&#8203;sabify](https://github.com/sabify) in https://github.com/leptos-rs/leptos/pull/3910 - feat: `impl From<MappedSignal<T>> for Signal<T>` (closes [#&#8203;3889](https://github.com/leptos-rs/leptos/issues/3889)) by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/3897 ##### New Contributors - [@&#8203;ryo33](https://github.com/ryo33) made their first contribution in https://github.com/leptos-rs/leptos/pull/3274 - [@&#8203;basro](https://github.com/basro) made their first contribution in https://github.com/leptos-rs/leptos/pull/3371 - [@&#8203;ilyvion](https://github.com/ilyvion) made their first contribution in https://github.com/leptos-rs/leptos/pull/3750 - [@&#8203;jmevel](https://github.com/jmevel) made their first contribution in https://github.com/leptos-rs/leptos/pull/3731 - [@&#8203;ChosunOne](https://github.com/ChosunOne) made their first contribution in https://github.com/leptos-rs/leptos/pull/3797 - [@&#8203;ifiokjr](https://github.com/ifiokjr) made their first contribution in https://github.com/leptos-rs/leptos/pull/3755 - [@&#8203;pico-bolero](https://github.com/pico-bolero) made their first contribution in https://github.com/leptos-rs/leptos/pull/3804 - [@&#8203;myypo](https://github.com/myypo) made their first contribution in https://github.com/leptos-rs/leptos/pull/3766 - [@&#8203;sathish-pv](https://github.com/sathish-pv) made their first contribution in https://github.com/leptos-rs/leptos/pull/3864 - [@&#8203;nnmm](https://github.com/nnmm) made their first contribution in https://github.com/leptos-rs/leptos/pull/3861 - [@&#8203;feathecutie](https://github.com/feathecutie) made their first contribution in https://github.com/leptos-rs/leptos/pull/3849 - [@&#8203;huuff](https://github.com/huuff) made their first contribution in https://github.com/leptos-rs/leptos/pull/3879 - [@&#8203;nickburlett](https://github.com/nickburlett) made their first contribution in https://github.com/leptos-rs/leptos/pull/3894 **Full Changelog**: https://github.com/leptos-rs/leptos/compare/v0.7.8...v0.8.0 ### [`v0.7.8`](https://github.com/leptos-rs/leptos/releases/tag/v0.7.8) [Compare Source](https://github.com/leptos-rs/leptos/compare/v0.7.7...v0.7.8) A minor release with some quality of life improvements and bugfixes ##### What's Changed - fix: remove extra placeholder in Vec of text nodes (closes [#&#8203;3583](https://github.com/leptos-rs/leptos/issues/3583)) by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/3592 - fix: occasional use-after-disposed panic in Suspense by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/3595 - projects/bevy3d_ui Migrate to leptos 0.7.7 by [@&#8203;martinfrances107](https://github.com/martinfrances107) in https://github.com/leptos-rs/leptos/pull/3596 - projects/bevy3d_ui: Bevy migration by [@&#8203;martinfrances107](https://github.com/martinfrances107) in https://github.com/leptos-rs/leptos/pull/3597 - Minor: leptos_config - Bump the "config" crate to version 0.15.8 by [@&#8203;martinfrances107](https://github.com/martinfrances107) in https://github.com/leptos-rs/leptos/pull/3594 - Minor: Bump itertools to "0.14.0" by [@&#8203;martinfrances107](https://github.com/martinfrances107) in https://github.com/leptos-rs/leptos/pull/3593 - Minor: Bumped version of convert_case to 0.7 by [@&#8203;martinfrances107](https://github.com/martinfrances107) in https://github.com/leptos-rs/leptos/pull/3590 - Minor: "wasm-bindgen" - Moved the crate definition up to the root workspace by [@&#8203;martinfrances107](https://github.com/martinfrances107) in https://github.com/leptos-rs/leptos/pull/3588 - Remove getrandom by [@&#8203;martinfrances107](https://github.com/martinfrances107) in https://github.com/leptos-rs/leptos/pull/3589 - Minor: Bump tokio to 1.43. by [@&#8203;martinfrances107](https://github.com/martinfrances107) in https://github.com/leptos-rs/leptos/pull/3600 - projects/bevy3d_ui: Bevy - Bugfix, clippy and crate bump by [@&#8203;martinfrances107](https://github.com/martinfrances107) in https://github.com/leptos-rs/leptos/pull/3603 - Add invert to the OptionStoreExt by [@&#8203;mahdi739](https://github.com/mahdi739) in https://github.com/leptos-rs/leptos/pull/3534 - feat: allow pausing and resuming effects by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/3599 - Impl into<Signal> for subfields by [@&#8203;jvdwrf](https://github.com/jvdwrf) in https://github.com/leptos-rs/leptos/pull/3579 - fix: reorder pause check in new_isomorphic by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/3613 - Minor: drop create_signal form the landing page. by [@&#8203;martinfrances107](https://github.com/martinfrances107) in https://github.com/leptos-rs/leptos/pull/3611 - chore: update `either_of` minimum version in workspace by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/3612 - fix: hydration of `()` by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/3615 - Put serde_json in the root workspace by [@&#8203;martinfrances107](https://github.com/martinfrances107) in https://github.com/leptos-rs/leptos/pull/3610 - fix: only render meta tags when rendered, not when created (closes [#&#8203;3629](https://github.com/leptos-rs/leptos/issues/3629)) by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/3630 - fix: allow decoding already-decoded URI components (closes [#&#8203;3606](https://github.com/leptos-rs/leptos/issues/3606)) by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/3628 - chore(ci): update pinned nightly version by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/3644 - chore: fix Axum test setup by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/3651 - feat: map and and_then for resource variants by [@&#8203;TERRORW0LF](https://github.com/TERRORW0LF) in https://github.com/leptos-rs/leptos/pull/3652 - Implement `Debug` for `ArcField` and `Field` by [@&#8203;mahdi739](https://github.com/mahdi739) in https://github.com/leptos-rs/leptos/pull/3660 - Minor: examples/server_fns_axum - Bumped various packages (not axum). by [@&#8203;martinfrances107](https://github.com/martinfrances107) in https://github.com/leptos-rs/leptos/pull/3655 - fix: do not double-insert hash character in URLs (closes [#&#8203;3647](https://github.com/leptos-rs/leptos/issues/3647)) by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/3661 - fix: param segments should not match an empty string that contains only `/` separator (closes [#&#8203;3527](https://github.com/leptos-rs/leptos/issues/3527)) by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/3662 - fix: ensure cleanups run for all replaced nested routes (closes [#&#8203;3665](https://github.com/leptos-rs/leptos/issues/3665)) by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/3666 - Minor: clippy - Replace mem::replace with Option::replace by [@&#8203;martinfrances107](https://github.com/martinfrances107) in https://github.com/leptos-rs/leptos/pull/3668 - fix: point `bind:group` to correct location (closes [#&#8203;3678](https://github.com/leptos-rs/leptos/issues/3678)) by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/3680 - fix: enum stack size by [@&#8203;sabify](https://github.com/sabify) in https://github.com/leptos-rs/leptos/pull/3677 - fix: semver and feature handy script for update nightly by [@&#8203;sabify](https://github.com/sabify) in https://github.com/leptos-rs/leptos/pull/3674 - fix: untrack in `NodeRef::on_load()` to avoid re-triggering it if you read something reactively (closes [#&#8203;3684](https://github.com/leptos-rs/leptos/issues/3684)) by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/3686 - `ImmediateEffect` by [@&#8203;QuartzLibrary](https://github.com/QuartzLibrary) in https://github.com/leptos-rs/leptos/pull/3650 - `ImmediateEffect` follow up by [@&#8203;QuartzLibrary](https://github.com/QuartzLibrary) in https://github.com/leptos-rs/leptos/pull/3692 - Allow LocalResource sync methods to be used outside Suspense by [@&#8203;zakstucke](https://github.com/zakstucke) in https://github.com/leptos-rs/leptos/pull/3708 - fix: ensure that store subfield mutations notify from the root down (closes [#&#8203;3704](https://github.com/leptos-rs/leptos/issues/3704)) by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/3714 - fix(reactive_stores_macro): Make tuple struct field locator in `impl Patch` be `syn::Index` instead of `usize` by [@&#8203;DanikVitek](https://github.com/DanikVitek) in https://github.com/leptos-rs/leptos/pull/3700 - Various issues related to setting signals and context in cleanups by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/3687 - test: regression from [#&#8203;3502](https://github.com/leptos-rs/leptos/issues/3502) by [@&#8203;metatoaster](https://github.com/metatoaster) in https://github.com/leptos-rs/leptos/pull/3720 - Fix typo by [@&#8203;NCura](https://github.com/NCura) in https://github.com/leptos-rs/leptos/pull/3727 - fix: matching optional params after an initial static param (closes [#&#8203;3730](https://github.com/leptos-rs/leptos/issues/3730)) by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/3732 - docs: update example tailwind input css to v4 by [@&#8203;bimoadityar](https://github.com/bimoadityar) in https://github.com/leptos-rs/leptos/pull/3702 ##### New Contributors - [@&#8203;TERRORW0LF](https://github.com/TERRORW0LF) made their first contribution in https://github.com/leptos-rs/leptos/pull/3652 - [@&#8203;QuartzLibrary](https://github.com/QuartzLibrary) made their first contribution in https://github.com/leptos-rs/leptos/pull/3650 - [@&#8203;bimoadityar](https://github.com/bimoadityar) made their first contribution in https://github.com/leptos-rs/leptos/pull/3702 **Full Changelog**: https://github.com/leptos-rs/leptos/compare/v0.7.7...v0.7.8 ### [`v0.7.7`](https://github.com/leptos-rs/leptos/releases/tag/v0.7.7) **If you're migrating from 0.6 to 0.7, please see the 0.7.0 release notes [here](https://github.com/leptos-rs/leptos/releases/tag/v0.7.0).** This is a small patch release including primarily bugfixes, and some small ergonomic improvements. ##### What's Changed - add file_and_error_handler_with_context by [@&#8203;sstepanchuk](https://github.com/sstepanchuk) in https://github.com/leptos-rs/leptos/pull/3526 - feat: impl `From<ArcField<T>>` for `Field<T>` by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/3533 - Implement PatchField for Option by [@&#8203;iradicek](https://github.com/iradicek) in https://github.com/leptos-rs/leptos/pull/3528 - fix: attribute type erasure nightly (closes [#&#8203;3536](https://github.com/leptos-rs/leptos/issues/3536)) by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/3537 - fix: emit syntax errors in components rather than swallowing them (closes [#&#8203;3535](https://github.com/leptos-rs/leptos/issues/3535)) by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/3538 - Fix ci by [@&#8203;zakstucke](https://github.com/zakstucke) in https://github.com/leptos-rs/leptos/pull/3557 - Implement `Attribute` for `Either<A, B>` by [@&#8203;alexisfontaine](https://github.com/alexisfontaine) in https://github.com/leptos-rs/leptos/pull/3556 - chore(ci): `cargo install --locked` for `cargo-leptos` installation by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/3559 - fix: don't use InertElement for `style:` etc. (closes [#&#8203;3554](https://github.com/leptos-rs/leptos/issues/3554)) by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/3558 - fix: do not hold lock on arena when dispatching Action by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/3561 - fix: Return empty iterator instead of panicking when the KeyedSubfield is disposed by [@&#8203;mahdi739](https://github.com/mahdi739) in https://github.com/leptos-rs/leptos/pull/3550 - Less panic in stores by [@&#8203;mahdi739](https://github.com/mahdi739) in https://github.com/leptos-rs/leptos/pull/3551 - Handle `erase_components` on `Either<A, B>` by [@&#8203;alexisfontaine](https://github.com/alexisfontaine) in https://github.com/leptos-rs/leptos/pull/3572 - fix(reactive_stores_macro): `store` attribute signature error message by [@&#8203;DanikVitek](https://github.com/DanikVitek) in https://github.com/leptos-rs/leptos/pull/3567 - feat: add `:capture` flag for events to handle them during capture phase (closes [#&#8203;3457](https://github.com/leptos-rs/leptos/issues/3457)) by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/3575 - Add missing `<fieldset>` attributes by [@&#8203;alexisfontaine](https://github.com/alexisfontaine) in https://github.com/leptos-rs/leptos/pull/3581 - Allows non static lifetimes in component macro by [@&#8203;jvdwrf](https://github.com/jvdwrf) in https://github.com/leptos-rs/leptos/pull/3571 ##### New Contributors - [@&#8203;sstepanchuk](https://github.com/sstepanchuk) made their first contribution in https://github.com/leptos-rs/leptos/pull/3526 - [@&#8203;iradicek](https://github.com/iradicek) made their first contribution in https://github.com/leptos-rs/leptos/pull/3528 - [@&#8203;jvdwrf](https://github.com/jvdwrf) made their first contribution in https://github.com/leptos-rs/leptos/pull/3571 **Full Changelog**: https://github.com/leptos-rs/leptos/compare/v0.7.5...v0.7.7 ### [`v0.7.5`](https://github.com/leptos-rs/leptos/releases/tag/v0.7.5) [Compare Source](https://github.com/leptos-rs/leptos/compare/v0.7.4...v0.7.5) **If you're migrating from 0.6 to 0.7, please see the 0.7.0 release notes [here](https://github.com/leptos-rs/leptos/releases/tag/v0.7.0).** This is a small patch release including primarily bugfixes. ##### What's Changed - chore: work around wasm-bindgen breakage by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/3498 - Add support for custom patch by [@&#8203;mscofield0](https://github.com/mscofield0) in https://github.com/leptos-rs/leptos/pull/3449 - feat: either_or combinator by [@&#8203;geovie](https://github.com/geovie) in https://github.com/leptos-rs/leptos/pull/3417 - (wip): implement unboxing support for recursive store nodes (closes [#&#8203;3491](https://github.com/leptos-rs/leptos/issues/3491)) by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/3493 - fix: correctly handle `ErrorBoundary` through reactive views (closes [#&#8203;3487](https://github.com/leptos-rs/leptos/issues/3487)) by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/3492 - chore: restore reactivity warning at top level of components (closes [#&#8203;3354](https://github.com/leptos-rs/leptos/issues/3354)) by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/3499 - feat: `#[lazy]` macros to support lazy loading and code splitting by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/3477 - chore(ci): add CI for `leptos_0.8` branch by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/3500 - fix: including `node_ref` after `{..}` on arbitrary components by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/3503 - Enhanced docs for reactive_stores by [@&#8203;dcsturman](https://github.com/dcsturman) in https://github.com/leptos-rs/leptos/pull/3508 - Adding a project detailing flexible mocking architecture inspired by hexagonal architecture for leptos app by [@&#8203;sjud](https://github.com/sjud) in https://github.com/leptos-rs/leptos/pull/3342 - issue-3467 - bumping codee version to support rkyv 8 by [@&#8203;thestarmaker](https://github.com/thestarmaker) in https://github.com/leptos-rs/leptos/pull/3504 - docs: Fix README.md & Add MSRV badge by [@&#8203;DanikVitek](https://github.com/DanikVitek) in https://github.com/leptos-rs/leptos/pull/3480 - update workspace dependency versions by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/3506 - feat (`either_of`): Extent API; Implement other iterator methods; Update deps by [@&#8203;DanikVitek](https://github.com/DanikVitek) in https://github.com/leptos-rs/leptos/pull/3478 - AddAnyAttr working with erase_components by [@&#8203;zakstucke](https://github.com/zakstucke) in https://github.com/leptos-rs/leptos/pull/3518 - impl IntoAttributeValue for TextProp by [@&#8203;SleeplessOne1917](https://github.com/SleeplessOne1917) in https://github.com/leptos-rs/leptos/pull/3517 - Fix memo recomputation by [@&#8203;stefnotch](https://github.com/stefnotch) in https://github.com/leptos-rs/leptos/pull/3495 - feat(callback): implement `matches` method for Callback and UnsyncCallback by [@&#8203;geoffreygarrett](https://github.com/geoffreygarrett) in https://github.com/leptos-rs/leptos/pull/3520 - fix: correctly notify descendants and ancestors of store fields (closes [#&#8203;3523](https://github.com/leptos-rs/leptos/issues/3523)) by [@&#8203;gbj](https://github.com/gbj) in https://github.com/leptos-rs/leptos/pull/3524 - feat: allow raw identifiers in Params derive macro by [@&#8203;geovie](https://github.com/geovie) in https://github.com/leptos-rs/leptos/pull/3525 ##### New Contributors - [@&#8203;dcsturman](https://github.com/dcsturman) made their first contribution in https://github.com/leptos-rs/leptos/pull/3508 **Full Changelog**: https://github.com/leptos-rs/leptos/compare/v0.7.4...v0.7.5 </details> <details> <summary>rust-lang/log (log)</summary> ### [`v0.4.29`](https://github.com/rust-lang/log/blob/HEAD/CHANGELOG.md#0429---2025-12-02) [Compare Source](https://github.com/rust-lang/log/compare/0.4.28...0.4.29) ### [`v0.4.28`](https://github.com/rust-lang/log/blob/HEAD/CHANGELOG.md#0428---2025-09-02) [Compare Source](https://github.com/rust-lang/log/compare/0.4.27...0.4.28) ### [`v0.4.27`](https://github.com/rust-lang/log/blob/HEAD/CHANGELOG.md#0427---2025-03-24) [Compare Source](https://github.com/rust-lang/log/compare/0.4.26...0.4.27) ##### What's Changed - A few minor lint fixes by [@&#8203;nyurik](https://github.com/nyurik) in https://github.com/rust-lang/log/pull/671 - Enable clippy support for format-like macros by [@&#8203;nyurik](https://github.com/nyurik) in https://github.com/rust-lang/log/pull/665 - Add an optional logger param by [@&#8203;tisonkun](https://github.com/tisonkun) in https://github.com/rust-lang/log/pull/664 - Pass global logger by value, supplied logger by ref by [@&#8203;KodrAus](https://github.com/KodrAus) in https://github.com/rust-lang/log/pull/673 **Full Changelog**: https://github.com/rust-lang/log/compare/0.4.26...0.4.27 ### [`v0.4.26`](https://github.com/rust-lang/log/blob/HEAD/CHANGELOG.md#0426---2025-02-18) [Compare Source](https://github.com/rust-lang/log/compare/0.4.25...0.4.26) ##### What's Changed - Derive `Clone` for `kv::Value` by [@&#8203;SpriteOvO](https://github.com/SpriteOvO) in https://github.com/rust-lang/log/pull/668 - Add `spdlog-rs` link to crate doc by [@&#8203;SpriteOvO](https://github.com/SpriteOvO) in https://github.com/rust-lang/log/pull/669 **Full Changelog**: https://github.com/rust-lang/log/compare/0.4.25...0.4.26 </details> <details> <summary>seanmonstar/reqwest (reqwest)</summary> ### [`v0.12.24`](https://github.com/seanmonstar/reqwest/blob/HEAD/CHANGELOG.md#v01224) [Compare Source](https://github.com/seanmonstar/reqwest/compare/v0.12.23...v0.12.24) - Refactor cookie handling to an internal middleware. - Refactor internal random generator. - Refactor base64 encoding to reduce a copy. - Documentation updates. ### [`v0.12.23`](https://github.com/seanmonstar/reqwest/blob/HEAD/CHANGELOG.md#v01223) [Compare Source](https://github.com/seanmonstar/reqwest/compare/v0.12.22...v0.12.23) - Add `ClientBuilder::unix_socket(path)` option that will force all requests over that Unix Domain Socket. - Add `ClientBuilder::retry(policy)` and `reqwest::retry::Builder` to configure automatic retries. - Add `ClientBuilder::dns_resolver2()` with more ergonomic argument bounds, allowing more resolver implementations. - Add `http3_*` options to `blocking::ClientBuilder`. - Fix default TCP timeout values to enabled and faster. - Fix SOCKS proxies to default to port 1080 - (wasm) Add cache methods to `RequestBuilder`. ### [`v0.12.22`](https://github.com/seanmonstar/reqwest/blob/HEAD/CHANGELOG.md#v01222) [Compare Source](https://github.com/seanmonstar/reqwest/compare/v0.12.21...v0.12.22) - Fix socks proxies when resolving IPv6 destinations. ### [`v0.12.21`](https://github.com/seanmonstar/reqwest/blob/HEAD/CHANGELOG.md#v01221) [Compare Source](https://github.com/seanmonstar/reqwest/compare/v0.12.20...v0.12.21) - Fix socks proxy to use `socks4a://` instead of `socks4h://`. - Fix `Error::is_timeout()` to check for hyper and IO timeouts too. - Fix request `Error` to again include URLs when possible. - Fix socks connect error to include more context. - (wasm) implement `Default` for `Body`. ### [`v0.12.20`](https://github.com/seanmonstar/reqwest/blob/HEAD/CHANGELOG.md#v01220) [Compare Source](https://github.com/seanmonstar/reqwest/compare/v0.12.19...v0.12.20) - Add `ClientBuilder::tcp_user_timeout(Duration)` option to set `TCP_USER_TIMEOUT`. - Fix proxy headers only using the first matched proxy. - (wasm) Fix re-adding `Error::is_status()`. ### [`v0.12.19`](https://github.com/seanmonstar/reqwest/blob/HEAD/CHANGELOG.md#v01219) [Compare Source](https://github.com/seanmonstar/reqwest/compare/v0.12.18...v0.12.19) - Fix redirect that changes the method to GET should remove payload headers. - Fix redirect to only check the next scheme if the policy action is to follow. - (wasm) Fix compilation error if `cookies` feature is enabled (by the way, it's a noop feature in wasm). ### [`v0.12.18`](https://github.com/seanmonstar/reqwest/blob/HEAD/CHANGELOG.md#v01218) [Compare Source](https://github.com/seanmonstar/reqwest/compare/v0.12.17...v0.12.18) - Fix compilation when `socks` enabled without TLS. ### [`v0.12.17`](https://github.com/seanmonstar/reqwest/blob/HEAD/CHANGELOG.md#v01217) [Compare Source](https://github.com/seanmonstar/reqwest/compare/v0.12.16...v0.12.17) - Fix compilation on macOS. ### [`v0.12.16`](https://github.com/seanmonstar/reqwest/blob/HEAD/CHANGELOG.md#v01216) [Compare Source](https://github.com/seanmonstar/reqwest/compare/v0.12.15...v0.12.16) - Add `ClientBuilder::http3_congestion_bbr()` to enable BBR congestion control. - Add `ClientBuilder::http3_send_grease()` to configure whether to send use QUIC grease. - Add `ClientBuilder::http3_max_field_section_size()` to configure the maximum response headers. - Add `ClientBuilder::tcp_keepalive_interval()` to configure TCP probe interval. - Add `ClientBuilder::tcp_keepalive_retries()` to configure TCP probe count. - Add `Proxy::headers()` to add extra headers that should be sent to a proxy. - Fix `redirect::Policy::limit()` which had an off-by-1 error, allowing 1 more redirect than specified. - Fix HTTP/3 to support streaming request bodies. - (wasm) Fix null bodies when calling `Response::bytes_stream()`. ### [`v0.12.15`](https://github.com/seanmonstar/reqwest/blob/HEAD/CHANGELOG.md#v01215) [Compare Source](https://github.com/seanmonstar/reqwest/compare/v0.12.14...v0.12.15) - Fix Windows to support both `ProxyOverride` and `NO_PROXY`. - Fix http3 to support streaming response bodies. - Fix http3 dependency from public API misuse. ### [`v0.12.14`](https://github.com/seanmonstar/reqwest/blob/HEAD/CHANGELOG.md#v01214) [Compare Source](https://github.com/seanmonstar/reqwest/compare/v0.12.13...v0.12.14) - Fix missing `fetch_mode_no_cors()`, marking as deprecated when not on WASM. ### [`v0.12.13`](https://github.com/seanmonstar/reqwest/blob/HEAD/CHANGELOG.md#v01213) [Compare Source](https://github.com/seanmonstar/reqwest/compare/v0.12.12...v0.12.13) - Add `Form::into_reader()` for blocking `multipart` forms. - Add `Form::into_stream()` for async `multipart` forms. - Add support for SOCKS4a proxies. - Fix decoding responses with multiple zstd frames. - Fix `RequestBuilder::form()` from overwriting a previously set `Content-Type` header, like the other builder methods. - Fix cloning of request timeout in `blocking::Request`. - Fix http3 synchronization of connection creation, reducing unneccesary extra connections. - Fix Windows system proxy to use `ProxyOverride` as a `NO_PROXY` value. - Fix blocking read to correctly reserve and zero read buffer. - (wasm) Add support for request timeouts. - (wasm) Fix `Error::is_timeout()` to return true when from a request timeout. </details> <details> <summary>serde-rs/json (serde_json)</summary> ### [`v1.0.145`](https://github.com/serde-rs/json/releases/tag/v1.0.145) [Compare Source](https://github.com/serde-rs/json/compare/v1.0.144...v1.0.145) - Raise serde version requirement to >=1.0.220 ### [`v1.0.144`](https://github.com/serde-rs/json/releases/tag/v1.0.144) [Compare Source](https://github.com/serde-rs/json/compare/v1.0.143...v1.0.144) - Switch serde dependency to serde_core ([#&#8203;1285](https://github.com/serde-rs/json/issues/1285)) ### [`v1.0.143`](https://github.com/serde-rs/json/releases/tag/v1.0.143) [Compare Source](https://github.com/serde-rs/json/compare/v1.0.142...v1.0.143) - Implement Clone and Debug for serde_json::Map iterators ([#&#8203;1264](https://github.com/serde-rs/json/issues/1264), thanks [@&#8203;xlambein](https://github.com/xlambein)) - Implement Default for CompactFormatter ([#&#8203;1268](https://github.com/serde-rs/json/issues/1268), thanks [@&#8203;SOF3](https://github.com/SOF3)) - Implement FromStr for serde_json::Map ([#&#8203;1271](https://github.com/serde-rs/json/issues/1271), thanks [@&#8203;mickvangelderen](https://github.com/mickvangelderen)) ### [`v1.0.142`](https://github.com/serde-rs/json/releases/tag/v1.0.142) [Compare Source](https://github.com/serde-rs/json/compare/v1.0.141...v1.0.142) - impl Default for \&Value ([#&#8203;1265](https://github.com/serde-rs/json/issues/1265), thanks [@&#8203;aatifsyed](https://github.com/aatifsyed)) ### [`v1.0.141`](https://github.com/serde-rs/json/releases/tag/v1.0.141) [Compare Source](https://github.com/serde-rs/json/compare/v1.0.140...v1.0.141) - Optimize string escaping during serialization ([#&#8203;1273](https://github.com/serde-rs/json/issues/1273), thanks [@&#8203;conradludgate](https://github.com/conradludgate)) ### [`v1.0.140`](https://github.com/serde-rs/json/releases/tag/v1.0.140) [Compare Source](https://github.com/serde-rs/json/compare/v1.0.139...v1.0.140) - Documentation improvements ### [`v1.0.139`](https://github.com/serde-rs/json/releases/tag/v1.0.139) [Compare Source](https://github.com/serde-rs/json/compare/v1.0.138...v1.0.139) - Documentation improvements ### [`v1.0.138`](https://github.com/serde-rs/json/releases/tag/v1.0.138) [Compare Source](https://github.com/serde-rs/json/compare/v1.0.137...v1.0.138) - Documentation improvements ### [`v1.0.137`](https://github.com/serde-rs/json/releases/tag/v1.0.137) [Compare Source](https://github.com/serde-rs/json/compare/v1.0.136...v1.0.137) - Turn on "float_roundtrip" and "unbounded_depth" features for serde_json in play.rust-lang.org ([#&#8203;1231](https://github.com/serde-rs/json/issues/1231)) </details> <details> <summary>borntyping/rust-simple_logger (simple_logger)</summary> ### [`v5.1.0`](https://github.com/borntyping/rust-simple_logger/releases/tag/v5.1.0) [Compare Source](https://github.com/borntyping/rust-simple_logger/compare/v5.0.0...v5.1.0) - Added documentation and an example for `init_with_env` (closes [#&#8203;96](https://github.com/borntyping/rust-simple_logger/issues/96)). - Updated minimum versions of dependencies (closes [#&#8203;74](https://github.com/borntyping/rust-simple_logger/issues/74)). **Full Changelog**: https://github.com/borntyping/rust-simple_logger/compare/v5.0.0...v5.1.0 </details> <details> <summary>dtolnay/thiserror (thiserror)</summary> ### [`v2.0.17`](https://github.com/dtolnay/thiserror/releases/tag/2.0.17) [Compare Source](https://github.com/dtolnay/thiserror/compare/2.0.16...2.0.17) - Use differently named \__private module per patch release ([#&#8203;434](https://github.com/dtolnay/thiserror/issues/434)) ### [`v2.0.16`](https://github.com/dtolnay/thiserror/releases/tag/2.0.16) [Compare Source](https://github.com/dtolnay/thiserror/compare/2.0.15...2.0.16) - Add to "no-std" crates.io category ([#&#8203;429](https://github.com/dtolnay/thiserror/issues/429)) ### [`v2.0.15`](https://github.com/dtolnay/thiserror/releases/tag/2.0.15) [Compare Source](https://github.com/dtolnay/thiserror/compare/2.0.14...2.0.15) - Prevent `Error::provide` API becoming unavailable from a future new compiler lint ([#&#8203;427](https://github.com/dtolnay/thiserror/issues/427)) ### [`v2.0.14`](https://github.com/dtolnay/thiserror/releases/tag/2.0.14) [Compare Source](https://github.com/dtolnay/thiserror/compare/2.0.13...2.0.14) - Allow build-script cleanup failure with NFSv3 output directory to be non-fatal ([#&#8203;426](https://github.com/dtolnay/thiserror/issues/426)) ### [`v2.0.13`](https://github.com/dtolnay/thiserror/releases/tag/2.0.13) [Compare Source](https://github.com/dtolnay/thiserror/compare/2.0.12...2.0.13) - Documentation improvements ### [`v2.0.12`](https://github.com/dtolnay/thiserror/releases/tag/2.0.12) [Compare Source](https://github.com/dtolnay/thiserror/compare/2.0.11...2.0.12) - Prevent elidable_lifetime_names pedantic clippy lint in generated impl ([#&#8203;413](https://github.com/dtolnay/thiserror/issues/413)) </details> <details> <summary>tokio-rs/tokio (tokio)</summary> ### [`v1.48.0`](https://github.com/tokio-rs/tokio/releases/tag/tokio-1.48.0): Tokio v1.48.0 [Compare Source](https://github.com/tokio-rs/tokio/compare/tokio-1.47.2...tokio-1.48.0) ### 1.48.0 (October 14th, 2025) The MSRV is increased to 1.71. ##### Added - fs: add `File::max_buf_size` ([#&#8203;7594]) - io: export `Chain` of `AsyncReadExt::chain` ([#&#8203;7599]) - net: add `SocketAddr::as_abstract_name` ([#&#8203;7491]) - net: add `TcpStream::quickack` and `TcpStream::set_quickack` ([#&#8203;7490]) - net: implement `AsRef<Self>` for `TcpStream` and `UnixStream` ([#&#8203;7573]) - task: add `LocalKey::try_get` ([#&#8203;7666]) - task: implement `Ord` for `task::Id` ([#&#8203;7530]) ##### Changed - deps: bump windows-sys to version 0.61 ([#&#8203;7645]) - fs: preserve `max_buf_size` when cloning a `File` ([#&#8203;7593]) - macros: suppress `clippy::unwrap_in_result` in `#[tokio::main]` ([#&#8203;7651]) - net: remove `PollEvented` noise from Debug formats ([#&#8203;7675]) - process: upgrade `Command::spawn_with` to use `FnOnce` ([#&#8203;7511]) - sync: remove inner mutex in `SetOnce` ([#&#8203;7554]) - sync: use `UnsafeCell::get_mut` in `Mutex::get_mut` and `RwLock::get_mut` ([#&#8203;7569]) - time: reduce the generated code size of `Timeout<T>::poll` ([#&#8203;7535]) ##### Fixed - macros: fix hygiene issue in `join!` and `try_join!` ([#&#8203;7638]) - net: fix copy/paste errors in udp peek methods ([#&#8203;7604]) - process: fix error when runtime is shut down on nightly-2025-10-12 ([#&#8203;7672]) - runtime: use release ordering in `wake_by_ref()` even if already woken ([#&#8203;7622]) - sync: close the `broadcast::Sender` in `broadcast::Sender::new()` ([#&#8203;7629]) - sync: fix implementation of unused `RwLock::try_*` methods ([#&#8203;7587]) ##### Unstable - tokio: use cargo features instead of `--cfg` flags for `taskdump` and `io_uring` ([#&#8203;7655], [#&#8203;7621]) - fs: support `io_uring` in `fs::write` ([#&#8203;7567]) - fs: support `io_uring` with `File::open()` ([#&#8203;7617]) - fs: support `io_uring` with `OpenOptions` ([#&#8203;7321]) - macros: add `local` runtime flavor ([#&#8203;7375], [#&#8203;7597]) ##### Documented - io: clarify the zero capacity case of `AsyncRead::poll_read` ([#&#8203;7580]) - io: fix typos in the docs of `AsyncFd` readiness guards ([#&#8203;7583]) - net: clarify socket gets closed on drop ([#&#8203;7526]) - net: clarify the behavior of `UCred::pid()` on Cygwin ([#&#8203;7611]) - net: clarify the supported platform of `set_reuseport()` and `reuseport()` ([#&#8203;7628]) - net: qualify that `SO_REUSEADDR` is only set on Unix ([#&#8203;7533]) - runtime: add guide for choosing between runtime types ([#&#8203;7635]) - runtime: clarify the behavior of `Handle::block_on` ([#&#8203;7665]) - runtime: clarify the edge case of `Builder::global_queue_interval()` ([#&#8203;7605]) - sync: clarify bounded channel panic behavior ([#&#8203;7641]) - sync: clarify the behavior of `tokio::sync::watch::Receiver` ([#&#8203;7584]) - sync: document cancel safety on `SetOnce::wait` ([#&#8203;7506]) - sync: fix the docs of `parking_lot` feature flag ([#&#8203;7663]) - sync: improve the docs of `UnboundedSender::send` ([#&#8203;7661]) - sync: improve the docs of `sync::watch` ([#&#8203;7601]) - sync: reword allocation failure paragraph in broadcast docs ([#&#8203;7595]) - task: clarify the behavior of several `spawn_local` methods ([#&#8203;7669]) - task: clarify the task ID reuse guarantees ([#&#8203;7577]) - task: improve the example of `poll_proceed` ([#&#8203;7586]) [#&#8203;7321]: https://github.com/tokio-rs/tokio/pull/7321 [#&#8203;7375]: https://github.com/tokio-rs/tokio/pull/7375 [#&#8203;7490]: https://github.com/tokio-rs/tokio/pull/7490 [#&#8203;7491]: https://github.com/tokio-rs/tokio/pull/7491 [#&#8203;7494]: https://github.com/tokio-rs/tokio/pull/7494 [#&#8203;7506]: https://github.com/tokio-rs/tokio/pull/7506 [#&#8203;7511]: https://github.com/tokio-rs/tokio/pull/7511 [#&#8203;7526]: https://github.com/tokio-rs/tokio/pull/7526 [#&#8203;7530]: https://github.com/tokio-rs/tokio/pull/7530 [#&#8203;7533]: https://github.com/tokio-rs/tokio/pull/7533 [#&#8203;7535]: https://github.com/tokio-rs/tokio/pull/7535 [#&#8203;7554]: https://github.com/tokio-rs/tokio/pull/7554 [#&#8203;7567]: https://github.com/tokio-rs/tokio/pull/7567 [#&#8203;7569]: https://github.com/tokio-rs/tokio/pull/7569 [#&#8203;7573]: https://github.com/tokio-rs/tokio/pull/7573 [#&#8203;7577]: https://github.com/tokio-rs/tokio/pull/7577 [#&#8203;7580]: https://github.com/tokio-rs/tokio/pull/7580 [#&#8203;7583]: https://github.com/tokio-rs/tokio/pull/7583 [#&#8203;7584]: https://github.com/tokio-rs/tokio/pull/7584 [#&#8203;7586]: https://github.com/tokio-rs/tokio/pull/7586 [#&#8203;7587]: https://github.com/tokio-rs/tokio/pull/7587 [#&#8203;7593]: https://github.com/tokio-rs/tokio/pull/7593 [#&#8203;7594]: https://github.com/tokio-rs/tokio/pull/7594 [#&#8203;7595]: https://github.com/tokio-rs/tokio/pull/7595 [#&#8203;7597]: https://github.com/tokio-rs/tokio/pull/7597 [#&#8203;7599]: https://github.com/tokio-rs/tokio/pull/7599 [#&#8203;7601]: https://github.com/tokio-rs/tokio/pull/7601 [#&#8203;7604]: https://github.com/tokio-rs/tokio/pull/7604 [#&#8203;7605]: https://github.com/tokio-rs/tokio/pull/7605 [#&#8203;7611]: https://github.com/tokio-rs/tokio/pull/7611 [#&#8203;7617]: https://github.com/tokio-rs/tokio/pull/7617 [#&#8203;7621]: https://github.com/tokio-rs/tokio/pull/7621 [#&#8203;7622]: https://github.com/tokio-rs/tokio/pull/7622 [#&#8203;7628]: https://github.com/tokio-rs/tokio/pull/7628 [#&#8203;7629]: https://github.com/tokio-rs/tokio/pull/7629 [#&#8203;7635]: https://github.com/tokio-rs/tokio/pull/7635 [#&#8203;7638]: https://github.com/tokio-rs/tokio/pull/7638 [#&#8203;7641]: https://github.com/tokio-rs/tokio/pull/7641 [#&#8203;7645]: https://github.com/tokio-rs/tokio/pull/7645 [#&#8203;7651]: https://github.com/tokio-rs/tokio/pull/7651 [#&#8203;7655]: https://github.com/tokio-rs/tokio/pull/7655 [#&#8203;7661]: https://github.com/tokio-rs/tokio/pull/7661 [#&#8203;7663]: https://github.com/tokio-rs/tokio/pull/7663 [#&#8203;7665]: https://github.com/tokio-rs/tokio/pull/7665 [#&#8203;7666]: https://github.com/tokio-rs/tokio/pull/7666 [#&#8203;7669]: https://github.com/tokio-rs/tokio/pull/7669 [#&#8203;7672]: https://github.com/tokio-rs/tokio/pull/7672 [#&#8203;7675]: https://github.com/tokio-rs/tokio/pull/7675 ### [`v1.47.2`](https://github.com/tokio-rs/tokio/compare/tokio-1.47.1...tokio-1.47.2) [Compare Source](https://github.com/tokio-rs/tokio/compare/tokio-1.47.1...tokio-1.47.2) ### [`v1.47.1`](https://github.com/tokio-rs/tokio/releases/tag/tokio-1.47.1): Tokio v1.47.1 [Compare Source](https://github.com/tokio-rs/tokio/compare/tokio-1.47.0...tokio-1.47.1) ### 1.47.1 (August 1st, 2025) ##### Fixed - process: fix panic from spurious pidfd wakeup ([#&#8203;7494]) - sync: fix broken link of Python `asyncio.Event` in `SetOnce` docs ([#&#8203;7485]) [#&#8203;7485]: https://github.com/tokio-rs/tokio/pull/7485 [#&#8203;7494]: https://github.com/tokio-rs/tokio/pull/7494 ### [`v1.47.0`](https://github.com/tokio-rs/tokio/releases/tag/tokio-1.47.0): Tokio v1.47.0 [Compare Source](https://github.com/tokio-rs/tokio/compare/tokio-1.46.1...tokio-1.47.0) ### 1.47.0 (July 25th, 2025) This release adds `poll_proceed` and `cooperative` to the `coop` module for cooperative scheduling, adds `SetOnce` to the `sync` module which provides similar functionality to \[`std::sync::OnceLock`], and adds a new method `sync::Notify::notified_owned()` which returns an `OwnedNotified` without a lifetime parameter. #### Added - coop: add `cooperative` and `poll_proceed` ([#&#8203;7405]) - sync: add `SetOnce` ([#&#8203;7418]) - sync: add `sync::Notify::notified_owned()` ([#&#8203;7465]) #### Changed - deps: upgrade windows-sys 0.52 → 0.59 (\[[#&#8203;7117](https://github.com/tokio-rs/tokio/issues/7117)]) - deps: update to socket2 v0.6 (\[[#&#8203;7443](https://github.com/tokio-rs/tokio/issues/7443)]) - sync: improve `AtomicWaker::wake` performance ([#&#8203;7450]) #### Documented - metrics: fix listed feature requirements for some metrics ([#&#8203;7449]) - runtime: improve safety comments of `Readiness<'_>` ([#&#8203;7415]) [#&#8203;7405]: https://github.com/tokio-rs/tokio/pull/7405 [#&#8203;7415]: https://github.com/tokio-rs/tokio/pull/7415 [#&#8203;7418]: https://github.com/tokio-rs/tokio/pull/7418 [#&#8203;7449]: https://github.com/tokio-rs/tokio/pull/7449 [#&#8203;7450]: https://github.com/tokio-rs/tokio/pull/7450 [#&#8203;7465]: https://github.com/tokio-rs/tokio/pull/7465 ### [`v1.46.1`](https://github.com/tokio-rs/tokio/releases/tag/tokio-1.46.1): Tokio v1.46.1 [Compare Source](https://github.com/tokio-rs/tokio/compare/tokio-1.46.0...tokio-1.46.1) ### 1.46.1 (July 4th, 2025) This release fixes incorrect spawn locations in runtime task hooks for tasks spawned using `tokio::spawn` rather than `Runtime::spawn`. This issue only effected the spawn location in `TaskMeta::spawned_at`, and did not effect task locations in Tracing events. #### Unstable - runtime: add `TaskMeta::spawn_location` tracking where a task was spawned ([#&#8203;7440]) [#&#8203;7440]: https://github.com/tokio-rs/tokio/pull/7440 ### [`v1.46.0`](https://github.com/tokio-rs/tokio/releases/tag/tokio-1.46.0): Tokio v1.46.0 [Compare Source](https://github.com/tokio-rs/tokio/compare/tokio-1.45.1...tokio-1.46.0) ### 1.46.0 (July 2nd, 2025) ##### Fixed - net: fixed `TcpStream::shutdown` incorrectly returning an error on macOS ([#&#8203;7290]) #### Added - sync: `mpsc::OwnedPermit::{same_channel, same_channel_as_sender}` methods ([#&#8203;7389]) - macros: `biased` option for `join!` and `try_join!`, similar to `select!` ([#&#8203;7307]) - net: support for cygwin ([#&#8203;7393]) - net: support `pope::OpenOptions::read_write` on Android ([#&#8203;7426]) - net: add `Clone` implementation for `net::unix::SocketAddr` ([#&#8203;7422]) #### Changed - runtime: eliminate unnecessary lfence while operating on `queue::Local<T>` ([#&#8203;7340]) - task: disallow blocking in `LocalSet::{poll,drop}` ([#&#8203;7372]) #### Unstable - runtime: add `TaskMeta::spawn_location` tracking where a task was spawned ([#&#8203;7417]) - runtime: removed borrow from `LocalOptions` parameter to `runtime::Builder::build_local` ([#&#8203;7346]) #### Documented - io: clarify behavior of seeking when `start_seek` is not used ([#&#8203;7366]) - io: document cancellation safety of `AsyncWriteExt::flush` ([#&#8203;7364]) - net: fix docs for `recv_buffer_size` method ([#&#8203;7336]) - net: fix broken link of `RawFd` in `TcpSocket` docs ([#&#8203;7416]) - net: update `AsRawFd` doc link to current Rust stdlib location ([#&#8203;7429]) - readme: fix double period in reactor description ([#&#8203;7363]) - runtime: add doc note that `on_*_task_poll` is unstable ([#&#8203;7311]) - sync: update broadcast docs on allocation failure ([#&#8203;7352]) - time: add a missing panic scenario of `time::advance` ([#&#8203;7394]) [#&#8203;7290]: https://github.com/tokio-rs/tokio/pull/7290 [#&#8203;7307]: https://github.com/tokio-rs/tokio/pull/7307 [#&#8203;7311]: https://github.com/tokio-rs/tokio/pull/7311 [#&#8203;7336]: https://github.com/tokio-rs/tokio/pull/7336 [#&#8203;7340]: https://github.com/tokio-rs/tokio/pull/7340 [#&#8203;7346]: https://github.com/tokio-rs/tokio/pull/7346 [#&#8203;7352]: https://github.com/tokio-rs/tokio/pull/7352 [#&#8203;7363]: https://github.com/tokio-rs/tokio/pull/7363 [#&#8203;7364]: https://github.com/tokio-rs/tokio/pull/7364 [#&#8203;7366]: https://github.com/tokio-rs/tokio/pull/7366 [#&#8203;7372]: https://github.com/tokio-rs/tokio/pull/7372 [#&#8203;7389]: https://github.com/tokio-rs/tokio/pull/7389 [#&#8203;7393]: https://github.com/tokio-rs/tokio/pull/7393 [#&#8203;7394]: https://github.com/tokio-rs/tokio/pull/7394 [#&#8203;7416]: https://github.com/tokio-rs/tokio/pull/7416 [#&#8203;7422]: https://github.com/tokio-rs/tokio/pull/7422 [#&#8203;7426]: https://github.com/tokio-rs/tokio/pull/7426 [#&#8203;7429]: https://github.com/tokio-rs/tokio/pull/7429 [#&#8203;7417]: https://github.com/tokio-rs/tokio/pull/7417 ### [`v1.45.1`](https://github.com/tokio-rs/tokio/releases/tag/tokio-1.45.1): Tokio v1.45.1 [Compare Source](https://github.com/tokio-rs/tokio/compare/tokio-1.45.0...tokio-1.45.1) ### 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 - Disable time-based metrics on wasm32-unknown-unknown ([#&#8203;7322]) [#&#8203;7322]: https://github.com/tokio-rs/tokio/pull/7322 ### [`v1.45.0`](https://github.com/tokio-rs/tokio/releases/tag/tokio-1.45.0): Tokio v1.45.0 [Compare Source](https://github.com/tokio-rs/tokio/compare/tokio-1.44.2...tokio-1.45.0) ##### Added - metrics: stabilize `worker_total_busy_duration`, `worker_park_count`, and `worker_unpark_count` ([#&#8203;6899], [#&#8203;7276]) - process: add `Command::spawn_with` ([#&#8203;7249]) ##### Changed - io: do not require `Unpin` for some trait impls ([#&#8203;7204]) - rt: mark `runtime::Handle` as unwind safe ([#&#8203;7230]) - time: revert internal sharding implementation ([#&#8203;7226]) ##### Unstable - rt: remove alt multi-threaded runtime ([#&#8203;7275]) [#&#8203;6899]: https://github.com/tokio-rs/tokio/pull/6899 [#&#8203;7276]: https://github.com/tokio-rs/tokio/pull/7276 [#&#8203;7249]: https://github.com/tokio-rs/tokio/pull/7249 [#&#8203;7204]: https://github.com/tokio-rs/tokio/pull/7204 [#&#8203;7230]: https://github.com/tokio-rs/tokio/pull/7230 [#&#8203;7226]: https://github.com/tokio-rs/tokio/pull/7226 [#&#8203;7275]: https://github.com/tokio-rs/tokio/pull/7275 ### [`v1.44.2`](https://github.com/tokio-rs/tokio/releases/tag/tokio-1.44.2): Tokio v1.44.2 [Compare Source](https://github.com/tokio-rs/tokio/compare/tokio-1.44.1...tokio-1.44.2) This release fixes a soundness issue in the broadcast channel. The channel accepts values that are `Send` but `!Sync`. Previously, the channel called `clone()` 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 - sync: synchronize `clone()` call in broadcast channel ([#&#8203;7232]) [#&#8203;7232]: https://github.com/tokio-rs/tokio/pull/7232 ### [`v1.44.1`](https://github.com/tokio-rs/tokio/releases/tag/tokio-1.44.1): Tokio v1.44.1 [Compare Source](https://github.com/tokio-rs/tokio/compare/tokio-1.44.0...tokio-1.44.1) ### 1.44.1 (March 13th, 2025) ##### Fixed - rt: skip defer queue in `block_in_place` context ([#&#8203;7216]) [#&#8203;7216]: https://github.com/tokio-rs/tokio/pull/7216 ### [`v1.44.0`](https://github.com/tokio-rs/tokio/releases/tag/tokio-1.44.0): Tokio v1.44.0 [Compare Source](https://github.com/tokio-rs/tokio/compare/tokio-1.43.3...tokio-1.44.0) ### 1.44.0 (March 7th, 2025) This release changes the `from_std` method 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 [#&#8203;7172]. ##### Added - coop: add `task::coop` module ([#&#8203;7116]) - process: add `Command::get_kill_on_drop()` ([#&#8203;7086]) - sync: add `broadcast::Sender::closed` ([#&#8203;6685], [#&#8203;7090]) - sync: add `broadcast::WeakSender` ([#&#8203;7100]) - sync: add `oneshot::Receiver::is_empty()` ([#&#8203;7153]) - sync: add `oneshot::Receiver::is_terminated()` ([#&#8203;7152]) ##### Fixed - fs: empty reads on `File` should not start a background read ([#&#8203;7139]) - process: calling `start_kill` on exited child should not fail ([#&#8203;7160]) - signal: fix `CTRL_CLOSE`, `CTRL_LOGOFF`, `CTRL_SHUTDOWN` on windows ([#&#8203;7122]) - sync: properly handle panic during mpsc drop ([#&#8203;7094]) ##### Changes - runtime: clean up magic number in registration set ([#&#8203;7112]) - coop: make coop yield using waker defer strategy ([#&#8203;7185]) - macros: make `select!` budget-aware ([#&#8203;7164]) - net: panic when passing a blocking socket to `from_std` ([#&#8203;7166]) - io: clean up buffer casts ([#&#8203;7142]) ##### Changes to unstable APIs - rt: add before and after task poll callbacks ([#&#8203;7120]) - tracing: make the task tracing API unstable public ([#&#8203;6972]) ##### Documented - docs: fix nesting of sections in top-level docs ([#&#8203;7159]) - fs: rename symlink and hardlink parameter names ([#&#8203;7143]) - io: swap reader/writer in simplex doc test ([#&#8203;7176]) - macros: docs about `select!` alternatives ([#&#8203;7110]) - net: rename the argument for `send_to` ([#&#8203;7146]) - process: add example for reading `Child` stdout ([#&#8203;7141]) - process: clarify `Child::kill` behavior ([#&#8203;7162]) - process: fix grammar of the `ChildStdin` struct doc comment ([#&#8203;7192]) - runtime: consistently use `worker_threads` instead of `core_threads` ([#&#8203;7186]) [#&#8203;6685]: https://github.com/tokio-rs/tokio/pull/6685 [#&#8203;6972]: https://github.com/tokio-rs/tokio/pull/6972 [#&#8203;7086]: https://github.com/tokio-rs/tokio/pull/7086 [#&#8203;7090]: https://github.com/tokio-rs/tokio/pull/7090 [#&#8203;7094]: https://github.com/tokio-rs/tokio/pull/7094 [#&#8203;7100]: https://github.com/tokio-rs/tokio/pull/7100 [#&#8203;7110]: https://github.com/tokio-rs/tokio/pull/7110 [#&#8203;7112]: https://github.com/tokio-rs/tokio/pull/7112 [#&#8203;7116]: https://github.com/tokio-rs/tokio/pull/7116 [#&#8203;7120]: https://github.com/tokio-rs/tokio/pull/7120 [#&#8203;7122]: https://github.com/tokio-rs/tokio/pull/7122 [#&#8203;7139]: https://github.com/tokio-rs/tokio/pull/7139 [#&#8203;7141]: https://github.com/tokio-rs/tokio/pull/7141 [#&#8203;7142]: https://github.com/tokio-rs/tokio/pull/7142 [#&#8203;7143]: https://github.com/tokio-rs/tokio/pull/7143 [#&#8203;7146]: https://github.com/tokio-rs/tokio/pull/7146 [#&#8203;7152]: https://github.com/tokio-rs/tokio/pull/7152 [#&#8203;7153]: https://github.com/tokio-rs/tokio/pull/7153 [#&#8203;7159]: https://github.com/tokio-rs/tokio/pull/7159 [#&#8203;7160]: https://github.com/tokio-rs/tokio/pull/7160 [#&#8203;7162]: https://github.com/tokio-rs/tokio/pull/7162 [#&#8203;7164]: https://github.com/tokio-rs/tokio/pull/7164 [#&#8203;7166]: https://github.com/tokio-rs/tokio/pull/7166 [#&#8203;7172]: https://github.com/tokio-rs/tokio/pull/7172 [#&#8203;7176]: https://github.com/tokio-rs/tokio/pull/7176 [#&#8203;7185]: https://github.com/tokio-rs/tokio/pull/7185 [#&#8203;7186]: https://github.com/tokio-rs/tokio/pull/7186 [#&#8203;7192]: https://github.com/tokio-rs/tokio/pull/7192 ### [`v1.43.3`](https://github.com/tokio-rs/tokio/compare/tokio-1.43.2...tokio-1.43.3) [Compare Source](https://github.com/tokio-rs/tokio/compare/tokio-1.43.2...tokio-1.43.3) ### [`v1.43.2`](https://github.com/tokio-rs/tokio/releases/tag/tokio-1.43.2): Tokio v1.43.2 [Compare Source](https://github.com/tokio-rs/tokio/compare/tokio-1.43.1...tokio-1.43.2) ### 1.43.2 (August 1st, 2025) ##### Fixed - process: fix panic from spurious pidfd wakeup ([#&#8203;7494]) [#&#8203;7494]: https://github.com/tokio-rs/tokio/pull/7494 ### [`v1.43.1`](https://github.com/tokio-rs/tokio/compare/tokio-1.43.0...tokio-1.43.1) [Compare Source](https://github.com/tokio-rs/tokio/compare/tokio-1.43.0...tokio-1.43.1) </details> <details> <summary>tower-rs/tower-http (tower-http)</summary> ### [`v0.6.7`](https://github.com/tower-rs/tower-http/releases/tag/tower-http-0.6.7) [Compare Source](https://github.com/tower-rs/tower-http/compare/tower-http-0.6.6...tower-http-0.6.7) #### Added - `TimeoutLayer::with_status_code(status)` to define the status code returned when timeout is reached. ([#&#8203;599]) #### Deprecated - `auth::require_authorization` is too basic for real-world. ([#&#8203;591]) - `TimeoutLayer::new()` should be replaced with `TimeoutLayer::with_status_code()`. (Previously was `StatusCode::REQUEST_TIMEOUT`) ([#&#8203;599]) #### Fixed - `on_eos` is now called even for successful responses. ([#&#8203;580]) - `ServeDir`: call fallback when filename is invalid ([#&#8203;586]) - `decompression` will not fail when body is empty ([#&#8203;618]) [#&#8203;580]: https://github.com/tower-rs/tower-http/pull/580 [#&#8203;586]: https://github.com/tower-rs/tower-http/pull/586 [#&#8203;591]: https://github.com/tower-rs/tower-http/pull/591 [#&#8203;599]: https://github.com/tower-rs/tower-http/pull/599 [#&#8203;618]: https://github.com/tower-rs/tower-http/pull/618 #### New Contributors - [@&#8203;mladedav](https://github.com/mladedav) made their first contribution in https://github.com/tower-rs/tower-http/pull/580 - [@&#8203;aryaveersr](https://github.com/aryaveersr) made their first contribution in https://github.com/tower-rs/tower-http/pull/586 - [@&#8203;soerenmeier](https://github.com/soerenmeier) made their first contribution in https://github.com/tower-rs/tower-http/pull/588 - [@&#8203;gjabell](https://github.com/gjabell) made their first contribution in https://github.com/tower-rs/tower-http/pull/591 - [@&#8203;FalkWoldmann](https://github.com/FalkWoldmann) made their first contribution in https://github.com/tower-rs/tower-http/pull/599 - [@&#8203;ducaale](https://github.com/ducaale) made their first contribution in https://github.com/tower-rs/tower-http/pull/618 **Full Changelog**: https://github.com/tower-rs/tower-http/compare/tower-http-0.6.6...tower-http-0.6.7 ### [`v0.6.6`](https://github.com/tower-rs/tower-http/releases/tag/tower-http-0.6.6) [Compare Source](https://github.com/tower-rs/tower-http/compare/tower-http-0.6.5...tower-http-0.6.6) #### Fixed - compression: fix panic when looking in vary header ([#&#8203;578]) [#&#8203;578]: https://github.com/tower-rs/tower-http/pull/578 #### New Contributors - [@&#8203;sulami](https://github.com/sulami) made their first contribution in https://github.com/tower-rs/tower-http/pull/578 **Full Changelog**: https://github.com/tower-rs/tower-http/compare/tower-http-0.6.5...tower-http-0.6.6 ### [`v0.6.5`](https://github.com/tower-rs/tower-http/releases/tag/tower-http-0.6.5) [Compare Source](https://github.com/tower-rs/tower-http/compare/tower-http-0.6.4...tower-http-0.6.5) #### Added - normalize_path: add `append_trailing_slash()` mode ([#&#8203;547]) #### Fixed - redirect: remove payload headers if redirect changes method to GET ([#&#8203;575]) - compression: avoid setting `vary: accept-encoding` if already set ([#&#8203;572]) [#&#8203;547]: https://github.com/tower-rs/tower-http/pull/547 [#&#8203;572]: https://github.com/tower-rs/tower-http/pull/572 [#&#8203;575]: https://github.com/tower-rs/tower-http/pull/575 #### New Contributors - [@&#8203;daalfox](https://github.com/daalfox) made their first contribution in https://github.com/tower-rs/tower-http/pull/547 - [@&#8203;mherrerarendon](https://github.com/mherrerarendon) made their first contribution in https://github.com/tower-rs/tower-http/pull/574 - [@&#8203;linyihai](https://github.com/linyihai) made their first contribution in https://github.com/tower-rs/tower-http/pull/575 **Full Changelog**: https://github.com/tower-rs/tower-http/compare/tower-http-0.6.4...tower-http-0.6.5 ### [`v0.6.4`](https://github.com/tower-rs/tower-http/releases/tag/tower-http-0.6.4): tower-http 0.6.4 [Compare Source](https://github.com/tower-rs/tower-http/compare/tower-http-0.6.3...tower-http-0.6.4) #### Added - decompression: Support HTTP responses containing multiple ZSTD frames ([#&#8203;548]) - The `ServiceExt` trait for chaining layers onto an arbitrary http service just like `ServiceBuilderExt` allows for `ServiceBuilder` ([#&#8203;563]) #### Fixed - Remove unnecessary trait bounds on `S::Error` for `Service` impls of `RequestBodyTimeout<S>` and `ResponseBodyTimeout<S>` ([#&#8203;533]) - compression: Respect `is_end_stream` ([#&#8203;535]) - Fix a rare panic in `fs::ServeDir` ([#&#8203;553]) - Fix invalid `content-lenght` of 1 in response to range requests to empty files ([#&#8203;556]) - In `AsyncRequireAuthorization`, use the original inner service after it is ready, instead of using a clone ([#&#8203;561]) [#&#8203;533]: https://github.com/tower-rs/tower-http/pull/533 [#&#8203;535]: https://github.com/tower-rs/tower-http/pull/535 [#&#8203;548]: https://github.com/tower-rs/tower-http/pull/548 [#&#8203;553]: https://github.com/tower-rs/tower-http/pull/556 [#&#8203;556]: https://github.com/tower-rs/tower-http/pull/556 [#&#8203;561]: https://github.com/tower-rs/tower-http/pull/561 [#&#8203;563]: https://github.com/tower-rs/tower-http/pull/563 ### [`v0.6.3`](https://github.com/tower-rs/tower-http/releases/tag/tower-http-0.6.3): tower-http 0.6.3 [Compare Source](https://github.com/tower-rs/tower-http/compare/tower-http-0.6.2...tower-http-0.6.3) *This release was yanked because its definition of `ServiceExt` was quite unhelpful, in a way that's very unlikely that anybody would start depending on within the small timeframe before this was yanked, but that was technically breaking to change.* </details> <details> <summary>uuid-rs/uuid (uuid)</summary> ### [`v1.19.0`](https://github.com/uuid-rs/uuid/releases/tag/v1.19.0) [Compare Source](https://github.com/uuid-rs/uuid/compare/v1.18.1...v1.19.0) #### What's Changed - Switch serde dependency to serde_core by [@&#8203;paolobarbolini](https://github.com/paolobarbolini) in https://github.com/uuid-rs/uuid/pull/843 - Upgrade to 2021 edition and fix most clippy warnings by [@&#8203;paolobarbolini](https://github.com/paolobarbolini) in https://github.com/uuid-rs/uuid/pull/848 - Prepare for 1.19.0 release by [@&#8203;KodrAus](https://github.com/KodrAus) in https://github.com/uuid-rs/uuid/pull/849 **Full Changelog**: https://github.com/uuid-rs/uuid/compare/v1.18.1...v1.19.0 ### [`v1.18.1`](https://github.com/uuid-rs/uuid/releases/tag/v1.18.1) [Compare Source](https://github.com/uuid-rs/uuid/compare/v1.18.0...v1.18.1) #### What's Changed - Unsafe cleanup by [@&#8203;KodrAus](https://github.com/KodrAus) in https://github.com/uuid-rs/uuid/pull/841 - Prepare for 1.18.1 release by [@&#8203;KodrAus](https://github.com/KodrAus) in https://github.com/uuid-rs/uuid/pull/842 **Full Changelog**: https://github.com/uuid-rs/uuid/compare/v1.18.0...v1.18.1 ### [`v1.18.0`](https://github.com/uuid-rs/uuid/releases/tag/v1.18.0) [Compare Source](https://github.com/uuid-rs/uuid/compare/v1.17.0...v1.18.0) #### What's Changed - Fix up mismatched_lifetime_syntaxes lint by [@&#8203;KodrAus](https://github.com/KodrAus) in https://github.com/uuid-rs/uuid/pull/837 - Conversions between `Timestamp` and `std::time::SystemTime` by [@&#8203;dcormier](https://github.com/dcormier) in https://github.com/uuid-rs/uuid/pull/835 - Wrap the error type used in time conversions by [@&#8203;KodrAus](https://github.com/KodrAus) in https://github.com/uuid-rs/uuid/pull/838 - Prepare for 1.18.0 release by [@&#8203;KodrAus](https://github.com/KodrAus) in https://github.com/uuid-rs/uuid/pull/839 #### New Contributors - [@&#8203;dcormier](https://github.com/dcormier) made their first contribution in https://github.com/uuid-rs/uuid/pull/835 **Full Changelog**: https://github.com/uuid-rs/uuid/compare/v1.17.0...v1.18.0 ### [`v1.17.0`](https://github.com/uuid-rs/uuid/releases/tag/v1.17.0) [Compare Source](https://github.com/uuid-rs/uuid/compare/v1.16.0...v1.17.0) #### What's Changed - Added convenience implementation TryFrom<String> for std by [@&#8203;Nahuel-M](https://github.com/Nahuel-M) in https://github.com/uuid-rs/uuid/pull/819 - Update OSX builds to arm by [@&#8203;KodrAus](https://github.com/KodrAus) in https://github.com/uuid-rs/uuid/pull/825 - Replace derive(Hash) with manual impl in Uuid by [@&#8203;diopoex](https://github.com/diopoex) in https://github.com/uuid-rs/uuid/pull/824 - Add `wasm32v1-none` Support by [@&#8203;bushrat011899](https://github.com/bushrat011899) in https://github.com/uuid-rs/uuid/pull/828 - Prepare for 1.17.0 release by [@&#8203;KodrAus](https://github.com/KodrAus) in https://github.com/uuid-rs/uuid/pull/829 #### New Contributors - [@&#8203;Nahuel-M](https://github.com/Nahuel-M) made their first contribution in https://github.com/uuid-rs/uuid/pull/819 - [@&#8203;diopoex](https://github.com/diopoex) made their first contribution in https://github.com/uuid-rs/uuid/pull/824 **Full Changelog**: https://github.com/uuid-rs/uuid/compare/v1.16.0...v1.17.0 ### [`v1.16.0`](https://github.com/uuid-rs/uuid/releases/tag/v1.16.0) [Compare Source](https://github.com/uuid-rs/uuid/compare/v1.15.1...v1.16.0) #### What's Changed - Mark `Uuid::new_v8` const by [@&#8203;tguichaoua](https://github.com/tguichaoua) in https://github.com/uuid-rs/uuid/pull/815 - Prepare for 1.16.0 release by [@&#8203;KodrAus](https://github.com/KodrAus) in https://github.com/uuid-rs/uuid/pull/817 #### New Contributors - [@&#8203;tguichaoua](https://github.com/tguichaoua) made their first contribution in https://github.com/uuid-rs/uuid/pull/815 **Full Changelog**: https://github.com/uuid-rs/uuid/compare/v1.15.1...v1.16.0 ### [`v1.15.1`](https://github.com/uuid-rs/uuid/releases/tag/v1.15.1) [Compare Source](https://github.com/uuid-rs/uuid/compare/v1.15.0...v1.15.1) #### What's Changed - Guarantee v7 timestamp will never overflow by [@&#8203;KodrAus](https://github.com/KodrAus) in https://github.com/uuid-rs/uuid/pull/811 - Prepare for 1.15.1 release by [@&#8203;KodrAus](https://github.com/KodrAus) in https://github.com/uuid-rs/uuid/pull/812 **Full Changelog**: https://github.com/uuid-rs/uuid/compare/v1.15.0...v1.15.1 ### [`v1.15.0`](https://github.com/uuid-rs/uuid/releases/tag/v1.15.0) [Compare Source](https://github.com/uuid-rs/uuid/compare/v1.14.0...v1.15.0) #### What's Changed - Add a manual `Debug` implementation for NonNilUUid by [@&#8203;rick-de-water](https://github.com/rick-de-water) in https://github.com/uuid-rs/uuid/pull/808 - Support higher precision, shiftable timestamps in V7 UUIDs by [@&#8203;KodrAus](https://github.com/KodrAus) in https://github.com/uuid-rs/uuid/pull/809 - Prepare for 1.15.0 release by [@&#8203;KodrAus](https://github.com/KodrAus) in https://github.com/uuid-rs/uuid/pull/810 #### New Contributors - [@&#8203;rick-de-water](https://github.com/rick-de-water) made their first contribution in https://github.com/uuid-rs/uuid/pull/808 **Full Changelog**: https://github.com/uuid-rs/uuid/compare/v1.14.0...v1.15.0 ### [`v1.14.0`](https://github.com/uuid-rs/uuid/releases/tag/v1.14.0) [Compare Source](https://github.com/uuid-rs/uuid/compare/v1.13.2...v1.14.0) #### What's Changed - Add FromStr impls to the fmt structs by [@&#8203;tysen](https://github.com/tysen) in https://github.com/uuid-rs/uuid/pull/806 - Prepare for 1.14.0 release by [@&#8203;KodrAus](https://github.com/KodrAus) in https://github.com/uuid-rs/uuid/pull/807 #### New Contributors - [@&#8203;tysen](https://github.com/tysen) made their first contribution in https://github.com/uuid-rs/uuid/pull/806 **Full Changelog**: https://github.com/uuid-rs/uuid/compare/v1.13.2...v1.14.0 ### [`v1.13.2`](https://github.com/uuid-rs/uuid/releases/tag/v1.13.2) [Compare Source](https://github.com/uuid-rs/uuid/compare/1.13.1...v1.13.2) #### What's Changed - Add a compile_error when no source of randomness is available on wasm32-unknown-unknown by [@&#8203;KodrAus](https://github.com/KodrAus) in https://github.com/uuid-rs/uuid/pull/804 - Prepare for 1.13.2 release by [@&#8203;KodrAus](https://github.com/KodrAus) in https://github.com/uuid-rs/uuid/pull/805 **Full Changelog**: https://github.com/uuid-rs/uuid/compare/1.13.1...v1.13.2 ### [`v1.13.1`](https://github.com/uuid-rs/uuid/releases/tag/1.13.1) [Compare Source](https://github.com/uuid-rs/uuid/compare/1.13.0...1.13.1) #### What's Changed - Fix `wasm32` with `atomics` by [@&#8203;bushrat011899](https://github.com/bushrat011899) in https://github.com/uuid-rs/uuid/pull/797 - Prepare for 1.13.1 release by [@&#8203;KodrAus](https://github.com/KodrAus) in https://github.com/uuid-rs/uuid/pull/799 #### New Contributors - [@&#8203;bushrat011899](https://github.com/bushrat011899) made their first contribution in https://github.com/uuid-rs/uuid/pull/797 **Full Changelog**: https://github.com/uuid-rs/uuid/compare/1.13.0...1.13.1 ### [`v1.13.0`](https://github.com/uuid-rs/uuid/releases/tag/1.13.0) [Compare Source](https://github.com/uuid-rs/uuid/compare/1.12.1...1.13.0) #### :warning: Potential Breakage This release updates our version of `getrandom` to `0.3` and `rand` to `0.9`. It is a **potentially breaking change** for the following users: ##### no-std users who enable the `rng` feature `uuid` still uses `getrandom` by default on these platforms. Upgrade your version of `getrandom` and [follow its new docs](https://docs.rs/getrandom/0.3.1/getrandom/index.html#custom-backend) on configuring a custom backend. ##### `wasm32-unknown-unknown` users who enable the `rng` feature without the `js` feature Upgrade your version of `getrandom` and [follow its new docs](https://docs.rs/getrandom/0.3.1/getrandom/index.html#custom-backend) on configuring a backend. You'll also need to enable the `rng-getrandom` or `rng-rand` feature of `uuid` to force it to use `getrandom` as its backend: ```diff [dependencies.uuid] version = "1.13.0" - features = ["v4"] + features = ["v4", "rng-getrandom"] [dependencies.getrandom] version = "0.3" ``` If you're on `wasm32-unknown-unknown` and using the `js` feature of `uuid` you shouldn't see any breakage. We've kept this behavior by vendoring in `getrandom`'s web-based backend when the `js` feature is enabled. #### What's Changed - Update `getrandom` to `0.3` and `rand` to `0.9` by [@&#8203;KodrAus](https://github.com/KodrAus) in https://github.com/uuid-rs/uuid/pull/793 - Support forcing `getrandom` on `wasm32-unknown-unknown` without JavaScript by [@&#8203;KodrAus](https://github.com/KodrAus) in https://github.com/uuid-rs/uuid/pull/794 - Prepare for 1.13.0 release by [@&#8203;KodrAus](https://github.com/KodrAus) in https://github.com/uuid-rs/uuid/pull/795 **Full Changelog**: https://github.com/uuid-rs/uuid/compare/1.12.1...1.13.0 ### [`v1.12.1`](https://github.com/uuid-rs/uuid/releases/tag/1.12.1) [Compare Source](https://github.com/uuid-rs/uuid/compare/1.12.0...1.12.1) #### What's Changed - Fix links to namespaces in documentation by [@&#8203;cstyles](https://github.com/cstyles) in https://github.com/uuid-rs/uuid/pull/789 - use inherent to_be_bytes and to_le_bytes methods by [@&#8203;Vrtgs](https://github.com/Vrtgs) in https://github.com/uuid-rs/uuid/pull/788 - Reduce bitshifts in from_u64\_pair by [@&#8203;KodrAus](https://github.com/KodrAus) in https://github.com/uuid-rs/uuid/pull/790 - prepare for 1.12.1 release by [@&#8203;KodrAus](https://github.com/KodrAus) in https://github.com/uuid-rs/uuid/pull/791 #### New Contributors - [@&#8203;cstyles](https://github.com/cstyles) made their first contribution in https://github.com/uuid-rs/uuid/pull/789 - [@&#8203;Vrtgs](https://github.com/Vrtgs) made their first contribution in https://github.com/uuid-rs/uuid/pull/788 **Full Changelog**: https://github.com/uuid-rs/uuid/compare/1.12.0...1.12.1 </details> <details> <summary>wasm-bindgen/wasm-bindgen (wasm-bindgen)</summary> ### [`v0.2.106`](https://github.com/wasm-bindgen/wasm-bindgen/blob/HEAD/CHANGELOG.md#02106) [Compare Source](https://github.com/wasm-bindgen/wasm-bindgen/compare/0.2.105...0.2.106) ##### Added - New MSRV policy, and bump of the MSRV fo 1.71. [#&#8203;4801](https://github.com/wasm-bindgen/wasm-bindgen/pull4801) - Added typed `this` support in the first argument in free function exports via a new `#[wasm_bindgen(this)]` attribute. [#&#8203;4757](https://github.com/wasm-bindgen/wasm-bindgen/pull/4757) - Added `reexport` attribute for imports to support re-exporting imported types, with optional renaming. [#&#8203;4759](https://github.com/wasm-bindgen/wasm-bindgen/pull/4759) - Added `js_namespace` attribute on exported types, mirroring the import semantics to enable arbitrarily nested exported interface objects. [#&#8203;4744](https://github.com/wasm-bindgen/wasm-bindgen/pull/4744) - Added 'container' attribute to `ScrollIntoViewOptions` [#&#8203;4806](https://github.com/wasm-bindgen/wasm-bindgen/pull/4806) - Updated and refactored output generation to use alphabetical ordering of declarations. [#&#8203;4813](https://github.com/wasm-bindgen/wasm-bindgen/pull/4813) - Added benchmark support to `wasm-bindgen-test`. [#&#8203;4812](https://github.com/wasm-bindgen/wasm-bindgen/pull/4812) [#&#8203;4823](https://github.com/wasm-bindgen/wasm-bindgen/pull/4823) ##### Fixed - Fixed node test harness getting stuck after tests completed. [#&#8203;4776](https://github.com/wasm-bindgen/wasm-bindgen/pull/4776) - Quote names containing colons in generated .d.ts. [#&#8203;4488](https://github.com/wasm-bindgen/wasm-bindgen/pull/4488) - Fixes TryFromJsValue for structs JsValue stack corruption on failure. [#&#8203;4786](https://github.com/wasm-bindgen/wasm-bindgen/pull/4786) - Fixed `wasm-bindgen-test-runner` outputting empty line when using the `--list` option. In particular, `cargo-nextest` now works correctly. [#&#8203;4803](https://github.com/wasm-bindgen/wasm-bindgen/pull/4803) - It now works to build with `-Cpanic=unwind`. [#&#8203;4796](https://github.com/wasm-bindgen/wasm-bindgen/pull/4796) [#&#8203;4783](https://github.com/wasm-bindgen/wasm-bindgen/pull/4783) [#&#8203;4782](https://github.com/wasm-bindgen/wasm-bindgen/pull/4782) - Fixed duplicate symbols caused by enabling v0 mangling. [#&#8203;4822](https://github.com/wasm-bindgen/wasm-bindgen/pull/4822) - Fixed a multithreaded wasm32+atomics race where `Atomics.waitAsync` promise callbacks could call `run` without waking first, causing sporadic panics. [#&#8203;4821](https://github.com/wasm-bindgen/wasm-bindgen/pull/4821) ##### Removed ### [`v0.2.105`](https://github.com/wasm-bindgen/wasm-bindgen/blob/HEAD/CHANGELOG.md#02105) [Compare Source](https://github.com/wasm-bindgen/wasm-bindgen/compare/0.2.104...0.2.105) ##### Added - Added `Math::PI` binding to `js_sys`, exposing the ECMAScript `Math.PI` constant. [#&#8203;4748](https://github.com/wasm-bindgen/wasm-bindgen/pull/4748) - Added ability to use `--keep-lld-exports` in `wasm-bindgen-test-runner` by setting the `WASM_BINDGEN_KEEP_LLD_EXPORTS` environment variable. [#&#8203;4736](https://github.com/wasm-bindgen/wasm-bindgen/pull/4736) - Added `CookieStore` API. [#&#8203;4706](https://github.com/wasm-bindgen/wasm-bindgen/pull/4706) - Added `run_cli_with_args` library functions to all `wasm_bindgen_cli` entrypoints. [#&#8203;4710](https://github.com/wasm-bindgen/wasm-bindgen/pull/4710) - Added `get_raw` and `set_raw` for `WebAssembly.Table`. [#&#8203;4701](https://github.com/wasm-bindgen/wasm-bindgen/pull/4701) - Added `new_with_value` and `grow_with_value` for `WebAssembly.Table`. [#&#8203;4698](https://github.com/wasm-bindgen/wasm-bindgen/pull/4698) - Added better support for async stack traces when building in debug mode. [#&#8203;4711](https://github.com/wasm-bindgen/wasm-bindgen/pull/4711) - Extended support for `TryFromJsValue` trait implementations. [#&#8203;4714](https://github.com/wasm-bindgen/wasm-bindgen/pull/4714) - New `JsValue.is_null_or_undefined()` method and intrinsic. [#&#8203;4751](https://github.com/wasm-bindgen/wasm-bindgen/pull/4751) - Support for `Option<JsValue>` in function arguments and return. [#&#8203;4752](https://github.com/wasm-bindgen/wasm-bindgen/pull/4752) - Support for `WASM_BINDGEN_KEEP_TEST_BUILD=1` environment variable to retain build files when using the test runner. [#&#8203;4758](https://github.com/wasm-bindgen/wasm-bindgen/pull/4758) ##### Fixed - Fixed multithreading JS output for targets `bundler`, `deno` and `module`. [#&#8203;4685](https://github.com/wasm-bindgen/wasm-bindgen/pull/4685) - Fixed `TextDe/Encoder` detection for audio worklet use-cases. [#&#8203;4703](https://github.com/wasm-bindgen/wasm-bindgen/pull/4703) - Fixed post-processing failures in case Std has debug assertions enabled. [#&#8203;4705](https://github.com/wasm-bindgen/wasm-bindgen/pull/4705) - Fixed JS memory leak in `wasm_bindgen::Closure`. [#&#8203;4709](https://github.dev/wasm-bindgen/wasm-bindgen/pull/4709) - Fixed warning when using `#[wasm_bindgen(wasm_bindgen=xxx)]` on struct. [#&#8203;4715](https://github.dev/wasm-bindgen/wasm-bindgen/pull/4715) ##### Removed - Internal crate `wasm-bindgen-backend` will no longer be published. [#&#8203;4696](https://github.com/wasm-bindgen/wasm-bindgen/pull/4696) ### [`v0.2.104`](https://github.com/wasm-bindgen/wasm-bindgen/blob/HEAD/CHANGELOG.md#02104) [Compare Source](https://github.com/wasm-bindgen/wasm-bindgen/compare/0.2.103...0.2.104) ##### Added - Added bindings for `WeakRef`. [#&#8203;4659](https://github.com/wasm-bindgen/wasm-bindgen/pull/4659) - Support `Symbol.dispose` methods by default, when it is supported in the environment. [#&#8203;4666](https://github.com/wasm-bindgen/wasm-bindgen/pull/4666) - Added `aarch64-unknown-linux-musl` release artifacts. [#&#8203;4668](https://github.com/wasm-bindgen/wasm-bindgen/pull/4668) ##### Changed - Unconditionally use the global `TextEncoder`/`TextDecoder` for string encoding/decoding. The Node.js output now requires a minimum of Node.js v11. [#&#8203;4670](https://github.com/wasm-bindgen/wasm-bindgen/pull/4670) - Deprecate the `msrv` crate feature. MSRV detection is now always on. [#&#8203;4675](https://github.com/wasm-bindgen/wasm-bindgen/pull/4675) ##### Fixed - Fixed wasm-bindgen-cli's `encode_into` argument not working. [#&#8203;4663](https://github.com/wasm-bindgen/wasm-bindgen/pull/4663) - Fixed a bug in `--experimental-reset-state-function` support for heap reset. [#&#8203;4665](https://github.com/wasm-bindgen/wasm-bindgen/pull/4665) - Fixed compilation failures on Rust v1.82 and v1.83. [#&#8203;4675](https://github.com/wasm-bindgen/wasm-bindgen/pull/4675) *** ### [`v0.2.103`](https://github.com/wasm-bindgen/wasm-bindgen/blob/HEAD/CHANGELOG.md#02103) [Compare Source](https://github.com/wasm-bindgen/wasm-bindgen/compare/0.2.102...0.2.103) ##### Fixed - Fixed incorrect function mapping during post-processing. [#&#8203;4656](https://github.com/wasm-bindgen/wasm-bindgen/pull/4656) *** ### [`v0.2.102`](https://github.com/wasm-bindgen/wasm-bindgen/blob/HEAD/CHANGELOG.md#02102) [Compare Source](https://github.com/wasm-bindgen/wasm-bindgen/compare/0.2.101...0.2.102) ##### Added - Added `DocumentOrShadowRoot.adoptedStyleSheets`. [#&#8203;4625](https://github.com/wasm-bindgen/wasm-bindgen/pull/4625) - Added support for arguments with spaces using shell-style quoting in webdriver `*_ARGS` environment variables to `wasm-bindgen-test`. [#&#8203;4433](https://github.com/wasm-bindgen/wasm-bindgen/pull/4433) - Added ability to determine WebDriver JSON config location via `WASM_BINDGEN_TEST_WEBDRIVER_JSON` environment variable to `wasm-bindgen-test`. [#&#8203;4434](https://github.com/wasm-bindgen/wasm-bindgen/pull/4434) - Generate DWARF for tests by default. See the [guide on debug information] for more details. [#&#8203;4635](https://github.com/wasm-bindgen/wasm-bindgen/pull/4635) [guide on debug information]: https://wasm-bindgen.github.io/wasm-bindgen/reference/debug-info.html - New `--target=module` target for outputting source phase imports. [#&#8203;4638](https://github.com/wasm-bindgen/wasm-bindgen/pull/4638) ##### Changed - Hidden deprecated options from the `wasm-bindgen --help` docs. [#&#8203;4646](https://github.com/wasm-bindgen/wasm-bindgen/pull/4646) ##### Fixed - Fixed wrong method names for `GestureEvent` bindings. [#&#8203;4615](https://github.com/wasm-bindgen/wasm-bindgen/pull/4615) - Fix crash caused by allocations during `TypedArray` interactions. [#&#8203;4622](https://github.com/wasm-bindgen/wasm-bindgen/pull/4622) *** ### [`v0.2.101`](https://github.com/wasm-bindgen/wasm-bindgen/blob/HEAD/CHANGELOG.md#02101) [Compare Source](https://github.com/wasm-bindgen/wasm-bindgen/compare/0.2.100...0.2.101) ##### Added - Added format and colorSpace support to VideoFrameCopyToOptions [#&#8203;4543](https://github.com/wasm-bindgen/wasm-bindgen/pull/4543) - Added support for the [`onbeforeinput`](https://developer.mozilla.org/en-US/docs/Web/API/Element/beforeinput_event) attribute. [#&#8203;4544](https://github.com/wasm-bindgen/wasm-bindgen/pull/4544) - `TypedArray::new_from_slice(&[T])` constructor that allows to create a JS-owned `TypedArray` from a Rust slice. [#&#8203;4555](https://github.com/wasm-bindgen/wasm-bindgen/pull/4555) - Added `Function::call4` and `Function::bind4` through `Function::call9` `Function::bind9` methods for calling and binding JavaScript functions with 4-9 arguments. [#&#8203;4572](https://github.com/wasm-bindgen/wasm-bindgen/pull/4572) - Added isPointInFill and isPointInStroke methods for the SVGGeometryElement idl. [#&#8203;4509](https://github.com/wasm-bindgen/wasm-bindgen/pull/4509) - Added unstable bindings for `GestureEvent`. [#&#8203;4589](https://github.com/wasm-bindgen/wasm-bindgen/pull/4589) - Stricter checks for `module`, `raw_module` and `inline_js` attributes applied to inapplicable items. [#&#8203;4522](https://github.com/wasm-bindgen/wasm-bindgen/pull/4522) - Add bindings for `PictureInPicture`. [#&#8203;4593](https://github.com/rustwasm/wasm-bindgen/pull/4593) - Added `bytes` method for the `Blob` idl [#&#8203;4506](https://github.com/wasm-bindgen/wasm-bindgen/pull/4506) - Add error message when export symbol is not found [#&#8203;4594](https://github.com/wasm-bindgen/wasm-bindgen/pull/4594) ##### Changed - Deprecate async constructors. [#&#8203;4402](https://github.com/rustwasm/wasm-bindgen/pull/4402) - The `size` argument to `GPUCommandEncoder.copyBufferToBuffer` is now optional. [#&#8203;4508](https://github.com/wasm-bindgen/wasm-bindgen/pull/4508) - MSRV of CLI tools bumped to v1.82. This does not affect libraries like `wasm-bindgen`, `js-sys` and `web-sys`! [#&#8203;4608](https://github.com/wasm-bindgen/wasm-bindgen/pull/4608) ##### Fixed - Detect more failure scenarios when retrieving the Wasm module. [#&#8203;4556](https://github.com/wasm-bindgen/wasm-bindgen/pull/4556) - Add a workaround for `TextDecoder` failing in older version of Safari when too many bytes are decoded through it over its lifetime. [#&#8203;4472](https://github.com/wasm-bindgen/wasm-bindgen/pull/4472) - `TypedArray::from(&[T])` now works reliably across memory reallocations. [#&#8203;4555](https://github.com/wasm-bindgen/wasm-bindgen/pull/4555) - Fix incorrect memory loading and storing assertions during post-processing. [#&#8203;4554](https://github.com/wasm-bindgen/wasm-bindgen/pull/4554) - Fix test `--exact` option not working as expected. [#&#8203;4549](https://github.com/wasm-bindgen/wasm-bindgen/pull/4549) - Fix tables being removed even though they are used by stack closures. [#&#8203;4119](https://github.com/wasm-bindgen/wasm-bindgen/pull/4564) - Skip `__wasm_call_ctors` which we don't want to interpret. [#&#8203;4562](https://github.com/wasm-bindgen/wasm-bindgen/pull/4562) - Fix infinite recursion caused by the lack of proc-macro hygiene. [#&#8203;4601](https://github.com/wasm-bindgen/wasm-bindgen/pull/4601) - Fix running coverage with no_modules. [#&#8203;4604](https://github.com/wasm-bindgen/wasm-bindgen/pull/4604) - Fix proc-macro hygiene with `core`. [#&#8203;4606](https://github.com/wasm-bindgen/wasm-bindgen/pull/4606) ##### Removed - Crates intended purely for internal consumption by the wasm-bindgen CLI will no longer be published: [#&#8203;4608](https://github.com/wasm-bindgen/wasm-bindgen/pull/4608) - `wasm-bindgen-externref-xform` - `wasm-bindgen-multi-value-xform` - `wasm-bindgen-threads-xform` - `wasm-bindgen-wasm-conventions` - `wasm-bindgen-wasm-interpreter` *** </details> --- ### Configuration 📅 **Schedule**: Branch creation - At any time (no schedule defined), Automerge - At any time (no schedule defined). 🚦 **Automerge**: Enabled. ♻ **Rebasing**: Whenever PR is behind base branch, or you tick the rebase/retry checkbox. 👻 **Immortal**: This PR will be recreated if closed unmerged. Get [config help](https://github.com/renovatebot/renovate/discussions) if that's undesired. --- - [ ] <!-- rebase-check -->If you want to rebase/retry this PR, check this box --- This PR has been generated by [Renovate Bot](https://github.com/renovatebot/renovate). <!--renovate-debug:eyJjcmVhdGVkSW5WZXIiOiIzNy40MjQuMyIsInVwZGF0ZWRJblZlciI6IjM5LjI2NC4wIiwidGFyZ2V0QnJhbmNoIjoibWFpbiIsImxhYmVscyI6W119-->
kjuulh added 1 commit 2025-01-12 02:41:13 +01:00
chore(deps): update rust crate axum to 0.8
Some checks failed
renovate/artifacts Artifact file update failure
continuous-integration/drone/push Build is passing
continuous-integration/drone/pr Build is failing
f3f0bcf02e
kjuulh force-pushed renovate/all from f3f0bcf02e to cb95813436 2025-01-13 02:45:05 +01:00 Compare
kjuulh force-pushed renovate/all from cb95813436 to 3f1e5d3f8c 2025-01-13 06:43:47 +01:00 Compare
kjuulh changed title from chore(deps): update rust crate axum to 0.8 to chore(deps): update all dependencies 2025-01-15 02:52:39 +01:00
kjuulh force-pushed renovate/all from 3f1e5d3f8c to 5e3140e3e6 2025-01-19 02:47:46 +01:00 Compare
kjuulh force-pushed renovate/all from 5e3140e3e6 to 247953ba03 2025-01-19 06:44:03 +01:00 Compare
kjuulh force-pushed renovate/all from 247953ba03 to 68dadd1c5b 2025-01-20 02:45:38 +01:00 Compare
kjuulh force-pushed renovate/all from 68dadd1c5b to 4eabf15136 2025-01-21 06:49:23 +01:00 Compare
kjuulh force-pushed renovate/all from 4eabf15136 to 1f49fc0a47 2025-01-22 02:46:48 +01:00 Compare
kjuulh force-pushed renovate/all from 1f49fc0a47 to 824a92b1f0 2025-01-22 06:43:40 +01:00 Compare
kjuulh force-pushed renovate/all from 824a92b1f0 to d618989860 2025-01-23 02:46:53 +01:00 Compare
kjuulh force-pushed renovate/all from d618989860 to f5fa1c7e50 2025-01-23 06:48:25 +01:00 Compare
kjuulh force-pushed renovate/all from f5fa1c7e50 to 442ff5974e 2025-01-24 02:54:43 +01:00 Compare
kjuulh force-pushed renovate/all from 442ff5974e to 01bce81f92 2025-01-24 06:53:51 +01:00 Compare
kjuulh force-pushed renovate/all from 01bce81f92 to db62639f39 2025-01-25 02:48:54 +01:00 Compare
kjuulh force-pushed renovate/all from db62639f39 to 1cba80e9e2 2025-01-25 06:44:35 +01:00 Compare
kjuulh force-pushed renovate/all from 1cba80e9e2 to 557af389a7 2025-01-26 02:51:39 +01:00 Compare
kjuulh force-pushed renovate/all from 557af389a7 to 54a2be2630 2025-01-26 06:45:07 +01:00 Compare
kjuulh force-pushed renovate/all from 54a2be2630 to 3630272750 2025-01-27 02:50:30 +01:00 Compare
kjuulh force-pushed renovate/all from 3630272750 to df5640ded3 2025-01-27 06:46:26 +01:00 Compare
kjuulh force-pushed renovate/all from df5640ded3 to fa7d51a921 2025-01-28 02:45:57 +01:00 Compare
kjuulh force-pushed renovate/all from fa7d51a921 to 83d59247ad 2025-01-28 06:47:33 +01:00 Compare
kjuulh force-pushed renovate/all from 83d59247ad to dbfda2a260 2025-01-29 02:53:40 +01:00 Compare
kjuulh force-pushed renovate/all from dbfda2a260 to f9eeaeaeb6 2025-01-29 06:50:33 +01:00 Compare
kjuulh force-pushed renovate/all from f9eeaeaeb6 to 6040b92371 2025-01-30 02:56:53 +01:00 Compare
kjuulh force-pushed renovate/all from 6040b92371 to f149408940 2025-01-30 07:01:09 +01:00 Compare
kjuulh force-pushed renovate/all from f149408940 to ff875c85fb 2025-01-31 02:50:19 +01:00 Compare
kjuulh force-pushed renovate/all from ff875c85fb to 405e0e88c1 2025-01-31 06:47:32 +01:00 Compare
kjuulh force-pushed renovate/all from 405e0e88c1 to b913a214d4 2025-02-01 02:48:22 +01:00 Compare
kjuulh force-pushed renovate/all from b913a214d4 to fa10ed656e 2025-02-01 06:48:22 +01:00 Compare
kjuulh force-pushed renovate/all from fa10ed656e to 1092b24f4a 2025-02-02 02:47:27 +01:00 Compare
kjuulh force-pushed renovate/all from 1092b24f4a to 7ac14cb8f9 2025-02-02 06:43:36 +01:00 Compare
kjuulh force-pushed renovate/all from 7ac14cb8f9 to f4384afb36 2025-02-03 02:44:59 +01:00 Compare
kjuulh force-pushed renovate/all from f4384afb36 to a1d4c17398 2025-02-03 06:43:20 +01:00 Compare
kjuulh force-pushed renovate/all from a1d4c17398 to 2f74b08e1d 2025-02-04 02:52:08 +01:00 Compare
kjuulh force-pushed renovate/all from 2f74b08e1d to bf4f94da42 2025-02-04 06:47:58 +01:00 Compare
kjuulh force-pushed renovate/all from bf4f94da42 to b8523945e5 2025-02-05 02:48:15 +01:00 Compare
kjuulh force-pushed renovate/all from b8523945e5 to 3284cdc880 2025-02-05 06:51:52 +01:00 Compare
kjuulh force-pushed renovate/all from 3284cdc880 to 99bd4e0249 2025-02-06 02:52:58 +01:00 Compare
kjuulh force-pushed renovate/all from 99bd4e0249 to d43f01248c 2025-02-06 06:45:48 +01:00 Compare
kjuulh force-pushed renovate/all from d43f01248c to f42fa748ed 2025-02-07 02:47:27 +01:00 Compare
kjuulh force-pushed renovate/all from f42fa748ed to 9b78dd5ddf 2025-02-07 06:43:12 +01:00 Compare
kjuulh force-pushed renovate/all from 9b78dd5ddf to 36bf0758e2 2025-02-08 02:48:29 +01:00 Compare
kjuulh force-pushed renovate/all from 36bf0758e2 to 19a8bdf781 2025-02-08 06:44:13 +01:00 Compare
kjuulh force-pushed renovate/all from 19a8bdf781 to fb5250ee58 2025-02-09 02:48:41 +01:00 Compare
kjuulh force-pushed renovate/all from fb5250ee58 to b07d60d348 2025-02-09 06:44:16 +01:00 Compare
kjuulh force-pushed renovate/all from b07d60d348 to 850497d054 2025-02-10 02:46:16 +01:00 Compare
kjuulh force-pushed renovate/all from 850497d054 to 19bd097cc0 2025-02-10 06:44:46 +01:00 Compare
kjuulh force-pushed renovate/all from 19bd097cc0 to 098bc3dad6 2025-02-11 02:49:46 +01:00 Compare
kjuulh force-pushed renovate/all from 098bc3dad6 to 4c1a568686 2025-02-11 06:47:28 +01:00 Compare
kjuulh force-pushed renovate/all from 4c1a568686 to 165193bbf8 2025-02-12 02:53:01 +01:00 Compare
kjuulh force-pushed renovate/all from 165193bbf8 to eaec6e1a9e 2025-02-12 06:48:36 +01:00 Compare
kjuulh force-pushed renovate/all from eaec6e1a9e to e2b0834b10 2025-02-13 02:48:32 +01:00 Compare
kjuulh force-pushed renovate/all from e2b0834b10 to ce21720fec 2025-02-13 06:45:59 +01:00 Compare
kjuulh force-pushed renovate/all from ce21720fec to 6e51d4b329 2025-02-14 02:46:18 +01:00 Compare
kjuulh force-pushed renovate/all from 6e51d4b329 to 0a22f1b1da 2025-02-14 06:44:58 +01:00 Compare
kjuulh force-pushed renovate/all from 0a22f1b1da to c3ebf79844 2025-02-15 02:43:15 +01:00 Compare
kjuulh force-pushed renovate/all from c3ebf79844 to faa3579c10 2025-02-15 06:40:35 +01:00 Compare
kjuulh force-pushed renovate/all from faa3579c10 to badccf41ba 2025-02-16 02:41:55 +01:00 Compare
kjuulh force-pushed renovate/all from badccf41ba to 6b576edea0 2025-02-16 06:39:19 +01:00 Compare
kjuulh force-pushed renovate/all from 6b576edea0 to 74815fc9c4 2025-02-17 02:44:02 +01:00 Compare
kjuulh force-pushed renovate/all from 74815fc9c4 to c67a27ba94 2025-02-17 06:42:06 +01:00 Compare
kjuulh force-pushed renovate/all from c67a27ba94 to 363b588f38 2025-02-18 02:49:36 +01:00 Compare
kjuulh force-pushed renovate/all from 363b588f38 to 9f858510ec 2025-02-18 06:45:12 +01:00 Compare
kjuulh force-pushed renovate/all from 9f858510ec to 3802746bb5 2025-02-19 02:43:42 +01:00 Compare
kjuulh force-pushed renovate/all from 3802746bb5 to d81ebcefaa 2025-02-19 06:41:41 +01:00 Compare
kjuulh force-pushed renovate/all from d81ebcefaa to 50b0107c85 2025-02-20 02:55:31 +01:00 Compare
kjuulh force-pushed renovate/all from 50b0107c85 to 17ad1283f7 2025-02-20 06:52:29 +01:00 Compare
kjuulh force-pushed renovate/all from 17ad1283f7 to b7b5b9bfe1 2025-02-21 02:52:28 +01:00 Compare
kjuulh force-pushed renovate/all from b7b5b9bfe1 to 1c61c0c604 2025-02-21 06:43:25 +01:00 Compare
kjuulh force-pushed renovate/all from 1c61c0c604 to 1219e56373 2025-02-22 02:46:06 +01:00 Compare
kjuulh force-pushed renovate/all from 1219e56373 to 4ae94b575d 2025-02-22 06:48:46 +01:00 Compare
kjuulh force-pushed renovate/all from 4ae94b575d to 3cb354d74b 2025-02-23 02:44:39 +01:00 Compare
kjuulh force-pushed renovate/all from 3cb354d74b to c2c38d8972 2025-02-23 06:45:36 +01:00 Compare
kjuulh force-pushed renovate/all from c2c38d8972 to 481b3bfd6e 2025-02-24 02:45:11 +01:00 Compare
kjuulh force-pushed renovate/all from 481b3bfd6e to a33b8f51dd 2025-02-24 06:42:52 +01:00 Compare
kjuulh force-pushed renovate/all from a33b8f51dd to 5971cd95ad 2025-02-25 02:48:40 +01:00 Compare
kjuulh force-pushed renovate/all from 5971cd95ad to e51886ef9c 2025-02-25 06:46:20 +01:00 Compare
kjuulh force-pushed renovate/all from e51886ef9c to 23be176af7 2025-02-26 02:45:32 +01:00 Compare
kjuulh force-pushed renovate/all from 23be176af7 to cbe24a661f 2025-02-26 06:44:29 +01:00 Compare
kjuulh force-pushed renovate/all from cbe24a661f to 8d3019ef00 2025-02-27 02:55:16 +01:00 Compare
kjuulh force-pushed renovate/all from 8d3019ef00 to e9f0a74681 2025-02-27 06:52:19 +01:00 Compare
kjuulh force-pushed renovate/all from e9f0a74681 to 9c3b128321 2025-02-28 02:54:19 +01:00 Compare
kjuulh force-pushed renovate/all from 9c3b128321 to 7ed2789a96 2025-02-28 06:50:20 +01:00 Compare
kjuulh force-pushed renovate/all from 7ed2789a96 to 83c872ec1b 2025-03-01 02:50:54 +01:00 Compare
kjuulh force-pushed renovate/all from 83c872ec1b to 061b0371f8 2025-03-01 06:47:38 +01:00 Compare
kjuulh force-pushed renovate/all from 061b0371f8 to 8ceacdb201 2025-03-02 02:47:46 +01:00 Compare
kjuulh force-pushed renovate/all from 8ceacdb201 to 2e524a4bd5 2025-03-02 07:10:24 +01:00 Compare
kjuulh force-pushed renovate/all from 2e524a4bd5 to 7cf48fbe9f 2025-03-03 02:45:43 +01:00 Compare
kjuulh force-pushed renovate/all from 7cf48fbe9f to 954d84a94a 2025-03-03 06:48:58 +01:00 Compare
kjuulh force-pushed renovate/all from 954d84a94a to d543b0e8ca 2025-03-04 02:56:42 +01:00 Compare
kjuulh force-pushed renovate/all from d543b0e8ca to a2cd18a96f 2025-03-04 06:53:30 +01:00 Compare
kjuulh force-pushed renovate/all from a2cd18a96f to 1736aa1683 2025-03-05 02:51:14 +01:00 Compare
kjuulh force-pushed renovate/all from 1736aa1683 to d694e965e4 2025-03-05 06:47:51 +01:00 Compare
kjuulh force-pushed renovate/all from d694e965e4 to e89a2db6ae 2025-03-06 02:53:08 +01:00 Compare
kjuulh force-pushed renovate/all from e89a2db6ae to b8e641740f 2025-03-06 06:51:02 +01:00 Compare
kjuulh force-pushed renovate/all from b8e641740f to 0cdcb5bf27 2025-03-26 00:04:14 +01:00 Compare
kjuulh changed title from chore(deps): update all dependencies to fix(deps): update all dependencies 2025-03-26 00:04:14 +01:00
kjuulh force-pushed renovate/all from 0cdcb5bf27 to 384cb4a75d 2025-04-06 02:33:31 +02:00 Compare
kjuulh force-pushed renovate/all from 384cb4a75d to ffd16301af 2025-04-06 05:33:07 +02:00 Compare
kjuulh force-pushed renovate/all from ffd16301af to 4afdfd9580 2025-04-07 02:32:51 +02:00 Compare
kjuulh force-pushed renovate/all from 4afdfd9580 to 319b6ffe93 2025-04-07 05:30:37 +02:00 Compare
kjuulh force-pushed renovate/all from 319b6ffe93 to b512bab2fc 2025-04-08 02:32:38 +02:00 Compare
kjuulh force-pushed renovate/all from b512bab2fc to 543fb53ff0 2025-04-08 05:33:16 +02:00 Compare
kjuulh force-pushed renovate/all from 543fb53ff0 to c76335f8c9 2025-04-09 02:32:45 +02:00 Compare
kjuulh force-pushed renovate/all from c76335f8c9 to 8412aa3754 2025-04-09 05:30:56 +02:00 Compare
kjuulh force-pushed renovate/all from 8412aa3754 to 05e77f8e57 2025-04-10 02:33:35 +02:00 Compare
kjuulh force-pushed renovate/all from 05e77f8e57 to ca402377d4 2025-04-10 05:31:12 +02:00 Compare
kjuulh force-pushed renovate/all from ca402377d4 to 5fab79cd2f 2025-04-11 02:33:02 +02:00 Compare
kjuulh force-pushed renovate/all from 5fab79cd2f to bed23919da 2025-04-11 05:31:28 +02:00 Compare
kjuulh force-pushed renovate/all from bed23919da to c1fd15bc88 2025-04-12 02:36:27 +02:00 Compare
kjuulh force-pushed renovate/all from c1fd15bc88 to 1b5a8098e7 2025-04-12 05:33:02 +02:00 Compare
kjuulh force-pushed renovate/all from 1b5a8098e7 to 3758d3365c 2025-04-13 02:34:03 +02:00 Compare
kjuulh force-pushed renovate/all from 3758d3365c to 9e1fff4a0e 2025-04-13 05:32:38 +02:00 Compare
kjuulh force-pushed renovate/all from 9e1fff4a0e to dd847ab81a 2025-04-14 02:31:57 +02:00 Compare
kjuulh force-pushed renovate/all from dd847ab81a to 2cddac16b6 2025-04-14 05:33:30 +02:00 Compare
kjuulh force-pushed renovate/all from 2cddac16b6 to c3a8199e2b 2025-04-15 02:36:24 +02:00 Compare
kjuulh force-pushed renovate/all from c3a8199e2b to ac5c5b4089 2025-04-15 05:31:44 +02:00 Compare
kjuulh force-pushed renovate/all from ac5c5b4089 to f574945be8 2025-04-16 02:33:07 +02:00 Compare
kjuulh force-pushed renovate/all from f574945be8 to 959e14105d 2025-04-16 05:31:23 +02:00 Compare
kjuulh force-pushed renovate/all from 959e14105d to f0c067f97b 2025-04-17 02:30:41 +02:00 Compare
kjuulh force-pushed renovate/all from f0c067f97b to 5e9c57c7a7 2025-04-17 05:30:47 +02:00 Compare
kjuulh force-pushed renovate/all from 5e9c57c7a7 to 386c536b3c 2025-04-18 02:32:59 +02:00 Compare
kjuulh force-pushed renovate/all from 386c536b3c to e46c2046cd 2025-04-18 05:30:23 +02:00 Compare
kjuulh force-pushed renovate/all from e46c2046cd to 8540801df8 2025-04-19 02:33:33 +02:00 Compare
kjuulh force-pushed renovate/all from 8540801df8 to e799ab7e14 2025-04-19 05:32:47 +02:00 Compare
kjuulh force-pushed renovate/all from e799ab7e14 to e2c11e65be 2025-04-20 02:32:39 +02:00 Compare
kjuulh force-pushed renovate/all from e2c11e65be to d2dae55628 2025-04-20 05:30:55 +02:00 Compare
kjuulh force-pushed renovate/all from d2dae55628 to bef8ad83f8 2025-04-21 02:32:43 +02:00 Compare
kjuulh force-pushed renovate/all from bef8ad83f8 to 816c9f1aa6 2025-04-21 05:30:34 +02:00 Compare
kjuulh force-pushed renovate/all from 816c9f1aa6 to 158d61fc6e 2025-04-22 02:35:04 +02:00 Compare
kjuulh force-pushed renovate/all from 158d61fc6e to dfef804a81 2025-04-22 05:32:12 +02:00 Compare
kjuulh force-pushed renovate/all from dfef804a81 to 5db7b1a3e1 2025-04-23 02:33:45 +02:00 Compare
kjuulh force-pushed renovate/all from 5db7b1a3e1 to c78b1c7868 2025-04-23 05:33:09 +02:00 Compare
kjuulh force-pushed renovate/all from c78b1c7868 to 048693b45d 2025-04-24 02:31:58 +02:00 Compare
kjuulh force-pushed renovate/all from 048693b45d to ffd4c58507 2025-04-24 05:31:18 +02:00 Compare
kjuulh force-pushed renovate/all from ffd4c58507 to 2f78d6e79f 2025-04-25 02:33:56 +02:00 Compare
kjuulh force-pushed renovate/all from 2f78d6e79f to 384d11d5e1 2025-04-25 05:31:29 +02:00 Compare
kjuulh force-pushed renovate/all from 384d11d5e1 to 552b203c38 2025-04-26 02:34:24 +02:00 Compare
kjuulh force-pushed renovate/all from 552b203c38 to 698d90d5f4 2025-04-26 05:32:25 +02:00 Compare
kjuulh force-pushed renovate/all from 698d90d5f4 to fdcacf58cb 2025-04-27 02:32:08 +02:00 Compare
kjuulh force-pushed renovate/all from fdcacf58cb to 1cdd7d90b4 2025-04-27 05:31:35 +02:00 Compare
kjuulh force-pushed renovate/all from 1cdd7d90b4 to 7ae430b8d7 2025-04-28 02:33:30 +02:00 Compare
kjuulh force-pushed renovate/all from 7ae430b8d7 to 1773245660 2025-04-28 05:34:50 +02:00 Compare
kjuulh force-pushed renovate/all from 1773245660 to d0790ae05a 2025-04-29 02:36:58 +02:00 Compare
kjuulh force-pushed renovate/all from d0790ae05a to 8933adfa33 2025-04-29 05:35:16 +02:00 Compare
kjuulh force-pushed renovate/all from 8933adfa33 to f93829a3ec 2025-04-30 02:35:17 +02:00 Compare
kjuulh force-pushed renovate/all from f93829a3ec to 57865c8e1c 2025-04-30 05:32:42 +02:00 Compare
kjuulh force-pushed renovate/all from 57865c8e1c to bd45e37d34 2025-05-01 02:33:08 +02:00 Compare
kjuulh force-pushed renovate/all from bd45e37d34 to fa025b0e4e 2025-05-01 05:31:35 +02:00 Compare
kjuulh force-pushed renovate/all from fa025b0e4e to 2fce2fe4c9 2025-05-02 02:32:23 +02:00 Compare
kjuulh force-pushed renovate/all from 2fce2fe4c9 to 0be1b9f2a2 2025-05-07 02:34:46 +02:00 Compare
kjuulh force-pushed renovate/all from 0be1b9f2a2 to e64f43c71e 2025-05-07 05:33:26 +02:00 Compare
kjuulh force-pushed renovate/all from e64f43c71e to 455305ffe7 2025-05-08 02:32:53 +02:00 Compare
kjuulh force-pushed renovate/all from 455305ffe7 to 55d71d9694 2025-05-11 02:33:03 +02:00 Compare
kjuulh force-pushed renovate/all from 55d71d9694 to d229606cdf 2025-05-11 05:33:46 +02:00 Compare
kjuulh force-pushed renovate/all from d229606cdf to 5c6e5b7d38 2025-05-12 02:34:48 +02:00 Compare
kjuulh force-pushed renovate/all from 5c6e5b7d38 to ae44b5f6bd 2025-05-23 05:32:44 +02:00 Compare
kjuulh force-pushed renovate/all from ae44b5f6bd to 312a46ff1d 2025-05-24 02:34:38 +02:00 Compare
kjuulh force-pushed renovate/all from 312a46ff1d to 3d86248d47 2025-05-24 05:32:29 +02:00 Compare
kjuulh force-pushed renovate/all from 3d86248d47 to 54a03bb306 2025-05-25 02:33:57 +02:00 Compare
kjuulh force-pushed renovate/all from 54a03bb306 to 28f8d9e7a3 2025-05-25 05:33:47 +02:00 Compare
kjuulh force-pushed renovate/all from 28f8d9e7a3 to fee9cc1081 2025-05-26 02:33:15 +02:00 Compare
kjuulh force-pushed renovate/all from fee9cc1081 to b0a417c4df 2025-06-02 05:31:34 +02:00 Compare
kjuulh force-pushed renovate/all from b0a417c4df to 413d34a360 2025-06-04 02:35:06 +02:00 Compare
kjuulh force-pushed renovate/all from 413d34a360 to 8800f4062b 2025-06-10 02:39:16 +02:00 Compare
kjuulh force-pushed renovate/all from 8800f4062b to 67ae706cdd 2025-07-03 02:36:33 +02:00 Compare
kjuulh force-pushed renovate/all from 67ae706cdd to 00aed911ba 2025-07-05 02:43:51 +02:00 Compare
Author
Owner

⚠️ Artifact update problem

Renovate failed to update artifacts related to this branch. You probably do not want to merge this PR as-is.

♻ Renovate will retry this branch, including artifacts, only when one of the following happens:

  • any of the package files in this branch needs updating, or
  • the branch becomes conflicted, or
  • you click the rebase/retry checkbox if found above, or
  • you rename this PR's title to start with "rebase!" to trigger it manually

The artifact failure details are included below:

File name: Cargo.lock
Command failed: cargo update --config net.git-fetch-with-cli=true --manifest-path Cargo.toml --package leptos@0.7.4 --precise 0.8.14
error: package ID specification `leptos@0.7.4` did not match any packages
help: there are similar package ID specifications:

  leptos@0.8.2

File name: Cargo.lock
Command failed: cargo update --config net.git-fetch-with-cli=true --manifest-path crates/app/Cargo.toml --package reqwest@0.12.12 --precise 0.12.24
    Updating crates.io index
error: failed to select a version for `tower-http`.
    ... required by package `reqwest v0.12.24`
    ... which satisfies dependency `reqwest = "^0.12.11"` of package `app v0.1.0 (/tmp/renovate/repos/gitea/kjuulh/lebusiness-client/crates/app)`
    ... which satisfies path dependency `app` (locked to 0.1.0) of package `frontend v0.1.0 (/tmp/renovate/repos/gitea/kjuulh/lebusiness-client/crates/frontend)`
versions that meet the requirements `^0.6.5` are: 0.6.7, 0.6.6

all possible versions conflict with previously selected packages.

  previously selected package `tower-http v0.6.2`
    ... which satisfies dependency `tower-http = "^0.6"` (locked to 0.6.2) of package `lebusiness-client v0.1.0 (/tmp/renovate/repos/gitea/kjuulh/lebusiness-client/crates/lebusiness-client)`

failed to select a version for `tower-http` which could resolve this conflict

### ⚠️ Artifact update problem Renovate failed to update artifacts related to this branch. You probably do not want to merge this PR as-is. ♻ Renovate will retry this branch, including artifacts, only when one of the following happens: - any of the package files in this branch needs updating, or - the branch becomes conflicted, or - you click the rebase/retry checkbox if found above, or - you rename this PR's title to start with "rebase!" to trigger it manually The artifact failure details are included below: ##### File name: Cargo.lock ``` Command failed: cargo update --config net.git-fetch-with-cli=true --manifest-path Cargo.toml --package leptos@0.7.4 --precise 0.8.14 error: package ID specification `leptos@0.7.4` did not match any packages help: there are similar package ID specifications: leptos@0.8.2 ``` ##### File name: Cargo.lock ``` Command failed: cargo update --config net.git-fetch-with-cli=true --manifest-path crates/app/Cargo.toml --package reqwest@0.12.12 --precise 0.12.24 Updating crates.io index error: failed to select a version for `tower-http`. ... required by package `reqwest v0.12.24` ... which satisfies dependency `reqwest = "^0.12.11"` of package `app v0.1.0 (/tmp/renovate/repos/gitea/kjuulh/lebusiness-client/crates/app)` ... which satisfies path dependency `app` (locked to 0.1.0) of package `frontend v0.1.0 (/tmp/renovate/repos/gitea/kjuulh/lebusiness-client/crates/frontend)` versions that meet the requirements `^0.6.5` are: 0.6.7, 0.6.6 all possible versions conflict with previously selected packages. previously selected package `tower-http v0.6.2` ... which satisfies dependency `tower-http = "^0.6"` (locked to 0.6.2) of package `lebusiness-client v0.1.0 (/tmp/renovate/repos/gitea/kjuulh/lebusiness-client/crates/lebusiness-client)` failed to select a version for `tower-http` which could resolve this conflict ```
kjuulh force-pushed renovate/all from 00aed911ba to 3915ef3b6c 2025-11-13 03:14:21 +01:00 Compare
kjuulh force-pushed renovate/all from 3915ef3b6c to 12f23cc1a7 2025-11-28 05:37:16 +01:00 Compare
Some checks failed
renovate/artifacts Artifact file update failure
This pull request can be merged automatically.
You are not authorized to merge this pull request.
View command line instructions

Checkout

From your project repository, check out a new branch and test the changes.
git fetch -u origin renovate/all:renovate/all
git checkout renovate/all
Sign in to join this conversation.
No Reviewers
No Label
1 Participants
Notifications
Due Date
No due date set.
Dependencies

No dependencies set.

Reference: kjuulh/lebusiness-client#1
No description provided.