Enum polars::prelude::Expr

source ·
pub enum Expr {
Show 26 variants Alias(Arc<Expr>, Arc<str>), Column(Arc<str>), Columns(Vec<String>), DtypeColumn(Vec<DataType>), Literal(LiteralValue), BinaryExpr { left: Arc<Expr>, op: Operator, right: Arc<Expr>, }, Cast { expr: Arc<Expr>, data_type: DataType, strict: bool, }, Sort { expr: Arc<Expr>, options: SortOptions, }, Gather { expr: Arc<Expr>, idx: Arc<Expr>, returns_scalar: bool, }, SortBy { expr: Arc<Expr>, by: Vec<Expr>, sort_options: SortMultipleOptions, }, Agg(AggExpr), Ternary { predicate: Arc<Expr>, truthy: Arc<Expr>, falsy: Arc<Expr>, }, Function { input: Vec<Expr>, function: FunctionExpr, options: FunctionOptions, }, Explode(Arc<Expr>), Filter { input: Arc<Expr>, by: Arc<Expr>, }, Window { function: Arc<Expr>, partition_by: Vec<Expr>, options: WindowType, }, Wildcard, Slice { input: Arc<Expr>, offset: Arc<Expr>, length: Arc<Expr>, }, Exclude(Arc<Expr>, Vec<Excluded>), KeepName(Arc<Expr>), Len, Nth(i64), RenameAlias { function: SpecialEq<Arc<dyn RenameAliasFn>>, expr: Arc<Expr>, }, AnonymousFunction { input: Vec<Expr>, function: SpecialEq<Arc<dyn SeriesUdf>>, output_type: SpecialEq<Arc<dyn FunctionOutputField>>, options: FunctionOptions, }, SubPlan(SpecialEq<Arc<LogicalPlan>>, Vec<String>), Selector(Selector),
}
Available on crate feature lazy only.
Expand description

Expressions that can be used in various contexts. Queries consist of multiple expressions. When using the polars lazy API, don’t construct an Expr directly; instead, create one using the functions in the polars_lazy::dsl module. See that module’s docs for more info.

Variants§

§

Alias(Arc<Expr>, Arc<str>)

§

Column(Arc<str>)

§

Columns(Vec<String>)

§

DtypeColumn(Vec<DataType>)

§

Literal(LiteralValue)

§

BinaryExpr

Fields

§left: Arc<Expr>
§right: Arc<Expr>
§

Cast

Fields

§expr: Arc<Expr>
§data_type: DataType
§strict: bool
§

Sort

Fields

§expr: Arc<Expr>
§options: SortOptions
§

Gather

Fields

§expr: Arc<Expr>
§idx: Arc<Expr>
§returns_scalar: bool
§

SortBy

Fields

§expr: Arc<Expr>
§by: Vec<Expr>
§sort_options: SortMultipleOptions
§

Agg(AggExpr)

§

Ternary

A ternary operation if true then “foo” else “bar”

Fields

§predicate: Arc<Expr>
§truthy: Arc<Expr>
§falsy: Arc<Expr>
§

Function

Fields

§input: Vec<Expr>

function arguments

§function: FunctionExpr

function to apply

§

Explode(Arc<Expr>)

§

Filter

Fields

§input: Arc<Expr>
§by: Arc<Expr>
§

Window

See postgres window functions

Fields

§function: Arc<Expr>

Also has the input. i.e. avg(“foo”)

§partition_by: Vec<Expr>
§options: WindowType
§

Wildcard

§

Slice

Fields

§input: Arc<Expr>
§offset: Arc<Expr>

length is not yet known so we accept negative offsets

§length: Arc<Expr>
§

Exclude(Arc<Expr>, Vec<Excluded>)

Can be used in a select statement to exclude a column from selection

§

KeepName(Arc<Expr>)

Set root name as Alias

§

Len

§

Nth(i64)

Take the nth column in the DataFrame

§

RenameAlias

Fields

§function: SpecialEq<Arc<dyn RenameAliasFn>>
§expr: Arc<Expr>
§

AnonymousFunction

Fields

§input: Vec<Expr>

function arguments

§function: SpecialEq<Arc<dyn SeriesUdf>>

function to apply

§output_type: SpecialEq<Arc<dyn FunctionOutputField>>

