You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@beam.apache.org by pa...@apache.org on 2019/12/09 17:16:29 UTC

[beam] branch master updated: [BEAM-7390] Add code snippet for Mean

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

pabloem 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 a88fa86  [BEAM-7390] Add code snippet for Mean
     new 369fe49  Merge pull request #10176 from davidcavazos/mean-code
a88fa86 is described below

commit a88fa86cb093a15d26d9f66567c1771d58c20fda
Author: David Cavazos <dc...@google.com>
AuthorDate: Tue Nov 19 13:17:30 2019 -0800

    [BEAM-7390] Add code snippet for Mean
---
 .../snippets/transforms/aggregation/mean.py        | 59 +++++++++++++++++++++
 .../snippets/transforms/aggregation/mean_test.py   | 60 ++++++++++++++++++++++
 2 files changed, 119 insertions(+)

diff --git a/sdks/python/apache_beam/examples/snippets/transforms/aggregation/mean.py b/sdks/python/apache_beam/examples/snippets/transforms/aggregation/mean.py
new file mode 100644
index 0000000..36fa5b5
--- /dev/null
+++ b/sdks/python/apache_beam/examples/snippets/transforms/aggregation/mean.py
@@ -0,0 +1,59 @@
+# coding=utf-8
+#
+# 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.
+#
+
+from __future__ import absolute_import
+from __future__ import print_function
+
+
+def mean_globally(test=None):
+  # [START mean_globally]
+  import apache_beam as beam
+
+  with beam.Pipeline() as pipeline:
+    mean_element = (
+        pipeline
+        | 'Create numbers' >> beam.Create([3, 4, 1, 2])
+        | 'Get mean value' >> beam.combiners.Mean.Globally()
+        | beam.Map(print)
+    )
+    # [END mean_globally]
+    if test:
+      test(mean_element)
+
+
+def mean_per_key(test=None):
+  # [START mean_per_key]
+  import apache_beam as beam
+
+  with beam.Pipeline() as pipeline:
+    elements_with_mean_value_per_key = (
+        pipeline
+        | 'Create produce' >> beam.Create([
+            ('🥕', 3),
+            ('🥕', 2),
+            ('🍆', 1),
+            ('🍅', 4),
+            ('🍅', 5),
+            ('🍅', 3),
+        ])
+        | 'Get mean value per key' >> beam.combiners.Mean.PerKey()
+        | beam.Map(print)
+    )
+    # [END mean_per_key]
+    if test:
+      test(elements_with_mean_value_per_key)
diff --git a/sdks/python/apache_beam/examples/snippets/transforms/aggregation/mean_test.py b/sdks/python/apache_beam/examples/snippets/transforms/aggregation/mean_test.py
new file mode 100644
index 0000000..38b27a0
--- /dev/null
+++ b/sdks/python/apache_beam/examples/snippets/transforms/aggregation/mean_test.py
@@ -0,0 +1,60 @@
+# coding=utf-8
+#
+# 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.
+#
+
+from __future__ import absolute_import
+from __future__ import print_function
+
+import unittest
+
+import mock
+
+from apache_beam.examples.snippets.util import assert_matches_stdout
+from apache_beam.testing.test_pipeline import TestPipeline
+
+from . import mean
+
+
+def check_mean_element(actual):
+  expected = '''[START mean_element]
+2.5
+[END mean_element]'''.splitlines()[1:-1]
+  assert_matches_stdout(actual, expected)
+
+
+def check_elements_with_mean_value_per_key(actual):
+  expected = '''[START elements_with_mean_value_per_key]
+('🥕', 2.5)
+('🍆', 1.0)
+('🍅', 4.0)
+[END elements_with_mean_value_per_key]'''.splitlines()[1:-1]
+  assert_matches_stdout(actual, expected)
+
+
+@mock.patch('apache_beam.Pipeline', TestPipeline)
+@mock.patch(
+    'apache_beam.examples.snippets.transforms.aggregation.mean.print', str)
+class MeanTest(unittest.TestCase):
+  def test_mean_globally(self):
+    mean.mean_globally(check_mean_element)
+
+  def test_mean_per_key(self):
+    mean.mean_per_key(check_elements_with_mean_value_per_key)
+
+
+if __name__ == '__main__':
+  unittest.main()