Enum Column

Source
pub enum Column {
    Series(SeriesColumn),
    Partitioned(PartitionedColumn),
    Scalar(ScalarColumn),
}
Expand description

A column within a DataFrame.

This is lazily initialized to a Series with methods like as_materialized_series and take_materialized_series.

Currently, there are two ways to represent a Column.

  1. A Series of values
  2. A ScalarColumn that repeats a single Scalar

Variants§

§

Series(SeriesColumn)

§

Partitioned(PartitionedColumn)

§

Scalar(ScalarColumn)

Implementations§

Source§

impl Column

Source

pub fn new<T, Phantom>(name: PlSmallStr, values: T) -> Column
where Series: NamedFrom<T, Phantom>, Phantom: ?Sized,

Source

pub fn new_empty(name: PlSmallStr, dtype: &DataType) -> Column

Source

pub fn new_scalar(name: PlSmallStr, scalar: Scalar, length: usize) -> Column

Source

pub fn new_partitioned( name: PlSmallStr, scalar: Scalar, length: usize, ) -> Column

Source

pub fn new_row_index( name: PlSmallStr, offset: u32, length: usize, ) -> Result<Column, PolarsError>

Source

pub fn as_materialized_series(&self) -> &Series

Get a reference to a Series for this Column

This may need to materialize the Series on the first invocation for a specific column.

Source

pub fn as_materialized_series_maintain_scalar(&self) -> Series

If the memory repr of this Column is a scalar, a unit-length Series will be returned.

Source

pub fn _get_backing_series(&self) -> Series

Returns the backing Series for the values of this column.

  • For Column::Series columns, simply returns the inner Series.
  • For Column::Partitioned columns, returns the series representing the values.
  • For Column::Scalar columns, returns an empty or unit length series.
§Note

This method is safe to use. However, care must be taken when operating on the returned Series to ensure result correctness. E.g. It is suitable to perform elementwise operations on it, however e.g. aggregations will return unspecified results.

Source

pub fn _to_new_from_backing(&self, new_s: Series) -> Column

Constructs a new Column of the same variant as self from a backing Series representing the values.

§Panics

Panics if:

  • self is Column::Series and the length of new_s does not match that of self.
  • self is Column::Partitioned and the length of new_s does not match that of the existing partitions.
  • self is Column::Scalar and if either:
    • self is not empty and new_s is not of unit length.
    • self is empty and new_s is not empty.
Source

pub fn into_materialized_series(&mut self) -> &mut Series

Turn Column into a Column::Series.

This may need to materialize the Series on the first invocation for a specific column.

Source

pub fn take_materialized_series(self) -> Series

Take Series from a Column

This may need to materialize the Series on the first invocation for a specific column.

Source

pub fn dtype(&self) -> &DataType

Source

pub fn field(&self) -> Cow<'_, Field>

Source

pub fn name(&self) -> &PlSmallStr

Source

pub fn len(&self) -> usize

Source

pub fn with_name(self, name: PlSmallStr) -> Column

Source

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

Source

pub fn as_series(&self) -> Option<&Series>

Source

pub fn as_partitioned_column(&self) -> Option<&PartitionedColumn>

Source

pub fn as_scalar_column(&self) -> Option<&ScalarColumn>

Source

pub fn as_scalar_column_mut(&mut self) -> Option<&mut ScalarColumn>

Source

pub fn try_bool(&self) -> Option<&ChunkedArray<BooleanType>>

Source

pub fn try_i8(&self) -> Option<&ChunkedArray<Int8Type>>

Source

pub fn try_i16(&self) -> Option<&ChunkedArray<Int16Type>>

Source

pub fn try_i32(&self) -> Option<&ChunkedArray<Int32Type>>

Source

pub fn try_i64(&self) -> Option<&ChunkedArray<Int64Type>>

Source

pub fn try_u8(&self) -> Option<&ChunkedArray<UInt8Type>>

Source

pub fn try_u16(&self) -> Option<&ChunkedArray<UInt16Type>>

Source

pub fn try_u32(&self) -> Option<&ChunkedArray<UInt32Type>>

Source

pub fn try_u64(&self) -> Option<&ChunkedArray<UInt64Type>>

Source

pub fn try_f32(&self) -> Option<&ChunkedArray<Float32Type>>

Source

pub fn try_f64(&self) -> Option<&ChunkedArray<Float64Type>>

