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 2017/03/28 17:06:17 UTC

[1/2] beam git commit: Rename RunnableOnService to ValidatesRunner in poms and Jenkins jobs

Repository: beam
Updated Branches:
  refs/heads/master 118da8171 -> 0582eb9fc


Rename RunnableOnService to ValidatesRunner in poms and Jenkins jobs


Project: http://git-wip-us.apache.org/repos/asf/beam/repo
Commit: http://git-wip-us.apache.org/repos/asf/beam/commit/8cff7442
Tree: http://git-wip-us.apache.org/repos/asf/beam/tree/8cff7442
Diff: http://git-wip-us.apache.org/repos/asf/beam/diff/8cff7442

Branch: refs/heads/master
Commit: 8cff7442acd04efece95f8780fc786c0827301c8
Parents: 85b820c
Author: Jason Kuster <ja...@google.com>
Authored: Mon Mar 27 21:18:29 2017 -0700
Committer: Kenneth Knowles <kl...@google.com>
Committed: Tue Mar 28 10:05:20 2017 -0700

----------------------------------------------------------------------
 ...ostCommit_Java_RunnableOnService_Apex.groovy | 47 -------------------
 ...ommit_Java_RunnableOnService_Dataflow.groovy | 45 ------------------
 ...stCommit_Java_RunnableOnService_Flink.groovy | 44 ------------------
 ...ommit_Java_RunnableOnService_Gearpump.groovy | 49 --------------------
 ...stCommit_Java_RunnableOnService_Spark.groovy | 44 ------------------
 ..._PostCommit_Java_ValidatesRunner_Apex.groovy | 48 +++++++++++++++++++
 ...tCommit_Java_ValidatesRunner_Dataflow.groovy | 45 ++++++++++++++++++
 ...PostCommit_Java_ValidatesRunner_Flink.groovy | 43 +++++++++++++++++
 ...tCommit_Java_ValidatesRunner_Gearpump.groovy | 49 ++++++++++++++++++++
 ...PostCommit_Java_ValidatesRunner_Spark.groovy | 44 ++++++++++++++++++
 runners/apex/pom.xml                            |  4 +-
 runners/direct-java/pom.xml                     |  2 +-
 runners/flink/examples/pom.xml                  |  4 +-
 runners/flink/runner/pom.xml                    |  8 ++--
 runners/google-cloud-dataflow-java/pom.xml      |  2 +-
 runners/pom.xml                                 | 10 ++--
 runners/spark/pom.xml                           |  4 +-
 17 files changed, 246 insertions(+), 246 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/beam/blob/8cff7442/.jenkins/job_beam_PostCommit_Java_RunnableOnService_Apex.groovy
----------------------------------------------------------------------
diff --git a/.jenkins/job_beam_PostCommit_Java_RunnableOnService_Apex.groovy b/.jenkins/job_beam_PostCommit_Java_RunnableOnService_Apex.groovy
deleted file mode 100644
index b03e34e..0000000
--- a/.jenkins/job_beam_PostCommit_Java_RunnableOnService_Apex.groovy
+++ /dev/null
@@ -1,47 +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.
- */
-
-import common_job_properties
-
-// This job runs the suite of RunnableOnService tests against the Apex runner.
-mavenJob('beam_PostCommit_Java_RunnableOnService_Apex') {
-  description('Runs the RunnableOnService suite on the Apex runner.')
-
-  // Set common parameters.
-  common_job_properties.setTopLevelMainJobProperties(delegate)
-
-  // Set maven parameters.
-  common_job_properties.setMavenConfig(delegate)
-
-  // Sets that this is a PostCommit job.
-  common_job_properties.setPostCommit(delegate)
-
-  // Allows triggering this build against pull requests.
-  common_job_properties.enablePhraseTriggeringFromPullRequest(
-    delegate,
-    'Apache Apex Runner RunnableOnService Tests',
-    'Run Apex RunnableOnService')
-
-  // Maven goals for this job.
-  goals('''clean verify --projects runners/apex \
-      --also-make \
-      --batch-mode \
-      --errors \
-      --activate-profiles runnable-on-service-tests \
-      --activate-profiles local-runnable-on-service-tests''')
-}

