Type Alias StructChunked

Source
pub type StructChunked = ChunkedArray<StructType>;

Aliased Type§

struct StructChunked { /* private fields */ }

Implementations

Source§

impl ChunkedArray<StructType>

Source

pub fn from_columns( name: PlSmallStr, length: usize, fields: &[Column], ) -> Result<ChunkedArray<StructType>, PolarsError>

Source

pub fn from_series<'a, I>( name: PlSmallStr, length: usize, fields: I, ) -> Result<ChunkedArray<StructType>, PolarsError>
where I: ExactSizeIterator<Item = &'a Series> + Clone,

Source

pub fn to_physical_repr(&self) -> Cow<'_, ChunkedArray<StructType>>

Convert a struct to the underlying physical datatype.

Source

pub unsafe fn from_physical_unchecked( &self, to_fields: &[Field], ) -> Result<ChunkedArray<StructType>, PolarsError>

Convert a non-logical StructChunked back into a logical StructChunked without casting.

§Safety

This can lead to invalid memory access in downstream code.

Source

pub fn struct_fields(&self) -> &[Field]

Source

pub fn fields_as_series(&self) -> Vec<Series>

Source

pub fn cast_with_options( &self, dtype: &DataType, cast_options: CastOptions, ) -> Result<Series, PolarsError>

Source

pub fn cast(&self, dtype: &DataType) -> Result<Series, PolarsError>

Source

pub fn _apply_fields<F>( &self, func: F, ) -> Result<ChunkedArray<StructType>, PolarsError>
where F: FnMut(&Series) -> Series,

Source

pub fn try_apply_fields<F>( &self, func: F, ) -> Result<ChunkedArray<StructType>, PolarsError>

Source

pub fn get_row_encoded_array( &self, options: SortOptions, ) -> Result<BinaryArray<i64>, PolarsError>

Source

pub fn get_row_encoded( &self, options: SortOptions, ) -> Result<ChunkedArray<BinaryOffsetType>, PolarsError>

Source

pub fn zip_outer_validity(&mut self, other: &ChunkedArray<StructType>)

Combine the validities of two structs.

Source

pub fn unnest(self) -> DataFrame

Source

pub fn field_by_name(&self, name: &str) -> Result<Series, PolarsError>

Get access to one of this StructChunked’s fields

Source

pub fn with_outer_validity( self, validity: Option<Bitmap>, ) -> ChunkedArray<StructType>

Source§

impl<T> ChunkedArray<T>
where T: PolarsDataType, <<T as PolarsDataType>::Array as StaticArray>::ValueT<'a>: for<'a> AsRef<[u8]>,

Source

pub fn to_bytes_hashes<'a>( &'a self, multithreaded: bool, hb: RandomState, ) -> Vec<Vec<BytesHash<'a>>>

Source§

impl<T> ChunkedArray<T>

Source

pub fn to_canonical(&self) -> ChunkedArray<T>

Source§

impl<T> ChunkedArray<T>

Source

pub fn is_nan(&self) -> ChunkedArray<BooleanType>

Source

pub fn is_not_nan(&self) -> ChunkedArray<BooleanType>

Source

pub fn is_finite(&self) -> ChunkedArray<BooleanType>

Source

pub fn is_infinite(&self) -> ChunkedArray<BooleanType>

Source

pub fn none_to_nan(&self) -> ChunkedArray<T>

Convert missing values to NaN values.

Source§

impl<T> ChunkedArray<T>

Source

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.

Source

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.

Source

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<T> ChunkedArray<T>
where T: PolarsDataType,

Source

pub fn with_chunk<A>(name: PlSmallStr, arr: A) -> ChunkedArray<T>
where A: Array, T: PolarsDataType<Array = A>,

Source

pub fn with_chunk_like<A>(ca: &ChunkedArray<T>, arr: A) -> ChunkedArray<T>
where A: Array, T: PolarsDataType<Array = A>,

Source

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,

Source

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,

Source

pub fn try_from_chunk_iter<I, A, E>( name: PlSmallStr, iter: I, ) -> Result<ChunkedArray<T>, E>
where I: IntoIterator<Item = Result<A, E>>, T: PolarsDataType<Array = A>, A: Array,

Source

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.

Source

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.

Source

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.

Source

pub fn full_null_like(ca: &ChunkedArray<T>, length: usize) -> ChunkedArray<T>

Source§

impl<T> ChunkedArray<T>
where T: PolarsDataType,

Source

pub fn iter(&self) -> impl PolarsIterator

Source§

impl<T> ChunkedArray<T>
where T: PolarsDataType,

Source

pub fn unpack_series_matching_type<'a>( &self, series: &'a Series, ) -> Result<&'a ChunkedArray<T>, PolarsError>

Series to ChunkedArray<T>

Source

pub unsafe fn new_with_dims( field: Arc<Field>, chunks: Vec<Box<dyn Array>>, length: usize, null_count: usize, ) -> ChunkedArray<T>

Create a new ChunkedArray and explicitly set its length and null_count.

§Safety

The length and null_count must be correct.

Source

pub fn unset_fast_explode_list(&mut self)

Source

pub fn set_fast_explode_list(&mut self, value: bool)

Source

pub fn get_fast_explode_list(&self) -> bool

Source

pub fn get_flags(&self) -> StatisticsFlags

Source

pub fn is_sorted_flag(&self) -> IsSorted

Source

pub fn retain_flags_from<U>( &mut self, from: &ChunkedArray<U>, retain_flags: StatisticsFlags, )
where U: PolarsDataType,

Source

pub fn set_sorted_flag(&mut self, sorted: IsSorted)

Set the ‘sorted’ bit meta info.