output dtype of the function

§

SubPlan(SpecialEq<Arc<LogicalPlan>>, Vec<String>)

§

Selector(Selector)

Expressions in this node should only be expanding e.g. Expr::Columns Expr::Dtypes Expr::Wildcard Expr::Exclude

Implementations§

source§

impl Expr

source

pub fn to_dot(&self) -> Result<String, PolarsError>

Get a dot language representation of the Expression.

source§

impl Expr

source

pub fn floor_div(self, rhs: Expr) -> Expr

Floor divide self by rhs.

source

pub fn pow<E>(self, exponent: E) -> Expr
where E: Into<Expr>,

Raise expression to the power exponent

source

pub fn sqrt(self) -> Expr

Compute the square root of the given expression

source

pub fn cbrt(self) -> Expr

Compute the cube root of the given expression

source§

impl Expr

source

pub fn to_field( &self, schema: &Schema, ctxt: Context ) -> Result<Field, PolarsError>

Get Field result of the expression. The schema is the input data.

source§

impl Expr

source

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

source

pub fn sample_n( self, n: Expr, with_replacement: bool, shuffle: bool, seed: Option<u64> ) -> Expr

source

pub fn sample_frac( self, frac: Expr, with_replacement: bool, shuffle: bool, seed: Option<u64> ) -> Expr

source§

impl Expr

source

pub fn std(self, ddof: u8) -> Expr

Standard deviation of the values of the Series.

source

pub fn var(self, ddof: u8) -> Expr

Variance of the values of the Series.

source

pub fn min(self) -> Expr

Reduce groups to minimal value.

source

pub fn max(self) -> Expr

Reduce groups to maximum value.

source

pub fn nan_min(self) -> Expr

Reduce groups to minimal value.

source

pub fn nan_max(self) -> Expr

Reduce groups to maximum value.

source

pub fn mean(self) -> Expr

Reduce groups to the mean value.

source

pub fn median(self) -> Expr

Reduce groups to the median value.

source

pub fn sum(self) -> Expr

Reduce groups to the sum of all the values.

source§

impl Expr

source

pub fn eq<E>(self, other: E) -> Expr
where E: Into<Expr>,

Compare Expr with other Expr on equality.

source

pub fn eq_missing<E>(self, other: E) -> Expr
where E: Into<Expr>,

Compare Expr with other Expr on equality where None == None.

source

pub fn neq<E>(self, other: E) -> Expr
where E: Into<Expr>,

Compare Expr with other Expr on non-equality.

source

pub fn neq_missing<E>(self, other: E) -> Expr
where E: Into<Expr>,

Compare Expr with other Expr on non-equality where None == None.

source

pub fn lt<E>(self, other: E) -> Expr
where E: Into<Expr>,

Check if Expr < Expr.

source

pub fn gt<E>(self, other: E) -> Expr
where E: Into<Expr>,

Check if Expr > Expr.

source

pub fn gt_eq<E>(self, other: E) -> Expr
where E: Into<Expr>,

Check if Expr >= Expr.

source

pub fn lt_eq<E>(self, other: E) -> Expr
where E: Into<Expr>,

Check if Expr <= Expr.

source

pub fn not(self) -> Expr

Negate Expr.

source

pub fn alias(self, name: &str) -> Expr

Rename Column.

source

pub fn is_null(self) -> Expr

Run is_null operation on Expr.

source

pub fn is_not_null(self) -> Expr

Run is_not_null operation on Expr.

source

pub fn drop_nulls(self) -> Expr

Drop null values.

source

pub fn drop_nans(self) -> Expr

Drop NaN values.

source

pub fn n_unique(self) -> Expr

Get the number of unique values in the groups.

source

pub fn first(self) -> Expr

Get the first value in the group.

source

pub fn last(self) -> Expr

Get the last value in the group.

source

pub fn implode(self) -> Expr

GroupBy the group to a Series.

source

pub fn quantile(self, quantile: Expr, interpol: QuantileInterpolOptions) -> Expr

Compute the quantile per group.

source

pub fn agg_groups(self) -> Expr

Get the group indexes of the group by operation.

source

pub fn flatten(self) -> Expr

Alias for explode.

source

pub fn explode(self) -> Expr

