See 
<https://ci-beam.apache.org/job/beam_PostCommit_Python35_VR_Flink/2213/display/redirect?page=changes>

Changes:

[nielm] Merge the 2 stages 'Gather and Sort' and 'Create Batches'

[nielm] Add additional documentation on Batching and Grouping

[nielm] Use ref-counted connection to Spanner to prevent multiple connections.

[pulasthi911] adding twister2 runner with support for batch piplines

[noreply] [BEAM-10023] Don't add interactive extra for dependency check in 
python

[daniel.o.programmer] [BEAM-10311] Sharing restriction trackers between SDF and 
DataSource.

[noreply] [BEAM-10329] Change dataflow runner BatchStatefulParDoOverrides to use

[noreply] [BEAM-10303] Add support for the non-window observing optimization to

[noreply] [BEAM-10219] Support ZetaSQL TIME functions in BeamSQL (#12054)


------------------------------------------
[...truncated 2.88 MB...]
        at 
org.apache.beam.runners.fnexecution.control.FnApiControlClient$ResponseStreamObserver.onNext(FnApiControlClient.java:157)
        at 
org.apache.beam.vendor.grpc.v1p26p0.io.grpc.stub.ServerCalls$StreamingServerCallHandler$StreamingServerCallListener.onMessage(ServerCalls.java:251)
        at 
org.apache.beam.vendor.grpc.v1p26p0.io.grpc.ForwardingServerCallListener.onMessage(ForwardingServerCallListener.java:33)
        at 
org.apache.beam.vendor.grpc.v1p26p0.io.grpc.Contexts$ContextualizedServerCallListener.onMessage(Contexts.java:76)
        at 
org.apache.beam.vendor.grpc.v1p26p0.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailableInternal(ServerCallImpl.java:309)
        at 
org.apache.beam.vendor.grpc.v1p26p0.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailable(ServerCallImpl.java:292)
        at 
org.apache.beam.vendor.grpc.v1p26p0.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1MessagesAvailable.runInContext(ServerImpl.java:782)
        at 
org.apache.beam.vendor.grpc.v1p26p0.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
        at 
org.apache.beam.vendor.grpc.v1p26p0.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:123)
        at 
java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
        at 
java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
        ... 1 more
ERROR:root:java.lang.RuntimeException: Error received from SDK harness for 
instruction 4: Traceback (most recent call last):
  File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/worker/sdk_worker.py";,>
 line 247, in _execute
    response = task()
  File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/worker/sdk_worker.py";,>
 line 304, in <lambda>
    lambda: self.create_worker().do_instruction(request), request)
  File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/worker/sdk_worker.py";,>
 line 473, in do_instruction
    getattr(request, request_type), request.instruction_id)
  File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/worker/sdk_worker.py";,>
 line 508, in process_bundle
    bundle_processor.process_bundle(instruction_id))
  File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/worker/bundle_processor.py";,>
 line 978, in process_bundle
    element.data)
  File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/worker/bundle_processor.py";,>
 line 218, in process_encoded
    self.output(decoded_value)
  File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/worker/operations.py";,>
 line 332, in output
    cython.cast(Receiver, self.receivers[output_index]).receive(windowed_value)
  File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/worker/operations.py";,>
 line 195, in receive
    self.consumer.process(windowed_value)
  File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/worker/operations.py";,>
 line 764, in process
    delayed_application = self.dofn_runner.process_with_sized_restriction(o)
  File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/common.py";,>
 line 975, in process_with_sized_restriction
    watermark_estimator=watermark_estimator)
  File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/common.py";,>
 line 712, in invoke_process
    windowed_value, additional_args, additional_kwargs)
  File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/common.py";,>
 line 819, in _invoke_process_per_window
    self.threadsafe_restriction_tracker.check_done()
  File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/sdf_utils.py";,>
 line 115, in check_done
    return self._restriction_tracker.check_done()
  File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/io/restriction_trackers.py";,>
 line 101, 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