Source

pub fn try_str(&self) -> Option<&ChunkedArray<StringType>>

Source

pub fn try_list(&self) -> Option<&ChunkedArray<ListType>>

Source

pub fn try_binary(&self) -> Option<&ChunkedArray<BinaryType>>

Source

pub fn try_idx(&self) -> Option<&ChunkedArray<UInt32Type>>

Source

pub fn try_binary_offset(&self) -> Option<&ChunkedArray<BinaryOffsetType>>

Source

pub fn try_datetime(&self) -> Option<&Logical<DatetimeType, Int64Type>>

Source

pub fn try_struct(&self) -> Option<&ChunkedArray<StructType>>

Source

pub fn try_decimal(&self) -> Option<&Logical<DecimalType, Int128Type>>

Source

pub fn try_array(&self) -> Option<&ChunkedArray<FixedSizeListType>>

Source

pub fn try_cat<T>( &self, ) -> Option<&Logical<T, <T as PolarsCategoricalType>::PolarsPhysical>>

Source

pub fn try_cat8( &self, ) -> Option<&Logical<Categorical8Type, <Categorical8Type as PolarsCategoricalType>::PolarsPhysical>>

Source

pub fn try_cat16( &self, ) -> Option<&Logical<Categorical16Type, <Categorical16Type as PolarsCategoricalType>::PolarsPhysical>>

Source

pub fn try_cat32( &self, ) -> Option<&Logical<Categorical32Type, <Categorical32Type as PolarsCategoricalType>::PolarsPhysical>>

Source

pub fn try_date(&self) -> Option<&Logical<DateType, Int32Type>>

Source

pub fn try_duration(&self) -> Option<&Logical<DurationType, Int64Type>>

Source

pub fn bool(&self) -> Result<&ChunkedArray<BooleanType>, PolarsError>

Source

pub fn i8(&self) -> Result<&ChunkedArray<Int8Type>, PolarsError>

Source

pub fn i16(&self) -> Result<&ChunkedArray<Int16Type>, PolarsError>

Source

pub fn i32(&self) -> Result<&ChunkedArray<Int32Type>, PolarsError>

Source

pub fn i64(&self) -> Result<&ChunkedArray<Int64Type>, PolarsError>

Source

pub fn i128(&self) -> Result<&ChunkedArray<Int128Type>, PolarsError>

Source

pub fn u8(&self) -> Result<&ChunkedArray<UInt8Type>, PolarsError>

Source

pub fn u16(&self) -> Result<&ChunkedArray<UInt16Type>, PolarsError>

Source

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

Source

pub fn u64(&self) -> Result<&ChunkedArray<UInt64Type>, PolarsError>

Source

pub fn f32(&self) -> Result<&ChunkedArray<Float32Type>, PolarsError>

Source

pub fn f64(&self) -> Result<&ChunkedArray<Float64Type>, PolarsError>

Source

pub fn str(&self) -> Result<&ChunkedArray<StringType>, PolarsError>

Source

pub fn list(&self) -> Result<&ChunkedArray<ListType>, PolarsError>

Source

pub fn binary(&self) -> Result<&ChunkedArray<BinaryType>, PolarsError>

Source

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

Source

pub fn binary_offset( &self, ) -> Result<&ChunkedArray<BinaryOffsetType>, PolarsError>

Source

pub fn datetime(&self) -> Result<&Logical<DatetimeType, Int64Type>, PolarsError>

Source

pub fn struct_(&self) -> Result<&ChunkedArray<StructType>, PolarsError>

Source

pub fn decimal(&self) -> Result<&Logical<DecimalType, Int128Type>, PolarsError>

Source

pub fn array(&self) -> Result<&ChunkedArray<FixedSizeListType>, PolarsError>

Source

pub fn cat<T>( &self, ) -> Result<&Logical<T, <T as PolarsCategoricalType>::PolarsPhysical>, PolarsError>

Source

pub fn cat8( &self, ) -> Result<&Logical<Categorical8Type, <Categorical8Type as PolarsCategoricalType>::PolarsPhysical>, PolarsError>

Source

pub fn cat16( &self, ) -> Result<&Logical<Categorical16Type, <Categorical16Type as PolarsCategoricalType>::PolarsPhysical>, PolarsError>

Source

