hi folks! i'm running into an odd issue with `pref...
# prefect-community
j
hi folks! i'm running into an odd issue with
prefect 2.0
and
pydantic
where it looks like extra attributes are being ignored? details in thread
simple example here:
Copy code
class Something(BaseModel):
    a: int

    class Config:
        extra = Extra.allow

@task
def my_task(model: Something):
    logger = get_run_logger()
    <http://logger.info|logger.info>(f"in my_task: {model.dict()}")


def my_regular_function(model: Something):
    logger = get_run_logger()
    <http://logger.info|logger.info>(f"in my_regular_function: {model.dict()}")


@flow
def my_flow():
    model = Something(a=1, b=2)

    logger = get_run_logger()
    <http://logger.info|logger.info>(f"in my_flow: {model.dict()}")

    my_regular_function(model)
    my_task(model)


if __name__ == '__main__':
    my_flow()
this is the output that's generated:
Copy code
11:00:32.593 | INFO    | prefect.engine - Created flow run 'interesting-otter' for flow 'my-flow'
11:00:32.593 | INFO    | Flow run 'interesting-otter' - Using task runner 'ConcurrentTaskRunner'
11:00:32.645 | WARNING | Flow run 'interesting-otter' - No default storage is configured on the server. Results from this flow run will be stored in a temporary directory in its runtime environment.
11:00:32.707 | INFO    | Flow run 'interesting-otter' - in my_flow: {'a': 1, 'b': 2}
11:00:32.707 | INFO    | Flow run 'interesting-otter' - in my_regular_function: {'a': 1, 'b': 2}
11:00:32.765 | INFO    | Flow run 'interesting-otter' - Created task run 'my_task-ec9685da-0' for task 'my_task'
11:00:32.857 | INFO    | Task run 'my_task-ec9685da-0' - in my_task: {'a': 1}
11:00:32.908 | INFO    | Task run 'my_task-ec9685da-0' - Finished in state Completed()
11:00:32.953 | INFO    | Flow run 'interesting-otter' - Finished in state Completed('All states completed.')
you can see when i call
my_regular_function
, the extra attribute isn't lost and
{'a': 1, 'b': 2}
is printed. when i call
my_task
, i only get
{'a': 1}
i'm guessing this is due to some serialization stuff that's happening, but i wouldn't expect the extra key to be lost
yeah, digging into it i see this code in `prefect.utilities.collections`:
Copy code
elif (
        # Recurse into Pydantic models but do _not_ do so for states/datadocs
        isinstance(expr, pydantic.BaseModel)
        and not isinstance(expr, prefect.orion.schemas.states.State)
        and not isinstance(expr, prefect.orion.schemas.data.DataDocument)
    ):
        values = await gather(
            *[visit_nested(getattr(expr, field)) for field in expr.__fields__]
        )
        result = {field: value for field, value in zip(expr.__fields__, values)}
        return typ(**result) if return_data else None
which will exclude extra keys
k
As far as I can tell this is a bug. We’ll make an issue and get a proper response from the engineers. The one responsible for this might be out this week so you may have to wait for next week. @Marvin open “Pydantic seems to drops extra keys for tasks”
👍 1
j
sounds good! we'll work around it by just using plain dicts until it's resolved. thank you!
k
Thank you for the detailed write-up