Skip to content
Merged
Show file tree
Hide file tree
Changes from 1 commit
Commits
File filter

Filter by extension

Filter by extension


Conversations
Failed to load comments.
Loading
Jump to
Jump to file
Failed to load files.
Loading
Diff view
Diff view
1 change: 1 addition & 0 deletions .gitignore
Original file line number Diff line number Diff line change
Expand Up @@ -25,6 +25,7 @@ dist
# intended to run in multiple environments; otherwise, check them in:
.python-version
venv
.venv

apache-rat-*.jar
*rat.txt
Expand Down
5 changes: 0 additions & 5 deletions Cargo.lock

Some generated files are not rendered by default. Learn more about how customized files appear on GitHub.

7 changes: 1 addition & 6 deletions Cargo.toml
Original file line number Diff line number Diff line change
Expand Up @@ -39,11 +39,6 @@ rand = "0.8"
pyo3 = { version = "0.21", features = ["extension-module", "abi3", "abi3-py38"] }
arrow = { version = "52", feature = ["pyarrow"] }
datafusion = { version = "41.0.0", features = ["pyarrow", "avro", "unicode_expressions"] }
datafusion-common = { version = "41.0.0", features = ["pyarrow"] }
datafusion-expr = { version = "41.0.0" }
datafusion-functions-nested = { version = "41.0.0" }
datafusion-optimizer = { version = "41.0.0" }
datafusion-sql = { version = "41.0.0" }
datafusion-substrait = { version = "41.0.0", optional = true }
prost = "0.12" # keep in line with `datafusion-substrait`
prost-types = "0.12" # keep in line with `datafusion-substrait`
Expand All @@ -67,4 +62,4 @@ crate-type = ["cdylib", "rlib"]
[profile.release]
lto = true
codegen-units = 1


4 changes: 2 additions & 2 deletions src/common/data_type.rs
Original file line number Diff line number Diff line change
Expand Up @@ -17,8 +17,8 @@

use datafusion::arrow::array::Array;
use datafusion::arrow::datatypes::{DataType, IntervalUnit, TimeUnit};
use datafusion_common::{DataFusionError, ScalarValue};
use datafusion_expr::sqlparser::ast::NullTreatment as DFNullTreatment;
use datafusion::common::{DataFusionError, ScalarValue};
use datafusion::logical_expr::sqlparser::ast::NullTreatment as DFNullTreatment;
use pyo3::{exceptions::PyValueError, prelude::*};

use crate::errors::py_datafusion_err;
Expand Down
2 changes: 1 addition & 1 deletion src/common/df_schema.rs
Original file line number Diff line number Diff line change
Expand Up @@ -17,7 +17,7 @@

use std::sync::Arc;

use datafusion_common::DFSchema;
use datafusion::common::DFSchema;
use pyo3::prelude::*;

#[derive(Debug, Clone)]
Expand Down
14 changes: 7 additions & 7 deletions src/common/schema.rs
Original file line number Diff line number Diff line change
Expand Up @@ -18,10 +18,10 @@
use std::any::Any;

use datafusion::arrow::datatypes::SchemaRef;
use datafusion_expr::{Expr, TableProviderFilterPushDown, TableSource};
use datafusion::logical_expr::{Expr, TableProviderFilterPushDown, TableSource};
use pyo3::prelude::*;

use datafusion_expr::utils::split_conjunction;
use datafusion::logical_expr::utils::split_conjunction;

use super::{data_type::DataTypeMap, function::SqlFunction};

