Martijn Sanderse
09/05/2025, 12:11 PM"state": {
    "id": "019919bf-f823-7153-990f-8779580ab822",
    "type": "COMPLETED",
    "name": "Completed",
    "timestamp": "2025-09-05T12:00:35.363054Z",
    "message": null,
    "data": {
      "storage_key": "/root/.prefect/storage/5419026f36f948c396a057500d24261c",
      "expiration": null,
      "serializer": {
        "type": "json",
        "jsonlib": "json",
        "object_encoder": "prefect.serializers.prefect_json_object_encoder",
        "object_decoder": "prefect.serializers.prefect_json_object_decoder",
        "dumps_kwargs": {},
        "loads_kwargs": {}
      },
      "prefect_version": "3.4.14",
      "storage_block_id": null
    },
    "state_details": {
      "flow_run_id": "78b4288d-a6a1-493f-b578-b5d257e47a64",
      "task_run_id": null,
      "child_flow_run_id": null,
      "scheduled_time": null,
      "cache_key": null,
      "cache_expiration": null,
      "deferred": null,
      "untrackable_result": false,
      "pause_timeout": null,
      "pause_reschedule": false,
      "pause_key": null,
      "run_input_keyset": null,
      "refresh_cache": null,
      "retriable": null,
      "transition_id": "1ce9fb5b-3ba7-4e22-ac55-1049ab27fcfb",
      "task_parameters_id": null,
      "traceparent": null,
      "deployment_concurrency_lease_id": null
    }
  },Marvin
09/05/2025, 12:11 PMMarvin
09/05/2025, 12:16 PM/root/.prefect/storage/...prefect flow-run inspect <FLOW_RUN_ID>prefect flow-run inspect 78b4288d-a6a1-493f-b578-b5d257e47a64import asyncio
from prefect.client.orchestration import get_client
from prefect.states import get_state_result
async def fetch_result(flow_run_id: str):
    async with get_client() as client:
        flow_run = await client.read_flow_run(flow_run_id)
    # Resolve and return the Python object stored as the flow's result
    return get_state_result(flow_run.state)
if __name__ == "__main__":
    result = asyncio.run(fetch_result("78b4288d-a6a1-493f-b578-b5d257e47a64"))
    print("Flow result:", result)read_task_run(task_run_id)get_state_resultimport json
from prefect.serializers import prefect_json_object_decoder
path = "/root/.prefect/storage/5419026f36f948c396a057500d24261c"
with open(path, "rb") as f:
    value = json.loads(f.read(), object_hook=prefect_json_object_decoder)
print("Flow result:", value)/root/.prefect/storage/...get_state_resultget_state_result