this all works fine for sequentialtaskrunner. However it does not seem to format the output for dask or ray. Output I get and test code is below. What am I missing?
[I know there is a known issue which prevents it showing on orion but here I am talking about console output.]
sequential
11:15:29.331 | WARNING | Task run 'testtask-3dde1f43-0' - warning hi
11:15:29.333 | WARNING | root - warning std root log
11:15:29.335 | WARNING | test1 - warning extra log
dask
warning hi
warning std root log
warning extra log
ray
(begin_task_run pid=6347) warning hi
(begin_task_run pid=6347) warning std root log
(begin_task_run pid=6347) warning extra log
import os
os.environ.update(
PREFECT_ORION_DATABASE_CONNECTION_TIMEOUT="60.0",
PREFECT_LOGGING_EXTRA_LOGGERS="test1",
PREFECT_API_URL="http://127.0.0.1:4200/api",
)
from prefect.flows import flow
from prefect.tasks import task
from prefect_dask.task_runners import DaskTaskRunner as runner
# from prefect.task_runners import SequentialTaskRunner as runner
# from prefect_ray.task_runners import RayTaskRunner as runner
from prefect import get_run_logger
import logging
@flow(task_runner=runner())
def testflow():
testtask()
@task
def testtask():
log = get_run_logger()
log.warning("warning hi")
log.debug("debug hi")
log = logging.getLogger()
log.warning("warning std root log")
log.debug("debug std root log")
log = logging.getLogger("test1")
log.warning("warning extra log")
log.debug("debug extra log")
if __name__ == "__main__":
testflow()