pub struct ChunkedArray<T>where
T: PolarsDataType,{ /* private fields */ }
Expand description
§ChunkedArray
Every Series contains a ChunkedArray<T>
. Unlike Series
, ChunkedArray
s are typed. This allows
us to apply closures to the data and collect the results to a ChunkedArray
of the same type T
.
Below we use an apply to use the cosine function to the values of a ChunkedArray
.
fn apply_cosine_and_cast(ca: &Float32Chunked) -> Float32Chunked {
ca.apply_values(|v| v.cos())
}
§Conversion between Series and ChunkedArrays
Conversion from a Series
to a ChunkedArray
is effortless.
fn to_chunked_array(series: &Series) -> PolarsResult<&Int32Chunked>{
series.i32()
}
fn to_series(ca: Int32Chunked) -> Series {
ca.into_series()
}
§Iterators
ChunkedArray
s fully support Rust native Iterator
and DoubleEndedIterator traits, thereby
giving access to all the excellent methods available for Iterators.
fn iter_forward(ca: &Float32Chunked) {
ca.iter()
.for_each(|opt_v| println!("{:?}", opt_v))
}
fn iter_backward(ca: &Float32Chunked) {
ca.iter()
.rev()
.for_each(|opt_v| println!("{:?}", opt_v))
}
§Memory layout
ChunkedArray
s use Apache Arrow as backend for the memory layout.
Arrows memory is immutable which makes it possible to make multiple zero copy (sub)-views from a single array.
To be able to append data, Polars uses chunks to append new memory locations, hence the ChunkedArray<T>
data structure.
Appends are cheap, because it will not lead to a full reallocation of the whole array (as could be the case with a Rust Vec).
However, multiple chunks in a ChunkedArray
will slow down many operations that need random access because we have an extra indirection
and indexes need to be mapped to the proper chunk. Arithmetic may also be slowed down by this.
When multiplying two ChunkedArray
s with different chunk sizes they cannot utilize SIMD for instance.
If you want to have predictable performance
(no unexpected re-allocation of memory), it is advised to call the ChunkedArray::rechunk
after
multiple append operations.
See also ChunkedArray::extend
for appends within a chunk.
§Invariants
- A
ChunkedArray
should always have at least a singleArrayRef
. - The
PolarsDataType
T
should always map to the correctArrowDataType
in theArrayRef
chunks. - Nested datatypes such as
List
and [Array
] store the physical types instead of the logical type given by the datatype.
Implementations§
Source§impl ChunkedArray<BooleanType>
impl ChunkedArray<BooleanType>
Booleans are cast to 1 or 0.
Source§impl ChunkedArray<BinaryType>
impl ChunkedArray<BinaryType>
pub fn max_binary(&self) -> Option<&[u8]>
pub fn min_binary(&self) -> Option<&[u8]>
Source§impl<T> ChunkedArray<T>where
T: PolarsDataType<IsNested = FalseT, IsObject = FalseT>,
<T as PolarsDataType>::Physical<'a>: for<'a> TotalOrd,
impl<T> ChunkedArray<T>where
T: PolarsDataType<IsNested = FalseT, IsObject = FalseT>,
<T as PolarsDataType>::Physical<'a>: for<'a> TotalOrd,
Sourcepub fn append(&mut self, other: &ChunkedArray<T>) -> Result<(), PolarsError>
pub fn append(&mut self, other: &ChunkedArray<T>) -> Result<(), PolarsError>
Append in place. This is done by adding the chunks of other
to this ChunkedArray
.
See also extend
for appends to the underlying memory
Source§impl<T> ChunkedArray<T>where
T: PolarsDataType,
impl<T> ChunkedArray<T>where
T: PolarsDataType,
Sourcepub fn apply_nonnull_values_generic<'a, U, K, F>(
&'a self,
dtype: DataType,
op: F,
) -> ChunkedArray<U>where
U: PolarsDataType,
F: FnMut(<T as PolarsDataType>::Physical<'a>) -> K,
<U as PolarsDataType>::Array: ArrayFromIterDtype<K> + ArrayFromIterDtype<Option<K>>,
pub fn apply_nonnull_values_generic<'a, U, K, F>(
&'a self,
dtype: DataType,
op: F,
) -> ChunkedArray<U>where
U: PolarsDataType,
F: FnMut(<T as PolarsDataType>::Physical<'a>) -> K,
<U as PolarsDataType>::Array: ArrayFromIterDtype<K> + ArrayFromIterDtype<Option<K>>,
Applies a function only to the non-null elements, propagating nulls.
Sourcepub fn try_apply_nonnull_values_generic<'a, U, K, F, E>(
&'a self,
op: F,
) -> Result<ChunkedArray<U>, E>where
U: PolarsDataType,
F: FnMut(<T as PolarsDataType>::Physical<'a>) -> Result<K, E>,
<U as PolarsDataType>::Array: ArrayFromIter<K> + ArrayFromIter<Option<K>>,
pub fn try_apply_nonnull_values_generic<'a, U, K, F, E>(
&'a self,
op: F,
) -> Result<ChunkedArray<U>, E>where
U: PolarsDataType,
F: FnMut(<T as PolarsDataType>::Physical<'a>) -> Result<K, E>,
<U as PolarsDataType>::Array: ArrayFromIter<K> + ArrayFromIter<Option<K>>,
Applies a function only to the non-null elements, propagating nulls.
pub fn apply_into_string_amortized<'a, F>( &'a self, f: F, ) -> ChunkedArray<StringType>
pub fn try_apply_into_string_amortized<'a, F, E>( &'a self, f: F, ) -> Result<ChunkedArray<StringType>, E>
Source§impl<T> ChunkedArray<T>where
T: PolarsNumericType,
impl<T> ChunkedArray<T>where
T: PolarsNumericType,
Sourcepub fn cast_and_apply_in_place<F, S>(&self, f: F) -> ChunkedArray<S>where
F: Fn(<S as PolarsNumericType>::Native) -> <S as PolarsNumericType>::Native + Copy,
S: PolarsNumericType,
pub fn cast_and_apply_in_place<F, S>(&self, f: F) -> ChunkedArray<S>where
F: Fn(<S as PolarsNumericType>::Native) -> <S as PolarsNumericType>::Native + Copy,
S: PolarsNumericType,
Cast a numeric array to another numeric data type and apply a function in place. This saves an allocation.
Sourcepub fn apply_in_place<F>(self, f: F) -> ChunkedArray<T>
pub fn apply_in_place<F>(self, f: F) -> ChunkedArray<T>
Cast a numeric array to another numeric data type and apply a function in place. This saves an allocation.
Source§impl<T> ChunkedArray<T>where
T: PolarsNumericType,
impl<T> ChunkedArray<T>where
T: PolarsNumericType,
Source§impl ChunkedArray<StringType>
impl ChunkedArray<StringType>
pub fn apply_mut<'a, F>(&'a self, f: F) -> ChunkedArray<StringType>
Source§impl ChunkedArray<BinaryType>
impl ChunkedArray<BinaryType>
pub fn apply_mut<'a, F>(&'a self, f: F) -> ChunkedArray<BinaryType>
Source§impl ChunkedArray<StringType>
impl ChunkedArray<StringType>
Sourcepub unsafe fn apply_views<F>(&self, update_view: F) -> ChunkedArray<StringType>
pub unsafe fn apply_views<F>(&self, update_view: F) -> ChunkedArray<StringType>
§Safety
Update the views. All invariants of the views apply.
Source§impl ChunkedArray<Float32Type>
impl ChunkedArray<Float32Type>
Used to save compilation paths. Use carefully. Although this is safe, if misused it can lead to incorrect results.
Source§impl<T> ChunkedArray<T>where
T: PolarsDataType,
impl<T> ChunkedArray<T>where
T: PolarsDataType,
Sourcepub fn null_count(&self) -> usize
pub fn null_count(&self) -> usize
Return the number of null values in the ChunkedArray.
Sourcepub unsafe fn set_null_count(&mut self, null_count: u32)
pub unsafe fn set_null_count(&mut self, null_count: u32)
Set the null count directly.
This can be useful after mutably adjusting the validity of the underlying arrays.
§Safety
The new null count must match the total null count of the underlying arrays.
pub fn rechunk(&self) -> ChunkedArray<T>
pub fn rechunk_validity(&self) -> Option<Bitmap>
Sourcepub fn split_at(&self, offset: i64) -> (ChunkedArray<T>, ChunkedArray<T>)
pub fn split_at(&self, offset: i64) -> (ChunkedArray<T>, ChunkedArray<T>)
Split the array. The chunks are reallocated the underlying data slices are zero copy.
When offset is negative it will be counted from the end of the array. This method will never error, and will slice the best match when offset, or length is out of bounds
Sourcepub fn slice(&self, offset: i64, length: usize) -> ChunkedArray<T>
pub fn slice(&self, offset: i64, length: usize) -> ChunkedArray<T>
Slice the array. The chunks are reallocated the underlying data slices are zero copy.
When offset is negative it will be counted from the end of the array. This method will never error, and will slice the best match when offset, or length is out of bounds
Sourcepub fn limit(&self, num_elements: usize) -> ChunkedArray<T>where
ChunkedArray<T>: Sized,
pub fn limit(&self, num_elements: usize) -> ChunkedArray<T>where
ChunkedArray<T>: Sized,
Take a view of top n elements
Sourcepub fn head(&self, length: Option<usize>) -> ChunkedArray<T>where
ChunkedArray<T>: Sized,
pub fn head(&self, length: Option<usize>) -> ChunkedArray<T>where
ChunkedArray<T>: Sized,
Get the head of the ChunkedArray
Sourcepub fn tail(&self, length: Option<usize>) -> ChunkedArray<T>where
ChunkedArray<T>: Sized,
pub fn tail(&self, length: Option<usize>) -> ChunkedArray<T>where
ChunkedArray<T>: Sized,
Get the tail of the ChunkedArray
Sourcepub fn prune_empty_chunks(&mut self)
pub fn prune_empty_chunks(&mut self)
Remove empty chunks.
Source§impl ChunkedArray<StringType>
impl ChunkedArray<StringType>
Sourcepub fn to_decimal(&self, infer_length: usize) -> Result<Series, PolarsError>
pub fn to_decimal(&self, infer_length: usize) -> Result<Series, PolarsError>
Convert an StringChunked
to a Series
of DataType::Decimal
.
Scale needed for the decimal type are inferred. Parsing is not strict.
Scale inference assumes that all tested strings are well-formed numbers,
and may produce unexpected results for scale if this is not the case.
If the decimal precision
and scale
are already known, consider
using the cast
method.
Source§impl<T> ChunkedArray<T>where
T: PolarsNumericType,
impl<T> ChunkedArray<T>where
T: PolarsNumericType,
Sourcepub fn extend(&mut self, other: &ChunkedArray<T>) -> Result<(), PolarsError>
pub fn extend(&mut self, other: &ChunkedArray<T>) -> Result<(), PolarsError>
Extend the memory backed by this array with the values from other
.
Different from ChunkedArray::append
which adds chunks to this ChunkedArray
extend
appends the data from other
to the underlying PrimitiveArray
and thus may cause a reallocation.
However if this does not cause a reallocation, the resulting data structure will not have any extra chunks and thus will yield faster queries.
Prefer extend
over append
when you want to do a query after a single append. For instance during
online operations where you add n
rows and rerun a query.
Prefer append
over extend
when you want to append many times before doing a query. For instance
when you read in multiple files and when to store them in a single DataFrame
.
In the latter case finish the sequence of append
operations with a rechunk
.
Source§impl<T> ChunkedArray<T>where
T: PolarsDataType,
impl<T> ChunkedArray<T>where
T: PolarsDataType,
Source§impl ChunkedArray<FixedSizeListType>
impl ChunkedArray<FixedSizeListType>
pub fn full_null_with_dtype( name: PlSmallStr, length: usize, inner_dtype: &DataType, width: usize, ) -> ChunkedArray<FixedSizeListType>
dtype-array
only.Source§impl ChunkedArray<ListType>
impl ChunkedArray<ListType>
pub fn full_null_with_dtype( name: PlSmallStr, length: usize, inner_dtype: &DataType, ) -> ChunkedArray<ListType>
Source§impl ChunkedArray<UInt32Type>
impl ChunkedArray<UInt32Type>
pub fn with_nullable_idx<T, F>(idx: &[NullableIdxSize], f: F) -> T
Source§impl<T> ChunkedArray<T>where
T: PolarsDataType,
impl<T> ChunkedArray<T>where
T: PolarsDataType,
Sourcepub fn is_null(&self) -> ChunkedArray<BooleanType>
pub fn is_null(&self) -> ChunkedArray<BooleanType>
Get a mask of the null values.
Sourcepub fn is_not_null(&self) -> ChunkedArray<BooleanType>
pub fn is_not_null(&self) -> ChunkedArray<BooleanType>
Get a mask of the valid values.
Source§impl<T> ChunkedArray<T>where
ChunkedArray<T>: IntoSeries,
T: PolarsFloatType,
<T as PolarsNumericType>::Native: Float + IsFloat + SubAssign + Pow<<T as PolarsNumericType>::Native, Output = <T as PolarsNumericType>::Native>,
impl<T> ChunkedArray<T>where
ChunkedArray<T>: IntoSeries,
T: PolarsFloatType,
<T as PolarsNumericType>::Native: Float + IsFloat + SubAssign + Pow<<T as PolarsNumericType>::Native, Output = <T as PolarsNumericType>::Native>,
Sourcepub fn rolling_map_float<F>(
&self,
window_size: usize,
f: F,
) -> Result<ChunkedArray<T>, PolarsError>
pub fn rolling_map_float<F>( &self, window_size: usize, f: F, ) -> Result<ChunkedArray<T>, PolarsError>
Apply a rolling custom function. This is pretty slow because of dynamic dispatch.
Source§impl ChunkedArray<BinaryType>
impl ChunkedArray<BinaryType>
Sourcepub unsafe fn to_string_unchecked(&self) -> ChunkedArray<StringType>
pub unsafe fn to_string_unchecked(&self) -> ChunkedArray<StringType>
§Safety
String is not validated
Source§impl ChunkedArray<StringType>
impl ChunkedArray<StringType>
pub fn as_binary(&self) -> ChunkedArray<BinaryType>
Source§impl ChunkedArray<BooleanType>
impl ChunkedArray<BooleanType>
Sourcepub fn any(&self) -> bool
pub fn any(&self) -> bool
Returns whether any of the values in the column are true
.
Null values are ignored.
Sourcepub fn all(&self) -> bool
pub fn all(&self) -> bool
Returns whether all values in the array are true
.
Null values are ignored.
Sourcepub fn any_kleene(&self) -> Option<bool>
pub fn any_kleene(&self) -> Option<bool>
Returns whether any of the values in the column are true
.
The output is unknown (None
) if the array contains any null values and
no true
values.
Sourcepub fn all_kleene(&self) -> Option<bool>
pub fn all_kleene(&self) -> Option<bool>
Returns whether all values in the column are true
.
The output is unknown (None
) if the array contains any null values and
no false
values.
Source§impl<T> ChunkedArray<T>
impl<T> ChunkedArray<T>
pub fn is_nan(&self) -> ChunkedArray<BooleanType>
pub fn is_not_nan(&self) -> ChunkedArray<BooleanType>
pub fn is_finite(&self) -> ChunkedArray<BooleanType>
pub fn is_infinite(&self) -> ChunkedArray<BooleanType>
Sourcepub fn none_to_nan(&self) -> ChunkedArray<T>
pub fn none_to_nan(&self) -> ChunkedArray<T>
Convert missing values to NaN
values.
Source§impl<T> ChunkedArray<T>
impl<T> ChunkedArray<T>
pub fn to_canonical(&self) -> ChunkedArray<T>
Source§impl ChunkedArray<ListType>
impl ChunkedArray<ListType>
Source§impl<T> ChunkedArray<T>where
T: PolarsDataType,
impl<T> ChunkedArray<T>where
T: PolarsDataType,
pub fn iter(&self) -> impl PolarsIterator
Source§impl<T> ChunkedArray<T>where
T: PolarsNumericType,
impl<T> ChunkedArray<T>where
T: PolarsNumericType,
Sourcepub fn to_ndarray(
&self,
) -> Result<ArrayBase<ViewRepr<&<T as PolarsNumericType>::Native>, Dim<[usize; 1]>>, PolarsError>
pub fn to_ndarray( &self, ) -> Result<ArrayBase<ViewRepr<&<T as PolarsNumericType>::Native>, Dim<[usize; 1]>>, PolarsError>
If data is aligned in a single chunk and has no Null values a zero copy view is returned as an ndarray
Source§impl ChunkedArray<ListType>
impl ChunkedArray<ListType>
Sourcepub fn to_ndarray<N>(
&self,
) -> Result<ArrayBase<OwnedRepr<<N as PolarsNumericType>::Native>, Dim<[usize; 2]>>, PolarsError>where
N: PolarsNumericType,
pub fn to_ndarray<N>(
&self,
) -> Result<ArrayBase<OwnedRepr<<N as PolarsNumericType>::Native>, Dim<[usize; 2]>>, PolarsError>where
N: PolarsNumericType,
If all nested Series
have the same length, a 2 dimensional ndarray::Array
is returned.
Source§impl ChunkedArray<FixedSizeListType>
impl ChunkedArray<FixedSizeListType>
Sourcepub fn amortized_iter(
&self,
) -> AmortizedListIter<'_, impl Iterator<Item = Option<Box<dyn Array>>>>
pub fn amortized_iter( &self, ) -> AmortizedListIter<'_, impl Iterator<Item = Option<Box<dyn Array>>>>
This is an iterator over a ArrayChunked
that save allocations.
A Series is:
1. Arc<ChunkedArray>
ChunkedArray is:
2. Vec< 3. ArrayRef>
The ArrayRef
we indicated with 3. will be updated during iteration.
The Series will be pinned in memory, saving an allocation for
- Arc<..>
- Vec<…>
§Warning
Though memory safe in the sense that it will not read unowned memory, UB, or memory leaks
this function still needs precautions. The returned should never be cloned or taken longer
than a single iteration, as every call on next
of the iterator will change the contents of
that Series.
§Safety
The lifetime of AmortSeries is bound to the iterator. Keeping it alive longer than the iterator is UB.
Sourcepub fn amortized_iter_with_name(
&self,
name: PlSmallStr,
) -> AmortizedListIter<'_, impl Iterator<Item = Option<Box<dyn Array>>>>
pub fn amortized_iter_with_name( &self, name: PlSmallStr, ) -> AmortizedListIter<'_, impl Iterator<Item = Option<Box<dyn Array>>>>
This is an iterator over a ArrayChunked
that save allocations.
A Series is:
1. Arc<ChunkedArray>
ChunkedArray is:
2. Vec< 3. ArrayRef>
The ArrayRef we indicated with 3. will be updated during iteration. The Series will be pinned in memory, saving an allocation for
- Arc<..>
- Vec<…>
If the returned AmortSeries
is cloned, the local copy will be replaced and a new container
will be set.
pub fn try_apply_amortized_to_list<F>( &self, f: F, ) -> Result<ChunkedArray<ListType>, PolarsError>
Sourcepub unsafe fn apply_amortized_same_type<F>(
&self,
f: F,
) -> ChunkedArray<FixedSizeListType>
pub unsafe fn apply_amortized_same_type<F>( &self, f: F, ) -> ChunkedArray<FixedSizeListType>
Apply a closure F
to each array.
§Safety
Return series of F
must has the same dtype and number of elements as input.
Sourcepub unsafe fn try_apply_amortized_same_type<F>(
&self,
f: F,
) -> Result<ChunkedArray<FixedSizeListType>, PolarsError>
pub unsafe fn try_apply_amortized_same_type<F>( &self, f: F, ) -> Result<ChunkedArray<FixedSizeListType>, PolarsError>
Try apply a closure F
to each array.
§Safety
Return series of F
must has the same dtype and number of elements as input if it is Ok.
Sourcepub unsafe fn zip_and_apply_amortized_same_type<'a, T, F>(
&'a self,
ca: &'a ChunkedArray<T>,
f: F,
) -> ChunkedArray<FixedSizeListType>where
T: PolarsDataType,
F: FnMut(Option<AmortSeries>, Option<<T as PolarsDataType>::Physical<'a>>) -> Option<Series>,
pub unsafe fn zip_and_apply_amortized_same_type<'a, T, F>(
&'a self,
ca: &'a ChunkedArray<T>,
f: F,
) -> ChunkedArray<FixedSizeListType>where
T: PolarsDataType,
F: FnMut(Option<AmortSeries>, Option<<T as PolarsDataType>::Physical<'a>>) -> Option<Series>,
Zip with a ChunkedArray
then apply a binary function F
elementwise.
§Safety
Sourcepub fn apply_amortized_generic<F, K, V>(&self, f: F) -> ChunkedArray<V>where
V: PolarsDataType,
F: FnMut(Option<AmortSeries>) -> Option<K> + Copy,
<V as PolarsDataType>::Array: ArrayFromIter<Option<K>>,
pub fn apply_amortized_generic<F, K, V>(&self, f: F) -> ChunkedArray<V>where
V: PolarsDataType,
F: FnMut(Option<AmortSeries>) -> Option<K> + Copy,
<V as PolarsDataType>::Array: ArrayFromIter<Option<K>>,
Apply a closure F
elementwise.
Sourcepub fn try_apply_amortized_generic<F, K, V>(
&self,
f: F,
) -> Result<ChunkedArray<V>, PolarsError>where
V: PolarsDataType,
F: FnMut(Option<AmortSeries>) -> Result<Option<K>, PolarsError> + Copy,
<V as PolarsDataType>::Array: ArrayFromIter<Option<K>>,
pub fn try_apply_amortized_generic<F, K, V>(
&self,
f: F,
) -> Result<ChunkedArray<V>, PolarsError>where
V: PolarsDataType,
F: FnMut(Option<AmortSeries>) -> Result<Option<K>, PolarsError> + Copy,
<V as PolarsDataType>::Array: ArrayFromIter<Option<K>>,
Try apply a closure F
elementwise.
pub fn for_each_amortized<F>(&self, f: F)
Source§impl ChunkedArray<FixedSizeListType>
impl ChunkedArray<FixedSizeListType>
Sourcepub fn inner_dtype(&self) -> &DataType
pub fn inner_dtype(&self) -> &DataType
Get the inner data type of the fixed size list.
pub fn width(&self) -> usize
Sourcepub unsafe fn to_logical(&mut self, inner_dtype: DataType)
pub unsafe fn to_logical(&mut self, inner_dtype: DataType)
§Safety
The caller must ensure that the logical type given fits the physical type of the array.
Sourcepub fn apply_to_inner(
&self,
func: &dyn Fn(Series) -> Result<Series, PolarsError>,
) -> Result<ChunkedArray<FixedSizeListType>, PolarsError>
pub fn apply_to_inner( &self, func: &dyn Fn(Series) -> Result<Series, PolarsError>, ) -> Result<ChunkedArray<FixedSizeListType>, PolarsError>
Ignore the list indices and apply func
to the inner type as Series
.
Sourcepub fn get_leaf_array(&self) -> Series
pub fn get_leaf_array(&self) -> Series
Recurse nested types until we are at the leaf array.
Source§impl<T> ChunkedArray<T>where
T: PolarsDataType,
<<T as PolarsDataType>::Array as StaticArray>::ValueT<'a>: for<'a> AsRef<[u8]>,
impl<T> ChunkedArray<T>where
T: PolarsDataType,
<<T as PolarsDataType>::Array as StaticArray>::ValueT<'a>: for<'a> AsRef<[u8]>,
Source§impl<T> ChunkedArray<T>where
T: PolarsDataType,
impl<T> ChunkedArray<T>where
T: PolarsDataType,
pub fn with_chunk<A>(name: PlSmallStr, arr: A) -> ChunkedArray<T>where
A: Array,
T: PolarsDataType<Array = A>,
pub fn with_chunk_like<A>(ca: &ChunkedArray<T>, arr: A) -> ChunkedArray<T>where
A: Array,
T: PolarsDataType<Array = A>,
pub fn from_chunk_iter<I>(name: PlSmallStr, iter: I) -> ChunkedArray<T>where
I: IntoIterator,
T: PolarsDataType<Array = <I as IntoIterator>::Item>,
<I as IntoIterator>::Item: Array,
pub fn from_chunk_iter_like<I>(ca: &ChunkedArray<T>, iter: I) -> ChunkedArray<T>where
I: IntoIterator,
T: PolarsDataType<Array = <I as IntoIterator>::Item>,
<I as IntoIterator>::Item: Array,
pub fn try_from_chunk_iter<I, A, E>( name: PlSmallStr, iter: I, ) -> Result<ChunkedArray<T>, E>
Sourcepub unsafe fn from_chunks(
name: PlSmallStr,
chunks: Vec<Box<dyn Array>>,
) -> ChunkedArray<T>
pub unsafe fn from_chunks( name: PlSmallStr, chunks: Vec<Box<dyn Array>>, ) -> ChunkedArray<T>
Create a new ChunkedArray
from existing chunks.
§Safety
The Arrow datatype of all chunks must match the PolarsDataType
T
.
Sourcepub unsafe fn with_chunks(&self, chunks: Vec<Box<dyn Array>>) -> ChunkedArray<T>
pub unsafe fn with_chunks(&self, chunks: Vec<Box<dyn Array>>) -> ChunkedArray<T>
§Safety
The Arrow datatype of all chunks must match the PolarsDataType
T
.
Sourcepub unsafe fn from_chunks_and_dtype(
name: PlSmallStr,
chunks: Vec<Box<dyn Array>>,
dtype: DataType,
) -> ChunkedArray<T>
pub unsafe fn from_chunks_and_dtype( name: PlSmallStr, chunks: Vec<Box<dyn Array>>, dtype: DataType, ) -> ChunkedArray<T>
Create a new ChunkedArray
from existing chunks.
§Safety
The Arrow datatype of all chunks must match the PolarsDataType
T
.
pub fn full_null_like(ca: &ChunkedArray<T>, length: usize) -> ChunkedArray<T>
Source§impl<T> ChunkedArray<T>where
T: PolarsNumericType,
impl<T> ChunkedArray<T>where
T: PolarsNumericType,
Sourcepub fn from_vec(
name: PlSmallStr,
v: Vec<<T as PolarsNumericType>::Native>,
) -> ChunkedArray<T>
pub fn from_vec( name: PlSmallStr, v: Vec<<T as PolarsNumericType>::Native>, ) -> ChunkedArray<T>
Create a new ChunkedArray by taking ownership of the Vec. This operation is zero copy.
Sourcepub fn from_vec_validity(
name: PlSmallStr,
values: Vec<<T as PolarsNumericType>::Native>,
buffer: Option<Bitmap>,
) -> ChunkedArray<T>
pub fn from_vec_validity( name: PlSmallStr, values: Vec<<T as PolarsNumericType>::Native>, buffer: Option<Bitmap>, ) -> ChunkedArray<T>
Create a new ChunkedArray from a Vec and a validity mask.
Sourcepub unsafe fn mmap_slice(
name: PlSmallStr,
values: &[<T as PolarsNumericType>::Native],
) -> ChunkedArray<T>
pub unsafe fn mmap_slice( name: PlSmallStr, values: &[<T as PolarsNumericType>::Native], ) -> ChunkedArray<T>
Create a temporary ChunkedArray
from a slice.
§Safety
The lifetime will be bound to the lifetime of the slice. This will not be checked by the borrowchecker.
Source§impl ChunkedArray<BooleanType>
impl ChunkedArray<BooleanType>
Sourcepub unsafe fn mmap_slice(
name: PlSmallStr,
values: &[u8],
offset: usize,
len: usize,
) -> ChunkedArray<BooleanType>
pub unsafe fn mmap_slice( name: PlSmallStr, values: &[u8], offset: usize, len: usize, ) -> ChunkedArray<BooleanType>
Create a temporary ChunkedArray
from a slice.
§Safety
The lifetime will be bound to the lifetime of the slice. This will not be checked by the borrowchecker.
Source§impl ChunkedArray<ListType>
impl ChunkedArray<ListType>
Sourcepub fn amortized_iter(
&self,
) -> AmortizedListIter<'_, impl Iterator<Item = Option<Box<dyn Array>>>>
pub fn amortized_iter( &self, ) -> AmortizedListIter<'_, impl Iterator<Item = Option<Box<dyn Array>>>>
This is an iterator over a ListChunked
that saves allocations.
A Series is:
1. Arc<ChunkedArray>
ChunkedArray is:
2. Vec< 3. ArrayRef>
The ArrayRef we indicated with 3. will be updated during iteration. The Series will be pinned in memory, saving an allocation for
- Arc<..>
- Vec<…>
If the returned AmortSeries
is cloned, the local copy will be replaced and a new container
will be set.
Sourcepub fn amortized_iter_with_name(
&self,
name: PlSmallStr,
) -> AmortizedListIter<'_, impl Iterator<Item = Option<Box<dyn Array>>>>
pub fn amortized_iter_with_name( &self, name: PlSmallStr, ) -> AmortizedListIter<'_, impl Iterator<Item = Option<Box<dyn Array>>>>
See amortized_iter
.
Sourcepub fn apply_amortized_generic<F, K, V>(&self, f: F) -> ChunkedArray<V>where
V: PolarsDataType,
F: FnMut(Option<AmortSeries>) -> Option<K> + Copy,
<V as PolarsDataType>::Array: ArrayFromIter<Option<K>>,
pub fn apply_amortized_generic<F, K, V>(&self, f: F) -> ChunkedArray<V>where
V: PolarsDataType,
F: FnMut(Option<AmortSeries>) -> Option<K> + Copy,
<V as PolarsDataType>::Array: ArrayFromIter<Option<K>>,
Apply a closure F
elementwise.
pub fn try_apply_amortized_generic<F, K, V>(
&self,
f: F,
) -> Result<ChunkedArray<V>, PolarsError>where
V: PolarsDataType,
F: FnMut(Option<AmortSeries>) -> Result<Option<K>, PolarsError> + Copy,
<V as PolarsDataType>::Array: ArrayFromIter<Option<K>>,
pub fn for_each_amortized<F>(&self, f: F)
Sourcepub fn zip_and_apply_amortized<'a, T, I, F>(
&'a self,
ca: &'a ChunkedArray<T>,
f: F,
) -> ChunkedArray<ListType>where
T: PolarsDataType,
&'a ChunkedArray<T>: IntoIterator<IntoIter = I>,
I: TrustedLen<Item = Option<<T as PolarsDataType>::Physical<'a>>>,
F: FnMut(Option<AmortSeries>, Option<<T as PolarsDataType>::Physical<'a>>) -> Option<Series>,
pub fn zip_and_apply_amortized<'a, T, I, F>(
&'a self,
ca: &'a ChunkedArray<T>,
f: F,
) -> ChunkedArray<ListType>where
T: PolarsDataType,
&'a ChunkedArray<T>: IntoIterator<IntoIter = I>,
I: TrustedLen<Item = Option<<T as PolarsDataType>::Physical<'a>>>,
F: FnMut(Option<AmortSeries>, Option<<T as PolarsDataType>::Physical<'a>>) -> Option<Series>,
Zip with a ChunkedArray
then apply a binary function F
elementwise.
pub fn binary_zip_and_apply_amortized<'a, T, U, F>(
&'a self,
ca1: &'a ChunkedArray<T>,
ca2: &'a ChunkedArray<U>,
f: F,
) -> ChunkedArray<ListType>where
T: PolarsDataType,
U: PolarsDataType,
F: FnMut(Option<AmortSeries>, Option<<T as PolarsDataType>::Physical<'a>>, Option<<U as PolarsDataType>::Physical<'a>>) -> Option<Series>,
pub fn try_zip_and_apply_amortized<'a, T, I, F>(
&'a self,
ca: &'a ChunkedArray<T>,
f: F,
) -> Result<ChunkedArray<ListType>, PolarsError>where
T: PolarsDataType,
&'a ChunkedArray<T>: IntoIterator<IntoIter = I>,
I: TrustedLen<Item = Option<<T as PolarsDataType>::Physical<'a>>>,
F: FnMut(Option<AmortSeries>, Option<<T as PolarsDataType>::Physical<'a>>) -> Result<Option<Series>, PolarsError>,
Sourcepub fn apply_amortized<F>(&self, f: F) -> ChunkedArray<ListType>
pub fn apply_amortized<F>(&self, f: F) -> ChunkedArray<ListType>
Apply a closure F
elementwise.
pub fn try_apply_amortized<F>( &self, f: F, ) -> Result<ChunkedArray<ListType>, PolarsError>
Source§impl ChunkedArray<ListType>
impl ChunkedArray<ListType>
Sourcepub fn inner_dtype(&self) -> &DataType
pub fn inner_dtype(&self) -> &DataType
Get the inner data type of the list.
pub fn set_inner_dtype(&mut self, dtype: DataType)
pub fn set_fast_explode(&mut self)
pub fn _can_fast_explode(&self) -> bool
Sourcepub unsafe fn to_logical(&mut self, inner_dtype: DataType)
pub unsafe fn to_logical(&mut self, inner_dtype: DataType)
Set the logical type of the ListChunked
.
§Safety
The caller must ensure that the logical type given fits the physical type of the array.
Sourcepub fn apply_to_inner(
&self,
func: &dyn Fn(Series) -> Result<Series, PolarsError>,
) -> Result<ChunkedArray<ListType>, PolarsError>
pub fn apply_to_inner( &self, func: &dyn Fn(Series) -> Result<Series, PolarsError>, ) -> Result<ChunkedArray<ListType>, PolarsError>
Ignore the list indices and apply func
to the inner type as Series
.
pub fn rechunk_and_trim_to_normalized_offsets(&self) -> ChunkedArray<ListType>
Source§impl ChunkedArray<Int64Type>
impl ChunkedArray<Int64Type>
pub fn into_datetime( self, timeunit: TimeUnit, tz: Option<PlSmallStr>, ) -> Logical<DatetimeType, Int64Type>
Source§impl ChunkedArray<Int128Type>
impl ChunkedArray<Int128Type>
pub fn into_decimal_unchecked( self, precision: Option<usize>, scale: usize, ) -> Logical<DecimalType, Int128Type>
pub fn into_decimal( self, precision: Option<usize>, scale: usize, ) -> Result<Logical<DecimalType, Int128Type>, PolarsError>
Source§impl ChunkedArray<Int64Type>
impl ChunkedArray<Int64Type>
pub fn into_duration( self, timeunit: TimeUnit, ) -> Logical<DurationType, Int64Type>
Source§impl<T> ChunkedArray<ObjectType<T>>where
T: PolarsObject,
impl<T> ChunkedArray<ObjectType<T>>where
T: PolarsObject,
pub fn new_from_vec(name: PlSmallStr, v: Vec<T>) -> ChunkedArray<ObjectType<T>>
pub fn new_from_vec_and_validity( name: PlSmallStr, v: Vec<T>, validity: Bitmap, ) -> ChunkedArray<ObjectType<T>>
pub fn new_empty(name: PlSmallStr) -> ChunkedArray<ObjectType<T>>
Source§impl<T> ChunkedArray<ObjectType<T>>where
T: PolarsObject,
impl<T> ChunkedArray<ObjectType<T>>where
T: PolarsObject,
Sourcepub unsafe fn get_object_unchecked(
&self,
index: usize,
) -> Option<&(dyn PolarsObjectSafe + 'static)>
pub unsafe fn get_object_unchecked( &self, index: usize, ) -> Option<&(dyn PolarsObjectSafe + 'static)>
Get a hold to an object that can be formatted or downcasted via the Any trait.
§Safety
No bounds checks
Sourcepub fn get_object(
&self,
index: usize,
) -> Option<&(dyn PolarsObjectSafe + 'static)>
pub fn get_object( &self, index: usize, ) -> Option<&(dyn PolarsObjectSafe + 'static)>
Get a hold to an object that can be formatted or downcasted via the Any trait.
Source§impl<T> ChunkedArray<T>
impl<T> ChunkedArray<T>
Source§impl<T> ChunkedArray<T>
impl<T> ChunkedArray<T>
Sourcepub fn sample_n(
&self,
n: usize,
with_replacement: bool,
shuffle: bool,
seed: Option<u64>,
) -> Result<ChunkedArray<T>, PolarsError>
pub fn sample_n( &self, n: usize, with_replacement: bool, shuffle: bool, seed: Option<u64>, ) -> Result<ChunkedArray<T>, PolarsError>
Sample n datapoints from this ChunkedArray
.
Sourcepub fn sample_frac(
&self,
frac: f64,
with_replacement: bool,
shuffle: bool,
seed: Option<u64>,
) -> Result<ChunkedArray<T>, PolarsError>
pub fn sample_frac( &self, frac: f64, with_replacement: bool, shuffle: bool, seed: Option<u64>, ) -> Result<ChunkedArray<T>, PolarsError>
Sample a fraction between 0.0-1.0 of this ChunkedArray
.
Source§impl<T> ChunkedArray<T>
impl<T> ChunkedArray<T>
Sourcepub fn rand_normal(
name: PlSmallStr,
length: usize,
mean: f64,
std_dev: f64,
) -> Result<ChunkedArray<T>, PolarsError>
pub fn rand_normal( name: PlSmallStr, length: usize, mean: f64, std_dev: f64, ) -> Result<ChunkedArray<T>, PolarsError>
Create ChunkedArray
with samples from a Normal distribution.
Sourcepub fn rand_standard_normal(name: PlSmallStr, length: usize) -> ChunkedArray<T>
pub fn rand_standard_normal(name: PlSmallStr, length: usize) -> ChunkedArray<T>
Create ChunkedArray
with samples from a Standard Normal distribution.
Sourcepub fn rand_uniform(
name: PlSmallStr,
length: usize,
low: f64,
high: f64,
) -> ChunkedArray<T>
pub fn rand_uniform( name: PlSmallStr, length: usize, low: f64, high: f64, ) -> ChunkedArray<T>
Create ChunkedArray
with samples from a Uniform distribution.
Source§impl ChunkedArray<BooleanType>
impl ChunkedArray<BooleanType>
Sourcepub fn rand_bernoulli(
name: PlSmallStr,
length: usize,
p: f64,
) -> Result<ChunkedArray<BooleanType>, PolarsError>
pub fn rand_bernoulli( name: PlSmallStr, length: usize, p: f64, ) -> Result<ChunkedArray<BooleanType>, PolarsError>
Create ChunkedArray
with samples from a Bernoulli distribution.
Source§impl ChunkedArray<StructType>
impl ChunkedArray<StructType>
pub fn from_columns( name: PlSmallStr, length: usize, fields: &[Column], ) -> Result<ChunkedArray<StructType>, PolarsError>
pub fn from_series<'a, I>( name: PlSmallStr, length: usize, fields: I, ) -> Result<ChunkedArray<StructType>, PolarsError>
pub fn struct_fields(&self) -> &[Field]
pub fn fields_as_series(&self) -> Vec<Series>
pub fn cast_with_options( &self, dtype: &DataType, cast_options: CastOptions, ) -> Result<Series, PolarsError>
pub fn cast(&self, dtype: &DataType) -> Result<Series, PolarsError>
pub fn _apply_fields<F>( &self, func: F, ) -> Result<ChunkedArray<StructType>, PolarsError>
pub fn try_apply_fields<F>( &self, func: F, ) -> Result<ChunkedArray<StructType>, PolarsError>
pub fn get_row_encoded_array( &self, options: SortOptions, ) -> Result<BinaryArray<i64>, PolarsError>
pub fn get_row_encoded( &self, options: SortOptions, ) -> Result<ChunkedArray<BinaryOffsetType>, PolarsError>
Sourcepub fn zip_outer_validity(&mut self, other: &ChunkedArray<StructType>)
pub fn zip_outer_validity(&mut self, other: &ChunkedArray<StructType>)
Combine the validities of two structs.
pub fn unnest(self) -> DataFrame
Sourcepub fn field_by_name(&self, name: &str) -> Result<Series, PolarsError>
pub fn field_by_name(&self, name: &str) -> Result<Series, PolarsError>
Get access to one of this StructChunked
’s fields
pub fn with_outer_validity( self, validity: Option<Bitmap>, ) -> ChunkedArray<StructType>
pub fn with_outer_validity_chunked( self, validity: ChunkedArray<BooleanType>, ) -> ChunkedArray<StructType>
Source§impl<T> ChunkedArray<T>where
T: PolarsNumericType,
impl<T> ChunkedArray<T>where
T: PolarsNumericType,
Sourcepub fn to_vec(&self) -> Vec<Option<<T as PolarsNumericType>::Native>>
pub fn to_vec(&self) -> Vec<Option<<T as PolarsNumericType>::Native>>
Convert to a Vec
of Option<T::Native>
.
Sourcepub fn to_vec_null_aware(
&self,
) -> Either<Vec<<T as PolarsNumericType>::Native>, Vec<Option<<T as PolarsNumericType>::Native>>> ⓘ
pub fn to_vec_null_aware( &self, ) -> Either<Vec<<T as PolarsNumericType>::Native>, Vec<Option<<T as PolarsNumericType>::Native>>> ⓘ
Convert to a Vec
but don’t return Option<T::Native>
if there are no null values
Source§impl<T> ChunkedArray<T>
impl<T> ChunkedArray<T>
Sourcepub fn metadata_dyn(&self) -> Option<RwLockReadGuard<'_, dyn MetadataTrait>>
pub fn metadata_dyn(&self) -> Option<RwLockReadGuard<'_, dyn MetadataTrait>>
Attempt to get a reference to the trait object containing the ChunkedArray
’s Metadata
This fails if there is a need to block.
Sourcepub fn boxed_metadata_dyn<'a>(&'a self) -> Box<dyn MetadataTrait + 'a>
pub fn boxed_metadata_dyn<'a>(&'a self) -> Box<dyn MetadataTrait + 'a>
Attempt to get a reference to the trait object containing the ChunkedArray
’s Metadata
This fails if there is a need to block.
Source§impl<T> ChunkedArray<T>where
T: PolarsDataType,
impl<T> ChunkedArray<T>where
T: PolarsDataType,
Sourcepub unsafe fn new_with_dims(
field: Arc<Field>,
chunks: Vec<Box<dyn Array>>,
length: u32,
null_count: u32,
) -> ChunkedArray<T>
pub unsafe fn new_with_dims( field: Arc<Field>, chunks: Vec<Box<dyn Array>>, length: u32, null_count: u32, ) -> ChunkedArray<T>
Create a new ChunkedArray
and explicitly set its length
and null_count
.
§Safety
The length and null_count must be correct.
Sourcepub fn metadata(&self) -> MetadataReadGuard<'_, T>
pub fn metadata(&self) -> MetadataReadGuard<'_, T>
Get a guard to read the ChunkedArray
’s Metadata
Sourcepub fn interior_mut_metadata(&self) -> RwLockWriteGuard<'_, Metadata<T>>
pub fn interior_mut_metadata(&self) -> RwLockWriteGuard<'_, Metadata<T>>
Get a guard to read/write the ChunkedArray
’s Metadata
Sourcepub fn metadata_arc(&self) -> &Arc<IMMetadata<T>>
pub fn metadata_arc(&self) -> &Arc<IMMetadata<T>>
Get a reference to Arc
that contains the ChunkedArray
’s Metadata
Sourcepub fn metadata_owned_arc(&self) -> Arc<IMMetadata<T>>
pub fn metadata_owned_arc(&self) -> Arc<IMMetadata<T>>
Get a Arc
that contains the ChunkedArray
’s Metadata
Sourcepub fn metadata_mut(&mut self) -> &mut Arc<IMMetadata<T>>
pub fn metadata_mut(&mut self) -> &mut Arc<IMMetadata<T>>
Get a mutable reference to the Arc
that contains the ChunkedArray
’s Metadata
pub fn unset_fast_explode_list(&mut self)
pub fn set_fast_explode_list(&mut self, value: bool)
pub fn get_fast_explode_list(&self) -> bool
pub fn get_flags(&self) -> MetadataFlags
pub fn is_sorted_flag(&self) -> IsSorted
Sourcepub fn set_sorted_flag(&mut self, sorted: IsSorted)
pub fn set_sorted_flag(&mut self, sorted: IsSorted)
Set the ‘sorted’ bit meta info.
Sourcepub fn with_sorted_flag(&self, sorted: IsSorted) -> ChunkedArray<T>
pub fn with_sorted_flag(&self, sorted: IsSorted) -> ChunkedArray<T>
Set the ‘sorted’ bit meta info.
pub fn get_min_value(&self) -> Option<<T as PolarsDataType>::OwnedPhysical>
pub fn get_max_value(&self) -> Option<<T as PolarsDataType>::OwnedPhysical>
pub fn get_distinct_count(&self) -> Option<u32>
pub fn merge_metadata(&mut self, md: Metadata<T>)
Sourcepub fn copy_metadata_cast<O>(
&mut self,
other: &ChunkedArray<O>,
props: MetadataProperties,
)where
O: PolarsDataType,
pub fn copy_metadata_cast<O>(
&mut self,
other: &ChunkedArray<O>,
props: MetadataProperties,
)where
O: PolarsDataType,
Copies Metadata
properties specified by props
from other
with different underlying PolarsDataType
into
self
.
This does not copy the properties with a different type between the Metadata
s (e.g.
min_value
and max_value
) and will panic on debug builds if that is attempted.
Sourcepub fn copy_metadata(
&mut self,
other: &ChunkedArray<T>,
props: MetadataProperties,
)
pub fn copy_metadata( &mut self, other: &ChunkedArray<T>, props: MetadataProperties, )
Copies Metadata
properties specified by props
from other
into self
.
Sourcepub fn first_non_null(&self) -> Option<usize>
pub fn first_non_null(&self) -> Option<usize>
Get the index of the first non null value in this ChunkedArray
.
Sourcepub fn last_non_null(&self) -> Option<usize>
pub fn last_non_null(&self) -> Option<usize>
Get the index of the last non null value in this ChunkedArray
.
pub fn drop_nulls(&self) -> ChunkedArray<T>
Sourcepub fn iter_validities(
&self,
) -> Map<Iter<'_, Box<dyn Array>>, fn(_: &Box<dyn Array>) -> Option<&Bitmap>> ⓘ
pub fn iter_validities( &self, ) -> Map<Iter<'_, Box<dyn Array>>, fn(_: &Box<dyn Array>) -> Option<&Bitmap>> ⓘ
Get the buffer of bits representing null values
Sourcepub fn has_nulls(&self) -> bool
pub fn has_nulls(&self) -> bool
Return if any the chunks in this ChunkedArray
have nulls.
Sourcepub fn shrink_to_fit(&mut self)
pub fn shrink_to_fit(&mut self)
Shrink the capacity of this array to fit its length.
pub fn clear(&self) -> ChunkedArray<T>
Sourcepub fn unpack_series_matching_type(
&self,
series: &Series,
) -> Result<&ChunkedArray<T>, PolarsError>
pub fn unpack_series_matching_type( &self, series: &Series, ) -> Result<&ChunkedArray<T>, PolarsError>
Series to ChunkedArray<T>
Sourcepub fn chunk_lengths(
&self,
) -> Map<Iter<'_, Box<dyn Array>>, fn(_: &Box<dyn Array>) -> usize> ⓘ
pub fn chunk_lengths( &self, ) -> Map<Iter<'_, Box<dyn Array>>, fn(_: &Box<dyn Array>) -> usize> ⓘ
Returns an iterator over the lengths of the chunks of the array.
Sourcepub unsafe fn chunks_mut(&mut self) -> &mut Vec<Box<dyn Array>>
pub unsafe fn chunks_mut(&mut self) -> &mut Vec<Box<dyn Array>>
Sourcepub fn is_optimal_aligned(&self) -> bool
pub fn is_optimal_aligned(&self) -> bool
Returns true if contains a single chunk and has no null values
Sourcepub fn dtype(&self) -> &DataType
pub fn dtype(&self) -> &DataType
Get data type of ChunkedArray
.
Sourcepub fn name(&self) -> &PlSmallStr
pub fn name(&self) -> &PlSmallStr
Name of the ChunkedArray
.
Sourcepub fn rename(&mut self, name: PlSmallStr)
pub fn rename(&mut self, name: PlSmallStr)
Rename this ChunkedArray
.
Sourcepub fn with_name(self, name: PlSmallStr) -> ChunkedArray<T>
pub fn with_name(self, name: PlSmallStr) -> ChunkedArray<T>
Return this ChunkedArray
with a new name.
Source§impl<T> ChunkedArray<T>where
T: PolarsDataType,
impl<T> ChunkedArray<T>where
T: PolarsDataType,
Sourcepub fn get(&self, idx: usize) -> Option<<T as PolarsDataType>::Physical<'_>>
pub fn get(&self, idx: usize) -> Option<<T as PolarsDataType>::Physical<'_>>
Get a single value from this ChunkedArray
. If the return values is None
this
indicates a NULL value.
§Panics
This function will panic if idx
is out of bounds.
Sourcepub unsafe fn get_unchecked(
&self,
idx: usize,
) -> Option<<T as PolarsDataType>::Physical<'_>>
pub unsafe fn get_unchecked( &self, idx: usize, ) -> Option<<T as PolarsDataType>::Physical<'_>>
Get a single value from this ChunkedArray
. If the return values is None
this
indicates a NULL value.
§Safety
It is the callers responsibility that the idx < self.len()
.
Sourcepub unsafe fn value_unchecked(
&self,
idx: usize,
) -> <T as PolarsDataType>::Physical<'_>
pub unsafe fn value_unchecked( &self, idx: usize, ) -> <T as PolarsDataType>::Physical<'_>
Get a single value from this ChunkedArray
. Null values are ignored and the returned
value could be garbage if it was masked out by NULL. Note that the value always is initialized.
§Safety
It is the callers responsibility that the idx < self.len()
.
pub fn first(&self) -> Option<<T as PolarsDataType>::Physical<'_>>
pub fn last(&self) -> Option<<T as PolarsDataType>::Physical<'_>>
Source§impl ChunkedArray<ListType>
impl ChunkedArray<ListType>
pub fn get_as_series(&self, idx: usize) -> Option<Series>
Source§impl ChunkedArray<FixedSizeListType>
impl ChunkedArray<FixedSizeListType>
pub fn get_as_series(&self, idx: usize) -> Option<Series>
dtype-array
only.Source§impl<T> ChunkedArray<T>where
T: PolarsDataType,
impl<T> ChunkedArray<T>where
T: PolarsDataType,
pub fn layout(&self) -> ChunkedArrayLayout<'_, T>
Source§impl<T> ChunkedArray<T>where
T: PolarsNumericType,
impl<T> ChunkedArray<T>where
T: PolarsNumericType,
Sourcepub fn cont_slice(
&self,
) -> Result<&[<T as PolarsNumericType>::Native], PolarsError>
pub fn cont_slice( &self, ) -> Result<&[<T as PolarsNumericType>::Native], PolarsError>
Returns the values of the array as a contiguous slice.
Sourcepub fn data_views(&self) -> impl DoubleEndedIterator
pub fn data_views(&self) -> impl DoubleEndedIterator
Get slices of the underlying arrow data. NOTE: null values should be taken into account by the user of these slices as they are handled separately
pub fn into_no_null_iter( &self, ) -> impl Send + Sync + ExactSizeIterator + DoubleEndedIterator + TrustedLen
Source§impl<T> ChunkedArray<T>
impl<T> ChunkedArray<T>
Sourcepub unsafe fn group_tuples_perfect(
&self,
num_groups: usize,
multithreaded: bool,
group_capacity: usize,
) -> GroupsProxy
pub unsafe fn group_tuples_perfect( &self, num_groups: usize, multithreaded: bool, group_capacity: usize, ) -> GroupsProxy
Use the indexes as perfect groups.
§Safety
This ChunkedArray must contain each value in [0..num_groups) at least once, and nothing outside this range.
Source§impl<T> ChunkedArray<T>where
T: PolarsNumericType,
impl<T> ChunkedArray<T>where
T: PolarsNumericType,
Sourcepub fn new_vec(
name: PlSmallStr,
v: Vec<<T as PolarsNumericType>::Native>,
) -> ChunkedArray<T>
pub fn new_vec( name: PlSmallStr, v: Vec<<T as PolarsNumericType>::Native>, ) -> ChunkedArray<T>
Specialization that prevents an allocation
prefer this over ChunkedArray::new when you have a Vec<T::Native>
and no null values.
Source§impl<T> ChunkedArray<T>
impl<T> ChunkedArray<T>
We cannot override the left hand side behaviour. So we create a trait LhsNumOps. This allows for 1.add(&Series)
Sourcepub fn lhs_sub<N>(&self, lhs: N) -> ChunkedArray<T>
pub fn lhs_sub<N>(&self, lhs: N) -> ChunkedArray<T>
Apply lhs - self
Sourcepub fn lhs_div<N>(&self, lhs: N) -> ChunkedArray<T>
pub fn lhs_div<N>(&self, lhs: N) -> ChunkedArray<T>
Apply lhs / self
Sourcepub fn lhs_rem<N>(&self, lhs: N) -> ChunkedArray<T>
pub fn lhs_rem<N>(&self, lhs: N) -> ChunkedArray<T>
Apply lhs % self
Trait Implementations§
Source§impl Add<&[u8]> for &ChunkedArray<BinaryType>
impl Add<&[u8]> for &ChunkedArray<BinaryType>
Source§type Output = ChunkedArray<BinaryType>
type Output = ChunkedArray<BinaryType>
+
operator.Source§fn add(self, rhs: &[u8]) -> <&ChunkedArray<BinaryType> as Add<&[u8]>>::Output
fn add(self, rhs: &[u8]) -> <&ChunkedArray<BinaryType> as Add<&[u8]>>::Output
+
operation. Read moreSource§impl Add<&str> for &ChunkedArray<StringType>
impl Add<&str> for &ChunkedArray<StringType>
Source§type Output = ChunkedArray<StringType>
type Output = ChunkedArray<StringType>
+
operator.Source§fn add(self, rhs: &str) -> <&ChunkedArray<StringType> as Add<&str>>::Output
fn add(self, rhs: &str) -> <&ChunkedArray<StringType> as Add<&str>>::Output
+
operation. Read moreSource§impl<T, N> Add<N> for &ChunkedArray<T>
impl<T, N> Add<N> for &ChunkedArray<T>
Source§impl<T, N> Add<N> for ChunkedArray<T>
impl<T, N> Add<N> for ChunkedArray<T>
Source§impl Add for &ChunkedArray<BinaryType>
impl Add for &ChunkedArray<BinaryType>
Source§type Output = ChunkedArray<BinaryType>
type Output = ChunkedArray<BinaryType>
+
operator.Source§fn add(
self,
rhs: &ChunkedArray<BinaryType>,
) -> <&ChunkedArray<BinaryType> as Add>::Output
fn add( self, rhs: &ChunkedArray<BinaryType>, ) -> <&ChunkedArray<BinaryType> as Add>::Output
+
operation. Read moreSource§impl Add for &ChunkedArray<BooleanType>
impl Add for &ChunkedArray<BooleanType>
Source§type Output = ChunkedArray<UInt32Type>
type Output = ChunkedArray<UInt32Type>
+
operator.Source§fn add(
self,
rhs: &ChunkedArray<BooleanType>,
) -> <&ChunkedArray<BooleanType> as Add>::Output
fn add( self, rhs: &ChunkedArray<BooleanType>, ) -> <&ChunkedArray<BooleanType> as Add>::Output
+
operation. Read moreSource§impl Add for &ChunkedArray<StringType>
impl Add for &ChunkedArray<StringType>
Source§type Output = ChunkedArray<StringType>
type Output = ChunkedArray<StringType>
+
operator.Source§fn add(
self,
rhs: &ChunkedArray<StringType>,
) -> <&ChunkedArray<StringType> as Add>::Output
fn add( self, rhs: &ChunkedArray<StringType>, ) -> <&ChunkedArray<StringType> as Add>::Output
+
operation. Read moreSource§impl<T> Add for &ChunkedArray<T>where
T: PolarsNumericType,
impl<T> Add for &ChunkedArray<T>where
T: PolarsNumericType,
Source§type Output = ChunkedArray<T>
type Output = ChunkedArray<T>
+
operator.Source§fn add(self, rhs: &ChunkedArray<T>) -> <&ChunkedArray<T> as Add>::Output
fn add(self, rhs: &ChunkedArray<T>) -> <&ChunkedArray<T> as Add>::Output
+
operation. Read moreSource§impl Add for ChunkedArray<BinaryType>
impl Add for ChunkedArray<BinaryType>
Source§type Output = ChunkedArray<BinaryType>
type Output = ChunkedArray<BinaryType>
+
operator.Source§fn add(
self,
rhs: ChunkedArray<BinaryType>,
) -> <ChunkedArray<BinaryType> as Add>::Output
fn add( self, rhs: ChunkedArray<BinaryType>, ) -> <ChunkedArray<BinaryType> as Add>::Output
+
operation. Read moreSource§impl Add for ChunkedArray<BooleanType>
impl Add for ChunkedArray<BooleanType>
Source§type Output = ChunkedArray<UInt32Type>
type Output = ChunkedArray<UInt32Type>
+
operator.Source§fn add(
self,
rhs: ChunkedArray<BooleanType>,
) -> <ChunkedArray<BooleanType> as Add>::Output
fn add( self, rhs: ChunkedArray<BooleanType>, ) -> <ChunkedArray<BooleanType> as Add>::Output
+
operation. Read moreSource§impl Add for ChunkedArray<StringType>
impl Add for ChunkedArray<StringType>
Source§type Output = ChunkedArray<StringType>
type Output = ChunkedArray<StringType>
+
operator.Source§fn add(
self,
rhs: ChunkedArray<StringType>,
) -> <ChunkedArray<StringType> as Add>::Output
fn add( self, rhs: ChunkedArray<StringType>, ) -> <ChunkedArray<StringType> as Add>::Output
+
operation. Read moreSource§impl<T> Add for ChunkedArray<T>where
T: PolarsNumericType,
impl<T> Add for ChunkedArray<T>where
T: PolarsNumericType,
Source§type Output = ChunkedArray<T>
type Output = ChunkedArray<T>
+
operator.Source§fn add(self, rhs: ChunkedArray<T>) -> <ChunkedArray<T> as Add>::Output
fn add(self, rhs: ChunkedArray<T>) -> <ChunkedArray<T> as Add>::Output
+
operation. Read moreSource§impl AggList for ChunkedArray<BinaryType>
impl AggList for ChunkedArray<BinaryType>
Source§impl AggList for ChunkedArray<BooleanType>
impl AggList for ChunkedArray<BooleanType>
Source§impl AggList for ChunkedArray<FixedSizeListType>
Available on crate feature dtype-array
only.
impl AggList for ChunkedArray<FixedSizeListType>
dtype-array
only.Source§impl AggList for ChunkedArray<ListType>
impl AggList for ChunkedArray<ListType>
Source§impl<T> AggList for ChunkedArray<ObjectType<T>>where
T: PolarsObject,
Available on crate feature object
only.
impl<T> AggList for ChunkedArray<ObjectType<T>>where
T: PolarsObject,
object
only.Source§impl AggList for ChunkedArray<StringType>
impl AggList for ChunkedArray<StringType>
Source§impl AggList for ChunkedArray<StructType>
Available on crate feature dtype-struct
only.
impl AggList for ChunkedArray<StructType>
dtype-struct
only.Source§impl<T> AggList for ChunkedArray<T>
impl<T> AggList for ChunkedArray<T>
Source§impl<T> ArithmeticChunked for &ChunkedArray<T>where
T: PolarsNumericType,
impl<T> ArithmeticChunked for &ChunkedArray<T>where
T: PolarsNumericType,
type Scalar = <T as PolarsNumericType>::Native
type Out = ChunkedArray<T>
type TrueDivOut = ChunkedArray<<<T as PolarsNumericType>::Native as NumericNative>::TrueDivPolarsType>
fn wrapping_abs(self) -> <&ChunkedArray<T> as ArithmeticChunked>::Out
fn wrapping_neg(self) -> <&ChunkedArray<T> as ArithmeticChunked>::Out
fn wrapping_add( self, rhs: &ChunkedArray<T>, ) -> <&ChunkedArray<T> as ArithmeticChunked>::Out
fn wrapping_sub( self, rhs: &ChunkedArray<T>, ) -> <&ChunkedArray<T> as ArithmeticChunked>::Out
fn wrapping_mul( self, rhs: &ChunkedArray<T>, ) -> <&ChunkedArray<T> as ArithmeticChunked>::Out
fn wrapping_floor_div( self, rhs: &ChunkedArray<T>, ) -> <&ChunkedArray<T> as ArithmeticChunked>::Out
fn wrapping_trunc_div( self, rhs: &ChunkedArray<T>, ) -> <&ChunkedArray<T> as ArithmeticChunked>::Out
fn wrapping_mod( self, rhs: &ChunkedArray<T>, ) -> <&ChunkedArray<T> as ArithmeticChunked>::Out
fn wrapping_add_scalar( self, rhs: <&ChunkedArray<T> as ArithmeticChunked>::Scalar, ) -> <&ChunkedArray<T> as ArithmeticChunked>::Out
fn wrapping_sub_scalar( self, rhs: <&ChunkedArray<T> as ArithmeticChunked>::Scalar, ) -> <&ChunkedArray<T> as ArithmeticChunked>::Out
fn wrapping_sub_scalar_lhs( lhs: <&ChunkedArray<T> as ArithmeticChunked>::Scalar, rhs: &ChunkedArray<T>, ) -> <&ChunkedArray<T> as ArithmeticChunked>::Out
fn wrapping_mul_scalar( self, rhs: <&ChunkedArray<T> as ArithmeticChunked>::Scalar, ) -> <&ChunkedArray<T> as ArithmeticChunked>::Out
fn wrapping_floor_div_scalar( self, rhs: <&ChunkedArray<T> as ArithmeticChunked>::Scalar, ) -> <&ChunkedArray<T> as ArithmeticChunked>::Out
fn wrapping_floor_div_scalar_lhs( lhs: <&ChunkedArray<T> as ArithmeticChunked>::Scalar, rhs: &ChunkedArray<T>, ) -> <&ChunkedArray<T> as ArithmeticChunked>::Out
fn wrapping_trunc_div_scalar( self, rhs: <&ChunkedArray<T> as ArithmeticChunked>::Scalar, ) -> <&ChunkedArray<T> as ArithmeticChunked>::Out
fn wrapping_trunc_div_scalar_lhs( lhs: <&ChunkedArray<T> as ArithmeticChunked>::Scalar, rhs: &ChunkedArray<T>, ) -> <&ChunkedArray<T> as ArithmeticChunked>::Out
fn wrapping_mod_scalar( self, rhs: <&ChunkedArray<T> as ArithmeticChunked>::Scalar, ) -> <&ChunkedArray<T> as ArithmeticChunked>::Out
fn wrapping_mod_scalar_lhs( lhs: <&ChunkedArray<T> as ArithmeticChunked>::Scalar, rhs: &ChunkedArray<T>, ) -> <&ChunkedArray<T> as ArithmeticChunked>::Out
fn true_div( self, rhs: &ChunkedArray<T>, ) -> <&ChunkedArray<T> as ArithmeticChunked>::TrueDivOut
fn true_div_scalar( self, rhs: <&ChunkedArray<T> as ArithmeticChunked>::Scalar, ) -> <&ChunkedArray<T> as ArithmeticChunked>::TrueDivOut
fn true_div_scalar_lhs( lhs: <&ChunkedArray<T> as ArithmeticChunked>::Scalar, rhs: &ChunkedArray<T>, ) -> <&ChunkedArray<T> as ArithmeticChunked>::TrueDivOut
fn legacy_div( self, rhs: &ChunkedArray<T>, ) -> <&ChunkedArray<T> as ArithmeticChunked>::Out
fn legacy_div_scalar( self, rhs: <&ChunkedArray<T> as ArithmeticChunked>::Scalar, ) -> <&ChunkedArray<T> as ArithmeticChunked>::Out
fn legacy_div_scalar_lhs( lhs: <&ChunkedArray<T> as ArithmeticChunked>::Scalar, rhs: &ChunkedArray<T>, ) -> <&ChunkedArray<T> as ArithmeticChunked>::Out
Source§impl<T> ArithmeticChunked for ChunkedArray<T>where
T: PolarsNumericType,
impl<T> ArithmeticChunked for ChunkedArray<T>where
T: PolarsNumericType,
type Scalar = <T as PolarsNumericType>::Native
type Out = ChunkedArray<T>
type TrueDivOut = ChunkedArray<<<T as PolarsNumericType>::Native as NumericNative>::TrueDivPolarsType>
fn wrapping_abs(self) -> <ChunkedArray<T> as ArithmeticChunked>::Out
fn wrapping_neg(self) -> <ChunkedArray<T> as ArithmeticChunked>::Out
fn wrapping_add( self, rhs: ChunkedArray<T>, ) -> <ChunkedArray<T> as ArithmeticChunked>::Out
fn wrapping_sub( self, rhs: ChunkedArray<T>, ) -> <ChunkedArray<T> as ArithmeticChunked>::Out
fn wrapping_mul( self, rhs: ChunkedArray<T>, ) -> <ChunkedArray<T> as ArithmeticChunked>::Out
fn wrapping_floor_div( self, rhs: ChunkedArray<T>, ) -> <ChunkedArray<T> as ArithmeticChunked>::Out
fn wrapping_trunc_div( self, rhs: ChunkedArray<T>, ) -> <ChunkedArray<T> as ArithmeticChunked>::Out
fn wrapping_mod( self, rhs: ChunkedArray<T>, ) -> <ChunkedArray<T> as ArithmeticChunked>::Out
fn wrapping_add_scalar( self, rhs: <ChunkedArray<T> as ArithmeticChunked>::Scalar, ) -> <ChunkedArray<T> as ArithmeticChunked>::Out
fn wrapping_sub_scalar( self, rhs: <ChunkedArray<T> as ArithmeticChunked>::Scalar, ) -> <ChunkedArray<T> as ArithmeticChunked>::Out
fn wrapping_sub_scalar_lhs( lhs: <ChunkedArray<T> as ArithmeticChunked>::Scalar, rhs: ChunkedArray<T>, ) -> <ChunkedArray<T> as ArithmeticChunked>::Out
fn wrapping_mul_scalar( self, rhs: <ChunkedArray<T> as ArithmeticChunked>::Scalar, ) -> <ChunkedArray<T> as ArithmeticChunked>::Out
fn wrapping_floor_div_scalar( self, rhs: <ChunkedArray<T> as ArithmeticChunked>::Scalar, ) -> <ChunkedArray<T> as ArithmeticChunked>::Out
fn wrapping_floor_div_scalar_lhs( lhs: <ChunkedArray<T> as ArithmeticChunked>::Scalar, rhs: ChunkedArray<T>, ) -> <ChunkedArray<T> as ArithmeticChunked>::Out
fn wrapping_trunc_div_scalar( self, rhs: <ChunkedArray<T> as ArithmeticChunked>::Scalar, ) -> <ChunkedArray<T> as ArithmeticChunked>::Out
fn wrapping_trunc_div_scalar_lhs( lhs: <ChunkedArray<T> as ArithmeticChunked>::Scalar, rhs: ChunkedArray<T>, ) -> <ChunkedArray<T> as ArithmeticChunked>::Out
fn wrapping_mod_scalar( self, rhs: <ChunkedArray<T> as ArithmeticChunked>::Scalar, ) -> <ChunkedArray<T> as ArithmeticChunked>::Out
fn wrapping_mod_scalar_lhs( lhs: <ChunkedArray<T> as ArithmeticChunked>::Scalar, rhs: ChunkedArray<T>, ) -> <ChunkedArray<T> as ArithmeticChunked>::Out
fn true_div( self, rhs: ChunkedArray<T>, ) -> <ChunkedArray<T> as ArithmeticChunked>::TrueDivOut
fn true_div_scalar( self, rhs: <ChunkedArray<T> as ArithmeticChunked>::Scalar, ) -> <ChunkedArray<T> as ArithmeticChunked>::TrueDivOut
fn true_div_scalar_lhs( lhs: <ChunkedArray<T> as ArithmeticChunked>::Scalar, rhs: ChunkedArray<T>, ) -> <ChunkedArray<T> as ArithmeticChunked>::TrueDivOut
fn legacy_div( self, rhs: ChunkedArray<T>, ) -> <ChunkedArray<T> as ArithmeticChunked>::Out
fn legacy_div_scalar( self, rhs: <ChunkedArray<T> as ArithmeticChunked>::Scalar, ) -> <ChunkedArray<T> as ArithmeticChunked>::Out
fn legacy_div_scalar_lhs( lhs: <ChunkedArray<T> as ArithmeticChunked>::Scalar, rhs: ChunkedArray<T>, ) -> <ChunkedArray<T> as ArithmeticChunked>::Out
Source§impl ArrayNameSpace for ChunkedArray<FixedSizeListType>
impl ArrayNameSpace for ChunkedArray<FixedSizeListType>
fn array_max(&self) -> Series
fn array_min(&self) -> Series
fn array_sum(&self) -> Result<Series, PolarsError>
fn array_median(&self) -> Result<Series, PolarsError>
fn array_std(&self, ddof: u8) -> Result<Series, PolarsError>
fn array_var(&self, ddof: u8) -> Result<Series, PolarsError>
fn array_unique(&self) -> Result<ChunkedArray<ListType>, PolarsError>
fn array_unique_stable(&self) -> Result<ChunkedArray<ListType>, PolarsError>
fn array_n_unique(&self) -> Result<ChunkedArray<UInt32Type>, PolarsError>
fn array_sort( &self, options: SortOptions, ) -> Result<ChunkedArray<FixedSizeListType>, PolarsError>
fn array_reverse(&self) -> ChunkedArray<FixedSizeListType>
fn array_arg_min(&self) -> ChunkedArray<UInt32Type>
fn array_arg_max(&self) -> ChunkedArray<UInt32Type>
fn array_get( &self, index: &ChunkedArray<Int64Type>, null_on_oob: bool, ) -> Result<Series, PolarsError>
fn array_join( &self, separator: &ChunkedArray<StringType>, ignore_nulls: bool, ) -> Result<Series, PolarsError>
fn array_shift(&self, n: &Series) -> Result<Series, PolarsError>
Source§impl AsArray for ChunkedArray<FixedSizeListType>
impl AsArray for ChunkedArray<FixedSizeListType>
fn as_array(&self) -> &ChunkedArray<FixedSizeListType>
Source§impl AsBinary for ChunkedArray<BinaryType>
impl AsBinary for ChunkedArray<BinaryType>
fn as_binary(&self) -> &ChunkedArray<BinaryType>
Source§impl AsList for ChunkedArray<ListType>
impl AsList for ChunkedArray<ListType>
fn as_list(&self) -> &ChunkedArray<ListType>
Source§impl<T> AsMut<ChunkedArray<T>> for dyn SeriesTrait + '_where
T: 'static + PolarsDataType,
impl<T> AsMut<ChunkedArray<T>> for dyn SeriesTrait + '_where
T: 'static + PolarsDataType,
Source§fn as_mut(&mut self) -> &mut ChunkedArray<T>
fn as_mut(&mut self) -> &mut ChunkedArray<T>
Source§impl<T> AsRef<ChunkedArray<T>> for ChunkedArray<T>where
T: PolarsDataType,
impl<T> AsRef<ChunkedArray<T>> for ChunkedArray<T>where
T: PolarsDataType,
Source§fn as_ref(&self) -> &ChunkedArray<T>
fn as_ref(&self) -> &ChunkedArray<T>
Source§impl<T> AsRef<ChunkedArray<T>> for dyn SeriesTrait + '_where
T: 'static + PolarsDataType,
impl<T> AsRef<ChunkedArray<T>> for dyn SeriesTrait + '_where
T: 'static + PolarsDataType,
Source§fn as_ref(&self) -> &ChunkedArray<T>
fn as_ref(&self) -> &ChunkedArray<T>
Source§impl<T> AsRefDataType for ChunkedArray<T>where
T: PolarsDataType,
impl<T> AsRefDataType for ChunkedArray<T>where
T: PolarsDataType,
fn as_ref_dtype(&self) -> &DataType
Source§impl AsString for ChunkedArray<StringType>
impl AsString for ChunkedArray<StringType>
fn as_string(&self) -> &ChunkedArray<StringType>
Source§impl AsString for ChunkedArray<StringType>
impl AsString for ChunkedArray<StringType>
fn as_string(&self) -> &ChunkedArray<StringType>
Source§impl BinaryNameSpaceImpl for ChunkedArray<BinaryType>
impl BinaryNameSpaceImpl for ChunkedArray<BinaryType>
Source§fn contains(&self, lit: &[u8]) -> ChunkedArray<BooleanType>
fn contains(&self, lit: &[u8]) -> ChunkedArray<BooleanType>
fn contains_chunked( &self, lit: &ChunkedArray<BinaryType>, ) -> ChunkedArray<BooleanType>
Source§fn ends_with(&self, sub: &[u8]) -> ChunkedArray<BooleanType>
fn ends_with(&self, sub: &[u8]) -> ChunkedArray<BooleanType>
Source§fn starts_with(&self, sub: &[u8]) -> ChunkedArray<BooleanType>
fn starts_with(&self, sub: &[u8]) -> ChunkedArray<BooleanType>
fn starts_with_chunked( &self, prefix: &ChunkedArray<BinaryType>, ) -> ChunkedArray<BooleanType>
fn ends_with_chunked( &self, suffix: &ChunkedArray<BinaryType>, ) -> ChunkedArray<BooleanType>
Source§fn size_bytes(&self) -> ChunkedArray<UInt32Type>
fn size_bytes(&self) -> ChunkedArray<UInt32Type>
Source§impl BitAnd for &ChunkedArray<BooleanType>
impl BitAnd for &ChunkedArray<BooleanType>
Source§type Output = ChunkedArray<BooleanType>
type Output = ChunkedArray<BooleanType>
&
operator.Source§fn bitand(
self,
rhs: &ChunkedArray<BooleanType>,
) -> <&ChunkedArray<BooleanType> as BitAnd>::Output
fn bitand( self, rhs: &ChunkedArray<BooleanType>, ) -> <&ChunkedArray<BooleanType> as BitAnd>::Output
&
operation. Read moreSource§impl<T> BitAnd for &ChunkedArray<T>where
T: PolarsIntegerType,
<T as PolarsNumericType>::Native: BitAnd<Output = <T as PolarsNumericType>::Native>,
impl<T> BitAnd for &ChunkedArray<T>where
T: PolarsIntegerType,
<T as PolarsNumericType>::Native: BitAnd<Output = <T as PolarsNumericType>::Native>,
Source§type Output = ChunkedArray<T>
type Output = ChunkedArray<T>
&
operator.Source§fn bitand(self, rhs: &ChunkedArray<T>) -> <&ChunkedArray<T> as BitAnd>::Output
fn bitand(self, rhs: &ChunkedArray<T>) -> <&ChunkedArray<T> as BitAnd>::Output
&
operation. Read moreSource§impl BitAnd for ChunkedArray<BooleanType>
impl BitAnd for ChunkedArray<BooleanType>
Source§type Output = ChunkedArray<BooleanType>
type Output = ChunkedArray<BooleanType>
&
operator.Source§fn bitand(
self,
rhs: ChunkedArray<BooleanType>,
) -> <ChunkedArray<BooleanType> as BitAnd>::Output
fn bitand( self, rhs: ChunkedArray<BooleanType>, ) -> <ChunkedArray<BooleanType> as BitAnd>::Output
&
operation. Read moreSource§impl BitOr for &ChunkedArray<BooleanType>
impl BitOr for &ChunkedArray<BooleanType>
Source§type Output = ChunkedArray<BooleanType>
type Output = ChunkedArray<BooleanType>
|
operator.Source§fn bitor(
self,
rhs: &ChunkedArray<BooleanType>,
) -> <&ChunkedArray<BooleanType> as BitOr>::Output
fn bitor( self, rhs: &ChunkedArray<BooleanType>, ) -> <&ChunkedArray<BooleanType> as BitOr>::Output
|
operation. Read moreSource§impl<T> BitOr for &ChunkedArray<T>where
T: PolarsIntegerType,
<T as PolarsNumericType>::Native: BitOr<Output = <T as PolarsNumericType>::Native>,
impl<T> BitOr for &ChunkedArray<T>where
T: PolarsIntegerType,
<T as PolarsNumericType>::Native: BitOr<Output = <T as PolarsNumericType>::Native>,
Source§type Output = ChunkedArray<T>
type Output = ChunkedArray<T>
|
operator.Source§fn bitor(self, rhs: &ChunkedArray<T>) -> <&ChunkedArray<T> as BitOr>::Output
fn bitor(self, rhs: &ChunkedArray<T>) -> <&ChunkedArray<T> as BitOr>::Output
|
operation. Read moreSource§impl BitOr for ChunkedArray<BooleanType>
impl BitOr for ChunkedArray<BooleanType>
Source§type Output = ChunkedArray<BooleanType>
type Output = ChunkedArray<BooleanType>
|
operator.Source§fn bitor(
self,
rhs: ChunkedArray<BooleanType>,
) -> <ChunkedArray<BooleanType> as BitOr>::Output
fn bitor( self, rhs: ChunkedArray<BooleanType>, ) -> <ChunkedArray<BooleanType> as BitOr>::Output
|
operation. Read moreSource§impl BitXor for &ChunkedArray<BooleanType>
impl BitXor for &ChunkedArray<BooleanType>
Source§type Output = ChunkedArray<BooleanType>
type Output = ChunkedArray<BooleanType>
^
operator.Source§fn bitxor(
self,
rhs: &ChunkedArray<BooleanType>,
) -> <&ChunkedArray<BooleanType> as BitXor>::Output
fn bitxor( self, rhs: &ChunkedArray<BooleanType>, ) -> <&ChunkedArray<BooleanType> as BitXor>::Output
^
operation. Read moreSource§impl<T> BitXor for &ChunkedArray<T>where
T: PolarsIntegerType,
<T as PolarsNumericType>::Native: BitXor<Output = <T as PolarsNumericType>::Native>,
impl<T> BitXor for &ChunkedArray<T>where
T: PolarsIntegerType,
<T as PolarsNumericType>::Native: BitXor<Output = <T as PolarsNumericType>::Native>,
Source§type Output = ChunkedArray<T>
type Output = ChunkedArray<T>
^
operator.Source§fn bitxor(self, rhs: &ChunkedArray<T>) -> <&ChunkedArray<T> as BitXor>::Output
fn bitxor(self, rhs: &ChunkedArray<T>) -> <&ChunkedArray<T> as BitXor>::Output
^
operation. Read moreSource§impl BitXor for ChunkedArray<BooleanType>
impl BitXor for ChunkedArray<BooleanType>
Source§type Output = ChunkedArray<BooleanType>
type Output = ChunkedArray<BooleanType>
^
operator.Source§fn bitxor(
self,
rhs: ChunkedArray<BooleanType>,
) -> <ChunkedArray<BooleanType> as BitXor>::Output
fn bitxor( self, rhs: ChunkedArray<BooleanType>, ) -> <ChunkedArray<BooleanType> as BitXor>::Output
^
operation. Read moreSource§impl<T> ChunkAgg<<T as PolarsNumericType>::Native> for ChunkedArray<T>where
PrimitiveArray<<T as PolarsNumericType>::Native>: for<'a> MinMaxKernel<Scalar<'a> = <T as PolarsNumericType>::Native>,
<<T as PolarsNumericType>::Native as Simd>::Simd: Add<Output = <<T as PolarsNumericType>::Native as Simd>::Simd> + Sum<<T as PolarsNumericType>::Native>,
T: PolarsNumericType,
impl<T> ChunkAgg<<T as PolarsNumericType>::Native> for ChunkedArray<T>where
PrimitiveArray<<T as PolarsNumericType>::Native>: for<'a> MinMaxKernel<Scalar<'a> = <T as PolarsNumericType>::Native>,
<<T as PolarsNumericType>::Native as Simd>::Simd: Add<Output = <<T as PolarsNumericType>::Native as Simd>::Simd> + Sum<<T as PolarsNumericType>::Native>,
T: PolarsNumericType,
Source§fn sum(&self) -> Option<<T as PolarsNumericType>::Native>
fn sum(&self) -> Option<<T as PolarsNumericType>::Native>
None
if not implemented for T
.
If the array is empty, 0
is returnedfn _sum_as_f64(&self) -> f64
fn min(&self) -> Option<<T as PolarsNumericType>::Native>
Source§fn max(&self) -> Option<<T as PolarsNumericType>::Native>
fn max(&self) -> Option<<T as PolarsNumericType>::Native>
None
if the array is empty or only contains null values.fn min_max( &self, ) -> Option<(<T as PolarsNumericType>::Native, <T as PolarsNumericType>::Native)>
Source§impl ChunkAggSeries for ChunkedArray<BinaryType>
impl ChunkAggSeries for ChunkedArray<BinaryType>
Source§fn sum_reduce(&self) -> Scalar
fn sum_reduce(&self) -> Scalar
ChunkedArray
as a new Series
of length 1.Source§fn max_reduce(&self) -> Scalar
fn max_reduce(&self) -> Scalar
ChunkedArray
as a new Series
of length 1.Source§fn min_reduce(&self) -> Scalar
fn min_reduce(&self) -> Scalar
ChunkedArray
as a new Series
of length 1.Source§fn prod_reduce(&self) -> Scalar
fn prod_reduce(&self) -> Scalar
ChunkedArray
as a new Series
of length 1.Source§impl ChunkAggSeries for ChunkedArray<BooleanType>
impl ChunkAggSeries for ChunkedArray<BooleanType>
Source§fn sum_reduce(&self) -> Scalar
fn sum_reduce(&self) -> Scalar
ChunkedArray
as a new Series
of length 1.Source§fn max_reduce(&self) -> Scalar
fn max_reduce(&self) -> Scalar
ChunkedArray
as a new Series
of length 1.Source§fn min_reduce(&self) -> Scalar
fn min_reduce(&self) -> Scalar
ChunkedArray
as a new Series
of length 1.Source§fn prod_reduce(&self) -> Scalar
fn prod_reduce(&self) -> Scalar
ChunkedArray
as a new Series
of length 1.Source§impl<T> ChunkAggSeries for ChunkedArray<ObjectType<T>>where
T: PolarsObject,
Available on crate feature object
only.
impl<T> ChunkAggSeries for ChunkedArray<ObjectType<T>>where
T: PolarsObject,
object
only.Source§fn sum_reduce(&self) -> Scalar
fn sum_reduce(&self) -> Scalar
ChunkedArray
as a new Series
of length 1.Source§fn max_reduce(&self) -> Scalar
fn max_reduce(&self) -> Scalar
ChunkedArray
as a new Series
of length 1.Source§fn min_reduce(&self) -> Scalar
fn min_reduce(&self) -> Scalar
ChunkedArray
as a new Series
of length 1.Source§fn prod_reduce(&self) -> Scalar
fn prod_reduce(&self) -> Scalar
ChunkedArray
as a new Series
of length 1.Source§impl ChunkAggSeries for ChunkedArray<StringType>
impl ChunkAggSeries for ChunkedArray<StringType>
Source§fn max_reduce(&self) -> Scalar
fn max_reduce(&self) -> Scalar
ChunkedArray
as a new Series
of length 1.Source§fn min_reduce(&self) -> Scalar
fn min_reduce(&self) -> Scalar
ChunkedArray
as a new Series
of length 1.Source§fn sum_reduce(&self) -> Scalar
fn sum_reduce(&self) -> Scalar
ChunkedArray
as a new Series
of length 1.Source§fn prod_reduce(&self) -> Scalar
fn prod_reduce(&self) -> Scalar
ChunkedArray
as a new Series
of length 1.Source§impl<T> ChunkAggSeries for ChunkedArray<T>where
PrimitiveArray<<T as PolarsNumericType>::Native>: for<'a> MinMaxKernel<Scalar<'a> = <T as PolarsNumericType>::Native>,
<<T as PolarsNumericType>::Native as Simd>::Simd: Add<Output = <<T as PolarsNumericType>::Native as Simd>::Simd> + Sum<<T as PolarsNumericType>::Native>,
T: PolarsNumericType,
ChunkedArray<T>: IntoSeries,
impl<T> ChunkAggSeries for ChunkedArray<T>where
PrimitiveArray<<T as PolarsNumericType>::Native>: for<'a> MinMaxKernel<Scalar<'a> = <T as PolarsNumericType>::Native>,
<<T as PolarsNumericType>::Native as Simd>::Simd: Add<Output = <<T as PolarsNumericType>::Native as Simd>::Simd> + Sum<<T as PolarsNumericType>::Native>,
T: PolarsNumericType,
ChunkedArray<T>: IntoSeries,
Source§fn sum_reduce(&self) -> Scalar
fn sum_reduce(&self) -> Scalar
ChunkedArray
as a new Series
of length 1.Source§fn max_reduce(&self) -> Scalar
fn max_reduce(&self) -> Scalar
ChunkedArray
as a new Series
of length 1.Source§fn min_reduce(&self) -> Scalar
fn min_reduce(&self) -> Scalar
ChunkedArray
as a new Series
of length 1.Source§fn prod_reduce(&self) -> Scalar
fn prod_reduce(&self) -> Scalar
ChunkedArray
as a new Series
of length 1.Source§impl ChunkAnyValue for ChunkedArray<BinaryOffsetType>
impl ChunkAnyValue for ChunkedArray<BinaryOffsetType>
Source§unsafe fn get_any_value_unchecked(&self, index: usize) -> AnyValue<'_>
unsafe fn get_any_value_unchecked(&self, index: usize) -> AnyValue<'_>
Source§fn get_any_value(&self, index: usize) -> Result<AnyValue<'_>, PolarsError>
fn get_any_value(&self, index: usize) -> Result<AnyValue<'_>, PolarsError>
Source§impl ChunkAnyValue for ChunkedArray<BinaryType>
impl ChunkAnyValue for ChunkedArray<BinaryType>
Source§unsafe fn get_any_value_unchecked(&self, index: usize) -> AnyValue<'_>
unsafe fn get_any_value_unchecked(&self, index: usize) -> AnyValue<'_>
Source§fn get_any_value(&self, index: usize) -> Result<AnyValue<'_>, PolarsError>
fn get_any_value(&self, index: usize) -> Result<AnyValue<'_>, PolarsError>
Source§impl ChunkAnyValue for ChunkedArray<BooleanType>
impl ChunkAnyValue for ChunkedArray<BooleanType>
Source§unsafe fn get_any_value_unchecked(&self, index: usize) -> AnyValue<'_>
unsafe fn get_any_value_unchecked(&self, index: usize) -> AnyValue<'_>
Source§fn get_any_value(&self, index: usize) -> Result<AnyValue<'_>, PolarsError>
fn get_any_value(&self, index: usize) -> Result<AnyValue<'_>, PolarsError>
Source§impl ChunkAnyValue for ChunkedArray<FixedSizeListType>
Available on crate feature dtype-array
only.
impl ChunkAnyValue for ChunkedArray<FixedSizeListType>
dtype-array
only.Source§unsafe fn get_any_value_unchecked(&self, index: usize) -> AnyValue<'_>
unsafe fn get_any_value_unchecked(&self, index: usize) -> AnyValue<'_>
Source§fn get_any_value(&self, index: usize) -> Result<AnyValue<'_>, PolarsError>
fn get_any_value(&self, index: usize) -> Result<AnyValue<'_>, PolarsError>
Source§impl ChunkAnyValue for ChunkedArray<ListType>
impl ChunkAnyValue for ChunkedArray<ListType>
Source§unsafe fn get_any_value_unchecked(&self, index: usize) -> AnyValue<'_>
unsafe fn get_any_value_unchecked(&self, index: usize) -> AnyValue<'_>
Source§fn get_any_value(&self, index: usize) -> Result<AnyValue<'_>, PolarsError>
fn get_any_value(&self, index: usize) -> Result<AnyValue<'_>, PolarsError>
Source§impl<T> ChunkAnyValue for ChunkedArray<ObjectType<T>>where
T: PolarsObject,
Available on crate feature object
only.
impl<T> ChunkAnyValue for ChunkedArray<ObjectType<T>>where
T: PolarsObject,
object
only.Source§unsafe fn get_any_value_unchecked(&self, index: usize) -> AnyValue<'_>
unsafe fn get_any_value_unchecked(&self, index: usize) -> AnyValue<'_>
Source§fn get_any_value(&self, index: usize) -> Result<AnyValue<'_>, PolarsError>
fn get_any_value(&self, index: usize) -> Result<AnyValue<'_>, PolarsError>
Source§impl ChunkAnyValue for ChunkedArray<StringType>
impl ChunkAnyValue for ChunkedArray<StringType>
Source§unsafe fn get_any_value_unchecked(&self, index: usize) -> AnyValue<'_>
unsafe fn get_any_value_unchecked(&self, index: usize) -> AnyValue<'_>
Source§fn get_any_value(&self, index: usize) -> Result<AnyValue<'_>, PolarsError>
fn get_any_value(&self, index: usize) -> Result<AnyValue<'_>, PolarsError>
Source§impl ChunkAnyValue for ChunkedArray<StructType>
Available on crate feature dtype-struct
only.
impl ChunkAnyValue for ChunkedArray<StructType>
dtype-struct
only.Source§fn get_any_value(&self, i: usize) -> Result<AnyValue<'_>, PolarsError>
fn get_any_value(&self, i: usize) -> Result<AnyValue<'_>, PolarsError>
Gets AnyValue from LogicalType
Source§impl<T> ChunkAnyValue for ChunkedArray<T>where
T: PolarsNumericType,
impl<T> ChunkAnyValue for ChunkedArray<T>where
T: PolarsNumericType,
Source§unsafe fn get_any_value_unchecked(&self, index: usize) -> AnyValue<'_>
unsafe fn get_any_value_unchecked(&self, index: usize) -> AnyValue<'_>
Source§fn get_any_value(&self, index: usize) -> Result<AnyValue<'_>, PolarsError>
fn get_any_value(&self, index: usize) -> Result<AnyValue<'_>, PolarsError>
Source§impl<'a> ChunkApply<'a, &'a [u8]> for ChunkedArray<BinaryType>
impl<'a> ChunkApply<'a, &'a [u8]> for ChunkedArray<BinaryType>
type FuncRet = Cow<'a, [u8]>
Source§fn apply_values<F>(&'a self, f: F) -> ChunkedArray<BinaryType>
fn apply_values<F>(&'a self, f: F) -> ChunkedArray<BinaryType>
Source§fn apply<F>(&'a self, f: F) -> ChunkedArray<BinaryType>
fn apply<F>(&'a self, f: F) -> ChunkedArray<BinaryType>
Source§impl<'a, T> ChunkApply<'a, &'a T> for ChunkedArray<ObjectType<T>>where
T: PolarsObject,
Available on crate feature object
only.
impl<'a, T> ChunkApply<'a, &'a T> for ChunkedArray<ObjectType<T>>where
T: PolarsObject,
object
only.type FuncRet = T
Source§fn apply_values<F>(&'a self, f: F) -> ChunkedArray<ObjectType<T>>
fn apply_values<F>(&'a self, f: F) -> ChunkedArray<ObjectType<T>>
Source§fn apply<F>(&'a self, f: F) -> ChunkedArray<ObjectType<T>>
fn apply<F>(&'a self, f: F) -> ChunkedArray<ObjectType<T>>
Source§impl<'a> ChunkApply<'a, &'a str> for ChunkedArray<StringType>
impl<'a> ChunkApply<'a, &'a str> for ChunkedArray<StringType>
type FuncRet = Cow<'a, str>
Source§fn apply_values<F>(&'a self, f: F) -> ChunkedArray<StringType>
fn apply_values<F>(&'a self, f: F) -> ChunkedArray<StringType>
Source§fn apply<F>(&'a self, f: F) -> ChunkedArray<StringType>
fn apply<F>(&'a self, f: F) -> ChunkedArray<StringType>
Source§impl<'a, T> ChunkApply<'a, <T as PolarsNumericType>::Native> for ChunkedArray<T>where
T: PolarsNumericType,
impl<'a, T> ChunkApply<'a, <T as PolarsNumericType>::Native> for ChunkedArray<T>where
T: PolarsNumericType,
type FuncRet = <T as PolarsNumericType>::Native
Source§fn apply_values<F>(&'a self, f: F) -> ChunkedArray<T>
fn apply_values<F>(&'a self, f: F) -> ChunkedArray<T>
Source§fn apply<F>(&'a self, f: F) -> ChunkedArray<T>where
F: Fn(Option<<T as PolarsNumericType>::Native>) -> Option<<T as PolarsNumericType>::Native> + Copy,
fn apply<F>(&'a self, f: F) -> ChunkedArray<T>where
F: Fn(Option<<T as PolarsNumericType>::Native>) -> Option<<T as PolarsNumericType>::Native> + Copy,
Source§fn apply_to_slice<F, V>(&'a self, f: F, slice: &mut [V])
fn apply_to_slice<F, V>(&'a self, f: F, slice: &mut [V])
Source§impl<'a> ChunkApply<'a, Series> for ChunkedArray<ListType>
impl<'a> ChunkApply<'a, Series> for ChunkedArray<ListType>
Source§fn apply_values<F>(&'a self, f: F) -> ChunkedArray<ListType>
fn apply_values<F>(&'a self, f: F) -> ChunkedArray<ListType>
Apply a closure F
elementwise.
type FuncRet = Series
Source§fn apply<F>(&'a self, f: F) -> ChunkedArray<ListType>
fn apply<F>(&'a self, f: F) -> ChunkedArray<ListType>
Source§impl<'a> ChunkApply<'a, bool> for ChunkedArray<BooleanType>
impl<'a> ChunkApply<'a, bool> for ChunkedArray<BooleanType>
type FuncRet = bool
Source§fn apply_values<F>(&self, f: F) -> ChunkedArray<BooleanType>
fn apply_values<F>(&self, f: F) -> ChunkedArray<BooleanType>
Source§fn apply<F>(&'a self, f: F) -> ChunkedArray<BooleanType>
fn apply<F>(&'a self, f: F) -> ChunkedArray<BooleanType>
Source§impl ChunkApplyKernel<BinaryViewArrayGeneric<[u8]>> for ChunkedArray<BinaryType>
impl ChunkApplyKernel<BinaryViewArrayGeneric<[u8]>> for ChunkedArray<BinaryType>
Source§fn apply_kernel(
&self,
f: &dyn Fn(&BinaryViewArrayGeneric<[u8]>) -> Box<dyn Array>,
) -> ChunkedArray<BinaryType>
fn apply_kernel( &self, f: &dyn Fn(&BinaryViewArrayGeneric<[u8]>) -> Box<dyn Array>, ) -> ChunkedArray<BinaryType>
Source§fn apply_kernel_cast<S>(
&self,
f: &dyn Fn(&BinaryViewArrayGeneric<[u8]>) -> Box<dyn Array>,
) -> ChunkedArray<S>where
S: PolarsDataType,
fn apply_kernel_cast<S>(
&self,
f: &dyn Fn(&BinaryViewArrayGeneric<[u8]>) -> Box<dyn Array>,
) -> ChunkedArray<S>where
S: PolarsDataType,
Source§impl ChunkApplyKernel<BinaryViewArrayGeneric<str>> for ChunkedArray<StringType>
impl ChunkApplyKernel<BinaryViewArrayGeneric<str>> for ChunkedArray<StringType>
Source§fn apply_kernel(
&self,
f: &dyn Fn(&BinaryViewArrayGeneric<str>) -> Box<dyn Array>,
) -> ChunkedArray<StringType>
fn apply_kernel( &self, f: &dyn Fn(&BinaryViewArrayGeneric<str>) -> Box<dyn Array>, ) -> ChunkedArray<StringType>
Source§fn apply_kernel_cast<S>(
&self,
f: &dyn Fn(&BinaryViewArrayGeneric<str>) -> Box<dyn Array>,
) -> ChunkedArray<S>where
S: PolarsDataType,
fn apply_kernel_cast<S>(
&self,
f: &dyn Fn(&BinaryViewArrayGeneric<str>) -> Box<dyn Array>,
) -> ChunkedArray<S>where
S: PolarsDataType,
Source§impl ChunkApplyKernel<BooleanArray> for ChunkedArray<BooleanType>
impl ChunkApplyKernel<BooleanArray> for ChunkedArray<BooleanType>
Source§fn apply_kernel(
&self,
f: &dyn Fn(&BooleanArray) -> Box<dyn Array>,
) -> ChunkedArray<BooleanType>
fn apply_kernel( &self, f: &dyn Fn(&BooleanArray) -> Box<dyn Array>, ) -> ChunkedArray<BooleanType>
Source§fn apply_kernel_cast<S>(
&self,
f: &dyn Fn(&BooleanArray) -> Box<dyn Array>,
) -> ChunkedArray<S>where
S: PolarsDataType,
fn apply_kernel_cast<S>(
&self,
f: &dyn Fn(&BooleanArray) -> Box<dyn Array>,
) -> ChunkedArray<S>where
S: PolarsDataType,
Source§impl<T> ChunkApplyKernel<PrimitiveArray<<T as PolarsNumericType>::Native>> for ChunkedArray<T>where
T: PolarsNumericType,
impl<T> ChunkApplyKernel<PrimitiveArray<<T as PolarsNumericType>::Native>> for ChunkedArray<T>where
T: PolarsNumericType,
Source§fn apply_kernel(
&self,
f: &dyn Fn(&PrimitiveArray<<T as PolarsNumericType>::Native>) -> Box<dyn Array>,
) -> ChunkedArray<T>
fn apply_kernel( &self, f: &dyn Fn(&PrimitiveArray<<T as PolarsNumericType>::Native>) -> Box<dyn Array>, ) -> ChunkedArray<T>
Source§fn apply_kernel_cast<S>(
&self,
f: &dyn Fn(&PrimitiveArray<<T as PolarsNumericType>::Native>) -> Box<dyn Array>,
) -> ChunkedArray<S>where
S: PolarsDataType,
fn apply_kernel_cast<S>(
&self,
f: &dyn Fn(&PrimitiveArray<<T as PolarsNumericType>::Native>) -> Box<dyn Array>,
) -> ChunkedArray<S>where
S: PolarsDataType,
Source§impl<T> ChunkApproxNUnique for ChunkedArray<T>where
T: PolarsDataType,
<T as PolarsDataType>::Physical<'a>: for<'a> TotalHash + for<'a> TotalEq + for<'a> Copy + for<'a> ToTotalOrd,
<Option<<T as PolarsDataType>::Physical<'a>> as ToTotalOrd>::TotalOrdItem: for<'a> Hash + for<'a> Eq,
impl<T> ChunkApproxNUnique for ChunkedArray<T>where
T: PolarsDataType,
<T as PolarsDataType>::Physical<'a>: for<'a> TotalHash + for<'a> TotalEq + for<'a> Copy + for<'a> ToTotalOrd,
<Option<<T as PolarsDataType>::Physical<'a>> as ToTotalOrd>::TotalOrdItem: for<'a> Hash + for<'a> Eq,
fn approx_n_unique(&self) -> u32
Source§impl ChunkCast for ChunkedArray<BinaryOffsetType>
impl ChunkCast for ChunkedArray<BinaryOffsetType>
Source§fn cast_with_options(
&self,
dtype: &DataType,
options: CastOptions,
) -> Result<Series, PolarsError>
fn cast_with_options( &self, dtype: &DataType, options: CastOptions, ) -> Result<Series, PolarsError>
ChunkedArray
to DataType
Source§unsafe fn cast_unchecked(&self, dtype: &DataType) -> Result<Series, PolarsError>
unsafe fn cast_unchecked(&self, dtype: &DataType) -> Result<Series, PolarsError>
Source§fn cast(&self, dtype: &DataType) -> Result<Series, PolarsError>
fn cast(&self, dtype: &DataType) -> Result<Series, PolarsError>
ChunkedArray
to DataType
Source§impl ChunkCast for ChunkedArray<BinaryType>
impl ChunkCast for ChunkedArray<BinaryType>
Source§fn cast_with_options(
&self,
dtype: &DataType,
options: CastOptions,
) -> Result<Series, PolarsError>
fn cast_with_options( &self, dtype: &DataType, options: CastOptions, ) -> Result<Series, PolarsError>
ChunkedArray
to DataType
Source§unsafe fn cast_unchecked(&self, dtype: &DataType) -> Result<Series, PolarsError>
unsafe fn cast_unchecked(&self, dtype: &DataType) -> Result<Series, PolarsError>
Source§fn cast(&self, dtype: &DataType) -> Result<Series, PolarsError>
fn cast(&self, dtype: &DataType) -> Result<Series, PolarsError>
ChunkedArray
to DataType
Source§impl ChunkCast for ChunkedArray<BooleanType>
impl ChunkCast for ChunkedArray<BooleanType>
Source§fn cast_with_options(
&self,
dtype: &DataType,
options: CastOptions,
) -> Result<Series, PolarsError>
fn cast_with_options( &self, dtype: &DataType, options: CastOptions, ) -> Result<Series, PolarsError>
ChunkedArray
to DataType
Source§unsafe fn cast_unchecked(&self, dtype: &DataType) -> Result<Series, PolarsError>
unsafe fn cast_unchecked(&self, dtype: &DataType) -> Result<Series, PolarsError>
Source§fn cast(&self, dtype: &DataType) -> Result<Series, PolarsError>
fn cast(&self, dtype: &DataType) -> Result<Series, PolarsError>
ChunkedArray
to DataType
Source§impl ChunkCast for ChunkedArray<FixedSizeListType>
Available on crate feature dtype-array
only.
impl ChunkCast for ChunkedArray<FixedSizeListType>
dtype-array
only.We cannot cast anything to or from List/LargeList So this implementation casts the inner type
Source§fn cast_with_options(
&self,
dtype: &DataType,
options: CastOptions,
) -> Result<Series, PolarsError>
fn cast_with_options( &self, dtype: &DataType, options: CastOptions, ) -> Result<Series, PolarsError>
ChunkedArray
to DataType
Source§unsafe fn cast_unchecked(&self, dtype: &DataType) -> Result<Series, PolarsError>
unsafe fn cast_unchecked(&self, dtype: &DataType) -> Result<Series, PolarsError>
Source§fn cast(&self, dtype: &DataType) -> Result<Series, PolarsError>
fn cast(&self, dtype: &DataType) -> Result<Series, PolarsError>
ChunkedArray
to DataType
Source§impl ChunkCast for ChunkedArray<ListType>
impl ChunkCast for ChunkedArray<ListType>
We cannot cast anything to or from List/LargeList So this implementation casts the inner type
Source§fn cast_with_options(
&self,
dtype: &DataType,
options: CastOptions,
) -> Result<Series, PolarsError>
fn cast_with_options( &self, dtype: &DataType, options: CastOptions, ) -> Result<Series, PolarsError>
ChunkedArray
to DataType
Source§unsafe fn cast_unchecked(&self, dtype: &DataType) -> Result<Series, PolarsError>
unsafe fn cast_unchecked(&self, dtype: &DataType) -> Result<Series, PolarsError>
Source§fn cast(&self, dtype: &DataType) -> Result<Series, PolarsError>
fn cast(&self, dtype: &DataType) -> Result<Series, PolarsError>
ChunkedArray
to DataType
Source§impl ChunkCast for ChunkedArray<StringType>
impl ChunkCast for ChunkedArray<StringType>
Source§fn cast_with_options(
&self,
dtype: &DataType,
options: CastOptions,
) -> Result<Series, PolarsError>
fn cast_with_options( &self, dtype: &DataType, options: CastOptions, ) -> Result<Series, PolarsError>
ChunkedArray
to DataType
Source§unsafe fn cast_unchecked(&self, dtype: &DataType) -> Result<Series, PolarsError>
unsafe fn cast_unchecked(&self, dtype: &DataType) -> Result<Series, PolarsError>
Source§fn cast(&self, dtype: &DataType) -> Result<Series, PolarsError>
fn cast(&self, dtype: &DataType) -> Result<Series, PolarsError>
ChunkedArray
to DataType
Source§impl<T> ChunkCast for ChunkedArray<T>where
T: PolarsNumericType,
impl<T> ChunkCast for ChunkedArray<T>where
T: PolarsNumericType,
Source§fn cast_with_options(
&self,
dtype: &DataType,
options: CastOptions,
) -> Result<Series, PolarsError>
fn cast_with_options( &self, dtype: &DataType, options: CastOptions, ) -> Result<Series, PolarsError>
ChunkedArray
to DataType
Source§unsafe fn cast_unchecked(&self, dtype: &DataType) -> Result<Series, PolarsError>
unsafe fn cast_unchecked(&self, dtype: &DataType) -> Result<Series, PolarsError>
Source§fn cast(&self, dtype: &DataType) -> Result<Series, PolarsError>
fn cast(&self, dtype: &DataType) -> Result<Series, PolarsError>
ChunkedArray
to DataType
Source§impl ChunkCompareEq<&[u8]> for ChunkedArray<BinaryType>
impl ChunkCompareEq<&[u8]> for ChunkedArray<BinaryType>
type Item = ChunkedArray<BooleanType>
Source§fn equal(&self, rhs: &[u8]) -> ChunkedArray<BooleanType>
fn equal(&self, rhs: &[u8]) -> ChunkedArray<BooleanType>
Source§fn equal_missing(&self, rhs: &[u8]) -> ChunkedArray<BooleanType>
fn equal_missing(&self, rhs: &[u8]) -> ChunkedArray<BooleanType>
None == None
.Source§fn not_equal(&self, rhs: &[u8]) -> ChunkedArray<BooleanType>
fn not_equal(&self, rhs: &[u8]) -> ChunkedArray<BooleanType>
Source§fn not_equal_missing(&self, rhs: &[u8]) -> ChunkedArray<BooleanType>
fn not_equal_missing(&self, rhs: &[u8]) -> ChunkedArray<BooleanType>
None == None
.Source§impl ChunkCompareEq<&ChunkedArray<BinaryType>> for ChunkedArray<BinaryType>
impl ChunkCompareEq<&ChunkedArray<BinaryType>> for ChunkedArray<BinaryType>
type Item = ChunkedArray<BooleanType>
Source§fn equal(&self, rhs: &ChunkedArray<BinaryType>) -> ChunkedArray<BooleanType>
fn equal(&self, rhs: &ChunkedArray<BinaryType>) -> ChunkedArray<BooleanType>
Source§fn equal_missing(
&self,
rhs: &ChunkedArray<BinaryType>,
) -> ChunkedArray<BooleanType>
fn equal_missing( &self, rhs: &ChunkedArray<BinaryType>, ) -> ChunkedArray<BooleanType>
None == None
.Source§fn not_equal(&self, rhs: &ChunkedArray<BinaryType>) -> ChunkedArray<BooleanType>
fn not_equal(&self, rhs: &ChunkedArray<BinaryType>) -> ChunkedArray<BooleanType>
Source§fn not_equal_missing(
&self,
rhs: &ChunkedArray<BinaryType>,
) -> ChunkedArray<BooleanType>
fn not_equal_missing( &self, rhs: &ChunkedArray<BinaryType>, ) -> ChunkedArray<BooleanType>
None == None
.Source§impl ChunkCompareEq<&ChunkedArray<BooleanType>> for ChunkedArray<BooleanType>
impl ChunkCompareEq<&ChunkedArray<BooleanType>> for ChunkedArray<BooleanType>
type Item = ChunkedArray<BooleanType>
Source§fn equal(&self, rhs: &ChunkedArray<BooleanType>) -> ChunkedArray<BooleanType>
fn equal(&self, rhs: &ChunkedArray<BooleanType>) -> ChunkedArray<BooleanType>
Source§fn equal_missing(
&self,
rhs: &ChunkedArray<BooleanType>,
) -> ChunkedArray<BooleanType>
fn equal_missing( &self, rhs: &ChunkedArray<BooleanType>, ) -> ChunkedArray<BooleanType>
None == None
.Source§fn not_equal(
&self,
rhs: &ChunkedArray<BooleanType>,
) -> ChunkedArray<BooleanType>
fn not_equal( &self, rhs: &ChunkedArray<BooleanType>, ) -> ChunkedArray<BooleanType>
Source§fn not_equal_missing(
&self,
rhs: &ChunkedArray<BooleanType>,
) -> ChunkedArray<BooleanType>
fn not_equal_missing( &self, rhs: &ChunkedArray<BooleanType>, ) -> ChunkedArray<BooleanType>
None == None
.Source§impl ChunkCompareEq<&ChunkedArray<FixedSizeListType>> for ChunkedArray<FixedSizeListType>
Available on crate feature dtype-array
only.
impl ChunkCompareEq<&ChunkedArray<FixedSizeListType>> for ChunkedArray<FixedSizeListType>
dtype-array
only.type Item = ChunkedArray<BooleanType>
Source§fn equal(
&self,
rhs: &ChunkedArray<FixedSizeListType>,
) -> ChunkedArray<BooleanType>
fn equal( &self, rhs: &ChunkedArray<FixedSizeListType>, ) -> ChunkedArray<BooleanType>
Source§fn equal_missing(
&self,
rhs: &ChunkedArray<FixedSizeListType>,
) -> ChunkedArray<BooleanType>
fn equal_missing( &self, rhs: &ChunkedArray<FixedSizeListType>, ) -> ChunkedArray<BooleanType>
None == None
.Source§fn not_equal(
&self,
rhs: &ChunkedArray<FixedSizeListType>,
) -> ChunkedArray<BooleanType>
fn not_equal( &self, rhs: &ChunkedArray<FixedSizeListType>, ) -> ChunkedArray<BooleanType>
Source§fn not_equal_missing(
&self,
rhs: &ChunkedArray<FixedSizeListType>,
) -> <ChunkedArray<FixedSizeListType> as ChunkCompareEq<&ChunkedArray<FixedSizeListType>>>::Item
fn not_equal_missing( &self, rhs: &ChunkedArray<FixedSizeListType>, ) -> <ChunkedArray<FixedSizeListType> as ChunkCompareEq<&ChunkedArray<FixedSizeListType>>>::Item
None == None
.Source§impl ChunkCompareEq<&ChunkedArray<ListType>> for ChunkedArray<ListType>
impl ChunkCompareEq<&ChunkedArray<ListType>> for ChunkedArray<ListType>
type Item = ChunkedArray<BooleanType>
Source§fn equal(&self, rhs: &ChunkedArray<ListType>) -> ChunkedArray<BooleanType>
fn equal(&self, rhs: &ChunkedArray<ListType>) -> ChunkedArray<BooleanType>
Source§fn equal_missing(
&self,
rhs: &ChunkedArray<ListType>,
) -> ChunkedArray<BooleanType>
fn equal_missing( &self, rhs: &ChunkedArray<ListType>, ) -> ChunkedArray<BooleanType>
None == None
.Source§fn not_equal(&self, rhs: &ChunkedArray<ListType>) -> ChunkedArray<BooleanType>
fn not_equal(&self, rhs: &ChunkedArray<ListType>) -> ChunkedArray<BooleanType>
Source§fn not_equal_missing(
&self,
rhs: &ChunkedArray<ListType>,
) -> ChunkedArray<BooleanType>
fn not_equal_missing( &self, rhs: &ChunkedArray<ListType>, ) -> ChunkedArray<BooleanType>
None == None
.Source§impl ChunkCompareEq<&ChunkedArray<StringType>> for CategoricalChunked
impl ChunkCompareEq<&ChunkedArray<StringType>> for CategoricalChunked
type Item = Result<ChunkedArray<BooleanType>, PolarsError>
Source§fn equal(
&self,
rhs: &ChunkedArray<StringType>,
) -> <CategoricalChunked as ChunkCompareEq<&ChunkedArray<StringType>>>::Item
fn equal( &self, rhs: &ChunkedArray<StringType>, ) -> <CategoricalChunked as ChunkCompareEq<&ChunkedArray<StringType>>>::Item
Source§fn equal_missing(
&self,
rhs: &ChunkedArray<StringType>,
) -> <CategoricalChunked as ChunkCompareEq<&ChunkedArray<StringType>>>::Item
fn equal_missing( &self, rhs: &ChunkedArray<StringType>, ) -> <CategoricalChunked as ChunkCompareEq<&ChunkedArray<StringType>>>::Item
None == None
.Source§fn not_equal(
&self,
rhs: &ChunkedArray<StringType>,
) -> <CategoricalChunked as ChunkCompareEq<&ChunkedArray<StringType>>>::Item
fn not_equal( &self, rhs: &ChunkedArray<StringType>, ) -> <CategoricalChunked as ChunkCompareEq<&ChunkedArray<StringType>>>::Item
Source§fn not_equal_missing(
&self,
rhs: &ChunkedArray<StringType>,
) -> <CategoricalChunked as ChunkCompareEq<&ChunkedArray<StringType>>>::Item
fn not_equal_missing( &self, rhs: &ChunkedArray<StringType>, ) -> <CategoricalChunked as ChunkCompareEq<&ChunkedArray<StringType>>>::Item
None == None
.Source§impl ChunkCompareEq<&ChunkedArray<StringType>> for ChunkedArray<StringType>
impl ChunkCompareEq<&ChunkedArray<StringType>> for ChunkedArray<StringType>
type Item = ChunkedArray<BooleanType>
Source§fn equal(&self, rhs: &ChunkedArray<StringType>) -> ChunkedArray<BooleanType>
fn equal(&self, rhs: &ChunkedArray<StringType>) -> ChunkedArray<BooleanType>
Source§fn equal_missing(
&self,
rhs: &ChunkedArray<StringType>,
) -> ChunkedArray<BooleanType>
fn equal_missing( &self, rhs: &ChunkedArray<StringType>, ) -> ChunkedArray<BooleanType>
None == None
.Source§fn not_equal(&self, rhs: &ChunkedArray<StringType>) -> ChunkedArray<BooleanType>
fn not_equal(&self, rhs: &ChunkedArray<StringType>) -> ChunkedArray<BooleanType>
Source§fn not_equal_missing(
&self,
rhs: &ChunkedArray<StringType>,
) -> ChunkedArray<BooleanType>
fn not_equal_missing( &self, rhs: &ChunkedArray<StringType>, ) -> ChunkedArray<BooleanType>
None == None
.Source§impl ChunkCompareEq<&ChunkedArray<StructType>> for ChunkedArray<StructType>
Available on crate feature dtype-struct
only.
impl ChunkCompareEq<&ChunkedArray<StructType>> for ChunkedArray<StructType>
dtype-struct
only.type Item = ChunkedArray<BooleanType>
Source§fn equal(&self, rhs: &ChunkedArray<StructType>) -> ChunkedArray<BooleanType>
fn equal(&self, rhs: &ChunkedArray<StructType>) -> ChunkedArray<BooleanType>
Source§fn equal_missing(
&self,
rhs: &ChunkedArray<StructType>,
) -> ChunkedArray<BooleanType>
fn equal_missing( &self, rhs: &ChunkedArray<StructType>, ) -> ChunkedArray<BooleanType>
None == None
.Source§fn not_equal(&self, rhs: &ChunkedArray<StructType>) -> ChunkedArray<BooleanType>
fn not_equal(&self, rhs: &ChunkedArray<StructType>) -> ChunkedArray<BooleanType>
Source§fn not_equal_missing(
&self,
rhs: &ChunkedArray<StructType>,
) -> ChunkedArray<BooleanType>
fn not_equal_missing( &self, rhs: &ChunkedArray<StructType>, ) -> ChunkedArray<BooleanType>
None == None
.Source§impl<T> ChunkCompareEq<&ChunkedArray<T>> for ChunkedArray<T>where
<T as PolarsDataType>::Array: TotalOrdKernel<Scalar = <T as PolarsNumericType>::Native> + TotalEqKernel<Scalar = <T as PolarsNumericType>::Native>,
T: PolarsNumericType,
impl<T> ChunkCompareEq<&ChunkedArray<T>> for ChunkedArray<T>where
<T as PolarsDataType>::Array: TotalOrdKernel<Scalar = <T as PolarsNumericType>::Native> + TotalEqKernel<Scalar = <T as PolarsNumericType>::Native>,
T: PolarsNumericType,
type Item = ChunkedArray<BooleanType>
Source§fn equal(&self, rhs: &ChunkedArray<T>) -> ChunkedArray<BooleanType>
fn equal(&self, rhs: &ChunkedArray<T>) -> ChunkedArray<BooleanType>
Source§fn equal_missing(&self, rhs: &ChunkedArray<T>) -> ChunkedArray<BooleanType>
fn equal_missing(&self, rhs: &ChunkedArray<T>) -> ChunkedArray<BooleanType>
None == None
.Source§fn not_equal(&self, rhs: &ChunkedArray<T>) -> ChunkedArray<BooleanType>
fn not_equal(&self, rhs: &ChunkedArray<T>) -> ChunkedArray<BooleanType>
Source§fn not_equal_missing(&self, rhs: &ChunkedArray<T>) -> ChunkedArray<BooleanType>
fn not_equal_missing(&self, rhs: &ChunkedArray<T>) -> ChunkedArray<BooleanType>
None == None
.Source§impl ChunkCompareEq<&str> for ChunkedArray<StringType>
impl ChunkCompareEq<&str> for ChunkedArray<StringType>
type Item = ChunkedArray<BooleanType>
Source§fn equal(&self, rhs: &str) -> ChunkedArray<BooleanType>
fn equal(&self, rhs: &str) -> ChunkedArray<BooleanType>
Source§fn equal_missing(&self, rhs: &str) -> ChunkedArray<BooleanType>
fn equal_missing(&self, rhs: &str) -> ChunkedArray<BooleanType>
None == None
.Source§fn not_equal(&self, rhs: &str) -> ChunkedArray<BooleanType>
fn not_equal(&self, rhs: &str) -> ChunkedArray<BooleanType>
Source§fn not_equal_missing(&self, rhs: &str) -> ChunkedArray<BooleanType>
fn not_equal_missing(&self, rhs: &str) -> ChunkedArray<BooleanType>
None == None
.Source§impl<T, Rhs> ChunkCompareEq<Rhs> for ChunkedArray<T>where
T: PolarsNumericType,
Rhs: ToPrimitive,
<T as PolarsDataType>::Array: TotalOrdKernel<Scalar = <T as PolarsNumericType>::Native> + TotalEqKernel<Scalar = <T as PolarsNumericType>::Native>,
impl<T, Rhs> ChunkCompareEq<Rhs> for ChunkedArray<T>where
T: PolarsNumericType,
Rhs: ToPrimitive,
<T as PolarsDataType>::Array: TotalOrdKernel<Scalar = <T as PolarsNumericType>::Native> + TotalEqKernel<Scalar = <T as PolarsNumericType>::Native>,
type Item = ChunkedArray<BooleanType>
Source§fn equal(&self, rhs: Rhs) -> ChunkedArray<BooleanType>
fn equal(&self, rhs: Rhs) -> ChunkedArray<BooleanType>
Source§fn equal_missing(&self, rhs: Rhs) -> ChunkedArray<BooleanType>
fn equal_missing(&self, rhs: Rhs) -> ChunkedArray<BooleanType>
None == None
.Source§fn not_equal(&self, rhs: Rhs) -> ChunkedArray<BooleanType>
fn not_equal(&self, rhs: Rhs) -> ChunkedArray<BooleanType>
Source§fn not_equal_missing(&self, rhs: Rhs) -> ChunkedArray<BooleanType>
fn not_equal_missing(&self, rhs: Rhs) -> ChunkedArray<BooleanType>
None == None
.Source§impl ChunkCompareIneq<&[u8]> for ChunkedArray<BinaryType>
impl ChunkCompareIneq<&[u8]> for ChunkedArray<BinaryType>
type Item = ChunkedArray<BooleanType>
Source§fn gt(&self, rhs: &[u8]) -> ChunkedArray<BooleanType>
fn gt(&self, rhs: &[u8]) -> ChunkedArray<BooleanType>
Source§fn gt_eq(&self, rhs: &[u8]) -> ChunkedArray<BooleanType>
fn gt_eq(&self, rhs: &[u8]) -> ChunkedArray<BooleanType>
Source§fn lt(&self, rhs: &[u8]) -> ChunkedArray<BooleanType>
fn lt(&self, rhs: &[u8]) -> ChunkedArray<BooleanType>
Source§fn lt_eq(&self, rhs: &[u8]) -> ChunkedArray<BooleanType>
fn lt_eq(&self, rhs: &[u8]) -> ChunkedArray<BooleanType>
Source§impl ChunkCompareIneq<&ChunkedArray<BinaryType>> for ChunkedArray<BinaryType>
impl ChunkCompareIneq<&ChunkedArray<BinaryType>> for ChunkedArray<BinaryType>
type Item = ChunkedArray<BooleanType>
Source§fn lt(&self, rhs: &ChunkedArray<BinaryType>) -> ChunkedArray<BooleanType>
fn lt(&self, rhs: &ChunkedArray<BinaryType>) -> ChunkedArray<BooleanType>
Source§fn lt_eq(&self, rhs: &ChunkedArray<BinaryType>) -> ChunkedArray<BooleanType>
fn lt_eq(&self, rhs: &ChunkedArray<BinaryType>) -> ChunkedArray<BooleanType>
Source§fn gt(&self, rhs: &ChunkedArray<BinaryType>) -> ChunkedArray<BooleanType>
fn gt(&self, rhs: &ChunkedArray<BinaryType>) -> ChunkedArray<BooleanType>
Source§fn gt_eq(&self, rhs: &ChunkedArray<BinaryType>) -> ChunkedArray<BooleanType>
fn gt_eq(&self, rhs: &ChunkedArray<BinaryType>) -> ChunkedArray<BooleanType>
Source§impl ChunkCompareIneq<&ChunkedArray<BooleanType>> for ChunkedArray<BooleanType>
impl ChunkCompareIneq<&ChunkedArray<BooleanType>> for ChunkedArray<BooleanType>
type Item = ChunkedArray<BooleanType>
Source§fn lt(&self, rhs: &ChunkedArray<BooleanType>) -> ChunkedArray<BooleanType>
fn lt(&self, rhs: &ChunkedArray<BooleanType>) -> ChunkedArray<BooleanType>
Source§fn lt_eq(&self, rhs: &ChunkedArray<BooleanType>) -> ChunkedArray<BooleanType>
fn lt_eq(&self, rhs: &ChunkedArray<BooleanType>) -> ChunkedArray<BooleanType>
Source§fn gt(&self, rhs: &ChunkedArray<BooleanType>) -> ChunkedArray<BooleanType>
fn gt(&self, rhs: &ChunkedArray<BooleanType>) -> ChunkedArray<BooleanType>
Source§fn gt_eq(&self, rhs: &ChunkedArray<BooleanType>) -> ChunkedArray<BooleanType>
fn gt_eq(&self, rhs: &ChunkedArray<BooleanType>) -> ChunkedArray<BooleanType>
Source§impl ChunkCompareIneq<&ChunkedArray<StringType>> for CategoricalChunked
impl ChunkCompareIneq<&ChunkedArray<StringType>> for CategoricalChunked
type Item = Result<ChunkedArray<BooleanType>, PolarsError>
Source§fn gt(
&self,
rhs: &ChunkedArray<StringType>,
) -> <CategoricalChunked as ChunkCompareIneq<&ChunkedArray<StringType>>>::Item
fn gt( &self, rhs: &ChunkedArray<StringType>, ) -> <CategoricalChunked as ChunkCompareIneq<&ChunkedArray<StringType>>>::Item
Source§fn gt_eq(
&self,
rhs: &ChunkedArray<StringType>,
) -> <CategoricalChunked as ChunkCompareIneq<&ChunkedArray<StringType>>>::Item
fn gt_eq( &self, rhs: &ChunkedArray<StringType>, ) -> <CategoricalChunked as ChunkCompareIneq<&ChunkedArray<StringType>>>::Item
Source§fn lt(
&self,
rhs: &ChunkedArray<StringType>,
) -> <CategoricalChunked as ChunkCompareIneq<&ChunkedArray<StringType>>>::Item
fn lt( &self, rhs: &ChunkedArray<StringType>, ) -> <CategoricalChunked as ChunkCompareIneq<&ChunkedArray<StringType>>>::Item
Source§fn lt_eq(
&self,
rhs: &ChunkedArray<StringType>,
) -> <CategoricalChunked as ChunkCompareIneq<&ChunkedArray<StringType>>>::Item
fn lt_eq( &self, rhs: &ChunkedArray<StringType>, ) -> <CategoricalChunked as ChunkCompareIneq<&ChunkedArray<StringType>>>::Item
Source§impl ChunkCompareIneq<&ChunkedArray<StringType>> for ChunkedArray<StringType>
impl ChunkCompareIneq<&ChunkedArray<StringType>> for ChunkedArray<StringType>
type Item = ChunkedArray<BooleanType>
Source§fn gt(&self, rhs: &ChunkedArray<StringType>) -> ChunkedArray<BooleanType>
fn gt(&self, rhs: &ChunkedArray<StringType>) -> ChunkedArray<BooleanType>
Source§fn gt_eq(&self, rhs: &ChunkedArray<StringType>) -> ChunkedArray<BooleanType>
fn gt_eq(&self, rhs: &ChunkedArray<StringType>) -> ChunkedArray<BooleanType>
Source§fn lt(&self, rhs: &ChunkedArray<StringType>) -> ChunkedArray<BooleanType>
fn lt(&self, rhs: &ChunkedArray<StringType>) -> ChunkedArray<BooleanType>
Source§fn lt_eq(&self, rhs: &ChunkedArray<StringType>) -> ChunkedArray<BooleanType>
fn lt_eq(&self, rhs: &ChunkedArray<StringType>) -> ChunkedArray<BooleanType>
Source§impl<T> ChunkCompareIneq<&ChunkedArray<T>> for ChunkedArray<T>where
<T as PolarsDataType>::Array: TotalOrdKernel<Scalar = <T as PolarsNumericType>::Native> + TotalEqKernel<Scalar = <T as PolarsNumericType>::Native>,
T: PolarsNumericType,
impl<T> ChunkCompareIneq<&ChunkedArray<T>> for ChunkedArray<T>where
<T as PolarsDataType>::Array: TotalOrdKernel<Scalar = <T as PolarsNumericType>::Native> + TotalEqKernel<Scalar = <T as PolarsNumericType>::Native>,
T: PolarsNumericType,
type Item = ChunkedArray<BooleanType>
Source§fn lt(&self, rhs: &ChunkedArray<T>) -> ChunkedArray<BooleanType>
fn lt(&self, rhs: &ChunkedArray<T>) -> ChunkedArray<BooleanType>
Source§fn lt_eq(&self, rhs: &ChunkedArray<T>) -> ChunkedArray<BooleanType>
fn lt_eq(&self, rhs: &ChunkedArray<T>) -> ChunkedArray<BooleanType>
Source§fn gt(&self, rhs: &ChunkedArray<T>) -> ChunkedArray<BooleanType>
fn gt(&self, rhs: &ChunkedArray<T>) -> ChunkedArray<BooleanType>
Source§fn gt_eq(&self, rhs: &ChunkedArray<T>) -> ChunkedArray<BooleanType>
fn gt_eq(&self, rhs: &ChunkedArray<T>) -> ChunkedArray<BooleanType>
Source§impl ChunkCompareIneq<&str> for ChunkedArray<StringType>
impl ChunkCompareIneq<&str> for ChunkedArray<StringType>
type Item = ChunkedArray<BooleanType>
Source§fn gt(&self, rhs: &str) -> ChunkedArray<BooleanType>
fn gt(&self, rhs: &str) -> ChunkedArray<BooleanType>
Source§fn gt_eq(&self, rhs: &str) -> ChunkedArray<BooleanType>
fn gt_eq(&self, rhs: &str) -> ChunkedArray<BooleanType>
Source§fn lt(&self, rhs: &str) -> ChunkedArray<BooleanType>
fn lt(&self, rhs: &str) -> ChunkedArray<BooleanType>
Source§fn lt_eq(&self, rhs: &str) -> ChunkedArray<BooleanType>
fn lt_eq(&self, rhs: &str) -> ChunkedArray<BooleanType>
Source§impl<T, Rhs> ChunkCompareIneq<Rhs> for ChunkedArray<T>where
T: PolarsNumericType,
Rhs: ToPrimitive,
<T as PolarsDataType>::Array: TotalOrdKernel<Scalar = <T as PolarsNumericType>::Native> + TotalEqKernel<Scalar = <T as PolarsNumericType>::Native>,
impl<T, Rhs> ChunkCompareIneq<Rhs> for ChunkedArray<T>where
T: PolarsNumericType,
Rhs: ToPrimitive,
<T as PolarsDataType>::Array: TotalOrdKernel<Scalar = <T as PolarsNumericType>::Native> + TotalEqKernel<Scalar = <T as PolarsNumericType>::Native>,
type Item = ChunkedArray<BooleanType>
Source§fn gt(&self, rhs: Rhs) -> ChunkedArray<BooleanType>
fn gt(&self, rhs: Rhs) -> ChunkedArray<BooleanType>
Source§fn gt_eq(&self, rhs: Rhs) -> ChunkedArray<BooleanType>
fn gt_eq(&self, rhs: Rhs) -> ChunkedArray<BooleanType>
Source§fn lt(&self, rhs: Rhs) -> ChunkedArray<BooleanType>
fn lt(&self, rhs: Rhs) -> ChunkedArray<BooleanType>
Source§fn lt_eq(&self, rhs: Rhs) -> ChunkedArray<BooleanType>
fn lt_eq(&self, rhs: Rhs) -> ChunkedArray<BooleanType>
Source§impl ChunkExpandAtIndex<BinaryOffsetType> for ChunkedArray<BinaryOffsetType>
impl ChunkExpandAtIndex<BinaryOffsetType> for ChunkedArray<BinaryOffsetType>
Source§fn new_from_index(
&self,
index: usize,
length: usize,
) -> ChunkedArray<BinaryOffsetType>
fn new_from_index( &self, index: usize, length: usize, ) -> ChunkedArray<BinaryOffsetType>
Source§impl ChunkExpandAtIndex<BinaryType> for ChunkedArray<BinaryType>
impl ChunkExpandAtIndex<BinaryType> for ChunkedArray<BinaryType>
Source§fn new_from_index(
&self,
index: usize,
length: usize,
) -> ChunkedArray<BinaryType>
fn new_from_index( &self, index: usize, length: usize, ) -> ChunkedArray<BinaryType>
Source§impl ChunkExpandAtIndex<BooleanType> for ChunkedArray<BooleanType>
impl ChunkExpandAtIndex<BooleanType> for ChunkedArray<BooleanType>
Source§fn new_from_index(
&self,
index: usize,
length: usize,
) -> ChunkedArray<BooleanType>
fn new_from_index( &self, index: usize, length: usize, ) -> ChunkedArray<BooleanType>
Source§impl ChunkExpandAtIndex<FixedSizeListType> for ChunkedArray<FixedSizeListType>
Available on crate feature dtype-array
only.
impl ChunkExpandAtIndex<FixedSizeListType> for ChunkedArray<FixedSizeListType>
dtype-array
only.Source§fn new_from_index(
&self,
index: usize,
length: usize,
) -> ChunkedArray<FixedSizeListType>
fn new_from_index( &self, index: usize, length: usize, ) -> ChunkedArray<FixedSizeListType>
Source§impl ChunkExpandAtIndex<ListType> for ChunkedArray<ListType>
impl ChunkExpandAtIndex<ListType> for ChunkedArray<ListType>
Source§fn new_from_index(&self, index: usize, length: usize) -> ChunkedArray<ListType>
fn new_from_index(&self, index: usize, length: usize) -> ChunkedArray<ListType>
Source§impl<T> ChunkExpandAtIndex<ObjectType<T>> for ChunkedArray<ObjectType<T>>where
T: PolarsObject,
Available on crate feature object
only.
impl<T> ChunkExpandAtIndex<ObjectType<T>> for ChunkedArray<ObjectType<T>>where
T: PolarsObject,
object
only.Source§fn new_from_index(
&self,
index: usize,
length: usize,
) -> ChunkedArray<ObjectType<T>>
fn new_from_index( &self, index: usize, length: usize, ) -> ChunkedArray<ObjectType<T>>
Source§impl ChunkExpandAtIndex<StringType> for ChunkedArray<StringType>
impl ChunkExpandAtIndex<StringType> for ChunkedArray<StringType>
Source§fn new_from_index(
&self,
index: usize,
length: usize,
) -> ChunkedArray<StringType>
fn new_from_index( &self, index: usize, length: usize, ) -> ChunkedArray<StringType>
Source§impl ChunkExpandAtIndex<StructType> for ChunkedArray<StructType>
Available on crate feature dtype-struct
only.
impl ChunkExpandAtIndex<StructType> for ChunkedArray<StructType>
dtype-struct
only.Source§fn new_from_index(
&self,
index: usize,
length: usize,
) -> ChunkedArray<StructType>
fn new_from_index( &self, index: usize, length: usize, ) -> ChunkedArray<StructType>
Source§impl<T> ChunkExpandAtIndex<T> for ChunkedArray<T>
impl<T> ChunkExpandAtIndex<T> for ChunkedArray<T>
Source§fn new_from_index(&self, index: usize, length: usize) -> ChunkedArray<T>
fn new_from_index(&self, index: usize, length: usize) -> ChunkedArray<T>
Source§impl ChunkExplode for ChunkedArray<FixedSizeListType>
Available on crate feature dtype-array
only.
impl ChunkExplode for ChunkedArray<FixedSizeListType>
dtype-array
only.fn offsets(&self) -> Result<OffsetsBuffer<i64>, PolarsError>
fn explode_and_offsets( &self, ) -> Result<(Series, OffsetsBuffer<i64>), PolarsError>
fn explode(&self) -> Result<Series, PolarsError>
Source§impl ChunkExplode for ChunkedArray<ListType>
impl ChunkExplode for ChunkedArray<ListType>
fn offsets(&self) -> Result<OffsetsBuffer<i64>, PolarsError>
fn explode_and_offsets( &self, ) -> Result<(Series, OffsetsBuffer<i64>), PolarsError>
fn explode(&self) -> Result<Series, PolarsError>
Source§impl ChunkFillNullValue<&[u8]> for ChunkedArray<BinaryType>
impl ChunkFillNullValue<&[u8]> for ChunkedArray<BinaryType>
Source§fn fill_null_with_values(
&self,
value: &[u8],
) -> Result<ChunkedArray<BinaryType>, PolarsError>
fn fill_null_with_values( &self, value: &[u8], ) -> Result<ChunkedArray<BinaryType>, PolarsError>
T
.Source§impl<T> ChunkFillNullValue<<T as PolarsNumericType>::Native> for ChunkedArray<T>where
T: PolarsNumericType,
impl<T> ChunkFillNullValue<<T as PolarsNumericType>::Native> for ChunkedArray<T>where
T: PolarsNumericType,
Source§fn fill_null_with_values(
&self,
value: <T as PolarsNumericType>::Native,
) -> Result<ChunkedArray<T>, PolarsError>
fn fill_null_with_values( &self, value: <T as PolarsNumericType>::Native, ) -> Result<ChunkedArray<T>, PolarsError>
T
.Source§impl ChunkFillNullValue<bool> for ChunkedArray<BooleanType>
impl ChunkFillNullValue<bool> for ChunkedArray<BooleanType>
Source§fn fill_null_with_values(
&self,
value: bool,
) -> Result<ChunkedArray<BooleanType>, PolarsError>
fn fill_null_with_values( &self, value: bool, ) -> Result<ChunkedArray<BooleanType>, PolarsError>
T
.Source§impl ChunkFilter<BinaryType> for ChunkedArray<BinaryType>
impl ChunkFilter<BinaryType> for ChunkedArray<BinaryType>
Source§fn filter(
&self,
filter: &ChunkedArray<BooleanType>,
) -> Result<ChunkedArray<BinaryType>, PolarsError>
fn filter( &self, filter: &ChunkedArray<BooleanType>, ) -> Result<ChunkedArray<BinaryType>, PolarsError>
Source§impl<T> ChunkFilter<ObjectType<T>> for ChunkedArray<ObjectType<T>>where
T: PolarsObject,
Available on crate feature object
only.
impl<T> ChunkFilter<ObjectType<T>> for ChunkedArray<ObjectType<T>>where
T: PolarsObject,
object
only.Source§fn filter(
&self,
filter: &ChunkedArray<BooleanType>,
) -> Result<ChunkedArray<ObjectType<T>>, PolarsError>
fn filter( &self, filter: &ChunkedArray<BooleanType>, ) -> Result<ChunkedArray<ObjectType<T>>, PolarsError>
Source§impl ChunkFilter<StringType> for ChunkedArray<StringType>
impl ChunkFilter<StringType> for ChunkedArray<StringType>
Source§fn filter(
&self,
filter: &ChunkedArray<BooleanType>,
) -> Result<ChunkedArray<StringType>, PolarsError>
fn filter( &self, filter: &ChunkedArray<BooleanType>, ) -> Result<ChunkedArray<StringType>, PolarsError>
Source§impl<T> ChunkFilter<T> for ChunkedArray<T>
impl<T> ChunkFilter<T> for ChunkedArray<T>
Source§fn filter(
&self,
filter: &ChunkedArray<BooleanType>,
) -> Result<ChunkedArray<T>, PolarsError>
fn filter( &self, filter: &ChunkedArray<BooleanType>, ) -> Result<ChunkedArray<T>, PolarsError>
Source§impl<'a> ChunkFull<&'a [u8]> for ChunkedArray<BinaryOffsetType>
impl<'a> ChunkFull<&'a [u8]> for ChunkedArray<BinaryOffsetType>
Source§fn full(
name: PlSmallStr,
value: &'a [u8],
length: usize,
) -> ChunkedArray<BinaryOffsetType>
fn full( name: PlSmallStr, value: &'a [u8], length: usize, ) -> ChunkedArray<BinaryOffsetType>
Source§impl<'a> ChunkFull<&'a [u8]> for ChunkedArray<BinaryType>
impl<'a> ChunkFull<&'a [u8]> for ChunkedArray<BinaryType>
Source§fn full(
name: PlSmallStr,
value: &'a [u8],
length: usize,
) -> ChunkedArray<BinaryType>
fn full( name: PlSmallStr, value: &'a [u8], length: usize, ) -> ChunkedArray<BinaryType>
Source§impl ChunkFull<&Series> for ChunkedArray<FixedSizeListType>
Available on crate feature dtype-array
only.
impl ChunkFull<&Series> for ChunkedArray<FixedSizeListType>
dtype-array
only.Source§fn full(
name: PlSmallStr,
value: &Series,
length: usize,
) -> ChunkedArray<FixedSizeListType>
fn full( name: PlSmallStr, value: &Series, length: usize, ) -> ChunkedArray<FixedSizeListType>
Source§impl ChunkFull<&Series> for ChunkedArray<ListType>
impl ChunkFull<&Series> for ChunkedArray<ListType>
Source§fn full(
name: PlSmallStr,
value: &Series,
length: usize,
) -> ChunkedArray<ListType>
fn full( name: PlSmallStr, value: &Series, length: usize, ) -> ChunkedArray<ListType>
Source§impl<'a> ChunkFull<&'a str> for ChunkedArray<StringType>
impl<'a> ChunkFull<&'a str> for ChunkedArray<StringType>
Source§fn full(
name: PlSmallStr,
value: &'a str,
length: usize,
) -> ChunkedArray<StringType>
fn full( name: PlSmallStr, value: &'a str, length: usize, ) -> ChunkedArray<StringType>
Source§impl<T> ChunkFull<<T as PolarsNumericType>::Native> for ChunkedArray<T>where
T: PolarsNumericType,
impl<T> ChunkFull<<T as PolarsNumericType>::Native> for ChunkedArray<T>where
T: PolarsNumericType,
Source§fn full(
name: PlSmallStr,
value: <T as PolarsNumericType>::Native,
length: usize,
) -> ChunkedArray<T>
fn full( name: PlSmallStr, value: <T as PolarsNumericType>::Native, length: usize, ) -> ChunkedArray<T>
Source§impl<T> ChunkFull<T> for ChunkedArray<ObjectType<T>>where
T: PolarsObject,
Available on crate feature object
only.
impl<T> ChunkFull<T> for ChunkedArray<ObjectType<T>>where
T: PolarsObject,
object
only.Source§fn full(
name: PlSmallStr,
value: T,
length: usize,
) -> ChunkedArray<ObjectType<T>>
fn full( name: PlSmallStr, value: T, length: usize, ) -> ChunkedArray<ObjectType<T>>
Source§impl ChunkFull<bool> for ChunkedArray<BooleanType>
impl ChunkFull<bool> for ChunkedArray<BooleanType>
Source§fn full(
name: PlSmallStr,
value: bool,
length: usize,
) -> ChunkedArray<BooleanType>
fn full( name: PlSmallStr, value: bool, length: usize, ) -> ChunkedArray<BooleanType>
Source§impl ChunkFullNull for ChunkedArray<BinaryOffsetType>
impl ChunkFullNull for ChunkedArray<BinaryOffsetType>
fn full_null(name: PlSmallStr, length: usize) -> ChunkedArray<BinaryOffsetType>
Source§impl ChunkFullNull for ChunkedArray<BinaryType>
impl ChunkFullNull for ChunkedArray<BinaryType>
fn full_null(name: PlSmallStr, length: usize) -> ChunkedArray<BinaryType>
Source§impl ChunkFullNull for ChunkedArray<BooleanType>
impl ChunkFullNull for ChunkedArray<BooleanType>
fn full_null(name: PlSmallStr, length: usize) -> ChunkedArray<BooleanType>
Source§impl ChunkFullNull for ChunkedArray<FixedSizeListType>
Available on crate feature dtype-array
only.
impl ChunkFullNull for ChunkedArray<FixedSizeListType>
dtype-array
only.fn full_null(name: PlSmallStr, length: usize) -> ChunkedArray<FixedSizeListType>
Source§impl ChunkFullNull for ChunkedArray<ListType>
impl ChunkFullNull for ChunkedArray<ListType>
fn full_null(name: PlSmallStr, length: usize) -> ChunkedArray<ListType>
Source§impl<T> ChunkFullNull for ChunkedArray<ObjectType<T>>where
T: PolarsObject,
Available on crate feature object
only.
impl<T> ChunkFullNull for ChunkedArray<ObjectType<T>>where
T: PolarsObject,
object
only.fn full_null(name: PlSmallStr, length: usize) -> ChunkedArray<ObjectType<T>>
Source§impl ChunkFullNull for ChunkedArray<StringType>
impl ChunkFullNull for ChunkedArray<StringType>
fn full_null(name: PlSmallStr, length: usize) -> ChunkedArray<StringType>
Source§impl ChunkFullNull for ChunkedArray<StructType>
Available on crate feature dtype-struct
only.
impl ChunkFullNull for ChunkedArray<StructType>
dtype-struct
only.fn full_null(name: PlSmallStr, length: usize) -> ChunkedArray<StructType>
Source§impl<T> ChunkFullNull for ChunkedArray<T>where
T: PolarsNumericType,
impl<T> ChunkFullNull for ChunkedArray<T>where
T: PolarsNumericType,
fn full_null(name: PlSmallStr, length: usize) -> ChunkedArray<T>
Source§impl ChunkQuantile<Series> for ChunkedArray<FixedSizeListType>
Available on crate feature dtype-array
only.
impl ChunkQuantile<Series> for ChunkedArray<FixedSizeListType>
dtype-array
only.Source§fn median(&self) -> Option<T>
fn median(&self) -> Option<T>
None
if the array is empty or only contains null values.Source§fn quantile(
&self,
_quantile: f64,
_method: QuantileMethod,
) -> Result<Option<T>, PolarsError>
fn quantile( &self, _quantile: f64, _method: QuantileMethod, ) -> Result<Option<T>, PolarsError>
None
if the array is empty or only contains null values.Source§impl ChunkQuantile<Series> for ChunkedArray<ListType>
impl ChunkQuantile<Series> for ChunkedArray<ListType>
Source§fn median(&self) -> Option<T>
fn median(&self) -> Option<T>
None
if the array is empty or only contains null values.Source§fn quantile(
&self,
_quantile: f64,
_method: QuantileMethod,
) -> Result<Option<T>, PolarsError>
fn quantile( &self, _quantile: f64, _method: QuantileMethod, ) -> Result<Option<T>, PolarsError>
None
if the array is empty or only contains null values.Source§impl<T> ChunkQuantile<Series> for ChunkedArray<ObjectType<T>>where
T: PolarsObject,
Available on crate feature object
only.
impl<T> ChunkQuantile<Series> for ChunkedArray<ObjectType<T>>where
T: PolarsObject,
object
only.Source§fn median(&self) -> Option<T>
fn median(&self) -> Option<T>
None
if the array is empty or only contains null values.Source§fn quantile(
&self,
_quantile: f64,
_method: QuantileMethod,
) -> Result<Option<T>, PolarsError>
fn quantile( &self, _quantile: f64, _method: QuantileMethod, ) -> Result<Option<T>, PolarsError>
None
if the array is empty or only contains null values.Source§impl ChunkQuantile<String> for ChunkedArray<StringType>
impl ChunkQuantile<String> for ChunkedArray<StringType>
Source§fn median(&self) -> Option<T>
fn median(&self) -> Option<T>
None
if the array is empty or only contains null values.Source§fn quantile(
&self,
_quantile: f64,
_method: QuantileMethod,
) -> Result<Option<T>, PolarsError>
fn quantile( &self, _quantile: f64, _method: QuantileMethod, ) -> Result<Option<T>, PolarsError>
None
if the array is empty or only contains null values.Source§impl ChunkQuantile<bool> for ChunkedArray<BooleanType>
impl ChunkQuantile<bool> for ChunkedArray<BooleanType>
Source§fn median(&self) -> Option<T>
fn median(&self) -> Option<T>
None
if the array is empty or only contains null values.Source§fn quantile(
&self,
_quantile: f64,
_method: QuantileMethod,
) -> Result<Option<T>, PolarsError>
fn quantile( &self, _quantile: f64, _method: QuantileMethod, ) -> Result<Option<T>, PolarsError>
None
if the array is empty or only contains null values.Source§impl ChunkQuantile<f32> for ChunkedArray<Float32Type>
impl ChunkQuantile<f32> for ChunkedArray<Float32Type>
Source§fn quantile(
&self,
quantile: f64,
method: QuantileMethod,
) -> Result<Option<f32>, PolarsError>
fn quantile( &self, quantile: f64, method: QuantileMethod, ) -> Result<Option<f32>, PolarsError>
None
if the array is empty or only contains null values.Source§impl ChunkQuantile<f64> for ChunkedArray<Float64Type>
impl ChunkQuantile<f64> for ChunkedArray<Float64Type>
Source§fn quantile(
&self,
quantile: f64,
method: QuantileMethod,
) -> Result<Option<f64>, PolarsError>
fn quantile( &self, quantile: f64, method: QuantileMethod, ) -> Result<Option<f64>, PolarsError>
None
if the array is empty or only contains null values.Source§impl<T> ChunkQuantile<f64> for ChunkedArray<T>
impl<T> ChunkQuantile<f64> for ChunkedArray<T>
Source§fn quantile(
&self,
quantile: f64,
method: QuantileMethod,
) -> Result<Option<f64>, PolarsError>
fn quantile( &self, quantile: f64, method: QuantileMethod, ) -> Result<Option<f64>, PolarsError>
None
if the array is empty or only contains null values.Source§impl ChunkReverse for ChunkedArray<BinaryOffsetType>
impl ChunkReverse for ChunkedArray<BinaryOffsetType>
Source§fn reverse(&self) -> ChunkedArray<BinaryOffsetType>
fn reverse(&self) -> ChunkedArray<BinaryOffsetType>
Source§impl ChunkReverse for ChunkedArray<BinaryType>
impl ChunkReverse for ChunkedArray<BinaryType>
Source§fn reverse(&self) -> ChunkedArray<BinaryType>
fn reverse(&self) -> ChunkedArray<BinaryType>
Source§impl ChunkReverse for ChunkedArray<BooleanType>
impl ChunkReverse for ChunkedArray<BooleanType>
Source§fn reverse(&self) -> ChunkedArray<BooleanType>
fn reverse(&self) -> ChunkedArray<BooleanType>
Source§impl ChunkReverse for ChunkedArray<FixedSizeListType>
Available on crate feature dtype-array
only.
impl ChunkReverse for ChunkedArray<FixedSizeListType>
dtype-array
only.Source§fn reverse(&self) -> ChunkedArray<FixedSizeListType>
fn reverse(&self) -> ChunkedArray<FixedSizeListType>
Source§impl ChunkReverse for ChunkedArray<ListType>
impl ChunkReverse for ChunkedArray<ListType>
Source§fn reverse(&self) -> ChunkedArray<ListType>
fn reverse(&self) -> ChunkedArray<ListType>
Source§impl<T> ChunkReverse for ChunkedArray<ObjectType<T>>where
T: PolarsObject,
Available on crate feature object
only.
impl<T> ChunkReverse for ChunkedArray<ObjectType<T>>where
T: PolarsObject,
object
only.Source§fn reverse(&self) -> ChunkedArray<ObjectType<T>>
fn reverse(&self) -> ChunkedArray<ObjectType<T>>
Source§impl ChunkReverse for ChunkedArray<StringType>
impl ChunkReverse for ChunkedArray<StringType>
Source§fn reverse(&self) -> ChunkedArray<StringType>
fn reverse(&self) -> ChunkedArray<StringType>
Source§impl<T> ChunkReverse for ChunkedArray<T>where
T: PolarsNumericType,
impl<T> ChunkReverse for ChunkedArray<T>where
T: PolarsNumericType,
Source§fn reverse(&self) -> ChunkedArray<T>
fn reverse(&self) -> ChunkedArray<T>
Source§impl<T> ChunkRollApply for ChunkedArray<T>
impl<T> ChunkRollApply for ChunkedArray<T>
Source§fn rolling_map(
&self,
f: &dyn Fn(&Series) -> Series,
options: RollingOptionsFixedWindow,
) -> Result<Series, PolarsError>
fn rolling_map( &self, f: &dyn Fn(&Series) -> Series, options: RollingOptionsFixedWindow, ) -> Result<Series, PolarsError>
Apply a rolling custom function. This is pretty slow because of dynamic dispatch.
Source§impl<'a> ChunkSet<'a, &'a [u8], Vec<u8>> for ChunkedArray<BinaryType>
impl<'a> ChunkSet<'a, &'a [u8], Vec<u8>> for ChunkedArray<BinaryType>
Source§fn scatter_single<I>(
&'a self,
idx: I,
opt_value: Option<&'a [u8]>,
) -> Result<ChunkedArray<BinaryType>, PolarsError>
fn scatter_single<I>( &'a self, idx: I, opt_value: Option<&'a [u8]>, ) -> Result<ChunkedArray<BinaryType>, PolarsError>
Source§fn scatter_with<I, F>(
&'a self,
idx: I,
f: F,
) -> Result<ChunkedArray<BinaryType>, PolarsError>where
I: IntoIterator<Item = u32>,
ChunkedArray<BinaryType>: Sized,
F: Fn(Option<&'a [u8]>) -> Option<Vec<u8>>,
fn scatter_with<I, F>(
&'a self,
idx: I,
f: F,
) -> Result<ChunkedArray<BinaryType>, PolarsError>where
I: IntoIterator<Item = u32>,
ChunkedArray<BinaryType>: Sized,
F: Fn(Option<&'a [u8]>) -> Option<Vec<u8>>,
idx
by applying a closure to these values. Read moreSource§fn set(
&'a self,
mask: &ChunkedArray<BooleanType>,
value: Option<&'a [u8]>,
) -> Result<ChunkedArray<BinaryType>, PolarsError>
fn set( &'a self, mask: &ChunkedArray<BooleanType>, value: Option<&'a [u8]>, ) -> Result<ChunkedArray<BinaryType>, PolarsError>
Source§impl<'a> ChunkSet<'a, &'a str, String> for ChunkedArray<StringType>
impl<'a> ChunkSet<'a, &'a str, String> for ChunkedArray<StringType>
Source§fn scatter_single<I>(
&'a self,
idx: I,
opt_value: Option<&'a str>,
) -> Result<ChunkedArray<StringType>, PolarsError>
fn scatter_single<I>( &'a self, idx: I, opt_value: Option<&'a str>, ) -> Result<ChunkedArray<StringType>, PolarsError>
Source§fn scatter_with<I, F>(
&'a self,
idx: I,
f: F,
) -> Result<ChunkedArray<StringType>, PolarsError>where
I: IntoIterator<Item = u32>,
ChunkedArray<StringType>: Sized,
F: Fn(Option<&'a str>) -> Option<String>,
fn scatter_with<I, F>(
&'a self,
idx: I,
f: F,
) -> Result<ChunkedArray<StringType>, PolarsError>where
I: IntoIterator<Item = u32>,
ChunkedArray<StringType>: Sized,
F: Fn(Option<&'a str>) -> Option<String>,
idx
by applying a closure to these values. Read moreSource§fn set(
&'a self,
mask: &ChunkedArray<BooleanType>,
value: Option<&'a str>,
) -> Result<ChunkedArray<StringType>, PolarsError>
fn set( &'a self, mask: &ChunkedArray<BooleanType>, value: Option<&'a str>, ) -> Result<ChunkedArray<StringType>, PolarsError>
Source§impl<'a, T> ChunkSet<'a, <T as PolarsNumericType>::Native, <T as PolarsNumericType>::Native> for ChunkedArray<T>where
T: PolarsNumericType,
impl<'a, T> ChunkSet<'a, <T as PolarsNumericType>::Native, <T as PolarsNumericType>::Native> for ChunkedArray<T>where
T: PolarsNumericType,
Source§fn scatter_single<I>(
&'a self,
idx: I,
value: Option<<T as PolarsNumericType>::Native>,
) -> Result<ChunkedArray<T>, PolarsError>where
I: IntoIterator<Item = u32>,
fn scatter_single<I>(
&'a self,
idx: I,
value: Option<<T as PolarsNumericType>::Native>,
) -> Result<ChunkedArray<T>, PolarsError>where
I: IntoIterator<Item = u32>,
Source§fn scatter_with<I, F>(
&'a self,
idx: I,
f: F,
) -> Result<ChunkedArray<T>, PolarsError>where
I: IntoIterator<Item = u32>,
F: Fn(Option<<T as PolarsNumericType>::Native>) -> Option<<T as PolarsNumericType>::Native>,
fn scatter_with<I, F>(
&'a self,
idx: I,
f: F,
) -> Result<ChunkedArray<T>, PolarsError>where
I: IntoIterator<Item = u32>,
F: Fn(Option<<T as PolarsNumericType>::Native>) -> Option<<T as PolarsNumericType>::Native>,
idx
by applying a closure to these values. Read moreSource§fn set(
&'a self,
mask: &ChunkedArray<BooleanType>,
value: Option<<T as PolarsNumericType>::Native>,
) -> Result<ChunkedArray<T>, PolarsError>
fn set( &'a self, mask: &ChunkedArray<BooleanType>, value: Option<<T as PolarsNumericType>::Native>, ) -> Result<ChunkedArray<T>, PolarsError>
Source§impl<'a> ChunkSet<'a, bool, bool> for ChunkedArray<BooleanType>
impl<'a> ChunkSet<'a, bool, bool> for ChunkedArray<BooleanType>
Source§fn scatter_single<I>(
&'a self,
idx: I,
value: Option<bool>,
) -> Result<ChunkedArray<BooleanType>, PolarsError>where
I: IntoIterator<Item = u32>,
fn scatter_single<I>(
&'a self,
idx: I,
value: Option<bool>,
) -> Result<ChunkedArray<BooleanType>, PolarsError>where
I: IntoIterator<Item = u32>,
Source§fn scatter_with<I, F>(
&'a self,
idx: I,
f: F,
) -> Result<ChunkedArray<BooleanType>, PolarsError>
fn scatter_with<I, F>( &'a self, idx: I, f: F, ) -> Result<ChunkedArray<BooleanType>, PolarsError>
idx
by applying a closure to these values. Read moreSource§fn set(
&'a self,
mask: &ChunkedArray<BooleanType>,
value: Option<bool>,
) -> Result<ChunkedArray<BooleanType>, PolarsError>
fn set( &'a self, mask: &ChunkedArray<BooleanType>, value: Option<bool>, ) -> Result<ChunkedArray<BooleanType>, PolarsError>
Source§impl ChunkShift<BinaryOffsetType> for ChunkedArray<BinaryOffsetType>
impl ChunkShift<BinaryOffsetType> for ChunkedArray<BinaryOffsetType>
fn shift(&self, periods: i64) -> ChunkedArray<BinaryOffsetType>
Source§impl ChunkShift<BinaryType> for ChunkedArray<BinaryType>
impl ChunkShift<BinaryType> for ChunkedArray<BinaryType>
fn shift(&self, periods: i64) -> ChunkedArray<BinaryType>
Source§impl ChunkShift<BooleanType> for ChunkedArray<BooleanType>
impl ChunkShift<BooleanType> for ChunkedArray<BooleanType>
fn shift(&self, periods: i64) -> ChunkedArray<BooleanType>
Source§impl ChunkShift<FixedSizeListType> for ChunkedArray<FixedSizeListType>
Available on crate feature dtype-array
only.
impl ChunkShift<FixedSizeListType> for ChunkedArray<FixedSizeListType>
dtype-array
only.fn shift(&self, periods: i64) -> ChunkedArray<FixedSizeListType>
Source§impl ChunkShift<ListType> for ChunkedArray<ListType>
impl ChunkShift<ListType> for ChunkedArray<ListType>
Source§impl<T> ChunkShift<ObjectType<T>> for ChunkedArray<ObjectType<T>>where
T: PolarsObject,
Available on crate feature object
only.
impl<T> ChunkShift<ObjectType<T>> for ChunkedArray<ObjectType<T>>where
T: PolarsObject,
object
only.fn shift(&self, periods: i64) -> ChunkedArray<ObjectType<T>>
Source§impl ChunkShift<StringType> for ChunkedArray<StringType>
impl ChunkShift<StringType> for ChunkedArray<StringType>
fn shift(&self, periods: i64) -> ChunkedArray<StringType>
Source§impl ChunkShift<StructType> for ChunkedArray<StructType>
Available on crate feature dtype-struct
only.
impl ChunkShift<StructType> for ChunkedArray<StructType>
dtype-struct
only.fn shift(&self, periods: i64) -> ChunkedArray<StructType>
Source§impl<T> ChunkShift<T> for ChunkedArray<T>where
T: PolarsNumericType,
impl<T> ChunkShift<T> for ChunkedArray<T>where
T: PolarsNumericType,
fn shift(&self, periods: i64) -> ChunkedArray<T>
Source§impl ChunkShiftFill<BinaryOffsetType, Option<&[u8]>> for ChunkedArray<BinaryOffsetType>
impl ChunkShiftFill<BinaryOffsetType, Option<&[u8]>> for ChunkedArray<BinaryOffsetType>
Source§fn shift_and_fill(
&self,
periods: i64,
fill_value: Option<&[u8]>,
) -> ChunkedArray<BinaryOffsetType>
fn shift_and_fill( &self, periods: i64, fill_value: Option<&[u8]>, ) -> ChunkedArray<BinaryOffsetType>
fill_value
.Source§impl ChunkShiftFill<BinaryType, Option<&[u8]>> for ChunkedArray<BinaryType>
impl ChunkShiftFill<BinaryType, Option<&[u8]>> for ChunkedArray<BinaryType>
Source§fn shift_and_fill(
&self,
periods: i64,
fill_value: Option<&[u8]>,
) -> ChunkedArray<BinaryType>
fn shift_and_fill( &self, periods: i64, fill_value: Option<&[u8]>, ) -> ChunkedArray<BinaryType>
fill_value
.Source§impl ChunkShiftFill<BooleanType, Option<bool>> for ChunkedArray<BooleanType>
impl ChunkShiftFill<BooleanType, Option<bool>> for ChunkedArray<BooleanType>
Source§fn shift_and_fill(
&self,
periods: i64,
fill_value: Option<bool>,
) -> ChunkedArray<BooleanType>
fn shift_and_fill( &self, periods: i64, fill_value: Option<bool>, ) -> ChunkedArray<BooleanType>
fill_value
.Source§impl ChunkShiftFill<FixedSizeListType, Option<&Series>> for ChunkedArray<FixedSizeListType>
Available on crate feature dtype-array
only.
impl ChunkShiftFill<FixedSizeListType, Option<&Series>> for ChunkedArray<FixedSizeListType>
dtype-array
only.Source§fn shift_and_fill(
&self,
periods: i64,
fill_value: Option<&Series>,
) -> ChunkedArray<FixedSizeListType>
fn shift_and_fill( &self, periods: i64, fill_value: Option<&Series>, ) -> ChunkedArray<FixedSizeListType>
fill_value
.Source§impl ChunkShiftFill<ListType, Option<&Series>> for ChunkedArray<ListType>
impl ChunkShiftFill<ListType, Option<&Series>> for ChunkedArray<ListType>
Source§fn shift_and_fill(
&self,
periods: i64,
fill_value: Option<&Series>,
) -> ChunkedArray<ListType>
fn shift_and_fill( &self, periods: i64, fill_value: Option<&Series>, ) -> ChunkedArray<ListType>
fill_value
.Source§impl<T> ChunkShiftFill<ObjectType<T>, Option<ObjectType<T>>> for ChunkedArray<ObjectType<T>>where
T: PolarsObject,
Available on crate feature object
only.
impl<T> ChunkShiftFill<ObjectType<T>, Option<ObjectType<T>>> for ChunkedArray<ObjectType<T>>where
T: PolarsObject,
object
only.Source§fn shift_and_fill(
&self,
_periods: i64,
_fill_value: Option<ObjectType<T>>,
) -> ChunkedArray<ObjectType<T>>
fn shift_and_fill( &self, _periods: i64, _fill_value: Option<ObjectType<T>>, ) -> ChunkedArray<ObjectType<T>>
fill_value
.Source§impl ChunkShiftFill<StringType, Option<&str>> for ChunkedArray<StringType>
impl ChunkShiftFill<StringType, Option<&str>> for ChunkedArray<StringType>
Source§fn shift_and_fill(
&self,
periods: i64,
fill_value: Option<&str>,
) -> ChunkedArray<StringType>
fn shift_and_fill( &self, periods: i64, fill_value: Option<&str>, ) -> ChunkedArray<StringType>
fill_value
.Source§impl<T> ChunkShiftFill<T, Option<<T as PolarsNumericType>::Native>> for ChunkedArray<T>where
T: PolarsNumericType,
impl<T> ChunkShiftFill<T, Option<<T as PolarsNumericType>::Native>> for ChunkedArray<T>where
T: PolarsNumericType,
Source§fn shift_and_fill(
&self,
periods: i64,
fill_value: Option<<T as PolarsNumericType>::Native>,
) -> ChunkedArray<T>
fn shift_and_fill( &self, periods: i64, fill_value: Option<<T as PolarsNumericType>::Native>, ) -> ChunkedArray<T>
fill_value
.Source§impl ChunkSort<BinaryOffsetType> for ChunkedArray<BinaryOffsetType>
impl ChunkSort<BinaryOffsetType> for ChunkedArray<BinaryOffsetType>
Source§fn arg_sort_multiple(
&self,
by: &[Column],
options: &SortMultipleOptions,
) -> Result<ChunkedArray<UInt32Type>, PolarsError>
fn arg_sort_multiple( &self, by: &[Column], options: &SortMultipleOptions, ) -> Result<ChunkedArray<UInt32Type>, PolarsError>
§Panics
This function is very opinionated. On the implementation of ChunkedArray<T>
for numeric types,
we assume that all numeric Series
are of the same type.
In this case we assume that all numeric Series
are f64
types. The caller needs to
uphold this contract. If not, it will panic.
fn sort_with(&self, options: SortOptions) -> ChunkedArray<BinaryOffsetType>
Source§fn sort(&self, descending: bool) -> ChunkedArray<BinaryOffsetType>
fn sort(&self, descending: bool) -> ChunkedArray<BinaryOffsetType>
ChunkedArray
.Source§fn arg_sort(&self, options: SortOptions) -> ChunkedArray<UInt32Type>
fn arg_sort(&self, options: SortOptions) -> ChunkedArray<UInt32Type>
Source§impl ChunkSort<BinaryType> for ChunkedArray<BinaryType>
impl ChunkSort<BinaryType> for ChunkedArray<BinaryType>
fn sort_with(&self, options: SortOptions) -> ChunkedArray<BinaryType>
Source§fn sort(&self, descending: bool) -> ChunkedArray<BinaryType>
fn sort(&self, descending: bool) -> ChunkedArray<BinaryType>
ChunkedArray
.Source§fn arg_sort(&self, options: SortOptions) -> ChunkedArray<UInt32Type>
fn arg_sort(&self, options: SortOptions) -> ChunkedArray<UInt32Type>
Source§fn arg_sort_multiple(
&self,
by: &[Column],
options: &SortMultipleOptions,
) -> Result<ChunkedArray<UInt32Type>, PolarsError>
fn arg_sort_multiple( &self, by: &[Column], options: &SortMultipleOptions, ) -> Result<ChunkedArray<UInt32Type>, PolarsError>
Source§impl ChunkSort<BooleanType> for ChunkedArray<BooleanType>
impl ChunkSort<BooleanType> for ChunkedArray<BooleanType>
fn sort_with(&self, options: SortOptions) -> ChunkedArray<BooleanType>
Source§fn sort(&self, descending: bool) -> ChunkedArray<BooleanType>
fn sort(&self, descending: bool) -> ChunkedArray<BooleanType>
ChunkedArray
.Source§fn arg_sort(&self, options: SortOptions) -> ChunkedArray<UInt32Type>
fn arg_sort(&self, options: SortOptions) -> ChunkedArray<UInt32Type>
Source§fn arg_sort_multiple(
&self,
by: &[Column],
options: &SortMultipleOptions,
) -> Result<ChunkedArray<UInt32Type>, PolarsError>
fn arg_sort_multiple( &self, by: &[Column], options: &SortMultipleOptions, ) -> Result<ChunkedArray<UInt32Type>, PolarsError>
Source§impl ChunkSort<StringType> for ChunkedArray<StringType>
impl ChunkSort<StringType> for ChunkedArray<StringType>
Source§fn arg_sort_multiple(
&self,
by: &[Column],
options: &SortMultipleOptions,
) -> Result<ChunkedArray<UInt32Type>, PolarsError>
fn arg_sort_multiple( &self, by: &[Column], options: &SortMultipleOptions, ) -> Result<ChunkedArray<UInt32Type>, PolarsError>
§Panics
This function is very opinionated. On the implementation of ChunkedArray<T>
for numeric types,
we assume that all numeric Series
are of the same type.
In this case we assume that all numeric Series
are f64
types. The caller needs to
uphold this contract. If not, it will panic.
fn sort_with(&self, options: SortOptions) -> ChunkedArray<StringType>
Source§fn sort(&self, descending: bool) -> ChunkedArray<StringType>
fn sort(&self, descending: bool) -> ChunkedArray<StringType>
ChunkedArray
.Source§fn arg_sort(&self, options: SortOptions) -> ChunkedArray<UInt32Type>
fn arg_sort(&self, options: SortOptions) -> ChunkedArray<UInt32Type>
Source§impl ChunkSort<StructType> for ChunkedArray<StructType>
Available on crate feature dtype-struct
only.
impl ChunkSort<StructType> for ChunkedArray<StructType>
dtype-struct
only.fn sort_with(&self, options: SortOptions) -> ChunkedArray<StructType>
Source§fn sort(&self, descending: bool) -> ChunkedArray<StructType>
fn sort(&self, descending: bool) -> ChunkedArray<StructType>
ChunkedArray
.Source§fn arg_sort(&self, options: SortOptions) -> ChunkedArray<UInt32Type>
fn arg_sort(&self, options: SortOptions) -> ChunkedArray<UInt32Type>
Source§fn arg_sort_multiple(
&self,
by: &[Column],
_options: &SortMultipleOptions,
) -> Result<ChunkedArray<UInt32Type>, PolarsError>
fn arg_sort_multiple( &self, by: &[Column], _options: &SortMultipleOptions, ) -> Result<ChunkedArray<UInt32Type>, PolarsError>
Source§impl<T> ChunkSort<T> for ChunkedArray<T>where
T: PolarsNumericType,
impl<T> ChunkSort<T> for ChunkedArray<T>where
T: PolarsNumericType,
Source§fn arg_sort_multiple(
&self,
by: &[Column],
options: &SortMultipleOptions,
) -> Result<ChunkedArray<UInt32Type>, PolarsError>
fn arg_sort_multiple( &self, by: &[Column], options: &SortMultipleOptions, ) -> Result<ChunkedArray<UInt32Type>, PolarsError>
§Panics
This function is very opinionated.
We assume that all numeric Series
are of the same type, if not it will panic
fn sort_with(&self, options: SortOptions) -> ChunkedArray<T>
Source§fn sort(&self, descending: bool) -> ChunkedArray<T>
fn sort(&self, descending: bool) -> ChunkedArray<T>
ChunkedArray
.Source§fn arg_sort(&self, options: SortOptions) -> ChunkedArray<UInt32Type>
fn arg_sort(&self, options: SortOptions) -> ChunkedArray<UInt32Type>
Source§impl<T> ChunkTake<ChunkedArray<UInt32Type>> for ChunkedArray<T>
impl<T> ChunkTake<ChunkedArray<UInt32Type>> for ChunkedArray<T>
Source§fn take(
&self,
indices: &ChunkedArray<UInt32Type>,
) -> Result<ChunkedArray<T>, PolarsError>
fn take( &self, indices: &ChunkedArray<UInt32Type>, ) -> Result<ChunkedArray<T>, PolarsError>
Gather values from ChunkedArray by index.
Source§impl<T, I> ChunkTake<I> for ChunkedArray<T>
impl<T, I> ChunkTake<I> for ChunkedArray<T>
Source§fn take(&self, indices: &I) -> Result<ChunkedArray<T>, PolarsError>
fn take(&self, indices: &I) -> Result<ChunkedArray<T>, PolarsError>
Gather values from ChunkedArray by index.
Source§impl ChunkTakeUnchecked<ChunkedArray<UInt32Type>> for ChunkedArray<BinaryType>
impl ChunkTakeUnchecked<ChunkedArray<UInt32Type>> for ChunkedArray<BinaryType>
Source§unsafe fn take_unchecked(
&self,
indices: &ChunkedArray<UInt32Type>,
) -> ChunkedArray<BinaryType>
unsafe fn take_unchecked( &self, indices: &ChunkedArray<UInt32Type>, ) -> ChunkedArray<BinaryType>
Gather values from ChunkedArray by index.
Source§impl ChunkTakeUnchecked<ChunkedArray<UInt32Type>> for ChunkedArray<FixedSizeListType>
Available on crate feature dtype-array
only.
impl ChunkTakeUnchecked<ChunkedArray<UInt32Type>> for ChunkedArray<FixedSizeListType>
dtype-array
only.Source§unsafe fn take_unchecked(
&self,
indices: &ChunkedArray<UInt32Type>,
) -> ChunkedArray<FixedSizeListType>
unsafe fn take_unchecked( &self, indices: &ChunkedArray<UInt32Type>, ) -> ChunkedArray<FixedSizeListType>
Source§impl ChunkTakeUnchecked<ChunkedArray<UInt32Type>> for ChunkedArray<ListType>
impl ChunkTakeUnchecked<ChunkedArray<UInt32Type>> for ChunkedArray<ListType>
Source§unsafe fn take_unchecked(
&self,
indices: &ChunkedArray<UInt32Type>,
) -> ChunkedArray<ListType>
unsafe fn take_unchecked( &self, indices: &ChunkedArray<UInt32Type>, ) -> ChunkedArray<ListType>
Source§impl ChunkTakeUnchecked<ChunkedArray<UInt32Type>> for ChunkedArray<StringType>
impl ChunkTakeUnchecked<ChunkedArray<UInt32Type>> for ChunkedArray<StringType>
Source§unsafe fn take_unchecked(
&self,
indices: &ChunkedArray<UInt32Type>,
) -> ChunkedArray<StringType>
unsafe fn take_unchecked( &self, indices: &ChunkedArray<UInt32Type>, ) -> ChunkedArray<StringType>
Source§impl ChunkTakeUnchecked<ChunkedArray<UInt32Type>> for ChunkedArray<StructType>
Available on crate feature dtype-struct
only.
impl ChunkTakeUnchecked<ChunkedArray<UInt32Type>> for ChunkedArray<StructType>
dtype-struct
only.Source§unsafe fn take_unchecked(
&self,
indices: &ChunkedArray<UInt32Type>,
) -> ChunkedArray<StructType>
unsafe fn take_unchecked( &self, indices: &ChunkedArray<UInt32Type>, ) -> ChunkedArray<StructType>
Source§impl<T> ChunkTakeUnchecked<ChunkedArray<UInt32Type>> for ChunkedArray<T>
impl<T> ChunkTakeUnchecked<ChunkedArray<UInt32Type>> for ChunkedArray<T>
Source§unsafe fn take_unchecked(
&self,
indices: &ChunkedArray<UInt32Type>,
) -> ChunkedArray<T>
unsafe fn take_unchecked( &self, indices: &ChunkedArray<UInt32Type>, ) -> ChunkedArray<T>
Gather values from ChunkedArray by index.
Source§impl<I> ChunkTakeUnchecked<I> for ChunkedArray<BinaryType>
impl<I> ChunkTakeUnchecked<I> for ChunkedArray<BinaryType>
Source§unsafe fn take_unchecked(&self, indices: &I) -> ChunkedArray<BinaryType>
unsafe fn take_unchecked(&self, indices: &I) -> ChunkedArray<BinaryType>
Gather values from ChunkedArray by index.
Source§impl<I> ChunkTakeUnchecked<I> for ChunkedArray<FixedSizeListType>
Available on crate feature dtype-array
only.
impl<I> ChunkTakeUnchecked<I> for ChunkedArray<FixedSizeListType>
dtype-array
only.Source§unsafe fn take_unchecked(&self, indices: &I) -> ChunkedArray<FixedSizeListType>
unsafe fn take_unchecked(&self, indices: &I) -> ChunkedArray<FixedSizeListType>
Source§impl<I> ChunkTakeUnchecked<I> for ChunkedArray<ListType>
impl<I> ChunkTakeUnchecked<I> for ChunkedArray<ListType>
Source§unsafe fn take_unchecked(&self, indices: &I) -> ChunkedArray<ListType>
unsafe fn take_unchecked(&self, indices: &I) -> ChunkedArray<ListType>
Source§impl<I> ChunkTakeUnchecked<I> for ChunkedArray<StringType>
impl<I> ChunkTakeUnchecked<I> for ChunkedArray<StringType>
Source§unsafe fn take_unchecked(&self, indices: &I) -> ChunkedArray<StringType>
unsafe fn take_unchecked(&self, indices: &I) -> ChunkedArray<StringType>
Gather values from ChunkedArray by index.
Source§impl<I> ChunkTakeUnchecked<I> for ChunkedArray<StructType>
Available on crate feature dtype-struct
only.
impl<I> ChunkTakeUnchecked<I> for ChunkedArray<StructType>
dtype-struct
only.Source§unsafe fn take_unchecked(&self, indices: &I) -> ChunkedArray<StructType>
unsafe fn take_unchecked(&self, indices: &I) -> ChunkedArray<StructType>
Source§impl<T, I> ChunkTakeUnchecked<I> for ChunkedArray<T>where
T: PolarsDataType<HasViews = FalseT, IsStruct = FalseT, IsNested = FalseT> + PolarsDataType,
I: AsRef<[u32]> + ?Sized,
impl<T, I> ChunkTakeUnchecked<I> for ChunkedArray<T>where
T: PolarsDataType<HasViews = FalseT, IsStruct = FalseT, IsNested = FalseT> + PolarsDataType,
I: AsRef<[u32]> + ?Sized,
Source§unsafe fn take_unchecked(&self, indices: &I) -> ChunkedArray<T>
unsafe fn take_unchecked(&self, indices: &I) -> ChunkedArray<T>
Gather values from ChunkedArray by index.
Source§impl ChunkUnique for ChunkedArray<BinaryType>
impl ChunkUnique for ChunkedArray<BinaryType>
Source§fn unique(&self) -> Result<ChunkedArray<BinaryType>, PolarsError>
fn unique(&self) -> Result<ChunkedArray<BinaryType>, PolarsError>
Source§fn arg_unique(&self) -> Result<ChunkedArray<UInt32Type>, PolarsError>
fn arg_unique(&self) -> Result<ChunkedArray<UInt32Type>, PolarsError>
ChunkedArray
.
This Vec is sorted.Source§impl ChunkUnique for ChunkedArray<BooleanType>
impl ChunkUnique for ChunkedArray<BooleanType>
Source§fn unique(&self) -> Result<ChunkedArray<BooleanType>, PolarsError>
fn unique(&self) -> Result<ChunkedArray<BooleanType>, PolarsError>
Source§fn arg_unique(&self) -> Result<ChunkedArray<UInt32Type>, PolarsError>
fn arg_unique(&self) -> Result<ChunkedArray<UInt32Type>, PolarsError>
ChunkedArray
.
This Vec is sorted.Source§impl<T> ChunkUnique for ChunkedArray<ObjectType<T>>where
T: PolarsObject,
Available on crate feature object
only.
impl<T> ChunkUnique for ChunkedArray<ObjectType<T>>where
T: PolarsObject,
object
only.Source§fn unique(&self) -> Result<ChunkedArray<ObjectType<T>>, PolarsError>
fn unique(&self) -> Result<ChunkedArray<ObjectType<T>>, PolarsError>
Source§fn arg_unique(&self) -> Result<ChunkedArray<UInt32Type>, PolarsError>
fn arg_unique(&self) -> Result<ChunkedArray<UInt32Type>, PolarsError>
ChunkedArray
.
This Vec is sorted.Source§impl ChunkUnique for ChunkedArray<StringType>
impl ChunkUnique for ChunkedArray<StringType>
Source§fn unique(&self) -> Result<ChunkedArray<StringType>, PolarsError>
fn unique(&self) -> Result<ChunkedArray<StringType>, PolarsError>
Source§fn arg_unique(&self) -> Result<ChunkedArray<UInt32Type>, PolarsError>
fn arg_unique(&self) -> Result<ChunkedArray<UInt32Type>, PolarsError>
ChunkedArray
.
This Vec is sorted.Source§impl<T> ChunkUnique for ChunkedArray<T>where
T: PolarsNumericType,
<T as PolarsNumericType>::Native: TotalHash + TotalEq + ToTotalOrd,
<<T as PolarsNumericType>::Native as ToTotalOrd>::TotalOrdItem: Hash + Eq + Ord,
ChunkedArray<T>: IntoSeries + for<'a> ChunkCompareEq<&'a ChunkedArray<T>, Item = ChunkedArray<BooleanType>>,
impl<T> ChunkUnique for ChunkedArray<T>where
T: PolarsNumericType,
<T as PolarsNumericType>::Native: TotalHash + TotalEq + ToTotalOrd,
<<T as PolarsNumericType>::Native as ToTotalOrd>::TotalOrdItem: Hash + Eq + Ord,
ChunkedArray<T>: IntoSeries + for<'a> ChunkCompareEq<&'a ChunkedArray<T>, Item = ChunkedArray<BooleanType>>,
Source§fn unique(&self) -> Result<ChunkedArray<T>, PolarsError>
fn unique(&self) -> Result<ChunkedArray<T>, PolarsError>
Source§fn arg_unique(&self) -> Result<ChunkedArray<UInt32Type>, PolarsError>
fn arg_unique(&self) -> Result<ChunkedArray<UInt32Type>, PolarsError>
ChunkedArray
.
This Vec is sorted.Source§impl ChunkVar for ChunkedArray<BooleanType>
impl ChunkVar for ChunkedArray<BooleanType>
Source§impl ChunkVar for ChunkedArray<FixedSizeListType>
Available on crate feature dtype-array
only.
impl ChunkVar for ChunkedArray<FixedSizeListType>
dtype-array
only.Source§impl ChunkVar for ChunkedArray<ListType>
impl ChunkVar for ChunkedArray<ListType>
Source§impl<T> ChunkVar for ChunkedArray<ObjectType<T>>where
T: PolarsObject,
Available on crate feature object
only.
impl<T> ChunkVar for ChunkedArray<ObjectType<T>>where
T: PolarsObject,
object
only.Source§impl ChunkVar for ChunkedArray<StringType>
impl ChunkVar for ChunkedArray<StringType>
Source§impl<T> ChunkVar for ChunkedArray<T>
impl<T> ChunkVar for ChunkedArray<T>
Source§impl ChunkZip<StructType> for ChunkedArray<StructType>
Available on crate feature dtype-struct
only.
impl ChunkZip<StructType> for ChunkedArray<StructType>
dtype-struct
only.Source§fn zip_with(
&self,
mask: &ChunkedArray<BooleanType>,
other: &ChunkedArray<StructType>,
) -> Result<ChunkedArray<StructType>, PolarsError>
fn zip_with( &self, mask: &ChunkedArray<BooleanType>, other: &ChunkedArray<StructType>, ) -> Result<ChunkedArray<StructType>, PolarsError>
true
and values
from other
where the mask evaluates false
Source§impl<T> ChunkZip<T> for ChunkedArray<T>where
<T as PolarsDataType>::Array: for<'a> IfThenElseKernel<Scalar<'a> = <T as PolarsDataType>::Physical<'a>>,
T: PolarsDataType<IsStruct = FalseT>,
ChunkedArray<T>: ChunkExpandAtIndex<T>,
impl<T> ChunkZip<T> for ChunkedArray<T>where
<T as PolarsDataType>::Array: for<'a> IfThenElseKernel<Scalar<'a> = <T as PolarsDataType>::Physical<'a>>,
T: PolarsDataType<IsStruct = FalseT>,
ChunkedArray<T>: ChunkExpandAtIndex<T>,
Source§fn zip_with(
&self,
mask: &ChunkedArray<BooleanType>,
other: &ChunkedArray<T>,
) -> Result<ChunkedArray<T>, PolarsError>
fn zip_with( &self, mask: &ChunkedArray<BooleanType>, other: &ChunkedArray<T>, ) -> Result<ChunkedArray<T>, PolarsError>
true
and values
from other
where the mask evaluates false
Source§impl<'a> ChunkedSet<&'a str> for &'a ChunkedArray<StringType>
impl<'a> ChunkedSet<&'a str> for &'a ChunkedArray<StringType>
Source§impl<T> ChunkedSet<<T as PolarsNumericType>::Native> for &mut ChunkedArray<T>where
T: PolarsOpsNumericType,
ChunkedArray<T>: IntoSeries,
impl<T> ChunkedSet<<T as PolarsNumericType>::Native> for &mut ChunkedArray<T>where
T: PolarsOpsNumericType,
ChunkedArray<T>: IntoSeries,
Source§impl ChunkedSet<bool> for &ChunkedArray<BooleanType>
impl ChunkedSet<bool> for &ChunkedArray<BooleanType>
Source§impl<T> Clone for ChunkedArray<T>where
T: PolarsDataType,
impl<T> Clone for ChunkedArray<T>where
T: PolarsDataType,
Source§fn clone(&self) -> ChunkedArray<T>
fn clone(&self) -> ChunkedArray<T>
1.0.0 · Source§fn clone_from(&mut self, source: &Self)
fn clone_from(&mut self, source: &Self)
source
. Read moreSource§impl<T> Container for ChunkedArray<T>where
T: PolarsDataType,
impl<T> Container for ChunkedArray<T>where
T: PolarsDataType,
fn slice(&self, offset: i64, len: usize) -> ChunkedArray<T>
fn split_at(&self, offset: i64) -> (ChunkedArray<T>, ChunkedArray<T>)
fn len(&self) -> usize
fn iter_chunks(&self) -> impl Iterator<Item = ChunkedArray<T>>
fn n_chunks(&self) -> usize
fn chunk_lengths(&self) -> impl Iterator<Item = usize>
Source§impl Debug for ChunkedArray<BinaryType>
impl Debug for ChunkedArray<BinaryType>
Source§impl Debug for ChunkedArray<BooleanType>
impl Debug for ChunkedArray<BooleanType>
Source§impl Debug for ChunkedArray<FixedSizeListType>
Available on crate feature dtype-array
only.
impl Debug for ChunkedArray<FixedSizeListType>
dtype-array
only.Source§impl Debug for ChunkedArray<ListType>
impl Debug for ChunkedArray<ListType>
Source§impl<T> Debug for ChunkedArray<ObjectType<T>>where
T: PolarsObject,
Available on crate feature object
only.
impl<T> Debug for ChunkedArray<ObjectType<T>>where
T: PolarsObject,
object
only.Source§impl Debug for ChunkedArray<StringType>
impl Debug for ChunkedArray<StringType>
Source§impl<T> Debug for ChunkedArray<T>where
T: PolarsNumericType,
impl<T> Debug for ChunkedArray<T>where
T: PolarsNumericType,
Source§impl<T> Default for ChunkedArray<T>where
T: PolarsDataType,
impl<T> Default for ChunkedArray<T>where
T: PolarsDataType,
Source§fn default() -> ChunkedArray<T>
fn default() -> ChunkedArray<T>
Source§impl<T, N> Div<N> for &ChunkedArray<T>
impl<T, N> Div<N> for &ChunkedArray<T>
Source§impl<T, N> Div<N> for ChunkedArray<T>
impl<T, N> Div<N> for ChunkedArray<T>
Source§impl<T> Div for &ChunkedArray<T>where
T: PolarsNumericType,
impl<T> Div for &ChunkedArray<T>where
T: PolarsNumericType,
Source§type Output = ChunkedArray<T>
type Output = ChunkedArray<T>
/
operator.Source§fn div(self, rhs: &ChunkedArray<T>) -> <&ChunkedArray<T> as Div>::Output
fn div(self, rhs: &ChunkedArray<T>) -> <&ChunkedArray<T> as Div>::Output
/
operation. Read moreSource§impl<T> Div for ChunkedArray<T>where
T: PolarsNumericType,
impl<T> Div for ChunkedArray<T>where
T: PolarsNumericType,
Source§type Output = ChunkedArray<T>
type Output = ChunkedArray<T>
/
operator.Source§fn div(self, rhs: ChunkedArray<T>) -> <ChunkedArray<T> as Div>::Output
fn div(self, rhs: ChunkedArray<T>) -> <ChunkedArray<T> as Div>::Output
/
operation. Read moreSource§impl<T> Drop for ChunkedArray<T>where
T: PolarsDataType,
impl<T> Drop for ChunkedArray<T>where
T: PolarsDataType,
Source§impl<'a, T> From<&'a ChunkedArray<T>> for Vec<Option<<T as PolarsDataType>::Physical<'a>>>where
T: PolarsDataType,
impl<'a, T> From<&'a ChunkedArray<T>> for Vec<Option<<T as PolarsDataType>::Physical<'a>>>where
T: PolarsDataType,
Source§fn from(
ca: &'a ChunkedArray<T>,
) -> Vec<Option<<T as PolarsDataType>::Physical<'a>>>
fn from( ca: &'a ChunkedArray<T>, ) -> Vec<Option<<T as PolarsDataType>::Physical<'a>>>
Source§impl<T, A> From<A> for ChunkedArray<T>where
T: PolarsDataType<Array = A>,
A: Array,
impl<T, A> From<A> for ChunkedArray<T>where
T: PolarsDataType<Array = A>,
A: Array,
Source§fn from(arr: A) -> ChunkedArray<T>
fn from(arr: A) -> ChunkedArray<T>
Source§impl From<ChunkedArray<BooleanType>> for Vec<Option<bool>>
impl From<ChunkedArray<BooleanType>> for Vec<Option<bool>>
Source§fn from(ca: ChunkedArray<BooleanType>) -> Vec<Option<bool>>
fn from(ca: ChunkedArray<BooleanType>) -> Vec<Option<bool>>
Source§impl From<ChunkedArray<StringType>> for Vec<Option<String>>
impl From<ChunkedArray<StringType>> for Vec<Option<String>>
Source§fn from(ca: ChunkedArray<StringType>) -> Vec<Option<String>>
fn from(ca: ChunkedArray<StringType>) -> Vec<Option<String>>
Source§impl<T> From<ChunkedArray<T>> for Series
impl<T> From<ChunkedArray<T>> for Series
Source§fn from(ca: ChunkedArray<T>) -> Series
fn from(ca: ChunkedArray<T>) -> Series
Source§impl<T> FromIterator<(Vec<<T as PolarsNumericType>::Native>, Option<Bitmap>)> for ChunkedArray<T>where
T: PolarsNumericType,
impl<T> FromIterator<(Vec<<T as PolarsNumericType>::Native>, Option<Bitmap>)> for ChunkedArray<T>where
T: PolarsNumericType,
Source§fn from_iter<I>(iter: I) -> ChunkedArray<T>
fn from_iter<I>(iter: I) -> ChunkedArray<T>
Source§impl<T> FromIterator<Option<<T as PolarsNumericType>::Native>> for ChunkedArray<T>where
T: PolarsNumericType,
impl<T> FromIterator<Option<<T as PolarsNumericType>::Native>> for ChunkedArray<T>where
T: PolarsNumericType,
FromIterator trait
Source§fn from_iter<I>(iter: I) -> ChunkedArray<T>
fn from_iter<I>(iter: I) -> ChunkedArray<T>
Source§impl FromIterator<Option<Box<dyn Array>>> for ChunkedArray<ListType>
impl FromIterator<Option<Box<dyn Array>>> for ChunkedArray<ListType>
Source§impl FromIterator<Option<Column>> for ChunkedArray<ListType>
impl FromIterator<Option<Column>> for ChunkedArray<ListType>
Source§impl<Ptr> FromIterator<Option<Ptr>> for ChunkedArray<BinaryType>
impl<Ptr> FromIterator<Option<Ptr>> for ChunkedArray<BinaryType>
Source§fn from_iter<I>(iter: I) -> ChunkedArray<BinaryType>where
I: IntoIterator<Item = Option<Ptr>>,
fn from_iter<I>(iter: I) -> ChunkedArray<BinaryType>where
I: IntoIterator<Item = Option<Ptr>>,
Source§impl<Ptr> FromIterator<Option<Ptr>> for ChunkedArray<StringType>
impl<Ptr> FromIterator<Option<Ptr>> for ChunkedArray<StringType>
Source§fn from_iter<I>(iter: I) -> ChunkedArray<StringType>where
I: IntoIterator<Item = Option<Ptr>>,
fn from_iter<I>(iter: I) -> ChunkedArray<StringType>where
I: IntoIterator<Item = Option<Ptr>>,
Source§impl FromIterator<Option<Series>> for ChunkedArray<ListType>
impl FromIterator<Option<Series>> for ChunkedArray<ListType>
Source§impl<T> FromIterator<Option<T>> for ChunkedArray<ObjectType<T>>where
T: PolarsObject,
Available on crate feature object
only.
impl<T> FromIterator<Option<T>> for ChunkedArray<ObjectType<T>>where
T: PolarsObject,
object
only.Source§fn from_iter<I>(iter: I) -> ChunkedArray<ObjectType<T>>where
I: IntoIterator<Item = Option<T>>,
fn from_iter<I>(iter: I) -> ChunkedArray<ObjectType<T>>where
I: IntoIterator<Item = Option<T>>,
Source§impl FromIterator<Option<bool>> for ChunkedArray<BooleanType>
impl FromIterator<Option<bool>> for ChunkedArray<BooleanType>
Source§fn from_iter<I>(iter: I) -> ChunkedArray<BooleanType>
fn from_iter<I>(iter: I) -> ChunkedArray<BooleanType>
Source§impl<Ptr> FromIterator<Ptr> for ChunkedArray<BinaryType>where
Ptr: PolarsAsRef<[u8]>,
impl<Ptr> FromIterator<Ptr> for ChunkedArray<BinaryType>where
Ptr: PolarsAsRef<[u8]>,
Source§fn from_iter<I>(iter: I) -> ChunkedArray<BinaryType>where
I: IntoIterator<Item = Ptr>,
fn from_iter<I>(iter: I) -> ChunkedArray<BinaryType>where
I: IntoIterator<Item = Ptr>,
Source§impl<Ptr> FromIterator<Ptr> for ChunkedArray<ListType>
impl<Ptr> FromIterator<Ptr> for ChunkedArray<ListType>
Source§fn from_iter<I>(iter: I) -> ChunkedArray<ListType>where
I: IntoIterator<Item = Ptr>,
fn from_iter<I>(iter: I) -> ChunkedArray<ListType>where
I: IntoIterator<Item = Ptr>,
Source§impl<Ptr> FromIterator<Ptr> for ChunkedArray<StringType>where
Ptr: PolarsAsRef<str>,
impl<Ptr> FromIterator<Ptr> for ChunkedArray<StringType>where
Ptr: PolarsAsRef<str>,
Source§fn from_iter<I>(iter: I) -> ChunkedArray<StringType>where
I: IntoIterator<Item = Ptr>,
fn from_iter<I>(iter: I) -> ChunkedArray<StringType>where
I: IntoIterator<Item = Ptr>,
Source§impl FromIterator<bool> for ChunkedArray<BooleanType>
impl FromIterator<bool> for ChunkedArray<BooleanType>
Source§fn from_iter<I>(iter: I) -> ChunkedArray<BooleanType>where
I: IntoIterator<Item = bool>,
fn from_iter<I>(iter: I) -> ChunkedArray<BooleanType>where
I: IntoIterator<Item = bool>,
Source§impl<T> FromIteratorReversed<Option<<T as PolarsNumericType>::Native>> for ChunkedArray<T>where
T: PolarsNumericType,
impl<T> FromIteratorReversed<Option<<T as PolarsNumericType>::Native>> for ChunkedArray<T>where
T: PolarsNumericType,
fn from_trusted_len_iter_rev<I>(iter: I) -> ChunkedArray<T>
Source§impl FromIteratorReversed<Option<bool>> for ChunkedArray<BooleanType>
impl FromIteratorReversed<Option<bool>> for ChunkedArray<BooleanType>
fn from_trusted_len_iter_rev<I>(iter: I) -> ChunkedArray<BooleanType>
Source§impl FromParIterWithDtype<Option<Series>> for ChunkedArray<ListType>
impl FromParIterWithDtype<Option<Series>> for ChunkedArray<ListType>
fn from_par_iter_with_dtype<I>( iter: I, name: PlSmallStr, dtype: DataType, ) -> ChunkedArray<ListType>
Source§impl<T> FromParallelIterator<Option<<T as PolarsNumericType>::Native>> for ChunkedArray<T>where
T: PolarsNumericType,
impl<T> FromParallelIterator<Option<<T as PolarsNumericType>::Native>> for ChunkedArray<T>where
T: PolarsNumericType,
Source§fn from_par_iter<I>(iter: I) -> ChunkedArray<T>
fn from_par_iter<I>(iter: I) -> ChunkedArray<T>
par_iter
. Read moreSource§impl<Ptr> FromParallelIterator<Option<Ptr>> for ChunkedArray<BinaryType>
impl<Ptr> FromParallelIterator<Option<Ptr>> for ChunkedArray<BinaryType>
Source§fn from_par_iter<I>(iter: I) -> ChunkedArray<BinaryType>where
I: IntoParallelIterator<Item = Option<Ptr>>,
fn from_par_iter<I>(iter: I) -> ChunkedArray<BinaryType>where
I: IntoParallelIterator<Item = Option<Ptr>>,
par_iter
. Read moreSource§impl<Ptr> FromParallelIterator<Option<Ptr>> for ChunkedArray<StringType>
impl<Ptr> FromParallelIterator<Option<Ptr>> for ChunkedArray<StringType>
Source§fn from_par_iter<I>(iter: I) -> ChunkedArray<StringType>where
I: IntoParallelIterator<Item = Option<Ptr>>,
fn from_par_iter<I>(iter: I) -> ChunkedArray<StringType>where
I: IntoParallelIterator<Item = Option<Ptr>>,
par_iter
. Read moreSource§impl FromParallelIterator<Option<Series>> for ChunkedArray<ListType>
impl FromParallelIterator<Option<Series>> for ChunkedArray<ListType>
Source§fn from_par_iter<I>(par_iter: I) -> ChunkedArray<ListType>
fn from_par_iter<I>(par_iter: I) -> ChunkedArray<ListType>
par_iter
. Read moreSource§impl FromParallelIterator<Option<bool>> for ChunkedArray<BooleanType>
impl FromParallelIterator<Option<bool>> for ChunkedArray<BooleanType>
Source§fn from_par_iter<I>(iter: I) -> ChunkedArray<BooleanType>
fn from_par_iter<I>(iter: I) -> ChunkedArray<BooleanType>
par_iter
. Read moreSource§impl<Ptr> FromParallelIterator<Ptr> for ChunkedArray<BinaryType>
impl<Ptr> FromParallelIterator<Ptr> for ChunkedArray<BinaryType>
Source§fn from_par_iter<I>(iter: I) -> ChunkedArray<BinaryType>where
I: IntoParallelIterator<Item = Ptr>,
fn from_par_iter<I>(iter: I) -> ChunkedArray<BinaryType>where
I: IntoParallelIterator<Item = Ptr>,
par_iter
. Read moreSource§impl<Ptr> FromParallelIterator<Ptr> for ChunkedArray<StringType>
impl<Ptr> FromParallelIterator<Ptr> for ChunkedArray<StringType>
Source§fn from_par_iter<I>(iter: I) -> ChunkedArray<StringType>where
I: IntoParallelIterator<Item = Ptr>,
fn from_par_iter<I>(iter: I) -> ChunkedArray<StringType>where
I: IntoParallelIterator<Item = Ptr>,
par_iter
. Read moreSource§impl FromParallelIterator<bool> for ChunkedArray<BooleanType>
impl FromParallelIterator<bool> for ChunkedArray<BooleanType>
Source§fn from_par_iter<I>(iter: I) -> ChunkedArray<BooleanType>where
I: IntoParallelIterator<Item = bool>,
fn from_par_iter<I>(iter: I) -> ChunkedArray<BooleanType>where
I: IntoParallelIterator<Item = bool>,
par_iter
. Read moreSource§impl<T> FromTrustedLenIterator<Option<<T as PolarsNumericType>::Native>> for ChunkedArray<T>where
T: PolarsNumericType,
impl<T> FromTrustedLenIterator<Option<<T as PolarsNumericType>::Native>> for ChunkedArray<T>where
T: PolarsNumericType,
fn from_iter_trusted_length<I>(iter: I) -> ChunkedArray<T>where
I: IntoIterator<Item = Option<<T as PolarsNumericType>::Native>>,
<I as IntoIterator>::IntoIter: TrustedLen,
Source§impl<Ptr> FromTrustedLenIterator<Option<Ptr>> for ChunkedArray<BinaryOffsetType>
impl<Ptr> FromTrustedLenIterator<Option<Ptr>> for ChunkedArray<BinaryOffsetType>
fn from_iter_trusted_length<I>(iter: I) -> ChunkedArray<BinaryOffsetType>where
I: IntoIterator<Item = Option<Ptr>>,
Source§impl<Ptr> FromTrustedLenIterator<Option<Ptr>> for ChunkedArray<BinaryType>
impl<Ptr> FromTrustedLenIterator<Option<Ptr>> for ChunkedArray<BinaryType>
fn from_iter_trusted_length<I>(iter: I) -> ChunkedArray<BinaryType>where
I: IntoIterator<Item = Option<Ptr>>,
Source§impl<Ptr> FromTrustedLenIterator<Option<Ptr>> for ChunkedArray<StringType>
impl<Ptr> FromTrustedLenIterator<Option<Ptr>> for ChunkedArray<StringType>
fn from_iter_trusted_length<I>(iter: I) -> ChunkedArray<StringType>where
I: IntoIterator<Item = Option<Ptr>>,
Source§impl FromTrustedLenIterator<Option<Series>> for ChunkedArray<ListType>
impl FromTrustedLenIterator<Option<Series>> for ChunkedArray<ListType>
fn from_iter_trusted_length<I>(iter: I) -> ChunkedArray<ListType>
Source§impl<T> FromTrustedLenIterator<Option<T>> for ChunkedArray<ObjectType<T>>where
T: PolarsObject,
Available on crate feature object
only.
impl<T> FromTrustedLenIterator<Option<T>> for ChunkedArray<ObjectType<T>>where
T: PolarsObject,
object
only.fn from_iter_trusted_length<I>(iter: I) -> ChunkedArray<ObjectType<T>>where
I: IntoIterator<Item = Option<T>>,
Source§impl FromTrustedLenIterator<Option<bool>> for ChunkedArray<BooleanType>
impl FromTrustedLenIterator<Option<bool>> for ChunkedArray<BooleanType>
fn from_iter_trusted_length<I>(iter: I) -> ChunkedArray<BooleanType>
Source§impl<Ptr> FromTrustedLenIterator<Ptr> for ChunkedArray<BinaryOffsetType>where
Ptr: PolarsAsRef<[u8]>,
impl<Ptr> FromTrustedLenIterator<Ptr> for ChunkedArray<BinaryOffsetType>where
Ptr: PolarsAsRef<[u8]>,
fn from_iter_trusted_length<I>(iter: I) -> ChunkedArray<BinaryOffsetType>where
I: IntoIterator<Item = Ptr>,
Source§impl<Ptr> FromTrustedLenIterator<Ptr> for ChunkedArray<BinaryType>where
Ptr: PolarsAsRef<[u8]>,
impl<Ptr> FromTrustedLenIterator<Ptr> for ChunkedArray<BinaryType>where
Ptr: PolarsAsRef<[u8]>,
fn from_iter_trusted_length<I>(iter: I) -> ChunkedArray<BinaryType>where
I: IntoIterator<Item = Ptr>,
Source§impl<Ptr> FromTrustedLenIterator<Ptr> for ChunkedArray<ListType>
impl<Ptr> FromTrustedLenIterator<Ptr> for ChunkedArray<ListType>
fn from_iter_trusted_length<I>(iter: I) -> ChunkedArray<ListType>where
I: IntoIterator<Item = Ptr>,
Source§impl<Ptr> FromTrustedLenIterator<Ptr> for ChunkedArray<StringType>where
Ptr: PolarsAsRef<str>,
impl<Ptr> FromTrustedLenIterator<Ptr> for ChunkedArray<StringType>where
Ptr: PolarsAsRef<str>,
fn from_iter_trusted_length<I>(iter: I) -> ChunkedArray<StringType>where
I: IntoIterator<Item = Ptr>,
Source§impl FromTrustedLenIterator<bool> for ChunkedArray<BooleanType>
impl FromTrustedLenIterator<bool> for ChunkedArray<BooleanType>
fn from_iter_trusted_length<I>(iter: I) -> ChunkedArray<BooleanType>
Source§impl IntoGroupsProxy for ChunkedArray<BinaryOffsetType>
impl IntoGroupsProxy for ChunkedArray<BinaryOffsetType>
Source§fn group_tuples<'a>(
&'a self,
multithreaded: bool,
sorted: bool,
) -> Result<GroupsProxy, PolarsError>
fn group_tuples<'a>( &'a self, multithreaded: bool, sorted: bool, ) -> Result<GroupsProxy, PolarsError>
Source§impl IntoGroupsProxy for ChunkedArray<BinaryType>
impl IntoGroupsProxy for ChunkedArray<BinaryType>
Source§fn group_tuples<'a>(
&'a self,
multithreaded: bool,
sorted: bool,
) -> Result<GroupsProxy, PolarsError>
fn group_tuples<'a>( &'a self, multithreaded: bool, sorted: bool, ) -> Result<GroupsProxy, PolarsError>
Source§impl IntoGroupsProxy for ChunkedArray<BooleanType>
impl IntoGroupsProxy for ChunkedArray<BooleanType>
Source§fn group_tuples(
&self,
multithreaded: bool,
sorted: bool,
) -> Result<GroupsProxy, PolarsError>
fn group_tuples( &self, multithreaded: bool, sorted: bool, ) -> Result<GroupsProxy, PolarsError>
Source§impl IntoGroupsProxy for ChunkedArray<FixedSizeListType>
Available on crate feature dtype-array
only.
impl IntoGroupsProxy for ChunkedArray<FixedSizeListType>
dtype-array
only.Source§fn group_tuples<'a>(
&'a self,
_multithreaded: bool,
_sorted: bool,
) -> Result<GroupsProxy, PolarsError>
fn group_tuples<'a>( &'a self, _multithreaded: bool, _sorted: bool, ) -> Result<GroupsProxy, PolarsError>
Source§impl IntoGroupsProxy for ChunkedArray<ListType>
impl IntoGroupsProxy for ChunkedArray<ListType>
Source§fn group_tuples<'a>(
&'a self,
multithreaded: bool,
sorted: bool,
) -> Result<GroupsProxy, PolarsError>
fn group_tuples<'a>( &'a self, multithreaded: bool, sorted: bool, ) -> Result<GroupsProxy, PolarsError>
Source§impl<T> IntoGroupsProxy for ChunkedArray<ObjectType<T>>where
T: PolarsObject,
Available on crate feature object
only.
impl<T> IntoGroupsProxy for ChunkedArray<ObjectType<T>>where
T: PolarsObject,
object
only.Source§fn group_tuples(
&self,
_multithreaded: bool,
sorted: bool,
) -> Result<GroupsProxy, PolarsError>
fn group_tuples( &self, _multithreaded: bool, sorted: bool, ) -> Result<GroupsProxy, PolarsError>
Source§impl IntoGroupsProxy for ChunkedArray<StringType>
impl IntoGroupsProxy for ChunkedArray<StringType>
Source§fn group_tuples<'a>(
&'a self,
multithreaded: bool,
sorted: bool,
) -> Result<GroupsProxy, PolarsError>
fn group_tuples<'a>( &'a self, multithreaded: bool, sorted: bool, ) -> Result<GroupsProxy, PolarsError>
Source§impl<T> IntoGroupsProxy for ChunkedArray<T>
impl<T> IntoGroupsProxy for ChunkedArray<T>
Source§fn group_tuples(
&self,
multithreaded: bool,
sorted: bool,
) -> Result<GroupsProxy, PolarsError>
fn group_tuples( &self, multithreaded: bool, sorted: bool, ) -> Result<GroupsProxy, PolarsError>
Source§impl<'a> IntoIterator for &'a ChunkedArray<BinaryOffsetType>
impl<'a> IntoIterator for &'a ChunkedArray<BinaryOffsetType>
Source§type IntoIter = Box<dyn PolarsIterator<Item = <&'a ChunkedArray<BinaryOffsetType> as IntoIterator>::Item> + 'a>
type IntoIter = Box<dyn PolarsIterator<Item = <&'a ChunkedArray<BinaryOffsetType> as IntoIterator>::Item> + 'a>
Source§fn into_iter(
self,
) -> <&'a ChunkedArray<BinaryOffsetType> as IntoIterator>::IntoIter
fn into_iter( self, ) -> <&'a ChunkedArray<BinaryOffsetType> as IntoIterator>::IntoIter
Source§impl<'a> IntoIterator for &'a ChunkedArray<BinaryType>
impl<'a> IntoIterator for &'a ChunkedArray<BinaryType>
Source§type IntoIter = Box<dyn PolarsIterator<Item = <&'a ChunkedArray<BinaryType> as IntoIterator>::Item> + 'a>
type IntoIter = Box<dyn PolarsIterator<Item = <&'a ChunkedArray<BinaryType> as IntoIterator>::Item> + 'a>
Source§fn into_iter(self) -> <&'a ChunkedArray<BinaryType> as IntoIterator>::IntoIter
fn into_iter(self) -> <&'a ChunkedArray<BinaryType> as IntoIterator>::IntoIter
Source§impl<'a> IntoIterator for &'a ChunkedArray<BooleanType>
impl<'a> IntoIterator for &'a ChunkedArray<BooleanType>
Source§type IntoIter = Box<dyn PolarsIterator<Item = <&'a ChunkedArray<BooleanType> as IntoIterator>::Item> + 'a>
type IntoIter = Box<dyn PolarsIterator<Item = <&'a ChunkedArray<BooleanType> as IntoIterator>::Item> + 'a>
Source§fn into_iter(self) -> <&'a ChunkedArray<BooleanType> as IntoIterator>::IntoIter
fn into_iter(self) -> <&'a ChunkedArray<BooleanType> as IntoIterator>::IntoIter
Source§impl<'a> IntoIterator for &'a ChunkedArray<FixedSizeListType>
Available on crate feature dtype-array
only.
impl<'a> IntoIterator for &'a ChunkedArray<FixedSizeListType>
dtype-array
only.Source§type IntoIter = Box<dyn PolarsIterator<Item = <&'a ChunkedArray<FixedSizeListType> as IntoIterator>::Item> + 'a>
type IntoIter = Box<dyn PolarsIterator<Item = <&'a ChunkedArray<FixedSizeListType> as IntoIterator>::Item> + 'a>
Source§fn into_iter(
self,
) -> <&'a ChunkedArray<FixedSizeListType> as IntoIterator>::IntoIter
fn into_iter( self, ) -> <&'a ChunkedArray<FixedSizeListType> as IntoIterator>::IntoIter
Source§impl<'a> IntoIterator for &'a ChunkedArray<ListType>
impl<'a> IntoIterator for &'a ChunkedArray<ListType>
Source§type IntoIter = Box<dyn PolarsIterator<Item = <&'a ChunkedArray<ListType> as IntoIterator>::Item> + 'a>
type IntoIter = Box<dyn PolarsIterator<Item = <&'a ChunkedArray<ListType> as IntoIterator>::Item> + 'a>
Source§fn into_iter(self) -> <&'a ChunkedArray<ListType> as IntoIterator>::IntoIter
fn into_iter(self) -> <&'a ChunkedArray<ListType> as IntoIterator>::IntoIter
Source§impl<'a, T> IntoIterator for &'a ChunkedArray<ObjectType<T>>where
T: PolarsObject,
Available on crate feature object
only.
impl<'a, T> IntoIterator for &'a ChunkedArray<ObjectType<T>>where
T: PolarsObject,
object
only.Source§type IntoIter = Box<dyn PolarsIterator<Item = <&'a ChunkedArray<ObjectType<T>> as IntoIterator>::Item> + 'a>
type IntoIter = Box<dyn PolarsIterator<Item = <&'a ChunkedArray<ObjectType<T>> as IntoIterator>::Item> + 'a>
Source§fn into_iter(
self,
) -> <&'a ChunkedArray<ObjectType<T>> as IntoIterator>::IntoIter
fn into_iter( self, ) -> <&'a ChunkedArray<ObjectType<T>> as IntoIterator>::IntoIter
Source§impl<'a> IntoIterator for &'a ChunkedArray<StringType>
impl<'a> IntoIterator for &'a ChunkedArray<StringType>
Source§type IntoIter = Box<dyn PolarsIterator<Item = <&'a ChunkedArray<StringType> as IntoIterator>::Item> + 'a>
type IntoIter = Box<dyn PolarsIterator<Item = <&'a ChunkedArray<StringType> as IntoIterator>::Item> + 'a>
Source§fn into_iter(self) -> <&'a ChunkedArray<StringType> as IntoIterator>::IntoIter
fn into_iter(self) -> <&'a ChunkedArray<StringType> as IntoIterator>::IntoIter
Source§impl<'a, T> IntoIterator for &'a ChunkedArray<T>where
T: PolarsNumericType,
impl<'a, T> IntoIterator for &'a ChunkedArray<T>where
T: PolarsNumericType,
Source§type Item = Option<<T as PolarsNumericType>::Native>
type Item = Option<<T as PolarsNumericType>::Native>
Source§type IntoIter = Box<dyn PolarsIterator<Item = <&'a ChunkedArray<T> as IntoIterator>::Item> + 'a>
type IntoIter = Box<dyn PolarsIterator<Item = <&'a ChunkedArray<T> as IntoIterator>::Item> + 'a>
Source§fn into_iter(self) -> <&'a ChunkedArray<T> as IntoIterator>::IntoIter
fn into_iter(self) -> <&'a ChunkedArray<T> as IntoIterator>::IntoIter
Source§impl IntoSeries for ChunkedArray<Int128Type>
impl IntoSeries for ChunkedArray<Int128Type>
Source§impl<T> IntoSeries for ChunkedArray<T>
impl<T> IntoSeries for ChunkedArray<T>
fn into_series(self) -> Serieswhere
ChunkedArray<T>: Sized,
fn is_series() -> bool
Source§impl ListNameSpaceImpl for ChunkedArray<ListType>
impl ListNameSpaceImpl for ChunkedArray<ListType>
Source§fn lst_join(
&self,
separator: &ChunkedArray<StringType>,
ignore_nulls: bool,
) -> Result<ChunkedArray<StringType>, PolarsError>
fn lst_join( &self, separator: &ChunkedArray<StringType>, ignore_nulls: bool, ) -> Result<ChunkedArray<StringType>, PolarsError>
DataType::String
, the individual items will be joined into a
single string separated by separator
.fn join_literal( &self, separator: &str, ignore_nulls: bool, ) -> Result<ChunkedArray<StringType>, PolarsError>
fn join_many( &self, separator: &ChunkedArray<StringType>, ignore_nulls: bool, ) -> Result<ChunkedArray<StringType>, PolarsError>
fn lst_max(&self) -> Result<Series, PolarsError>
fn lst_min(&self) -> Result<Series, PolarsError>
fn lst_sum(&self) -> Result<Series, PolarsError>
fn lst_mean(&self) -> Series
fn lst_median(&self) -> Series
fn lst_std(&self, ddof: u8) -> Series
fn lst_var(&self, ddof: u8) -> Series
fn same_type(&self, out: ChunkedArray<ListType>) -> ChunkedArray<ListType>
fn lst_sort( &self, options: SortOptions, ) -> Result<ChunkedArray<ListType>, PolarsError>
fn lst_reverse(&self) -> ChunkedArray<ListType>
fn lst_n_unique(&self) -> Result<ChunkedArray<UInt32Type>, PolarsError>
fn lst_unique(&self) -> Result<ChunkedArray<ListType>, PolarsError>
fn lst_unique_stable(&self) -> Result<ChunkedArray<ListType>, PolarsError>
fn lst_arg_min(&self) -> ChunkedArray<UInt32Type>
fn lst_arg_max(&self) -> ChunkedArray<UInt32Type>
Source§fn lst_diff(
&self,
n: i64,
null_behavior: NullBehavior,
) -> Result<ChunkedArray<ListType>, PolarsError>
fn lst_diff( &self, n: i64, null_behavior: NullBehavior, ) -> Result<ChunkedArray<ListType>, PolarsError>
diff
only.fn lst_shift( &self, periods: &Column, ) -> Result<ChunkedArray<ListType>, PolarsError>
fn lst_slice(&self, offset: i64, length: usize) -> ChunkedArray<ListType>
fn lst_lengths(&self) -> ChunkedArray<UInt32Type>
Source§fn lst_get(&self, idx: i64, null_on_oob: bool) -> Result<Series, PolarsError>
fn lst_get(&self, idx: i64, null_on_oob: bool) -> Result<Series, PolarsError>
0
would return the first item of every sublist
and index -1
would return the last item of every sublist
if an index is out of bounds, it will return a None
.fn lst_concat( &self, other: &[Column], ) -> Result<ChunkedArray<ListType>, PolarsError>
Source§impl<T> MetadataCollectable<T> for ChunkedArray<T>where
T: PolarsDataType + PolarsNumericType,
ChunkedArray<T>: ChunkAgg<<T as PolarsNumericType>::Native>,
impl<T> MetadataCollectable<T> for ChunkedArray<T>where
T: PolarsDataType + PolarsNumericType,
ChunkedArray<T>: ChunkAgg<<T as PolarsNumericType>::Native>,
fn collect_cheap_metadata(&mut self)
fn with_cheap_metadata(self) -> Self
Source§impl<T, N> Mul<N> for &ChunkedArray<T>
impl<T, N> Mul<N> for &ChunkedArray<T>
Source§impl<T, N> Mul<N> for ChunkedArray<T>
impl<T, N> Mul<N> for ChunkedArray<T>
Source§impl<T> Mul for &ChunkedArray<T>where
T: PolarsNumericType,
impl<T> Mul for &ChunkedArray<T>where
T: PolarsNumericType,
Source§type Output = ChunkedArray<T>
type Output = ChunkedArray<T>
*
operator.Source§fn mul(self, rhs: &ChunkedArray<T>) -> <&ChunkedArray<T> as Mul>::Output
fn mul(self, rhs: &ChunkedArray<T>) -> <&ChunkedArray<T> as Mul>::Output
*
operation. Read moreSource§impl<T> Mul for ChunkedArray<T>where
T: PolarsNumericType,
impl<T> Mul for ChunkedArray<T>where
T: PolarsNumericType,
Source§type Output = ChunkedArray<T>
type Output = ChunkedArray<T>
*
operator.Source§fn mul(self, rhs: ChunkedArray<T>) -> <ChunkedArray<T> as Mul>::Output
fn mul(self, rhs: ChunkedArray<T>) -> <ChunkedArray<T> as Mul>::Output
*
operation. Read moreSource§impl<T> NamedFrom<&[T], &[T]> for ChunkedArray<ObjectType<T>>where
T: PolarsObject,
Available on crate feature object
only.
impl<T> NamedFrom<&[T], &[T]> for ChunkedArray<ObjectType<T>>where
T: PolarsObject,
object
only.Source§fn new(name: PlSmallStr, v: &[T]) -> ChunkedArray<ObjectType<T>>
fn new(name: PlSmallStr, v: &[T]) -> ChunkedArray<ObjectType<T>>
Source§impl NamedFrom<Range<i32>, Int32Type> for ChunkedArray<Int32Type>
impl NamedFrom<Range<i32>, Int32Type> for ChunkedArray<Int32Type>
Source§fn new(name: PlSmallStr, range: Range<i32>) -> ChunkedArray<Int32Type>
fn new(name: PlSmallStr, range: Range<i32>) -> ChunkedArray<Int32Type>
Source§impl NamedFrom<Range<i64>, Int64Type> for ChunkedArray<Int64Type>
impl NamedFrom<Range<i64>, Int64Type> for ChunkedArray<Int64Type>
Source§fn new(name: PlSmallStr, range: Range<i64>) -> ChunkedArray<Int64Type>
fn new(name: PlSmallStr, range: Range<i64>) -> ChunkedArray<Int64Type>
Source§impl NamedFrom<Range<u32>, UInt32Type> for ChunkedArray<UInt32Type>
impl NamedFrom<Range<u32>, UInt32Type> for ChunkedArray<UInt32Type>
Source§fn new(name: PlSmallStr, range: Range<u32>) -> ChunkedArray<UInt32Type>
fn new(name: PlSmallStr, range: Range<u32>) -> ChunkedArray<UInt32Type>
Source§impl NamedFrom<Range<u64>, UInt64Type> for ChunkedArray<UInt64Type>
impl NamedFrom<Range<u64>, UInt64Type> for ChunkedArray<UInt64Type>
Source§fn new(name: PlSmallStr, range: Range<u64>) -> ChunkedArray<UInt64Type>
fn new(name: PlSmallStr, range: Range<u64>) -> ChunkedArray<UInt64Type>
Source§impl<T, S> NamedFrom<S, [Option<T>]> for ChunkedArray<ObjectType<T>>
Available on crate feature object
only.
impl<T, S> NamedFrom<S, [Option<T>]> for ChunkedArray<ObjectType<T>>
object
only.Source§fn new(name: PlSmallStr, v: S) -> ChunkedArray<ObjectType<T>>
fn new(name: PlSmallStr, v: S) -> ChunkedArray<ObjectType<T>>
Source§impl<'a, T> NamedFrom<T, [&'a [u8]]> for ChunkedArray<BinaryType>
impl<'a, T> NamedFrom<T, [&'a [u8]]> for ChunkedArray<BinaryType>
Source§fn new(name: PlSmallStr, v: T) -> ChunkedArray<BinaryType>
fn new(name: PlSmallStr, v: T) -> ChunkedArray<BinaryType>
Source§impl<'a, T> NamedFrom<T, [&'a str]> for ChunkedArray<StringType>
impl<'a, T> NamedFrom<T, [&'a str]> for ChunkedArray<StringType>
Source§fn new(name: PlSmallStr, v: T) -> ChunkedArray<StringType>
fn new(name: PlSmallStr, v: T) -> ChunkedArray<StringType>
Source§impl<'a, T> NamedFrom<T, [Cow<'a, [u8]>]> for ChunkedArray<BinaryType>
impl<'a, T> NamedFrom<T, [Cow<'a, [u8]>]> for ChunkedArray<BinaryType>
Source§fn new(name: PlSmallStr, v: T) -> ChunkedArray<BinaryType>
fn new(name: PlSmallStr, v: T) -> ChunkedArray<BinaryType>
Source§impl<'a, T> NamedFrom<T, [Cow<'a, str>]> for ChunkedArray<StringType>
impl<'a, T> NamedFrom<T, [Cow<'a, str>]> for ChunkedArray<StringType>
Source§fn new(name: PlSmallStr, v: T) -> ChunkedArray<StringType>
fn new(name: PlSmallStr, v: T) -> ChunkedArray<StringType>
Source§impl<'a, T> NamedFrom<T, [Option<&'a [u8]>]> for ChunkedArray<BinaryType>
impl<'a, T> NamedFrom<T, [Option<&'a [u8]>]> for ChunkedArray<BinaryType>
Source§fn new(name: PlSmallStr, v: T) -> ChunkedArray<BinaryType>
fn new(name: PlSmallStr, v: T) -> ChunkedArray<BinaryType>
Source§impl<'a, T> NamedFrom<T, [Option<&'a str>]> for ChunkedArray<StringType>
impl<'a, T> NamedFrom<T, [Option<&'a str>]> for ChunkedArray<StringType>
Source§fn new(name: PlSmallStr, v: T) -> ChunkedArray<StringType>
fn new(name: PlSmallStr, v: T) -> ChunkedArray<StringType>
Source§impl<'a, T> NamedFrom<T, [Option<Cow<'a, [u8]>>]> for ChunkedArray<BinaryType>
impl<'a, T> NamedFrom<T, [Option<Cow<'a, [u8]>>]> for ChunkedArray<BinaryType>
Source§fn new(name: PlSmallStr, v: T) -> ChunkedArray<BinaryType>
fn new(name: PlSmallStr, v: T) -> ChunkedArray<BinaryType>
Source§impl<'a, T> NamedFrom<T, [Option<Cow<'a, str>>]> for ChunkedArray<StringType>
impl<'a, T> NamedFrom<T, [Option<Cow<'a, str>>]> for ChunkedArray<StringType>
Source§fn new(name: PlSmallStr, v: T) -> ChunkedArray<StringType>
fn new(name: PlSmallStr, v: T) -> ChunkedArray<StringType>
Source§impl<T> NamedFrom<T, [Option<String>]> for ChunkedArray<StringType>
impl<T> NamedFrom<T, [Option<String>]> for ChunkedArray<StringType>
Source§fn new(name: PlSmallStr, v: T) -> ChunkedArray<StringType>
fn new(name: PlSmallStr, v: T) -> ChunkedArray<StringType>
Source§impl<T> NamedFrom<T, [Option<Vec<u8>>]> for ChunkedArray<BinaryType>
impl<T> NamedFrom<T, [Option<Vec<u8>>]> for ChunkedArray<BinaryType>
Source§fn new(name: PlSmallStr, v: T) -> ChunkedArray<BinaryType>
fn new(name: PlSmallStr, v: T) -> ChunkedArray<BinaryType>
Source§impl<T> NamedFrom<T, [Option<bool>]> for ChunkedArray<BooleanType>
impl<T> NamedFrom<T, [Option<bool>]> for ChunkedArray<BooleanType>
Source§fn new(name: PlSmallStr, v: T) -> ChunkedArray<BooleanType>
fn new(name: PlSmallStr, v: T) -> ChunkedArray<BooleanType>
Source§impl<T> NamedFrom<T, [Option<f32>]> for ChunkedArray<Float32Type>
impl<T> NamedFrom<T, [Option<f32>]> for ChunkedArray<Float32Type>
Source§fn new(name: PlSmallStr, v: T) -> ChunkedArray<Float32Type>
fn new(name: PlSmallStr, v: T) -> ChunkedArray<Float32Type>
Source§impl<T> NamedFrom<T, [Option<f64>]> for ChunkedArray<Float64Type>
impl<T> NamedFrom<T, [Option<f64>]> for ChunkedArray<Float64Type>
Source§fn new(name: PlSmallStr, v: T) -> ChunkedArray<Float64Type>
fn new(name: PlSmallStr, v: T) -> ChunkedArray<Float64Type>
Source§impl<T> NamedFrom<T, [Option<i128>]> for ChunkedArray<Int128Type>
impl<T> NamedFrom<T, [Option<i128>]> for ChunkedArray<Int128Type>
Source§fn new(name: PlSmallStr, v: T) -> ChunkedArray<Int128Type>
fn new(name: PlSmallStr, v: T) -> ChunkedArray<Int128Type>
Source§impl<T> NamedFrom<T, [Option<i16>]> for ChunkedArray<Int16Type>
impl<T> NamedFrom<T, [Option<i16>]> for ChunkedArray<Int16Type>
Source§fn new(name: PlSmallStr, v: T) -> ChunkedArray<Int16Type>
fn new(name: PlSmallStr, v: T) -> ChunkedArray<Int16Type>
Source§impl<T> NamedFrom<T, [Option<i32>]> for ChunkedArray<Int32Type>
impl<T> NamedFrom<T, [Option<i32>]> for ChunkedArray<Int32Type>
Source§fn new(name: PlSmallStr, v: T) -> ChunkedArray<Int32Type>
fn new(name: PlSmallStr, v: T) -> ChunkedArray<Int32Type>
Source§impl<T> NamedFrom<T, [Option<i64>]> for ChunkedArray<Int64Type>
impl<T> NamedFrom<T, [Option<i64>]> for ChunkedArray<Int64Type>
Source§fn new(name: PlSmallStr, v: T) -> ChunkedArray<Int64Type>
fn new(name: PlSmallStr, v: T) -> ChunkedArray<Int64Type>
Source§impl<T> NamedFrom<T, [Option<i8>]> for ChunkedArray<Int8Type>
impl<T> NamedFrom<T, [Option<i8>]> for ChunkedArray<Int8Type>
Source§fn new(name: PlSmallStr, v: T) -> ChunkedArray<Int8Type>
fn new(name: PlSmallStr, v: T) -> ChunkedArray<Int8Type>
Source§impl<T> NamedFrom<T, [Option<u16>]> for ChunkedArray<UInt16Type>
impl<T> NamedFrom<T, [Option<u16>]> for ChunkedArray<UInt16Type>
Source§fn new(name: PlSmallStr, v: T) -> ChunkedArray<UInt16Type>
fn new(name: PlSmallStr, v: T) -> ChunkedArray<UInt16Type>
Source§impl<T> NamedFrom<T, [Option<u32>]> for ChunkedArray<UInt32Type>
impl<T> NamedFrom<T, [Option<u32>]> for ChunkedArray<UInt32Type>
Source§fn new(name: PlSmallStr, v: T) -> ChunkedArray<UInt32Type>
fn new(name: PlSmallStr, v: T) -> ChunkedArray<UInt32Type>
Source§impl<T> NamedFrom<T, [Option<u64>]> for ChunkedArray<UInt64Type>
impl<T> NamedFrom<T, [Option<u64>]> for ChunkedArray<UInt64Type>
Source§fn new(name: PlSmallStr, v: T) -> ChunkedArray<UInt64Type>
fn new(name: PlSmallStr, v: T) -> ChunkedArray<UInt64Type>
Source§impl<T> NamedFrom<T, [Option<u8>]> for ChunkedArray<UInt8Type>
impl<T> NamedFrom<T, [Option<u8>]> for ChunkedArray<UInt8Type>
Source§fn new(name: PlSmallStr, v: T) -> ChunkedArray<UInt8Type>
fn new(name: PlSmallStr, v: T) -> ChunkedArray<UInt8Type>
Source§impl<T> NamedFrom<T, [String]> for ChunkedArray<StringType>
impl<T> NamedFrom<T, [String]> for ChunkedArray<StringType>
Source§fn new(name: PlSmallStr, v: T) -> ChunkedArray<StringType>
fn new(name: PlSmallStr, v: T) -> ChunkedArray<StringType>
Source§impl<T> NamedFrom<T, [Vec<u8>]> for ChunkedArray<BinaryType>
impl<T> NamedFrom<T, [Vec<u8>]> for ChunkedArray<BinaryType>
Source§fn new(name: PlSmallStr, v: T) -> ChunkedArray<BinaryType>
fn new(name: PlSmallStr, v: T) -> ChunkedArray<BinaryType>
Source§impl<T> NamedFrom<T, [bool]> for ChunkedArray<BooleanType>
impl<T> NamedFrom<T, [bool]> for ChunkedArray<BooleanType>
Source§fn new(name: PlSmallStr, v: T) -> ChunkedArray<BooleanType>
fn new(name: PlSmallStr, v: T) -> ChunkedArray<BooleanType>
Source§impl<T> NamedFrom<T, [f32]> for ChunkedArray<Float32Type>
impl<T> NamedFrom<T, [f32]> for ChunkedArray<Float32Type>
Source§fn new(name: PlSmallStr, v: T) -> ChunkedArray<Float32Type>
fn new(name: PlSmallStr, v: T) -> ChunkedArray<Float32Type>
Source§impl<T> NamedFrom<T, [f64]> for ChunkedArray<Float64Type>
impl<T> NamedFrom<T, [f64]> for ChunkedArray<Float64Type>
Source§fn new(name: PlSmallStr, v: T) -> ChunkedArray<Float64Type>
fn new(name: PlSmallStr, v: T) -> ChunkedArray<Float64Type>
Source§impl<T> NamedFrom<T, [i128]> for ChunkedArray<Int128Type>
impl<T> NamedFrom<T, [i128]> for ChunkedArray<Int128Type>
Source§fn new(name: PlSmallStr, v: T) -> ChunkedArray<Int128Type>
fn new(name: PlSmallStr, v: T) -> ChunkedArray<Int128Type>
Source§impl<T> NamedFrom<T, [i16]> for ChunkedArray<Int16Type>
impl<T> NamedFrom<T, [i16]> for ChunkedArray<Int16Type>
Source§fn new(name: PlSmallStr, v: T) -> ChunkedArray<Int16Type>
fn new(name: PlSmallStr, v: T) -> ChunkedArray<Int16Type>
Source§impl<T> NamedFrom<T, [i32]> for ChunkedArray<Int32Type>
impl<T> NamedFrom<T, [i32]> for ChunkedArray<Int32Type>
Source§fn new(name: PlSmallStr, v: T) -> ChunkedArray<Int32Type>
fn new(name: PlSmallStr, v: T) -> ChunkedArray<Int32Type>
Source§impl<T> NamedFrom<T, [i64]> for ChunkedArray<Int64Type>
impl<T> NamedFrom<T, [i64]> for ChunkedArray<Int64Type>
Source§fn new(name: PlSmallStr, v: T) -> ChunkedArray<Int64Type>
fn new(name: PlSmallStr, v: T) -> ChunkedArray<Int64Type>
Source§impl<T> NamedFrom<T, [i8]> for ChunkedArray<Int8Type>
impl<T> NamedFrom<T, [i8]> for ChunkedArray<Int8Type>
Source§fn new(name: PlSmallStr, v: T) -> ChunkedArray<Int8Type>
fn new(name: PlSmallStr, v: T) -> ChunkedArray<Int8Type>
Source§impl<T> NamedFrom<T, [u16]> for ChunkedArray<UInt16Type>
impl<T> NamedFrom<T, [u16]> for ChunkedArray<UInt16Type>
Source§fn new(name: PlSmallStr, v: T) -> ChunkedArray<UInt16Type>
fn new(name: PlSmallStr, v: T) -> ChunkedArray<UInt16Type>
Source§impl<T> NamedFrom<T, [u32]> for ChunkedArray<UInt32Type>
impl<T> NamedFrom<T, [u32]> for ChunkedArray<UInt32Type>
Source§fn new(name: PlSmallStr, v: T) -> ChunkedArray<UInt32Type>
fn new(name: PlSmallStr, v: T) -> ChunkedArray<UInt32Type>
Source§impl<T> NamedFrom<T, [u64]> for ChunkedArray<UInt64Type>
impl<T> NamedFrom<T, [u64]> for ChunkedArray<UInt64Type>
Source§fn new(name: PlSmallStr, v: T) -> ChunkedArray<UInt64Type>
fn new(name: PlSmallStr, v: T) -> ChunkedArray<UInt64Type>
Source§impl<T> NamedFrom<T, [u8]> for ChunkedArray<UInt8Type>
impl<T> NamedFrom<T, [u8]> for ChunkedArray<UInt8Type>
Source§fn new(name: PlSmallStr, v: T) -> ChunkedArray<UInt8Type>
fn new(name: PlSmallStr, v: T) -> ChunkedArray<UInt8Type>
Source§impl<B> NewChunkedArray<BinaryType, B> for ChunkedArray<BinaryType>
impl<B> NewChunkedArray<BinaryType, B> for ChunkedArray<BinaryType>
Source§fn from_iter_values(
name: PlSmallStr,
it: impl Iterator<Item = B>,
) -> ChunkedArray<BinaryType>
fn from_iter_values( name: PlSmallStr, it: impl Iterator<Item = B>, ) -> ChunkedArray<BinaryType>
Create a new ChunkedArray from an iterator.
fn from_slice(name: PlSmallStr, v: &[B]) -> ChunkedArray<BinaryType>
fn from_slice_options( name: PlSmallStr, opt_v: &[Option<B>], ) -> ChunkedArray<BinaryType>
Source§fn from_iter_options(
name: PlSmallStr,
it: impl Iterator<Item = Option<B>>,
) -> ChunkedArray<BinaryType>
fn from_iter_options( name: PlSmallStr, it: impl Iterator<Item = Option<B>>, ) -> ChunkedArray<BinaryType>
Source§impl NewChunkedArray<BooleanType, bool> for ChunkedArray<BooleanType>
impl NewChunkedArray<BooleanType, bool> for ChunkedArray<BooleanType>
Source§fn from_iter_values(
name: PlSmallStr,
it: impl Iterator<Item = bool>,
) -> ChunkedArray<BooleanType>
fn from_iter_values( name: PlSmallStr, it: impl Iterator<Item = bool>, ) -> ChunkedArray<BooleanType>
Create a new ChunkedArray from an iterator.
fn from_slice(name: PlSmallStr, v: &[bool]) -> ChunkedArray<BooleanType>
fn from_slice_options( name: PlSmallStr, opt_v: &[Option<bool>], ) -> ChunkedArray<BooleanType>
Source§fn from_iter_options(
name: PlSmallStr,
it: impl Iterator<Item = Option<bool>>,
) -> ChunkedArray<BooleanType>
fn from_iter_options( name: PlSmallStr, it: impl Iterator<Item = Option<bool>>, ) -> ChunkedArray<BooleanType>
Source§impl<T> NewChunkedArray<ObjectType<T>, T> for ChunkedArray<ObjectType<T>>where
T: PolarsObject,
impl<T> NewChunkedArray<ObjectType<T>, T> for ChunkedArray<ObjectType<T>>where
T: PolarsObject,
Source§fn from_iter_values(
name: PlSmallStr,
it: impl Iterator<Item = T>,
) -> ChunkedArray<ObjectType<T>>
fn from_iter_values( name: PlSmallStr, it: impl Iterator<Item = T>, ) -> ChunkedArray<ObjectType<T>>
Create a new ChunkedArray from an iterator.
fn from_slice(name: PlSmallStr, v: &[T]) -> ChunkedArray<ObjectType<T>>
fn from_slice_options( name: PlSmallStr, opt_v: &[Option<T>], ) -> ChunkedArray<ObjectType<T>>
Source§fn from_iter_options(
name: PlSmallStr,
it: impl Iterator<Item = Option<T>>,
) -> ChunkedArray<ObjectType<T>>
fn from_iter_options( name: PlSmallStr, it: impl Iterator<Item = Option<T>>, ) -> ChunkedArray<ObjectType<T>>
Source§impl<S> NewChunkedArray<StringType, S> for ChunkedArray<StringType>
impl<S> NewChunkedArray<StringType, S> for ChunkedArray<StringType>
Source§fn from_iter_values(
name: PlSmallStr,
it: impl Iterator<Item = S>,
) -> ChunkedArray<StringType>
fn from_iter_values( name: PlSmallStr, it: impl Iterator<Item = S>, ) -> ChunkedArray<StringType>
Create a new ChunkedArray from an iterator.
fn from_slice(name: PlSmallStr, v: &[S]) -> ChunkedArray<StringType>
fn from_slice_options( name: PlSmallStr, opt_v: &[Option<S>], ) -> ChunkedArray<StringType>
Source§fn from_iter_options(
name: PlSmallStr,
it: impl Iterator<Item = Option<S>>,
) -> ChunkedArray<StringType>
fn from_iter_options( name: PlSmallStr, it: impl Iterator<Item = Option<S>>, ) -> ChunkedArray<StringType>
Source§impl<T> NewChunkedArray<T, <T as PolarsNumericType>::Native> for ChunkedArray<T>where
T: PolarsNumericType,
impl<T> NewChunkedArray<T, <T as PolarsNumericType>::Native> for ChunkedArray<T>where
T: PolarsNumericType,
Source§fn from_iter_values(
name: PlSmallStr,
it: impl Iterator<Item = <T as PolarsNumericType>::Native>,
) -> ChunkedArray<T>
fn from_iter_values( name: PlSmallStr, it: impl Iterator<Item = <T as PolarsNumericType>::Native>, ) -> ChunkedArray<T>
Create a new ChunkedArray from an iterator.
fn from_slice( name: PlSmallStr, v: &[<T as PolarsNumericType>::Native], ) -> ChunkedArray<T>
fn from_slice_options( name: PlSmallStr, opt_v: &[Option<<T as PolarsNumericType>::Native>], ) -> ChunkedArray<T>
Source§fn from_iter_options(
name: PlSmallStr,
it: impl Iterator<Item = Option<<T as PolarsNumericType>::Native>>,
) -> ChunkedArray<T>
fn from_iter_options( name: PlSmallStr, it: impl Iterator<Item = Option<<T as PolarsNumericType>::Native>>, ) -> ChunkedArray<T>
Source§impl Not for &ChunkedArray<BooleanType>
impl Not for &ChunkedArray<BooleanType>
Source§type Output = ChunkedArray<BooleanType>
type Output = ChunkedArray<BooleanType>
!
operator.Source§fn not(self) -> <&ChunkedArray<BooleanType> as Not>::Output
fn not(self) -> <&ChunkedArray<BooleanType> as Not>::Output
!
operation. Read moreSource§impl Not for ChunkedArray<BooleanType>
impl Not for ChunkedArray<BooleanType>
Source§type Output = ChunkedArray<BooleanType>
type Output = ChunkedArray<BooleanType>
!
operator.Source§fn not(self) -> <ChunkedArray<BooleanType> as Not>::Output
fn not(self) -> <ChunkedArray<BooleanType> as Not>::Output
!
operation. Read moreSource§impl<T> NumOpsDispatch for ChunkedArray<T>where
T: NumOpsDispatchInner,
impl<T> NumOpsDispatch for ChunkedArray<T>where
T: NumOpsDispatchInner,
fn subtract(&self, rhs: &Series) -> Result<Series, PolarsError>
fn add_to(&self, rhs: &Series) -> Result<Series, PolarsError>
fn multiply(&self, rhs: &Series) -> Result<Series, PolarsError>
fn divide(&self, rhs: &Series) -> Result<Series, PolarsError>
fn remainder(&self, rhs: &Series) -> Result<Series, PolarsError>
Source§impl<S> NumOpsDispatchChecked for ChunkedArray<S>where
S: NumOpsDispatchCheckedInner,
impl<S> NumOpsDispatchChecked for ChunkedArray<S>where
S: NumOpsDispatchCheckedInner,
Source§fn checked_div(&self, rhs: &Series) -> Result<Series, PolarsError>
fn checked_div(&self, rhs: &Series) -> Result<Series, PolarsError>
fn checked_div_num<T>(&self, rhs: T) -> Result<Series, PolarsError>where
T: ToPrimitive,
Source§impl QuantileAggSeries for ChunkedArray<Float32Type>
impl QuantileAggSeries for ChunkedArray<Float32Type>
Source§fn quantile_reduce(
&self,
quantile: f64,
method: QuantileMethod,
) -> Result<Scalar, PolarsError>
fn quantile_reduce( &self, quantile: f64, method: QuantileMethod, ) -> Result<Scalar, PolarsError>
ChunkedArray
as a new Series
of length 1.Source§fn median_reduce(&self) -> Scalar
fn median_reduce(&self) -> Scalar
ChunkedArray
as a new Series
of length 1.Source§impl QuantileAggSeries for ChunkedArray<Float64Type>
impl QuantileAggSeries for ChunkedArray<Float64Type>
Source§fn quantile_reduce(
&self,
quantile: f64,
method: QuantileMethod,
) -> Result<Scalar, PolarsError>
fn quantile_reduce( &self, quantile: f64, method: QuantileMethod, ) -> Result<Scalar, PolarsError>
ChunkedArray
as a new Series
of length 1.Source§fn median_reduce(&self) -> Scalar
fn median_reduce(&self) -> Scalar
ChunkedArray
as a new Series
of length 1.Source§impl<T> QuantileAggSeries for ChunkedArray<T>where
T: PolarsIntegerType,
<T as PolarsNumericType>::Native: Ord,
<<T as PolarsNumericType>::Native as Simd>::Simd: Add<Output = <<T as PolarsNumericType>::Native as Simd>::Simd> + Sum<<T as PolarsNumericType>::Native>,
impl<T> QuantileAggSeries for ChunkedArray<T>where
T: PolarsIntegerType,
<T as PolarsNumericType>::Native: Ord,
<<T as PolarsNumericType>::Native as Simd>::Simd: Add<Output = <<T as PolarsNumericType>::Native as Simd>::Simd> + Sum<<T as PolarsNumericType>::Native>,
Source§fn quantile_reduce(
&self,
quantile: f64,
method: QuantileMethod,
) -> Result<Scalar, PolarsError>
fn quantile_reduce( &self, quantile: f64, method: QuantileMethod, ) -> Result<Scalar, PolarsError>
ChunkedArray
as a new Series
of length 1.Source§fn median_reduce(&self) -> Scalar
fn median_reduce(&self) -> Scalar
ChunkedArray
as a new Series
of length 1.Source§impl Reinterpret for ChunkedArray<Float32Type>
Available on crate feature reinterpret
only.
impl Reinterpret for ChunkedArray<Float32Type>
reinterpret
only.fn reinterpret_signed(&self) -> Series
fn reinterpret_unsigned(&self) -> Series
Source§impl Reinterpret for ChunkedArray<Float64Type>
Available on crate feature reinterpret
only.
impl Reinterpret for ChunkedArray<Float64Type>
reinterpret
only.fn reinterpret_signed(&self) -> Series
fn reinterpret_unsigned(&self) -> Series
Source§impl Reinterpret for ChunkedArray<Int16Type>
Available on crate features reinterpret
and dtype-i16
and dtype-u16
only.
impl Reinterpret for ChunkedArray<Int16Type>
reinterpret
and dtype-i16
and dtype-u16
only.fn reinterpret_signed(&self) -> Series
fn reinterpret_unsigned(&self) -> Series
Source§impl Reinterpret for ChunkedArray<Int32Type>
Available on crate feature reinterpret
only.
impl Reinterpret for ChunkedArray<Int32Type>
reinterpret
only.fn reinterpret_signed(&self) -> Series
fn reinterpret_unsigned(&self) -> Series
Source§impl Reinterpret for ChunkedArray<Int64Type>
Available on crate feature reinterpret
only.
impl Reinterpret for ChunkedArray<Int64Type>
reinterpret
only.fn reinterpret_signed(&self) -> Series
fn reinterpret_unsigned(&self) -> Series
Source§impl Reinterpret for ChunkedArray<Int8Type>
Available on crate features reinterpret
and dtype-i8
and dtype-u8
only.
impl Reinterpret for ChunkedArray<Int8Type>
reinterpret
and dtype-i8
and dtype-u8
only.fn reinterpret_signed(&self) -> Series
fn reinterpret_unsigned(&self) -> Series
Source§impl Reinterpret for ChunkedArray<ListType>
Available on crate feature reinterpret
only.
impl Reinterpret for ChunkedArray<ListType>
reinterpret
only.fn reinterpret_signed(&self) -> Series
fn reinterpret_unsigned(&self) -> Series
Source§impl Reinterpret for ChunkedArray<UInt16Type>
Available on crate features reinterpret
and dtype-u16
and dtype-i16
only.
impl Reinterpret for ChunkedArray<UInt16Type>
reinterpret
and dtype-u16
and dtype-i16
only.fn reinterpret_signed(&self) -> Series
fn reinterpret_unsigned(&self) -> Series
Source§impl Reinterpret for ChunkedArray<UInt32Type>
Available on crate feature reinterpret
only.
impl Reinterpret for ChunkedArray<UInt32Type>
reinterpret
only.fn reinterpret_signed(&self) -> Series
fn reinterpret_unsigned(&self) -> Series
Source§impl Reinterpret for ChunkedArray<UInt64Type>
Available on crate feature reinterpret
only.
impl Reinterpret for ChunkedArray<UInt64Type>
reinterpret
only.fn reinterpret_signed(&self) -> Series
fn reinterpret_unsigned(&self) -> Series
Source§impl Reinterpret for ChunkedArray<UInt8Type>
Available on crate features reinterpret
and dtype-u8
and dtype-i8
only.
impl Reinterpret for ChunkedArray<UInt8Type>
reinterpret
and dtype-u8
and dtype-i8
only.fn reinterpret_signed(&self) -> Series
fn reinterpret_unsigned(&self) -> Series
Source§impl<T, N> Rem<N> for &ChunkedArray<T>
impl<T, N> Rem<N> for &ChunkedArray<T>
Source§impl<T, N> Rem<N> for ChunkedArray<T>
impl<T, N> Rem<N> for ChunkedArray<T>
Source§impl<T> Rem for &ChunkedArray<T>where
T: PolarsNumericType,
impl<T> Rem for &ChunkedArray<T>where
T: PolarsNumericType,
Source§type Output = ChunkedArray<T>
type Output = ChunkedArray<T>
%
operator.Source§fn rem(self, rhs: &ChunkedArray<T>) -> <&ChunkedArray<T> as Rem>::Output
fn rem(self, rhs: &ChunkedArray<T>) -> <&ChunkedArray<T> as Rem>::Output
%
operation. Read moreSource§impl<T> Rem for ChunkedArray<T>where
T: PolarsNumericType,
impl<T> Rem for ChunkedArray<T>where
T: PolarsNumericType,
Source§type Output = ChunkedArray<T>
type Output = ChunkedArray<T>
%
operator.Source§fn rem(self, rhs: ChunkedArray<T>) -> <ChunkedArray<T> as Rem>::Output
fn rem(self, rhs: ChunkedArray<T>) -> <ChunkedArray<T> as Rem>::Output
%
operation. Read moreSource§impl Serialize for ChunkedArray<BinaryType>
impl Serialize for ChunkedArray<BinaryType>
Source§fn serialize<S>(
&self,
serializer: S,
) -> Result<<S as Serializer>::Ok, <S as Serializer>::Error>where
S: Serializer,
fn serialize<S>(
&self,
serializer: S,
) -> Result<<S as Serializer>::Ok, <S as Serializer>::Error>where
S: Serializer,
Source§impl Serialize for ChunkedArray<BooleanType>
impl Serialize for ChunkedArray<BooleanType>
Source§fn serialize<S>(
&self,
serializer: S,
) -> Result<<S as Serializer>::Ok, <S as Serializer>::Error>where
S: Serializer,
fn serialize<S>(
&self,
serializer: S,
) -> Result<<S as Serializer>::Ok, <S as Serializer>::Error>where
S: Serializer,
Source§impl Serialize for ChunkedArray<FixedSizeListType>
impl Serialize for ChunkedArray<FixedSizeListType>
Source§fn serialize<S>(
&self,
serializer: S,
) -> Result<<S as Serializer>::Ok, <S as Serializer>::Error>where
S: Serializer,
fn serialize<S>(
&self,
serializer: S,
) -> Result<<S as Serializer>::Ok, <S as Serializer>::Error>where
S: Serializer,
Source§impl Serialize for ChunkedArray<ListType>
impl Serialize for ChunkedArray<ListType>
Source§fn serialize<S>(
&self,
serializer: S,
) -> Result<<S as Serializer>::Ok, <S as Serializer>::Error>where
S: Serializer,
fn serialize<S>(
&self,
serializer: S,
) -> Result<<S as Serializer>::Ok, <S as Serializer>::Error>where
S: Serializer,
Source§impl Serialize for ChunkedArray<StringType>
impl Serialize for ChunkedArray<StringType>
Source§fn serialize<S>(
&self,
serializer: S,
) -> Result<<S as Serializer>::Ok, <S as Serializer>::Error>where
S: Serializer,
fn serialize<S>(
&self,
serializer: S,
) -> Result<<S as Serializer>::Ok, <S as Serializer>::Error>where
S: Serializer,
Source§impl Serialize for ChunkedArray<StructType>
Available on crate feature dtype-struct
only.
impl Serialize for ChunkedArray<StructType>
dtype-struct
only.Source§fn serialize<S>(
&self,
serializer: S,
) -> Result<<S as Serializer>::Ok, <S as Serializer>::Error>where
S: Serializer,
fn serialize<S>(
&self,
serializer: S,
) -> Result<<S as Serializer>::Ok, <S as Serializer>::Error>where
S: Serializer,
Source§impl<T> Serialize for ChunkedArray<T>
impl<T> Serialize for ChunkedArray<T>
Source§fn serialize<S>(
&self,
serializer: S,
) -> Result<<S as Serializer>::Ok, <S as Serializer>::Error>where
S: Serializer,
fn serialize<S>(
&self,
serializer: S,
) -> Result<<S as Serializer>::Ok, <S as Serializer>::Error>where
S: Serializer,
Source§impl StringMethods for ChunkedArray<StringType>
impl StringMethods for ChunkedArray<StringType>
Source§fn as_time(
&self,
fmt: Option<&str>,
use_cache: bool,
) -> Result<Logical<TimeType, Int64Type>, PolarsError>
fn as_time( &self, fmt: Option<&str>, use_cache: bool, ) -> Result<Logical<TimeType, Int64Type>, PolarsError>
dtype-time
only.TimeChunked
Source§fn as_date_not_exact(
&self,
fmt: Option<&str>,
) -> Result<Logical<DateType, Int32Type>, PolarsError>
fn as_date_not_exact( &self, fmt: Option<&str>, ) -> Result<Logical<DateType, Int32Type>, PolarsError>
dtype-date
only.DateChunked
Different from as_date
this function allows matches that not contain the whole string
e.g. “foo-2021-01-01-bar” could match “2021-01-01”Source§fn as_datetime_not_exact(
&self,
fmt: Option<&str>,
tu: TimeUnit,
tz_aware: bool,
tz: Option<&PlSmallStr>,
_ambiguous: &ChunkedArray<StringType>,
) -> Result<Logical<DatetimeType, Int64Type>, PolarsError>
fn as_datetime_not_exact( &self, fmt: Option<&str>, tu: TimeUnit, tz_aware: bool, tz: Option<&PlSmallStr>, _ambiguous: &ChunkedArray<StringType>, ) -> Result<Logical<DatetimeType, Int64Type>, PolarsError>
dtype-datetime
only.DatetimeChunked
Different from as_datetime
this function allows matches that not contain the whole string
e.g. “foo-2021-01-01-bar” could match “2021-01-01”Source§fn as_date(
&self,
fmt: Option<&str>,
use_cache: bool,
) -> Result<Logical<DateType, Int32Type>, PolarsError>
fn as_date( &self, fmt: Option<&str>, use_cache: bool, ) -> Result<Logical<DateType, Int32Type>, PolarsError>
dtype-date
only.DateChunked
Source§fn as_datetime(
&self,
fmt: Option<&str>,
tu: TimeUnit,
use_cache: bool,
tz_aware: bool,
tz: Option<&PlSmallStr>,
ambiguous: &ChunkedArray<StringType>,
) -> Result<Logical<DatetimeType, Int64Type>, PolarsError>
fn as_datetime( &self, fmt: Option<&str>, tu: TimeUnit, use_cache: bool, tz_aware: bool, tz: Option<&PlSmallStr>, ambiguous: &ChunkedArray<StringType>, ) -> Result<Logical<DatetimeType, Int64Type>, PolarsError>
dtype-datetime
only.DatetimeChunked
.Source§impl StringNameSpaceImpl for ChunkedArray<StringType>
impl StringNameSpaceImpl for ChunkedArray<StringType>
Source§fn hex_decode(&self) -> Result<ChunkedArray<StringType>, PolarsError>
fn hex_decode(&self) -> Result<ChunkedArray<StringType>, PolarsError>
binary_encoding
only.Source§fn hex_encode(&self) -> ChunkedArray<StringType>
fn hex_encode(&self) -> ChunkedArray<StringType>
string_encoding
only.Source§fn base64_decode(&self) -> Result<ChunkedArray<StringType>, PolarsError>
fn base64_decode(&self) -> Result<ChunkedArray<StringType>, PolarsError>
binary_encoding
only.Source§fn base64_encode(&self) -> ChunkedArray<StringType>
fn base64_encode(&self) -> ChunkedArray<StringType>
string_encoding
only.Source§fn to_integer(
&self,
base: &ChunkedArray<UInt32Type>,
strict: bool,
) -> Result<ChunkedArray<Int64Type>, PolarsError>
fn to_integer( &self, base: &ChunkedArray<UInt32Type>, strict: bool, ) -> Result<ChunkedArray<Int64Type>, PolarsError>
string_to_integer
only.fn contains_chunked( &self, pat: &ChunkedArray<StringType>, literal: bool, strict: bool, ) -> Result<ChunkedArray<BooleanType>, PolarsError>
fn find_chunked( &self, pat: &ChunkedArray<StringType>, literal: bool, strict: bool, ) -> Result<ChunkedArray<UInt32Type>, PolarsError>
Source§fn starts_with(&self, sub: &str) -> ChunkedArray<BooleanType>
fn starts_with(&self, sub: &str) -> ChunkedArray<BooleanType>
Source§fn starts_with_chunked(
&self,
prefix: &ChunkedArray<StringType>,
) -> ChunkedArray<BooleanType>
fn starts_with_chunked( &self, prefix: &ChunkedArray<StringType>, ) -> ChunkedArray<BooleanType>
Source§fn str_len_chars(&self) -> ChunkedArray<UInt32Type>
fn str_len_chars(&self) -> ChunkedArray<UInt32Type>
Source§fn str_len_bytes(&self) -> ChunkedArray<UInt32Type>
fn str_len_bytes(&self) -> ChunkedArray<UInt32Type>
Source§fn contains(
&self,
pat: &str,
strict: bool,
) -> Result<ChunkedArray<BooleanType>, PolarsError>
fn contains( &self, pat: &str, strict: bool, ) -> Result<ChunkedArray<BooleanType>, PolarsError>
Source§fn contains_literal(
&self,
lit: &str,
) -> Result<ChunkedArray<BooleanType>, PolarsError>
fn contains_literal( &self, lit: &str, ) -> Result<ChunkedArray<BooleanType>, PolarsError>
Source§fn find_literal(
&self,
lit: &str,
) -> Result<ChunkedArray<UInt32Type>, PolarsError>
fn find_literal( &self, lit: &str, ) -> Result<ChunkedArray<UInt32Type>, PolarsError>
Source§fn find(
&self,
pat: &str,
strict: bool,
) -> Result<ChunkedArray<UInt32Type>, PolarsError>
fn find( &self, pat: &str, strict: bool, ) -> Result<ChunkedArray<UInt32Type>, PolarsError>
Source§fn replace<'a>(
&'a self,
pat: &str,
val: &str,
) -> Result<ChunkedArray<StringType>, PolarsError>
fn replace<'a>( &'a self, pat: &str, val: &str, ) -> Result<ChunkedArray<StringType>, PolarsError>
Source§fn replace_literal<'a>(
&'a self,
pat: &str,
val: &str,
n: usize,
) -> Result<ChunkedArray<StringType>, PolarsError>
fn replace_literal<'a>( &'a self, pat: &str, val: &str, n: usize, ) -> Result<ChunkedArray<StringType>, PolarsError>
Source§fn replace_all(
&self,
pat: &str,
val: &str,
) -> Result<ChunkedArray<StringType>, PolarsError>
fn replace_all( &self, pat: &str, val: &str, ) -> Result<ChunkedArray<StringType>, PolarsError>
Source§fn replace_literal_all<'a>(
&'a self,
pat: &str,
val: &str,
) -> Result<ChunkedArray<StringType>, PolarsError>
fn replace_literal_all<'a>( &'a self, pat: &str, val: &str, ) -> Result<ChunkedArray<StringType>, PolarsError>
Source§fn extract(
&self,
pat: &ChunkedArray<StringType>,
group_index: usize,
) -> Result<ChunkedArray<StringType>, PolarsError>
fn extract( &self, pat: &ChunkedArray<StringType>, group_index: usize, ) -> Result<ChunkedArray<StringType>, PolarsError>
Source§fn extract_all(&self, pat: &str) -> Result<ChunkedArray<ListType>, PolarsError>
fn extract_all(&self, pat: &str) -> Result<ChunkedArray<ListType>, PolarsError>
fn strip_chars( &self, pat: &Column, ) -> Result<ChunkedArray<StringType>, PolarsError>
fn strip_chars_start( &self, pat: &Column, ) -> Result<ChunkedArray<StringType>, PolarsError>
fn strip_chars_end( &self, pat: &Column, ) -> Result<ChunkedArray<StringType>, PolarsError>
fn strip_prefix( &self, prefix: &ChunkedArray<StringType>, ) -> ChunkedArray<StringType>
fn strip_suffix( &self, suffix: &ChunkedArray<StringType>, ) -> ChunkedArray<StringType>
Source§fn split_exact(
&self,
by: &ChunkedArray<StringType>,
n: usize,
) -> Result<ChunkedArray<StructType>, PolarsError>
fn split_exact( &self, by: &ChunkedArray<StringType>, n: usize, ) -> Result<ChunkedArray<StructType>, PolarsError>
dtype-struct
only.Source§fn split_exact_inclusive(
&self,
by: &ChunkedArray<StringType>,
n: usize,
) -> Result<ChunkedArray<StructType>, PolarsError>
fn split_exact_inclusive( &self, by: &ChunkedArray<StringType>, n: usize, ) -> Result<ChunkedArray<StructType>, PolarsError>
dtype-struct
only.Source§fn splitn(
&self,
by: &ChunkedArray<StringType>,
n: usize,
) -> Result<ChunkedArray<StructType>, PolarsError>
fn splitn( &self, by: &ChunkedArray<StringType>, n: usize, ) -> Result<ChunkedArray<StructType>, PolarsError>
dtype-struct
only.fn split(&self, by: &ChunkedArray<StringType>) -> ChunkedArray<ListType>
fn split_inclusive( &self, by: &ChunkedArray<StringType>, ) -> ChunkedArray<ListType>
Source§fn extract_all_many(
&self,
pat: &ChunkedArray<StringType>,
) -> Result<ChunkedArray<ListType>, PolarsError>
fn extract_all_many( &self, pat: &ChunkedArray<StringType>, ) -> Result<ChunkedArray<ListType>, PolarsError>
Source§fn extract_groups(
&self,
pat: &str,
dtype: &DataType,
) -> Result<Series, PolarsError>
fn extract_groups( &self, pat: &str, dtype: &DataType, ) -> Result<Series, PolarsError>
extract_groups
only.Source§fn count_matches(
&self,
pat: &str,
literal: bool,
) -> Result<ChunkedArray<UInt32Type>, PolarsError>
fn count_matches( &self, pat: &str, literal: bool, ) -> Result<ChunkedArray<UInt32Type>, PolarsError>
Source§fn count_matches_many(
&self,
pat: &ChunkedArray<StringType>,
literal: bool,
) -> Result<ChunkedArray<UInt32Type>, PolarsError>
fn count_matches_many( &self, pat: &ChunkedArray<StringType>, literal: bool, ) -> Result<ChunkedArray<UInt32Type>, PolarsError>
Source§fn to_lowercase(&self) -> ChunkedArray<StringType>
fn to_lowercase(&self) -> ChunkedArray<StringType>
Source§fn to_uppercase(&self) -> ChunkedArray<StringType>
fn to_uppercase(&self) -> ChunkedArray<StringType>
Source§fn to_titlecase(&self) -> ChunkedArray<StringType>
fn to_titlecase(&self) -> ChunkedArray<StringType>
nightly
only.Source§fn concat(&self, other: &ChunkedArray<StringType>) -> ChunkedArray<StringType>
fn concat(&self, other: &ChunkedArray<StringType>) -> ChunkedArray<StringType>
Source§fn str_reverse(&self) -> ChunkedArray<StringType>
fn str_reverse(&self) -> ChunkedArray<StringType>
string_reverse
only.Source§fn str_slice(
&self,
offset: &Column,
length: &Column,
) -> Result<ChunkedArray<StringType>, PolarsError>
fn str_slice( &self, offset: &Column, length: &Column, ) -> Result<ChunkedArray<StringType>, PolarsError>
Source§fn str_head(&self, n: &Column) -> Result<ChunkedArray<StringType>, PolarsError>
fn str_head(&self, n: &Column) -> Result<ChunkedArray<StringType>, PolarsError>
n
values of the string. Read moreSource§fn str_tail(&self, n: &Column) -> Result<ChunkedArray<StringType>, PolarsError>
fn str_tail(&self, n: &Column) -> Result<ChunkedArray<StringType>, PolarsError>
n
values of the string. Read moreSource§fn str_escape_regex(&self) -> ChunkedArray<StringType>
fn str_escape_regex(&self) -> ChunkedArray<StringType>
strings
only.Source§impl<T, N> Sub<N> for &ChunkedArray<T>
impl<T, N> Sub<N> for &ChunkedArray<T>
Source§impl<T, N> Sub<N> for ChunkedArray<T>
impl<T, N> Sub<N> for ChunkedArray<T>
Source§impl<T> Sub for &ChunkedArray<T>where
T: PolarsNumericType,
impl<T> Sub for &ChunkedArray<T>where
T: PolarsNumericType,
Source§type Output = ChunkedArray<T>
type Output = ChunkedArray<T>
-
operator.Source§fn sub(self, rhs: &ChunkedArray<T>) -> <&ChunkedArray<T> as Sub>::Output
fn sub(self, rhs: &ChunkedArray<T>) -> <&ChunkedArray<T> as Sub>::Output
-
operation. Read moreSource§impl<T> Sub for ChunkedArray<T>where
T: PolarsNumericType,
impl<T> Sub for ChunkedArray<T>where
T: PolarsNumericType,
Source§type Output = ChunkedArray<T>
type Output = ChunkedArray<T>
-
operator.Source§fn sub(self, rhs: ChunkedArray<T>) -> <ChunkedArray<T> as Sub>::Output
fn sub(self, rhs: ChunkedArray<T>) -> <ChunkedArray<T> as Sub>::Output
-
operation. Read moreSource§impl<T> TakeChunked for ChunkedArray<T>
impl<T> TakeChunked for ChunkedArray<T>
Source§unsafe fn take_chunked_unchecked<const B: u64>(
&self,
by: &[ChunkId<B>],
sorted: IsSorted,
) -> ChunkedArray<T>
unsafe fn take_chunked_unchecked<const B: u64>( &self, by: &[ChunkId<B>], sorted: IsSorted, ) -> ChunkedArray<T>
Source§unsafe fn take_opt_chunked_unchecked<const B: u64>(
&self,
by: &[ChunkId<B>],
) -> ChunkedArray<T>
unsafe fn take_opt_chunked_unchecked<const B: u64>( &self, by: &[ChunkId<B>], ) -> ChunkedArray<T>
Source§impl ValueSize for ChunkedArray<BinaryOffsetType>
impl ValueSize for ChunkedArray<BinaryOffsetType>
Source§fn get_values_size(&self) -> usize
fn get_values_size(&self) -> usize
Source§impl ValueSize for ChunkedArray<FixedSizeListType>
Available on crate feature dtype-array
only.
impl ValueSize for ChunkedArray<FixedSizeListType>
dtype-array
only.Source§fn get_values_size(&self) -> usize
fn get_values_size(&self) -> usize
Source§impl ValueSize for ChunkedArray<ListType>
impl ValueSize for ChunkedArray<ListType>
Source§fn get_values_size(&self) -> usize
fn get_values_size(&self) -> usize
Source§impl ValueSize for ChunkedArray<StringType>
impl ValueSize for ChunkedArray<StringType>
Source§fn get_values_size(&self) -> usize
fn get_values_size(&self) -> usize
Source§impl VarAggSeries for ChunkedArray<Float32Type>
impl VarAggSeries for ChunkedArray<Float32Type>
Source§fn var_reduce(&self, ddof: u8) -> Scalar
fn var_reduce(&self, ddof: u8) -> Scalar
ChunkedArray
as a new Series
of length 1.Source§fn std_reduce(&self, ddof: u8) -> Scalar
fn std_reduce(&self, ddof: u8) -> Scalar
ChunkedArray
as a new Series
of length 1.Source§impl VarAggSeries for ChunkedArray<Float64Type>
impl VarAggSeries for ChunkedArray<Float64Type>
Source§fn var_reduce(&self, ddof: u8) -> Scalar
fn var_reduce(&self, ddof: u8) -> Scalar
ChunkedArray
as a new Series
of length 1.Source§fn std_reduce(&self, ddof: u8) -> Scalar
fn std_reduce(&self, ddof: u8) -> Scalar
ChunkedArray
as a new Series
of length 1.Source§impl<T> VarAggSeries for ChunkedArray<T>
impl<T> VarAggSeries for ChunkedArray<T>
Source§fn var_reduce(&self, ddof: u8) -> Scalar
fn var_reduce(&self, ddof: u8) -> Scalar
ChunkedArray
as a new Series
of length 1.Source§fn std_reduce(&self, ddof: u8) -> Scalar
fn std_reduce(&self, ddof: u8) -> Scalar
ChunkedArray
as a new Series
of length 1.Source§impl VecHash for ChunkedArray<BinaryOffsetType>
impl VecHash for ChunkedArray<BinaryOffsetType>
Source§fn vec_hash(
&self,
random_state: RandomState,
buf: &mut Vec<u64>,
) -> Result<(), PolarsError>
fn vec_hash( &self, random_state: RandomState, buf: &mut Vec<u64>, ) -> Result<(), PolarsError>
fn vec_hash_combine( &self, random_state: RandomState, hashes: &mut [u64], ) -> Result<(), PolarsError>
Source§impl VecHash for ChunkedArray<BinaryType>
impl VecHash for ChunkedArray<BinaryType>
Source§fn vec_hash(
&self,
random_state: RandomState,
buf: &mut Vec<u64>,
) -> Result<(), PolarsError>
fn vec_hash( &self, random_state: RandomState, buf: &mut Vec<u64>, ) -> Result<(), PolarsError>
fn vec_hash_combine( &self, random_state: RandomState, hashes: &mut [u64], ) -> Result<(), PolarsError>
Source§impl VecHash for ChunkedArray<BooleanType>
impl VecHash for ChunkedArray<BooleanType>
Source§fn vec_hash(
&self,
random_state: RandomState,
buf: &mut Vec<u64>,
) -> Result<(), PolarsError>
fn vec_hash( &self, random_state: RandomState, buf: &mut Vec<u64>, ) -> Result<(), PolarsError>
fn vec_hash_combine( &self, random_state: RandomState, hashes: &mut [u64], ) -> Result<(), PolarsError>
Source§impl VecHash for ChunkedArray<Float32Type>
impl VecHash for ChunkedArray<Float32Type>
Source§fn vec_hash(
&self,
random_state: RandomState,
buf: &mut Vec<u64>,
) -> Result<(), PolarsError>
fn vec_hash( &self, random_state: RandomState, buf: &mut Vec<u64>, ) -> Result<(), PolarsError>
fn vec_hash_combine( &self, random_state: RandomState, hashes: &mut [u64], ) -> Result<(), PolarsError>
Source§impl VecHash for ChunkedArray<Float64Type>
impl VecHash for ChunkedArray<Float64Type>
Source§fn vec_hash(
&self,
random_state: RandomState,
buf: &mut Vec<u64>,
) -> Result<(), PolarsError>
fn vec_hash( &self, random_state: RandomState, buf: &mut Vec<u64>, ) -> Result<(), PolarsError>
fn vec_hash_combine( &self, random_state: RandomState, hashes: &mut [u64], ) -> Result<(), PolarsError>
Source§impl VecHash for ChunkedArray<Int128Type>
impl VecHash for ChunkedArray<Int128Type>
Source§fn vec_hash(
&self,
random_state: RandomState,
buf: &mut Vec<u64>,
) -> Result<(), PolarsError>
fn vec_hash( &self, random_state: RandomState, buf: &mut Vec<u64>, ) -> Result<(), PolarsError>
fn vec_hash_combine( &self, random_state: RandomState, hashes: &mut [u64], ) -> Result<(), PolarsError>
Source§impl VecHash for ChunkedArray<Int16Type>
impl VecHash for ChunkedArray<Int16Type>
Source§fn vec_hash(
&self,
random_state: RandomState,
buf: &mut Vec<u64>,
) -> Result<(), PolarsError>
fn vec_hash( &self, random_state: RandomState, buf: &mut Vec<u64>, ) -> Result<(), PolarsError>
fn vec_hash_combine( &self, random_state: RandomState, hashes: &mut [u64], ) -> Result<(), PolarsError>
Source§impl VecHash for ChunkedArray<Int32Type>
impl VecHash for ChunkedArray<Int32Type>
Source§fn vec_hash(
&self,
random_state: RandomState,
buf: &mut Vec<u64>,
) -> Result<(), PolarsError>
fn vec_hash( &self, random_state: RandomState, buf: &mut Vec<u64>, ) -> Result<(), PolarsError>
fn vec_hash_combine( &self, random_state: RandomState, hashes: &mut [u64], ) -> Result<(), PolarsError>
Source§impl VecHash for ChunkedArray<Int64Type>
impl VecHash for ChunkedArray<Int64Type>
Source§fn vec_hash(
&self,
random_state: RandomState,
buf: &mut Vec<u64>,
) -> Result<(), PolarsError>
fn vec_hash( &self, random_state: RandomState, buf: &mut Vec<u64>, ) -> Result<(), PolarsError>
fn vec_hash_combine( &self, random_state: RandomState, hashes: &mut [u64], ) -> Result<(), PolarsError>
Source§impl VecHash for ChunkedArray<Int8Type>
impl VecHash for ChunkedArray<Int8Type>
Source§fn vec_hash(
&self,
random_state: RandomState,
buf: &mut Vec<u64>,
) -> Result<(), PolarsError>
fn vec_hash( &self, random_state: RandomState, buf: &mut Vec<u64>, ) -> Result<(), PolarsError>
fn vec_hash_combine( &self, random_state: RandomState, hashes: &mut [u64], ) -> Result<(), PolarsError>
Source§impl<T> VecHash for ChunkedArray<ObjectType<T>>where
T: PolarsObject,
Available on crate feature object
only.
impl<T> VecHash for ChunkedArray<ObjectType<T>>where
T: PolarsObject,
object
only.Source§fn vec_hash(
&self,
random_state: RandomState,
buf: &mut Vec<u64>,
) -> Result<(), PolarsError>
fn vec_hash( &self, random_state: RandomState, buf: &mut Vec<u64>, ) -> Result<(), PolarsError>
fn vec_hash_combine( &self, random_state: RandomState, hashes: &mut [u64], ) -> Result<(), PolarsError>
Source§impl VecHash for ChunkedArray<StringType>
impl VecHash for ChunkedArray<StringType>
Source§fn vec_hash(
&self,
random_state: RandomState,
buf: &mut Vec<u64>,
) -> Result<(), PolarsError>
fn vec_hash( &self, random_state: RandomState, buf: &mut Vec<u64>, ) -> Result<(), PolarsError>
fn vec_hash_combine( &self, random_state: RandomState, hashes: &mut [u64], ) -> Result<(), PolarsError>
Source§impl VecHash for ChunkedArray<UInt16Type>
impl VecHash for ChunkedArray<UInt16Type>
Source§fn vec_hash(
&self,
random_state: RandomState,
buf: &mut Vec<u64>,
) -> Result<(), PolarsError>
fn vec_hash( &self, random_state: RandomState, buf: &mut Vec<u64>, ) -> Result<(), PolarsError>
fn vec_hash_combine( &self, random_state: RandomState, hashes: &mut [u64], ) -> Result<(), PolarsError>
Source§impl VecHash for ChunkedArray<UInt32Type>
impl VecHash for ChunkedArray<UInt32Type>
Source§fn vec_hash(
&self,
random_state: RandomState,
buf: &mut Vec<u64>,
) -> Result<(), PolarsError>
fn vec_hash( &self, random_state: RandomState, buf: &mut Vec<u64>, ) -> Result<(), PolarsError>
fn vec_hash_combine( &self, random_state: RandomState, hashes: &mut [u64], ) -> Result<(), PolarsError>
Source§impl VecHash for ChunkedArray<UInt64Type>
impl VecHash for ChunkedArray<UInt64Type>
Source§fn vec_hash(
&self,
random_state: RandomState,
buf: &mut Vec<u64>,
) -> Result<(), PolarsError>
fn vec_hash( &self, random_state: RandomState, buf: &mut Vec<u64>, ) -> Result<(), PolarsError>
fn vec_hash_combine( &self, random_state: RandomState, hashes: &mut [u64], ) -> Result<(), PolarsError>
Source§impl VecHash for ChunkedArray<UInt8Type>
impl VecHash for ChunkedArray<UInt8Type>
Source§fn vec_hash(
&self,
random_state: RandomState,
buf: &mut Vec<u64>,
) -> Result<(), PolarsError>
fn vec_hash( &self, random_state: RandomState, buf: &mut Vec<u64>, ) -> Result<(), PolarsError>
fn vec_hash_combine( &self, random_state: RandomState, hashes: &mut [u64], ) -> Result<(), PolarsError>
Auto Trait Implementations§
impl<T> Freeze for ChunkedArray<T>
impl<T> !RefUnwindSafe for ChunkedArray<T>
impl<T> Send for ChunkedArray<T>
impl<T> Sync for ChunkedArray<T>
impl<T> Unpin for ChunkedArray<T>
impl<T> !UnwindSafe for ChunkedArray<T>
Blanket Implementations§
Source§impl<T> BorrowMut<T> for Twhere
T: ?Sized,
impl<T> BorrowMut<T> for Twhere
T: ?Sized,
Source§fn borrow_mut(&mut self) -> &mut T
fn borrow_mut(&mut self) -> &mut T
Source§impl<T> CloneToUninit for Twhere
T: Clone,
impl<T> CloneToUninit for Twhere
T: Clone,
Source§unsafe fn clone_to_uninit(&self, dst: *mut T)
unsafe fn clone_to_uninit(&self, dst: *mut T)
clone_to_uninit
)§impl<I, C> CompactStringExt for C
impl<I, C> CompactStringExt for C
§fn concat_compact(&self) -> CompactString
fn concat_compact(&self) -> CompactString
CompactString
] Read more§fn join_compact<S>(&self, separator: S) -> CompactString
fn join_compact<S>(&self, separator: S) -> CompactString
CompactString
] Read more§impl<T> Instrument for T
impl<T> Instrument for T
§fn instrument(self, span: Span) -> Instrumented<Self>
fn instrument(self, span: Span) -> Instrumented<Self>
§fn in_current_span(self) -> Instrumented<Self>
fn in_current_span(self) -> Instrumented<Self>
Source§impl<T> IntoColumn for Twhere
T: IntoSeries,
impl<T> IntoColumn for Twhere
T: IntoSeries,
fn into_column(self) -> Column
Source§impl<T> IntoEither for T
impl<T> IntoEither for T
Source§fn into_either(self, into_left: bool) -> Either<Self, Self> ⓘ
fn into_either(self, into_left: bool) -> Either<Self, Self> ⓘ
self
into a Left
variant of Either<Self, Self>
if into_left
is true
.
Converts self
into a Right
variant of Either<Self, Self>
otherwise. Read moreSource§fn into_either_with<F>(self, into_left: F) -> Either<Self, Self> ⓘ
fn into_either_with<F>(self, into_left: F) -> Either<Self, Self> ⓘ
self
into a Left
variant of Either<Self, Self>
if into_left(&self)
returns true
.
Converts self
into a Right
variant of Either<Self, Self>
otherwise. Read more