Struct aws_sdk_cloudfront::ByteStream [−][src]
pub struct ByteStream(_);Expand description
Stream of binary data
ByteStream wraps a stream of binary data for ease of use.
Getting data out of a ByteStream
ByteStream provides two primary mechanisms for accessing the data:
- 
With .collect():.collect()reads the complete ByteStream into memory and stores it inAggregatedBytes, a non-contiguous ByteBuffer.use aws_smithy_http::byte_stream::{ByteStream, AggregatedBytes}; use aws_smithy_http::body::SdkBody; use bytes::Buf; async fn example() { let stream = ByteStream::new(SdkBody::from("hello! This is some data")); // Load data from the stream into memory: let data = stream.collect().await.expect("error reading data"); // collect returns a `bytes::Buf`: println!("first chunk: {:?}", data.chunk()); }
- 
Via impl Stream:Note: An import of StreamExtis required to usetry_next().For use-cases where holding the entire ByteStream in memory is unnecessary, use the Streamimplementation:use aws_smithy_http::byte_stream::{ByteStream, AggregatedBytes, Error}; use aws_smithy_http::body::SdkBody; use tokio_stream::StreamExt; async fn example() -> Result<(), Error> { let mut stream = ByteStream::from(vec![1, 2, 3, 4, 5, 99]); let mut digest = crc32::Digest::new(); while let Some(bytes) = stream.try_next().await? { digest.write(&bytes); } println!("digest: {}", digest.finish()); Ok(()) }
Getting data into a ByteStream
ByteStreams can be created in one of three ways:
- 
From in-memory binary data: ByteStreams created from in-memory data are always retryable. Data will be converted into Bytesenabling a cheap clone during retries.use bytes::Bytes; use aws_smithy_http::byte_stream::ByteStream; let stream = ByteStream::from(vec![1,2,3]); let stream = ByteStream::from(Bytes::from_static(b"hello!"));
- 
From a file: ByteStreams created from a path can be retried. A new file descriptor will be opened if a retry occurs. #[cfg(feature = "tokio-rt")] use aws_smithy_http::byte_stream::ByteStream; let stream = ByteStream::from_path("big_file.csv");
- 
From an SdkBodydirectly: For more advanced / custom use cases, a ByteStream can be created directly from an SdkBody. When created from an SdkBody, care must be taken to ensure retriability. An SdkBody is retryable when constructed from in-memory data or when usingSdkBody::retryable.use aws_smithy_http::byte_stream::ByteStream; use aws_smithy_http::body::SdkBody; use bytes::Bytes; let (mut tx, channel_body) = hyper::Body::channel(); // this will not be retryable because the SDK has no way to replay this stream let stream = ByteStream::new(SdkBody::from(channel_body)); tx.send_data(Bytes::from_static(b"hello world!")); tx.send_data(Bytes::from_static(b"hello again!")); // NOTE! You must ensure that `tx` is dropped to ensure that EOF is sent
Implementations
Consumes the ByteStream, returning the wrapped SdkBody
Read all the data from this ByteStream into memory
If an error in the underlying stream is encountered, ByteStreamError is returned.
Data is read into an AggregatedBytes that stores data non-contiguously as it was received
over the network. If a contiguous slice is required, use into_bytes().
use bytes::Bytes;
use aws_smithy_http::body;
use aws_smithy_http::body::SdkBody;
use aws_smithy_http::byte_stream::{ByteStream, Error};
async fn get_data() {
    let stream = ByteStream::new(SdkBody::from("hello!"));
    let data: Result<Bytes, Error> = stream.collect().await.map(|data| data.into_bytes());
}Create a ByteStream that streams data from the filesystem
This function creates a retryable ByteStream for a given path. The returned ByteStream
will provide a size hint when used as an HTTP body. If the request fails, the read will
begin again by reloading the file handle.
Warning
The contents of the file MUST not change during retries. The length & checksum of the file will be cached. If the contents of the file change, the operation will almost certainly fail.
Furthermore, a partial write MAY seek in the file and resume from the previous location.
Examples
use aws_smithy_http::byte_stream::ByteStream;
use std::path::Path;
 async fn make_bytestream() -> ByteStream {
    ByteStream::from_path("docs/rows.csv").await.expect("file should be readable")
}Create a ByteStream from a file
NOTE: This will NOT result in a retryable ByteStream. For a ByteStream that can be retried in the case of
upstream failures, use ByteStream::from_path
Trait Implementations
Returns the “default value” for a type. Read more
Performs the conversion.
Construct a retryable ByteStream from a Vec<u8>.
This will convert the Vec<u8> into bytes::Bytes to enable efficient
retries.
pub fn poll_next(
    self: Pin<&mut ByteStream>, 
    cx: &mut Context<'_>
) -> Poll<Option<<ByteStream as Stream>::Item>>
pub fn poll_next(
    self: Pin<&mut ByteStream>, 
    cx: &mut Context<'_>
) -> Poll<Option<<ByteStream as Stream>::Item>>
Attempt to pull out the next value of this stream, registering the
current task for wakeup if the value is not yet available, and returning
None if the stream is exhausted. Read more
Auto Trait Implementations
impl !RefUnwindSafe for ByteStream
impl Send for ByteStream
impl Sync for ByteStream
impl !UnwindSafe for ByteStream
Blanket Implementations
Mutably borrows from an owned value. Read more
impl<T> StreamExt for T where
    T: Stream + ?Sized, 
impl<T> StreamExt for T where
    T: Stream + ?Sized, 
Creates a future that resolves to the next item in the stream. Read more
fn into_future(self) -> StreamFuture<Self> where
    Self: Unpin, 
fn into_future(self) -> StreamFuture<Self> where
    Self: Unpin, 
Maps this stream’s items to a different type, returning a new stream of the resulting type. Read more
fn enumerate(self) -> Enumerate<Self>
fn enumerate(self) -> Enumerate<Self>
Creates a stream which gives the current iteration count as well as the next value. Read more
Filters the values produced by this stream according to the provided asynchronous predicate. Read more
fn filter_map<Fut, T, F>(self, f: F) -> FilterMap<Self, Fut, F> where
    F: FnMut(Self::Item) -> Fut,
    Fut: Future<Output = Option<T>>, 
fn filter_map<Fut, T, F>(self, f: F) -> FilterMap<Self, Fut, F> where
    F: FnMut(Self::Item) -> Fut,
    Fut: Future<Output = Option<T>>, 
Filters the values produced by this stream while simultaneously mapping them to a different type according to the provided asynchronous closure. Read more
Computes from this stream’s items new items of a different type using an asynchronous closure. Read more
Transforms a stream into a collection, returning a future representing the result of that computation. Read more
Converts a stream of pairs into a future, which resolves to pair of containers. Read more
fn concat(self) -> Concat<Self> where
    Self::Item: Extend<<Self::Item as IntoIterator>::Item>,
    Self::Item: IntoIterator,
    Self::Item: Default, 
fn concat(self) -> Concat<Self> where
    Self::Item: Extend<<Self::Item as IntoIterator>::Item>,
    Self::Item: IntoIterator,
    Self::Item: Default, 
Concatenate all items of a stream into a single extendable destination, returning a future representing the end result. Read more
fn count(self) -> Count<Self>
fn count(self) -> Count<Self>
Drives the stream to completion, counting the number of items. Read more
Execute an accumulating asynchronous computation over a stream, collecting all the values into one final result. Read more
Execute predicate over asynchronous stream, and return true if any element in stream satisfied a predicate. Read more
Execute predicate over asynchronous stream, and return true if all element in stream satisfied a predicate. Read more
fn flatten(self) -> Flatten<Self> where
    Self::Item: Stream, 
fn flatten(self) -> Flatten<Self> where
    Self::Item: Stream, 
Flattens a stream of streams into just one continuous stream. Read more
Maps a stream like [StreamExt::map] but flattens nested Streams. Read more
Combinator similar to [StreamExt::fold] that holds internal state
and produces a new stream. Read more
fn skip_while<Fut, F>(self, f: F) -> SkipWhile<Self, Fut, F> where
    F: FnMut(&Self::Item) -> Fut,
    Fut: Future<Output = bool>, 
fn skip_while<Fut, F>(self, f: F) -> SkipWhile<Self, Fut, F> where
    F: FnMut(&Self::Item) -> Fut,
    Fut: Future<Output = bool>, 
Skip elements on this stream while the provided asynchronous predicate
resolves to true. Read more
fn take_while<Fut, F>(self, f: F) -> TakeWhile<Self, Fut, F> where
    F: FnMut(&Self::Item) -> Fut,
    Fut: Future<Output = bool>, 
fn take_while<Fut, F>(self, f: F) -> TakeWhile<Self, Fut, F> where
    F: FnMut(&Self::Item) -> Fut,
    Fut: Future<Output = bool>, 
Take elements from this stream while the provided asynchronous predicate
resolves to true. Read more
fn take_until<Fut>(self, fut: Fut) -> TakeUntil<Self, Fut> where
    Fut: Future, 
fn take_until<Fut>(self, fut: Fut) -> TakeUntil<Self, Fut> where
    Fut: Future, 
Take elements from this stream until the provided future resolves. Read more
Runs this stream to completion, executing the provided asynchronous closure for each element on the stream. Read more
Runs this stream to completion, executing the provided asynchronous closure for each element on the stream concurrently as elements become available. Read more
Creates a new stream of at most n items of the underlying stream. Read more
Creates a new stream which skips n items of the underlying stream. Read more
fn fuse(self) -> Fuse<Self>
fn fuse(self) -> Fuse<Self>
fn catch_unwind(self) -> CatchUnwind<Self> where
    Self: UnwindSafe, 
fn catch_unwind(self) -> CatchUnwind<Self> where
    Self: UnwindSafe, 
Catches unwinding panics while polling the stream. Read more
Wrap the stream in a Box, pinning it. Read more
fn boxed_local<'a>(self) -> Pin<Box<dyn Stream<Item = Self::Item> + 'a, Global>> where
    Self: 'a, 
fn boxed_local<'a>(self) -> Pin<Box<dyn Stream<Item = Self::Item> + 'a, Global>> where
    Self: 'a, 
Wrap the stream in a Box, pinning it. Read more
An adaptor for creating a buffered list of pending futures. Read more
fn buffer_unordered(self, n: usize) -> BufferUnordered<Self> where
    Self::Item: Future, 
fn buffer_unordered(self, n: usize) -> BufferUnordered<Self> where
    Self::Item: Future, 
An adaptor for creating a buffered list of pending futures (unordered). Read more
fn zip<St>(self, other: St) -> Zip<Self, St> where
    St: Stream, 
fn zip<St>(self, other: St) -> Zip<Self, St> where
    St: Stream, 
An adapter for zipping two streams together. Read more
fn chain<St>(self, other: St) -> Chain<Self, St> where
    St: Stream<Item = Self::Item>, 
fn chain<St>(self, other: St) -> Chain<Self, St> where
    St: Stream<Item = Self::Item>, 
Adapter for chaining two streams. Read more
An adaptor for chunking up items of the stream inside a vector. Read more
fn ready_chunks(self, capacity: usize) -> ReadyChunks<Self>
fn ready_chunks(self, capacity: usize) -> ReadyChunks<Self>
An adaptor for chunking up ready items of the stream inside a vector. Read more
Do something with each item of this stream, afterwards passing it on. Read more
fn left_stream<B>(self) -> Either<Self, B> where
    B: Stream<Item = Self::Item>, 
fn left_stream<B>(self) -> Either<Self, B> where
    B: Stream<Item = Self::Item>, 
Wrap this stream in an Either stream, making it the left-hand variant
of that Either. Read more
fn right_stream<B>(self) -> Either<B, Self> where
    B: Stream<Item = Self::Item>, 
fn right_stream<B>(self) -> Either<B, Self> where
    B: Stream<Item = Self::Item>, 
Wrap this stream in an Either stream, making it the right-hand variant
of that Either. Read more
fn poll_next_unpin(&mut self, cx: &mut Context<'_>) -> Poll<Option<Self::Item>> where
    Self: Unpin, 
fn poll_next_unpin(&mut self, cx: &mut Context<'_>) -> Poll<Option<Self::Item>> where
    Self: Unpin, 
fn select_next_some(&mut self) -> SelectNextSome<'_, Self> where
    Self: Unpin + FusedStream, 
fn select_next_some(&mut self) -> SelectNextSome<'_, Self> where
    Self: Unpin + FusedStream, 
Consumes and returns the next value in the stream or None if the
stream is finished. Read more
Consumes and returns the next item in the stream. If an error is encountered before the next item, the error is returned instead. Read more
Maps this stream’s items to a different type, returning a new stream of the resulting type. Read more
Combine two streams into one by interleaving the output of both as it is produced. Read more
Filters the values produced by this stream according to the provided predicate. Read more
Filters the values produced by this stream while simultaneously mapping them to a different type according to the provided closure. Read more
Creates a new stream of at most n items of the underlying stream. Read more
Take elements from this stream while the provided predicate
resolves to true. Read more
Creates a new stream that will skip the n first items of the
underlying stream. Read more
Skip elements from the underlying stream while the provided predicate
resolves to true. Read more
Tests if every element of the stream matches a predicate. Read more
Tests if any element of the stream matches a predicate. Read more
Combine two streams into one by first returning all values from the first stream then all values from the second stream. Read more
A combinator that applies a function to every element in a stream producing a single, final value. Read more
Drain stream pushing all emitted values into a collection. Read more
Applies a per-item timeout to the passed stream. Read more
impl<S> TryStreamExt for S where
    S: TryStream + ?Sized, 
impl<S> TryStreamExt for S where
    S: TryStream + ?Sized, 
Wraps the current stream in a new stream which converts the error type into the one provided. Read more
Wraps the current stream in a new stream which maps the success value using the provided closure. Read more
Wraps the current stream in a new stream which maps the error value using the provided closure. Read more
Chain on a computation for when a value is ready, passing the successful
results to the provided closure f. Read more
Chain on a computation for when an error happens, passing the
erroneous result to the provided closure f. Read more
fn inspect_ok<F>(self, f: F) -> InspectOk<Self, F> where
    F: FnMut(&Self::Ok), 
fn inspect_ok<F>(self, f: F) -> InspectOk<Self, F> where
    F: FnMut(&Self::Ok), 
Do something with the success value of this stream, afterwards passing it on. Read more
fn inspect_err<F>(self, f: F) -> InspectErr<Self, F> where
    F: FnMut(&Self::Error), 
fn inspect_err<F>(self, f: F) -> InspectErr<Self, F> where
    F: FnMut(&Self::Error), 
Do something with the error value of this stream, afterwards passing it on. Read more
fn into_stream(self) -> IntoStream<Self>
fn into_stream(self) -> IntoStream<Self>
Creates a future that attempts to resolve the next item in the stream. If an error is encountered before the next item, the error is returned instead. Read more
fn try_for_each<Fut, F>(self, f: F) -> TryForEach<Self, Fut, F> where
    F: FnMut(Self::Ok) -> Fut,
    Fut: TryFuture<Ok = (), Error = Self::Error>, 
fn try_for_each<Fut, F>(self, f: F) -> TryForEach<Self, Fut, F> where
    F: FnMut(Self::Ok) -> Fut,
    Fut: TryFuture<Ok = (), Error = Self::Error>, 
Attempts to run this stream to completion, executing the provided asynchronous closure for each element on the stream. Read more
fn try_skip_while<Fut, F>(self, f: F) -> TrySkipWhile<Self, Fut, F> where
    F: FnMut(&Self::Ok) -> Fut,
    Fut: TryFuture<Ok = bool, Error = Self::Error>, 
fn try_skip_while<Fut, F>(self, f: F) -> TrySkipWhile<Self, Fut, F> where
    F: FnMut(&Self::Ok) -> Fut,
    Fut: TryFuture<Ok = bool, Error = Self::Error>, 
Skip elements on this stream while the provided asynchronous predicate
resolves to true. Read more
fn try_take_while<Fut, F>(self, f: F) -> TryTakeWhile<Self, Fut, F> where
    F: FnMut(&Self::Ok) -> Fut,
    Fut: TryFuture<Ok = bool, Error = Self::Error>, 
fn try_take_while<Fut, F>(self, f: F) -> TryTakeWhile<Self, Fut, F> where
    F: FnMut(&Self::Ok) -> Fut,
    Fut: TryFuture<Ok = bool, Error = Self::Error>, 
Take elements on this stream while the provided asynchronous predicate
resolves to true. Read more
Attempts to run this stream to completion, executing the provided asynchronous closure for each element on the stream concurrently as elements become available, exiting as soon as an error occurs. Read more
fn try_collect<C>(self) -> TryCollect<Self, C> where
    C: Default + Extend<Self::Ok>, 
fn try_collect<C>(self) -> TryCollect<Self, C> where
    C: Default + Extend<Self::Ok>, 
Attempt to transform a stream into a collection, returning a future representing the result of that computation. Read more
fn try_chunks(self, capacity: usize) -> TryChunks<Self>
fn try_chunks(self, capacity: usize) -> TryChunks<Self>
An adaptor for chunking up successful items of the stream inside a vector. Read more
fn try_filter<Fut, F>(self, f: F) -> TryFilter<Self, Fut, F> where
    Fut: Future<Output = bool>,
    F: FnMut(&Self::Ok) -> Fut, 
fn try_filter<Fut, F>(self, f: F) -> TryFilter<Self, Fut, F> where
    Fut: Future<Output = bool>,
    F: FnMut(&Self::Ok) -> Fut, 
Attempt to filter the values produced by this stream according to the provided asynchronous closure. Read more
fn try_filter_map<Fut, F, T>(self, f: F) -> TryFilterMap<Self, Fut, F> where
    Fut: TryFuture<Ok = Option<T>, Error = Self::Error>,
    F: FnMut(Self::Ok) -> Fut, 
fn try_filter_map<Fut, F, T>(self, f: F) -> TryFilterMap<Self, Fut, F> where
    Fut: TryFuture<Ok = Option<T>, Error = Self::Error>,
    F: FnMut(Self::Ok) -> Fut, 
Attempt to filter the values produced by this stream while simultaneously mapping them to a different type according to the provided asynchronous closure. Read more
fn try_flatten(self) -> TryFlatten<Self> where
    Self::Ok: TryStream,
    <Self::Ok as TryStream>::Error: From<Self::Error>, 
fn try_flatten(self) -> TryFlatten<Self> where
    Self::Ok: TryStream,
    <Self::Ok as TryStream>::Error: From<Self::Error>, 
Flattens a stream of streams into just one continuous stream. Read more
Attempt to execute an accumulating asynchronous computation over a stream, collecting all the values into one final result. Read more
fn try_concat(self) -> TryConcat<Self> where
    Self::Ok: Extend<<Self::Ok as IntoIterator>::Item>,
    Self::Ok: IntoIterator,
    Self::Ok: Default, 
fn try_concat(self) -> TryConcat<Self> where
    Self::Ok: Extend<<Self::Ok as IntoIterator>::Item>,
    Self::Ok: IntoIterator,
    Self::Ok: Default, 
Attempt to concatenate all items of a stream into a single extendable destination, returning a future representing the end result. Read more
fn try_buffer_unordered(self, n: usize) -> TryBufferUnordered<Self> where
    Self::Ok: TryFuture,
    <Self::Ok as TryFuture>::Error == Self::Error, 
fn try_buffer_unordered(self, n: usize) -> TryBufferUnordered<Self> where
    Self::Ok: TryFuture,
    <Self::Ok as TryFuture>::Error == Self::Error, 
Attempt to execute several futures from a stream concurrently (unordered). Read more
fn try_buffered(self, n: usize) -> TryBuffered<Self> where
    Self::Ok: TryFuture,
    <Self::Ok as TryFuture>::Error == Self::Error, 
fn try_buffered(self, n: usize) -> TryBuffered<Self> where
    Self::Ok: TryFuture,
    <Self::Ok as TryFuture>::Error == Self::Error, 
Attempt to execute several futures from a stream concurrently. Read more
Attaches the provided Subscriber to this type, returning a
WithDispatch wrapper. Read more
Attaches the current default Subscriber to this type, returning a
WithDispatch wrapper. Read more