Source

pub fn with_sorted_flag(&self, sorted: IsSorted) -> ChunkedArray<T>

Set the ‘sorted’ bit meta info.

Source

pub fn first_non_null(&self) -> Option<usize>

Get the index of the first non null value in this ChunkedArray.

Source

pub fn last_non_null(&self) -> Option<usize>

Get the index of the last non null value in this ChunkedArray.

Source

pub fn drop_nulls(&self) -> ChunkedArray<T>

Source

pub fn iter_validities( &self, ) -> Map<Iter<'_, Box<dyn Array>>, fn(_: &Box<dyn Array>) -> Option<&Bitmap>>

Get the buffer of bits representing null values

Source

pub fn has_nulls(&self) -> bool

Return if any the chunks in this ChunkedArray have nulls.

Source

pub fn shrink_to_fit(&mut self)

Shrink the capacity of this array to fit its length.

Source

pub fn clear(&self) -> ChunkedArray<T>

Source

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.

Source

pub fn chunks(&self) -> &Vec<Box<dyn Array>>

A reference to the chunks

Source

pub unsafe fn chunks_mut(&mut self) -> &mut Vec<Box<dyn Array>>

A mutable reference to the chunks

§Safety

The caller must ensure to not change the DataType or length of any of the chunks. And the null_count remains correct.

Source

pub fn is_optimal_aligned(&self) -> bool

Returns true if contains a single chunk and has no null values

Source

pub fn dtype(&self) -> &DataType

Get data type of ChunkedArray.

Source

pub fn name(&self) -> &PlSmallStr

Name of the ChunkedArray.

Source

pub fn ref_field(&self) -> &Field

Get a reference to the field.

Source

pub fn rename(&mut self, name: PlSmallStr)

Rename this ChunkedArray.

Source

pub fn with_name(self, name: PlSmallStr) -> ChunkedArray<T>

Return this ChunkedArray with a new name.

Source§

impl<T> ChunkedArray<T>
where T: PolarsDataType,

Source

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.

Source

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().

Source

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().

Source

pub fn first(&self) -> Option<<T as PolarsDataType>::Physical<'_>>

Source

pub fn last(&self) -> Option<<T as PolarsDataType>::Physical<'_>>

Source§

impl<T> ChunkedArray<T>
where T: PolarsDataType,

Source

pub fn layout(&self) -> ChunkedArrayLayout<'_, T>

Source§

impl<T> ChunkedArray<T>

Source

pub fn cont_slice( &self, ) -> Result<&[<T as PolarsNumericType>::Native], PolarsError>

Returns the values of the array as a contiguous slice.

Source

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

Source

pub fn into_no_null_iter( &self, ) -> impl Send + Sync + ExactSizeIterator + DoubleEndedIterator + TrustedLen

Source§

impl<T> ChunkedArray<T>

Source

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<T> ChunkedArray<T>
where T: PolarsDataType<IsNested = FalseT, IsObject = FalseT>, <T as PolarsDataType>::Physical<'a>: for<'a> TotalOrd,

Source

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

pub fn append_owned( &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,

Source

pub fn apply_nonnull_values_generic<'a, U, K, F>( &'a self, dtype: DataType, op: F, ) -> ChunkedArray<U>

Applies a function only to the non-null elements, propagating nulls.

Source

pub fn try_apply_nonnull_values_generic<'a, U, K, F, E>( &'a self, op: F, ) -> Result<ChunkedArray<U>, E>

Applies a function only to the non-null elements, propagating nulls.

Source