pub fn cat32( &self, ) -> Result<&Logical<Categorical32Type, <Categorical32Type as PolarsCategoricalType>::PolarsPhysical>, PolarsError>

Source

pub fn date(&self) -> Result<&Logical<DateType, Int32Type>, PolarsError>

Source

pub fn duration(&self) -> Result<&Logical<DurationType, Int64Type>, PolarsError>

Source

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

Source

pub fn strict_cast(&self, dtype: &DataType) -> Result<Column, PolarsError>

Source

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

Source

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

§Safety

This can lead to invalid memory access in downstream code.

Source

pub fn clear(&self) -> Column

Source

pub fn shrink_to_fit(&mut self)

Source

pub fn new_from_index(&self, index: usize, length: usize) -> Column

Source

pub fn has_nulls(&self) -> bool

Source

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

Source

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

Source

pub fn to_physical_repr(&self) -> Column

Source

pub unsafe fn from_physical_unchecked( &self, dtype: &DataType, ) -> Result<Column, PolarsError>

§Safety

This can lead to invalid memory access in downstream code.

Source

pub fn head(&self, length: Option<usize>) -> Column

Source

pub fn tail(&self, length: Option<usize>) -> Column

Source

pub fn slice(&self, offset: i64, length: usize) -> Column

Source

pub fn split_at(&self, offset: i64) -> (Column, Column)

Source

pub fn null_count(&self) -> usize

Source

pub fn take( &self, indices: &ChunkedArray<UInt32Type>, ) -> Result<Column, PolarsError>

Source

pub fn take_slice(&self, indices: &[u32]) -> Result<Column, PolarsError>

Source

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

§Safety

No bounds on the indexes are performed.

Source

pub unsafe fn take_slice_unchecked(&self, indices: &[u32]) -> Column

§Safety

No bounds on the indexes are performed.

Source

pub unsafe fn agg_min(&self, groups: &GroupsType) -> Column

§Safety

Does no bounds checks, groups must be correct.

Source

pub unsafe fn agg_max(&self, groups: &GroupsType) -> Column

§Safety

Does no bounds checks, groups must be correct.

Source

pub unsafe fn agg_mean(&self, groups: &GroupsType) -> Column

§Safety

Does no bounds checks, groups must be correct.

Source

pub unsafe fn agg_sum(&self, groups: &GroupsType) -> Column

§Safety

Does no bounds checks, groups must be correct.

Source

pub unsafe fn agg_first(&self, groups: &GroupsType) -> Column

§Safety

Does no bounds checks, groups must be correct.

Source

pub unsafe fn agg_last(&self, groups: &GroupsType) -> Column

§Safety

Does no bounds checks, groups must be correct.

Source

pub unsafe fn agg_n_unique(&self, groups: &GroupsType) -> Column

§Safety

Does no bounds checks, groups must be correct.

Source

pub unsafe fn agg_quantile( &self, groups: &GroupsType, quantile: f64, method: QuantileMethod, ) -> Column

§Safety

Does no bounds checks, groups must be correct.

Source

pub unsafe fn agg_median(&self, groups: &GroupsType) -> Column

§Safety

Does no bounds checks, groups must be correct.

Source

pub unsafe fn agg_var(&self, groups: &GroupsType, ddof: u8) -> Column

§Safety

Does no bounds checks, groups must be correct.

Source

pub unsafe fn agg_std(&self, groups: &GroupsType, ddof: u8) -> Column

§Safety

Does no bounds checks, groups must be correct.

Source

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

§Safety

Does no bounds checks, groups must be correct.

Source

pub fn agg_valid_count(&self, groups: &GroupsType) -> Column

§Safety

Does no bounds checks, groups must be correct.

Source

pub fn agg_and(&self, groups: &GroupsType) -> Column

§Safety

Does no bounds checks, groups must be correct.

Source

pub fn agg_or(&self, groups: &GroupsType) -> Column

§Safety

Does no bounds checks, groups must be correct.

Source

pub fn agg_xor(&self, groups: &GroupsType) -> Column

§Safety

Does no bounds checks, groups must be correct.

Source

pub fn full_null(name: PlSmallStr, size: usize, dtype: &DataType) -> Column

Source

pub fn is_empty(&self) -> bool

Source

pub fn reverse(&self) -> Column

Source

pub fn equals(&self, other: &Column) -> bool

Source

