You are viewing a plain text version of this content. The canonical link for it is here.
Posted to builds@beam.apache.org by Apache Jenkins Server <je...@builds.apache.org> on 2019/01/06 12:31:59 UTC

Build failed in Jenkins: beam_PreCommit_Python_Cron #794

See <https://builds.apache.org/job/beam_PreCommit_Python_Cron/794/display/redirect?page=changes>

Changes:

[tweise] [BEAM-6009] Modify Github template and README to include Flink PVR for

------------------------------------------
[...truncated 1.58 MB...]
      value {
        unique_name: "11Create/Read.None"
        coder_id: "ref_Coder_VarIntCoder_1_windowed"
        is_bounded: BOUNDED
        windowing_strategy_id: "ref_Windowing_Windowing_1"
      }
    }
    pcollections {
      key: "ref_PCollection_PCollection_2"
      value {
        unique_name: "10Map(first).None"
        coder_id: "ref_Coder_FastPrimitivesCoder_3_windowed"
        is_bounded: BOUNDED
        windowing_strategy_id: "ref_Windowing_Windowing_1"
      }
    }
    windowing_strategies {
      key: "ref_Windowing_Windowing_1"
      value {
        window_fn {
          spec {
            urn: "beam:windowfn:global_windows:v0.1"
          }
          environment_id: "ref_Environment_default_environment_1"
        }
        merge_status: NON_MERGING
        window_coder_id: "ref_Coder_GlobalWindowCoder_2"
        trigger {
          default {
          }
        }
        accumulation_mode: DISCARDING
        output_time: END_OF_WINDOW
        closing_behavior: EMIT_ALWAYS
        OnTimeBehavior: FIRE_ALWAYS
      }
    }
    coders {
      key: "bytes_coder"
      value {
        spec {
          spec {
            urn: "beam:coder:bytes:v1"
          }
        }
      }
    }
    coders {
      key: "bytes_coder_windowed"
      value {
        spec {
          spec {
            urn: "beam:coder:windowed_value:v1"
          }
        }
        component_coder_ids: "bytes_coder"
        component_coder_ids: "ref_Coder_GlobalWindowCoder_2"
      }
    }
    coders {
      key: "ref_Coder_FastPrimitivesCoder_3"
      value {
        spec {
          spec {
            urn: "beam:coder:pickled_python:v1"
            payload: "\n\230\001FastPrimitivesCoder$eNprYE5OLEhMzkiNT0pNzNVLzk9JLSqGUlxuicUlAUWZuZklmWWpxc4gQa5CBs3GQsbaQqYIfgYGhvi0xJycpMTk7HiwlkJ8pgVkJmfnpEJNYQGawlpbyJZUnKQHACYlLgM="
          }
          environment_id: "ref_Environment_default_environment_1"
        }
      }
    }
    coders {
      key: "ref_Coder_FastPrimitivesCoder_3_windowed"
      value {
        spec {
          spec {
            urn: "beam:coder:windowed_value:v1"
          }
        }
        component_coder_ids: "ref_Coder_FastPrimitivesCoder_3"
        component_coder_ids: "ref_Coder_GlobalWindowCoder_2"
      }
    }
    coders {
      key: "ref_Coder_GlobalWindowCoder_2"
      value {
        spec {
          spec {
            urn: "beam:coder:global_window:v1"
          }
          environment_id: "ref_Environment_default_environment_1"
        }
      }
    }
    coders {
      key: "ref_Coder_VarIntCoder_1"
      value {
        spec {
          spec {
            urn: "beam:coder:varint:v1"
          }
          environment_id: "ref_Environment_default_environment_1"
        }
      }
    }
    coders {
      key: "ref_Coder_VarIntCoder_1_windowed"
      value {
        spec {
          spec {
            urn: "beam:coder:windowed_value:v1"
          }
        }
        component_coder_ids: "ref_Coder_VarIntCoder_1"
        component_coder_ids: "ref_Coder_GlobalWindowCoder_2"
      }
    }
    environments {
      key: "ref_Environment_default_environment_1"
      value {
        urn: "beam:env:embedded_python:v1"
      }
    }
  }
}

root: DEBUG: CONTROL RESPONSE instruction_id: "control_1"
register {
}