http://git-wip-us.apache.org/repos/asf/beam/blob/8cff7442/.jenkins/job_beam_PostCommit_Java_RunnableOnService_Dataflow.groovy
----------------------------------------------------------------------
diff --git a/.jenkins/job_beam_PostCommit_Java_RunnableOnService_Dataflow.groovy b/.jenkins/job_beam_PostCommit_Java_RunnableOnService_Dataflow.groovy
deleted file mode 100644
index 77c4864..0000000
--- a/.jenkins/job_beam_PostCommit_Java_RunnableOnService_Dataflow.groovy
+++ /dev/null
@@ -1,45 +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.
- */
-
-import common_job_properties
-
-// This job runs the suite of RunnableOnService tests against the Dataflow
-// runner.
-mavenJob('beam_PostCommit_Java_RunnableOnService_Dataflow') {
-  description('Runs the RunnableOnService suite on the Dataflow runner.')
-
-  previousNames('beam_PostCommit_RunnableOnService_GoogleCloudDataflow')
-
-  // Set common parameters.
-  common_job_properties.setTopLevelMainJobProperties(delegate, 'master', 120)
-
-  // Set maven parameters.
-  common_job_properties.setMavenConfig(delegate)
-
-  // Sets that this is a PostCommit job.
-  common_job_properties.setPostCommit(delegate)
-
-  // Allows triggering this build against pull requests.
-  common_job_properties.enablePhraseTriggeringFromPullRequest(
-    delegate,
-    'Google Cloud Dataflow Runner RunnableOnService Tests',
-    'Run Dataflow RunnableOnService')
-
-  // Maven goals for this job.
-  goals('-B -e clean verify -am -pl runners/google-cloud-dataflow-java -DforkCount=0 -DrunnableOnServicePipelineOptions=\'[ "--runner=org.apache.beam.runners.dataflow.testing.TestDataflowRunner", "--project=apache-beam-testing", "--tempRoot=gs://temp-storage-for-runnable-on-service-tests/" ]\'')
-}

http://git-wip-us.apache.org/repos/asf/beam/blob/8cff7442/.jenkins/job_beam_PostCommit_Java_RunnableOnService_Flink.groovy
----------------------------------------------------------------------
diff --git a/.jenkins/job_beam_PostCommit_Java_RunnableOnService_Flink.groovy b/.jenkins/job_beam_PostCommit_Java_RunnableOnService_Flink.groovy
deleted file mode 100644
index 9dd0fa3..0000000
--- a/.jenkins/job_beam_PostCommit_Java_RunnableOnService_Flink.groovy
+++ /dev/null
@@ -1,44 +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.
- */
-
-import common_job_properties
-
-// This job runs the suite of RunnableOnService tests against the Flink runner.
-mavenJob('beam_PostCommit_Java_RunnableOnService_Flink') {
-  description('Runs the RunnableOnService suite on the Flink runner.')
-
-  previousNames('beam_PostCommit_RunnableOnService_FlinkLocal')
-
-  // Set common parameters.
-  common_job_properties.setTopLevelMainJobProperties(delegate)
-
-  // Set maven parameters.
-  common_job_properties.setMavenConfig(delegate)
-
-  // Sets that this is a PostCommit job.
-  common_job_properties.setPostCommit(delegate)
-
-  // Allows triggering this build against pull requests.
-  common_job_properties.enablePhraseTriggeringFromPullRequest(
-    delegate,
-    'Apache Flink Runner RunnableOnService Tests',
-    'Run Flink RunnableOnService')
-
-  // Maven goals for this job.
-  goals('-B -e clean verify -am -pl runners/flink/runner -Plocal-runnable-on-service-tests -Prunnable-on-service-tests')
-}

