You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@beam.apache.org by al...@apache.org on 2017/08/24 20:59:57 UTC

[1/2] beam git commit: Added tests for python gaming examples

Repository: beam
Updated Branches:
  refs/heads/master 73c2026db -> d261d6bde


Added tests for python gaming examples


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

Branch: refs/heads/master
Commit: 0f53e2adc7509cd8383341c2b2a8c0275b7f0816
Parents: 73c2026
Author: David Cavazos <dc...@google.com>
Authored: Thu Aug 24 11:43:23 2017 -0700
Committer: Ahmet Altay <al...@google.com>
Committed: Thu Aug 24 13:59:16 2017 -0700

----------------------------------------------------------------------
 .../examples/complete/game/game_stats_test.py   | 81 ++++++++++++++++++++
 .../examples/complete/game/leader_board_test.py | 69 +++++++++++++++++
 2 files changed, 150 insertions(+)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/beam/blob/0f53e2ad/sdks/python/apache_beam/examples/complete/game/game_stats_test.py
----------------------------------------------------------------------
diff --git a/sdks/python/apache_beam/examples/complete/game/game_stats_test.py b/sdks/python/apache_beam/examples/complete/game/game_stats_test.py
new file mode 100644
index 0000000..971f9dc
--- /dev/null
+++ b/sdks/python/apache_beam/examples/complete/game/game_stats_test.py
@@ -0,0 +1,81 @@
+#
+# 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.
+#
+
+"""Test for the game_stats example."""
+
+import logging
+import unittest
+
+import apache_beam as beam
+from apache_beam.examples.complete.game import game_stats
+from apache_beam.testing.test_pipeline import TestPipeline
+from apache_beam.testing.util import assert_that
+from apache_beam.testing.util import equal_to
+
+
+class GameStatsTest(unittest.TestCase):
+
+  SAMPLE_DATA = [
+      'user1_team1,team1,18,1447686663000,2015-11-16 15:11:03.921',
+      'user1_team1,team1,18,1447690263000,2015-11-16 16:11:03.921',
+      'user2_team2,team2,2,1447690263000,2015-11-16 16:11:03.955',
+      'user3_team3,team3,8,1447690263000,2015-11-16 16:11:03.955',
+      'user4_team3,team3,5,1447690263000,2015-11-16 16:11:03.959',
+      'user1_team1,team1,14,1447697463000,2015-11-16 18:11:03.955',
+      'robot1_team1,team1,9000,1447697463000,2015-11-16 18:11:03.955',
+      'robot2_team2,team2,1,1447697463000,2015-11-16 20:11:03.955',
+      'robot2_team2,team2,9000,1447697463000,2015-11-16 21:11:03.955',
+  ]
+
+  def create_data(self, p):
+    return (p
+            | beam.Create(GameStatsTest.SAMPLE_DATA)
+            | beam.ParDo(game_stats.ParseGameEventFn())
+            | beam.Map(lambda elem:\
+                       beam.window.TimestampedValue(elem, elem['timestamp'])))
+
+  def test_spammy_users(self):
+    with TestPipeline() as p:
+      result = (
+          self.create_data(p)
+          | beam.Map(lambda elem: (elem['user'], elem['score']))
+          | game_stats.CalculateSpammyUsers())
+      assert_that(result, equal_to([
+          ('robot1_team1', 9000), ('robot2_team2', 9001)]))
+
+  def test_game_stats_sessions(self):
+    session_gap = 5 * 60
+    user_activity_window_duration = 30 * 60
+    with TestPipeline() as p:
+      result = (
+          self.create_data(p)
+          | beam.Map(lambda elem: (elem['user'], elem['score']))
+          | 'WindowIntoSessions' >> beam.WindowInto(
+              beam.window.Sessions(session_gap),
+              timestamp_combiner=beam.window.TimestampCombiner.OUTPUT_AT_EOW)
+          | beam.CombinePerKey(lambda _: None)
+          | beam.ParDo(game_stats.UserSessionActivity())
+          | 'WindowToExtractSessionMean' >> beam.WindowInto(
+              beam.window.FixedWindows(user_activity_window_duration))
+          | beam.CombineGlobally(beam.combiners.MeanCombineFn())\
+              .without_defaults())
+      assert_that(result, equal_to([300.0, 300.0, 300.0]))
+
+
+if __name__ == '__main__':
+  logging.getLogger().setLevel(logging.INFO)
+  unittest.main()