Explode the String/List column.

source

pub fn slice<E, F>(self, offset: E, length: F) -> Expr
where E: Into<Expr>, F: Into<Expr>,

Slice the Series. offset may be negative.

source

pub fn append<E>(self, other: E, upcast: bool) -> Expr
where E: Into<Expr>,

Append expressions. This is done by adding the chunks of other to this Series.

source

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

Get the first n elements of the Expr result.

source

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

Get the last n elements of the Expr result.

source

pub fn unique(self) -> Expr

Get unique values of this expression.

source

pub fn unique_stable(self) -> Expr

Get unique values of this expression, while maintaining order. This requires more work than Expr::unique.

source

pub fn arg_unique(self) -> Expr

Get the first index of unique values of this expression.

source

pub fn arg_min(self) -> Expr

Get the index value that has the minimum value.

source

pub fn arg_max(self) -> Expr

Get the index value that has the maximum value.

source

pub fn arg_sort(self, sort_options: SortOptions) -> Expr

Get the index values that would sort this expression.

source

pub fn strict_cast(self, data_type: DataType) -> Expr

Cast expression to another data type. Throws an error if conversion had overflows.

source

pub fn cast(self, data_type: DataType) -> Expr

Cast expression to another data type.

source

pub fn gather<E>(self, idx: E) -> Expr
where E: Into<Expr>,

Take the values by idx.

source

pub fn get<E>(self, idx: E) -> Expr
where E: Into<Expr>,

Take the values by a single index.

source

pub fn sort(self, options: SortOptions) -> Expr

Sort with given options.

§Example
let lf = df! {
   "a" => [Some(5), Some(4), Some(3), Some(2), None]
}?
.lazy();

let sorted = lf
    .select(
        vec![col("a").sort(SortOptions::default())],
    )
    .collect()?;

assert_eq!(
    sorted,
    df! {
        "a" => [None, Some(2), Some(3), Some(4), Some(5)]
    }?
);

See SortOptions for more options.

source

pub fn reverse(self) -> Expr

Reverse column

source

pub fn map<F>( self, function: F, output_type: SpecialEq<Arc<dyn FunctionOutputField>> ) -> Expr
where F: Fn(Series) -> Result<Option<Series>, PolarsError> + 'static + Send + Sync,

Apply a function/closure once the logical plan get executed.

This function is very similar to Expr::apply, but differs in how it handles aggregations.

  • map should be used for operations that are independent of groups, e.g. multiply * 2, or raise to the power
  • apply should be used for operations that work on a group of data. e.g. sum, count, etc.

It is the responsibility of the caller that the schema is correct by giving the correct output_type. If None given the output type of the input expr is used.

source

pub fn map_many<F>( self, function: F, arguments: &[Expr], output_type: SpecialEq<Arc<dyn FunctionOutputField>> ) -> Expr
where F: Fn(&mut [Series]) -> Result<Option<Series>, PolarsError> + 'static + Send + Sync,

Apply a function/closure once the logical plan get executed with many arguments.

See the Expr::map function for the differences between map and apply.

source

pub fn map_list<F>( self, function: F, output_type: SpecialEq<Arc<dyn FunctionOutputField>> ) -> Expr
where F: Fn(Series) -> Result<Option<Series>, PolarsError> + 'static + Send + Sync,

Apply a function/closure once the logical plan get executed.

This function is very similar to apply, but differs in how it handles aggregations.

  • map should be used for operations that are independent of groups, e.g. multiply * 2, or raise to the power
  • apply should be used for operations that work on a group of data. e.g. sum, count, etc.
  • map_list should be used when the function expects a list aggregated series.
source

pub fn function_with_options<F>( self, function: F, output_type: SpecialEq<Arc<dyn FunctionOutputField>>, options: FunctionOptions ) -> Expr
where F: Fn(Series) -> Result<Option<Series>, PolarsError> + 'static + Send + Sync,

A function that cannot be expressed with map or apply and requires extra settings.

source

pub fn apply<F>( self, function: F, output_type: SpecialEq<Arc<dyn FunctionOutputField>> ) -> Expr
where F: Fn(Series) -> Result<Option<Series>, PolarsError> + 'static + Send + Sync,

Apply a function/closure over the groups. This should only be used in a group_by aggregation.