pub fn apply_into_string_amortized<'a, F>( &'a self, f: F, ) -> ChunkedArray<StringType>
where F: FnMut(<T as PolarsDataType>::Physical<'a>, &mut String),

Source

pub fn try_apply_into_string_amortized<'a, F, E>( &'a self, f: F, ) -> Result<ChunkedArray<StringType>, E>
where F: FnMut(<T as PolarsDataType>::Physical<'a>, &mut String) -> Result<(), E>,

Source§

impl<T> ChunkedArray<T>

Source

pub fn cast_and_apply_in_place<F, S>(&self, f: F) -> ChunkedArray<S>

Cast a numeric array to another numeric data type and apply a function in place. This saves an allocation.

Source

pub fn apply_in_place<F>(self, f: F) -> ChunkedArray<T>
where F: Fn(<T as PolarsNumericType>::Native) -> <T as PolarsNumericType>::Native + Copy,

Cast a numeric array to another numeric data type and apply a function in place. This saves an allocation.

Source§

impl<T> ChunkedArray<T>

Source

pub fn apply_mut<F>(&mut self, f: F)
where F: Fn(<T as PolarsNumericType>::Native) -> <T as PolarsNumericType>::Native + Copy,

Source§

impl<T> ChunkedArray<T>
where T: PolarsDataType,

Source

pub fn len(&self) -> usize

Get the length of the ChunkedArray

Source

pub fn null_count(&self) -> usize

Return the number of null values in the ChunkedArray.

Source

pub unsafe fn set_null_count(&mut self, null_count: usize)

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.

Source

pub fn is_empty(&self) -> bool

Check if ChunkedArray is empty.

Source

pub fn rechunk(&self) -> Cow<'_, ChunkedArray<T>>

Rechunks this ChunkedArray, returning a new Cow::Owned ChunkedArray if it was rechunked or simply a Cow::Borrowed of itself if it was already a single chunk.

Source

pub fn rechunk_mut(&mut self)

Rechunks this ChunkedArray in-place.

Source

pub fn rechunk_validity(&self) -> Option<Bitmap>

Source

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

Source

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

Source

pub fn limit(&self, num_elements: usize) -> ChunkedArray<T>
where ChunkedArray<T>: Sized,

Take a view of top n elements

Source

pub fn head(&self, length: Option<usize>) -> ChunkedArray<T>
where ChunkedArray<T>: Sized,

Get the head of the ChunkedArray

Source

pub fn tail(&self, length: Option<usize>) -> ChunkedArray<T>
where ChunkedArray<T>: Sized,

Get the tail of the ChunkedArray

Source

pub fn prune_empty_chunks(&mut self)

Remove empty chunks.

Source§

impl<T> ChunkedArray<T>

Source

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,

Source

pub fn for_each<'a, F>(&'a self, op: F)
where F: FnMut(Option<<T as PolarsDataType>::Physical<'a>>),

Source§

impl<T> ChunkedArray<T>
where T: PolarsDataType,

Source

pub fn is_null(&self) -> ChunkedArray<BooleanType>

Get a mask of the null values.

Source

pub fn is_not_null(&self) -> ChunkedArray<BooleanType>

Get a mask of the valid values.

Source§

impl<T> ChunkedArray<T>

Source

pub fn rolling_map_float<F>( &self, window_size: usize, f: F, ) -> Result<ChunkedArray<T>, PolarsError>
where F: FnMut(&mut ChunkedArray<T>) -> Option<<T as PolarsNumericType>::Native>,

Apply a rolling custom function. This is pretty slow because of dynamic dispatch.

Source§

impl<T> ChunkedArray<T>

Source

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.

Source

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>

Source

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.

Source

pub fn rand_standard_normal(name: PlSmallStr, length: usize) -> ChunkedArray<T>

Create ChunkedArray with samples from a Standard Normal distribution.

Source

pub fn rand_uniform( name: PlSmallStr, length: usize, low: f64, high: f64, ) -> ChunkedArray<T>

Create ChunkedArray with samples from a Uniform distribution.

Source§

impl<T> ChunkedArray<T>

Source

pub fn init_rand( size: usize, null_density: f32, seed: Option<u64>, ) -> ChunkedArray<T>

Source§

impl<T> ChunkedArray<T>

Source

pub fn to_vec(&self) -> Vec<Option<<T as PolarsNumericType>::Native>>

Convert to a Vec of Option<T::Native>.

Source

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>

Source

pub unsafe fn group_tuples_perfect( &self, num_groups: usize, multithreaded: bool, group_capacity: usize, ) -> GroupsType

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>

Source

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>

We cannot override the left hand side behaviour. So we create a trait LhsNumOps. This allows for 1.add(&Series)

Source

pub fn lhs_sub<N>(&self, lhs: N) -> ChunkedArray<T>
where N: Num + NumCast,

Apply lhs - self

Source

pub fn lhs_div<N>(&self, lhs: N) -> ChunkedArray<T>
where N: Num + NumCast,

Apply lhs / self

Source

pub fn lhs_rem<N>(&self, lhs: N) -> ChunkedArray<T>
where N: Num + NumCast,

Apply lhs % self

Trait Implementations

Source§

impl<T, N> Add<N> for ChunkedArray<T>

Source§

type Output = ChunkedArray<T>

The resulting type after applying the + operator.
Source§

fn add(self, rhs: N) -> <ChunkedArray<T> as Add<N>>::Output

Performs the + operation. Read more
Source§

impl<T> Add for ChunkedArray<T>

Source§

type Output = ChunkedArray<T>

The resulting type after applying the + operator.
Source§

fn add(self, rhs: ChunkedArray<T>) -> <ChunkedArray<T> as Add>::Output

Performs the + operation. Read more
Source§

impl AggList for ChunkedArray<StructType>

Available on crate feature dtype-struct only.
Source§

unsafe fn agg_list(&self, groups: &GroupsType) -> Series

Safety Read more
Source§

impl<T> AggList for ChunkedArray<T>

Source§

unsafe fn agg_list(&self, groups: &GroupsType) -> Series

Safety Read more
Source§

impl<T> ArithmeticChunked for ChunkedArray<T>

Source§

type Scalar = <T as PolarsNumericType>::Native

Source§

type Out = ChunkedArray<T>

Source§

type TrueDivOut = ChunkedArray<<<T as PolarsNumericType>::Native as NumericNative>::TrueDivPolarsType>

Source§

fn wrapping_abs(self) -> <ChunkedArray<T> as ArithmeticChunked>::Out

Source§

fn wrapping_neg(self) -> <ChunkedArray<T> as ArithmeticChunked>::Out

Source§

fn wrapping_add( self, rhs: ChunkedArray<T>, ) -> <ChunkedArray<T> as ArithmeticChunked>::Out

Source§

fn wrapping_sub( self, rhs: ChunkedArray<T>, ) -> <ChunkedArray<T> as ArithmeticChunked>::Out

Source§

fn wrapping_mul( self, rhs: ChunkedArray<T>, ) -> <ChunkedArray<T> as ArithmeticChunked>::Out

Source§

fn wrapping_floor_div( self, rhs: ChunkedArray<T>, ) -> <ChunkedArray<T> as ArithmeticChunked>::Out

Source§

fn wrapping_trunc_div( self, rhs: ChunkedArray<T>, ) -> <ChunkedArray<T> as ArithmeticChunked>::Out

Source§

fn wrapping_mod( self, rhs: ChunkedArray<T>, ) -> <ChunkedArray<T> as ArithmeticChunked>::Out

Source§

fn wrapping_add_scalar( self, rhs: <ChunkedArray<T> as ArithmeticChunked>::Scalar, ) -> <ChunkedArray<T> as ArithmeticChunked>::Out

Source§

fn wrapping_sub_scalar( self, rhs: <ChunkedArray<T> as ArithmeticChunked>::Scalar, ) -> <ChunkedArray<T> as ArithmeticChunked>::Out

Source§

fn wrapping_sub_scalar_lhs( lhs: <ChunkedArray<T> as ArithmeticChunked>::Scalar, rhs: ChunkedArray<T>, ) -> <ChunkedArray<T> as ArithmeticChunked>::Out

Source§

fn wrapping_mul_scalar( self, rhs: <ChunkedArray<T> as ArithmeticChunked>::Scalar, ) -> <ChunkedArray<T> as ArithmeticChunked>::Out

Source§

fn wrapping_floor_div_scalar( self, rhs: <ChunkedArray<T> as ArithmeticChunked>::Scalar, ) -> <ChunkedArray<T> as ArithmeticChunked>::Out

Source§

fn wrapping_floor_div_scalar_lhs( lhs: <ChunkedArray<T> as ArithmeticChunked>::Scalar, rhs: ChunkedArray<T>, ) -> <ChunkedArray<T> as ArithmeticChunked>::Out

Source§

fn wrapping_trunc_div_scalar( self, rhs: <ChunkedArray<T> as ArithmeticChunked>::Scalar, ) -> <ChunkedArray<T> as ArithmeticChunked>::Out

Source§

fn wrapping_trunc_div_scalar_lhs( lhs: <ChunkedArray<T> as ArithmeticChunked>::Scalar, rhs: ChunkedArray<T>, ) -> <ChunkedArray<T> as ArithmeticChunked>::Out

Source§

fn wrapping_mod_scalar( self, rhs: <ChunkedArray<T> as ArithmeticChunked>::Scalar, ) -> <ChunkedArray<T> as ArithmeticChunked>::Out

Source§

fn wrapping_mod_scalar_lhs( lhs: <ChunkedArray<T> as ArithmeticChunked>::Scalar, rhs: ChunkedArray<T>, ) -> <ChunkedArray<T> as ArithmeticChunked>::Out

Source§

fn true_div( self, rhs: ChunkedArray<T>, ) -> <ChunkedArray<T> as ArithmeticChunked>::TrueDivOut

Source§

fn true_div_scalar( self, rhs: <ChunkedArray<T> as ArithmeticChunked>::Scalar, ) -> <ChunkedArray<T> as ArithmeticChunked>::TrueDivOut

Source§

fn true_div_scalar_lhs( lhs: <ChunkedArray<T> as ArithmeticChunked>::Scalar, rhs: ChunkedArray<T>, ) -> <ChunkedArray<T> as ArithmeticChunked>::TrueDivOut

Source§

fn legacy_div( self, rhs: ChunkedArray<T>, ) -> <ChunkedArray<T> as ArithmeticChunked>::Out

Source§

fn legacy_div_scalar( self, rhs: <ChunkedArray<T> as ArithmeticChunked>::Scalar, ) -> <ChunkedArray<T> as ArithmeticChunked>::Out

Source§

fn legacy_div_scalar_lhs( lhs: <ChunkedArray<T> as ArithmeticChunked>::Scalar, rhs: ChunkedArray<T>, ) -> <ChunkedArray<T> as ArithmeticChunked>::Out

Source§

impl<T> AsRef<ChunkedArray<T>> for ChunkedArray<T>
where T: PolarsDataType,

Source§

fn as_ref(&self) -> &ChunkedArray<T>

Converts this type into a shared reference of the (usually inferred) input type.
Source§

impl<T> AsRefDataType for ChunkedArray<T>
where T: PolarsDataType,

Source§

impl<T> ChunkAgg<<T as PolarsNumericType>::Native> for ChunkedArray<T>
where T: PolarsNumericType, <T as PolarsNumericType>::Native: WrappingSum, PrimitiveArray<<T as PolarsNumericType>::Native>: for<'a> MinMaxKernel<Scalar<'a> = <T as PolarsNumericType>::Native>,

Source§

fn sum(&self) -> Option<<T as PolarsNumericType>::Native>

Aggregate the sum of the ChunkedArray. Returns None if not implemented for T. If the array is empty, 0 is returned
Source§

fn _sum_as_f64(&self) -> f64

Source§

fn min(&self) -> Option<<T as PolarsNumericType>::Native>

Source§

fn max(&self) -> Option<<T as PolarsNumericType>::Native>

Returns the maximum value in the array, according to the natural order. Returns None if the array is empty or only contains null values.
Source§

fn min_max( &self, ) -> Option<(<T as PolarsNumericType>::Native, <T as PolarsNumericType>::Native)>

Source§

fn mean(&self) -> Option<f64>

Returns the mean value in the array. Returns None if the array is empty or only contains null values.
Source§

impl<T> ChunkAggSeries for ChunkedArray<T>
where T: PolarsNumericType, <T as PolarsNumericType>::Native: WrappingSum, PrimitiveArray<<T as PolarsNumericType>::Native>: for<'a> MinMaxKernel<Scalar<'a> = <T as PolarsNumericType>::Native>, ChunkedArray<T>: IntoSeries,

Source§

fn sum_reduce(&self) -> Scalar

Get the sum of the ChunkedArray as a new Series of length 1.
Source§

fn max_reduce(&self) -> Scalar

Get the max of the ChunkedArray as a new Series of length 1.
Source§

fn min_reduce(&self) -> Scalar

Get the min of the ChunkedArray as a new Series of length 1.
Source§

fn prod_reduce(&self) -> Scalar

Get the product of the ChunkedArray as a new Series of length 1.
Source§

impl ChunkAnyValue for ChunkedArray<StructType>

Available on crate feature dtype-struct only.
Source§

fn get_any_value(&self, i: usize) -> Result<AnyValue<'_>, PolarsError>

Gets AnyValue from LogicalType

Source§

unsafe fn get_any_value_unchecked(&self, i: usize) -> AnyValue<'_>

Get a single value. Beware this is slow. If you need to use this slightly performant, cast Categorical to UInt32 Read more
Source§

impl<T> ChunkAnyValue for ChunkedArray<T>

Source§

unsafe fn get_any_value_unchecked(&self, index: usize) -> AnyValue<'_>

Get a single value. Beware this is slow. If you need to use this slightly performant, cast Categorical to UInt32 Read more
Source§

fn get_any_value(&self, index: usize) -> Result<AnyValue<'_>, PolarsError>

Get a single value. Beware this is slow.
Source§

impl<'a, T> ChunkApply<'a, <T as PolarsNumericType>::Native> for ChunkedArray<T>

Source§

type FuncRet = <T as PolarsNumericType>::Native

Source§

fn apply_values<F>(&'a self, f: F) -> ChunkedArray<T>
where F: Fn(<T as PolarsNumericType>::Native) -> <T as PolarsNumericType>::Native + Copy,

Apply a closure elementwise. This is fastest when the null check branching is more expensive than the closure application. Often it is. Read more
Source§

fn apply<F>(&'a self, f: F) -> ChunkedArray<T>

Apply a closure elementwise including null values.
Source§

fn apply_to_slice<F, V>(&'a self, f: F, slice: &mut [V])
where F: Fn(Option<<T as PolarsNumericType>::Native>, &V) -> V,

Apply a closure elementwise and write results to a mutable slice.
Source§

impl<T> ChunkApplyKernel<PrimitiveArray<<T as PolarsNumericType>::Native>> for ChunkedArray<T>

Source§

fn apply_kernel( &self, f: &dyn Fn(&PrimitiveArray<<T as PolarsNumericType>::Native>) -> Box<dyn Array>, ) -> ChunkedArray<T>

Apply kernel and return result as a new ChunkedArray.
Source§

fn apply_kernel_cast<S>( &self, f: &dyn Fn(&PrimitiveArray<<T as PolarsNumericType>::Native>) -> Box<dyn Array>, ) -> ChunkedArray<S>
where S: PolarsDataType,

Apply a kernel that outputs an array of different type.
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,

Source§

impl<T> ChunkCast for ChunkedArray<T>

Source§

fn cast_with_options( &self, dtype: &DataType, options: CastOptions, ) -> Result<Series, PolarsError>

Source§

unsafe fn cast_unchecked(&self, dtype: &DataType) -> Result<Series, PolarsError>

Does not check if the cast is a valid one and may over/underflow Read more
Source§

fn cast(&self, dtype: &DataType) -> Result<Series, PolarsError>

Source§

impl ChunkCompareEq<&ChunkedArray<StructType>> for ChunkedArray<StructType>

Available on crate feature dtype-struct only.
Source§

type Item = ChunkedArray<BooleanType>

Source§

fn equal(&self, rhs: &ChunkedArray<StructType>) -> ChunkedArray<BooleanType>

Check for equality.
Source§

fn equal_missing( &self, rhs: &ChunkedArray<StructType>, ) -> ChunkedArray<BooleanType>

Check for equality where None == None.
Source§

fn not_equal(&self, rhs: &ChunkedArray<StructType>) -> ChunkedArray<BooleanType>

Check for inequality.
Source§

fn not_equal_missing( &self, rhs: &ChunkedArray<StructType>, ) -> ChunkedArray<BooleanType>

Check for inequality where 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,

Source§

type Item = ChunkedArray<BooleanType>

Source§

fn equal(&self, rhs: &ChunkedArray<T>) -> ChunkedArray<BooleanType>

Check for equality.
Source§

fn equal_missing(&self, rhs: &ChunkedArray<T>) -> ChunkedArray<BooleanType>

Check for equality where None == None.
Source§

fn not_equal(&self, rhs: &ChunkedArray<T>) -> ChunkedArray<BooleanType>

Check for inequality.
Source§

fn not_equal_missing(&self, rhs: &ChunkedArray<T>) -> ChunkedArray<BooleanType>

Check for inequality where 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>,

Source§

type Item = ChunkedArray<BooleanType>

Source§

fn equal(&self, rhs: Rhs) -> ChunkedArray<BooleanType>

Check for equality.
Source§

fn equal_missing(&self, rhs: Rhs) -> ChunkedArray<BooleanType>

Check for equality where None == None.
Source§

fn not_equal(&self, rhs: Rhs) -> ChunkedArray<BooleanType>

Check for inequality.
Source§

fn not_equal_missing(&self, rhs: Rhs) -> ChunkedArray<BooleanType>

Check for inequality where None == None.
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,

Source§

type Item = ChunkedArray<BooleanType>

Source§

fn lt(&self, rhs: &ChunkedArray<T>) -> ChunkedArray<BooleanType>

Less than comparison.
Source§

fn lt_eq(&self, rhs: &ChunkedArray<T>) -> ChunkedArray<BooleanType>

Less than or equal comparison
Source§

fn gt(&self, rhs: &ChunkedArray<T>) -> ChunkedArray<BooleanType>

Greater than comparison.
Source§

fn gt_eq(&self, rhs: &ChunkedArray<T>) -> ChunkedArray<BooleanType>

Greater than or equal comparison.
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>,

Source§

type Item = ChunkedArray<BooleanType>

Source§

fn gt(&self, rhs: Rhs) -> ChunkedArray<BooleanType>

Greater than comparison.
Source§

fn gt_eq(&self, rhs: Rhs) -> ChunkedArray<BooleanType>

Greater than or equal comparison.
Source§

fn lt(&self, rhs: Rhs) -> ChunkedArray<BooleanType>

Less than comparison.
Source§

fn lt_eq(&self, rhs: Rhs) -> ChunkedArray<BooleanType>

Less than or equal comparison
Source§

impl ChunkExpandAtIndex<StructType> for ChunkedArray<StructType>

Available on crate feature dtype-struct only.
Source§

fn new_from_index( &self, index: usize, length: usize, ) -> ChunkedArray<StructType>

Create a new ChunkedArray filled with values at that index.
Source§

impl<T> ChunkExpandAtIndex<T> for ChunkedArray<T>

Source§

fn new_from_index(&self, index: usize, length: usize) -> ChunkedArray<T>

Create a new ChunkedArray filled with values at that index.
Source§

impl<T> ChunkFillNullValue<<T as PolarsNumericType>::Native> for ChunkedArray<T>

Source§

fn fill_null_with_values( &self, value: <T as PolarsNumericType>::Native, ) -> Result<ChunkedArray<T>, PolarsError>

Replace None values with a give value T.
Source§

impl<T> ChunkFilter<T> for ChunkedArray<T>
where T: PolarsDataType<HasViews = FalseT, IsObject = FalseT>,

Source§

fn filter( &self, filter: &ChunkedArray<BooleanType>, ) -> Result<ChunkedArray<T>, PolarsError>

Filter values in the ChunkedArray with a boolean mask. Read more
Source§

impl<T> ChunkFull<<T as PolarsNumericType>::Native> for ChunkedArray<T>

Source§

fn full( name: PlSmallStr, value: <T as PolarsNumericType>::Native, length: usize, ) -> ChunkedArray<T>

Create a ChunkedArray with a single value.
Source§

impl ChunkFullNull for ChunkedArray<StructType>

Available on crate feature dtype-struct only.
Source§

impl<T> ChunkFullNull for ChunkedArray<T>

Source§

impl<T> ChunkQuantile<f64> for ChunkedArray<T>

Source§

fn quantile( &self, quantile: f64, method: QuantileMethod, ) -> Result<Option<f64>, PolarsError>

Aggregate a given quantile of the ChunkedArray. Returns None if the array is empty or only contains null values.
Source§

fn median(&self) -> Option<f64>

Returns the mean value in the array. Returns None if the array is empty or only contains null values.
Source§

impl<T> ChunkReverse for ChunkedArray<T>

Source§

fn reverse(&self) -> ChunkedArray<T>

Return a reversed version of this array.
Source§

impl<T> ChunkRollApply for ChunkedArray<T>

Source§

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, T> ChunkSet<'a, <T as PolarsNumericType>::Native, <T as PolarsNumericType>::Native> for ChunkedArray<T>

Source§

fn scatter_single<I>( &'a self, idx: I, value: Option<<T as PolarsNumericType>::Native>, ) -> Result<ChunkedArray<T>, PolarsError>
where I: IntoIterator<Item = u32>,

Set the values at indexes idx to some optional value Option<T>. Read more
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>,

Set the values at indexes idx by applying a closure to these values. Read more
Source§

fn set( &'a self, mask: &ChunkedArray<BooleanType>, value: Option<<T as PolarsNumericType>::Native>, ) -> Result<ChunkedArray<T>, PolarsError>

Set the values where the mask evaluates to true to some optional value Option<T>. Read more
Source§

impl ChunkShift<StructType> for ChunkedArray<StructType>

Available on crate feature dtype-struct only.
Source§

fn shift(&self, periods: i64) -> ChunkedArray<StructType>

Source§

impl<T> ChunkShift<T> for ChunkedArray<T>

Source§

fn shift(&self, periods: i64) -> ChunkedArray<T>

Source§

impl<T> ChunkShiftFill<T, Option<<T as PolarsNumericType>::Native>> for ChunkedArray<T>

Source§

fn shift_and_fill( &self, periods: i64, fill_value: Option<<T as PolarsNumericType>::Native>, ) -> ChunkedArray<T>

Shift the values by a given period and fill the parts that will be empty due to this operation with fill_value.
Source§

impl ChunkSort<StructType> for ChunkedArray<StructType>

Available on crate feature dtype-struct only.
Source§

fn sort_with(&self, options: SortOptions) -> ChunkedArray<StructType>

Source§

fn sort(&self, descending: bool) -> ChunkedArray<StructType>

Returned a sorted ChunkedArray.
Source§

fn arg_sort(&self, options: SortOptions) -> ChunkedArray<UInt32Type>

Retrieve the indexes needed to sort this array.
Source§

fn arg_sort_multiple( &self, by: &[Column], _options: &SortMultipleOptions, ) -> Result<ChunkedArray<UInt32Type>, PolarsError>

Retrieve the indexes need to sort this and the other arrays.
Source§

impl<T> ChunkSort<T> for ChunkedArray<T>

Source§

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

Source§

fn sort_with(&self, options: SortOptions) -> ChunkedArray<T>

Source§

fn sort(&self, descending: bool) -> ChunkedArray<T>

Returned a sorted ChunkedArray.
Source§

fn arg_sort(&self, options: SortOptions) -> ChunkedArray<UInt32Type>

Retrieve the indexes needed to sort this array.
Source§

impl<T> ChunkTake<ChunkedArray<UInt32Type>> for ChunkedArray<T>

Source§

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>

Source§

fn take(&self, indices: &I) -> Result<ChunkedArray<T>, PolarsError>

Gather values from ChunkedArray by index.

Source§

impl ChunkTakeUnchecked<ChunkedArray<UInt32Type>> for ChunkedArray<StructType>

Available on crate feature dtype-struct only.
Source§

unsafe fn take_unchecked( &self, indices: &ChunkedArray<UInt32Type>, ) -> ChunkedArray<StructType>

Gather values from ChunkedArray by index. Read more
Source§

impl<T> ChunkTakeUnchecked<ChunkedArray<UInt32Type>> for ChunkedArray<T>
where T: PolarsDataType<HasViews = FalseT, IsStruct = FalseT, IsNested = FalseT> + PolarsDataType,

Source§

unsafe fn take_unchecked( &self, indices: &ChunkedArray<UInt32Type>, ) -> ChunkedArray<T>

Gather values from ChunkedArray by index.

Source§

impl<I> ChunkTakeUnchecked<I> for ChunkedArray<StructType>
where I: AsRef<[u32]> + ?Sized,

Available on crate feature dtype-struct only.
Source§

unsafe fn take_unchecked(&self, indices: &I) -> ChunkedArray<StructType>

Gather values from ChunkedArray by index. Read more
Source§

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>

Gather values from ChunkedArray by index.

Source§

impl<T> ChunkUnique for ChunkedArray<T>

Source§

fn unique(&self) -> Result<ChunkedArray<T>, PolarsError>

Get unique values of a ChunkedArray
Source§

fn arg_unique(&self) -> Result<ChunkedArray<UInt32Type>, PolarsError>

Get first index of the unique values in a ChunkedArray. This Vec is sorted.
Source§

fn n_unique(&self) -> Result<usize, PolarsError>

Number of unique values in the ChunkedArray
Source§

impl<T> ChunkVar for ChunkedArray<T>

Source§

fn var(&self, ddof: u8) -> Option<f64>

Compute the variance of this ChunkedArray/Series.
Source§

fn std(&self, ddof: u8) -> Option<f64>

Compute the standard deviation of this ChunkedArray/Series.
Source§

impl ChunkZip<StructType> for ChunkedArray<StructType>

Available on crate feature dtype-struct only.
Source§

fn zip_with( &self, mask: &ChunkedArray<BooleanType>, other: &ChunkedArray<StructType>, ) -> Result<ChunkedArray<StructType>, PolarsError>

Create a new ChunkedArray with values from self where the mask evaluates 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>,

Source§

fn zip_with( &self, mask: &ChunkedArray<BooleanType>, other: &ChunkedArray<T>, ) -> Result<ChunkedArray<T>, PolarsError>

Create a new ChunkedArray with values from self where the mask evaluates true and values from other where the mask evaluates false
Source§

impl<T> Clone for ChunkedArray<T>
where T: PolarsDataType,

Source§

fn clone(&self) -> ChunkedArray<T>

Returns a copy of the value. Read more
1.0.0 · Source§

fn clone_from(&mut self, source: &Self)

Performs copy-assignment from source. Read more
Source§

impl<T> Container for ChunkedArray<T>
where T: PolarsDataType,

Source§

fn slice(&self, offset: i64, len: usize) -> ChunkedArray<T>

Source§

fn split_at(&self, offset: i64) -> (ChunkedArray<T>, ChunkedArray<T>)

Source§

fn len(&self) -> usize

Source§

fn iter_chunks(&self) -> impl Iterator<Item = ChunkedArray<T>>

Source§

fn n_chunks(&self) -> usize

Source§

fn chunk_lengths(&self) -> impl Iterator<Item = usize>

Source§

impl<T> Debug for ChunkedArray<T>

Source§

fn fmt(&self, f: &mut Formatter<'_>) -> Result<(), Error>

Formats the value using the given formatter. Read more
Source§

impl<T> Default for ChunkedArray<T>
where T: PolarsDataType,

Source§

fn default() -> ChunkedArray<T>

Returns the “default value” for a type. Read more
Source§

impl<T, N> Div<N> for ChunkedArray<T>

Source§

type Output = ChunkedArray<T>

The resulting type after applying the / operator.
Source§

fn div(self, rhs: N) -> <ChunkedArray<T> as Div<N>>::Output

Performs the / operation. Read more
Source§

impl<T> Div for ChunkedArray<T>

Source§

type Output = ChunkedArray<T>

The resulting type after applying the / operator.
Source§

fn div(self, rhs: ChunkedArray<T>) -> <ChunkedArray<T> as Div>::Output

Performs the / operation. Read more
Source§

impl<T> Drop for ChunkedArray<T>
where T: PolarsDataType,

Source§

fn drop(&mut self)

Executes the destructor for this type. Read more
Source§

impl<T, A> From<A> for ChunkedArray<T>
where T: PolarsDataType<Array = A>, A: Array,

Source§

fn from(arr: A) -> ChunkedArray<T>

Converts to this type from the input type.
Source§

impl<T> FromIterator<(Vec<<T as PolarsNumericType>::Native>, Option<Bitmap>)> for ChunkedArray<T>

Source§

fn from_iter<I>(iter: I) -> ChunkedArray<T>
where I: IntoIterator<Item = (Vec<<T as PolarsNumericType>::Native>, Option<Bitmap>)>,

Creates a value from an iterator. Read more
Source§

impl<T> FromIterator<Option<<T as PolarsNumericType>::Native>> for ChunkedArray<T>

FromIterator trait

Source§

fn from_iter<I>(iter: I) -> ChunkedArray<T>
where I: IntoIterator<Item = Option<<T as PolarsNumericType>::Native>>,

Creates a value from an iterator. Read more
Source§

impl<T> FromIteratorReversed<Option<<T as PolarsNumericType>::Native>> for ChunkedArray<T>

Source§

fn from_trusted_len_iter_rev<I>(iter: I) -> ChunkedArray<T>
where I: TrustedLen<Item = Option<<T as PolarsNumericType>::Native>>,

Source§

impl<T> FromParallelIterator<Option<<T as PolarsNumericType>::Native>> for ChunkedArray<T>

Source§

fn from_par_iter<I>(iter: I) -> ChunkedArray<T>
where I: IntoParallelIterator<Item = Option<<T as PolarsNumericType>::Native>>,

Creates an instance of the collection from the parallel iterator par_iter. Read more
Source§

impl<T> FromTrustedLenIterator<Option<<T as PolarsNumericType>::Native>> for ChunkedArray<T>

Source§

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<T> IntoGroupsType for ChunkedArray<T>

Source§

fn group_tuples( &self, multithreaded: bool, sorted: bool, ) -> Result<GroupsType, PolarsError>

Create the tuples need for a group_by operation. * The first value in the tuple is the first index of the group. * The second value in the tuple is the indexes of the groups including the first value.
Source§

impl<T> IntoSeries for ChunkedArray<T>
where T: PolarsDataType + 'static, SeriesWrap<ChunkedArray<T>>: SeriesTrait,

Source§

impl<T, N> Mul<N> for ChunkedArray<T>

Source§

type Output = ChunkedArray<T>

The resulting type after applying the * operator.
Source§

fn mul(self, rhs: N) -> <ChunkedArray<T> as Mul<N>>::Output

Performs the * operation. Read more
Source§

impl<T> Mul for ChunkedArray<T>

Source§

type Output = ChunkedArray<T>

The resulting type after applying the * operator.
Source§

fn mul(self, rhs: ChunkedArray<T>) -> <ChunkedArray<T> as Mul>::Output

Performs the * operation. Read more
Source§

impl<T> NewChunkedArray<T, <T as PolarsNumericType>::Native> for ChunkedArray<T>

Source§

fn from_iter_values( name: PlSmallStr, it: impl Iterator<Item = <T as PolarsNumericType>::Native>, ) -> ChunkedArray<T>

Create a new ChunkedArray from an iterator.

Source§

fn from_slice( name: PlSmallStr, v: &[<T as PolarsNumericType>::Native], ) -> ChunkedArray<T>

Source§

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>

Create a new ChunkedArray from an iterator.
Source§

impl<T> NumOpsDispatch for ChunkedArray<T>

Source§

impl<S> NumOpsDispatchChecked for ChunkedArray<S>

Source§

fn checked_div(&self, rhs: &Series) -> Result<Series, PolarsError>

Checked integer division. Computes self / rhs, returning None if rhs == 0 or the division results in overflow.
Source§

fn checked_div_num<T>(&self, rhs: T) -> Result<Series, PolarsError>
where T: ToPrimitive,

Source§

impl<T> QuantileAggSeries for ChunkedArray<T>
where T: PolarsIntegerType, <T as PolarsNumericType>::Native: Ord + WrappingSum,

Source§

fn quantile_reduce( &self, quantile: f64, method: QuantileMethod, ) -> Result<Scalar, PolarsError>

Get the quantile of the ChunkedArray as a new Series of length 1.
Source§

fn median_reduce(&self) -> Scalar

Get the median of the ChunkedArray as a new Series of length 1.
Source§

impl<T, N> Rem<N> for ChunkedArray<T>

Source§

type Output = ChunkedArray<T>

The resulting type after applying the % operator.
Source§

fn rem(self, rhs: N) -> <ChunkedArray<T> as Rem<N>>::Output

Performs the % operation. Read more
Source§

impl<T> Rem for ChunkedArray<T>

Source§

type Output = ChunkedArray<T>

The resulting type after applying the % operator.
Source§

fn rem(self, rhs: ChunkedArray<T>) -> <ChunkedArray<T> as Rem>::Output

Performs the % operation. Read more
Source§

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,

Serialize this value into the given Serde serializer. Read more
Source§

impl<T, N> Sub<N> for ChunkedArray<T>

Source§

type Output = ChunkedArray<T>

The resulting type after applying the - operator.
Source§

fn sub(self, rhs: N) -> <ChunkedArray<T> as Sub<N>>::Output

Performs the - operation. Read more
Source§

impl<T> Sub for ChunkedArray<T>

Source§

type Output = ChunkedArray<T>

The resulting type after applying the - operator.
Source§

fn sub(self, rhs: ChunkedArray<T>) -> <ChunkedArray<T> as Sub>::Output

Performs the - operation. Read more
Source§

impl<T> TakeChunked for ChunkedArray<T>

Source§

unsafe fn take_chunked_unchecked<const B: u64>( &self, by: &[ChunkId<B>], sorted: IsSorted, _allow_sharing: bool, ) -> ChunkedArray<T>

Gathers elements from a ChunkedArray, specifying for each element a chunk index and index within that chunk through ChunkId. If avoid_sharing is true the returned data should not share references with the original array (like shared buffers in views). Read more
Source§

unsafe fn take_opt_chunked_unchecked<const B: u64>( &self, by: &[ChunkId<B>], _allow_sharing: bool, ) -> ChunkedArray<T>

Safety Read more
Source§

impl<T> VarAggSeries for ChunkedArray<T>

Source§

fn var_reduce(&self, ddof: u8) -> Scalar

Get the variance of the ChunkedArray as a new Series of length 1.
Source§

fn std_reduce(&self, ddof: u8) -> Scalar

Get the standard deviation of the ChunkedArray as a new Series of length 1.