Expand Down Expand Up @@ -166,7 +166,7 @@ impl TableSource for SqlTableSource {
fn supports_filter_pushdown(
&self,
filter: &Expr,
) -> datafusion_common::Result<TableProviderFilterPushDown> {
) -> datafusion::common::Result<TableProviderFilterPushDown> {
let filters = split_conjunction(filter);
if filters.iter().all(|f| is_supported_push_down_expr(f)) {
// Push down filters to the tablescan operation if all are supported
Expand All @@ -180,22 +180,22 @@ impl TableSource for SqlTableSource {
}
}

fn table_type(&self) -> datafusion_expr::TableType {
datafusion_expr::TableType::Base
fn table_type(&self) -> datafusion::logical_expr::TableType {
datafusion::logical_expr::TableType::Base
}

#[allow(deprecated)]
fn supports_filters_pushdown(
&self,
filters: &[&Expr],
) -> datafusion_common::Result<Vec<TableProviderFilterPushDown>> {
) -> datafusion::common::Result<Vec<TableProviderFilterPushDown>> {
filters
.iter()
.map(|f| self.supports_filter_pushdown(f))
.collect()
}

fn get_logical_plan(&self) -> Option<&datafusion_expr::LogicalPlan> {
fn get_logical_plan(&self) -> Option<&datafusion::logical_expr::LogicalPlan> {
None
}
}
Expand Down
2 changes: 1 addition & 1 deletion src/config.rs
Original file line number Diff line number Diff line change
Expand Up @@ -18,8 +18,8 @@
use pyo3::prelude::*;
use pyo3::types::*;

use datafusion::common::ScalarValue;
use datafusion::config::ConfigOptions;
use datafusion_common::ScalarValue;

#[pyclass(name = "Config", module = "datafusion", subclass)]
#[derive(Clone)]
Expand Down
6 changes: 3 additions & 3 deletions src/context.rs
Original file line number Diff line number Diff line change
Expand Up @@ -46,6 +46,7 @@ use crate::utils::{get_tokio_runtime, wait_for_future};
use datafusion::arrow::datatypes::{DataType, Schema, SchemaRef};
use datafusion::arrow::pyarrow::PyArrowType;
use datafusion::arrow::record_batch::RecordBatch;
use datafusion::common::ScalarValue;
use datafusion::datasource::file_format::file_compression_type::FileCompressionType;
use datafusion::datasource::file_format::parquet::ParquetFormat;
use datafusion::datasource::listing::{
Expand All @@ -61,7 +62,6 @@ use datafusion::physical_plan::SendableRecordBatchStream;
use datafusion::prelude::{
AvroReadOptions, CsvReadOptions, DataFrame, NdJsonReadOptions, ParquetReadOptions,
};
use datafusion_common::ScalarValue;
use pyo3::types::{PyDict, PyList, PyTuple};
use tokio::task::JoinHandle;

Expand Down Expand Up @@ -962,15 +962,15 @@ impl PySessionContext {
// create a Tokio runtime to run the async code
let rt = &get_tokio_runtime(py).0;
let plan = plan.plan.clone();
let fut: JoinHandle<datafusion_common::Result<SendableRecordBatchStream>> =
let fut: JoinHandle<datafusion::common::Result<SendableRecordBatchStream>> =
rt.spawn(async move { plan.execute(part, Arc::new(ctx)) });
let stream = wait_for_future(py, fut).map_err(py_datafusion_err)?;
Ok(PyRecordBatchStream::new(stream?))
}
}

impl PySessionContext {
async fn _table(&self, name: &str) -> datafusion_common::Result<DataFrame> {
async fn _table(&self, name: &str) -> datafusion::common::Result<DataFrame> {
self.ctx.table(name).await
}
}
Expand Down
6 changes: 3 additions & 3 deletions src/dataframe.rs
Original file line number Diff line number Diff line change
Expand Up @@ -27,12 +27,12 @@ use arrow::util::display::{ArrayFormatter, FormatOptions};
use datafusion::arrow::datatypes::Schema;
use datafusion::arrow::pyarrow::{PyArrowType, ToPyArrow};
use datafusion::arrow::util::pretty;
use datafusion::common::UnnestOptions;
use datafusion::config::{CsvOptions, TableParquetOptions};
use datafusion::dataframe::{DataFrame, DataFrameWriteOptions};
use datafusion::execution::SendableRecordBatchStream;
use datafusion::parquet::basic::{BrotliLevel, Compression, GzipLevel, ZstdLevel};
use datafusion::prelude::*;
use datafusion_common::UnnestOptions;
use pyo3::exceptions::{PyTypeError, PyValueError};
use pyo3::prelude::*;
use pyo3::pybacked::PyBackedStr;
Expand Down Expand Up @@ -541,7 +541,7 @@ impl PyDataFrame {
// create a Tokio runtime to run the async code
let rt = &get_tokio_runtime(py).0;
let df = self.df.as_ref().clone();
let fut: JoinHandle<datafusion_common::Result<SendableRecordBatchStream>> =
let fut: JoinHandle<datafusion::common::Result<SendableRecordBatchStream>> =
rt.spawn(async move { df.execute_stream().await });
let stream = wait_for_future(py, fut).map_err(py_datafusion_err)?;
Ok(PyRecordBatchStream::new(stream?))
Expand All @@ -551,7 +551,7 @@ impl PyDataFrame {
// create a Tokio runtime to run the async code
let rt = &get_tokio_runtime(py).0;
let df = self.df.as_ref().clone();
let fut: JoinHandle<datafusion_common::Result<Vec<SendableRecordBatchStream>>> =
let fut: JoinHandle<datafusion::common::Result<Vec<SendableRecordBatchStream>>> =
rt.spawn(async move { df.execute_stream_partitioned().await });
let stream = wait_for_future(py, fut).map_err(py_datafusion_err)?;

Expand Down
2 changes: 1 addition & 1 deletion src/dataset.rs
Original file line number Diff line number Diff line change
Expand Up @@ -31,9 +31,9 @@ use datafusion::arrow::datatypes::SchemaRef;
use datafusion::arrow::pyarrow::PyArrowType;
use datafusion::datasource::{TableProvider, TableType};
use datafusion::error::{DataFusionError, Result as DFResult};
use datafusion::logical_expr::Expr;
use datafusion::logical_expr::TableProviderFilterPushDown;
use datafusion::physical_plan::ExecutionPlan;
use datafusion_expr::Expr;

use crate::dataset_exec::DatasetExec;
use crate::pyarrow_filter_expression::PyArrowFilterExpression;
Expand Down
4 changes: 2 additions & 2 deletions src/dataset_exec.rs
Original file line number Diff line number Diff line change
Expand Up @@ -32,14 +32,14 @@ use datafusion::arrow::pyarrow::PyArrowType;
use datafusion::arrow::record_batch::RecordBatch;
use datafusion::error::{DataFusionError as InnerDataFusionError, Result as DFResult};
use datafusion::execution::context::TaskContext;
use datafusion::logical_expr::utils::conjunction;
use datafusion::logical_expr::Expr;
use datafusion::physical_expr::{EquivalenceProperties, PhysicalSortExpr};
use datafusion::physical_plan::stream::RecordBatchStreamAdapter;
use datafusion::physical_plan::{
DisplayAs, DisplayFormatType, ExecutionMode, ExecutionPlan, ExecutionPlanProperties,
Partitioning, SendableRecordBatchStream, Statistics,
};
use datafusion_expr::utils::conjunction;
use datafusion_expr::Expr;

use crate::errors::DataFusionError;
use crate::pyarrow_filter_expression::PyArrowFilterExpression;
Expand Down
8 changes: 4 additions & 4 deletions src/expr.rs
Original file line number Diff line number Diff line change
Expand Up @@ -15,8 +15,8 @@
// specific language governing permissions and limitations
// under the License.

use datafusion_expr::utils::exprlist_to_fields;
use datafusion_expr::{ExprFuncBuilder, ExprFunctionExt, LogicalPlan};
use datafusion::logical_expr::utils::exprlist_to_fields;
use datafusion::logical_expr::{ExprFuncBuilder, ExprFunctionExt, LogicalPlan};
use pyo3::{basic::CompareOp, prelude::*};
use std::convert::{From, Into};
use std::sync::Arc;
Expand All @@ -26,12 +26,12 @@ use arrow::pyarrow::ToPyArrow;
use datafusion::arrow::datatypes::{DataType, Field};
use datafusion::arrow::pyarrow::PyArrowType;
use datafusion::functions::core::expr_ext::FieldAccessor;
use datafusion::scalar::ScalarValue;
use datafusion_expr::{
use datafusion::logical_expr::{
col,
expr::{AggregateFunction, InList, InSubquery, ScalarFunction, Sort, WindowFunction},
lit, Between, BinaryExpr, Case, Cast, Expr, Like, Operator, TryCast,
};
use datafusion::scalar::ScalarValue;

use crate::common::data_type::{DataTypeMap, NullTreatment, RexType};
use crate::errors::{py_runtime_err, py_type_err, py_unsupported_variant_err, DataFusionError};
Expand Down
8 changes: 4 additions & 4 deletions src/expr/aggregate.rs
Original file line number Diff line number Diff line change
Expand Up @@ -15,10 +15,10 @@
// specific language governing permissions and limitations
// under the License.

use datafusion_common::DataFusionError;
use datafusion_expr::expr::{AggregateFunction, Alias};
use datafusion_expr::logical_plan::Aggregate;
use datafusion_expr::Expr;
use datafusion::common::DataFusionError;
use datafusion::logical_expr::expr::{AggregateFunction, Alias};
use datafusion::logical_expr::logical_plan::Aggregate;
use datafusion::logical_expr::Expr;
use pyo3::prelude::*;
use std::fmt::{self, Display, Formatter};

Expand Down
2 changes: 1 addition & 1 deletion src/expr/aggregate_expr.rs
Original file line number Diff line number Diff line change
Expand Up @@ -16,7 +16,7 @@
// under the License.

use crate::expr::PyExpr;
use datafusion_expr::expr::AggregateFunction;
use datafusion::logical_expr::expr::AggregateFunction;
use pyo3::prelude::*;
use std::fmt::{Display, Formatter};

Expand Down
2 changes: 1 addition & 1 deletion src/expr/alias.rs
Original file line number Diff line number Diff line change
Expand Up @@ -19,7 +19,7 @@ use crate::expr::PyExpr;
use pyo3::prelude::*;
use std::fmt::{self, Display, Formatter};

use datafusion_expr::expr::Alias;
use datafusion::logical_expr::expr::Alias;

#[pyclass(name = "Alias", module = "datafusion.expr", subclass)]
#[derive(Clone)]
Expand Down
2 changes: 1 addition & 1 deletion src/expr/analyze.rs
Original file line number Diff line number Diff line change
Expand Up @@ -15,7 +15,7 @@
// specific language governing permissions and limitations
// under the License.

use datafusion_expr::logical_plan::Analyze;
use datafusion::logical_expr::logical_plan::Analyze;
use pyo3::prelude::*;
use std::fmt::{self, Display, Formatter};

Expand Down
2 changes: 1 addition & 1 deletion src/expr/between.rs
Original file line number Diff line number Diff line change
Expand Up @@ -16,7 +16,7 @@
// under the License.

use crate::expr::PyExpr;
use datafusion_expr::expr::Between;
use datafusion::logical_expr::expr::Between;
use pyo3::prelude::*;
use std::fmt::{self, Display, Formatter};

Expand Down
2 changes: 1 addition & 1 deletion src/expr/binary_expr.rs
Original file line number Diff line number Diff line change
Expand Up @@ -16,7 +16,7 @@
// under the License.

use crate::expr::PyExpr;
use datafusion_expr::BinaryExpr;
use datafusion::logical_expr::BinaryExpr;
use pyo3::prelude::*;

#[pyclass(name = "BinaryExpr", module = "datafusion.expr", subclass)]
Expand Down
2 changes: 1 addition & 1 deletion src/expr/bool_expr.rs
Original file line number Diff line number Diff line change
Expand Up @@ -15,7 +15,7 @@
// specific language governing permissions and limitations
// under the License.

use datafusion_expr::Expr;
use datafusion::logical_expr::Expr;
use pyo3::prelude::*;
use std::fmt::{self, Display, Formatter};

Expand Down
2 changes: 1 addition & 1 deletion src/expr/case.rs
Original file line number Diff line number Diff line change
Expand Up @@ -16,7 +16,7 @@
// under the License.

use crate::expr::PyExpr;
use datafusion_expr::Case;
use datafusion::logical_expr::Case;
use pyo3::prelude::*;

#[pyclass(name = "Case", module = "datafusion.expr", subclass)]
Expand Down
2 changes: 1 addition & 1 deletion src/expr/cast.rs
Original file line number Diff line number Diff line change
Expand Up @@ -16,7 +16,7 @@
// under the License.

use crate::{common::data_type::PyDataType, expr::PyExpr};
use datafusion_expr::{Cast, TryCast};
use datafusion::logical_expr::{Cast, TryCast};
use pyo3::prelude::*;

#[pyclass(name = "Cast", module = "datafusion.expr", subclass)]
Expand Down
2 changes: 1 addition & 1 deletion src/expr/column.rs
Original file line number Diff line number Diff line change
Expand Up @@ -15,7 +15,7 @@
// specific language governing permissions and limitations
// under the License.

use datafusion_common::Column;
use datafusion::common::Column;
use pyo3::prelude::*;

#[pyclass(name = "Column", module = "datafusion.expr", subclass)]
Expand Down
2 changes: 1 addition & 1 deletion src/expr/conditional_expr.rs
Original file line number Diff line number Diff line change
Expand Up @@ -16,7 +16,7 @@
// under the License.

use crate::expr::PyExpr;
use datafusion_expr::conditional_expressions::CaseBuilder;
use datafusion::logical_expr::conditional_expressions::CaseBuilder;
use pyo3::prelude::*;

#[pyclass(name = "CaseBuilder", module = "datafusion.expr", subclass)]
Expand Down
2 changes: 1 addition & 1 deletion src/expr/create_memory_table.rs
Original file line number Diff line number Diff line change
Expand Up @@ -17,7 +17,7 @@

use std::fmt::{self, Display, Formatter};

use datafusion_expr::CreateMemoryTable;
use datafusion::logical_expr::CreateMemoryTable;
use pyo3::prelude::*;

use crate::sql::logical::PyLogicalPlan;
Expand Down
2 changes: 1 addition & 1 deletion src/expr/create_view.rs
Original file line number Diff line number Diff line change
Expand Up @@ -17,7 +17,7 @@

use std::fmt::{self, Display, Formatter};

use datafusion_expr::{CreateView, DdlStatement, LogicalPlan};
use datafusion::logical_expr::{CreateView, DdlStatement, LogicalPlan};
use pyo3::prelude::*;

use crate::{errors::py_type_err, sql::logical::PyLogicalPlan};
Expand Down
2 changes: 1 addition & 1 deletion src/expr/cross_join.rs
Original file line number Diff line number Diff line change
Expand Up @@ -15,7 +15,7 @@
// specific language governing permissions and limitations
// under the License.

use datafusion_expr::logical_plan::CrossJoin;
use datafusion::logical_expr::logical_plan::CrossJoin;
use pyo3::prelude::*;
use std::fmt::{self, Display, Formatter};

Expand Down
2 changes: 1 addition & 1 deletion src/expr/distinct.rs
Original file line number Diff line number Diff line change
Expand Up @@ -17,7 +17,7 @@

use std::fmt::{self, Display, Formatter};

use datafusion_expr::Distinct;
use datafusion::logical_expr::Distinct;
use pyo3::prelude::*;

use crate::sql::logical::PyLogicalPlan;
Expand Down
2 changes: 1 addition & 1 deletion src/expr/drop_table.rs
Original file line number Diff line number Diff line change
Expand Up @@ -17,7 +17,7 @@

use std::fmt::{self, Display, Formatter};

use datafusion_expr::logical_plan::DropTable;
use datafusion::logical_expr::logical_plan::DropTable;
use pyo3::prelude::*;

use crate::sql::logical::PyLogicalPlan;
Expand Down
2 changes: 1 addition & 1 deletion src/expr/empty_relation.rs
Original file line number Diff line number Diff line change
Expand Up @@ -16,7 +16,7 @@
// under the License.

use crate::{common::df_schema::PyDFSchema, sql::logical::PyLogicalPlan};
use datafusion_expr::EmptyRelation;
use datafusion::logical_expr::EmptyRelation;
use pyo3::prelude::*;
use std::fmt::{self, Display, Formatter};

Expand Down
Loading
Loading