pub fn equals_missing(&self, other: &Column) -> bool

Source

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

Source

pub fn get_flags(&self) -> StatisticsFlags

Source

pub fn set_flags(&mut self, flags: StatisticsFlags) -> bool

Returns whether the flags were set

Source

pub fn vec_hash( &self, build_hasher: SeedableRandomState, buf: &mut Vec<u64>, ) -> Result<(), PolarsError>

Source

pub fn vec_hash_combine( &self, build_hasher: SeedableRandomState, hashes: &mut [u64], ) -> Result<(), PolarsError>

Source

pub fn append(&mut self, other: &Column) -> Result<&mut Column, PolarsError>

Source

pub fn append_owned( &mut self, other: Column, ) -> Result<&mut Column, PolarsError>

Source

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

Source

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

Source

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

Source

pub fn bit_repr(&self) -> Option<BitRepr>

Source

pub fn into_frame(self) -> DataFrame

Source

pub fn extend(&mut self, other: &Column) -> Result<&mut Column, PolarsError>

Source

pub fn rechunk(&self) -> Column

Source

pub fn explode(&self, skip_empty: bool) -> Result<Column, PolarsError>

Source

pub fn implode(&self) -> Result<ChunkedArray<ListType>, PolarsError>

Source

pub fn fill_null( &self, strategy: FillNullStrategy, ) -> Result<Column, PolarsError>

Source

pub fn divide(&self, rhs: &Column) -> Result<Column, PolarsError>

Source

pub fn shift(&self, periods: i64) -> Column

Source

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

Source

pub fn zip_with_same_type( &self, mask: &ChunkedArray<BooleanType>, other: &Column, ) -> Result<Column, PolarsError>

Source

pub fn drop_nulls(&self) -> Column

Source

pub fn as_list(&self) -> ChunkedArray<ListType>

Packs every element into a list.

Source

pub fn is_sorted_flag(&self) -> IsSorted

Source

pub fn unique(&self) -> Result<Column, PolarsError>

Source

pub fn unique_stable(&self) -> Result<Column, PolarsError>

Source

pub fn reshape_list( &self, dimensions: &[ReshapeDimension], ) -> Result<Column, PolarsError>

Source

pub fn reshape_array( &self, dimensions: &[ReshapeDimension], ) -> Result<Column, PolarsError>

Source

pub fn sort(&self, sort_options: SortOptions) -> Result<Column, PolarsError>

Source

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

Source

pub fn shuffle(&self, seed: Option<u64>) -> Column

Source

pub fn sample_frac( &self, frac: f64, with_replacement: bool, shuffle: bool, seed: Option<u64>, ) -> Result<Column, PolarsError>

Source

pub fn sample_n( &self, n: usize, with_replacement: bool, shuffle: bool, seed: Option<u64>, ) -> Result<Column, PolarsError>

Source

pub fn gather_every( &self, n: usize, offset: usize, ) -> Result<Column, PolarsError>

Source

