You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@beam.apache.org by ro...@apache.org on 2016/12/06 18:10:59 UTC

[1/2] incubator-beam git commit: Move template_runners_test to runners folder.

Repository: incubator-beam
Updated Branches:
  refs/heads/python-sdk e73bdb5c2 -> 6dcc429e5


Move template_runners_test to runners folder.


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

Branch: refs/heads/python-sdk
Commit: 4a02a688dbacd640e40d7b3d3ca268fde9806e73
Parents: e73bdb5
Author: Ahmet Altay <al...@google.com>
Authored: Mon Dec 5 14:57:14 2016 -0800
Committer: Robert Bradshaw <ro...@gmail.com>
Committed: Tue Dec 6 10:10:44 2016 -0800

----------------------------------------------------------------------
 .../apache_beam/runners/template_runner_test.py | 82 +++++++++++++++++++
 sdks/python/apache_beam/template_runner_test.py | 83 --------------------
 2 files changed, 82 insertions(+), 83 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-beam/blob/4a02a688/sdks/python/apache_beam/runners/template_runner_test.py
----------------------------------------------------------------------
diff --git a/sdks/python/apache_beam/runners/template_runner_test.py b/sdks/python/apache_beam/runners/template_runner_test.py
new file mode 100644
index 0000000..a141521
--- /dev/null
+++ b/sdks/python/apache_beam/runners/template_runner_test.py
@@ -0,0 +1,82 @@
+#
+# 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.
+#
+
+"""Unit tests for templated pipelines."""
+
+from __future__ import absolute_import
+
+import json
+import unittest
+import tempfile
+
+import apache_beam as beam
+from apache_beam.pipeline import Pipeline
+from apache_beam.runners.dataflow_runner import DataflowPipelineRunner
+from apache_beam.utils.options import PipelineOptions
+from apache_beam.internal import apiclient
+
+
+class TemplatingDataflowPipelineRunnerTest(unittest.TestCase):
+  """TemplatingDataflow tests."""
+  def test_full_completion(self):
+    dummy_file = tempfile.NamedTemporaryFile()
+    dummy_dir = tempfile.mkdtemp()
+
+    remote_runner = DataflowPipelineRunner()
+    pipeline = Pipeline(remote_runner,
+                        options=PipelineOptions([
+                            '--dataflow_endpoint=ignored',
+                            '--sdk_location=' + dummy_file.name,
+                            '--job_name=test-job',
+                            '--project=test-project',
+                            '--staging_location=' + dummy_dir,
+                            '--temp_location=/dev/null',
+                            '--template_location=' + dummy_file.name,
+                            '--no_auth=True']))
+
+    pipeline | beam.Create([1, 2, 3]) | beam.Map(lambda x: x) # pylint: disable=expression-not-assigned
+    pipeline.run()
+    with open(dummy_file.name) as template_file:
+      saved_job_dict = json.load(template_file)
+      self.assertEqual(
+          saved_job_dict['environment']['sdkPipelineOptions']
+          ['options']['project'], 'test-project')
+      self.assertEqual(
+          saved_job_dict['environment']['sdkPipelineOptions']
+          ['options']['job_name'], 'test-job')
+
+  def test_bad_path(self):
+    dummy_sdk_file = tempfile.NamedTemporaryFile()
+    remote_runner = DataflowPipelineRunner()
+    pipeline = Pipeline(remote_runner,
+                        options=PipelineOptions([
+                            '--dataflow_endpoint=ignored',
+                            '--sdk_location=' + dummy_sdk_file.name,
+                            '--job_name=test-job',
+                            '--project=test-project',
+                            '--staging_location=ignored',
+                            '--temp_location=/dev/null',
+                            '--template_location=/bad/path',
+                            '--no_auth=True']))
+    remote_runner.job = apiclient.Job(pipeline.options)
+
+    with self.assertRaises(IOError):
+      pipeline.run()
+
+
+if __name__ == '__main__':
+  unittest.main()