It is the responsibility of the caller that the schema is correct by giving the correct output_type. If None given the output type of the input expr is used.

This difference with map is that apply will create a separate Series per group.

  • map should be used for operations that are independent of groups, e.g. multiply * 2, or raise to the power
  • apply should be used for operations that work on a group of data. e.g. sum, count, etc.
source

pub fn apply_many<F>( self, function: F, arguments: &[Expr], output_type: SpecialEq<Arc<dyn FunctionOutputField>> ) -> Expr
where F: Fn(&mut [Series]) -> Result<Option<Series>, PolarsError> + 'static + Send + Sync,

Apply a function/closure over the groups with many arguments. This should only be used in a group_by aggregation.

See the Expr::apply function for the differences between map and apply.

source

pub fn apply_many_private( self, function_expr: FunctionExpr, arguments: &[Expr], returns_scalar: bool, cast_to_supertypes: bool ) -> Expr

source

pub fn map_many_private( self, function_expr: FunctionExpr, arguments: &[Expr], returns_scalar: bool, cast_to_supertypes: bool ) -> Expr

source

pub fn is_finite(self) -> Expr

Get mask of finite values if dtype is Float.

source

pub fn is_infinite(self) -> Expr

Get mask of infinite values if dtype is Float.

source

pub fn is_nan(self) -> Expr

Get mask of NaN values if dtype is Float.

source

pub fn is_not_nan(self) -> Expr

Get inverse mask of NaN values if dtype is Float.

source

pub fn shift(self, n: Expr) -> Expr

Shift the values in the array by some period. See the eager implementation.

source

pub fn shift_and_fill<E, IE>(self, n: E, fill_value: IE) -> Expr
where E: Into<Expr>, IE: Into<Expr>,

Shift the values in the array by some period and fill the resulting empty values.

source

pub fn cum_count(self, reverse: bool) -> Expr

Available on crate feature cum_agg only.

Cumulatively count values from 0 to len.

source

pub fn cum_sum(self, reverse: bool) -> Expr

Available on crate feature cum_agg only.

Get an array with the cumulative sum computed at every element.

source

pub fn cum_prod(self, reverse: bool) -> Expr

Available on crate feature cum_agg only.

Get an array with the cumulative product computed at every element.

source

pub fn cum_min(self, reverse: bool) -> Expr

Available on crate feature cum_agg only.

Get an array with the cumulative min computed at every element.

source

pub fn cum_max(self, reverse: bool) -> Expr

Available on crate feature cum_agg only.

Get an array with the cumulative max computed at every element.

source

pub fn product(self) -> Expr

Get the product aggregation of an expression.

source

pub fn backward_fill(self, limit: Option<u32>) -> Expr

Fill missing value with next non-null.

source

pub fn forward_fill(self, limit: Option<u32>) -> Expr

Fill missing value with previous non-null.

source

pub fn round(self, decimals: u32) -> Expr

Available on crate feature round_series only.

Round underlying floating point array to given decimal numbers.

source

pub fn round_sig_figs(self, digits: i32) -> Expr

Available on crate feature round_series only.

Round to a number of significant figures.

source

pub fn floor(self) -> Expr

Available on crate feature round_series only.

Floor underlying floating point array to the lowest integers smaller or equal to the float value.

source

pub fn pi() -> Expr

Available on crate feature round_series only.

Constant Pi

source

pub fn ceil(self) -> Expr

Available on crate feature round_series only.

Ceil underlying floating point array to the highest integers smaller or equal to the float value.

source

pub fn clip(self, min: Expr, max: Expr) -> Expr

Available on crate feature round_series only.

Clip underlying values to a set boundary.

source

pub fn clip_max(self, max: Expr) -> Expr

Available on crate feature round_series only.

Clip underlying values to a set boundary.

source

pub fn clip_min(self, min: Expr) -> Expr

Available on crate feature round_series only.

Clip underlying values to a set boundary.

source

pub fn abs(self) -> Expr

Available on crate feature abs only.

Convert all values to their absolute/positive value.

source

pub fn over<E, IE>(self, partition_by: E) -> Expr
where E: AsRef<[IE]>, IE: Into<Expr> + Clone,

Apply window function over a subgroup. This is similar to a group_by + aggregation + self join. Or similar to window functions in Postgres.

