Exemple #1
0
    def test_creds_are_pulled_from_secret_at_runtime(self, monkeypatch):
        task = OpenGitHubIssue(token_secret="GITHUB_ACCESS_TOKEN")

        req = MagicMock()
        monkeypatch.setattr(requests, "post", req)

        with prefect.context(secrets=dict(GITHUB_ACCESS_TOKEN={"key": 42})):
            task.run(repo="org/repo")

        assert req.call_args[1]["headers"]["AUTHORIZATION"] == "token {'key': 42}"
Exemple #2
0
    def test_creds_secret_can_be_overwritten(self, monkeypatch):
        task = OpenGitHubIssue(token_secret="MY_SECRET")

        req = MagicMock()
        monkeypatch.setattr("prefect.tasks.github.issues.requests", req)

        with set_temporary_config({"cloud.use_local_secrets": True}):
            with prefect.context(secrets=dict(MY_SECRET={"key": 42})):
                task.run(repo="org/repo")

        assert req.post.call_args[1]["headers"]["AUTHORIZATION"] == "token {'key': 42}"
Exemple #3
0
    def test_creds_are_pulled_from_secret_at_runtime(self, monkeypatch):
        task = OpenGitHubIssue()

        req = MagicMock()
        monkeypatch.setattr("prefect.tasks.github.issues.requests", req)

        with set_temporary_config({"cloud.use_local_secrets": True}):
            with prefect.context(secrets=dict(GITHUB_ACCESS_TOKEN={"key": 42})):
                task.run(repo="org/repo")

        assert req.post.call_args[1]["headers"]["AUTHORIZATION"] == "token {'key': 42}"
Exemple #4
0
 def test_initializes_with_nothing_and_sets_defaults(self):
     task = OpenGitHubIssue()
     assert task.repo is None
     assert task.title is None
     assert task.body is None
     assert task.labels == []
     assert task.token_secret == "GITHUB_ACCESS_TOKEN"
Exemple #5
0
 def test_repo_is_required_eventually(self):
     task = OpenGitHubIssue()
     with pytest.raises(ValueError, match="repo"):
         task.run()
Exemple #6
0
 def test_initializes_attr_from_kwargs(self, attr):
     task = OpenGitHubIssue(**{attr: "my-value"})
     assert getattr(task, attr) == "my-value"
Exemple #7
0
 def test_additional_kwargs_passed_upstream(self):
     task = OpenGitHubIssue(name="test-task", checkpoint=True, tags=["bob"])
     assert task.name == "test-task"
     assert task.checkpoint is True
     assert task.tags == {"bob"}
Exemple #8
0
 def test_initializes_with_nothing_and_sets_defaults(self):
     task = OpenGitHubIssue()
     assert task.repo is None
     assert task.title is None
     assert task.body is None
     assert task.labels == []
Exemple #9
0
 def test_repo_is_required_eventually(self):
     task = OpenGitHubIssue()
     with pytest.raises(ValueError) as exc:
         task.run()
     assert "repo" in str(exc.value)
Exemple #10
0
    base="master",
    head="dev",
    title="Bi-weekly Release",
    max_retries=1,
    retry_delay=datetime.timedelta(minutes=1),
)


@task(trigger=any_failed)
def prepare_exception(exc):
    return repr(exc)


issue_task = OpenGitHubIssue(
    name="Open Release Issue",
    repo="PrefectHQ/cloud",
    title="Release Cycle is Broken",
    labels=["release", "bug"],
)

biweekly_schedule = IntervalSchedule(start_date=pendulum.parse("2019-03-18"),
                                     interval=datetime.timedelta(days=14))

with Flow("Biweekly Cloud Release", schedule=biweekly_schedule) as flow:
    exc = prepare_exception(
        pr_task)  # will only run if pr_task fails in some way
    issue = issue_task(body=exc)

flow.set_reference_tasks([pr_task])
flow.run()