pub fn extend_constant( &self, value: AnyValue<'_>, n: usize, ) -> Result<Column, PolarsError>

Source

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

Source

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

Source

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

Source

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

Source

pub fn wrapping_trunc_div_scalar<T>(&self, rhs: T) -> Column
where T: Num + NumCast,

Source

pub fn product(&self) -> Result<Scalar, PolarsError>

Source

pub fn phys_iter(&self) -> Box<dyn ExactSizeIterator<Item = AnyValue<'_>> + '_>

Source

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

Source

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

§Safety

Does not perform bounds check on index

Source

pub fn get_object( &self, index: usize, ) -> Option<&(dyn PolarsObjectSafe + 'static)>

Source

pub fn bitand(&self, rhs: &Column) -> Result<Column, PolarsError>

Source

pub fn bitor(&self, rhs: &Column) -> Result<Column, PolarsError>

Source

pub fn bitxor(&self, rhs: &Column) -> Result<Column, PolarsError>

Source

pub fn try_add_owned(self, other: Column) -> Result<Column, PolarsError>

Source

pub fn try_sub_owned(self, other: Column) -> Result<Column, PolarsError>

Source

pub fn try_mul_owned(self, other: Column) -> Result<Column, PolarsError>

Source

pub fn min_reduce(&self) -> Result<Scalar, PolarsError>

Source

pub fn max_reduce(&self) -> Result<Scalar, PolarsError>

Source

pub fn median_reduce(&self) -> Result<Scalar, PolarsError>

Source

pub fn mean_reduce(&self) -> Scalar

Source

pub fn std_reduce(&self, ddof: u8) -> Result<Scalar, PolarsError>

Source

pub fn var_reduce(&self, ddof: u8) -> Result<Scalar, PolarsError>

Source

pub fn sum_reduce(&self) -> Result<Scalar, PolarsError>

Source

pub fn and_reduce(&self) -> Result<Scalar, PolarsError>

Source

pub fn or_reduce(&self) -> Result<Scalar, PolarsError>

Source

pub fn xor_reduce(&self) -> Result<Scalar, PolarsError>

Source

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

Source

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

Source

pub fn sort_with(&self, options: SortOptions) -> Result<Column, PolarsError>

Source

pub fn map_unary_elementwise_to_bool( &self, f: impl Fn(&Series) -> ChunkedArray<BooleanType>, ) -> ChunkedArray<BooleanType>

Source

pub fn try_map_unary_elementwise_to_bool( &self, f: impl Fn(&Series) -> Result<ChunkedArray<BooleanType>, PolarsError>, ) -> Result<ChunkedArray<BooleanType>, PolarsError>

Source

pub fn apply_unary_elementwise(&self, f: impl Fn(&Series) -> Series) -> Column

Source

pub fn try_apply_unary_elementwise( &self, f: impl Fn(&Series) -> Result<Series, PolarsError>, ) -> Result<Column, PolarsError>

Source

pub fn apply_broadcasting_binary_elementwise( &self, other: &Column, op: impl Fn(&Series, &Series) -> Series, ) -> Result<Column, PolarsError>

Source

pub fn try_apply_broadcasting_binary_elementwise( &self, other: &Column, op: impl Fn(&Series, &Series) -> Result<Series, PolarsError>, ) -> Result<Column, PolarsError>

Source

pub fn apply_binary_elementwise( &self, other: &Column, f: impl Fn(&Series, &Series) -> Series, f_lb: impl Fn(&Scalar, &Series) -> Series, f_rb: impl Fn(&Series, &Scalar) -> Series, ) -> Column

Source

pub fn try_apply_binary_elementwise( &self, other: &Column, f: impl Fn(&Series, &Series) -> Result<Series, PolarsError>, f_lb: impl Fn(&Scalar, &Series) -> Result<Series, PolarsError>, f_rb: impl Fn(&Series, &Scalar) -> Result<Series, PolarsError>, ) -> Result<Column, PolarsError>

Source

pub fn approx_n_unique(&self) -> Result<u32, PolarsError>

Source

pub fn n_chunks(&self) -> usize

Source

pub fn rechunk_to_arrow(self, compat_level: CompatLevel) -> Box<dyn Array>

Source

pub fn trim_lists_to_normalized_offsets(&self) -> Option<Column>

Source

pub fn propagate_nulls(&self) -> Option<Column>

Trait Implementations§

Source§

impl<T> Add<T> for &Column
where T: Num + NumCast,

Source§

type Output = Column

The resulting type after applying the + operator.
Source§

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

Performs the + operation. Read more
Source§

impl<T> Add<T> for Column
where T: Num + NumCast,

Source§

type Output = Column

The resulting type after applying the + operator.
Source§

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

Performs the + operation. Read more
Source§

impl Add for &Column

Source§

type Output = Result<Column, PolarsError>

The resulting type after applying the + operator.
Source§

fn add(self, rhs: &Column) -> <&Column as Add>::Output

Performs the + operation. Read more
Source§

impl Add for Column

Source§

type Output = Result<Column, PolarsError>

The resulting type after applying the + operator.
Source§

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

Performs the + operation. Read more
Source§

impl BitAnd for &Column

Source§

type Output = Result<Column, PolarsError>

The resulting type after applying the & operator.
Source§

fn bitand(self, rhs: &Column) -> <&Column as BitAnd>::Output

Performs the & operation. Read more
Source§

impl BitAnd for Column

Source§

type Output = Result<Column, PolarsError>

The resulting type after applying the & operator.
Source§

fn bitand(self, rhs: Column) -> <Column as BitAnd>::Output

Performs the & operation. Read more
Source§

impl BitOr for &Column

Source§

type Output = Result<Column, PolarsError>

The resulting type after applying the | operator.
Source§

fn bitor(self, rhs: &Column) -> <&Column as BitOr>::Output

Performs the | operation. Read more
Source§

impl BitOr for Column

Source§

type Output = Result<Column, PolarsError>

The resulting type after applying the | operator.
Source§

fn bitor(self, rhs: Column) -> <Column as BitOr>::Output

Performs the | operation. Read more
Source§

impl BitXor for &Column

Source§

type Output = Result<Column, PolarsError>

The resulting type after applying the ^ operator.
Source§

fn bitxor(self, rhs: &Column) -> <&Column as BitXor>::Output

Performs the ^ operation. Read more
Source§

impl BitXor for Column

Source§

type Output = Result<Column, PolarsError>

The resulting type after applying the ^ operator.
Source§

fn bitxor(self, rhs: Column) -> <Column as BitXor>::Output

Performs the ^ operation. Read more
Source§

impl ChunkCompareEq<&Column> for Column

Source§

fn equal(&self, rhs: &Column) -> Result<ChunkedArray<BooleanType>, PolarsError>

Create a boolean mask by checking for equality.

Source§

fn equal_missing( &self, rhs: &Column, ) -> Result<ChunkedArray<BooleanType>, PolarsError>

Create a boolean mask by checking for equality.

Source§

fn not_equal( &self, rhs: &Column, ) -> Result<ChunkedArray<BooleanType>, PolarsError>

Create a boolean mask by checking for inequality.

Source§

fn not_equal_missing( &self, rhs: &Column, ) -> Result<ChunkedArray<BooleanType>, PolarsError>

Create a boolean mask by checking for inequality.

Source§

type Item = Result<ChunkedArray<BooleanType>, PolarsError>

Source§

impl ChunkCompareIneq<&Column> for Column

Source§

fn gt(&self, rhs: &Column) -> Result<ChunkedArray<BooleanType>, PolarsError>

Create a boolean mask by checking if self > rhs.

Source§

fn gt_eq(&self, rhs: &Column) -> Result<ChunkedArray<BooleanType>, PolarsError>

Create a boolean mask by checking if self >= rhs.

Source§

fn lt(&self, rhs: &Column) -> Result<ChunkedArray<BooleanType>, PolarsError>

Create a boolean mask by checking if self < rhs.

Source§

fn lt_eq(&self, rhs: &Column) -> Result<ChunkedArray<BooleanType>, PolarsError>

Create a boolean mask by checking if self <= rhs.

Source§

type Item = Result<ChunkedArray<BooleanType>, PolarsError>

Source§

impl Clone for Column

Source§

fn clone(&self) -> Column

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

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

Performs copy-assignment from source. Read more
Source§

impl Debug for Column

Source§

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

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

impl Default for Column

Source§

fn default() -> Column

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

impl<'de> Deserialize<'de> for Column

Source§

fn deserialize<__D>( __deserializer: __D, ) -> Result<Column, <__D as Deserializer<'de>>::Error>
where __D: Deserializer<'de>,

Deserialize this value from the given Serde deserializer. Read more
Source§

impl<T> Div<T> for &Column
where T: Num + NumCast,

Source§

type Output = Column

The resulting type after applying the / operator.
Source§

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

Performs the / operation. Read more
Source§

impl<T> Div<T> for Column
where T: Num + NumCast,

Source§

type Output = Column

The resulting type after applying the / operator.
Source§

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

Performs the / operation. Read more
Source§

impl Div for &Column

Source§

type Output = Result<Column, PolarsError>

The resulting type after applying the / operator.
Source§

fn div(self, rhs: &Column) -> <&Column as Div>::Output

Performs the / operation. Read more
Source§

impl Div for Column

Source§

type Output = Result<Column, PolarsError>

The resulting type after applying the / operator.
Source§

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

Performs the / operation. Read more
Source§

impl From<PartitionedColumn> for Column

Source§

fn from(value: PartitionedColumn) -> Column

Converts to this type from the input type.
Source§

impl From<ScalarColumn> for Column

Source§

fn from(value: ScalarColumn) -> Column

Converts to this type from the input type.
Source§

impl From<Series> for Column

Source§

fn from(series: Series) -> Column

Converts to this type from the input type.
Source§

impl FromIterator<Column> for DataFrame

Source§

fn from_iter<T>(iter: T) -> DataFrame
where T: IntoIterator<Item = Column>,

§Panics

Panics if Column have different lengths.

Source§

impl IntoColumn for Column

Source§

impl<T> Mul<T> for &Column
where T: Num + NumCast,

Source§

type Output = Column

The resulting type after applying the * operator.
Source§

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

Performs the * operation. Read more
Source§

impl<T> Mul<T> for Column
where T: Num + NumCast,

Source§

type Output = Column

The resulting type after applying the * operator.
Source§

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

Performs the * operation. Read more
Source§

impl Mul for &Column

Source§

type Output = Result<Column, PolarsError>

The resulting type after applying the * operator.
Source§

fn mul(self, rhs: &Column) -> <&Column as Mul>::Output

Performs the * operation. Read more
Source§

impl Mul for Column

Source§

type Output = Result<Column, PolarsError>

The resulting type after applying the * operator.
Source§

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

Performs the * operation. Read more
Source§

impl PartialEq for Column

Source§

fn eq(&self, other: &Column) -> bool

Tests for self and other values to be equal, and is used by ==.
1.0.0 · Source§

const fn ne(&self, other: &Rhs) -> bool

Tests for !=. The default implementation is almost always sufficient, and should not be overridden without very good reason.
Source§

impl<T> Rem<T> for &Column
where T: Num + NumCast,

Source§

type Output = Column

The resulting type after applying the % operator.
Source§

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

Performs the % operation. Read more
Source§

impl<T> Rem<T> for Column
where T: Num + NumCast,

Source§

type Output = Column

The resulting type after applying the % operator.
Source§

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

Performs the % operation. Read more
Source§

impl Rem for &Column

Source§

type Output = Result<Column, PolarsError>

The resulting type after applying the % operator.
Source§

fn rem(self, rhs: &Column) -> <&Column as Rem>::Output

Performs the % operation. Read more
Source§

impl Rem for Column

Source§

type Output = Result<Column, PolarsError>

The resulting type after applying the % operator.
Source§

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

Performs the % operation. Read more
Source§

impl Serialize for Column

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> Sub<T> for &Column
where T: Num + NumCast,

Source§

type Output = Column

The resulting type after applying the - operator.
Source§

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

Performs the - operation. Read more
Source§

impl<T> Sub<T> for Column
where T: Num + NumCast,

Source§

type Output = Column

The resulting type after applying the - operator.
Source§

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

Performs the - operation. Read more
Source§

impl Sub for &Column

Source§

type Output = Result<Column, PolarsError>

The resulting type after applying the - operator.
Source§

fn sub(self, rhs: &Column) -> <&Column as Sub>::Output

Performs the - operation. Read more
Source§

impl Sub for Column

Source§

type Output = Result<Column, PolarsError>

The resulting type after applying the - operator.
Source§

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

Performs the - operation. Read more
Source§

impl TakeChunked for Column

Source§

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

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>], avoid_sharing: bool, ) -> Column