§Example
#[macro_use] extern crate polars_core;
use polars_core::prelude::*;
use polars_lazy::prelude::*;

fn example() -> PolarsResult<()> {
    let df = df! {
            "groups" => &[1, 1, 2, 2, 1, 2, 3, 3, 1],
            "values" => &[1, 2, 3, 4, 5, 6, 7, 8, 8]
        }?;

    let out = df
     .lazy()
     .select(&[
         col("groups"),
         sum("values").over([col("groups")]),
     ])
     .collect()?;
    println!("{}", &out);
    Ok(())
}

Outputs:

╭────────┬────────╮
│ groups ┆ values │
│ ---    ┆ ---    │
│ i32    ┆ i32    │
╞════════╪════════╡
│ 1      ┆ 16     │
│ 1      ┆ 16     │
│ 2      ┆ 13     │
│ 2      ┆ 13     │
│ …      ┆ …      │
│ 1      ┆ 16     │
│ 2      ┆ 13     │
│ 3      ┆ 15     │
│ 3      ┆ 15     │
│ 1      ┆ 16     │
╰────────┴────────╯
source

pub fn over_with_options<E, IE>( self, partition_by: E, options: WindowMapping ) -> Expr
where E: AsRef<[IE]>, IE: Into<Expr> + Clone,

source

pub fn rolling(self, options: RollingGroupOptions) -> Expr

Available on crate feature dynamic_group_by only.
source

pub fn fill_null<E>(self, fill_value: E) -> Expr
where E: Into<Expr>,

Replace the null values by a value.

source

pub fn fill_null_with_strategy(self, strategy: FillNullStrategy) -> Expr

source

pub fn fill_nan<E>(self, fill_value: E) -> Expr
where E: Into<Expr>,

Replace the floating point NaN values by a value.

source

pub fn count(self) -> Expr

Count the values of the Series or Get counts of the group by operation.

source

pub fn len(self) -> Expr

source

pub fn is_between<E>(self, lower: E, upper: E, closed: ClosedInterval) -> Expr
where E: Into<Expr>,

Available on crate feature is_between only.
source

pub fn and<E>(self, expr: E) -> Expr
where E: Into<Expr>,

“and” operation.

source

pub fn xor<E>(self, expr: E) -> Expr
where E: Into<Expr>,

“xor” operation.

source

pub fn or<E>(self, expr: E) -> Expr
where E: Into<Expr>,

“or” operation.

source

pub fn logical_or<E>(self, expr: E) -> Expr
where E: Into<Expr>,

“or” operation.

source

pub fn logical_and<E>(self, expr: E) -> Expr
where E: Into<Expr>,

“or” operation.

source

pub fn filter<E>(self, predicate: E) -> Expr
where E: Into<Expr>,

Filter a single column.

Should be used in aggregation context. If you want to filter on a DataFrame level, use LazyFrame::filter.

source

pub fn is_in<E>(self, other: E) -> Expr
where E: Into<Expr>,

Available on crate feature is_in only.

Check if the values of the left expression are in the lists of the right expr.

source

pub fn sort_by<E, IE>(self, by: E, sort_options: SortMultipleOptions) -> Expr
where E: AsRef<[IE]>, IE: Into<Expr> + Clone,

Sort this column by the ordering of another column evaluated from given expr. Can also be used in a group_by context to sort the groups.

§Example
let lf = df! {
    "a" => [1, 2, 3, 4, 5],
    "b" => [5, 4, 3, 2, 1]
}?.lazy();

let sorted = lf
    .select(
        vec![col("a").sort_by(col("b"), SortOptions::default())],
    )
    .collect()?;

assert_eq!(
    sorted,
    df! { "a" => [5, 4, 3, 2, 1] }?
);
source

pub fn repeat_by<E>(self, by: E) -> Expr
where E: Into<Expr>,

Available on crate feature repeat_by only.

Repeat the column n times, where n is determined by the values in by. This yields an Expr of dtype List.

source

pub fn is_first_distinct(self) -> Expr

Available on crate feature is_first_distinct only.

Get a mask of the first unique value.

source

pub fn is_last_distinct(self) -> Expr

Available on crate feature is_last_distinct only.