http://git-wip-us.apache.org/repos/asf/beam/blob/8cff7442/.jenkins/job_beam_PostCommit_Java_RunnableOnService_Gearpump.groovy
----------------------------------------------------------------------
diff --git a/.jenkins/job_beam_PostCommit_Java_RunnableOnService_Gearpump.groovy b/.jenkins/job_beam_PostCommit_Java_RunnableOnService_Gearpump.groovy
deleted file mode 100644
index 8f41c3e..0000000
--- a/.jenkins/job_beam_PostCommit_Java_RunnableOnService_Gearpump.groovy
+++ /dev/null
@@ -1,49 +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.
- */
-
-import common_job_properties
-
-// This job runs the suite of RunnableOnService tests against the Gearpump
-// runner.
-mavenJob('beam_PostCommit_Java_RunnableOnService_Gearpump') {
-  description('Runs the RunnableOnService suite on the Gearpump runner.')
-
-  previousNames('beam_PostCommit_RunnableOnService_GearpumpLocal')
-
-  // Set common parameters.
-  common_job_properties.setTopLevelMainJobProperties(
-      delegate,
-      'gearpump-runner')
-
-  // Set maven parameters.
-  common_job_properties.setMavenConfig(delegate)
-
-  // Sets that this is a PostCommit job.
-  // 0 5 31 2 * will run on Feb 31 (i.e. never) according to job properties.
-  // In post-commit this job triggers only on SCM changes.
-  common_job_properties.setPostCommit(delegate, '0 5 31 2 *')
-
-  // Allows triggering this build against pull requests.
-  common_job_properties.enablePhraseTriggeringFromPullRequest(
-    delegate,
-    'Apache Gearpump Runner RunnableOnService Tests',
-    'Run Gearpump RunnableOnService')
-
-  // Maven goals for this job.
-  goals('-B -e clean verify -am -pl runners/gearpump -DforkCount=0 -DrunnableOnServicePipelineOptions=\'[ "--runner=TestGearpumpRunner", "--streaming=false" ]\'')
-}

http://git-wip-us.apache.org/repos/asf/beam/blob/8cff7442/.jenkins/job_beam_PostCommit_Java_RunnableOnService_Spark.groovy
----------------------------------------------------------------------
diff --git a/.jenkins/job_beam_PostCommit_Java_RunnableOnService_Spark.groovy b/.jenkins/job_beam_PostCommit_Java_RunnableOnService_Spark.groovy
deleted file mode 100644
index a1983bd..0000000
--- a/.jenkins/job_beam_PostCommit_Java_RunnableOnService_Spark.groovy
+++ /dev/null
@@ -1,44 +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.
- */
-
-import common_job_properties
-
-// This job runs the suite of RunnableOnService tests against the Spark runner.
-mavenJob('beam_PostCommit_Java_RunnableOnService_Spark') {
-  description('Runs the RunnableOnService suite on the Spark runner.')
-
-  previousNames('beam_PostCommit_RunnableOnService_SparkLocal')
-
-  // Set common parameters.
-  common_job_properties.setTopLevelMainJobProperties(delegate)
-
-  // Set maven parameters.
-  common_job_properties.setMavenConfig(delegate)
-
-  // Sets that this is a PostCommit job.
-  common_job_properties.setPostCommit(delegate)
-
-  // Allows triggering this build against pull requests.
-  common_job_properties.enablePhraseTriggeringFromPullRequest(
-    delegate,
-    'Apache Spark Runner RunnableOnService Tests',
-    'Run Spark RunnableOnService')
-
-  // Maven goals for this job.
-  goals('-B -e clean verify -am -pl runners/spark -Prunnable-on-service-tests -Plocal-runnable-on-service-tests -Dspark.ui.enabled=false')
-}