Safety Read more

Auto Trait Implementations§

§

impl !Freeze for Column

§

impl !RefUnwindSafe for Column

§

impl Send for Column

§

impl Sync for Column

§

impl Unpin for Column

§

impl !UnwindSafe for Column

Blanket Implementations§

Source§

impl<T> Any for T
where T: 'static + ?Sized,

Source§

fn type_id(&self) -> TypeId

Gets the TypeId of self. Read more
Source§

impl<T> Borrow<T> for T
where T: ?Sized,

Source§

fn borrow(&self) -> &T

Immutably borrows from an owned value. Read more
Source§

impl<T> BorrowMut<T> for T
where T: ?Sized,

Source§

fn borrow_mut(&mut self) -> &mut T

Mutably borrows from an owned value. Read more
Source§

impl<T> CloneToUninit for T
where T: Clone,

Source§

unsafe fn clone_to_uninit(&self, dest: *mut u8)

🔬This is a nightly-only experimental API. (clone_to_uninit)
Performs copy-assignment from self to dest. Read more
Source§

impl<T> DynClone for T
where T: Clone,

Source§

fn __clone_box(&self, _: Private) -> *mut ()

Source§

impl<T> From<T> for T

Source§

fn from(t: T) -> T

Returns the argument unchanged.

§