Get a mask of the last unique value.

source

pub fn dot<E>(self, other: E) -> Expr
where E: Into<Expr>,

Compute the dot/inner product between two expressions.

source

pub fn mode(self) -> Expr

Available on crate feature mode only.

Compute the mode(s) of this column. This is the most occurring value.

source

pub fn exclude(self, columns: impl IntoVec<String>) -> Expr

Exclude a column from a wildcard/regex selection.

You may also use regexes in the exclude as long as they start with ^ and end with $/

source

pub fn exclude_dtype<D>(self, dtypes: D) -> Expr
where D: AsRef<[DataType]>,

source

pub fn interpolate(self, method: InterpolationMethod) -> Expr

Available on crate feature interpolate only.

Fill null values using interpolation.

source

pub fn rolling_min(self, options: RollingOptions) -> Expr

Available on crate feature rolling_window only.

Apply a rolling minimum.

See: [RollingAgg::rolling_min]

source

pub fn rolling_max(self, options: RollingOptions) -> Expr

Available on crate feature rolling_window only.

Apply a rolling maximum.

See: [RollingAgg::rolling_max]

source

pub fn rolling_mean(self, options: RollingOptions) -> Expr

Available on crate feature rolling_window only.

Apply a rolling mean.

See: [RollingAgg::rolling_mean]

source

pub fn rolling_sum(self, options: RollingOptions) -> Expr

Available on crate feature rolling_window only.

Apply a rolling sum.

See: [RollingAgg::rolling_sum]

source

pub fn rolling_median(self, options: RollingOptions) -> Expr

Available on crate feature rolling_window only.

Apply a rolling median.

See: [RollingAgg::rolling_median]

source

pub fn rolling_quantile( self, interpol: QuantileInterpolOptions, quantile: f64, options: RollingOptions ) -> Expr

Available on crate feature rolling_window only.

Apply a rolling quantile.

See: [RollingAgg::rolling_quantile]

source

pub fn rolling_var(self, options: RollingOptions) -> Expr

Available on crate feature rolling_window only.

Apply a rolling variance.

source

pub fn rolling_std(self, options: RollingOptions) -> Expr

Available on crate feature rolling_window only.

Apply a rolling std-dev.

source

pub fn rolling_map( self, f: Arc<dyn Fn(&Series) -> Series + Sync + Send>, output_type: SpecialEq<Arc<dyn FunctionOutputField>>, options: RollingOptionsFixedWindow ) -> Expr

Available on crate feature rolling_window only.

Apply a custom function over a rolling/ moving window of the array. This has quite some dynamic dispatch, so prefer rolling_min, max, mean, sum over this.

source

pub fn rolling_map_float<F>(self, window_size: usize, f: F) -> Expr
where F: 'static + FnMut(&mut ChunkedArray<Float64Type>) -> Option<f64> + Send + Sync + Copy,

Available on crate feature rolling_window only.

Apply a custom function over a rolling/ moving window of the array. Prefer this over rolling_apply in case of floating point numbers as this is faster. This has quite some dynamic dispatch, so prefer rolling_min, max, mean, sum over this.

source

pub fn rank(self, options: RankOptions, seed: Option<u64>) -> Expr

Available on crate feature rank only.

Assign ranks to data, dealing with ties appropriately.

source

pub fn replace<E>( self, old: E, new: E, default: Option<E>, return_dtype: Option<DataType> ) -> Expr
where E: Into<Expr>,

Available on crate feature replace only.

Replace the given values with other values.

source

pub fn diff(self, n: i64, null_behavior: NullBehavior) -> Expr

Available on crate feature diff only.

Calculate the n-th discrete difference between values.

source

pub fn upper_bound(self) -> Expr

Get maximal value that could be hold by this dtype.

source

pub fn lower_bound(self) -> Expr

Get minimal value that could be hold by this dtype.

source

pub fn reshape(self, dimensions: &[i64]) -> Expr

source

pub fn any(self, ignore_nulls: bool) -> Expr

Returns whether any of the values in the column are true.

If ignore_nulls is False, Kleene logic is used to deal with nulls: if the column contains any null values and no true values, the output is null.

source

pub fn all(self, ignore_nulls: bool) -> Expr

Returns whether all values in the column are true.