http://git-wip-us.apache.org/repos/asf/incubator-beam/blob/4a02a688/sdks/python/apache_beam/template_runner_test.py
----------------------------------------------------------------------
diff --git a/sdks/python/apache_beam/template_runner_test.py b/sdks/python/apache_beam/template_runner_test.py
deleted file mode 100644
index bfcd70c..0000000
--- a/sdks/python/apache_beam/template_runner_test.py
+++ /dev/null
@@ -1,83 +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.
-#
-
-"""Unit tests for templated pipelines."""
-
-from __future__ import absolute_import
-
-import json
-import unittest
-import tempfile
-
-import apache_beam as beam
-from apache_beam.pipeline import Pipeline
-from apache_beam.runners.dataflow_runner import DataflowPipelineRunner
-from apache_beam.utils.options import PipelineOptions
-from apache_beam.internal import apiclient
-
-
-class TemplatingDataflowPipelineRunnerTest(unittest.TestCase):
-  """TemplatingDataflow tests."""
-  def test_full_completion(self):
-    dummy_file = tempfile.NamedTemporaryFile()
-    dummy_dir = tempfile.mkdtemp()
-
-    remote_runner = DataflowPipelineRunner()
-    pipeline = Pipeline(remote_runner,
-                        options=PipelineOptions([
-                            '--dataflow_endpoint=ignored',
-                            '--sdk_location=' + dummy_file.name,
-                            '--job_name=test-job',
-                            '--project=test-project',
-                            '--staging_location=' + dummy_dir,
-                            '--temp_location=/dev/null',
-                            '--template_location=' + dummy_file.name,
-                            '--no_auth=True']))
-
-    pipeline | beam.Create([1, 2, 3]) | beam.Map(lambda x: x) # pylint: disable=expression-not-assigned
-    pipeline.run()
-    with open(dummy_file.name) as template_file:
-      saved_job_dict = json.load(template_file)
-      self.assertEqual(
-          saved_job_dict['environment']['sdkPipelineOptions']
-          ['options']['project'], 'test-project')
-      self.assertEqual(
-          saved_job_dict['environment']['sdkPipelineOptions']
-          ['options']['job_name'], 'test-job')
-
-  def test_bad_path(self):
-    dummy_sdk_file = tempfile.NamedTemporaryFile()
-    remote_runner = DataflowPipelineRunner()
-    pipeline = Pipeline(remote_runner,
-                        options=PipelineOptions([
-                            '--dataflow_endpoint=ignored',
-                            '--sdk_location=' + dummy_sdk_file.name,
-                            '--job_name=test-job',
-                            '--project=test-project',
-                            '--staging_location=ignored',
-                            '--temp_location=/dev/null',
-                            '--template_location=/bad/path',
-                            '--no_auth=True']))
-    remote_runner.job = apiclient.Job(pipeline.options)
-
-    with self.assertRaises(IOError):
-      pipeline.run()
-
-
-if __name__ == '__main__':
-  logging.getLogger().setLevel(logging.INFO)
-  unittest.main()


[2/2] incubator-beam git commit: Closes #1512

Posted by ro...@apache.org.
Closes #1512


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

Branch: refs/heads/python-sdk
Commit: 6dcc429e5bf4bb37605773be6de31efa3f887093
Parents: e73bdb5 4a02a68
Author: Robert Bradshaw <ro...@gmail.com>
Authored: Tue Dec 6 10:10:45 2016 -0800
Committer: Robert Bradshaw <ro...@gmail.com>
Committed: Tue Dec 6 10:10:45 2016 -0800

----------------------------------------------------------------------
 .../apache_beam/runners/template_runner_test.py | 82 +++++++++++++++++++
 sdks/python/apache_beam/template_runner_test.py | 83 --------------------
 2 files changed, 82 insertions(+), 83 deletions(-)
----------------------------------------------------------------------