# KV Store Cloud

Looking for the latest Prefect 2 release? Prefect 2 and Prefect Cloud 2 have been released for General Availability. See https://docs.prefect.io/ for details.

Key Value Store is a managed metadata database for Prefect Cloud.

Keys are strings. Values are JSON blobs.

The number of key value pairs allowed is limited by license, starting with 10 pairs on the Free tier. Values are limited to 10 KB in size.

Key value pairs can be configured via the Prefect CLI, Python library, API, and UI.

# UI

You can view, update, and delete key value pairs on the KV Store page of the UI.

# Setting key value pairs

Setting a key value pair will overwrite the existing value if the key exists.

# Getting the value of a key

# Deleting key value pairs

# Listing keys

# Using key value pairs in flows

To interact with the KV Store from a flow, call the Prefect Core library functions in a task.

For example, let's say we wanted to track the last date a flow has been executed and pick up from that date.

from datetime import datetime, timedelta
import prefect
from prefect import task, Flow
from prefect.backend import set_key_value, get_key_value

LAST_EXECUTED_KEY = 'my-flow-last-executed'

@task
def get_last_execution_date():
    last_executed = get_key_value(LAST_EXECUTED_KEY)
    return datetime.strptime(last_executed, "%Y-%m-%d")

@task
def run_etl(start_date):
    logger = prefect.context.get("logger")
    while start_date <= datetime.today():
        logger.info(f"Running ETL for date {start_date.strftime('%Y-%m-%d')}")
        # do some etl
        start_date += timedelta(days=1)
    return start_date.strftime('%Y-%m-%d')

@task
def set_last_execution_date(date):
    set_key_value(key=LAST_EXECUTED_KEY, value=date)

with Flow('my-flow') as flow:
    last_executed_date = get_last_execution_date()
    final_execution_date = run_etl(last_executed_date)
    set_last_execution_date(final_execution_date)