If ignore_nulls is False, Kleene logic is used to deal with nulls: if the column contains any null values and no true values, the output is null.

source

pub fn shrink_dtype(self) -> Expr

Shrink numeric columns to the minimal required datatype needed to fit the extrema of this Series. This can be used to reduce memory pressure.

source

pub fn value_counts(self, sort: bool, parallel: bool) -> Expr

Available on crate feature dtype-struct only.

Count all unique values and create a struct mapping value to count. (Note that it is better to turn parallel off in the aggregation context).

source

pub fn null_count(self) -> Expr

Get the null count of the column/group.

source

pub fn set_sorted_flag(self, sorted: IsSorted) -> Expr

Set this Series as sorted so that downstream code can use fast paths for sorted arrays.

§Warning

This can lead to incorrect results if this Series is not sorted!! Use with care!

source

pub fn to_physical(self) -> Expr

source

pub fn gather_every(self, n: usize, offset: usize) -> Expr

source

pub fn extend_constant(self, value: Expr, n: Expr) -> Expr

source

pub fn str(self) -> StringNameSpace

Available on crate feature strings only.
source

pub fn binary(self) -> BinaryNameSpace

source

pub fn dt(self) -> DateLikeNameSpace

Available on crate feature temporal only.
source

pub fn list(self) -> ListNameSpace

source

pub fn name(self) -> ExprNameNameSpace

source

pub fn arr(self) -> ArrayNameSpace

Available on crate feature dtype-array only.
source

pub fn cat(self) -> CategoricalNameSpace

Available on crate feature dtype-categorical only.
source

pub fn struct_(self) -> StructNameSpace

Available on crate feature dtype-struct only.
source§

impl Expr

source

pub fn nodes<'a>(&'a self, container: &mut UnitVec<&'a Expr>)

source

pub fn nodes_owned(self, container: &mut UnitVec<Expr>)

source

pub fn map_expr<F>(self, f: F) -> Expr
where F: FnMut(Expr) -> Expr,

source

pub fn try_map_expr<F>(self, f: F) -> Result<Expr, PolarsError>
where F: FnMut(Expr) -> Result<Expr, PolarsError>,

Trait Implementations§

source§

impl Add for Expr

§

type Output = Expr

The resulting type after applying the + operator.
source§

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

Performs the + operation. Read more
source§

impl AsRef<Expr> for AggExpr

source§

fn as_ref(&self) -> &Expr

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

impl Clone for Expr

source§

fn clone(&self) -> Expr

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 Debug for Expr

source§

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

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

impl Default for Expr

source§

fn default() -> Expr

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

impl Display for Expr

source§

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

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

impl Div for Expr

§

type Output = Expr

The resulting type after applying the / operator.
source§

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

Performs the / operation. Read more
source§

impl ExprEvalExtension for Expr

source§

fn cumulative_eval(self, expr: Expr, min_periods: usize, parallel: bool) -> Expr

Run an expression over a sliding window that increases 1 slot every iteration. Read more
source§

impl From<&str> for Expr

source§

fn from(s: &str) -> Expr

Converts to this type from the input type.
source§

impl From<AggExpr> for Expr

source§

fn from(agg: AggExpr) -> Expr

Converts to this type from the input type.
source§

impl From<bool> for Expr

source§

fn from(val: bool) -> Expr

Converts to this type from the input type.
source§

impl From<f32> for Expr

source§

fn from(val: f32) -> Expr

Converts to this type from the input type.
source§

impl From<f64> for Expr

source§

fn from(val: f64) -> Expr

Converts to this type from the input type.
source§

impl From<i16> for Expr

source§

fn from(val: i16) -> Expr

Converts to this type from the input type.
source§

impl From<i32> for Expr

source§

fn from(val: i32) -> Expr

Converts to this type from the input type.
source§

impl From<i64> for Expr

source§

fn from(val: i64) -> Expr

Converts to this type from the input type.
source§

impl From<i8> for Expr

source§

fn from(val: i8) -> Expr

Converts to this type from the input type.
source§

impl From<u16> for Expr

source§

fn from(val: u16) -> Expr

Converts to this type from the input type.
source§

impl From<u32> for Expr

source§

fn from(val: u32) -> Expr

Converts to this type from the input type.
source§