root: DEBUG: CONTROL REQUEST instruction_id: "bundle_508"
process_bundle {
  process_bundle_descriptor_reference: "0"
}

root: DEBUG: start <DoOperation Map(first) output_tags=['out'], receivers=[ConsumerSet[Map(first).out0, coder=WindowedValueCoder[FastPrimitivesCoder], len(consumers)=0]]>
root: DEBUG: start <ImpulseReadOperation receivers=[ConsumerSet[Create/Read.out0, coder=WindowedValueCoder[VarIntCoder], len(consumers)=1]]>
root: DEBUG: start <DataInputOperation receivers=[ConsumerSet[Create/Read/Impulse.out0, coder=WindowedValueCoder[BytesCoder], len(consumers)=1]]>
root: ERROR: Error running pipeline.
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/apache_beam/runners/common.py",> line 684, in process
    self.do_fn_invoker.invoke_process(windowed_value)
  File "<https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/apache_beam/runners/common.py",> line 421, in invoke_process
    windowed_value, self.process_method(windowed_value.value))
  File "<https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/apache_beam/transforms/core.py",> line 1085, in <lambda>
    wrapper = lambda x: [fn(x)]
  File "<https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/apache_beam/runners/portability/fn_api_runner_test.py",> line 456, in first
    return second(x)
  File "<https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/apache_beam/runners/portability/fn_api_runner_test.py",> line 459, in second
    return third(x)
  File "<https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/apache_beam/runners/portability/fn_api_runner_test.py",> line 462, in third
    raise ValueError('x')
ValueError: x

During handling of the above exception, another exception occurred:

Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/apache_beam/runners/portability/local_job_service.py",> line 223, in run
    fn_api_runner.FnApiRunner().run_via_runner_api(self._pipeline_proto)
  File "<https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/apache_beam/runners/portability/fn_api_runner.py",> line 268, in run_via_runner_api
    return self.run_stages(*self.create_stages(pipeline_proto))
  File "<https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/apache_beam/runners/portability/fn_api_runner.py",> line 355, in run_stages
    safe_coders)
  File "<https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/apache_beam/runners/portability/fn_api_runner.py",> line 501, in run_stage
    self._progress_frequency).process_bundle(data_input, data_output)
  File "<https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/apache_beam/runners/portability/fn_api_runner.py",> line 952, in process_bundle
    result_future = self._controller.control_handler.push(process_bundle)
  File "<https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/apache_beam/runners/portability/fn_api_runner.py",> line 744, in push
    response = self.worker.do_instruction(request)
  File "<https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/apache_beam/runners/worker/sdk_worker.py",> line 256, in do_instruction
    request.instruction_id)
  File "<https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/apache_beam/runners/worker/sdk_worker.py",> line 272, in process_bundle
    bundle_processor.process_bundle(instruction_id)
  File "<https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/apache_beam/runners/worker/bundle_processor.py",> line 489, in process_bundle
    ].process_encoded(data.data)
  File "<https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/apache_beam/runners/worker/bundle_processor.py",> line 126, in process_encoded
    self.output(decoded_value)
  File "<https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/apache_beam/runners/worker/operations.py",> line 183, in output
    cython.cast(Receiver, self.receivers[output_index]).receive(windowed_value)
  File "<https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/apache_beam/runners/worker/operations.py",> line 89, in receive
    cython.cast(Operation, consumer).process(windowed_value)
  File "<https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/apache_beam/runners/worker/operations.py",> line 340, in process
    self.output(windowed_value)
  File "<https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/apache_beam/runners/worker/operations.py",> line 183, in output
    cython.cast(Receiver, self.receivers[output_index]).receive(windowed_value)
  File "<https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/apache_beam/runners/worker/operations.py",> line 89, in receive
    cython.cast(Operation, consumer).process(windowed_value)
  File "<https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/apache_beam/runners/worker/operations.py",> line 498, in process
    self.dofn_receiver.receive(o)
  File "<https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/apache_beam/runners/common.py",> line 680, in receive
    self.process(windowed_value)
  File "<https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/apache_beam/runners/common.py",> line 686, in process
    self._reraise_augmented(exn)
  File "<https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/apache_beam/runners/common.py",> line 724, in _reraise_augmented
    raise_with_traceback(new_exn)
  File "<https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/target/.tox/py3/lib/python3.5/site-packages/future/utils/__init__.py",> line 419, in raise_with_traceback
    raise exc.with_traceback(traceback)
  File "<https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/apache_beam/runners/common.py",> line 684, in process
    self.do_fn_invoker.invoke_process(windowed_value)
  File "<https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/apache_beam/runners/common.py",> line 421, in invoke_process
    windowed_value, self.process_method(windowed_value.value))
  File "<https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/apache_beam/transforms/core.py",> line 1085, in <lambda>
    wrapper = lambda x: [fn(x)]
  File "<https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/apache_beam/runners/portability/fn_api_runner_test.py",> line 456, in first
    return second(x)
  File "<https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/apache_beam/runners/portability/fn_api_runner_test.py",> line 459, in second
    return third(x)
  File "<https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/apache_beam/runners/portability/fn_api_runner_test.py",> line 462, in third
    raise ValueError('x')
