Skip to content

Commit

Permalink
Finish renaming arroyo-df crate to arroyo-planner
Browse files Browse the repository at this point in the history
  • Loading branch information
mwylde committed Dec 12, 2024
1 parent a8b95f1 commit 3c5e0d9
Show file tree
Hide file tree
Showing 21 changed files with 81 additions and 80 deletions.
106 changes: 53 additions & 53 deletions Cargo.lock

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

2 changes: 1 addition & 1 deletion crates/arroyo-api/Cargo.toml
Original file line number Diff line number Diff line change
Expand Up @@ -9,7 +9,7 @@ default = []

[dependencies]
arroyo-types = { path = "../arroyo-types" }
arroyo-df = { path = "../arroyo-planner" }
arroyo-planner = { path = "../arroyo-planner" }
arroyo-rpc = { path = "../arroyo-rpc" }
arroyo-server-common = { path = "../arroyo-server-common" }
arroyo-operator = { path = "../arroyo-operator" }
Expand Down
4 changes: 2 additions & 2 deletions crates/arroyo-api/src/pipelines.rs
Original file line number Diff line number Diff line change
Expand Up @@ -27,8 +27,8 @@ use arroyo_connectors::kafka::{KafkaConfig, KafkaTable, SchemaRegistry};
use arroyo_datastream::logical::{
ChainedLogicalOperator, LogicalNode, LogicalProgram, OperatorChain, OperatorName,
};
use arroyo_df::{ArroyoSchemaProvider, CompiledSql, SqlConfig};
use arroyo_formats::ser::ArrowSerializer;
use arroyo_planner::{ArroyoSchemaProvider, CompiledSql, SqlConfig};
use arroyo_rpc::formats::Format;
use arroyo_rpc::grpc::rpc::compiler_grpc_client::CompilerGrpcClient;
use arroyo_rpc::public_ids::{generate_id, IdTypes};
Expand Down Expand Up @@ -174,7 +174,7 @@ async fn compile_sql<'a>(
schema_provider.add_connection_profile(profile);
}