.sssINFO:apache_beam.runners.worker.worker_pool_main:Listening for workers at 
localhost:46247
WARNING:root:Make sure that locally built Python SDK docker image has Python 
3.5 interpreter.
INFO:root:Using Python SDK docker image: apache/beam_python3.5_sdk:2.23.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}])'.
[[5]{Create, Map(<lambda at fn_runner_test.py:489>), WindowInto(WindowIntoFn), 
Map(<lambda at fn_runner_test.py:492>)} (1/2)] WARN 
org.apache.flink.metrics.MetricGroup - The operator name [5]{Create, 
Map(<lambda at fn_runner_test.py:489>), WindowInto(WindowIntoFn), Map(<lambda 
at fn_runner_test.py:492>)} exceeded the 80 characters length limit and was 
truncated.
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:44467.
INFO:apache_beam.runners.worker.sdk_worker:Control channel established.
[[5]{Create, Map(<lambda at fn_runner_test.py:489>), WindowInto(WindowIntoFn), 
Map(<lambda at fn_runner_test.py:492>)} (2/2)] WARN 
org.apache.flink.metrics.MetricGroup - The operator name [5]{Create, 
Map(<lambda at fn_runner_test.py:489>), WindowInto(WindowIntoFn), Map(<lambda 
at fn_runner_test.py:492>)} 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:35029.
INFO:apache_beam.runners.worker.sdk_worker:State channel established.
INFO:apache_beam.runners.worker.data_plane:Creating client data channel for 
localhost:37745
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.
[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.
[grpc-default-executor-3] WARN 
org.apache.beam.sdk.fn.data.BeamFnDataGrpcMultiplexer - Hanged up for unknown 
endpoint.
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:43719
WARNING:root:Make sure that locally built Python SDK docker image has Python 
3.5 interpreter.
INFO:root:Using Python SDK docker image: apache/beam_python3.5_sdk:2.23.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:44733.
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:34441.
INFO:apache_beam.runners.worker.sdk_worker:State channel established.
INFO:apache_beam.runners.worker.data_plane:Creating client data channel for 
localhost:42863
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.
[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:__main__:removing conf dir: /tmp/flinktest-confxjkd28ki

======================================================================
ERROR: test_assert_that (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/fn_api_runner/fn_runner_test.py";,>
 line 113, in test_assert_that
    assert_that(p | beam.Create(['a', 'b']), equal_to(['a']))
  File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/pipeline.py";,>
 line 547, in __exit__
    self.run().wait_until_finish()
  File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/portable_runner.py";,>
 line 543, in wait_until_finish
    self._observe_state(message_thread)
  File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/portable_runner.py";,>
 line 552, in _observe_state
    for state_response in self._state_stream:
  File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/build/gradleenv/2022703439/lib/python3.5/site-packages/grpc/_channel.py";,>
 line 416, in __next__
    return self._next()
  File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/build/gradleenv/2022703439/lib/python3.5/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_PostCommit_Python35_VR_Flink/ws/src/build/gradleenv/2022703439/lib/python3.5/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_PostCommit_Python35_VR_Flink/ws/src/build/gradleenv/2022703439/lib/python3.5/site-packages/grpc/_common.py";,>
 line 103, in _wait_once
    wait_fn(timeout=timeout)
  File "/usr/lib/python3.5/threading.py", line 297, in wait
    gotit = waiter.acquire(True, timeout)
  File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/portable_runner_test.py";,>
 line 82, in handler
    raise BaseException(msg)
BaseException: Timed out after 60 seconds.

======================================================================
ERROR: test_external_transforms (__main__.FlinkRunnerTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/flink_runner_test.py";,>
 line 225, in test_external_transforms
    expansion_service=get_expansion_service()))
  File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/transforms/ptransform.py";,>
 line 562, in __ror__
    result = p.apply(self, pvalueish, label)
  File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/pipeline.py";,>
 line 655, in apply
    pvalueish_result = self.runner.apply(transform, pvalueish, self._options)
  File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/runner.py";,>
 line 198, in apply
    return m(transform, input, options)
  File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/runner.py";,>
 line 228, in apply_PTransform
    return transform.expand(input)
  File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/transforms/external.py";,>
 line 321, in expand
    pipeline.local_tempdir)
  File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/transforms/external.py";,>
 line 363, in _resolve_artifacts
    artifact_service.resolve_artifacts(env.dependencies, service, dest))
  File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/artifact_service.py";,>
 line 281, in resolve_artifacts
    artifacts=artifacts)).replacements
  File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/artifact_service.py";,>
 line 279, in <listcomp>
    dest_dir) for artifact in service.ResolveArtifacts(
  File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/artifact_service.py";,>
 line 297, in maybe_store_artifact
    return store_artifact(artifact, service, dest_dir)
  File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/artifact_service.py";,>
 line 306, in store_artifact
    beam_artifact_api_pb2.GetArtifactRequest(artifact=artifact)):
  File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/build/gradleenv/2022703439/lib/python3.5/site-packages/grpc/_channel.py";,>
 line 416, in __next__
    return self._next()
  File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/build/gradleenv/2022703439/lib/python3.5/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_PostCommit_Python35_VR_Flink/ws/src/build/gradleenv/2022703439/lib/python3.5/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_PostCommit_Python35_VR_Flink/ws/src/build/gradleenv/2022703439/lib/python3.5/site-packages/grpc/_common.py";,>
 line 103, in _wait_once
    wait_fn(timeout=timeout)
  File "/usr/lib/python3.5/threading.py", line 297, in wait
    gotit = waiter.acquire(True, timeout)
  File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/apache_beam/runners/portability/portable_runner_test.py";,>
 line 82, in handler
    raise BaseException(msg)
