https://prefect.io logo
Docs
Join the conversationJoin Slack
Channels
announcements
ask-marvin
best-practices-coordination-plane
data-ecosystem
data-tricks-and-tips
events
find-a-prefect-job
geo-australia
geo-bay-area
geo-berlin
geo-boston
geo-chicago
geo-colorado
geo-dc
geo-israel
geo-japan
geo-london
geo-nyc
geo-seattle
geo-texas
gratitude
introductions
marvin-in-the-wild
prefect-ai
prefect-aws
prefect-azure
prefect-cloud
prefect-community
prefect-contributors
prefect-dbt
prefect-docker
prefect-gcp
prefect-getting-started
prefect-integrations
prefect-kubernetes
prefect-recipes
prefect-server
prefect-ui
random
show-us-what-you-got
Powered by Linen
prefect-community
  • a

    alex

    01/05/2023, 10:32 PM
    Is it possible to access the flow name from a task run context? I can use
    get_run_context().flow.name
    from the flow context but am unable to find an equivalent on the task level
    m
    a
    19 replies · 3 participants
  • e

    Edmondo Porcu

    01/05/2023, 10:46 PM
    One more annoying question about Prefect Helm chart. this https://github.com/PrefectHQ/prefect-helm/blob/main/charts/prefect-orion/values.yaml#L233 is for an admin user capable of creating a new database within the server. Is it also possible to specify username and password for the “prefect” user?
    m
    m
    5 replies · 3 participants
  • m

    Mason Menges

    01/05/2023, 10:50 PM
    Hey @Tuoyi Zhao That definitely doesn't look right can you try running through the steps in this article to clear the cache for the webpage and see if it's still occurring after that https://discourse.prefect.io/t/login-to-prefect-cloud-fails-with-an-error-failed-to-loa[…]checking-is-enforced-for-module-scripts-per-html-spec/1722
    t
    4 replies · 2 participants
  • m

    Miller Jiang

    01/05/2023, 11:09 PM
    Hi, when I used aws credential block to access S3 via boto3, I have this error
    boto3.exceptions.S3UploadFailedError: Failed to upload. An error occurred (SignatureDoesNotMatch) when calling the PutObject operation: The request signature we calculated does not match the signature you provided. Check your key and signing method.
    k
    w
    4 replies · 3 participants
  • m

    Marcelo Santoro

    01/06/2023, 2:16 AM
    I tried again with new syntax... and now I have this error:
    Auto GKE disallows use of <http://cluster-autoscaler.kubernetes.io/safe-to-evict=false|cluster-autoscaler.kubernetes.io/safe-to-evict=false> annotation on workloads
    c
    3 replies · 2 participants
  • s

    Santhosh Solomon (Fluffy)

    01/06/2023, 2:31 AM
    Can anyone help me with understanding the concurrency concept in prefect? I have created a sample flow to understand the concurrency at both queue level and task(tag) level. I used the below script
    from prefect import task, flow
    from time import sleep
    from prefect.task_runners import ConcurrentTaskRunner
    
    @task(tags=['concurrent-task'])
    def perf_task(input):
        sleep(25)
        print(input)
    
    @flow(task_runner=ConcurrentTaskRunner)
    def test_flow():
        for i in range(100):
            perf_task(i)
    
    
    if __name__ == '__main__':
        test_flow()
    ✅ 1
    t
    2 replies · 2 participants
  • s

    Siva Balusu

    01/06/2023, 3:29 AM
    @here Is there a way to delete a JSON block via python?
  • s

    Siva Balusu

    01/06/2023, 3:30 AM
    I have tried to use .delete but it throws the following error JSON.delete("prefect-kv-test") AttributeError: type object 'JSON' has no attribute 'delete'
    m
    2 replies · 2 participants
  • s

    Siva Balusu

    01/06/2023, 3:46 AM
    I am using Prefect 2.0
  • k

    Khyaati Jindal

    01/06/2023, 10:32 AM
    Hi guys, I am running a huge queue ( 15 tasks) , it runs into this SSLWantReadError Traceback (most recent call last): File "/home/ubuntu/function-triggers/env/lib/python3.10/site-packages/anyio/streams/tls.py", line 130, in _call_sslobject_method result = func(*args) File "/usr/lib/python3.10/ssl.py", line 917, in read v = self._sslobj.read(len) ssl.SSLWantReadError: The operation did not complete (read) (_ssl.c:2548) During handling of the above exception, another exception occurred: Traceback (most recent call last): File "/home/ubuntu/function-triggers/env/lib/python3.10/site-packages/httpcore/backends/asyncio.py", line 33, in read return await self._stream.receive(max_bytes=max_bytes) Traceback (most recent call last): File "/home/ubuntu/function-triggers/env/lib/python3.10/site-packages/httpcore/backends/asyncio.py", line 33, in read return await self._stream.receive(max_bytes=max_bytes) File "/home/ubuntu/function-triggers/env/lib/python3.10/site-packages/anyio/streams/tls.py", line 195, in receive data = await self._call_sslobject_method(self._ssl_object.read, max_bytes) File "/home/ubuntu/function-triggers/env/lib/python3.10/site-packages/anyio/streams/tls.py", line 137, in _call_sslobject_method data = await self.transport_stream.receive() File "/home/ubuntu/function-triggers/env/lib/python3.10/site-packages/anyio/_backends/_asyncio.py", line 1265, in receive await self._protocol.read_event.wait() File "/usr/lib/python3.10/asyncio/locks.py", line 214, in wait await fut asyncio.exceptions.CancelledError During handling of the above exception, another exception occurred: Traceback (most recent call last): File "/home/ubuntu/function-triggers/env/lib/python3.10/site-packages/httpcore/_exceptions.py", line 8, in map_exceptions yield File "/home/ubuntu/function-triggers/env/lib/python3.10/site-packages/httpcore/backends/asyncio.py", line 31, in read with anyio.fail_after(timeout): File "/home/ubuntu/function-triggers/env/lib/python3.10/site-packages/anyio/_core/_tasks.py", line 118, in exit raise TimeoutError TimeoutError During handling of the above exception, another exception occurred:
    Traceback (most recent call last):
  • k

    Khyaati Jindal

    01/06/2023, 10:34 AM
    Hi guys, I am running a huge queue ( 15 tasks) , it runs into this SSLWantReadError
    Traceback (most recent call last):
      File "/home/ubuntu/function-triggers/env/lib/python3.10/site-packages/anyio/streams/tls.py", line 130, in _call_sslobject_method
        result = func(*args)
      File "/usr/lib/python3.10/ssl.py", line 917, in read
        v = self._sslobj.read(len)
    ssl.SSLWantReadError: The operation did not complete (read) (_ssl.c:2548)
    
    During handling of the above exception, another exception occurred:
    
    Traceback (most recent call last):
      File "/home/ubuntu/function-triggers/env/lib/python3.10/site-packages/httpcore/backends/asyncio.py", line 33, in read
        return await self._stream.receive(max_bytes=max_bytes)
    
    Traceback (most recent call last):
      File "/home/ubuntu/function-triggers/env/lib/python3.10/site-packages/httpcore/backends/asyncio.py", line 33, in read
        return await self._stream.receive(max_bytes=max_bytes)
      File "/home/ubuntu/function-triggers/env/lib/python3.10/site-packages/anyio/streams/tls.py", line 195, in receive
        data = await self._call_sslobject_method(self._ssl_object.read, max_bytes)
      File "/home/ubuntu/function-triggers/env/lib/python3.10/site-packages/anyio/streams/tls.py", line 137, in _call_sslobject_method
        data = await self.transport_stream.receive()
      File "/home/ubuntu/function-triggers/env/lib/python3.10/site-packages/anyio/_backends/_asyncio.py", line 1265, in receive
        await self._protocol.read_event.wait()
      File "/usr/lib/python3.10/asyncio/locks.py", line 214, in wait
        await fut
    asyncio.exceptions.CancelledError
    
    During handling of the above exception, another exception occurred:
    
    Traceback (most recent call last):
      File "/home/ubuntu/function-triggers/env/lib/python3.10/site-packages/httpcore/_exceptions.py", line 8, in map_exceptions
        yield
      File "/home/ubuntu/function-triggers/env/lib/python3.10/site-packages/httpcore/backends/asyncio.py", line 31, in read
        with anyio.fail_after(timeout):
      File "/home/ubuntu/function-triggers/env/lib/python3.10/site-packages/anyio/_core/_tasks.py", line 118, in __exit__
        raise TimeoutError
    TimeoutError
    During handling of the above exception, another exception occurred:
    
    Traceback (most recent call last):
    File "/home/ubuntu/functions-triggers/env/lib/python3.10/site-packages/httpcore/_exceptions.py", line 12, in map_exceptions
        raise to_exc(exc)  
    httpcore.ReadTimeout
    Any idea what does this error mean or why is it crashing ?
    c
    m
    +1
    8 replies · 4 participants
  • k

    Khyaati Jindal

    01/06/2023, 11:27 AM
    Can somebody tell me , which space is the this error referring to
    "[Errno 28] No space left on device:
    got this error during the agent run.
    ✅ 1
    j
    c
    47 replies · 3 participants
  • j

    James Zhang

    01/06/2023, 12:54 PM
    hey guys, I’m trying to start multiple deployment runs in a Flow using
    prefect.deployments.run_deployment()
    , is it possible to start these deployment runs concurrently?
    ✅ 1
    b
    b
    13 replies · 3 participants
  • c

    Charalampos Malathounis

    01/06/2023, 2:00 PM
    Hello everyone! Is there a way to run/skip each one of a series of tasks based on a list of True/False statements?
    p
    4 replies · 2 participants
  • d

    David Cheedie

    01/06/2023, 2:20 PM
    hey prefect team, we had a flow crash overnight with a 404 error. using prefect cloud UI and prefect agent is v2.7.4. it has run hundreds of times before with no error like this, and I haven't changed any configuration settings. any ideas on what the cause could be for the bad api URL and how to prevent it in the future?
    httpx.HTTPStatusError: Client error '404 Not Found' for url '<https://api.prefect.cloud/api/accounts/8ff05591-b922-43d6-96e2-0a956c1a55e7/workspaces/c573eb73-711f-42a5-a82d-f11e6defcd82/flow_runs/2c132385-8d43-471c-9dc5-dfad65eb5e41/set_state>'
    
    Encountered exception during execution:
    Traceback (most recent call last):
      File "/home/analytics/miniconda3/envs/prefect_env/lib/python3.10/site-packages/prefect/client/orion.py", line 1564, in set_flow_run_state
        response = await <http://self._client.post|self._client.post>(
      File "/home/analytics/miniconda3/envs/prefect_env/lib/python3.10/site-packages/httpx/_client.py", line 1848, in post
        return await self.request(
      File "/home/analytics/miniconda3/envs/prefect_env/lib/python3.10/site-packages/httpx/_client.py", line 1533, in request
        return await self.send(request, auth=auth, follow_redirects=follow_redirects)
      File "/home/analytics/miniconda3/envs/prefect_env/lib/python3.10/site-packages/prefect/client/base.py", line 251, in send
        response.raise_for_status()
      File "/home/analytics/miniconda3/envs/prefect_env/lib/python3.10/site-packages/httpx/_models.py", line 745, in raise_for_status
        raise HTTPStatusError(message, request=request, response=self)
    httpx.HTTPStatusError: Client error '404 Not Found' for url '<https://api.prefect.cloud/api/accounts/8ff05591-b922-43d6-96e2-0a956c1a55e7/workspaces/c573eb73-711f-42a5-a82d-f11e6defcd82/flow_runs/2c132385-8d43-471c-9dc5-dfad65eb5e41/set_state>'
    For more information check: <https://httpstatuses.com/404>
    
    The above exception was the direct cause of the following exception:
    
    Traceback (most recent call last):
      File "/home/analytics/miniconda3/envs/prefect_env/lib/python3.10/site-packages/prefect/engine.py", line 1574, in report_flow_run_crashes
        yield
      File "/home/analytics/miniconda3/envs/prefect_env/lib/python3.10/site-packages/prefect/engine.py", line 514, in create_and_begin_subflow_run
        terminal_state = await orchestrate_flow_run(
      File "/home/analytics/miniconda3/envs/prefect_env/lib/python3.10/site-packages/prefect/engine.py", line 599, in orchestrate_flow_run
        state = await propose_state(client, Running(), flow_run_id=flow_run.id)
      File "/home/analytics/miniconda3/envs/prefect_env/lib/python3.10/site-packages/prefect/engine.py", line 1741, in propose_state
        response = await client.set_flow_run_state(
      File "/home/analytics/miniconda3/envs/prefect_env/lib/python3.10/site-packages/prefect/client/orion.py", line 1570, in set_flow_run_state
        raise prefect.exceptions.ObjectNotFound(http_exc=e) from e
    prefect.exceptions.ObjectNotFound
    k
    4 replies · 2 participants
  • n

    Nate

    01/06/2023, 3:45 PM
    Hi @Tadej Svetina - apologies that this is unclear, but this page is meant to track relationships between tasks we're currently working on clarifying the purpose of this page! (also see link for an example)
    t
    4 replies · 2 participants
  • j

    Jelle Vegter

    01/06/2023, 3:49 PM
    I use Azure as storage btw
    c
    4 replies · 2 participants
  • n

    Nathan Low

    01/06/2023, 4:56 PM
    Hey All, hope you're all having a great day. Is there any way to name the run of a sub-flow, I really like the cool-names but it would be really helpful for my team-mates to see which dates of a sub-flow failed at a glance by looking at the flow name.
    ✅ 1
    m
    2 replies · 2 participants
  • a

    alex

    01/06/2023, 5:14 PM
    I use a composition pattern to generate multiple flows with different structures based on some configs. With Prefect 1.0 I was able to deploy and run the flows locally but I'm having issues with the LocalStorage with Prefect2.0. Details in thread:
    k
    5 replies · 2 participants
  • a

    Arun Giridharan

    01/06/2023, 6:02 PM
    Is there a way to add a task attribute during runtime? I have a task object created outside of the flow, but I would like to update the task arguments inside of the flow before running it.
    k
    4 replies · 2 participants
  • i

    Ilya Galperin

    01/06/2023, 6:53 PM
    Hello! We had four deployments fail last night with the same error (see below). All four deployments were long-running and had a large number of tasks (3.5k, 3.4k, 1.1k, and 675 respectively). These deployments were part of two different flows with two very different sets of code. One of these flows is running Prefect 2.7.5, the other is running 2.6.7. Our agent is running 2.7.5 and we are using Prefect-hosted Orion. Any insights as to what may have happened?
    prefect.exceptions.MissingResult: State data is missing. Typically, this occurs when result persistence is disabled and the state has been retrieved from the API.
    (full traceback in thread)
    k
    m
    +2
    135 replies · 5 participants
  • b

    Billy McMonagle

    01/06/2023, 9:19 PM
    Hi there, hopefully a quick question about Prefect 2 run context and specifically getting a dict of parameters.
    m
    3 replies · 2 participants
  • c

    Christopher Boyd

    01/06/2023, 9:34 PM
    Hi Guy, Is that the path for your flow ?
    g
    12 replies · 2 participants
  • a

    Agnieszka

    01/06/2023, 9:44 PM
    Hello, Is there a way to catch output stream/`docker logs` from a
    prefect.infrastructure.DockerContainer
    run?
    2 replies · 1 participant
  • k

    Kevin Grismore

    01/06/2023, 10:41 PM
    if you go to the deployments page and click on any deployment, there's a run button in the top right of the page
    :thank-you: 1
    n
    j
    2 replies · 3 participants
  • s

    Siva Balusu

    01/07/2023, 3:16 AM
    Hi I am on prefect 2.0 cloud and my deployment suddenly stopped working with the below error. Deployment pushed the flows to s3 bucket but agent is having issues to get those flows?
    Flow could not be retrieved from deployment.
    Traceback (most recent call last):
      File "/usr/local/lib/python3.10/site-packages/prefect/engine.py", line 260, in retrieve_flow_then_begin_flow_run
        flow = await load_flow_from_flow_run(flow_run, client=client)
      File "/usr/local/lib/python3.10/site-packages/prefect/client/utilities.py", line 47, in with_injected_client
        return await fn(*args, **kwargs)
      File "/usr/local/lib/python3.10/site-packages/prefect/deployments.py", line 167, in load_flow_from_flow_run
        await storage_block.get_directory(from_path=deployment.path, local_path=".")
      File "/usr/local/lib/python3.10/site-packages/prefect/filesystems.py", line 463, in get_directory
        return await self.filesystem.get_directory(
      File "/usr/local/lib/python3.10/site-packages/prefect/filesystems.py", line 308, in get_directory
        return self.filesystem.get(from_path, local_path, recursive=True)
      File "/usr/local/lib/python3.10/site-packages/fsspec/asyn.py", line 113, in wrapper
        return sync(self.loop, func, *args, **kwargs)
      File "/usr/local/lib/python3.10/site-packages/fsspec/asyn.py", line 98, in sync
        raise return_result
      File "/usr/local/lib/python3.10/site-packages/fsspec/asyn.py", line 53, in _runner
        result[0] = await coro
      File "/usr/local/lib/python3.10/site-packages/fsspec/asyn.py", line 551, in _get
        rpaths = await self._expand_path(rpath, recursive=recursive)
      File "/usr/local/lib/python3.10/site-packages/fsspec/asyn.py", line 751, in _expand_path
        out = await self._expand_path([path], recursive, maxdepth)
      File "/usr/local/lib/python3.10/site-packages/fsspec/asyn.py", line 775, in _expand_path
        raise FileNotFoundError(path)
    FileNotFoundError: ['prefect-bucket/prefect_test2']
    [7:10 PM] @here any help is much appreciated [7:10 PM] agent is in kubernetes
    [7:10 PM] I have no name!@prefect-agent-656bfcdc7d-pqjzx:~$ pip list | grep "prefect"
    prefect                    2.7.1
    prefect-aws                0.2.3
    prefect-dask               0.2.2
    prefect-kv                 0.1.0
    prefect-snowflake          0.25
    ✅ 1
    c
    b
    4 replies · 3 participants
  • k

    Khyaati Jindal

    01/07/2023, 5:41 AM
    Hi guys, So there something unexpected happening with my prefect flows. So I deployed my flows last night and agent stopped working around 20:01 UTC and when I opened the screen that was running the agent , the agent came back alive again . The agent is supposed to run flows every half an hour. Look at the time stamps.
    20:01:27.858 | INFO    | Flow run 'lovely-emu' - Created task run 'RAREA12to13-2f7bbdf5-0' for task 'RAREA12to13'
    20:01:27.864 | INFO    | Flow run 'lovely-emu' - Executing 'RAREA12to13-2f7bbdf5-0' immediately...
    20:01:29.858 | INFO    | Task run 'RAREA12to13-2f7bbdf5-0' - Finished in state Completed()
    20:01:30.235 | INFO    | Flow run 'lovely-emu' - Finished in state Completed('All states completed.')
    05:28:05.934 | INFO    | prefect.infrastructure.process - Opening process 'augmented-warthog'...
    05:28:16.139 | INFO    | prefect.infrastructure.process - Process 'quaint-barracuda' exited cleanly.
    05:28:25.094 | INFO    | prefect.infrastructure.process - Process 'benign-myna' exited cleanly.
    05:28:35.179 | INFO    | prefect.infrastructure.process - Process 'pastel-swine' exited cleanly.
    05:28:35.180 | INFO    | prefect.infrastructure.process - Opening process 'helpful-turkey'...
    05:28:35.230 | INFO    | prefect.infrastructure.process - Opening process 'enormous-gecko'...
    05:28:55.267 | INFO    | prefect.infrastructure.process - Process 'lumpy-wallaby' exited cleanly.                                  05:29:13.009 | INFO    | prefect.infrastructure.process - Process 'rigorous-elephant' exited cleanly.
    05:29:31.230 | INFO    | prefect.infrastructure.process - Process 'lovely-emu' exited cleanly.20:01:27.858 | INFO    | Flow run 'lovely-emu' - Created task run 'RAREA12to13-2f7bbdf5-0' for task 'RAREA12to13'
    20:01:27.864 | INFO    | Flow run 'lovely-emu' - Executing 'RAREA12to13-2f7bbdf5-0' immediately...
    20:01:29.858 | INFO    | Task run 'RAREA12to13-2f7bbdf5-0' - Finished in state Completed()
    20:01:30.235 | INFO    | Flow run 'lovely-emu' - Finished in state Completed('All states completed.')
    05:28:05.934 | INFO    | prefect.infrastructure.process - Opening process 'augmented-warthog'...
    05:28:16.139 | INFO    | prefect.infrastructure.process - Process 'quaint-barracuda' exited cleanly.
    05:28:25.094 | INFO    | prefect.infrastructure.process - Process 'benign-myna' exited cleanly.
    05:28:35.179 | INFO    | prefect.infrastructure.process - Process 'pastel-swine' exited cleanly.
    05:28:35.180 | INFO    | prefect.infrastructure.process - Opening process 'helpful-turkey'...
    05:28:35.230 | INFO    | prefect.infrastructure.process - Opening process 'enormous-gecko'...
    05:28:55.267 | INFO    | prefect.infrastructure.process - Process 'lumpy-wallaby' exited cleanly.                                  05:29:13.009 | INFO    | prefect.infrastructure.process - Process 'rigorous-elephant' exited cleanly.
    05:29:31.230 | INFO    | prefect.infrastructure.process - Process 'lovely-emu' exited cleanly.
    Another weird thing about this is , even though I have enabled notifications for these flows from the prefect UI, no notifications were sent for the flow being in 'late' state.
    c
    3 replies · 2 participants
  • s

    Stephen Herron

    01/07/2023, 5:00 PM
    seeing some odd behaviour with prefect 2.7.7 and
    prefect-snowflake
    n
    a
    3 replies · 3 participants
  • y

    YD

    01/07/2023, 8:57 PM
    Having issues deploying on Prefect 2.0
    $ prefect version
    Version:             2.7.7
    API version:         0.8.4
    Python version:      3.8.10
    Git commit:          e8ca30b8
    Built:               Fri, Jan 6, 2023 4:25 PM
    OS/Arch:             linux/aarch64
    Profile:             default
    Server type:         cloud
    Error:
    $ prefect deployment apply run_collect_stocks_data-deployment.yaml
    Successfully loaded 'yquark_deployment'
    Traceback (most recent call last):
      File "/home/youval/.local/lib/python3.8/site-packages/prefect/cli/_utilities.py", line 41, in wrapper
        return fn(*args, **kwargs)
      File "/home/youval/.local/lib/python3.8/site-packages/prefect/utilities/asyncutils.py", line 230, in coroutine_wrapper
        return run_async_in_new_loop(async_fn, *args, **kwargs)
      File "/home/youval/.local/lib/python3.8/site-packages/prefect/utilities/asyncutils.py", line 181, in run_async_in_new_loop
        return anyio.run(partial(__fn, *args, **kwargs))
      File "/home/youval/.local/lib/python3.8/site-packages/anyio/_core/_eventloop.py", line 70, in run
        return asynclib.run(func, *args, **backend_options)
      File "/home/youval/.local/lib/python3.8/site-packages/anyio/_backends/_asyncio.py", line 292, in run
        return native_run(wrapper(), debug=debug)
      File "/usr/lib/python3.8/asyncio/runners.py", line 44, in run
        return loop.run_until_complete(main)
      File "/usr/lib/python3.8/asyncio/base_events.py", line 616, in run_until_complete
        return future.result()
      File "/home/youval/.local/lib/python3.8/site-packages/anyio/_backends/_asyncio.py", line 287, in wrapper
        return await func(*args)
      File "/home/youval/.local/lib/python3.8/site-packages/prefect/cli/deployment.py", line 594, in apply
        deployment_id = await deployment.apply()
      File "/home/youval/.local/lib/python3.8/site-packages/prefect/deployments.py", line 633, in apply
        deployment_id = await client.create_deployment(
      File "/home/youval/.local/lib/python3.8/site-packages/prefect/client/orion.py", line 1313, in create_deployment
        response = await <http://self._client.post|self._client.post>(
      File "/home/youval/.local/lib/python3.8/site-packages/httpx/_client.py", line 1848, in post
        return await self.request(
      File "/home/youval/.local/lib/python3.8/site-packages/httpx/_client.py", line 1533, in request
        return await self.send(request, auth=auth, follow_redirects=follow_redirects)
      File "/home/youval/.local/lib/python3.8/site-packages/prefect/client/base.py", line 251, in send
        response.raise_for_status()
      File "/home/youval/.local/lib/python3.8/site-packages/httpx/_models.py", line 745, in raise_for_status
        raise HTTPStatusError(message, request=request, response=self)
    httpx.HTTPStatusError: Client error '422 Unprocessable Entity' for url '<https://api.prefect.cloud/api/accounts>
    n
    a
    +1
    18 replies · 4 participants
  • y

    YD

    01/08/2023, 2:29 AM
    Are there limitation on the numpy version with Prefect 2.7.6? my numpy version is:
    numpy                      1.24.1
    and I get an error when running:
    $ prefect deployment build ...
    the error is:
    encountered an exception: AttributeError("module 'numpy' has no attribute 'typeDict'")
    ✅ 1
    1 reply · 1 participant
Powered by Linen
Title
y

YD

01/08/2023, 2:29 AM
Are there limitation on the numpy version with Prefect 2.7.6? my numpy version is:
numpy                      1.24.1
and I get an error when running:
$ prefect deployment build ...
the error is:
encountered an exception: AttributeError("module 'numpy' has no attribute 'typeDict'")
✅ 1
doing
$ pip3 install numpy==1.21.1
solve the issue
👍 3
🙌 1
View count: 3