arroyo_df::parse_and_get_program(
arroyo_planner::parse_and_get_program(
&query,
schema_provider,
SqlConfig {
Expand Down
2 changes: 1 addition & 1 deletion crates/arroyo-planner/Cargo.toml
Original file line number Diff line number Diff line change
@@ -1,5 +1,5 @@
[package]
name = "arroyo-df"
name = "arroyo-planner"
version = "0.13.0-dev"
edition = "2021"

Expand Down
2 changes: 1 addition & 1 deletion crates/arroyo-sql-testing/Cargo.toml
Original file line number Diff line number Diff line change
Expand Up @@ -21,7 +21,7 @@ serde_json = "1.0"
anyhow = "1.0"

arroyo-types = { path = "../arroyo-types" }
arroyo-df = { path = "../arroyo-planner" }
arroyo-planner = { path = "../arroyo-planner" }
arroyo-datastream = { path = "../arroyo-datastream" }
arroyo-rpc = { path = "../arroyo-rpc" }
arroyo-worker = { path = "../arroyo-worker" }
Expand Down
2 changes: 1 addition & 1 deletion crates/arroyo-sql-testing/src/smoke_tests.rs
Original file line number Diff line number Diff line change
Expand Up @@ -2,7 +2,7 @@ use anyhow::Result;
use arroyo_datastream::logical::{
LogicalEdge, LogicalEdgeType, LogicalGraph, LogicalNode, LogicalProgram, OperatorName,
};
use arroyo_df::{parse_and_get_arrow_program, ArroyoSchemaProvider, SqlConfig};
use arroyo_planner::{parse_and_get_arrow_program, ArroyoSchemaProvider, SqlConfig};
use arroyo_state::parquet::ParquetBackend;
use petgraph::algo::has_path_connecting;
use petgraph::visit::EdgeRef;
Expand Down
2 changes: 1 addition & 1 deletion crates/arroyo-worker/Cargo.toml
Original file line number Diff line number Diff line change
Expand Up @@ -15,7 +15,7 @@ arroyo-storage = { path = "../arroyo-storage" }
arroyo-metrics = { path = "../arroyo-metrics" }
arroyo-formats = { path = "../arroyo-formats" }
arroyo-datastream = { path = "../arroyo-datastream" }
arroyo-df = { path = "../arroyo-planner" }
arroyo-planner = { path = "../arroyo-planner" }
arroyo-operator = { path = "../arroyo-operator" }
arroyo-connectors = { path = "../arroyo-connectors" }
arroyo-udf-host = { path = "../arroyo-udf/arroyo-udf-host" }
Expand Down
2 changes: 1 addition & 1 deletion crates/arroyo-worker/src/arrow/async_udf.rs
Original file line number Diff line number Diff line change
Expand Up @@ -3,12 +3,12 @@ use arrow::row::{OwnedRow, RowConverter, SortField};
use arrow_array::{make_array, Array, RecordBatch, UInt64Array};
use arrow_schema::{Field, Schema};
use arroyo_datastream::logical::DylibUdfConfig;
use arroyo_df::ASYNC_RESULT_FIELD;
use arroyo_operator::context::{Collector, OperatorContext};
use arroyo_operator::operator::{
ArrowOperator, AsDisplayable, ConstructedOperator, DisplayableOperator, OperatorConstructor,
Registry,
};
use arroyo_planner::ASYNC_RESULT_FIELD;
use arroyo_rpc::grpc::api;
use arroyo_rpc::grpc::rpc::TableConfig;
use arroyo_state::global_table_config;
Expand Down
2 changes: 1 addition & 1 deletion crates/arroyo-worker/src/arrow/instant_join.rs
Original file line number Diff line number Diff line change
Expand Up @@ -2,11 +2,11 @@ use super::sync::streams::KeyedCloneableStreamFuture;
use anyhow::Result;
use arrow::compute::{max, min, partition, sort_to_indices, take};
use arrow_array::{RecordBatch, TimestampNanosecondArray};
use arroyo_df::physical::{ArroyoPhysicalExtensionCodec, DecodingContext};
use arroyo_operator::context::{Collector, OperatorContext};
use arroyo_operator::operator::{
ArrowOperator, ConstructedOperator, DisplayableOperator, OperatorConstructor, Registry,
};
use arroyo_planner::physical::{ArroyoPhysicalExtensionCodec, DecodingContext};
use arroyo_rpc::{
df::{ArroyoSchema, ArroyoSchemaRef},
grpc::{api, rpc::TableConfig},
Expand Down
2 changes: 1 addition & 1 deletion crates/arroyo-worker/src/arrow/join_with_expiration.rs
Original file line number Diff line number Diff line change
@@ -1,12 +1,12 @@
use anyhow::Result;
use arrow::compute::concat_batches;
use arrow_array::RecordBatch;
use arroyo_df::physical::{ArroyoPhysicalExtensionCodec, DecodingContext};
use arroyo_operator::context::{Collector, OperatorContext};
use arroyo_operator::operator::{
ArrowOperator, AsDisplayable, ConstructedOperator, DisplayableOperator, OperatorConstructor,
Registry,
};
use arroyo_planner::physical::{ArroyoPhysicalExtensionCodec, DecodingContext};
use arroyo_rpc::{
df::ArroyoSchema,
grpc::{api, rpc::TableConfig},
Expand Down
4 changes: 2 additions & 2 deletions crates/arroyo-worker/src/arrow/mod.rs
Original file line number Diff line number Diff line change
@@ -1,12 +1,12 @@
use arrow::datatypes::SchemaRef;
use arrow_array::RecordBatch;
use arroyo_df::physical::ArroyoPhysicalExtensionCodec;
use arroyo_df::physical::DecodingContext;
use arroyo_operator::context::{Collector, OperatorContext};
use arroyo_operator::operator::{
ArrowOperator, AsDisplayable, ConstructedOperator, DisplayableOperator, OperatorConstructor,
Registry,
};
use arroyo_planner::physical::ArroyoPhysicalExtensionCodec;
use arroyo_planner::physical::DecodingContext;
use arroyo_rpc::grpc::api;
use datafusion::common::DataFusionError;
use datafusion::common::Result as DFResult;
Expand Down
4 changes: 2 additions & 2 deletions crates/arroyo-worker/src/arrow/session_aggregating_window.rs
Original file line number Diff line number Diff line change
Expand Up @@ -17,11 +17,11 @@ use arrow_array::{
TimestampNanosecondArray,
};
use arrow_schema::{DataType, Field, FieldRef};
use arroyo_df::schemas::window_arrow_struct;
use arroyo_operator::{
context::OperatorContext,
operator::{ArrowOperator, ConstructedOperator, OperatorConstructor},
};
use arroyo_planner::schemas::window_arrow_struct;
use arroyo_rpc::{
grpc::{api, rpc::TableConfig},
Converter,
Expand All @@ -32,9 +32,9 @@ use arroyo_state::{
use arroyo_types::{from_nanos, print_time, to_nanos, CheckpointBarrier, Watermark};
use datafusion::{execution::context::SessionContext, physical_plan::ExecutionPlan};

use arroyo_df::physical::{ArroyoPhysicalExtensionCodec, DecodingContext};
use arroyo_operator::context::Collector;
use arroyo_operator::operator::Registry;
use arroyo_planner::physical::{ArroyoPhysicalExtensionCodec, DecodingContext};
use arroyo_rpc::df::{ArroyoSchema, ArroyoSchemaRef};
use datafusion::execution::{
runtime_env::{RuntimeConfig, RuntimeEnv},
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -22,9 +22,9 @@ use std::{
use futures::stream::FuturesUnordered;

use super::sync::streams::KeyedCloneableStreamFuture;
use arroyo_df::physical::{ArroyoPhysicalExtensionCodec, DecodingContext};
use arroyo_operator::context::Collector;
use arroyo_operator::operator::{AsDisplayable, DisplayableOperator, Registry};
use arroyo_planner::physical::{ArroyoPhysicalExtensionCodec, DecodingContext};
use arroyo_rpc::df::ArroyoSchema;
use datafusion::execution::{
runtime_env::{RuntimeConfig, RuntimeEnv},
Expand Down
4 changes: 2 additions & 2 deletions crates/arroyo-worker/src/arrow/tumbling_aggregating_window.rs
Original file line number Diff line number Diff line change
Expand Up @@ -2,12 +2,12 @@ use anyhow::{anyhow, Result};
use arrow::compute::{partition, sort_to_indices, take};
use arrow_array::{types::TimestampNanosecondType, Array, PrimitiveArray, RecordBatch};
use arrow_schema::SchemaRef;
use arroyo_df::schemas::add_timestamp_field_arrow;
use arroyo_operator::context::{Collector, OperatorContext};
use arroyo_operator::operator::{
ArrowOperator, AsDisplayable, ConstructedOperator, DisplayableOperator, OperatorConstructor,
Registry,
};
use arroyo_planner::schemas::add_timestamp_field_arrow;
use arroyo_rpc::grpc::{api, rpc::TableConfig};
use arroyo_state::timestamp_table_config;
use arroyo_types::{from_nanos, print_time, to_nanos, CheckpointBarrier, Watermark};
Expand All @@ -25,7 +25,7 @@ use std::{
time::SystemTime,
};

use arroyo_df::physical::{ArroyoPhysicalExtensionCodec, DecodingContext};
use arroyo_planner::physical::{ArroyoPhysicalExtensionCodec, DecodingContext};
use arroyo_rpc::df::ArroyoSchema;
use datafusion::execution::{
runtime_env::{RuntimeConfig, RuntimeEnv},
Expand Down
2 changes: 1 addition & 1 deletion crates/arroyo-worker/src/arrow/updating_aggregator.rs
Original file line number Diff line number Diff line change
Expand Up @@ -12,7 +12,6 @@ use arrow_array::{Array, BooleanArray, RecordBatch, StructArray};

use arrow_array::cast::AsArray;
use arrow_schema::SchemaRef;
use arroyo_df::physical::{ArroyoPhysicalExtensionCodec, DecodingContext};
use arroyo_operator::context::Collector;
use arroyo_operator::{
context::OperatorContext,
Expand All @@ -21,6 +20,7 @@ use arroyo_operator::{
OperatorConstructor, Registry,
},
};
use arroyo_planner::physical::{ArroyoPhysicalExtensionCodec, DecodingContext};
use arroyo_rpc::df::ArroyoSchemaRef;
use arroyo_rpc::grpc::{api::UpdatingAggregateOperator, rpc::TableConfig};
use arroyo_rpc::{updating_meta_fields, UPDATING_META_FIELD};
Expand Down
2 changes: 1 addition & 1 deletion crates/arroyo-worker/src/arrow/window_fn.rs
Original file line number Diff line number Diff line change
Expand Up @@ -6,11 +6,11 @@ use std::{collections::BTreeMap, sync::RwLock, time::SystemTime};
use anyhow::{anyhow, Result};
use arrow::compute::{max, min};
use arrow_array::RecordBatch;
use arroyo_df::physical::{ArroyoPhysicalExtensionCodec, DecodingContext};
use arroyo_operator::context::{Collector, OperatorContext};
use arroyo_operator::operator::{
ArrowOperator, ConstructedOperator, OperatorConstructor, Registry,
};
use arroyo_planner::physical::{ArroyoPhysicalExtensionCodec, DecodingContext};
use arroyo_rpc::df::ArroyoSchema;
use arroyo_rpc::grpc::rpc::TableConfig;
use arroyo_rpc::{df::ArroyoSchemaRef, grpc::api};
Expand Down
2 changes: 1 addition & 1 deletion crates/arroyo-worker/src/engine.rs
Original file line number Diff line number Diff line change
Expand Up @@ -13,11 +13,11 @@ use arroyo_connectors::connectors;
use arroyo_datastream::logical::{
LogicalEdge, LogicalEdgeType, LogicalGraph, LogicalNode, OperatorChain, OperatorName,
};
use arroyo_df::physical::new_registry;
use arroyo_operator::context::{batch_bounded, BatchReceiver, BatchSender, OperatorContext};
use arroyo_operator::operator::Registry;
use arroyo_operator::operator::{ChainedOperator, ConstructedOperator, OperatorNode, SourceNode};
use arroyo_operator::ErasedConstructor;
use arroyo_planner::physical::new_registry;
use arroyo_rpc::config::config;
use arroyo_rpc::df::ArroyoSchema;
use arroyo_rpc::grpc::{
Expand Down
2 changes: 1 addition & 1 deletion crates/arroyo-worker/src/lib.rs
Original file line number Diff line number Diff line change
Expand Up @@ -40,7 +40,7 @@ use prost::Message;

use crate::utils::to_d2;
use arroyo_datastream::logical::LogicalProgram;
use arroyo_df::physical::new_registry;
use arroyo_planner::physical::new_registry;
use arroyo_rpc::config::config;
use arroyo_server_common::shutdown::ShutdownGuard;
use arroyo_server_common::wrap_start;
Expand Down
2 changes: 1 addition & 1 deletion crates/arroyo-worker/src/utils.rs
Original file line number Diff line number Diff line change
@@ -1,8 +1,8 @@
use crate::engine::construct_operator;
use arrow_schema::Schema;
use arroyo_datastream::logical::{ChainedLogicalOperator, LogicalEdgeType, LogicalProgram};
use arroyo_df::physical::new_registry;
use arroyo_operator::operator::Registry;
use arroyo_planner::physical::new_registry;
use std::fmt::Write;
use std::sync::Arc;

Expand Down
Loading

0 comments on commit 3c5e0d9

Please sign in to comment.