From 99271e9ce18d9e775b4f58e2a4b3cf2c440b13af Mon Sep 17 00:00:00 2001 From: alecmocatta Date: Sun, 26 Jul 2020 19:33:54 +0100 Subject: [PATCH 1/4] use reexported amadeus crates in amadeus-derive --- amadeus-derive/src/lib.rs | 10 +++++----- src/lib.rs | 20 ++++++++++++++++++++ 2 files changed, 25 insertions(+), 5 deletions(-) diff --git a/amadeus-derive/src/lib.rs b/amadeus-derive/src/lib.rs index 564f3b4a..e9a4e324 100644 --- a/amadeus-derive/src/lib.rs +++ b/amadeus-derive/src/lib.rs @@ -262,7 +262,7 @@ fn impl_struct( let mut parquet_derives = None; if cfg!(feature = "parquet") { parquet_includes = Some(quote! { - pub use ::amadeus_parquet::derive::{ + pub use #amadeus_path::amadeus_parquet::derive::{ ParquetData, Repetition, ColumnReader, ParquetError, ParquetResult, ParquetSchema, Reader, DisplaySchemaGroup, ColumnPath, Type }; }); @@ -384,7 +384,7 @@ fn impl_struct( let mut postgres_derives = None; if cfg!(feature = "postgres") { postgres_includes = Some(quote! { - pub use ::amadeus_postgres::{Names,read_be_i32,read_value,_internal as postgres,PostgresData}; + pub use #amadeus_path::amadeus_postgres::{Names,read_be_i32,read_value,_internal as postgres,PostgresData}; }); postgres_derives = Some(quote! { #[automatically_derived] @@ -436,7 +436,7 @@ fn impl_struct( let mut serde_derives = None; if cfg!(feature = "serde") { serde_includes = Some(quote! { - pub use ::amadeus_serde::{SerdeData,_internal::{Serialize, Deserialize, Serializer, Deserializer}}; + pub use #amadeus_path::amadeus_serde::{SerdeData, _internal::{Serialize, Deserialize, Serializer, Deserializer}}; pub use #amadeus_path::data::serde_data; }); serde_derives = Some(quote! { @@ -471,8 +471,8 @@ fn impl_struct( #parquet_includes #postgres_includes #serde_includes - pub use ::amadeus_core::util::Wrapper; - pub use ::amadeus_types::{AmadeusOrd, Data as CoreData, DowncastFrom, Downcast, DowncastError, Value, Group, SchemaIncomplete, ListVec, __internal::{Serialize as Serialize_, Deserialize as Deserialize_, Serializer as Serializer_, Deserializer as Deserializer_, SerializeTuple, Error as SerdeError, Visitor, SeqAccess}}; + pub use #amadeus_path::amadeus_core::util::Wrapper; + pub use #amadeus_path::amadeus_types::{AmadeusOrd, Data as CoreData, DowncastFrom, Downcast, DowncastError, Value, Group, SchemaIncomplete, ListVec, __internal::{Serialize as Serialize_, Deserialize as Deserialize_, Serializer as Serializer_, Deserializer as Deserializer_, SerializeTuple, Error as SerdeError, Visitor, SeqAccess}}; pub use #amadeus_path::data::Data; pub use ::std::{borrow::ToOwned, boxed::Box, clone::Clone, collections::HashMap, convert::{From, Into}, cmp::{Ordering, PartialEq}, default::Default, error::Error, fmt::{self, Debug, Write}, format, hash::{Hash, Hasher}, iter::{ExactSizeIterator, IntoIterator, Iterator}, marker::{PhantomData, Send, Sized, Sync}, result::Result::{self, Ok, Err}, string::String, panic, vec, vec::{IntoIter, Vec}, option::Option::{self, Some, None}}; } diff --git a/src/lib.rs b/src/lib.rs index 28559e96..e8b646ab 100644 --- a/src/lib.rs +++ b/src/lib.rs @@ -87,3 +87,23 @@ pub mod prelude { }, par_pipe::ParallelPipe, par_stream::Identity, pool::ThreadPool, source::*, Data, FromParallelStream, IntoParallelStream, IteratorExt, List, ParallelStream, Value }; } + +#[cfg(feature = "aws")] +#[doc(hidden)] +pub use amadeus_aws; +#[cfg(feature = "commoncrawl")] +#[doc(hidden)] +pub use amadeus_commoncrawl; +#[doc(hidden)] +pub use amadeus_core; +#[cfg(feature = "parquet")] +#[doc(hidden)] +pub use amadeus_parquet; +#[cfg(feature = "postgres")] +#[doc(hidden)] +pub use amadeus_postgres; +#[cfg(feature = "amadeus-serde")] +#[doc(hidden)] +pub use amadeus_serde; +#[doc(hidden)] +pub use amadeus_types; From 4716cefd71079a2e0f7339df825410363c7bf8f3 Mon Sep 17 00:00:00 2001 From: alecmocatta Date: Sun, 26 Jul 2020 19:35:35 +0100 Subject: [PATCH 2/4] bump to latest rust on ci --- amadeus-aws/src/cloudfront.rs | 10 +- amadeus-commoncrawl/src/lib.rs | 10 +- amadeus-core/src/lib.rs | 1 - amadeus-core/src/par_sink/combine.rs | 2 + amadeus-core/src/par_sink/combiner.rs | 2 +- amadeus-core/src/par_sink/group_by.rs | 38 +++--- amadeus-core/src/par_sink/tuple.rs | 2 +- amadeus-core/src/util.rs | 57 +------- amadeus-parquet/src/lib.rs | 79 +++++------ amadeus-postgres/src/lib.rs | 10 +- amadeus-serde/src/csv.rs | 10 +- amadeus-serde/src/json.rs | 10 +- amadeus-types/src/value.rs | 180 +++++--------------------- azure-pipelines.yml | 8 +- 14 files changed, 117 insertions(+), 302 deletions(-) diff --git a/amadeus-aws/src/cloudfront.rs b/amadeus-aws/src/cloudfront.rs index 63e91f30..62b12055 100644 --- a/amadeus-aws/src/cloudfront.rs +++ b/amadeus-aws/src/cloudfront.rs @@ -53,9 +53,9 @@ impl Cloudfront { } } -#[cfg(not(all(nightly, not(doc))))] +#[cfg(not(nightly))] type Output = std::pin::Pin> + Send>>; -#[cfg(all(nightly, not(doc)))] +#[cfg(nightly)] type Output = impl Stream> + Send; FnMutNamed! { @@ -103,7 +103,7 @@ FnMutNamed! { } .flatten_stream() .map(|x: Result, _>| x.and_then(identity)); - #[cfg(not(all(nightly, not(doc))))] + #[cfg(not(nightly))] let ret = ret.boxed(); ret } @@ -114,13 +114,13 @@ impl Source for Cloudfront { type Error = AwsError; type ParStream = DistParStream; - #[cfg(not(all(nightly, not(doc))))] + #[cfg(not(nightly))] #[allow(clippy::type_complexity)] type DistStream = amadeus_core::par_stream::FlatMap< amadeus_core::into_par_stream::IterDistStream>, Closure, >; - #[cfg(all(nightly, not(doc)))] + #[cfg(nightly)] type DistStream = impl DistributedStream>; fn par_stream(self) -> Self::ParStream { diff --git a/amadeus-commoncrawl/src/lib.rs b/amadeus-commoncrawl/src/lib.rs index 2f899f72..f0115674 100644 --- a/amadeus-commoncrawl/src/lib.rs +++ b/amadeus-commoncrawl/src/lib.rs @@ -80,9 +80,9 @@ impl CommonCrawl { } } -#[cfg(not(all(nightly, not(doc))))] +#[cfg(not(nightly))] type Output = std::pin::Pin, io::Error>> + Send>>; -#[cfg(all(nightly, not(doc)))] +#[cfg(nightly)] type Output = impl Stream, io::Error>> + Send; FnMutNamed! { @@ -99,7 +99,7 @@ FnMutNamed! { WarcParser::new(body) } .flatten_stream(); - #[cfg(not(all(nightly, not(doc))))] + #[cfg(not(nightly))] let ret = ret.boxed(); ret } @@ -110,13 +110,13 @@ impl Source for CommonCrawl { type Error = io::Error; type ParStream = DistParStream; - #[cfg(not(all(nightly, not(doc))))] + #[cfg(not(nightly))] #[allow(clippy::type_complexity)] type DistStream = amadeus_core::par_stream::FlatMap< amadeus_core::into_par_stream::IterDistStream>, Closure, >; - #[cfg(all(nightly, not(doc)))] + #[cfg(nightly)] type DistStream = impl DistributedStream>; fn par_stream(self) -> Self::ParStream { diff --git a/amadeus-core/src/lib.rs b/amadeus-core/src/lib.rs index 65b552c3..1548eba0 100644 --- a/amadeus-core/src/lib.rs +++ b/amadeus-core/src/lib.rs @@ -66,7 +66,6 @@ macro_rules! impl_par_dist_rename { IntoParallelStream IntoDistributedStream ParStream DistStream Send ProcessSend - ImplParallelStream ImplDistributedStream IterParStream IterDistStream into_par_stream into_dist_stream par_stream dist_stream diff --git a/amadeus-core/src/par_sink/combine.rs b/amadeus-core/src/par_sink/combine.rs index a11c713f..1baf18da 100644 --- a/amadeus-core/src/par_sink/combine.rs +++ b/amadeus-core/src/par_sink/combine.rs @@ -1,3 +1,5 @@ +#![allow(clippy::option_if_let_else)] + use derive_new::new; use educe::Educe; use serde::{Deserialize, Serialize}; diff --git a/amadeus-core/src/par_sink/combiner.rs b/amadeus-core/src/par_sink/combiner.rs index 187e0813..6394395c 100644 --- a/amadeus-core/src/par_sink/combiner.rs +++ b/amadeus-core/src/par_sink/combiner.rs @@ -1,4 +1,4 @@ -#![allow(unused_imports,clippy::single_component_path_imports)] +#![allow(unused_imports, clippy::single_component_path_imports, clippy::option_if_let_else)] use super::FolderSync; diff --git a/amadeus-core/src/par_sink/group_by.rs b/amadeus-core/src/par_sink/group_by.rs index 370fc2ee..b19e484a 100644 --- a/amadeus-core/src/par_sink/group_by.rs +++ b/amadeus-core/src/par_sink/group_by.rs @@ -181,15 +181,16 @@ where Sum2::A((k, u, r)) => { let waker = cx.waker(); let stream = stream::poll_fn(|cx| { - if let Some(u) = u.take() { - Poll::Ready(Some(u)) - } else { - let waker_ = cx.waker(); - if !waker.will_wake(waker_) { - waker_.wake_by_ref(); - } - Poll::Pending - } + u.take().map_or_else( + || { + let waker_ = cx.waker(); + if !waker.will_wake(waker_) { + waker_.wake_by_ref(); + } + Poll::Pending + }, + |u| Poll::Ready(Some(u)), + ) }) .fuse() .pipe(self_.pipe.as_mut()); @@ -332,15 +333,16 @@ where let mut v = Some(v); let waker = cx.waker(); let stream = stream::poll_fn(|cx| { - if let Some(v) = v.take() { - Poll::Ready(Some(v)) - } else { - let waker_ = cx.waker(); - if !waker.will_wake(waker_) { - waker_.wake_by_ref(); - } - Poll::Pending - } + v.take().map_or_else( + || { + let waker_ = cx.waker(); + if !waker.will_wake(waker_) { + waker_.wake_by_ref(); + } + Poll::Pending + }, + |v| Poll::Ready(Some(v)), + ) }) .fuse(); pin_mut!(stream); diff --git a/amadeus-core/src/par_sink/tuple.rs b/amadeus-core/src/par_sink/tuple.rs index eaf52232..837d8102 100644 --- a/amadeus-core/src/par_sink/tuple.rs +++ b/amadeus-core/src/par_sink/tuple.rs @@ -236,7 +236,7 @@ macro_rules! impl_tuple { $({ let stream = Peekable{stream:stream.as_mut(),peeked:&mut *self_.peeked}; pin_mut!(stream); - let stream_ = substream(cx, stream, |item| if let $enum::$t(_) = item { true } else { false }, |item| { progress = true; if let $enum::$t(item) = item { item } else { unreachable!() } }); + let stream_ = substream(cx, stream, |item| matches!(item, $enum::$t(_)), |item| { progress = true; if let $enum::$t(item) = item { item } else { unreachable!() } }); pin_mut!(stream_); if self_.ready.$num.is_none() { if let Poll::Ready(done) = self_.$t.as_mut().poll_forward(cx, stream_) { diff --git a/amadeus-core/src/util.rs b/amadeus-core/src/util.rs index e34bc714..36792962 100644 --- a/amadeus-core/src/util.rs +++ b/amadeus-core/src/util.rs @@ -6,7 +6,7 @@ use std::{ any::{Any, TypeId}, error, fmt, hash::{Hash, Hasher}, io, marker::PhantomData, pin::Pin, sync::Arc, task::{Context, Poll} }; -use crate::par_stream::{DistributedStream, ParallelStream, StreamTask}; +use crate::par_stream::{DistributedStream, ParallelStream}; pub struct ResultExpand(pub Result); impl IntoIterator for ResultExpand @@ -110,61 +110,6 @@ where } } -#[doc(hidden)] -pub struct ImplDistributedStream(PhantomData T>); -impl ImplDistributedStream { - pub fn new(_drop: U) -> Self - where - U: DistributedStream, - { - Self(PhantomData) - } -} -impl DistributedStream for ImplDistributedStream { - type Item = T; - type Task = ImplTask; - - fn size_hint(&self) -> (usize, Option) { - unreachable!() - } - fn next_task(self: Pin<&mut Self>, _cx: &mut Context) -> Poll> { - unreachable!() - } -} -impl ParallelStream for ImplDistributedStream { - type Item = T; - type Task = ImplTask; - - fn size_hint(&self) -> (usize, Option) { - unreachable!() - } - fn next_task(self: Pin<&mut Self>, _cx: &mut Context) -> Poll> { - unreachable!() - } -} - -#[doc(hidden)] -#[derive(Serialize, Deserialize)] -pub struct ImplTask(PhantomData T>); -impl StreamTask for ImplTask -where - T: 'static, -{ - type Item = T; - type Async = ImplTask; - - fn into_async(self) -> Self::Async { - self - } -} -impl Stream for ImplTask { - type Item = T; - - fn poll_next(self: Pin<&mut Self>, _cx: &mut Context) -> Poll> { - unreachable!() - } -} - // This is a dumb hack to avoid triggering https://github.com/rust-lang/rust/issues/48214 in amadeus-derive: see https://github.com/taiki-e/pin-project/issues/102#issuecomment-540472282 #[doc(hidden)] #[repr(transparent)] diff --git a/amadeus-parquet/src/lib.rs b/amadeus-parquet/src/lib.rs index 2d9504e1..8bad4b90 100644 --- a/amadeus-parquet/src/lib.rs +++ b/amadeus-parquet/src/lib.rs @@ -38,10 +38,10 @@ #[cfg(nightly)] extern crate test; -#[cfg(all(nightly, not(doc)))] +#[cfg(nightly)] mod internal; -#[cfg(all(nightly, not(doc)))] +#[cfg(nightly)] mod wrap { use super::internal; use async_trait::async_trait; @@ -106,58 +106,45 @@ mod wrap { <<::Partition as Partition>::Page as Page>::Error, >; - #[cfg(not(doc))] type ParStream = impl amadeus_core::par_stream::ParallelStream>; - #[cfg(doc)] - type ParStream = DistParStream< - amadeus_core::util::ImplDistributedStream>, - >; - #[cfg(not(doc))] type DistStream = impl DistributedStream>; - #[cfg(doc)] - type DistStream = - amadeus_core::util::ImplDistributedStream>; fn par_stream(self) -> Self::ParStream { DistParStream::new(self.dist_stream()) } #[allow(clippy::let_and_return)] fn dist_stream(self) -> Self::DistStream { - let ret = - self.partitions - .into_dist_stream() - .flat_map(FnMut!(|partition: F::Partition| async move { - Ok(stream::iter( - partition - .pages() - .await - .map_err(ParquetError::Partition)? - .into_iter(), - ) - .flat_map(|page| { - async move { - let mut buf = Vec::with_capacity(10 * 1024 * 1024); - let reader = Page::reader(page); - pin_mut!(reader); - let buf = PassError::new( - reader.read_to_end(&mut buf).await.map(|_| Cursor::new(buf)), - ); - Ok(stream::iter( - SerializedFileReader::new(buf)?.get_row_iter::(None)?, - )) - } - .map(ResultExpandIter::new) - .flatten_stream() - }) - .map(|row: Result, Self::Error>| Ok(row??))) - } - .map(ResultExpandIter::new) - .flatten_stream() - .map(|row: Result, Self::Error>| Ok(row??)))); - #[cfg(doc)] - let ret = amadeus_core::util::ImplDistributedStream::new(ret); - ret + self.partitions + .into_dist_stream() + .flat_map(FnMut!(|partition: F::Partition| async move { + Ok(stream::iter( + partition + .pages() + .await + .map_err(ParquetError::Partition)? + .into_iter(), + ) + .flat_map(|page| { + async move { + let mut buf = Vec::with_capacity(10 * 1024 * 1024); + let reader = Page::reader(page); + pin_mut!(reader); + let buf = PassError::new( + reader.read_to_end(&mut buf).await.map(|_| Cursor::new(buf)), + ); + Ok(stream::iter( + SerializedFileReader::new(buf)?.get_row_iter::(None)?, + )) + } + .map(ResultExpandIter::new) + .flatten_stream() + }) + .map(|row: Result, Self::Error>| Ok(row??))) + } + .map(ResultExpandIter::new) + .flatten_stream() + .map(|row: Result, Self::Error>| Ok(row??)))) } } @@ -371,5 +358,5 @@ mod wrap { } } } -#[cfg(all(nightly, not(doc)))] +#[cfg(nightly)] pub use wrap::*; diff --git a/amadeus-postgres/src/lib.rs b/amadeus-postgres/src/lib.rs index 70bd0da6..1d59112f 100644 --- a/amadeus-postgres/src/lib.rs +++ b/amadeus-postgres/src/lib.rs @@ -212,9 +212,9 @@ where } } -#[cfg(not(all(nightly, not(doc))))] +#[cfg(not(nightly))] type Output = Pin> + Send>>; -#[cfg(all(nightly, not(doc)))] +#[cfg(nightly)] type Output = impl Stream> + Send; FnMutNamed! { @@ -261,7 +261,7 @@ FnMutNamed! { }) } .flatten_stream(); - #[cfg(not(all(nightly, not(doc))))] + #[cfg(not(nightly))] let ret = ret.boxed(); ret } @@ -275,7 +275,7 @@ where type Error = PostgresError; type ParStream = DistParStream; - #[cfg(not(all(nightly, not(doc))))] + #[cfg(not(nightly))] #[allow(clippy::type_complexity)] type DistStream = amadeus_core::par_stream::FlatMap< amadeus_core::into_par_stream::IterDistStream< @@ -283,7 +283,7 @@ where >, Closure, >; - #[cfg(all(nightly, not(doc)))] + #[cfg(nightly)] type DistStream = impl DistributedStream>; fn par_stream(self) -> Self::ParStream { diff --git a/amadeus-serde/src/csv.rs b/amadeus-serde/src/csv.rs index 8c066aa8..b74995af 100644 --- a/amadeus-serde/src/csv.rs +++ b/amadeus-serde/src/csv.rs @@ -80,9 +80,9 @@ where } type Error = CsvError::Error, <

::Page as Page>::Error>; -#[cfg(not(all(nightly, not(doc))))] +#[cfg(not(nightly))] type Output = std::pin::Pin>>>>; -#[cfg(all(nightly, not(doc)))] +#[cfg(nightly)] type Output = impl Stream>>; FnMutNamed! { @@ -128,7 +128,7 @@ FnMutNamed! { .map(ResultExpandIter::new) .flatten_stream() .map(|row: Result>, Error>| Ok(row??)); - #[cfg(not(all(nightly, not(doc))))] + #[cfg(not(nightly))] let ret = ret.boxed_local(); ret } @@ -148,13 +148,13 @@ where >; type ParStream = DistParStream; - #[cfg(not(all(nightly, not(doc))))] + #[cfg(not(nightly))] #[allow(clippy::type_complexity)] type DistStream = amadeus_core::par_stream::FlatMap< amadeus_core::into_par_stream::IterDistStream>, Closure, >; - #[cfg(all(nightly, not(doc)))] + #[cfg(nightly)] type DistStream = impl DistributedStream>; fn par_stream(self) -> Self::ParStream { diff --git a/amadeus-serde/src/json.rs b/amadeus-serde/src/json.rs index dbc6c8a1..161176c2 100644 --- a/amadeus-serde/src/json.rs +++ b/amadeus-serde/src/json.rs @@ -39,9 +39,9 @@ where } type Error = JsonError::Error, <

::Page as Page>::Error>; -#[cfg(not(all(nightly, not(doc))))] +#[cfg(not(nightly))] type Output = std::pin::Pin>>>>; -#[cfg(all(nightly, not(doc)))] +#[cfg(nightly)] type Output = impl Stream>>; FnMutNamed! { @@ -82,7 +82,7 @@ FnMutNamed! { .map(ResultExpandIter::new) .flatten_stream() .map(|row: Result>, Error>| Ok(row??)); - #[cfg(not(all(nightly, not(doc))))] + #[cfg(not(nightly))] let ret = ret.boxed_local(); ret } @@ -102,13 +102,13 @@ where >; type ParStream = DistParStream; - #[cfg(not(all(nightly, not(doc))))] + #[cfg(not(nightly))] #[allow(clippy::type_complexity)] type DistStream = amadeus_core::par_stream::FlatMap< amadeus_core::into_par_stream::IterDistStream>, Closure, >; - #[cfg(all(nightly, not(doc)))] + #[cfg(nightly)] type DistStream = impl DistributedStream>; fn par_stream(self) -> Self::ParStream { diff --git a/amadeus-types/src/value.rs b/amadeus-types/src/value.rs index 22be2761..b33f39d9 100644 --- a/amadeus-types/src/value.rs +++ b/amadeus-types/src/value.rs @@ -447,11 +447,7 @@ impl Value { /// Returns true if the `Value` is an Bool. Returns false otherwise. pub fn is_bool(&self) -> bool { - if let Self::Bool(_) = self { - true - } else { - false - } + matches!(self, Self::Bool(_)) } /// If the `Value` is an Bool, return a reference to it. Returns Err otherwise. @@ -480,11 +476,7 @@ impl Value { /// Returns true if the `Value` is an U8. Returns false otherwise. pub fn is_u8(&self) -> bool { - if let Self::U8(_) = self { - true - } else { - false - } + matches!(self, Self::U8(_)) } /// If the `Value` is an U8, return a reference to it. Returns Err otherwise. @@ -513,11 +505,7 @@ impl Value { /// Returns true if the `Value` is an I8. Returns false otherwise. pub fn is_i8(&self) -> bool { - if let Self::I8(_) = self { - true - } else { - false - } + matches!(self, Self::I8(_)) } /// If the `Value` is an I8, return a reference to it. Returns Err otherwise. @@ -546,11 +534,7 @@ impl Value { /// Returns true if the `Value` is an U16. Returns false otherwise. pub fn is_u16(&self) -> bool { - if let Self::U16(_) = self { - true - } else { - false - } + matches!(self, Self::U16(_)) } /// If the `Value` is an U16, return a reference to it. Returns Err otherwise. @@ -579,11 +563,7 @@ impl Value { /// Returns true if the `Value` is an I16. Returns false otherwise. pub fn is_i16(&self) -> bool { - if let Self::I16(_) = self { - true - } else { - false - } + matches!(self, Self::I16(_)) } /// If the `Value` is an I16, return a reference to it. Returns Err otherwise. @@ -612,11 +592,7 @@ impl Value { /// Returns true if the `Value` is an U32. Returns false otherwise. pub fn is_u32(&self) -> bool { - if let Self::U32(_) = self { - true - } else { - false - } + matches!(self, Self::U32(_)) } /// If the `Value` is an U32, return a reference to it. Returns Err otherwise. @@ -645,11 +621,7 @@ impl Value { /// Returns true if the `Value` is an I32. Returns false otherwise. pub fn is_i32(&self) -> bool { - if let Self::I32(_) = self { - true - } else { - false - } + matches!(self, Self::I32(_)) } /// If the `Value` is an I32, return a reference to it. Returns Err otherwise. @@ -678,11 +650,7 @@ impl Value { /// Returns true if the `Value` is an U64. Returns false otherwise. pub fn is_u64(&self) -> bool { - if let Self::U64(_) = self { - true - } else { - false - } + matches!(self, Self::U64(_)) } /// If the `Value` is an U64, return a reference to it. Returns Err otherwise. @@ -711,11 +679,7 @@ impl Value { /// Returns true if the `Value` is an I64. Returns false otherwise. pub fn is_i64(&self) -> bool { - if let Self::I64(_) = self { - true - } else { - false - } + matches!(self, Self::I64(_)) } /// If the `Value` is an I64, return a reference to it. Returns Err otherwise. @@ -744,11 +708,7 @@ impl Value { /// Returns true if the `Value` is an F32. Returns false otherwise. pub fn is_f32(&self) -> bool { - if let Self::F32(_) = self { - true - } else { - false - } + matches!(self, Self::F32(_)) } /// If the `Value` is an F32, return a reference to it. Returns Err otherwise. @@ -777,11 +737,7 @@ impl Value { /// Returns true if the `Value` is an F64. Returns false otherwise. pub fn is_f64(&self) -> bool { - if let Self::F64(_) = self { - true - } else { - false - } + matches!(self, Self::F64(_)) } /// If the `Value` is an F64, return a reference to it. Returns Err otherwise. @@ -810,11 +766,7 @@ impl Value { /// Returns true if the `Value` is an Date. Returns false otherwise. pub fn is_date(&self) -> bool { - if let Self::Date(_) = self { - true - } else { - false - } + matches!(self, Self::Date(_)) } /// If the `Value` is an Date, return a reference to it. Returns Err otherwise. @@ -843,11 +795,7 @@ impl Value { /// Returns true if the `Value` is an DateWithoutTimezone. Returns false otherwise. pub fn is_date_without_timezone(&self) -> bool { - if let Self::DateWithoutTimezone(_) = self { - true - } else { - false - } + matches!(self, Self::DateWithoutTimezone(_)) } /// If the `Value` is an DateWithoutTimezone, return a reference to it. Returns Err otherwise. @@ -876,11 +824,7 @@ impl Value { /// Returns true if the `Value` is an Time. Returns false otherwise. pub fn is_time(&self) -> bool { - if let Self::Time(_) = self { - true - } else { - false - } + matches!(self, Self::Time(_)) } /// If the `Value` is an Time, return a reference to it. Returns Err otherwise. @@ -909,11 +853,7 @@ impl Value { /// Returns true if the `Value` is an TimeWithoutTimezone. Returns false otherwise. pub fn is_time_without_timezone(&self) -> bool { - if let Self::TimeWithoutTimezone(_) = self { - true - } else { - false - } + matches!(self, Self::TimeWithoutTimezone(_)) } /// If the `Value` is an TimeWithoutTimezone, return a reference to it. Returns Err otherwise. @@ -942,11 +882,7 @@ impl Value { /// Returns true if the `Value` is an DateTime. Returns false otherwise. pub fn is_date_time(&self) -> bool { - if let Self::DateTime(_) = self { - true - } else { - false - } + matches!(self, Self::DateTime(_)) } /// If the `Value` is an DateTime, return a reference to it. Returns Err otherwise. @@ -975,11 +911,7 @@ impl Value { /// Returns true if the `Value` is an DateTimeWithoutTimezone. Returns false otherwise. pub fn is_date_time_without_timezone(&self) -> bool { - if let Self::DateTimeWithoutTimezone(_) = self { - true - } else { - false - } + matches!(self, Self::DateTimeWithoutTimezone(_)) } /// If the `Value` is an DateTimeWithoutTimezone, return a reference to it. Returns Err otherwise. @@ -1008,11 +940,7 @@ impl Value { /// Returns true if the `Value` is an Timezone. Returns false otherwise. pub fn is_timezone(&self) -> bool { - if let Self::Timezone(_) = self { - true - } else { - false - } + matches!(self, Self::Timezone(_)) } /// If the `Value` is an Timezone, return a reference to it. Returns Err otherwise. @@ -1041,11 +969,7 @@ impl Value { /// Returns true if the `Value` is an Decimal. Returns false otherwise. pub fn is_decimal(&self) -> bool { - if let Self::Decimal(_) = self { - true - } else { - false - } + matches!(self, Self::Decimal(_)) } /// If the `Value` is an Decimal, return a reference to it. Returns Err otherwise. @@ -1074,11 +998,7 @@ impl Value { /// Returns true if the `Value` is an Bson. Returns false otherwise. pub fn is_bson(&self) -> bool { - if let Self::Bson(_) = self { - true - } else { - false - } + matches!(self, Self::Bson(_)) } /// If the `Value` is an Bson, return a reference to it. Returns Err otherwise. @@ -1107,11 +1027,7 @@ impl Value { /// Returns true if the `Value` is an String. Returns false otherwise. pub fn is_string(&self) -> bool { - if let Self::String(_) = self { - true - } else { - false - } + matches!(self, Self::String(_)) } /// If the `Value` is an String, return a reference to it. Returns Err otherwise. @@ -1140,11 +1056,7 @@ impl Value { /// Returns true if the `Value` is an Json. Returns false otherwise. pub fn is_json(&self) -> bool { - if let Self::Json(_) = self { - true - } else { - false - } + matches!(self, Self::Json(_)) } /// If the `Value` is an Json, return a reference to it. Returns Err otherwise. @@ -1173,11 +1085,7 @@ impl Value { /// Returns true if the `Value` is an Enum. Returns false otherwise. pub fn is_enum(&self) -> bool { - if let Self::Enum(_) = self { - true - } else { - false - } + matches!(self, Self::Enum(_)) } /// If the `Value` is an Enum, return a reference to it. Returns Err otherwise. @@ -1206,11 +1114,7 @@ impl Value { /// Returns true if the `Value` is an Url. Returns false otherwise. pub fn is_url(&self) -> bool { - if let Self::Url(_) = self { - true - } else { - false - } + matches!(self, Self::Url(_)) } /// If the `Value` is an Url, return a reference to it. Returns Err otherwise. @@ -1239,11 +1143,7 @@ impl Value { /// Returns true if the `Value` is an Webpage. Returns false otherwise. pub fn is_webpage(&self) -> bool { - if let Self::Webpage(_) = self { - true - } else { - false - } + matches!(self, Self::Webpage(_)) } /// If the `Value` is an Webpage, return a reference to it. Returns Err otherwise. @@ -1272,11 +1172,7 @@ impl Value { /// Returns true if the `Value` is an IpAddr. Returns false otherwise. pub fn is_ip_addr(&self) -> bool { - if let Self::IpAddr(_) = self { - true - } else { - false - } + matches!(self, Self::IpAddr(_)) } /// If the `Value` is an IpAddr, return a reference to it. Returns Err otherwise. @@ -1305,11 +1201,7 @@ impl Value { /// Returns true if the `Value` is an List. Returns false otherwise. pub fn is_list(&self) -> bool { - if let Self::List(_) = self { - true - } else { - false - } + matches!(self, Self::List(_)) } /// If the `Value` is an List, return a reference to it. Returns Err otherwise. @@ -1338,11 +1230,7 @@ impl Value { /// Returns true if the `Value` is an Map. Returns false otherwise. pub fn is_map(&self) -> bool { - if let Self::Map(_) = self { - true - } else { - false - } + matches!(self, Self::Map(_)) } /// If the `Value` is an Map, return a reference to it. Returns Err otherwise. @@ -1371,11 +1259,7 @@ impl Value { /// Returns true if the `Value` is an Group. Returns false otherwise. pub fn is_group(&self) -> bool { - if let Self::Group(_) = self { - true - } else { - false - } + matches!(self, Self::Group(_)) } /// If the `Value` is an Group, return a reference to it. Returns Err otherwise. @@ -1404,11 +1288,7 @@ impl Value { /// Returns true if the `Value` is an Option. Returns false otherwise. pub fn is_option(&self) -> bool { - if let Self::Option(_) = self { - true - } else { - false - } + matches!(self, Self::Option(_)) } /// If the `Value` is an Option, return a reference to it. Returns Err otherwise. diff --git a/azure-pipelines.yml b/azure-pipelines.yml index d3eba125..d265da45 100644 --- a/azure-pipelines.yml +++ b/azure-pipelines.yml @@ -20,7 +20,7 @@ jobs: endpoint: alecmocatta default: rust_toolchain: nightly - rust_lint_toolchain: nightly-2020-07-12 + rust_lint_toolchain: nightly-2020-07-26 rust_flags: '' rust_features_clippy: ';aws;commoncrawl;parquet;postgres;csv;json;constellation aws commoncrawl parquet postgres csv json' rust_features: 'constellation aws commoncrawl parquet postgres csv json' @@ -52,7 +52,7 @@ jobs: endpoint: alecmocatta default: rust_toolchain: stable - rust_lint_toolchain: nightly-2020-07-12 + rust_lint_toolchain: nightly-2020-07-26 rust_flags: '' rust_features_clippy: ';aws;commoncrawl;postgres;csv;json;aws commoncrawl postgres csv json' rust_features: 'aws commoncrawl postgres csv json' @@ -78,7 +78,7 @@ jobs: endpoint: alecmocatta default: rust_toolchain: nightly - rust_lint_toolchain: nightly-2020-07-12 + rust_lint_toolchain: nightly-2020-07-26 rust_flags: '' rust_packages: '-p amadeus-core -p amadeus-derive -p amadeus-parquet -p amadeus-serde -p amadeus-types -p amadeus' rust_features_clippy: ';parquet;csv;json;parquet csv json' @@ -106,7 +106,7 @@ jobs: endpoint: alecmocatta default: rust_toolchain: stable nightly - rust_lint_toolchain: nightly-2020-07-12 + rust_lint_toolchain: nightly-2020-07-26 rust_flags: '' rust_packages: '-p amadeus-core -p amadeus-derive -p amadeus-serde -p amadeus-types -p amadeus' rust_features_clippy: ';csv;json;csv json' From a7429a65afaedd4a66759c8401bcf47b8dbd19e0 Mon Sep 17 00:00:00 2001 From: alecmocatta Date: Sun, 26 Jul 2020 19:41:45 +0100 Subject: [PATCH 3/4] update rusoto --- amadeus-aws/Cargo.toml | 6 +++--- 1 file changed, 3 insertions(+), 3 deletions(-) diff --git a/amadeus-aws/Cargo.toml b/amadeus-aws/Cargo.toml index bb054c89..b57266ae 100644 --- a/amadeus-aws/Cargo.toml +++ b/amadeus-aws/Cargo.toml @@ -28,9 +28,9 @@ futures = { version = "0.3" } futures-retry = "0.5" http = "0.2" once_cell = "1.0" -rusoto_core = "0.44" -rusoto_credential = "0.44" -rusoto_s3 = "0.44" +rusoto_core = "0.45" +rusoto_credential = "0.45" +rusoto_s3 = "0.45" serde_closure = "0.3" serde = { version = "1.0", features = ["derive"] } tokio = "0.2" From 057df4b2163c8d985bcac6797a586b412b611c2e Mon Sep 17 00:00:00 2001 From: alecmocatta Date: Sun, 26 Jul 2020 19:44:05 +0100 Subject: [PATCH 4/4] v0.3.6 --- Cargo.toml | 18 +++++++++--------- amadeus-aws/Cargo.toml | 6 +++--- amadeus-aws/src/lib.rs | 2 +- amadeus-commoncrawl/Cargo.toml | 6 +++--- amadeus-commoncrawl/src/lib.rs | 2 +- amadeus-core/Cargo.toml | 2 +- amadeus-core/src/lib.rs | 2 +- amadeus-derive/Cargo.toml | 2 +- amadeus-derive/src/lib.rs | 2 +- amadeus-parquet/Cargo.toml | 6 +++--- amadeus-parquet/src/lib.rs | 2 +- amadeus-postgres/Cargo.toml | 6 +++--- amadeus-postgres/src/lib.rs | 2 +- amadeus-serde/Cargo.toml | 6 +++--- amadeus-serde/src/lib.rs | 2 +- amadeus-types/Cargo.toml | 4 ++-- amadeus-types/src/lib.rs | 2 +- src/lib.rs | 2 +- 18 files changed, 37 insertions(+), 37 deletions(-) diff --git a/Cargo.toml b/Cargo.toml index c4a4d547..a22cdd45 100644 --- a/Cargo.toml +++ b/Cargo.toml @@ -2,7 +2,7 @@ [package] name = "amadeus" -version = "0.3.5" +version = "0.3.6" license = "Apache-2.0" authors = ["Alec Mocatta "] categories = ["concurrency", "science", "database", "parser-implementations", "text-processing"] @@ -35,14 +35,14 @@ json = ["amadeus-serde", "amadeus-derive/serde"] features = ["constellation", "aws", "commoncrawl", "parquet", "postgres", "csv", "json"] [dependencies] -amadeus-core = { version = "=0.3.5", path = "amadeus-core" } -amadeus-derive = { version = "=0.3.5", path = "amadeus-derive" } -amadeus-types = { version = "=0.3.5", path = "amadeus-types" } -amadeus-aws = { version = "=0.3.5", path = "amadeus-aws", optional = true } -amadeus-commoncrawl = { version = "=0.3.5", path = "amadeus-commoncrawl", optional = true } -amadeus-parquet = { version = "=0.3.5", path = "amadeus-parquet", optional = true } -amadeus-postgres = { version = "=0.3.5", path = "amadeus-postgres", optional = true } -amadeus-serde = { version = "=0.3.5", path = "amadeus-serde", optional = true } +amadeus-core = { version = "=0.3.6", path = "amadeus-core" } +amadeus-derive = { version = "=0.3.6", path = "amadeus-derive" } +amadeus-types = { version = "=0.3.6", path = "amadeus-types" } +amadeus-aws = { version = "=0.3.6", path = "amadeus-aws", optional = true } +amadeus-commoncrawl = { version = "=0.3.6", path = "amadeus-commoncrawl", optional = true } +amadeus-parquet = { version = "=0.3.6", path = "amadeus-parquet", optional = true } +amadeus-postgres = { version = "=0.3.6", path = "amadeus-postgres", optional = true } +amadeus-serde = { version = "=0.3.6", path = "amadeus-serde", optional = true } async-channel = "1.1" constellation-rs = { version = "0.2.0-alpha.2", default-features = false, optional = true } derive-new = "0.5" diff --git a/amadeus-aws/Cargo.toml b/amadeus-aws/Cargo.toml index b57266ae..10c76fba 100644 --- a/amadeus-aws/Cargo.toml +++ b/amadeus-aws/Cargo.toml @@ -1,6 +1,6 @@ [package] name = "amadeus-aws" -version = "0.3.5" +version = "0.3.6" license = "Apache-2.0" authors = ["Alec Mocatta "] categories = ["concurrency", "science", "database", "parser-implementations", "text-processing"] @@ -19,8 +19,8 @@ azure-devops = { project = "alecmocatta/amadeus", pipeline = "tests", build = "2 maintenance = { status = "actively-developed" } [dependencies] -amadeus-core = { version = "=0.3.5", path = "../amadeus-core" } -amadeus-types = { version = "=0.3.5", path = "../amadeus-types" } +amadeus-core = { version = "=0.3.6", path = "../amadeus-core" } +amadeus-types = { version = "=0.3.6", path = "../amadeus-types" } async-compression = { version = "0.3.3", features = ["gzip", "futures-bufread"] } async-trait = "0.1" chrono = { version = "0.4", default-features = false } diff --git a/amadeus-aws/src/lib.rs b/amadeus-aws/src/lib.rs index 65310439..ff7b77d8 100644 --- a/amadeus-aws/src/lib.rs +++ b/amadeus-aws/src/lib.rs @@ -6,7 +6,7 @@ //! //! This is a support crate of [Amadeus](https://github.com/constellation-rs/amadeus) and is not intended to be used directly. These types are re-exposed in [`amadeus::source`](https://docs.rs/amadeus/0.3/amadeus/source/index.html). -#![doc(html_root_url = "https://docs.rs/amadeus-aws/0.3.5")] +#![doc(html_root_url = "https://docs.rs/amadeus-aws/0.3.6")] #![cfg_attr(nightly, feature(type_alias_impl_trait))] #![warn( // missing_copy_implementations, diff --git a/amadeus-commoncrawl/Cargo.toml b/amadeus-commoncrawl/Cargo.toml index 155287a4..27003c30 100644 --- a/amadeus-commoncrawl/Cargo.toml +++ b/amadeus-commoncrawl/Cargo.toml @@ -1,6 +1,6 @@ [package] name = "amadeus-commoncrawl" -version = "0.3.5" +version = "0.3.6" license = "MIT OR Apache-2.0" authors = ["Stephen Becker IV ", "Alec Mocatta "] categories = ["concurrency", "science", "database", "parser-implementations", "text-processing"] @@ -19,8 +19,8 @@ azure-devops = { project = "alecmocatta/amadeus", pipeline = "tests", build = "2 maintenance = { status = "actively-developed" } [dependencies] -amadeus-core = { version = "=0.3.5", path = "../amadeus-core" } -amadeus-types = { version = "=0.3.5", path = "../amadeus-types" } +amadeus-core = { version = "=0.3.6", path = "../amadeus-core" } +amadeus-types = { version = "=0.3.6", path = "../amadeus-types" } async-compression = { version = "0.3.3", features = ["gzip", "futures-bufread"] } futures = "0.3" nom = "4.2.3" diff --git a/amadeus-commoncrawl/src/lib.rs b/amadeus-commoncrawl/src/lib.rs index f0115674..9a081314 100644 --- a/amadeus-commoncrawl/src/lib.rs +++ b/amadeus-commoncrawl/src/lib.rs @@ -6,7 +6,7 @@ //! //! This is a support crate of [Amadeus](https://github.com/constellation-rs/amadeus) and is not intended to be used directly. These types are re-exposed in [`amadeus::source`](https://docs.rs/amadeus/0.3/amadeus/source/index.html). -#![doc(html_root_url = "https://docs.rs/amadeus-commoncrawl/0.3.5")] +#![doc(html_root_url = "https://docs.rs/amadeus-commoncrawl/0.3.6")] #![cfg_attr(nightly, feature(type_alias_impl_trait))] #![warn( // missing_copy_implementations, diff --git a/amadeus-core/Cargo.toml b/amadeus-core/Cargo.toml index abbbe31d..b1f824a8 100644 --- a/amadeus-core/Cargo.toml +++ b/amadeus-core/Cargo.toml @@ -1,6 +1,6 @@ [package] name = "amadeus-core" -version = "0.3.5" +version = "0.3.6" license = "Apache-2.0" authors = ["Alec Mocatta "] categories = ["concurrency", "science", "database", "parser-implementations", "text-processing"] diff --git a/amadeus-core/src/lib.rs b/amadeus-core/src/lib.rs index 1548eba0..23f47af9 100644 --- a/amadeus-core/src/lib.rs +++ b/amadeus-core/src/lib.rs @@ -6,7 +6,7 @@ //! //! This is a support crate of [Amadeus](https://github.com/constellation-rs/amadeus) and is not intended to be used directly. All functionality is re-exposed in [`amadeus`](https://docs.rs/amadeus/0.3/amadeus/). -#![doc(html_root_url = "https://docs.rs/amadeus-core/0.3.5")] +#![doc(html_root_url = "https://docs.rs/amadeus-core/0.3.6")] #![cfg_attr(nightly, feature(unboxed_closures))] #![recursion_limit = "25600"] #![warn( diff --git a/amadeus-derive/Cargo.toml b/amadeus-derive/Cargo.toml index 6042f3b0..cd11d2dd 100644 --- a/amadeus-derive/Cargo.toml +++ b/amadeus-derive/Cargo.toml @@ -1,6 +1,6 @@ [package] name = "amadeus-derive" -version = "0.3.5" +version = "0.3.6" license = "Apache-2.0" authors = ["Alec Mocatta "] categories = ["concurrency", "science", "database", "parser-implementations", "text-processing"] diff --git a/amadeus-derive/src/lib.rs b/amadeus-derive/src/lib.rs index e9a4e324..03a73ab3 100644 --- a/amadeus-derive/src/lib.rs +++ b/amadeus-derive/src/lib.rs @@ -6,7 +6,7 @@ //! //! This is a support crate of [Amadeus](https://github.com/constellation-rs/amadeus) and is not intended to be used directly. This macro is re-exposed as [`amadeus::data::Data`](https://docs.rs/amadeus/0.3/amadeus/data/derive.Data.html). -#![doc(html_root_url = "https://docs.rs/amadeus-derive/0.3.5")] +#![doc(html_root_url = "https://docs.rs/amadeus-derive/0.3.6")] #![recursion_limit = "400"] #![warn( missing_copy_implementations, diff --git a/amadeus-parquet/Cargo.toml b/amadeus-parquet/Cargo.toml index 166e99b0..109b1c19 100644 --- a/amadeus-parquet/Cargo.toml +++ b/amadeus-parquet/Cargo.toml @@ -1,6 +1,6 @@ [package] name = "amadeus-parquet" -version = "0.3.5" +version = "0.3.6" license = "Apache-2.0" authors = ["Alec Mocatta ", "Apache Arrow "] categories = ["concurrency", "science", "database", "parser-implementations", "text-processing"] @@ -19,8 +19,8 @@ azure-devops = { project = "alecmocatta/amadeus", pipeline = "tests", build = "2 maintenance = { status = "actively-developed" } [dependencies] -amadeus-core = { version = "=0.3.5", path = "../amadeus-core" } -amadeus-types = { version = "=0.3.5", path = "../amadeus-types" } +amadeus-core = { version = "=0.3.6", path = "../amadeus-core" } +amadeus-types = { version = "=0.3.6", path = "../amadeus-types" } async-trait = "0.1" brotli = "3.3" byteorder = "1.2" diff --git a/amadeus-parquet/src/lib.rs b/amadeus-parquet/src/lib.rs index 8bad4b90..87e23d4e 100644 --- a/amadeus-parquet/src/lib.rs +++ b/amadeus-parquet/src/lib.rs @@ -6,7 +6,7 @@ //! //! This is a support crate of [Amadeus](https://github.com/constellation-rs/amadeus) and is not intended to be used directly. These types are re-exposed in [`amadeus::source`](https://docs.rs/amadeus/0.3/amadeus/source/index.html). -#![doc(html_root_url = "https://docs.rs/amadeus-parquet/0.3.5")] +#![doc(html_root_url = "https://docs.rs/amadeus-parquet/0.3.6")] #![cfg_attr(nightly, feature(bufreader_seek_relative))] #![cfg_attr(nightly, feature(read_initializer))] #![cfg_attr(nightly, feature(specialization))] diff --git a/amadeus-postgres/Cargo.toml b/amadeus-postgres/Cargo.toml index 522418b4..91fc70fd 100644 --- a/amadeus-postgres/Cargo.toml +++ b/amadeus-postgres/Cargo.toml @@ -1,6 +1,6 @@ [package] name = "amadeus-postgres" -version = "0.3.5" +version = "0.3.6" license = "Apache-2.0" authors = ["Alec Mocatta "] categories = ["concurrency", "science", "database", "parser-implementations", "text-processing"] @@ -19,8 +19,8 @@ azure-devops = { project = "alecmocatta/amadeus", pipeline = "tests", build = "2 maintenance = { status = "actively-developed" } [dependencies] -amadeus-core = { version = "=0.3.5", path = "../amadeus-core" } -amadeus-types = { version = "=0.3.5", path = "../amadeus-types" } +amadeus-core = { version = "=0.3.6", path = "../amadeus-core" } +amadeus-types = { version = "=0.3.6", path = "../amadeus-types" } bytes = "0.5" chrono = { version = "0.4", default-features = false } educe = "0.4" diff --git a/amadeus-postgres/src/lib.rs b/amadeus-postgres/src/lib.rs index 1d59112f..04b49bf4 100644 --- a/amadeus-postgres/src/lib.rs +++ b/amadeus-postgres/src/lib.rs @@ -6,7 +6,7 @@ //! //! This is a support crate of [Amadeus](https://github.com/constellation-rs/amadeus) and is not intended to be used directly. These types are re-exposed in [`amadeus::source`](https://docs.rs/amadeus/0.3/amadeus/source/index.html). -#![doc(html_root_url = "https://docs.rs/amadeus-postgres/0.3.5")] +#![doc(html_root_url = "https://docs.rs/amadeus-postgres/0.3.6")] #![cfg_attr(nightly, feature(type_alias_impl_trait))] #![warn( // missing_copy_implementations, diff --git a/amadeus-serde/Cargo.toml b/amadeus-serde/Cargo.toml index 2d7930a9..2293c616 100644 --- a/amadeus-serde/Cargo.toml +++ b/amadeus-serde/Cargo.toml @@ -1,6 +1,6 @@ [package] name = "amadeus-serde" -version = "0.3.5" +version = "0.3.6" license = "Apache-2.0" authors = ["Alec Mocatta "] categories = ["concurrency", "science", "database", "parser-implementations", "text-processing"] @@ -19,8 +19,8 @@ azure-devops = { project = "alecmocatta/amadeus", pipeline = "tests", build = "2 maintenance = { status = "actively-developed" } [dependencies] -amadeus-core = { version = "=0.3.5", path = "../amadeus-core" } -amadeus-types = { version = "=0.3.5", path = "../amadeus-types" } +amadeus-core = { version = "=0.3.6", path = "../amadeus-core" } +amadeus-types = { version = "=0.3.6", path = "../amadeus-types" } chrono = { version = "0.4", default-features = false, features = ["serde"] } csv = "1.0" educe = "0.4" diff --git a/amadeus-serde/src/lib.rs b/amadeus-serde/src/lib.rs index 7e1b9af4..ada46c01 100644 --- a/amadeus-serde/src/lib.rs +++ b/amadeus-serde/src/lib.rs @@ -6,7 +6,7 @@ //! //! This is a support crate of [Amadeus](https://github.com/constellation-rs/amadeus) and is not intended to be used directly. These types are re-exposed in [`amadeus::source`](https://docs.rs/amadeus/0.3/amadeus/source/index.html). -#![doc(html_root_url = "https://docs.rs/amadeus-serde/0.3.5")] +#![doc(html_root_url = "https://docs.rs/amadeus-serde/0.3.6")] #![cfg_attr(nightly, feature(type_alias_impl_trait))] #![warn( // missing_copy_implementations, diff --git a/amadeus-types/Cargo.toml b/amadeus-types/Cargo.toml index 0fc46bc7..89ea1d75 100644 --- a/amadeus-types/Cargo.toml +++ b/amadeus-types/Cargo.toml @@ -1,6 +1,6 @@ [package] name = "amadeus-types" -version = "0.3.5" +version = "0.3.6" license = "Apache-2.0" authors = ["Alec Mocatta "] categories = ["concurrency", "science", "database", "date-and-time", "data-structures"] @@ -19,7 +19,7 @@ azure-devops = { project = "alecmocatta/amadeus", pipeline = "tests", build = "2 maintenance = { status = "actively-developed" } [dependencies] -amadeus-core = { version = "=0.3.5", path = "../amadeus-core" } +amadeus-core = { version = "=0.3.6", path = "../amadeus-core" } chrono = { version = "0.4", default-features = false, features = ["std", "serde"] } chrono-tz = { version = "0.5", features = ["serde"] } fxhash = "0.2" diff --git a/amadeus-types/src/lib.rs b/amadeus-types/src/lib.rs index 5fba4416..94f6e688 100644 --- a/amadeus-types/src/lib.rs +++ b/amadeus-types/src/lib.rs @@ -6,7 +6,7 @@ //! //! This is a support crate of [Amadeus](https://github.com/constellation-rs/amadeus) and is not intended to be used directly. These types are re-exposed in [`amadeus::data`](https://docs.rs/amadeus/0.3/amadeus/data/index.html). -#![doc(html_root_url = "https://docs.rs/amadeus-types/0.3.5")] +#![doc(html_root_url = "https://docs.rs/amadeus-types/0.3.6")] #![warn( // missing_copy_implementations, // missing_debug_implementations, diff --git a/src/lib.rs b/src/lib.rs index e8b646ab..6e66b5c9 100644 --- a/src/lib.rs +++ b/src/lib.rs @@ -4,7 +4,7 @@ //! 📦  Crates.io  â”‚  ðŸ“‘  GitHub  â”‚  ðŸ’¬  Chat //!

-#![doc(html_root_url = "https://docs.rs/amadeus/0.3.5")] +#![doc(html_root_url = "https://docs.rs/amadeus/0.3.6")] #![doc( html_logo_url = "https://raw.githubusercontent.com/constellation-rs/amadeus/master/logo.svg?sanitize=true" )]