# DBT Tasks


This module contains a task for interacting with dbt via the shell.

# DbtShellTask

class

prefect.tasks.dbt.dbt.DbtShellTask

(command=None, profile_name=None, env=None, environment=None, overwrite_profiles=False, profiles_dir=None, set_profiles_envar=True, dbt_kwargs=None, helper_script=None, shell="bash", return_all=False, **kwargs)[source]

Task for running dbt commands. It will create a profiles.yml file prior to running dbt commands.

Args:

  • command (string, optional): dbt command to be executed; can also be provided post-initialization by calling this task instance
  • dbt_kwargs (dict, optional): keyword arguments used to populate the profiles.yml file (e.g. {'type': 'snowflake', 'threads': 4, 'account': '...'}); can also be provided at runtime
  • env (dict, optional): dictionary of environment variables to use for the subprocess; can also be provided at runtime
  • environment (string, optional): The default target your dbt project will use
  • overwrite_profiles (boolean, optional): flag to indicate whether existing profiles.yml file should be overwritten; defaults to False
  • profile_name (string, optional): Profile name used for populating the profile name of profiles.yml
  • profiles_dir (string, optional): path to directory where the profile.yml file will be contained
  • set_profiles_envar (boolean, optional): flag to indicate whether DBT_PROFILES_DIR should be set to the provided profiles_dir; defaults to True
  • helper_script (str, optional): a string representing a shell script, which will be executed prior to the command in the same process. Can be used to change directories, define helper functions, etc. when re-using this Task for different commands in a Flow
  • shell (string, optional): shell to run the command with; defaults to "bash"
  • return_all (bool, optional): boolean specifying whether this task should return all lines of stdout as a list, or just the last line as a string; defaults to False
  • **kwargs: additional keyword arguments to pass to the Task constructor
Example:

    from prefect import Flow
    from prefect.tasks.dbt import DbtShellTask

    with Flow(name="dbt_flow") as f:
        task = DbtShellTask(
            profile_name='default',
            environment='test',
            dbt_kwargs={
                'type': 'snowflake',
                'threads': 1,
                'account': 'account.us-east-1'
            },
            overwrite_profiles=True,
            profiles_dir=test_path
        )(command='dbt run')

    out = f.run()

methods:                                                                                                                                                       

prefect.tasks.dbt.dbt.DbtShellTask.run

(command=None, env=None, dbt_kwargs=None)[source]

If no profiles.yml file is found or if overwrite_profiles flag is set to True, this will first generate a profiles.yml file in the profiles_dir directory. Then run the dbt cli shell command.

Args:

  • command (string): shell command to be executed; can also be provided at task initialization. Any variables / functions defined in self.helper_script will be available in the same process this command runs in
  • env (dict, optional): dictionary of environment variables to use for the subprocess
  • dbt_kwargs(dict, optional): keyword arguments used to populate the profiles.yml file
Returns:
  • stdout (string): if return_all is False (the default), only the last line of stdout is returned, otherwise all lines are returned, which is useful for passing result of shell command to other downstream tasks. If there is no output, None is returned.
Raises:
  • prefect.engine.signals.FAIL: if command has an exit code other than 0



This documentation was auto-generated from commit n/a
on June 17, 2020 at 17:27 UTC