impl<T> Instrument for T

§

fn instrument(self, span: Span) -> Instrumented<Self>

Instruments this type with the provided [Span], returning an Instrumented wrapper. Read more
§

fn in_current_span(self) -> Instrumented<Self>

Instruments this type with the current Span, returning an Instrumented wrapper. Read more
Source§

impl<T, U> Into<U> for T
where U: From<T>,

Source§

fn into(self) -> U

Calls U::from(self).

That is, this conversion is whatever the implementation of From<T> for U chooses to do.

Source§

impl<T> IntoEither for T

Source§

fn into_either(self, into_left: bool) -> Either<Self, Self>

Converts 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 more
Source§

fn into_either_with<F>(self, into_left: F) -> Either<Self, Self>
where F: FnOnce(&Self) -> bool,

Converts 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
Source§

impl<T> Key for T
where T: Clone,

Source§

fn align() -> usize

The alignment necessary for the key. Must return a power of two.
Source§

fn size(&self) -> usize

The size of the key in bytes.
Source§

unsafe fn init(&self, ptr: *mut u8)

Initialize the key in the given memory location. Read more
Source§

unsafe fn get<'a>(ptr: *const u8) -> &'a T

Get a reference to the key from the given memory location. Read more
Source§

unsafe fn drop_in_place(ptr: *mut u8)