http://git-wip-us.apache.org/repos/asf/beam/blob/8cff7442/.jenkins/job_beam_PostCommit_Java_ValidatesRunner_Apex.groovy
----------------------------------------------------------------------
diff --git a/.jenkins/job_beam_PostCommit_Java_ValidatesRunner_Apex.groovy b/.jenkins/job_beam_PostCommit_Java_ValidatesRunner_Apex.groovy
new file mode 100644
index 0000000..c16a1e2
--- /dev/null
+++ b/.jenkins/job_beam_PostCommit_Java_ValidatesRunner_Apex.groovy
@@ -0,0 +1,48 @@
+/*
+ * 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 common_job_properties
+
+// This job runs the suite of ValidatesRunner tests against the Apex runner.
+mavenJob('beam_PostCommit_Java_ValidatesRunner_Apex') {
+  description('Runs the ValidatesRunner suite on the Apex runner.')
+  previousNames('beam_PostCommit_Java_RunnableOnService_Apex')
+
+  // Set common parameters.
+  common_job_properties.setTopLevelMainJobProperties(delegate)
+
+  // Set maven parameters.
+  common_job_properties.setMavenConfig(delegate)
+
+  // Sets that this is a PostCommit job.
+  common_job_properties.setPostCommit(delegate)
+
+  // Allows triggering this build against pull requests.
+  common_job_properties.enablePhraseTriggeringFromPullRequest(
+    delegate,
+    'Apache Apex Runner ValidatesRunner Tests',
+    'Run Apex ValidatesRunner')
+
+  // Maven goals for this job.
+  goals('''clean verify --projects runners/apex \
+      --also-make \
+      --batch-mode \
+      --errors \
+      --activate-profiles validates-runner-tests \
+      --activate-profiles local-validates-runner-tests''')
+}

http://git-wip-us.apache.org/repos/asf/beam/blob/8cff7442/.jenkins/job_beam_PostCommit_Java_ValidatesRunner_Dataflow.groovy
----------------------------------------------------------------------
diff --git a/.jenkins/job_beam_PostCommit_Java_ValidatesRunner_Dataflow.groovy b/.jenkins/job_beam_PostCommit_Java_ValidatesRunner_Dataflow.groovy
new file mode 100644
index 0000000..33235ff
--- /dev/null
+++ b/.jenkins/job_beam_PostCommit_Java_ValidatesRunner_Dataflow.groovy
@@ -0,0 +1,45 @@
+/*
+ * 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 common_job_properties
+
+// This job runs the suite of ValidatesRunner tests against the Dataflow
+// runner.
+mavenJob('beam_PostCommit_Java_ValidatesRunner_Dataflow') {
+  description('Runs the ValidatesRunner suite on the Dataflow runner.')
+  previousNames('beam_PostCommit_Java_RunnableOnService_Dataflow')
+
+
+  // Set common parameters.
+  common_job_properties.setTopLevelMainJobProperties(delegate, 'master', 120)
+
+  // Set maven parameters.
+  common_job_properties.setMavenConfig(delegate)
+
+  // Sets that this is a PostCommit job.
+  common_job_properties.setPostCommit(delegate)
+
+  // Allows triggering this build against pull requests.
+  common_job_properties.enablePhraseTriggeringFromPullRequest(
+    delegate,
+    'Google Cloud Dataflow Runner ValidatesRunner Tests',
+    'Run Dataflow ValidatesRunner')
+
+  // Maven goals for this job.
+  goals('-B -e clean verify -am -pl runners/google-cloud-dataflow-java -DforkCount=0 -DvalidatesRunnerPipelineOptions=\'[ "--runner=org.apache.beam.runners.dataflow.testing.TestDataflowRunner", "--project=apache-beam-testing", "--tempRoot=gs://temp-storage-for-validates-runner-tests/" ]\'')
+}

http://git-wip-us.apache.org/repos/asf/beam/blob/8cff7442/.jenkins/job_beam_PostCommit_Java_ValidatesRunner_Flink.groovy
----------------------------------------------------------------------
diff --git a/.jenkins/job_beam_PostCommit_Java_ValidatesRunner_Flink.groovy b/.jenkins/job_beam_PostCommit_Java_ValidatesRunner_Flink.groovy
new file mode 100644
index 0000000..411106d
--- /dev/null
+++ b/.jenkins/job_beam_PostCommit_Java_ValidatesRunner_Flink.groovy
@@ -0,0 +1,43 @@
+/*
+ * 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 common_job_properties
+
+// This job runs the suite of ValidatesRunner tests against the Flink runner.
+mavenJob('beam_PostCommit_Java_ValidatesRunner_Flink') {
+  description('Runs the ValidatesRunner suite on the Flink runner.')
+  previousNames('beam_PostCommit_Java_RunnableOnService_Flink')
+
+  // Set common parameters.
+  common_job_properties.setTopLevelMainJobProperties(delegate)
+
+  // Set maven parameters.
+  common_job_properties.setMavenConfig(delegate)
+
+  // Sets that this is a PostCommit job.
+  common_job_properties.setPostCommit(delegate)
+
+  // Allows triggering this build against pull requests.
+  common_job_properties.enablePhraseTriggeringFromPullRequest(
+    delegate,
+    'Apache Flink Runner ValidatesRunner Tests',
+    'Run Flink ValidatesRunner')
+
+  // Maven goals for this job.
+  goals('-B -e clean verify -am -pl runners/flink/runner -Plocal-validates-runner-tests -Pvalidates-runner-tests')
+}

http://git-wip-us.apache.org/repos/asf/beam/blob/8cff7442/.jenkins/job_beam_PostCommit_Java_ValidatesRunner_Gearpump.groovy
----------------------------------------------------------------------
diff --git a/.jenkins/job_beam_PostCommit_Java_ValidatesRunner_Gearpump.groovy b/.jenkins/job_beam_PostCommit_Java_ValidatesRunner_Gearpump.groovy
new file mode 100644
index 0000000..1348a19
--- /dev/null
+++ b/.jenkins/job_beam_PostCommit_Java_ValidatesRunner_Gearpump.groovy
@@ -0,0 +1,49 @@
+/*
+ * 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 common_job_properties
+
+// This job runs the suite of ValidatesRunner tests against the Gearpump
+// runner.
+mavenJob('beam_PostCommit_Java_ValidatesRunner_Gearpump') {
+  description('Runs the ValidatesRunner suite on the Gearpump runner.')
+
+  previousNames('beam_PostCommit_Java_RunnableOnService_Gearpump')
+
+  // Set common parameters.
+  common_job_properties.setTopLevelMainJobProperties(
+      delegate,
+      'gearpump-runner')
+
+  // Set maven parameters.
+  common_job_properties.setMavenConfig(delegate)
+
+  // Sets that this is a PostCommit job.
+  // 0 5 31 2 * will run on Feb 31 (i.e. never) according to job properties.
+  // In post-commit this job triggers only on SCM changes.
+  common_job_properties.setPostCommit(delegate, '0 5 31 2 *')
+
+  // Allows triggering this build against pull requests.
+  common_job_properties.enablePhraseTriggeringFromPullRequest(
+    delegate,
+    'Apache Gearpump Runner ValidatesRunner Tests',
+    'Run Gearpump ValidatesRunner')
+
+  // Maven goals for this job.
+  goals('-B -e clean verify -am -pl runners/gearpump -DforkCount=0 -DvalidatesRunnerPipelineOptions=\'[ "--runner=TestGearpumpRunner", "--streaming=false" ]\'')
+}

http://git-wip-us.apache.org/repos/asf/beam/blob/8cff7442/.jenkins/job_beam_PostCommit_Java_ValidatesRunner_Spark.groovy
----------------------------------------------------------------------
diff --git a/.jenkins/job_beam_PostCommit_Java_ValidatesRunner_Spark.groovy b/.jenkins/job_beam_PostCommit_Java_ValidatesRunner_Spark.groovy
new file mode 100644
index 0000000..9fbc219
--- /dev/null
+++ b/.jenkins/job_beam_PostCommit_Java_ValidatesRunner_Spark.groovy
@@ -0,0 +1,44 @@
+/*
+ * 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 common_job_properties
+
+// This job runs the suite of ValidatesRunner tests against the Spark runner.
+mavenJob('beam_PostCommit_Java_ValidatesRunner_Spark') {
+  description('Runs the ValidatesRunner suite on the Spark runner.')
+
+  previousNames('beam_PostCommit_Java_RunnableOnService_Spark')
+
+  // Set common parameters.
+  common_job_properties.setTopLevelMainJobProperties(delegate)
+
+  // Set maven parameters.
+  common_job_properties.setMavenConfig(delegate)
+
+  // Sets that this is a PostCommit job.
+  common_job_properties.setPostCommit(delegate)
+
+  // Allows triggering this build against pull requests.
+  common_job_properties.enablePhraseTriggeringFromPullRequest(
+    delegate,
+    'Apache Spark Runner ValidatesRunner Tests',
+    'Run Spark ValidatesRunner')
+
+  // Maven goals for this job.
+  goals('-B -e clean verify -am -pl runners/spark -Pvalidates-runner-tests -Plocal-validates-runner-tests -Dspark.ui.enabled=false')
+}

http://git-wip-us.apache.org/repos/asf/beam/blob/8cff7442/runners/apex/pom.xml
----------------------------------------------------------------------
diff --git a/runners/apex/pom.xml b/runners/apex/pom.xml
index 3f01698..20253c2 100644
--- a/runners/apex/pom.xml
+++ b/runners/apex/pom.xml
@@ -42,7 +42,7 @@
 
   <profiles>
     <profile>
-      <id>local-runnable-on-service-tests</id>
+      <id>local-validates-runner-tests</id>
       <activation><activeByDefault>false</activeByDefault></activation>
       <properties>
         <skipIntegrationTests>false</skipIntegrationTests>
@@ -200,7 +200,7 @@
         </configuration>
         <executions>
           <execution>
-            <id>runnable-on-service-tests</id>
+            <id>validates-runner-tests</id>
             <phase>integration-test</phase>
             <goals>
               <goal>test</goal>

http://git-wip-us.apache.org/repos/asf/beam/blob/8cff7442/runners/direct-java/pom.xml
----------------------------------------------------------------------
diff --git a/runners/direct-java/pom.xml b/runners/direct-java/pom.xml
index 71dfa5d..03ed791 100644
--- a/runners/direct-java/pom.xml
+++ b/runners/direct-java/pom.xml
@@ -61,7 +61,7 @@
         </configuration>
         <executions>
           <execution>
-            <id>runnable-on-service-tests</id>
+            <id>validates-runner-tests</id>
             <phase>integration-test</phase>
             <goals>
               <goal>test</goal>

http://git-wip-us.apache.org/repos/asf/beam/blob/8cff7442/runners/flink/examples/pom.xml
----------------------------------------------------------------------
diff --git a/runners/flink/examples/pom.xml b/runners/flink/examples/pom.xml
index 661ed43..fa642bd 100644
--- a/runners/flink/examples/pom.xml
+++ b/runners/flink/examples/pom.xml
@@ -41,7 +41,7 @@
 
   <profiles>
     <profile>
-      <id>disable-runnable-on-service-tests</id>
+      <id>disable-validates-runner-tests</id>
       <activation>
         <activeByDefault>true</activeByDefault>
       </activation>
@@ -52,7 +52,7 @@
             <artifactId>maven-surefire-plugin</artifactId>
             <executions>
               <execution>
-                <id>runnable-on-service-tests</id>
+                <id>validates-runner-tests</id>
                 <configuration>
                   <skip>true</skip>
                 </configuration>

http://git-wip-us.apache.org/repos/asf/beam/blob/8cff7442/runners/flink/runner/pom.xml
----------------------------------------------------------------------
diff --git a/runners/flink/runner/pom.xml b/runners/flink/runner/pom.xml
index e013adb..3b35c8e 100644
--- a/runners/flink/runner/pom.xml
+++ b/runners/flink/runner/pom.xml
@@ -34,7 +34,7 @@
 
   <profiles>
     <profile>
-      <id>local-runnable-on-service-tests</id>
+      <id>local-validates-runner-tests</id>
       <activation><activeByDefault>false</activeByDefault></activation>
       <build>
         <plugins>
@@ -43,10 +43,10 @@
             <artifactId>maven-surefire-plugin</artifactId>
             <executions>
 
-              <!-- This configures the inherited runnable-on-service-tests
+              <!-- This configures the inherited validates-runner-tests
                    execution to execute with a local Flink instance. -->
               <execution>
-                <id>runnable-on-service-tests</id>
+                <id>validates-runner-tests</id>
                 <phase>integration-test</phase>
                 <goals>
                   <goal>test</goal>
@@ -77,7 +77,7 @@
 
               <!-- This second execution runs the tests in streaming mode -->
               <execution>
-                <id>streaming-runnable-on-service-tests</id>
+                <id>streaming-validates-runner-tests</id>
                 <phase>integration-test</phase>
                 <goals>
                   <goal>test</goal>

http://git-wip-us.apache.org/repos/asf/beam/blob/8cff7442/runners/google-cloud-dataflow-java/pom.xml
----------------------------------------------------------------------
diff --git a/runners/google-cloud-dataflow-java/pom.xml b/runners/google-cloud-dataflow-java/pom.xml
index 30d631f..d08e92d 100644
--- a/runners/google-cloud-dataflow-java/pom.xml
+++ b/runners/google-cloud-dataflow-java/pom.xml
@@ -76,7 +76,7 @@
         </configuration>
         <executions>
           <execution>
-            <id>runnable-on-service-tests</id>
+            <id>validates-runner-tests</id>
             <configuration>
               <excludedGroups>
                 org.apache.beam.sdk.testing.UsesAttemptedMetrics,

http://git-wip-us.apache.org/repos/asf/beam/blob/8cff7442/runners/pom.xml
----------------------------------------------------------------------
diff --git a/runners/pom.xml b/runners/pom.xml
index 9bf170d..150e987 100644
--- a/runners/pom.xml
+++ b/runners/pom.xml
@@ -56,12 +56,12 @@
     </profile>
 
     <!-- A profile that adds an integration test phase if and only if
-         the runnableOnServicePipelineOptions maven property has been set.
+         the validatesRunnerPipelineOptions maven property has been set.
          It should be set to a valid PipelineOptions JSON string. -->
     <profile>
-      <id>runnable-on-service-tests</id>
+      <id>validates-runner-tests</id>
       <activation>
-        <property><name>runnableOnServicePipelineOptions</name></property>
+        <property><name>validatesRunnerPipelineOptions</name></property>
       </activation>
       <build>
         <pluginManagement>
@@ -71,7 +71,7 @@
               <artifactId>maven-surefire-plugin</artifactId>
               <executions>
                 <execution>
-                  <id>runnable-on-service-tests</id>
+                  <id>validates-runner-tests</id>
                   <phase>integration-test</phase>
                   <goals>
                     <goal>test</goal>
@@ -84,7 +84,7 @@
                       <dependency>org.apache.beam:beam-sdks-java-core</dependency>
                     </dependenciesToScan>
                     <systemPropertyVariables>
-                      <beamTestPipelineOptions>${runnableOnServicePipelineOptions}</beamTestPipelineOptions>
+                      <beamTestPipelineOptions>${validatesRunnerPipelineOptions}</beamTestPipelineOptions>
                     </systemPropertyVariables>
                   </configuration>
                 </execution>

http://git-wip-us.apache.org/repos/asf/beam/blob/8cff7442/runners/spark/pom.xml
----------------------------------------------------------------------
diff --git a/runners/spark/pom.xml b/runners/spark/pom.xml
index a470fb5..96480cd 100644
--- a/runners/spark/pom.xml
+++ b/runners/spark/pom.xml
@@ -57,7 +57,7 @@
     <profile>
       <!-- This profile adds execution of ValidatesRunner integration tests
            against a local Spark endpoint. -->
-      <id>local-runnable-on-service-tests</id>
+      <id>local-validates-runner-tests</id>
       <activation><activeByDefault>false</activeByDefault></activation>
       <build>
         <plugins>
@@ -66,7 +66,7 @@
             <artifactId>maven-surefire-plugin</artifactId>
             <executions>
               <execution>
-                <id>runnable-on-service-tests</id>
+                <id>validates-runner-tests</id>
                 <phase>integration-test</phase>
                 <goals>
                   <goal>test</goal>


[2/2] beam git commit: This closes #2343: Rename RunnableOnService to ValidatesRunner in poms and Jenkins jobs

Posted by ke...@apache.org.
This closes #2343: Rename RunnableOnService to ValidatesRunner in poms and Jenkins jobs


Project: http://git-wip-us.apache.org/repos/asf/beam/repo
Commit: http://git-wip-us.apache.org/repos/asf/beam/commit/0582eb9f
Tree: http://git-wip-us.apache.org/repos/asf/beam/tree/0582eb9f
Diff: http://git-wip-us.apache.org/repos/asf/beam/diff/0582eb9f

Branch: refs/heads/master
Commit: 0582eb9fc31eacdff8b4aa6dfabe570b46fcf7ac
Parents: 118da81 8cff744
Author: Kenneth Knowles <kl...@google.com>
Authored: Tue Mar 28 10:05:46 2017 -0700
Committer: Kenneth Knowles <kl...@google.com>
Committed: Tue Mar 28 10:05:46 2017 -0700

----------------------------------------------------------------------
 ...ostCommit_Java_RunnableOnService_Apex.groovy | 47 -------------------
 ...ommit_Java_RunnableOnService_Dataflow.groovy | 45 ------------------
 ...stCommit_Java_RunnableOnService_Flink.groovy | 44 ------------------
 ...ommit_Java_RunnableOnService_Gearpump.groovy | 49 --------------------
 ...stCommit_Java_RunnableOnService_Spark.groovy | 44 ------------------
 ..._PostCommit_Java_ValidatesRunner_Apex.groovy | 48 +++++++++++++++++++
 ...tCommit_Java_ValidatesRunner_Dataflow.groovy | 45 ++++++++++++++++++
 ...PostCommit_Java_ValidatesRunner_Flink.groovy | 43 +++++++++++++++++
 ...tCommit_Java_ValidatesRunner_Gearpump.groovy | 49 ++++++++++++++++++++
 ...PostCommit_Java_ValidatesRunner_Spark.groovy | 44 ++++++++++++++++++
 runners/apex/pom.xml                            |  4 +-
 runners/direct-java/pom.xml                     |  2 +-
 runners/flink/examples/pom.xml                  |  4 +-
 runners/flink/runner/pom.xml                    |  8 ++--
 runners/google-cloud-dataflow-java/pom.xml      |  2 +-
 runners/pom.xml                                 | 10 ++--
 runners/spark/pom.xml                           |  4 +-
 17 files changed, 246 insertions(+), 246 deletions(-)
----------------------------------------------------------------------