ValueError: x [while running 'Map(first)']
root: DEBUG: start <DataInputOperation receivers=[ConsumerSet[Create/Read/Impulse.out0, coder=WindowedValueCoder[BytesCoder], len(consumers)=1]]>
root: INFO: Job state changed to STARTING
root: INFO: Job state changed to FAILED
--------------------- >> end captured logging << ---------------------

----------------------------------------------------------------------
XML: <https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/nosetests.xml>
----------------------------------------------------------------------
Ran 1469 tests in 165.536s

FAILED (SKIP=329, failures=1)
ERROR: InvocationError for command '<https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/target/.tox/py3/bin/python> setup.py nosetests --tests apache_beam.typehints,apache_beam.coders,apache_beam.options,apache_beam.tools,apache_beam.utils,apache_beam.internal,apache_beam.metrics,apache_beam.portability,apache_beam.pipeline_test,apache_beam.pvalue_test,apache_beam.runners,apache_beam.io.hadoopfilesystem_test,apache_beam.io.hdfs_integration_test,apache_beam.io.gcp.tests.utils_test,apache_beam.io.gcp.big_query_query_to_table_it_test,apache_beam.io.gcp.bigquery_io_read_it_test,apache_beam.io.gcp.bigquery_test,apache_beam.io.gcp.gcsfilesystem_test,apache_beam.io.gcp.gcsio_test,apache_beam.io.gcp.pubsub_integration_test,apache_beam.io.hdfs_integration_test,apache_beam.io.gcp.internal,apache_beam.io.filesystem_test,apache_beam.io.filesystems_test,apache_beam.io.range_trackers_test,apache_beam.io.sources_test,apache_beam.transforms,apache_beam.testing,apache_beam.io.filesystemio_test,apache_beam.io.localfilesystem_test,apache_beam.io.range_trackers_test,apache_beam.io.restriction_trackers_test,apache_beam.io.source_test_utils_test,apache_beam.io.concat_source_test,apache_beam.io.filebasedsink_test,apache_beam.io.filebasedsource_test' (exited with code 1)
___________________________________ summary ____________________________________
ERROR:   py3: commands failed

> Task :beam-sdks-python:testPython3 FAILED

FAILURE: Build failed with an exception.

* Where:
Build file '<https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/build.gradle'> line: 60

* What went wrong:
Execution failed for task ':beam-sdks-python:testPython3'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.

* Get more help at https://help.gradle.org

BUILD FAILED in 31m 5s
13 actionable tasks: 13 executed

Publishing build scan...
https://gradle.com/s/qqxaa35u7n5ge

Build step 'Invoke Gradle script' changed build result to FAILURE
Build step 'Invoke Gradle script' marked build as failure

---------------------------------------------------------------------
To unsubscribe, e-mail: builds-unsubscribe@beam.apache.org
For additional commands, e-mail: builds-help@beam.apache.org


Jenkins build is back to normal : beam_PreCommit_Python_Cron #795

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://builds.apache.org/job/beam_PreCommit_Python_Cron/795/display/redirect>


---------------------------------------------------------------------
To unsubscribe, e-mail: builds-unsubscribe@beam.apache.org
For additional commands, e-mail: builds-help@beam.apache.org