Drop the key in place. Read more
§

impl<T> Pointable for T

§

const ALIGN: usize

The alignment of pointer.
§

type Init = T

The type for initializers.
§

unsafe fn init(init: <T as Pointable>::Init) -> usize

Initializes a with the given initializer. Read more
§

unsafe fn deref<'a>(ptr: usize) -> &'a T

Dereferences the given pointer. Read more
§

unsafe fn deref_mut<'a>(ptr: usize) -> &'a mut T

Mutably dereferences the given pointer. Read more
§

unsafe fn drop(ptr: usize)

Drops the object pointed to by the given pointer. Read more
§

impl<T> PolicyExt for T
where T: ?Sized,

§

fn and<P, B, E>(self, other: P) -> And<T, P>
where T: Policy<B, E>, P: Policy<B, E>,

Create a new Policy that returns [Action::Follow] only if self and other return Action::Follow. Read more
§

fn or<P, B, E>(self, other: P) -> Or<T, P>
where T: Policy<B, E>, P: Policy<B, E>,

Create a new Policy that returns [Action::Follow] if either self or other returns Action::Follow. Read more
Source§

impl<T> ToOwned for T
where T: Clone,

Source§

type Owned = T

The resulting type after obtaining ownership.
Source§

fn to_owned(&self) -> T

Creates owned data from borrowed data, usually by cloning. Read more
Source§

fn clone_into(&self, target: &mut T)

Uses borrowed data to replace owned data, usually by cloning. Read more
Source§

impl<T, U> TryFrom<U> for T
where U: Into<T>,

Source§

type Error = Infallible

The type returned in the event of a conversion error.
Source§

fn try_from(value: U) -> Result<T, <T as TryFrom<U>>::Error>

Performs the conversion.
Source§

impl<T, U> TryInto<U> for T
where U: TryFrom<T>,

Source§

type Error = <U as TryFrom<T>>::Error

The type returned in the event of a conversion error.
Source§

fn try_into(self) -> Result<U, <U as TryFrom<T>>::Error>

Performs the conversion.
§

impl<V, T> VZip<V> for T
where V: MultiLane<T>,

§

fn vzip(self) -> V

§

impl<T> WithSubscriber for T

§

fn with_subscriber<S>(self, subscriber: S) -> WithDispatch<Self>
where S: Into<Dispatch>,

Attaches the provided Subscriber to this type, returning a [WithDispatch] wrapper. Read more
§

fn with_current_subscriber(self) -> WithDispatch<Self>

Attaches the current default Subscriber to this type, returning a [WithDispatch] wrapper. Read more
Source§

impl<T> DeserializeOwned for T
where T: for<'de> Deserialize<'de>,

§

impl<T> ErasedDestructor for T
where T: 'static,

Source§

impl<T, Rhs, Output> NumOps<Rhs, Output> for T
where T: Sub<Rhs, Output = Output> + Mul<Rhs, Output = Output> + Div<Rhs, Output = Output> + Add<Rhs, Output = Output> + Rem<Rhs, Output = Output>,

§

impl<T> PlanCallbackArgs for T

§

impl<T> PlanCallbackOut for T