Exemplo n.º 1
0
 def test_dataset_dest_and_table_dest_are_required_together_eventually(
         self, attr):
     task = BigQueryStreamingInsert(**{attr: "some-value"})
     with pytest.raises(ValueError) as exc:
         task.run(records=[])
     assert attr in str(exc.value)
     assert "must be provided" in str(exc.value)
Exemplo n.º 2
0
    def test_project_is_pulled_from_creds_and_can_be_overriden_at_anytime(
            self, monkeypatch):
        task = BigQueryStreamingInsert(
            dataset_id="id",
            table="table",
            credentials_secret="GOOGLE_APPLICATION_CREDENTIALS",
        )
        task_proj = BigQueryStreamingInsert(
            dataset_id="id",
            table="table",
            project="test-init",
            credentials_secret="GOOGLE_APPLICATION_CREDENTIALS",
        )

        client_util = MagicMock()
        monkeypatch.setattr("prefect.tasks.gcp.bigquery.get_bigquery_client",
                            client_util)

        with prefect.context(secrets=dict(GOOGLE_APPLICATION_CREDENTIALS={})):
            task.run(records=[])
            task_proj.run(records=[])
            task_proj.run(records=[], project="run-time")

        x, y, z = client_util.call_args_list

        assert x[1]["project"] is None  ## will be pulled from credentials
        assert y[1]["project"] == "test-init"  ## pulled from init
        assert z[1]["project"] == "run-time"  ## pulled from run kwarg
Exemplo n.º 3
0
    def test_creds_are_pulled_from_secret_at_runtime(self, monkeypatch):
        task = BigQueryStreamingInsert(
            dataset_id="id",
            table="table",
            credentials_secret="GOOGLE_APPLICATION_CREDENTIALS",
        )

        client_util = MagicMock()
        monkeypatch.setattr("prefect.tasks.gcp.bigquery.get_bigquery_client",
                            client_util)

        with prefect.context(secrets=dict(GOOGLE_APPLICATION_CREDENTIALS=42)):
            task.run(records=[])

        assert client_util.call_args[1]["credentials"] == 42
Exemplo n.º 4
0
 def test_additional_kwargs_passed_upstream(self):
     task = BigQueryStreamingInsert(name="test-task",
                                    checkpoint=True,
                                    tags=["bob"])
     assert task.name == "test-task"
     assert task.checkpoint is True
     assert task.tags == {"bob"}
Exemplo n.º 5
0
 def test_initializes_with_nothing_and_sets_defaults(self):
     task = BigQueryStreamingInsert()
     assert task.project is None
     assert task.location == "US"
     assert task.credentials_secret is None
     assert task.dataset_id is None
     assert task.table is None
Exemplo n.º 6
0
 def test_initializes_attr_from_kwargs(self, attr):
     task = BigQueryStreamingInsert(**{attr: "my-value"})
     assert getattr(task, attr) == "my-value"