You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@arrow.apache.org by ag...@apache.org on 2022/04/22 00:45:11 UTC

[arrow-datafusion] branch master updated: remove two source files that only had re-exports (#2313)

This is an automated email from the ASF dual-hosted git repository.

agrove pushed a commit to branch master
in repository https://gitbox.apache.org/repos/asf/arrow-datafusion.git


The following commit(s) were added to refs/heads/master by this push:
     new d97cd3b5c remove two source files that only had re-exports (#2313)
d97cd3b5c is described below

commit d97cd3b5c9c2594abe527c5e9d3e7d8944917f4d
Author: Andy Grove <ag...@apache.org>
AuthorDate: Thu Apr 21 18:45:06 2022 -0600

    remove two source files that only had re-exports (#2313)
---
 datafusion/core/src/logical_plan/builder.rs   |  2 +-
 datafusion/core/src/logical_plan/dfschema.rs  | 21 ---------------------
 datafusion/core/src/logical_plan/mod.rs       |  7 ++-----
 datafusion/core/src/logical_plan/operators.rs | 18 ------------------
 4 files changed, 3 insertions(+), 45 deletions(-)

diff --git a/datafusion/core/src/logical_plan/builder.rs b/datafusion/core/src/logical_plan/builder.rs
index 6b08b5beb..a0914ae73 100644
--- a/datafusion/core/src/logical_plan/builder.rs
+++ b/datafusion/core/src/logical_plan/builder.rs
@@ -43,7 +43,6 @@ use std::{
     sync::Arc,
 };
 
-use super::dfschema::ToDFSchema;
 use super::{exprlist_to_fields, Expr, JoinConstraint, JoinType, LogicalPlan, PlanType};
 use crate::logical_plan::{
     columnize_expr, normalize_col, normalize_cols, provider_as_source,
@@ -51,6 +50,7 @@ use crate::logical_plan::{
     Partitioning, Repartition, Values,
 };
 use crate::sql::utils::group_window_expr_by_sort_keys;
+use datafusion_common::ToDFSchema;
 
 /// Default table name for unnamed table
 pub const UNNAMED_TABLE: &str = "?table?";
diff --git a/datafusion/core/src/logical_plan/dfschema.rs b/datafusion/core/src/logical_plan/dfschema.rs
deleted file mode 100644
index eb624283e..000000000
--- a/datafusion/core/src/logical_plan/dfschema.rs
+++ /dev/null
@@ -1,21 +0,0 @@
-// Licensed to the Apache Software Foundation (ASF) under one
-// or more contributor license agreements.  See the NOTICE file
-// distributed with this work for additional information
-// regarding copyright ownership.  The ASF licenses this file
-// to you under the Apache License, Version 2.0 (the
-// "License"); you may not use this file except in compliance
-// with the License.  You may obtain a copy of the License at
-//
-//   http://www.apache.org/licenses/LICENSE-2.0
-//
-// Unless required by applicable law or agreed to in writing,
-// software distributed under the License is distributed on an
-// "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-// KIND, either express or implied.  See the License for the
-// specific language governing permissions and limitations
-// under the License.
-
-//! DFSchema is an extended schema struct that DataFusion uses to provide support for
-//! fields with optional relation names.
-
-pub use datafusion_common::{DFField, DFSchema, DFSchemaRef, ExprSchema, ToDFSchema};
diff --git a/datafusion/core/src/logical_plan/mod.rs b/datafusion/core/src/logical_plan/mod.rs
index 488a2b954..f131d3389 100644
--- a/datafusion/core/src/logical_plan/mod.rs
+++ b/datafusion/core/src/logical_plan/mod.rs
@@ -22,20 +22,18 @@
 //! physical query plans and executed.
 
 pub(crate) mod builder;
-mod dfschema;
 mod expr;
 mod expr_rewriter;
 mod expr_simplier;
 mod expr_visitor;
-mod operators;
 pub mod plan;
 mod registry;
 pub mod window_frames;
 pub use builder::{
     build_join_schema, union_with_alias, LogicalPlanBuilder, UNNAMED_TABLE,
 };
-pub use datafusion_expr::expr_fn::binary_expr;
-pub use dfschema::{DFField, DFSchema, DFSchemaRef, ToDFSchema};
+pub use datafusion_common::{DFField, DFSchema, DFSchemaRef, ToDFSchema};
+pub use datafusion_expr::{expr_fn::binary_expr, Operator};
 
 pub use crate::logical_expr::ExprSchemable;
 pub use expr::{
@@ -57,7 +55,6 @@ pub use expr_rewriter::{
 };
 pub use expr_simplier::{ExprSimplifiable, SimplifyInfo};
 pub use expr_visitor::{ExprVisitable, ExpressionVisitor, Recursion};
-pub use operators::Operator;
 pub use plan::{provider_as_source, source_as_provider};
 pub use plan::{
     CreateCatalog, CreateCatalogSchema, CreateExternalTable, CreateMemoryTable,
diff --git a/datafusion/core/src/logical_plan/operators.rs b/datafusion/core/src/logical_plan/operators.rs
deleted file mode 100644
index 132f8a89f..000000000
--- a/datafusion/core/src/logical_plan/operators.rs
+++ /dev/null
@@ -1,18 +0,0 @@
-// Licensed to the Apache Software Foundation (ASF) under one
-// or more contributor license agreements.  See the NOTICE file
-// distributed with this work for additional information
-// regarding copyright ownership.  The ASF licenses this file
-// to you under the Apache License, Version 2.0 (the
-// "License"); you may not use this file except in compliance
-// with the License.  You may obtain a copy of the License at
-//
-//   http://www.apache.org/licenses/LICENSE-2.0
-//
-// Unless required by applicable law or agreed to in writing,
-// software distributed under the License is distributed on an
-// "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-// KIND, either express or implied.  See the License for the
-// specific language governing permissions and limitations
-// under the License.
-
-pub use datafusion_expr::Operator;