You are viewing a plain text version of this content. The canonical link for it is here.
Posted to github@arrow.apache.org by "alamb (via GitHub)" <gi...@apache.org> on 2023/11/02 19:01:59 UTC

[PR] Minor: remove uncessary #cfg test [arrow-datafusion]

alamb opened a new pull request, #8036:
URL: https://github.com/apache/arrow-datafusion/pull/8036

   ## Which issue does this PR close?
   
   Follow on to https://github.com/apache/arrow-datafusion/pull/8025
   
   ## Rationale for this change
   
   @crepererum  noticed we could remove a level of indirection in the `fuzz` integration test -- https://github.com/apache/arrow-datafusion/pull/8025#discussion_r1379810867
   
   ## What changes are included in this PR?
   
   Remove unecessary cfg
   
   ## Are these changes tested?
   existing coverage. you can see the tests still run:
   
   ```
   ```
   )
   ## Are there any user-facing changes?
   
   No


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: github-unsubscribe@arrow.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org


Re: [PR] Minor: remove uncessary #cfg test [arrow-datafusion]

Posted by "crepererum (via GitHub)" <gi...@apache.org>.
crepererum merged PR #8036:
URL: https://github.com/apache/arrow-datafusion/pull/8036


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: github-unsubscribe@arrow.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org


Re: [PR] Minor: remove uncessary #cfg test [arrow-datafusion]

Posted by "alamb (via GitHub)" <gi...@apache.org>.
alamb commented on code in PR #8036:
URL: https://github.com/apache/arrow-datafusion/pull/8036#discussion_r1380656322


##########
datafusion/core/tests/fuzz_cases/aggregate_fuzz.rs:
##########
@@ -35,39 +35,33 @@ use datafusion_physical_expr::expressions::{col, Sum};
 use datafusion_physical_expr::{AggregateExpr, PhysicalSortExpr};
 use test_utils::add_empty_batches;
 
-#[cfg(test)]
-#[allow(clippy::items_after_test_module)]
-mod tests {
-    use super::*;
-
-    #[tokio::test(flavor = "multi_thread", worker_threads = 8)]
-    async fn aggregate_test() {
-        let test_cases = vec![
-            vec!["a"],
-            vec!["b", "a"],
-            vec!["c", "a"],
-            vec!["c", "b", "a"],
-            vec!["d", "a"],
-            vec!["d", "b", "a"],
-            vec!["d", "c", "a"],
-            vec!["d", "c", "b", "a"],
-        ];
-        let n = 300;
-        let distincts = vec![10, 20];
-        for distinct in distincts {
-            let mut handles = Vec::new();
-            for i in 0..n {
-                let test_idx = i % test_cases.len();
-                let group_by_columns = test_cases[test_idx].clone();
-                let job = tokio::spawn(run_aggregate_test(
-                    make_staggered_batches::<true>(1000, distinct, i as u64),
-                    group_by_columns,
-                ));
-                handles.push(job);
-            }
-            for job in handles {
-                job.await.unwrap();
-            }
+#[tokio::test(flavor = "multi_thread", worker_threads = 8)]

Review Comment:
   Reviewing this with whitespace blind diff shows what is going on pretty clearly



-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: github-unsubscribe@arrow.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org


Re: [PR] Minor: remove uncessary #cfg test [arrow-datafusion]

Posted by "waynexia (via GitHub)" <gi...@apache.org>.
waynexia commented on code in PR #8036:
URL: https://github.com/apache/arrow-datafusion/pull/8036#discussion_r1381117383


##########
datafusion/core/src/datasource/file_format/arrow.rs:
##########
@@ -105,7 +105,7 @@ impl FileFormat for ArrowFormat {
 const ARROW_MAGIC: [u8; 6] = [b'A', b'R', b'R', b'O', b'W', b'1'];
 const CONTINUATION_MARKER: [u8; 4] = [0xff; 4];
 
-/// Custom implementation of inferring schema. Should eventually be moved upstream to arrow-rs. 
+/// Custom implementation of inferring schema. Should eventually be moved upstream to arrow-rs.
 /// See https://github.com/apache/arrow-rs/issues/5021

Review Comment:
   ```suggestion
   /// See <https://github.com/apache/arrow-rs/issues/5021>
   ```
   
   Copied from `cargo doc`'s output. First heard of [this lint](https://github.com/rust-lang/rust/issues/77501) to me 🫣



##########
datafusion/core/src/datasource/file_format/arrow.rs:
##########
@@ -105,7 +105,7 @@ impl FileFormat for ArrowFormat {
 const ARROW_MAGIC: [u8; 6] = [b'A', b'R', b'R', b'O', b'W', b'1'];
 const CONTINUATION_MARKER: [u8; 4] = [0xff; 4];
 
-/// Custom implementation of inferring schema. Should eventually be moved upstream to arrow-rs. 
+/// Custom implementation of inferring schema. Should eventually be moved upstream to arrow-rs.
 /// See https://github.com/apache/arrow-rs/issues/5021

Review Comment:
   ```suggestion
   /// See <https://github.com/apache/arrow-rs/issues/5021>
   ```
   
   Copied from `cargo doc`'s output. First heard of [this lint](https://github.com/rust-lang/rust/issues/77501) to me 🫣



-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: github-unsubscribe@arrow.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org