See 
<https://builds.apache.org/job/beam_PostCommit_Python_Verify/2076/display/redirect>

------------------------------------------
[...truncated 470.95 KB...]
test_with_http_error_that_should_not_be_retried 
(apache_beam.utils.retry_test.RetryTest) ... ok
test_with_no_retry_decorator (apache_beam.utils.retry_test.RetryTest) ... ok
test_with_real_clock (apache_beam.utils.retry_test.RetryTest) ... ok
test_basic_test_stream (apache_beam.utils.test_stream_test.TestStreamTest) ... 
ok
test_test_stream_errors (apache_beam.utils.test_stream_test.TestStreamTest) ... 
ok
test_arithmetic (apache_beam.utils.timestamp_test.DurationTest) ... ok
test_of (apache_beam.utils.timestamp_test.DurationTest) ... ok
test_precision (apache_beam.utils.timestamp_test.DurationTest) ... ok
test_sort_order (apache_beam.utils.timestamp_test.DurationTest) ... ok
test_str (apache_beam.utils.timestamp_test.DurationTest) ... ok
test_arithmetic (apache_beam.utils.timestamp_test.TimestampTest) ... ok
test_of (apache_beam.utils.timestamp_test.TimestampTest) ... ok
test_precision (apache_beam.utils.timestamp_test.TimestampTest) ... ok
test_sort_order (apache_beam.utils.timestamp_test.TimestampTest) ... ok
test_str (apache_beam.utils.timestamp_test.TimestampTest) ... ok
test_utc_timestamp (apache_beam.utils.timestamp_test.TimestampTest) ... ok
test_runtime_value_provider_keyword_argument 
(apache_beam.utils.value_provider_test.ValueProviderTests) ... ok
test_runtime_value_provider_positional_argument 
(apache_beam.utils.value_provider_test.ValueProviderTests) ... ok
test_set_runtime_option 
(apache_beam.utils.value_provider_test.ValueProviderTests) ... ok
test_static_value_provider_keyword_argument 
(apache_beam.utils.value_provider_test.ValueProviderTests) ... ok
test_static_value_provider_positional_argument 
(apache_beam.utils.value_provider_test.ValueProviderTests) ... ok
test_static_value_provider_type_cast 
(apache_beam.utils.value_provider_test.ValueProviderTests) ... ok
test_equality (apache_beam.utils.windowed_value_test.WindowedValueTest) ... ok
test_hash (apache_beam.utils.windowed_value_test.WindowedValueTest) ... ok
test_pickle (apache_beam.utils.windowed_value_test.WindowedValueTest) ... ok
test_timestamps (apache_beam.utils.windowed_value_test.WindowedValueTest) ... ok
test_with_value (apache_beam.utils.windowed_value_test.WindowedValueTest) ... ok
test_element (apache_beam.pipeline_test.DoFnTest) ... ok
test_side_input_no_tag (apache_beam.pipeline_test.DoFnTest) ... ok
test_side_input_tagged (apache_beam.pipeline_test.DoFnTest) ... ok
test_timestamp_param (apache_beam.pipeline_test.DoFnTest) ... ok
test_window_param (apache_beam.pipeline_test.DoFnTest) ... ok
test_attribute_setting (apache_beam.pipeline_test.PipelineOptionsTest) ... ok
test_defaults (apache_beam.pipeline_test.PipelineOptionsTest) ... ok
test_dir (apache_beam.pipeline_test.PipelineOptionsTest) ... ok
test_flag_parsing (apache_beam.pipeline_test.PipelineOptionsTest) ... ok
test_keyword_parsing (apache_beam.pipeline_test.PipelineOptionsTest) ... ok
test_view_as (apache_beam.pipeline_test.PipelineOptionsTest) ... ok
test_aggregator_empty_input (apache_beam.pipeline_test.PipelineTest) ... ok
test_apply_custom_transform (apache_beam.pipeline_test.PipelineTest) ... ok
test_create (apache_beam.pipeline_test.PipelineTest) ... ok
test_create_singleton_pcollection (apache_beam.pipeline_test.PipelineTest) ... 
ok
test_flatmap_builtin (apache_beam.pipeline_test.PipelineTest) ... ok
test_memory_usage (apache_beam.pipeline_test.PipelineTest) ... ok
test_metrics_in_source (apache_beam.pipeline_test.PipelineTest) ... ok
test_pipeline_as_context (apache_beam.pipeline_test.PipelineTest) ... 
<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/sdks/python/apache_beam/coders/typecoders.py>:132:
 UserWarning: Using fallback coder for typehint: <type 'type'>.
  warnings.warn('Using fallback coder for typehint: %r.' % typehint)