impl From<u64> for Expr

source§

fn from(val: u64) -> Expr

Converts to this type from the input type.
source§

impl From<u8> for Expr

source§

fn from(val: u8) -> Expr

Converts to this type from the input type.
source§

impl Hash for Expr

source§

fn hash<H>(&self, state: &mut H)
where H: Hasher,

Feeds this value into the given Hasher. Read more
1.3.0 · source§

fn hash_slice<H>(data: &[Self], state: &mut H)
where H: Hasher, Self: Sized,

Feeds a slice of this type into the given Hasher. Read more
source§

impl<'a> IntoIterator for &'a Expr

§

type Item = &'a Expr

The type of the elements being iterated over.
§

type IntoIter = ExprIter<'a>

Which kind of iterator are we turning this into?
source§

fn into_iter(self) -> <&'a Expr as IntoIterator>::IntoIter

Creates an iterator from a value. Read more
source§

impl Mul for Expr

§

type Output = Expr

The resulting type after applying the * operator.
source§

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

Performs the * operation. Read more
source§

impl Neg for Expr

§

type Output = Expr

The resulting type after applying the - operator.
source§

fn neg(self) -> <Expr as Neg>::Output

Performs the unary - operation. Read more
source§

impl PartialEq for Expr

source§

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

This method tests for self and other values to be equal, and is used by ==.
1.0.0 · source§

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

This method tests for !=. The default implementation is almost always sufficient, and should not be overridden without very good reason.
source§

impl Rem for Expr

§

type Output = Expr

The resulting type after applying the % operator.
source§

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

Performs the % operation. Read more
source§

impl Sub for Expr

§

type Output = Expr

The resulting type after applying the - operator.
source§

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

Performs the - operation. Read more
source§

impl TreeWalker for Expr

§

type Arena = ()

source§

fn apply_children<F>( &self, op: &mut F, arena: &<Expr as TreeWalker>::Arena ) -> Result<VisitRecursion, PolarsError>

source§

fn map_children<F>( self, f: &mut F, _arena: &mut <Expr as TreeWalker>::Arena ) -> Result<Expr, PolarsError>
where F: FnMut(Expr, &mut <Expr as TreeWalker>::Arena) -> Result<Expr, PolarsError>,

source§

fn visit<V>( &self, visitor: &mut V, arena: &Self::Arena ) -> Result<VisitRecursion, PolarsError>
where V: Visitor<Node = Self, Arena = Self::Arena>,

Walks all nodes in depth-first-order.
source§

fn rewrite<R>( self, rewriter: &mut R, arena: &mut Self::Arena ) -> Result<Self, PolarsError>
where R: RewritingVisitor<Node = Self, Arena = Self::Arena>,

source§

impl Eq for Expr

source§

impl StructuralPartialEq for Expr

Auto Trait Implementations§

§

impl Freeze for Expr

§

impl !RefUnwindSafe for Expr

§

impl Send for Expr

§

impl Sync for Expr

§

impl Unpin for Expr

§

impl !UnwindSafe for Expr

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> DynClone for T
where T: Clone,

source§

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

source§

impl<Q, K> Equivalent<K> for Q
where Q: Eq + ?Sized, K: Borrow<Q> + ?Sized,

source§

fn equivalent(&self, key: &K) -> bool

Checks if this value is equivalent to the given key. Read more
source§

impl<Q, K> Equivalent<K> for Q
where Q: Eq + ?Sized, K: Borrow<Q> + ?Sized,

source§

fn equivalent(&self, key: &K) -> bool

Compare self to key and return true if they are equal.
source§

impl<T> From<T> for T

source§

fn from(t: T) -> T

Returns the argument unchanged.

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> Pointable for T

source§

const ALIGN: usize = _

The alignment of pointer.
§

type Init = T

The type for initializers.
source§

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

Initializes a with the given initializer. Read more
source§

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

Dereferences the given pointer. Read more
source§

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

Mutably dereferences the given pointer. Read more
source§

unsafe fn drop(ptr: usize)

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

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

§

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> ToString for T
where T: Display + ?Sized,

source§

default fn to_string(&self) -> String

Converts the given value to a String. Read more
source§

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

§

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>,

§

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.
source§

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

source§

fn vzip(self) -> V

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>,