You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@beam.apache.org by ke...@apache.org on 2022/06/15 20:37:08 UTC

[beam] branch master updated: Sharding IO tests (Kafka, Debezium, JDBC, Kinesis, Neo4j) from the javaPostCommit task (#21804)

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

kenn pushed a commit to branch master
in repository https://gitbox.apache.org/repos/asf/beam.git


The following commit(s) were added to refs/heads/master by this push:
     new b1332824612 Sharding IO tests (Kafka, Debezium, JDBC, Kinesis, Neo4j) from the javaPostCommit task (#21804)
b1332824612 is described below

commit b1332824612742bc842293289e64e1f8e0b09727
Author: Benjamin Gonzalez <74...@users.noreply.github.com>
AuthorDate: Wed Jun 15 15:37:02 2022 -0500

    Sharding IO tests (Kafka, Debezium, JDBC, Kinesis, Neo4j) from the javaPostCommit task (#21804)
---
 .../job_PreCommit_Java_Debezium_IO_Direct.groovy   | 37 ++++++++++++++++++++++
 .../job_PreCommit_Java_JDBC_IO_Direct.groovy       | 37 ++++++++++++++++++++++
 .../job_PreCommit_Java_Kafka_IO_Direct.groovy      | 37 ++++++++++++++++++++++
 .../job_PreCommit_Java_Kinesis_IO_Direct.groovy    | 37 ++++++++++++++++++++++
 .../job_PreCommit_Java_Neo4j_IO_Direct.groovy      | 37 ++++++++++++++++++++++
 build.gradle.kts                                   |  5 ---
 6 files changed, 185 insertions(+), 5 deletions(-)

diff --git a/.test-infra/jenkins/job_PreCommit_Java_Debezium_IO_Direct.groovy b/.test-infra/jenkins/job_PreCommit_Java_Debezium_IO_Direct.groovy
new file mode 100644
index 00000000000..8b42448faf9
--- /dev/null
+++ b/.test-infra/jenkins/job_PreCommit_Java_Debezium_IO_Direct.groovy
@@ -0,0 +1,37 @@
+/*
+ * 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.
+ */
+
+import PrecommitJobBuilder
+
+PrecommitJobBuilder builder = new PrecommitJobBuilder(
+    scope: this,
+    nameBase: 'Java_Debezium_IO_Direct',
+    gradleTask: ':sdks:java:io:debezium:integrationTest',
+    gradleSwitches: [
+      '-PdisableSpotlessCheck=true'
+    ], // spotless checked in separate pre-commit
+    triggerPathPatterns: [
+      '^sdks/java/io/debezium/.*$',
+    ],
+    timeoutMins: 60,
+    )
+builder.build {
+  publishers {
+    archiveJunit('**/build/test-results/**/*.xml')
+  }
+}
diff --git a/.test-infra/jenkins/job_PreCommit_Java_JDBC_IO_Direct.groovy b/.test-infra/jenkins/job_PreCommit_Java_JDBC_IO_Direct.groovy
new file mode 100644
index 00000000000..123a30fac56
--- /dev/null
+++ b/.test-infra/jenkins/job_PreCommit_Java_JDBC_IO_Direct.groovy
@@ -0,0 +1,37 @@
+/*
+ * 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.
+ */
+
+import PrecommitJobBuilder
+
+PrecommitJobBuilder builder = new PrecommitJobBuilder(
+    scope: this,
+    nameBase: 'Java_JDBC_IO_Direct',
+    gradleTask: ':sdks:java:io:jdbc:integrationTest',
+    gradleSwitches: [
+      '-PdisableSpotlessCheck=true'
+    ], // spotless checked in separate pre-commit
+    triggerPathPatterns: [
+      '^sdks/java/io/jdbc/.*$',
+    ],
+    timeoutMins: 60,
+    )
+builder.build {
+  publishers {
+    archiveJunit('**/build/test-results/**/*.xml')
+  }
+}
diff --git a/.test-infra/jenkins/job_PreCommit_Java_Kafka_IO_Direct.groovy b/.test-infra/jenkins/job_PreCommit_Java_Kafka_IO_Direct.groovy
new file mode 100644
index 00000000000..87c3044d4d2
--- /dev/null
+++ b/.test-infra/jenkins/job_PreCommit_Java_Kafka_IO_Direct.groovy
@@ -0,0 +1,37 @@
+/*
+ * 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.
+ */
+
+import PrecommitJobBuilder
+
+PrecommitJobBuilder builder = new PrecommitJobBuilder(
+    scope: this,
+    nameBase: 'Java_Kafka_IO_Direct',
+    gradleTask: ':sdks:java:io:kafka:kafkaVersionsCompatibilityTest',
+    gradleSwitches: [
+      '-PdisableSpotlessCheck=true'
+    ], // spotless checked in separate pre-commit
+    triggerPathPatterns: [
+      '^sdks/java/io/kafka/.*$',
+    ],
+    timeoutMins: 120,
+    )
+builder.build {
+  publishers {
+    archiveJunit('**/build/test-results/**/*.xml')
+  }
+}
diff --git a/.test-infra/jenkins/job_PreCommit_Java_Kinesis_IO_Direct.groovy b/.test-infra/jenkins/job_PreCommit_Java_Kinesis_IO_Direct.groovy
new file mode 100644
index 00000000000..cda54ba0867
--- /dev/null
+++ b/.test-infra/jenkins/job_PreCommit_Java_Kinesis_IO_Direct.groovy
@@ -0,0 +1,37 @@
+/*
+ * 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.
+ */
+
+import PrecommitJobBuilder
+
+PrecommitJobBuilder builder = new PrecommitJobBuilder(
+    scope: this,
+    nameBase: 'Java_Kinesis_IO_Direct',
+    gradleTask: ':sdks:java:io:kinesis:integrationTest',
+    gradleSwitches: [
+      '-PdisableSpotlessCheck=true'
+    ], // spotless checked in separate pre-commit
+    triggerPathPatterns: [
+      '^sdks/java/io/kinesis/.*$',
+    ],
+    timeoutMins: 60,
+    )
+builder.build {
+  publishers {
+    archiveJunit('**/build/test-results/**/*.xml')
+  }
+}
diff --git a/.test-infra/jenkins/job_PreCommit_Java_Neo4j_IO_Direct.groovy b/.test-infra/jenkins/job_PreCommit_Java_Neo4j_IO_Direct.groovy
new file mode 100644
index 00000000000..9042184bd65
--- /dev/null
+++ b/.test-infra/jenkins/job_PreCommit_Java_Neo4j_IO_Direct.groovy
@@ -0,0 +1,37 @@
+/*
+ * 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.
+ */
+
+import PrecommitJobBuilder
+
+PrecommitJobBuilder builder = new PrecommitJobBuilder(
+    scope: this,
+    nameBase: 'Java_Neo4j_IO_Direct',
+    gradleTask: ':sdks:java:io:neo4j:integrationTest',
+    gradleSwitches: [
+      '-PdisableSpotlessCheck=true'
+    ], // spotless checked in separate pre-commit
+    triggerPathPatterns: [
+      '^sdks/java/io/neo4j/.*$',
+    ],
+    timeoutMins: 60,
+    )
+builder.build {
+  publishers {
+    archiveJunit('**/build/test-results/**/*.xml')
+  }
+}
diff --git a/build.gradle.kts b/build.gradle.kts
index c6c0059f62a..e4c9fe4e84f 100644
--- a/build.gradle.kts
+++ b/build.gradle.kts
@@ -196,15 +196,10 @@ tasks.register("javaPreCommitPortabilityApi") {
 tasks.register("javaPostCommit") {
   dependsOn(":sdks:java:extensions:google-cloud-platform-core:postCommit")
   dependsOn(":sdks:java:extensions:zetasketch:postCommit")
-  dependsOn(":sdks:java:io:debezium:integrationTest")
-  dependsOn(":sdks:java:io:jdbc:integrationTest")
   dependsOn(":sdks:java:io:google-cloud-platform:postCommit")
-  dependsOn(":sdks:java:io:kinesis:integrationTest")
   dependsOn(":sdks:java:io:amazon-web-services:integrationTest")
   dependsOn(":sdks:java:io:amazon-web-services2:integrationTest")
   dependsOn(":sdks:java:extensions:ml:postCommit")
-  dependsOn(":sdks:java:io:kafka:kafkaVersionsCompatibilityTest")
-  dependsOn(":sdks:java:io:neo4j:integrationTest")
 }
 
 tasks.register("javaPostCommitSickbay") {