You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@airflow.apache.org by GitBox <gi...@apache.org> on 2020/06/12 12:23:10 UTC

[GitHub] [airflow] kaxil edited a comment on pull request #9247: CI: Propogate Exit Code Correctly

kaxil edited a comment on pull request #9247:
URL: https://github.com/apache/airflow/pull/9247#issuecomment-643241966


   > Fuuu. Tests have been running but not failing the build?
   
   Yup:
   
   ```
   ERROR tests/providers/apache/livy/hooks/test_livy.py::TestLivyHook::test_build_body
   ERROR tests/providers/apache/livy/hooks/test_livy.py::TestLivyHook::test_build_get_hook
   ERROR tests/providers/apache/livy/hooks/test_livy.py::TestLivyHook::test_check_session_id
   ERROR tests/providers/apache/livy/hooks/test_livy.py::TestLivyHook::test_delete_batch_fail
   ERROR tests/providers/apache/livy/hooks/test_livy.py::TestLivyHook::test_delete_batch_success
   ERROR tests/providers/apache/livy/hooks/test_livy.py::TestLivyHook::test_delete_batch_validation
   ERROR tests/providers/apache/livy/hooks/test_livy.py::TestLivyHook::test_get_batch_fail
   ERROR tests/providers/apache/livy/hooks/test_livy.py::TestLivyHook::test_get_batch_state_fail
   ERROR tests/providers/apache/livy/hooks/test_livy.py::TestLivyHook::test_get_batch_state_missing
   ERROR tests/providers/apache/livy/hooks/test_livy.py::TestLivyHook::test_get_batch_state_success
   ERROR tests/providers/apache/livy/hooks/test_livy.py::TestLivyHook::test_get_batch_state_validation
   ERROR tests/providers/apache/livy/hooks/test_livy.py::TestLivyHook::test_get_batch_success
   ERROR tests/providers/apache/livy/hooks/test_livy.py::TestLivyHook::test_get_batch_validation
   ERROR tests/providers/apache/livy/hooks/test_livy.py::TestLivyHook::test_invalid_uri
   ERROR tests/providers/apache/livy/hooks/test_livy.py::TestLivyHook::test_missing_batch_id
   ERROR tests/providers/apache/livy/hooks/test_livy.py::TestLivyHook::test_missing_host
   ERROR tests/providers/apache/livy/hooks/test_livy.py::TestLivyHook::test_parameters_validation
   ERROR tests/providers/apache/livy/hooks/test_livy.py::TestLivyHook::test_parse_post_response
   ERROR tests/providers/apache/livy/hooks/test_livy.py::TestLivyHook::test_post_batch_arguments
   ERROR tests/providers/apache/livy/hooks/test_livy.py::TestLivyHook::test_post_batch_fail
   ERROR tests/providers/apache/livy/hooks/test_livy.py::TestLivyHook::test_post_batch_success
   ERROR tests/providers/apache/livy/hooks/test_livy.py::TestLivyHook::test_validate_extra_conf
   ERROR tests/providers/apache/livy/hooks/test_livy.py::TestLivyHook::test_validate_list_of_stringables
   ERROR tests/providers/apache/livy/hooks/test_livy.py::TestLivyHook::test_validate_size_format
   FAILED tests/executors/test_dask_executor.py::TestDaskExecutor::test_dask_executor_functions
   FAILED tests/executors/test_dask_executor.py::TestDaskExecutorTLS::test_tls
   FAILED tests/executors/test_kubernetes_executor.py::TestKubernetesExecutor::test_run_next_exception
   FAILED tests/executors/test_local_executor.py::TestLocalExecutor::test_execution_limited_parallelism
   FAILED tests/executors/test_local_executor.py::TestLocalExecutor::test_execution_unlimited_parallelism
   
   FAILED tests/executors/test_local_executor.py::TestLocalExecutor::test_execution_limited_parallelism
   FAILED tests/executors/test_local_executor.py::TestLocalExecutor::test_execution_unlimited_parallelism
   FAILED tests/models/test_dagcode.py::TestDagCode::test_remove_unused_code - A...
   FAILED tests/providers/amazon/aws/operators/test_google_api_to_s3_transfer.py::TestGoogleApiToS3Transfer::test_execute
   FAILED tests/providers/amazon/aws/operators/test_google_api_to_s3_transfer.py::TestGoogleApiToS3Transfer::test_execute_with_xcom
   FAILED tests/providers/amazon/aws/operators/test_google_api_to_s3_transfer.py::TestGoogleApiToS3Transfer::test_execute_with_xcom_exceeded_max_xcom_size
   FAILED tests/providers/discord/hooks/test_discord_webhook.py::TestDiscordWebhookHook::test_build_discord_payload
   FAILED tests/providers/discord/hooks/test_discord_webhook.py::TestDiscordWebhookHook::test_build_discord_payload_message_length
   FAILED tests/providers/discord/hooks/test_discord_webhook.py::TestDiscordWebhookHook::test_get_webhook_endpoint_conn_id
   FAILED tests/providers/discord/hooks/test_discord_webhook.py::TestDiscordWebhookHook::test_get_webhook_endpoint_invalid_url
   FAILED tests/providers/discord/hooks/test_discord_webhook.py::TestDiscordWebhookHook::test_get_webhook_endpoint_manual_token
   FAILED tests/providers/google/common/hooks/test_discovery_api.py::TestGoogleDiscoveryApiHook::test_get_conn
   FAILED tests/providers/google/common/hooks/test_discovery_api.py::TestGoogleDiscoveryApiHook::test_query
   FAILED tests/providers/google/common/hooks/test_discovery_api.py::TestGoogleDiscoveryApiHook::test_query_with_pagination
   FAILED tests/providers/imap/hooks/test_imap.py::TestImapHook::test_connect_and_disconnect
   FAILED tests/providers/imap/hooks/test_imap.py::TestImapHook::test_download_mail_attachments_found
   FAILED tests/providers/imap/hooks/test_imap.py::TestImapHook::test_download_mail_attachments_not_found
   FAILED tests/providers/imap/hooks/test_imap.py::TestImapHook::test_download_mail_attachments_with_escaping_chars
   FAILED tests/providers/imap/hooks/test_imap.py::TestImapHook::test_download_mail_attachments_with_latest_only
   FAILED tests/providers/imap/hooks/test_imap.py::TestImapHook::test_download_mail_attachments_with_mail_filter
   FAILED tests/providers/imap/hooks/test_imap.py::TestImapHook::test_download_mail_attachments_with_regex_found
   FAILED tests/providers/imap/hooks/test_imap.py::TestImapHook::test_download_mail_attachments_with_regex_not_found
   FAILED tests/providers/imap/hooks/test_imap.py::TestImapHook::test_download_mail_attachments_with_symlink
   !!!!!!!!!!!!!!!!!!!!!!!!!! stopping after 50 failures !!!!!!!!!!!!!!!!!!!!!!!!!!
   = 26 failed, 4521 passed, 338 skipped, 1 xpassed, 9 warnings, 24 errors in 623.63s (0:10:23) =
   Disposing DB connection pool (PID 127)
   No metrics to flush. Continuing.
   No distributions to flush. Continuing.
   No events to flush. Continuing.
   Disposing DB connection pool (PID 127)
   EOF in transport thread
   EOF in transport thread
   EOF in transport thread
   EOF in transport thread
   ##############################################################################
   
      DUMPING LOG FILES FROM AIRFLOW AND SENDING THEM TO file.io
   
   ##############################################################################
   ###########################################################################################
                      Dumping logs from all the airflow tasks
   ###########################################################################################
   ~/airflow /opt/airflow /opt/airflow
   /opt/airflow /opt/airflow
   ###########################################################################################
   
      Logs saved to /tmp/2020-06-12_airflow_133036912_tests-postgres.log.tar.gz
   
   ##############################################################################
     % Total    % Received % Xferd  Average Speed   Time    Time     Time  Current
                                    Dload  Upload   Total   Spent    Left  Speed
   
     0     0    0     0    0     0      0      0 --:--:-- --:--:-- --:--:--     0
   100 32056  100    86  100 31970   1061   385k --:--:-- --:--:-- --:--:--  381k
   100 32056  100    86  100 31970   1023   371k --:--:-- --:--:-- --:--:--  368k
   {"success":true,"key":"D2BpfVu1","link":"https://file.io/D2BpfVu1","expiry":"14 days"}###########################################################################################
                      EXITING /opt/airflow/scripts/ci/in_container/run_ci_tests.sh WITH STATUS CODE 1
   ###########################################################################################
   ###########################################################################################
                      EXITING /opt/airflow/scripts/ci/in_container/entrypoint_ci.sh WITH STATUS CODE 1
   ###########################################################################################
   
   Finished the script ci_run_airflow_testing.sh
   Elapsed time spent in the script: 650 seconds
   Exit code 0
   ```


----------------------------------------------------------------
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

For queries about this service, please contact Infrastructure at:
users@infra.apache.org