http://git-wip-us.apache.org/repos/asf/beam/blob/0f53e2ad/sdks/python/apache_beam/examples/complete/game/leader_board_test.py
----------------------------------------------------------------------
diff --git a/sdks/python/apache_beam/examples/complete/game/leader_board_test.py b/sdks/python/apache_beam/examples/complete/game/leader_board_test.py
new file mode 100644
index 0000000..aece264
--- /dev/null
+++ b/sdks/python/apache_beam/examples/complete/game/leader_board_test.py
@@ -0,0 +1,69 @@
+#
+# 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.
+#
+
+"""Test for the leader_board example."""
+
+import logging
+import unittest
+
+import apache_beam as beam
+from apache_beam.examples.complete.game import leader_board
+from apache_beam.testing.test_pipeline import TestPipeline
+from apache_beam.testing.util import assert_that
+from apache_beam.testing.util import equal_to
+
+
+class LeaderBoardTest(unittest.TestCase):
+
+  SAMPLE_DATA = [
+      'user1_team1,team1,18,1447686663000,2015-11-16 15:11:03.921',
+      'user1_team1,team1,18,1447690263000,2015-11-16 16:11:03.921',
+      'user2_team2,team2,2,1447690263000,2015-11-16 16:11:03.955',
+      'user3_team3,team3,8,1447690263000,2015-11-16 16:11:03.955',
+      'user4_team3,team3,5,1447690263000,2015-11-16 16:11:03.959',
+      'user1_team1,team1,14,1447697463000,2015-11-16 18:11:03.955',
+  ]
+
+  def create_data(self, p):
+    return (p
+            | beam.Create(LeaderBoardTest.SAMPLE_DATA)
+            | beam.ParDo(leader_board.ParseGameEventFn())
+            | beam.Map(lambda elem:\
+                       beam.window.TimestampedValue(elem, elem['timestamp'])))
+
+  def test_leader_board_teams(self):
+    with TestPipeline() as p:
+      result = (
+          self.create_data(p)
+          | leader_board.CalculateTeamScores(
+              team_window_duration=60,
+              allowed_lateness=120))
+      assert_that(result, equal_to([
+          ('team1', 14), ('team1', 18), ('team1', 18), ('team2', 2),
+          ('team3', 13)]))
+
+  def test_leader_board_users(self):
+    with TestPipeline() as p:
+      result = (
+          self.create_data(p)
+          | leader_board.CalculateUserScores(allowed_lateness=120))
+      assert_that(result, equal_to([]))
+
+
+if __name__ == '__main__':
+  logging.getLogger().setLevel(logging.INFO)
+  unittest.main()


[2/2] beam git commit: This closes #3756

Posted by al...@apache.org.
This closes #3756


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

Branch: refs/heads/master
Commit: d261d6bde1a9fe128c7a5c56936c88caca7ca9eb
Parents: 73c2026 0f53e2a
Author: Ahmet Altay <al...@google.com>
Authored: Thu Aug 24 13:59:48 2017 -0700
Committer: Ahmet Altay <al...@google.com>
Committed: Thu Aug 24 13:59:48 2017 -0700

----------------------------------------------------------------------
 .../examples/complete/game/game_stats_test.py   | 81 ++++++++++++++++++++
 .../examples/complete/game/leader_board_test.py | 69 +++++++++++++++++
 2 files changed, 150 insertions(+)
----------------------------------------------------------------------