ok
test_read (apache_beam.pipeline_test.PipelineTest) ... ok
test_reuse_cloned_custom_transform_instance 
(apache_beam.pipeline_test.PipelineTest) ... ok
test_reuse_custom_transform_instance (apache_beam.pipeline_test.PipelineTest) 
... 
<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/sdks/python/apache_beam/pipeline_test.py>:196:
 DeprecationWarning: BaseException.message has been deprecated as of Python 2.6
  cm.exception.message,
ok
test_transform_no_super_init (apache_beam.pipeline_test.PipelineTest) ... ok
test_visit_entire_graph (apache_beam.pipeline_test.PipelineTest) ... ok
test_simple (apache_beam.pipeline_test.RunnerApiTest)
Tests serializing, deserializing, and running a simple pipeline. ... ok
test_pvalue_expected_arguments (apache_beam.pvalue_test.PValueTest) ... ok
test_append_extra_options (apache_beam.test_pipeline_test.TestPipelineTest) ... 
ok
test_append_verifier_in_extra_opt 
(apache_beam.test_pipeline_test.TestPipelineTest) ... ok
test_create_test_pipeline_options 
(apache_beam.test_pipeline_test.TestPipelineTest) ... ok
test_empty_option_args_parsing 
(apache_beam.test_pipeline_test.TestPipelineTest) ... ok
test_get_option (apache_beam.test_pipeline_test.TestPipelineTest) ... ok
test_option_args_parsing (apache_beam.test_pipeline_test.TestPipelineTest) ... 
ok
test_skip_IT (apache_beam.test_pipeline_test.TestPipelineTest) ... SKIP: IT is 
skipped because --test-pipeline-options is not specified
test_file_checksum_matchcer_invalid_sleep_time 
(apache_beam.tests.pipeline_verifiers_test.PipelineVerifiersTest) ... 
<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/sdks/python/apache_beam/tests/pipeline_verifiers_test.py>:129:
 DeprecationWarning: BaseException.message has been deprecated as of Python 2.6
  self.assertEqual(cm.exception.message,
ok
test_file_checksum_matcher_read_failed 
(apache_beam.tests.pipeline_verifiers_test.PipelineVerifiersTest) ... ok
test_file_checksum_matcher_service_error 
(apache_beam.tests.pipeline_verifiers_test.PipelineVerifiersTest) ... ok
test_file_checksum_matcher_sleep_before_verify 
(apache_beam.tests.pipeline_verifiers_test.PipelineVerifiersTest) ... ok
test_file_checksum_matcher_success 
(apache_beam.tests.pipeline_verifiers_test.PipelineVerifiersTest) ... ok
test_pipeline_state_matcher_fails 
(apache_beam.tests.pipeline_verifiers_test.PipelineVerifiersTest)
Test PipelineStateMatcher fails when using default expected state ... ok
test_pipeline_state_matcher_given_state 
(apache_beam.tests.pipeline_verifiers_test.PipelineVerifiersTest)
Test PipelineStateMatcher successes when matches given state ... ok
test_pipeline_state_matcher_success 
(apache_beam.tests.pipeline_verifiers_test.PipelineVerifiersTest)
Test PipelineStateMatcher successes when using default expected state ... ok

======================================================================
ERROR: test_pardo_side_and_main_outputs 
(apache_beam.runners.portability.maptask_executor_runner_test.MapTaskExecutorRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File 
"<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/sdks/python/apache_beam/runners/portability/maptask_executor_runner_test.py";,>
 line 129, in test_pardo_side_and_main_outputs
    assert_that(unnamed.odd, equal_to([1, 3]), label='unnamed.odd')
  File 
"<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/sdks/python/apache_beam/pipeline.py";,>
 line 173, in __exit__
    self.run().wait_until_finish()
  File 
"<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/sdks/python/apache_beam/pipeline.py";,>
 line 157, in run
    self.to_runner_api(), self.runner, self.options).run(False)
  File 
"<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/sdks/python/apache_beam/pipeline.py";,>
 line 166, in run
    return self.runner.run(self)
  File 
"<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/sdks/python/apache_beam/runners/portability/maptask_executor_runner.py";,>
 line 105, in run
    self.execute_map_tasks(ordered_map_tasks)
  File 
"<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/sdks/python/apache_beam/runners/portability/maptask_executor_runner.py";,>
 line 137, in execute_map_tasks
    map_executor.execute()
  File "apache_beam/runners/worker/operations.py", line 647, in 
apache_beam.runners.worker.operations.SimpleMapTaskExecutor.execute 
(apache_beam/runners/worker/operations.c:19301)
    with op.scoped_metrics_container:
  File "apache_beam/runners/worker/operations.py", line 648, in 
apache_beam.runners.worker.operations.SimpleMapTaskExecutor.execute 
(apache_beam/runners/worker/operations.c:19249)
    op.start()
  File "apache_beam/runners/worker/operations.py", line 202, in 
apache_beam.runners.worker.operations.ReadOperation.start 
(apache_beam/runners/worker/operations.c:7886)
    def start(self):
  File "apache_beam/runners/worker/operations.py", line 203, in 
apache_beam.runners.worker.operations.ReadOperation.start 
(apache_beam/runners/worker/operations.c:7790)
    with self.scoped_start_state:
  File "apache_beam/runners/worker/operations.py", line 212, in 
apache_beam.runners.worker.operations.ReadOperation.start 
(apache_beam/runners/worker/operations.c:7733)
    self.output(windowed_value)
  File "apache_beam/runners/worker/operations.py", line 153, in 
apache_beam.runners.worker.operations.Operation.output 
(apache_beam/runners/worker/operations.c:5770)
    cython.cast(Receiver, self.receivers[output_index]).receive(windowed_value)
  File "apache_beam/runners/worker/operations.py", line 86, in 
apache_beam.runners.worker.operations.ConsumerSet.receive 
(apache_beam/runners/worker/operations.c:3622)
    cython.cast(Operation, consumer).process(windowed_value)
  File "apache_beam/runners/worker/operations.py", line 338, in 
apache_beam.runners.worker.operations.DoOperation.process 
(apache_beam/runners/worker/operations.c:11076)
    with self.scoped_process_state:
  File "apache_beam/runners/worker/operations.py", line 339, in 
apache_beam.runners.worker.operations.DoOperation.process 
(apache_beam/runners/worker/operations.c:11030)
    self.dofn_receiver.receive(o)
  File "apache_beam/runners/common.py", line 372, in 
apache_beam.runners.common.DoFnRunner.receive 
(apache_beam/runners/common.c:9972)
    self.process(windowed_value)
  File "apache_beam/runners/common.py", line 380, in 
apache_beam.runners.common.DoFnRunner.process 
(apache_beam/runners/common.c:10274)
    self._reraise_augmented(exn)
  File "apache_beam/runners/common.py", line 410, in 
apache_beam.runners.common.DoFnRunner._reraise_augmented 
(apache_beam/runners/common.c:11277)
    raise type(exn), args, sys.exc_info()[2]
  File "apache_beam/runners/common.py", line 378, in 
apache_beam.runners.common.DoFnRunner.process 
(apache_beam/runners/common.c:10187)
    self.do_fn_invoker.invoke_process(windowed_value)
  File "apache_beam/runners/common.py", line 181, in 
apache_beam.runners.common.SimpleInvoker.invoke_process 
(apache_beam/runners/common.c:6086)
    self.output_processor.process_outputs(
  File "apache_beam/runners/common.py", line 439, in 
apache_beam.runners.common.OutputProcessor.process_outputs 
(apache_beam/runners/common.c:11638)
    for result in results:
  File 
"<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/sdks/python/apache_beam/runners/portability/maptask_executor_runner_test.py";,>
 line 116, in even_odd
    yield beam.pvalue.OutputValue('odd' if elem % 2 else 'even', elem)
AttributeError: 'module' object has no attribute 'OutputValue' [while running 
'named/FlatMap(even_odd)']
-------------------- >> begin captured logging << --------------------
root: INFO: Running [(u'Create/Read', 
WorkerRead(source=SourceBundle(weight=1.0, 
source=<apache_beam.transforms.core._CreateSource object at 0x7f80daf11650>, 
start_position=None, stop_position=None))), (u'named/FlatMap(even_odd)', 
WorkerDoFn(output_tags=['out', 'out_even', 'out_odd'], input=(0, 0))), 
(u'named.all/WindowInto(WindowIntoFn)', WorkerDoFn(output_tags=['out'], 
input=(1, 0))), (u'named.all/ToVoidKey', WorkerDoFn(output_tags=['out'], 
input=(2, 0))), (u'named.all/Group/pair_with_1', 
WorkerDoFn(output_tags=['out'], input=(3, 0))), 
(u'named.all/Group/Flatten/Write', 
WorkerInMemoryWrite(output_buffer=GroupingOutput[0], 
write_windowed_values=True, input=(4, 0))), 
(u'named.even/WindowInto(WindowIntoFn)', WorkerDoFn(output_tags=['out'], 
input=(1, 1))), (u'named.even/ToVoidKey', WorkerDoFn(output_tags=['out'], 
input=(6, 0))), (u'named.even/Group/pair_with_1', 
WorkerDoFn(output_tags=['out'], input=(7, 0))), 
(u'named.even/Group/Flatten/Write', 
WorkerInMemoryWrite(output_buffer=GroupingOutput[0], 
write_windowed_values=True, input=(8, 0))), 
(u'named.odd/WindowInto(WindowIntoFn)', WorkerDoFn(output_tags=['out'], 
input=(1, 2))), (u'named.odd/ToVoidKey', WorkerDoFn(output_tags=['out'], 
input=(10, 0))), (u'named.odd/Group/pair_with_1', 
WorkerDoFn(output_tags=['out'], input=(11, 0))), 
(u'named.odd/Group/Flatten/Write', 
WorkerInMemoryWrite(output_buffer=GroupingOutput[0], 
write_windowed_values=True, input=(12, 0))), (u'unnamed/FlatMap(even_odd)', 
WorkerDoFn(output_tags=['out', 'out_even', 'out_odd'], input=(0, 0))), 
(u'Map(id)', WorkerDoFn(output_tags=['out'], input=(14, 0))), 
(u'unnamed.all/WindowInto(WindowIntoFn)', WorkerDoFn(output_tags=['out'], 
input=(14, 0))), (u'unnamed.all/ToVoidKey', WorkerDoFn(output_tags=['out'], 
input=(16, 0))), (u'unnamed.all/Group/pair_with_1', 
WorkerDoFn(output_tags=['out'], input=(17, 0))), 
(u'unnamed.all/Group/Flatten/Write', 
WorkerInMemoryWrite(output_buffer=GroupingOutput[0], 
write_windowed_values=True, input=(18, 0))), 
(u'unnamed.even/WindowInto(WindowIntoFn)', WorkerDoFn(output_tags=['out'], 
input=(14, 1))), (u'unnamed.even/ToVoidKey', WorkerDoFn(output_tags=['out'], 
input=(20, 0))), (u'unnamed.even/Group/pair_with_1', 
WorkerDoFn(output_tags=['out'], input=(21, 0))), 
(u'unnamed.even/Group/Flatten/Write', 
WorkerInMemoryWrite(output_buffer=GroupingOutput[0], 
write_windowed_values=True, input=(22, 0))), 
(u'unnamed.odd/WindowInto(WindowIntoFn)', WorkerDoFn(output_tags=['out'], 
input=(14, 2))), (u'unnamed.odd/ToVoidKey', WorkerDoFn(output_tags=['out'], 
input=(24, 0))), (u'unnamed.odd/Group/pair_with_1', 
WorkerDoFn(output_tags=['out'], input=(25, 0))), 
(u'unnamed.odd/Group/Flatten/Write', 
WorkerInMemoryWrite(output_buffer=GroupingOutput[0], 
write_windowed_values=True, input=(26, 0)))]
root: DEBUG: Starting op 27 <InMemoryWriteOperation 
unnamed.odd/Group/Flatten/Write output_buffer=GroupingOutput[0], 
write_windowed_values=True, input=(26, 0)>
root: DEBUG: Starting op 26 <DoOperation unnamed.odd/Group/pair_with_1 
output_tags=['out'], input=(25, 0)>
root: DEBUG: Starting op 25 <DoOperation unnamed.odd/ToVoidKey 
output_tags=['out'], input=(24, 0)>
root: DEBUG: Starting op 24 <DoOperation unnamed.odd/WindowInto(WindowIntoFn) 
output_tags=['out'], input=(14, 2)>
root: DEBUG: Starting op 23 <InMemoryWriteOperation 
unnamed.even/Group/Flatten/Write output_buffer=GroupingOutput[0], 
write_windowed_values=True, input=(22, 0)>
root: DEBUG: Starting op 22 <DoOperation unnamed.even/Group/pair_with_1 
output_tags=['out'], input=(21, 0)>
root: DEBUG: Starting op 21 <DoOperation unnamed.even/ToVoidKey 
output_tags=['out'], input=(20, 0)>
root: DEBUG: Starting op 20 <DoOperation unnamed.even/WindowInto(WindowIntoFn) 
output_tags=['out'], input=(14, 1)>
root: DEBUG: Starting op 19 <InMemoryWriteOperation 
unnamed.all/Group/Flatten/Write output_buffer=GroupingOutput[0], 
write_windowed_values=True, input=(18, 0)>
root: DEBUG: Starting op 18 <DoOperation unnamed.all/Group/pair_with_1 
output_tags=['out'], input=(17, 0)>
root: DEBUG: Starting op 17 <DoOperation unnamed.all/ToVoidKey 
output_tags=['out'], input=(16, 0)>
root: DEBUG: Starting op 16 <DoOperation unnamed.all/WindowInto(WindowIntoFn) 
output_tags=['out'], input=(14, 0)>
root: DEBUG: Starting op 15 <DoOperation Map(id) output_tags=['out'], 
input=(14, 0)>
root: DEBUG: Starting op 14 <DoOperation unnamed/FlatMap(even_odd) 
output_tags=['out', 'out_even', 'out_odd'], input=(0, 0)>
root: DEBUG: Starting op 13 <InMemoryWriteOperation 
named.odd/Group/Flatten/Write output_buffer=GroupingOutput[0], 
write_windowed_values=True, input=(12, 0)>
root: DEBUG: Starting op 12 <DoOperation named.odd/Group/pair_with_1 
output_tags=['out'], input=(11, 0)>
root: DEBUG: Starting op 11 <DoOperation named.odd/ToVoidKey 
output_tags=['out'], input=(10, 0)>
root: DEBUG: Starting op 10 <DoOperation named.odd/WindowInto(WindowIntoFn) 
output_tags=['out'], input=(1, 2)>
root: DEBUG: Starting op 9 <InMemoryWriteOperation 
named.even/Group/Flatten/Write output_buffer=GroupingOutput[0], 
write_windowed_values=True, input=(8, 0)>
root: DEBUG: Starting op 8 <DoOperation named.even/Group/pair_with_1 
output_tags=['out'], input=(7, 0)>
root: DEBUG: Starting op 7 <DoOperation named.even/ToVoidKey 
output_tags=['out'], input=(6, 0)>
root: DEBUG: Starting op 6 <DoOperation named.even/WindowInto(WindowIntoFn) 
output_tags=['out'], input=(1, 1)>
root: DEBUG: Starting op 5 <InMemoryWriteOperation 
named.all/Group/Flatten/Write output_buffer=GroupingOutput[0], 
write_windowed_values=True, input=(4, 0)>
root: DEBUG: Starting op 4 <DoOperation named.all/Group/pair_with_1 
output_tags=['out'], input=(3, 0)>
root: DEBUG: Starting op 3 <DoOperation named.all/ToVoidKey 
output_tags=['out'], input=(2, 0)>
root: DEBUG: Starting op 2 <DoOperation named.all/WindowInto(WindowIntoFn) 
output_tags=['out'], input=(1, 0)>
root: DEBUG: Starting op 1 <DoOperation named/FlatMap(even_odd) 
output_tags=['out', 'out_even', 'out_odd'], input=(0, 0)>
root: DEBUG: Starting op 0 <ReadOperation Create/Read 
source=SourceBundle(weight=1.0, 
source=<apache_beam.transforms.core._CreateSource object at 0x7f80daf11650>, 
start_position=None, stop_position=None)>
root: DEBUG: Processing [((None, (1, 1)), MIN_TIMESTAMP, [GlobalWindow])] in 
<InMemoryWriteOperation named.all/Group/Flatten/Write 
output_buffer=GroupingOutput[0], write_windowed_values=True, input=(4, 0), 
receivers=[ConsumerSet[named.all/Group/Flatten/Write.out0, 
coder=WindowedValueCoder[TupleCoder[FastPrimitivesCoder, 
TupleCoder[FastPrimitivesCoder, FastPrimitivesCoder]]], len(consumers)=0]]>
--------------------- >> end captured logging << ---------------------

======================================================================
ERROR: test_pardo_side_outputs 
(apache_beam.runners.portability.maptask_executor_runner_test.MapTaskExecutorRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File 
"<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/sdks/python/apache_beam/runners/portability/maptask_executor_runner_test.py";,>
 line 111, in test_pardo_side_outputs
    assert_that(xy.y, equal_to(['y', 'xy']), label='y')
  File 
"<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/sdks/python/apache_beam/pipeline.py";,>
 line 173, in __exit__
    self.run().wait_until_finish()
  File 
"<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/sdks/python/apache_beam/pipeline.py";,>
 line 157, in run
    self.to_runner_api(), self.runner, self.options).run(False)
  File 
"<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/sdks/python/apache_beam/pipeline.py";,>
 line 166, in run
    return self.runner.run(self)
  File 
"<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/sdks/python/apache_beam/runners/portability/maptask_executor_runner.py";,>
 line 105, in run
    self.execute_map_tasks(ordered_map_tasks)
  File 
"<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/sdks/python/apache_beam/runners/portability/maptask_executor_runner.py";,>
 line 137, in execute_map_tasks
    map_executor.execute()
  File "apache_beam/runners/worker/operations.py", line 647, in 
apache_beam.runners.worker.operations.SimpleMapTaskExecutor.execute 
(apache_beam/runners/worker/operations.c:19301)
    with op.scoped_metrics_container:
  File "apache_beam/runners/worker/operations.py", line 648, in 
apache_beam.runners.worker.operations.SimpleMapTaskExecutor.execute 
(apache_beam/runners/worker/operations.c:19249)
    op.start()
  File "apache_beam/runners/worker/operations.py", line 202, in 
apache_beam.runners.worker.operations.ReadOperation.start 
(apache_beam/runners/worker/operations.c:7886)
    def start(self):
  File "apache_beam/runners/worker/operations.py", line 203, in 
apache_beam.runners.worker.operations.ReadOperation.start 
(apache_beam/runners/worker/operations.c:7790)
    with self.scoped_start_state:
  File "apache_beam/runners/worker/operations.py", line 212, in 
apache_beam.runners.worker.operations.ReadOperation.start 
(apache_beam/runners/worker/operations.c:7733)
    self.output(windowed_value)
  File "apache_beam/runners/worker/operations.py", line 153, in 
apache_beam.runners.worker.operations.Operation.output 
(apache_beam/runners/worker/operations.c:5770)
    cython.cast(Receiver, self.receivers[output_index]).receive(windowed_value)
  File "apache_beam/runners/worker/operations.py", line 86, in 
apache_beam.runners.worker.operations.ConsumerSet.receive 
(apache_beam/runners/worker/operations.c:3622)
    cython.cast(Operation, consumer).process(windowed_value)
  File "apache_beam/runners/worker/operations.py", line 338, in 
apache_beam.runners.worker.operations.DoOperation.process 
(apache_beam/runners/worker/operations.c:11076)
    with self.scoped_process_state:
  File "apache_beam/runners/worker/operations.py", line 339, in 
apache_beam.runners.worker.operations.DoOperation.process 
(apache_beam/runners/worker/operations.c:11030)
    self.dofn_receiver.receive(o)
  File "apache_beam/runners/common.py", line 372, in 
apache_beam.runners.common.DoFnRunner.receive 
(apache_beam/runners/common.c:9972)
    self.process(windowed_value)
  File "apache_beam/runners/common.py", line 380, in 
apache_beam.runners.common.DoFnRunner.process 
(apache_beam/runners/common.c:10274)
    self._reraise_augmented(exn)
  File "apache_beam/runners/common.py", line 410, in 
apache_beam.runners.common.DoFnRunner._reraise_augmented 
(apache_beam/runners/common.c:11277)
    raise type(exn), args, sys.exc_info()[2]
  File "apache_beam/runners/common.py", line 378, in 
apache_beam.runners.common.DoFnRunner.process 
(apache_beam/runners/common.c:10187)
    self.do_fn_invoker.invoke_process(windowed_value)
  File "apache_beam/runners/common.py", line 273, in 
apache_beam.runners.common.PerWindowInvoker.invoke_process 
(apache_beam/runners/common.c:8442)
    self._invoke_per_window(windowed_value)
  File "apache_beam/runners/common.py", line 298, in 
apache_beam.runners.common.PerWindowInvoker._invoke_per_window 
(apache_beam/runners/common.c:9129)
    self.output_processor.process_outputs(
  File "apache_beam/runners/common.py", line 439, in 
apache_beam.runners.common.OutputProcessor.process_outputs 
(apache_beam/runners/common.c:11638)
    for result in results:
  File 
"<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/sdks/python/apache_beam/runners/portability/maptask_executor_runner_test.py";,>
 line 105, in tee
    yield beam.pvalue.OutputValue(tag, elem)
AttributeError: 'module' object has no attribute 'OutputValue' [while running 
'FlatMap(tee)/FlatMap(tee)']
-------------------- >> begin captured logging << --------------------
root: INFO: Running [(u'Create/Read', 
WorkerRead(source=SourceBundle(weight=1.0, 
source=<apache_beam.transforms.core._CreateSource object at 0x7f80d83a51d0>, 
start_position=None, stop_position=None))), (u'FlatMap(tee)/FlatMap(tee)', 
WorkerDoFn(output_tags=['out', 'out_y', 'out_x'], input=(0, 0))), 
(u'x/WindowInto(WindowIntoFn)', WorkerDoFn(output_tags=['out'], input=(1, 2))), 
(u'x/ToVoidKey', WorkerDoFn(output_tags=['out'], input=(2, 0))), 
(u'x/Group/pair_with_1', WorkerDoFn(output_tags=['out'], input=(3, 0))), 
(u'x/Group/Flatten/Write', WorkerInMemoryWrite(output_buffer=GroupingOutput[0], 
write_windowed_values=True, input=(4, 0))), (u'y/WindowInto(WindowIntoFn)', 
WorkerDoFn(output_tags=['out'], input=(1, 1))), (u'y/ToVoidKey', 
WorkerDoFn(output_tags=['out'], input=(6, 0))), (u'y/Group/pair_with_1', 
WorkerDoFn(output_tags=['out'], input=(7, 0))), (u'y/Group/Flatten/Write', 
WorkerInMemoryWrite(output_buffer=GroupingOutput[0], 
write_windowed_values=True, input=(8, 0)))]
root: DEBUG: Starting op 9 <InMemoryWriteOperation y/Group/Flatten/Write 
output_buffer=GroupingOutput[0], write_windowed_values=True, input=(8, 0)>
root: DEBUG: Starting op 8 <DoOperation y/Group/pair_with_1 
output_tags=['out'], input=(7, 0)>
root: DEBUG: Starting op 7 <DoOperation y/ToVoidKey output_tags=['out'], 
input=(6, 0)>
root: DEBUG: Starting op 6 <DoOperation y/WindowInto(WindowIntoFn) 
output_tags=['out'], input=(1, 1)>
root: DEBUG: Starting op 5 <InMemoryWriteOperation x/Group/Flatten/Write 
output_buffer=GroupingOutput[0], write_windowed_values=True, input=(4, 0)>
root: DEBUG: Starting op 4 <DoOperation x/Group/pair_with_1 
output_tags=['out'], input=(3, 0)>
root: DEBUG: Starting op 3 <DoOperation x/ToVoidKey output_tags=['out'], 
input=(2, 0)>
root: DEBUG: Starting op 2 <DoOperation x/WindowInto(WindowIntoFn) 
output_tags=['out'], input=(1, 2)>
root: DEBUG: Starting op 1 <DoOperation FlatMap(tee)/FlatMap(tee) 
output_tags=['out', 'out_y', 'out_x'], input=(0, 0)>
root: DEBUG: Starting op 0 <ReadOperation Create/Read 
source=SourceBundle(weight=1.0, 
source=<apache_beam.transforms.core._CreateSource object at 0x7f80d83a51d0>, 
start_position=None, stop_position=None)>
--------------------- >> end captured logging << ---------------------

======================================================================
FAIL: test_using_slow_impl (apache_beam.coders.slow_coders_test.SlowCoders)
----------------------------------------------------------------------
Traceback (most recent call last):
  File 
"<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/sdks/python/apache_beam/coders/slow_coders_test.py";,>
 line 41, in test_using_slow_impl
    import apache_beam.coders.stream
AssertionError: ImportError not raised

----------------------------------------------------------------------
Ran 1198 tests in 118.156s

FAILED (failures=1, errors=2, skipped=15)
Test failed: <unittest.runner.TextTestResult run=1198 errors=2 failures=1>
error: Test failed: <unittest.runner.TextTestResult run=1198 errors=2 
failures=1>
ERROR: InvocationError: 
'<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/sdks/python/target/.tox/py27gcp/bin/python>
 setup.py test'
___________________________________ summary ____________________________________
  docs: commands succeeded
  lint: commands succeeded
ERROR:   py27: commands failed
ERROR:   py27cython: commands failed
ERROR:   py27gcp: commands failed
Build step 'Execute shell' marked build as failure
Not sending mail to unregistered user kirpic...@google.com

Reply via email to