BaseException: Timed out after 60 seconds.

----------------------------------------------------------------------
Ran 82 tests in 597.289s

FAILED (errors=2, skipped=15)
==================== Timed out after 60 seconds. ====================

# Thread: <Thread(wait_until_finish_read, started daemon 139632809342720)>

# Thread: <Thread(Thread-7, started daemon 139633297004288)>

# Thread: <_MainThread(MainThread, started 139634116384512)>

# Thread: <Thread(Thread-1, started daemon 139633905116928)>
==================== Timed out after 60 seconds. ====================

# Thread: <Thread(Thread-112, started daemon 139631735600896)>

# Thread: <_Worker(Thread-45, started daemon 139632230508288)>

# Thread: <_MainThread(MainThread, started 139634116384512)>

# Thread: <_Worker(Thread-16, started daemon 139633297004288)>

# Thread: <_Worker(Thread-25, started daemon 139632255686400)>

> Task 
> :sdks:python:test-suites:portable:py35:flinkCompatibilityMatrixStreamingPreOptimizeLOOPBACK
>  FAILED

FAILURE: Build completed with 3 failures.

1: Task failed with an exception.
-----------
* Where:
Script 
'<https://ci-beam.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/test-suites/portable/common.gradle'>
 line: 57

* What went wrong:
Execution failed for task 
':sdks:python:test-suites:portable:py35: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_PostCommit_Python35_VR_Flink/ws/src/sdks/python/test-suites/portable/common.gradle'>
 line: 57

* What went wrong:
Execution failed for task 
':sdks:python:test-suites:portable:py35:flinkCompatibilityMatrixStreamingLOOPBACK'.
> 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.
==============================================================================

3: Task failed with an exception.
-----------
* Where:
Script 
'<https://ci-beam.apache.org/job/beam_PostCommit_Python35_VR_Flink/ws/src/sdks/python/test-suites/portable/common.gradle'>
 line: 57

* What went wrong:
Execution failed for task 
':sdks:python:test-suites:portable:py35: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 50m 54s
78 actionable tasks: 61 executed, 16 from cache, 1 up-to-date

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

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]

Reply via email to