See
<https://ci-beam.apache.org/job/beam_PreCommit_Python2_PVR_Flink_Cron/1145/display/redirect?page=changes>
Changes:
[Etienne Chauchot] [BEAM-10471] Change assertion method to improve
expressiveness and
------------------------------------------
[...truncated 2.56 MB...]
ERROR:root:java.lang.RuntimeException: Error received from SDK harness for
instruction 5: Traceback (most recent call last):
File "apache_beam/runners/worker/sdk_worker.py", line 256, in _execute
response = task()
File "apache_beam/runners/worker/sdk_worker.py", line 313, in <lambda>
lambda: self.create_worker().do_instruction(request), request)
File "apache_beam/runners/worker/sdk_worker.py", line 483, in do_instruction
getattr(request, request_type), request.instruction_id)
File "apache_beam/runners/worker/sdk_worker.py", line 518, in process_bundle
bundle_processor.process_bundle(instruction_id))
File "apache_beam/runners/worker/bundle_processor.py", line 978, in
process_bundle
element.data)
File "apache_beam/runners/worker/bundle_processor.py", line 218, in
process_encoded
self.output(decoded_value)
File "apache_beam/runners/worker/operations.py", line 332, in output
cython.cast(Receiver, self.receivers[output_index]).receive(windowed_value)
File "apache_beam/runners/worker/operations.py", line 195, in receive
self.consumer.process(windowed_value)
File "apache_beam/runners/worker/operations.py", line 764, in process
delayed_application = self.dofn_runner.process_with_sized_restriction(o)
File "apache_beam/runners/common.py", line 990, in
process_with_sized_restriction
watermark_estimator_state=estimator_state)
File "apache_beam/runners/common.py", line 721, in invoke_process
windowed_value, additional_args, additional_kwargs)
File "apache_beam/runners/common.py", line 829, in _invoke_process_per_window
self.threadsafe_restriction_tracker.check_done()
File "apache_beam/runners/sdf_utils.py", line 115, in check_done
return self._restriction_tracker.check_done()
File "apache_beam/io/restriction_trackers.py", line 103, in check_done
self._range.stop))
ValueError: OffsetRestrictionTracker is not done since work in range [0, 6) has
not been claimed.
INFO:apache_beam.runners.portability.portable_runner:Job state changed to FAILED
.ssssINFO:apache_beam.runners.worker.worker_pool_main:Listening for workers at
localhost:33473
WARNING:root:Make sure that locally built Python SDK docker image has Python
2.7 interpreter.
INFO:root:Using Python SDK docker image: apache/beam_python2.7_sdk:2.24.0.dev.
If the image is not available at local, we will try to pull from hub.docker.com
INFO:apache_beam.runners.portability.portable_runner:Environment "LOOPBACK" has
started a component necessary for the execution. Be sure to run the pipeline
using
with Pipeline() as p:
p.apply(..)
This ensures that the pipeline finishes before this program exits.
INFO:apache_beam.runners.portability.portable_runner:Job state changed to
STOPPED
INFO:apache_beam.runners.portability.portable_runner:Job state changed to
STARTING
INFO:apache_beam.runners.portability.portable_runner:Job state changed to
RUNNING
[flink-runner-job-invoker] WARN
org.apache.flink.runtime.webmonitor.WebMonitorUtils - Log file environment
variable 'log.file' is not set.
[flink-runner-job-invoker] WARN
org.apache.flink.runtime.webmonitor.WebMonitorUtils - JobManager log files are
unavailable in the web dashboard. Log file location not found in environment
variable 'log.file' or configuration key 'Key: 'web.log.path' , default: null
(fallback keys: [{key=jobmanager.web.log.path, isDeprecated=true}])'.
INFO:apache_beam.runners.worker.statecache:Creating state cache with size 0
INFO:apache_beam.runners.worker.sdk_worker:Creating insecure control channel
for localhost:40483.
[[5]{Create, Map(<lambda at fn_runner_test.py:490>), WindowInto(WindowIntoFn),
Map(<lambda at fn_runner_test.py:493>)} (2/2)] WARN
org.apache.flink.metrics.MetricGroup - The operator name [5]{Create,
Map(<lambda at fn_runner_test.py:490>), WindowInto(WindowIntoFn), Map(<lambda
at fn_runner_test.py:493>)} exceeded the 80 characters length limit and was
truncated.
INFO:apache_beam.runners.worker.sdk_worker:Control channel established.
[[5]{Create, Map(<lambda at fn_runner_test.py:490>), WindowInto(WindowIntoFn),
Map(<lambda at fn_runner_test.py:493>)} (1/2)] WARN
org.apache.flink.metrics.MetricGroup - The operator name [5]{Create,
Map(<lambda at fn_runner_test.py:490>), WindowInto(WindowIntoFn), Map(<lambda
at fn_runner_test.py:493>)} exceeded the 80 characters length limit and was
truncated.
INFO:apache_beam.runners.worker.sdk_worker:Initializing SDKHarness with
unbounded number of workers.
INFO:apache_beam.runners.worker.sdk_worker:Creating insecure state channel for
localhost:46377.
INFO:apache_beam.runners.worker.sdk_worker:State channel established.
INFO:apache_beam.runners.worker.data_plane:Creating client data channel for
localhost:44459
INFO:apache_beam.runners.worker.sdk_worker:No more requests from control plane
INFO:apache_beam.runners.worker.sdk_worker:SDK Harness waiting for in-flight
requests to complete
INFO:apache_beam.runners.worker.data_plane:Closing all cached grpc data
channels.
INFO:apache_beam.runners.worker.sdk_worker:Closing all cached gRPC state
handlers.
[grpc-default-executor-2] WARN
org.apache.beam.sdk.fn.data.BeamFnDataGrpcMultiplexer - Hanged up for unknown
endpoint.
[assert_that/Group/GroupByKey -> [3]assert_that/{Group, Unkey, Match} (1/2)]
WARN org.apache.beam.sdk.fn.data.BeamFnDataGrpcMultiplexer - Hanged up for
unknown endpoint.
INFO:apache_beam.runners.worker.sdk_worker:Done consuming work.
INFO:apache_beam.runners.portability.portable_runner:Job state changed to DONE
.INFO:apache_beam.runners.worker.worker_pool_main:Listening for workers at
localhost:43545
WARNING:root:Make sure that locally built Python SDK docker image has Python
2.7 interpreter.
INFO:root:Using Python SDK docker image: apache/beam_python2.7_sdk:2.24.0.dev.
If the image is not available at local, we will try to pull from hub.docker.com
INFO:apache_beam.runners.portability.portable_runner:Environment "LOOPBACK" has
started a component necessary for the execution. Be sure to run the pipeline
using
with Pipeline() as p:
p.apply(..)
This ensures that the pipeline finishes before this program exits.
INFO:apache_beam.runners.portability.portable_runner:Job state changed to
STOPPED
INFO:apache_beam.runners.portability.portable_runner:Job state changed to
STARTING
INFO:apache_beam.runners.portability.portable_runner:Job state changed to
RUNNING
[flink-runner-job-invoker] WARN
org.apache.flink.runtime.webmonitor.WebMonitorUtils - Log file environment
variable 'log.file' is not set.
[flink-runner-job-invoker] WARN
org.apache.flink.runtime.webmonitor.WebMonitorUtils - JobManager log files are
unavailable in the web dashboard. Log file location not found in environment
variable 'log.file' or configuration key 'Key: 'web.log.path' , default: null
(fallback keys: [{key=jobmanager.web.log.path, isDeprecated=true}])'.
INFO:apache_beam.runners.worker.statecache:Creating state cache with size 0
INFO:apache_beam.runners.worker.sdk_worker:Creating insecure control channel
for localhost:42323.
INFO:apache_beam.runners.worker.sdk_worker:Control channel established.
INFO:apache_beam.runners.worker.sdk_worker:Initializing SDKHarness with
unbounded number of workers.
INFO:apache_beam.runners.worker.sdk_worker:Creating insecure state channel for
localhost:34021.
INFO:apache_beam.runners.worker.sdk_worker:State channel established.
INFO:apache_beam.runners.worker.data_plane:Creating client data channel for
localhost:36795
[assert_that/Group/GroupByKey -> [3]assert_that/{Group, Unkey, Match} (1/2)]
WARN org.apache.beam.sdk.fn.data.BeamFnDataGrpcMultiplexer - Hanged up for
unknown endpoint.
INFO:apache_beam.runners.worker.sdk_worker:No more requests from control plane
INFO:apache_beam.runners.worker.sdk_worker:SDK Harness waiting for in-flight
requests to complete
INFO:apache_beam.runners.worker.data_plane:Closing all cached grpc data
channels.
INFO:apache_beam.runners.worker.sdk_worker:Closing all cached gRPC state
handlers.
INFO:apache_beam.runners.worker.sdk_worker:Done consuming work.
INFO:apache_beam.runners.portability.portable_runner:Job state changed to DONE
.INFO:__main__:removing conf dir: /tmp/flinktest-confQ2fR6q
======================================================================
ERROR: test_external_transforms (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
File
"<https://ci-beam.apache.org/job/beam_PreCommit_Python2_PVR_Flink_Cron/ws/src/sdks/python/apache_beam/runners/portability/flink_runner_test.py",>
line 235, in test_external_transforms
expansion_service=self.get_expansion_service()))
File "apache_beam/transforms/ptransform.py", line 548, in __ror__
result = p.apply(self, pvalueish, label)
File "apache_beam/pipeline.py", line 664, in apply
pvalueish_result = self.runner.apply(transform, pvalueish, self._options)
File "apache_beam/runners/runner.py", line 198, in apply
return m(transform, input, options)
File "apache_beam/runners/runner.py", line 228, in apply_PTransform
return transform.expand(input)
File "apache_beam/transforms/external.py", line 314, in expand
response = service.Expand(request)
File
"<https://ci-beam.apache.org/job/beam_PreCommit_Python2_PVR_Flink_Cron/ws/src/build/gradleenv/1866363813/local/lib/python2.7/site-packages/grpc/_channel.py",>
line 825, in __call__
wait_for_ready, compression)
File
"<https://ci-beam.apache.org/job/beam_PreCommit_Python2_PVR_Flink_Cron/ws/src/build/gradleenv/1866363813/local/lib/python2.7/site-packages/grpc/_channel.py",>
line 813, in _blocking
event = call.next_event()
File "src/python/grpcio/grpc/_cython/_cygrpc/channel.pyx.pxi", line 338, in
grpc._cython.cygrpc.SegregatedCall.next_event
File "src/python/grpcio/grpc/_cython/_cygrpc/channel.pyx.pxi", line 169, in
grpc._cython.cygrpc._next_call_event
File "src/python/grpcio/grpc/_cython/_cygrpc/channel.pyx.pxi", line 163, in
grpc._cython.cygrpc._next_call_event
File "src/python/grpcio/grpc/_cython/_cygrpc/completion_queue.pyx.pxi", line
63, in grpc._cython.cygrpc._latent_event
File "src/python/grpcio/grpc/_cython/_cygrpc/completion_queue.pyx.pxi", line
42, in grpc._cython.cygrpc._next
File "apache_beam/runners/portability/portable_runner_test.py", line 82, in
handler
raise BaseException(msg)
BaseException: Timed out after 60 seconds.
======================================================================
ERROR: test_sql (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
File
"<https://ci-beam.apache.org/job/beam_PreCommit_Python2_PVR_Flink_Cron/ws/src/sdks/python/apache_beam/runners/portability/flink_runner_test.py",>
line 274, in test_sql
equal_to([(x, '{x}*{x}'.format(x=x), x * x) for x in range(5)]))
File "apache_beam/pipeline.py", line 556, in __exit__
self.result.wait_until_finish()
File "apache_beam/runners/portability/portable_runner.py", line 544, in
wait_until_finish
self._observe_state(message_thread)
File "apache_beam/runners/portability/portable_runner.py", line 553, in
_observe_state
for state_response in self._state_stream:
File
"<https://ci-beam.apache.org/job/beam_PreCommit_Python2_PVR_Flink_Cron/ws/src/build/gradleenv/1866363813/local/lib/python2.7/site-packages/grpc/_channel.py",>
line 413, in next
return self._next()
File
"<https://ci-beam.apache.org/job/beam_PreCommit_Python2_PVR_Flink_Cron/ws/src/build/gradleenv/1866363813/local/lib/python2.7/site-packages/grpc/_channel.py",>
line 697, in _next
_common.wait(self._state.condition.wait, _response_ready)
File
"<https://ci-beam.apache.org/job/beam_PreCommit_Python2_PVR_Flink_Cron/ws/src/build/gradleenv/1866363813/local/lib/python2.7/site-packages/grpc/_common.py",>
line 138, in wait
_wait_once(wait_fn, MAXIMUM_WAIT_TIMEOUT, spin_cb)
File
"<https://ci-beam.apache.org/job/beam_PreCommit_Python2_PVR_Flink_Cron/ws/src/build/gradleenv/1866363813/local/lib/python2.7/site-packages/grpc/_common.py",>
line 103, in _wait_once
wait_fn(timeout=timeout)
File "/usr/lib/python2.7/threading.py", line 359, in wait
_sleep(delay)
File "apache_beam/runners/portability/portable_runner_test.py", line 82, in
handler
raise BaseException(msg)
BaseException: Timed out after 60 seconds.
----------------------------------------------------------------------
Ran 88 tests in 770.572s
FAILED (errors=2, skipped=16)
==================== Timed out after 60 seconds. ====================
# Thread: <_Worker(Thread-37, started daemon 140054605305600)>
# Thread: <_Worker(Thread-15, started daemon 140055175747328)>
# Thread: <_MainThread(MainThread, started 140056477390592)>
# Thread: <_Worker(Thread-9, started daemon 140055184140032)>
==================== Timed out after 60 seconds. ====================
# Thread: <Thread(read_grpc_client_inputs, started daemon 140054093612800)>
# Thread: <Thread(Thread-652, started daemon 140054613698304)>
# Thread: <Thread(Thread-650, started daemon 140054655661824)>
# Thread: <Thread(run_worker_36-1, started daemon 140055158961920)>
# Thread: <_Worker(Thread-152, started daemon 140054110398208)>
# Thread: <_Worker(Thread-9, started daemon 140055184140032)>
# Thread: <Thread(Thread-643, started daemon 140054630483712)>
# Thread: <Thread(wait_until_finish_read, started daemon 140054638876416)>
# Thread: <_MainThread(MainThread, started 140056477390592)>
# Thread: <Thread(Thread-636, started daemon 140055167354624)>
# Thread: <PeriodicThread(Thread-646, started daemon 140055687411456)>
# Thread: <Thread(Thread-649, started daemon 140055192532736)>
# Thread: <Thread(Thread-651, started daemon 140054622091008)>
# Thread: <_Worker(Thread-151, started daemon 140054118790912)>
# Thread: <Thread(Thread-647, started daemon 140055150569216)>
# Thread: <_Worker(Thread-190, started daemon 140054102005504)>
# Thread: <_Worker(Thread-15, started daemon 140055175747328)>
# Thread: <Thread(Thread-648, started daemon 140055142176512)>
# Thread: <_Worker(Thread-37, started daemon 140054605305600)>
# Thread: <Thread(read_state, started daemon 140054647269120)>
Exception in thread Thread-772 (most likely raised during interpreter shutdown):
Traceback (most recent call last):
File "/usr/lib/python2.7/threading.py", line 801, in __bootstrap_inner
File "apache_beam/runners/worker/data_plane.py", line 184, in run
File "apache_beam/runners/worker/sdk_worker.py", line 440, in
shutdown_inactive_bundle_processors
<type 'exceptions.AttributeError'>: 'NoneType' object has no attribute 'time'
> Task
> :sdks:python:test-suites:portable:py2:flinkCompatibilityMatrixStreamingPreOptimizeLOOPBACK
> FAILED
FAILURE: Build completed with 2 failures.
1: Task failed with an exception.
-----------
* Where:
Script
'<https://ci-beam.apache.org/job/beam_PreCommit_Python2_PVR_Flink_Cron/ws/src/sdks/python/test-suites/portable/common.gradle'>
line: 57
* What went wrong:
Execution failed for task
':sdks:python:test-suites:portable:py2:flinkCompatibilityMatrixBatchLOOPBACK'.
> 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.
==============================================================================
2: Task failed with an exception.
-----------
* Where:
Script
'<https://ci-beam.apache.org/job/beam_PreCommit_Python2_PVR_Flink_Cron/ws/src/sdks/python/test-suites/portable/common.gradle'>
line: 57
* What went wrong:
Execution failed for task
':sdks:python:test-suites:portable:py2:flinkCompatibilityMatrixStreamingPreOptimizeLOOPBACK'.
> 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
Deprecated Gradle features were used in this build, making it incompatible with
Gradle 6.0.
Use '--warning-mode all' to show the individual deprecation warnings.
See
https://docs.gradle.org/5.2.1/userguide/command_line_interface.html#sec:command_line_warnings
BUILD FAILED in 34m 49s
103 actionable tasks: 74 executed, 28 from cache, 1 up-to-date
Publishing build scan...
https://gradle.com/s/4uwap3patuumy
Build step 'Invoke Gradle script' changed build result to FAILURE
Build step 'Invoke Gradle script' marked build as failure
---------------------------------------------------------------------
To unsubscribe, e-mail: [email protected]
For additional commands, e-mail: [email protected]