Nideesh
12/26/2024, 4:36 AMMarvin
12/26/2024, 4:36 AMyaml
services:
  prefect:
    image: prefecthq/prefect:3-python3.12
    environment:
      PREFECT_HOME: /data
    command: prefect server start --host 0.0.0.0
    ports:
      - "4200:4200"  # Prefect server UI and API
    volumes:
      - prefect-data:/data  # Persistent storage
      - .:/app  # Mount current directory
volumes:
  prefect-data: {}docker-compose.ymldocker compose updocker-compose up<http://localhost:4200>/appPREFECT_API_URLbash
export PREFECT_API_URL="<http://localhost:4200/api>"Nideesh
12/26/2024, 4:45 AMMarvin
12/26/2024, 4:45 AMbash
pip install prefect-kubernetes prefect-githubyaml
apiVersion: apps/v1
kind: Deployment
metadata:
  name: prefect-worker
spec:
  replicas: 1
  selector:
    matchLabels:
      app: prefect-worker
  template:
    metadata:
      labels:
        app: prefect-worker
    spec:
      containers:
      - name: prefect-worker
        image: prefecthq/prefect:3-python3.12
        command: ["prefect", "worker", "start", "--pool", "your-k8s-pool-name"]
        env:
        - name: PREFECT_API_URL
          value: "YOUR_PREFECT_API_URL"
        - name: PREFECT_API_KEY
          valueFrom:
            secretKeyRef:
              name: prefect-api-key
              key: keypython
from prefect import flow
from prefect.deployments import Deployment
from prefect_github import GitHubRepository
@flow
def your_flow():
    # Your flow code here
    pass
# Configure GitHub repository
github_repo = GitHubRepository(
    repository_url="<https://github.com/your-org/your-repo>",
    reference="main"  # or specific branch/tag
)
# Create deployment
deployment = Deployment.build_from_flow(
    flow=your_flow,
    name="k8s-github-deployment",
    work_pool_name="your-k8s-pool-name",
    storage=github_repo
)
deployment.apply()Nideesh
12/26/2024, 4:47 AMMarvin
12/26/2024, 4:47 AMbash
helm repo add prefect <https://prefecthq.github.io/prefect-helm>
helm repo updatebash
kubectl create namespace prefectvalues.yamlyaml
worker:
  enabled: true
  config:
    workPool:
      name: "your-k8s-pool-name"  # Work pool name from Prefect UI
    prefectApi:
      # For Prefect Cloud
      url: "<https://api.prefect.cloud/api/accounts/{ACCOUNT_ID}/workspaces/{WORKSPACE_ID}>"
      # For self-hosted
      # url: "<http://your-prefect-server:4200/api>"
  # Configure worker resources
  resources:
    requests:
      cpu: "500m"
      memory: "512Mi"
    limits:
      cpu: "1000m"
      memory: "1Gi"
  # Add GitHub credentials as a secret
  extraEnv:
    - name: PREFECT_GITHUB_TOKEN
      valueFrom:
        secretKeyRef:
          name: github-credentials
          key: token
  # If using private container registry
  imagePullSecrets:
    - name: your-registry-secret
# Optional: Configure persistence for work queue data
persistence:
  enabled: true
  size: 10Gibash
kubectl create secret generic prefect-api-key \
  --namespace prefect \
  --from-literal=key=pnu_YOUR_API_KEYbash
kubectl create secret generic github-credentials \
  --namespace prefect \
  --from-literal=token=ghp_YOUR_GITHUB_TOKENbash
helm install prefect prefect/prefect \
  --namespace prefect \
  --values values.yaml \
  --version 2023.XX.XX  # Replace with latest versionpython
from prefect import flow
from prefect.deployments import Deployment
from prefect_github import GitHubRepository
@flow
def your_flow():
    pass
github_repo = GitHubRepository(
    repository_url="<https://github.com/your-org/your-repo>",
    reference="main"
)
deployment = Deployment.build_from_flow(
    flow=your_flow,
    name="k8s-github-deployment",
    work_pool_name="your-k8s-pool-name",
    storage=github_repo
)
deployment.apply()bash
# Upgrade your deployment
helm upgrade prefect prefect/prefect -n prefect --values values.yaml
# Uninstall
helm uninstall prefect -n prefectbash
# Check pods
kubectl get pods -n prefect
# Check logs
kubectl logs -f deployment/prefect-worker -n prefectbash
# Describe pods for issues
kubectl describe pod -l <http://app.kubernetes.io/name=prefect-worker|app.kubernetes.io/name=prefect-worker> -n prefectNideesh
12/26/2024, 4:50 AMMarvin
12/26/2024, 4:50 AMbash
# Using CLI
prefect cloud webhook create \
  --name "my-webhook" \
  --template '{"event": "my-event", "resource": {"deployment_id": "{{ body.deployment_id }}", "parameters": {{ body.parameters }} }}'python
from prefect import flow
from prefect.client.schemas.actions import DeploymentTriggerTypes
@flow
def your_flow(param1: str = "default"):
    print(f"Flow triggered with {param1}")
# Create deployment
deployment = Deployment.build_from_flow(
    flow=your_flow,
    name="webhook-triggered-deployment",
    work_pool_name="your-pool"
)
deployment.apply()bash
curl -X POST <https://api.prefect.cloud/hooks/YOUR_WEBHOOK_ID> \
  -H "Content-Type: application/json" \
  -d '{
    "deployment_id": "your-deployment-id",
    "parameters": {
      "param1": "value1"
    }
  }'Nideesh
12/26/2024, 4:51 AMMarvin
12/26/2024, 4:52 AMpython
from fastapi import FastAPI, HTTPException
from prefect.client import get_client
from prefect.client.schemas import FlowRun
import asyncio
app = FastAPI()
@app.post("/trigger-flow/{deployment_id}")
async def trigger_flow(deployment_id: str, parameters: dict = None):
    async with get_client() as client:
        try:
            # Create a flow run from deployment
            flow_run = await client.create_flow_run_from_deployment(
                deployment_id=deployment_id,
                parameters=parameters
            )
            return {
                "flow_run_id": flow_run.id,
                "status": "created"
            }
        except Exception as e:
            raise HTTPException(status_code=400, detail=str(e))webhook_server.pybash
pip install "fastapi[all]"
uvicorn webhook_server:app --host 0.0.0.0 --port 8000bash
curl -X POST "<http://your-server:8000/trigger-flow/your-deployment-id>" \
  -H "Content-Type: application/json" \
  -d '{"parameter1": "value1"}'python
   from fastapi import Security, Depends
   from fastapi.security import APIKeyHeader
   
   api_key_header = APIKeyHeader(name="X-API-Key")
   
   async def verify_api_key(api_key: str = Security(api_key_header)):
       if api_key != "your-secret-key":
           raise HTTPException(status_code=403)
       return api_key
   
   @app.post("/trigger-flow/{deployment_id}")
   async def trigger_flow(
       deployment_id: str,
       parameters: dict = None,
       api_key: str = Depends(verify_api_key)
   ):
       # ... rest of the codebash
export PREFECT_API_URL="<http://your-prefect-server:4200/api>"python
from prefect.exceptions import ObjectNotFound
@app.post("/trigger-flow/{deployment_id}")
async def trigger_flow(deployment_id: str, parameters: dict = None):
    async with get_client() as client:
        try:
            flow_run = await client.create_flow_run_from_deployment(
                deployment_id=deployment_id,
                parameters=parameters
            )
            return {"flow_run_id": flow_run.id, "status": "created"}
        except ObjectNotFound:
            raise HTTPException(
                status_code=404,
                detail=f"Deployment {deployment_id} not found"
            )
        except Exception as e:
            raise HTTPException(status_code=500, detail=str(e))python
@app.get("/flow-run/{flow_run_id}")
async def get_flow_run_status(flow_run_id: str):
    async with get_client() as client:
        try:
            flow_run = await client.read_flow_run(flow_run_id)
            return {
                "state": flow_run.state.type,
                "state_message": flow_run.state.message
            }
        except Exception as e:
            raise HTTPException(status_code=400, detail=str(e))Nideesh
12/26/2024, 4:52 AMMarvin
12/26/2024, 4:53 AMpython
from prefect import flow
@flow
def my_simple_flow(name: str = "world"):
    print(f"Hello, {name}!")
    return f"Hello, {name}!"
# Run it directly
if __name__ == "__main__":
    my_simple_flow()flow.pybash
python flow.pypython
from prefect import flow, serve
@flow
def my_simple_flow(name: str = "world"):
    print(f"Hello, {name}!")
    return f"Hello, {name}!"
# Serve the flow
if __name__ == "__main__":
    my_simple_flow.serve(name="my-deployment")bash
python flow.pybash
prefect deployment run my-simple-flow/my-deploymentbash
prefect server start<http://localhost:4200>python
my_simple_flow.serve(
    name="my-deployment",
    interval="1h"  # Runs every hour
)bash
prefect deployment run my-simple-flow/my-deployment --params '{"name":"Marvin"}'python
from prefect import flow, serve
@flow
def flow_1():
    print("I'm flow 1!")
@flow
def flow_2():
    print("I'm flow 2!")
if __name__ == "__main__":
    # Serve both flows
    serve(
        flow_1.to_deployment(name="flow-1"),
        flow_2.to_deployment(name="flow-2")
    )Nideesh
12/26/2024, 4:54 AMMarvin
12/26/2024, 4:54 AMflows.pypython
from prefect import flow
from datetime import datetime
@flow
def my_flow(name: str = "world"):
    print(f"Hello {name} at {datetime.utcnow()}")
    return "Success!"
if __name__ == "__main__":
    # For local testing
    my_flow()dockerfile
FROM prefecthq/prefect:3-python3.12
COPY flows.py /opt/prefect/flows.py
# Add any additional dependencies you need
# RUN pip install your-packagesdocker-compose.ymlyaml
services:
  prefect-server:
    image: prefecthq/prefect:3-python3.12
    command: prefect server start --host 0.0.0.0
    ports:
      - "4200:4200"
    volumes:
      - prefect-data:/root/.prefect
      
  flow-runner:
    build: .
    environment:
      - PREFECT_API_URL=<http://prefect-server:4200/api>
    command: python /opt/prefect/flows.py
    depends_on:
      - prefect-server
volumes:
  prefect-data: {}yaml
apiVersion: apps/v1
kind: Deployment
metadata:
  name: prefect-server
spec:
  replicas: 1
  selector:
    matchLabels:
      app: prefect-server
  template:
    metadata:
      labels:
        app: prefect-server
    spec:
      containers:
      - name: prefect-server
        image: prefecthq/prefect:3-python3.12
        command: ["prefect", "server", "start", "--host", "0.0.0.0"]
        ports:
        - containerPort: 4200
---
apiVersion: v1
kind: Service
metadata:
  name: prefect-server
spec:
  selector:
    app: prefect-server
  ports:
  - port: 4200
    targetPort: 4200
---
apiVersion: apps/v1
kind: Deployment
metadata:
  name: flow-runner
spec:
  replicas: 1
  selector:
    matchLabels:
      app: flow-runner
  template:
    metadata:
      labels:
        app: flow-runner
    spec:
      containers:
      - name: flow-runner
        image: your-registry/your-flow-image:tag  # Build and push your Dockerfile
        env:
        - name: PREFECT_API_URL
          value: <http://prefect-server:4200/api>bash
# Start everything
docker compose up --build
# To trigger a flow run manually
curl -X POST <http://localhost:4200/api/deployments/my-flow/my-deployment/create_flow_run>bash
# Build and push your flow image
docker build -t your-registry/your-flow-image:tag .
docker push your-registry/your-flow-image:tag
# Deploy to K8s
kubectl apply -f k8s-deployment.yamlpython
from prefect import flow, serve
@flow
def my_flow(name: str = "world"):
    print(f"Hello {name} at {datetime.utcnow()}")
    return "Success!"
if __name__ == "__main__":
    # Serve with schedule
    my_flow.serve(
        name="my-deployment",
        interval="1h"  # or cron="0 * * * *" for hourly
    )Nideesh
12/26/2024, 4:55 AMMarvin
12/26/2024, 4:56 AMyour-prefect-project/
├── flows/
│   └── main.py
├── Dockerfile
├── docker-compose.yml
├── requirements.txt
└── helm/
    └── prefect/
        ├── Chart.yaml
        ├── values.yaml
        └── templates/
            ├── deployment.yaml
            └── service.yamlpython
from prefect import flow, serve
from datetime import datetime
@flow
def my_flow(name: str = "world"):
    print(f"Hello {name} at {datetime.utcnow()}")
    return "Success!"
if __name__ == "__main__":
    my_flow.serve(
        name="my-deployment",
        interval="1h"  # or remove for manual triggers only
    )dockerfile
FROM prefecthq/prefect:3-python3.12
COPY requirements.txt .
RUN pip install -r requirements.txt
COPY flows /opt/prefect/flows
WORKDIR /opt/prefectdocker-compose.ymlyaml
services:
  prefect-server:
    image: prefecthq/prefect:3-python3.12
    command: prefect server start --host 0.0.0.0
    ports:
      - "4200:4200"
    volumes:
      - prefect-data:/root/.prefect
  flow-runner:
    build: .
    environment:
      - PREFECT_API_URL=<http://prefect-server:4200/api>
    command: python flows/main.py
    depends_on:
      - prefect-server
volumes:
  prefect-data: {}yaml
apiVersion: v2
name: prefect
description: Prefect deployment
version: 0.1.0yaml
prefectServer:
  image: prefecthq/prefect:3-python3.12
  replicas: 1
flowRunner:
  image: your-registry/your-flow-image:tag
  replicas: 1
  github:
    repo: your-org/your-repo
    branch: main
    pat: "" # Will be set via secret
imagePullSecrets: []yaml
apiVersion: apps/v1
kind: Deployment
metadata:
  name: prefect-server
spec:
  replicas: {{ .Values.prefectServer.replicas }}
  selector:
    matchLabels:
      app: prefect-server
  template:
    metadata:
      labels:
        app: prefect-server
    spec:
      containers:
      - name: prefect-server
        image: {{ .Values.prefectServer.image }}
        command: ["prefect", "server", "start", "--host", "0.0.0.0"]
        ports:
        - containerPort: 4200
---
apiVersion: apps/v1
kind: Deployment
metadata:
  name: flow-runner
spec:
  replicas: {{ .Values.flowRunner.replicas }}
  selector:
    matchLabels:
      app: flow-runner
  template:
    metadata:
      labels:
        app: flow-runner
    spec:
      containers:
      - name: flow-runner
        image: {{ .Values.flowRunner.image }}
        env:
        - name: PREFECT_API_URL
          value: <http://prefect-server:4200/api>
        - name: GITHUB_TOKEN
          valueFrom:
            secretKeyRef:
              name: github-credentials
              key: pat.github/workflows/deploy.ymlNideesh
12/26/2024, 4:57 AMMarvin
12/26/2024, 4:57 AMflows/main.pypython
from prefect import flow
@flow
def my_flow(name: str = "world"):
    print(f"Hello {name}!")
    return "Success!"
if __name__ == "__main__":
    my_flow.serve(
        name="my-deployment"
    )yaml
services:
  prefect:
    image: prefecthq/prefect:3-python3.12
    command: prefect server start --host 0.0.0.0
    ports:
      - "4200:4200"
    volumes:
      - prefect-data:/root/.prefect
volumes:
  prefect-data: {}values.yamlyaml
prefect:
  image: prefecthq/prefect:3-python3.12
  tag: latestbash
helm repo add prefect <https://prefecthq.github.io/prefect-helm>
helm install prefect prefect/prefect -f values.yamlpython
from prefect import flow, serve
from prefect.runner import run_flow_from_github
# For local testing
flow_url = "<https://github.com/your-org/your-repo/blob/main/flows/main.py>"
run_flow_from_github(
    flow_url,
    entrypoint="main.py:my_flow",
    parameters={"name": "local"}
)
# For deployment
if __name__ == "__main__":
    my_flow.from_source(
        source="<https://github.com/your-org/your-repo>",
        entrypoint="flows/main.py:my_flow"
    ).serve(
        name="github-flow"
    )bash
# Start Prefect server
docker compose up -d
# Run your flow
python -c "from prefect.runner import run_flow_from_github; run_flow_from_github('<https://github.com/your-org/your-repo/blob/main/flows/main.py>', 'main.py:my_flow')"bash
# Port-forward to access the UI
kubectl port-forward svc/prefect 4200:4200
# Run the same Python command or use the UI to trigger flowsPREFECT_GITHUB_TOKENNideesh
12/26/2024, 4:58 AMMarvin
12/26/2024, 4:59 AMyour-project/
├── flows/
│   └── main.py          # Your flow code
└── k8s/
    └── values.yaml      # Only needed values for Helmpython
from prefect import flow
@flow
def my_flow(name: str = "world"):
    print(f"Hello {name}!")
    return "Success!"
if __name__ == "__main__":
    my_flow.from_source(
        "<https://github.com/your-org/your-repo>",  # Your repo URL
        entrypoint="flows/main.py:my_flow",
    ).serve()yaml
prefect:
  server:
    enabled: true
  env:
    - name: PREFECT_GITHUB_TOKEN
      valueFrom:
        secretKeyRef:
          name: github-creds
          key: tokenbash
# Create GitHub token secret
kubectl create secret generic github-creds --from-literal=token=your_github_token
# Add Prefect helm repo
helm repo add prefect <https://prefecthq.github.io/prefect-helm>
# Install
helm install prefect prefect/prefect -f k8s/values.yamlbash
prefect server start
export PREFECT_GITHUB_TOKEN=your_github_token
python flows/main.pyNideesh
12/26/2024, 5:00 AMMarvin
12/26/2024, 5:00 AM<http://github.com/your-username/your-repo|github.com/your-username/your-repo>python
from prefect import flow
@flow
def my_flow(name: str = "world"):
    print(f"Hello {name}!")
    return "Success!"
if __name__ == "__main__":
    my_flow.from_source(
        "<https://github.com/your-username/your-repo>",  # YOUR REPO HERE
        entrypoint="flows/main.py:my_flow",
    ).serve()bash
git add flows/main.py
git commit -m "add flow"
git pushbash
# Start Prefect server locally
prefect server start
# In a new terminal, run your flow
export PREFECT_GITHUB_TOKEN=your_github_personal_access_token
python flows/main.pybash
# Add Prefect's Helm repo
helm repo add prefect <https://prefecthq.github.io/prefect-helm>
helm repo update
# Create GitHub token secret in K8s
kubectl create secret generic github-creds \
  --from-literal=token=your_github_personal_access_token
# Install Prefect with the secret
helm install prefect prefect/prefect \
  --set "prefect.server.enabled=true" \
  --set "prefect.env[0].name=PREFECT_GITHUB_TOKEN" \
  --set "prefect.env[0].valueFrom.secretKeyRef.name=github-creds" \
  --set "prefect.env[0].valueFrom.secretKeyRef.key=token"
# Access the UI (in a new terminal)
kubectl port-forward svc/prefect 4200:4200your-username/your-repoNideesh
12/26/2024, 5:01 AMMarvin
12/26/2024, 5:01 AMdocker-compose.ymlyaml
services:
  prefect:
    image: prefecthq/prefect:3-python3.12
    command: prefect server start --host 0.0.0.0
    ports:
      - "4200:4200"
    volumes:
      - prefect-data:/root/.prefect
  flow:
    image: prefecthq/prefect:3-python3.12
    environment:
      - PREFECT_API_URL=<http://prefect:4200/api>
      - PREFECT_GITHUB_TOKEN=your_github_token_here  # Replace this
    command: python flows/main.py
    volumes:
      - ./flows:/opt/prefect/flows
    depends_on:
      - prefect
volumes:
  prefect-data: {}flows/main.pypython
from prefect import flow
@flow
def my_flow(name: str = "world"):
    print(f"Hello {name}!")
    return "Success!"
if __name__ == "__main__":
    my_flow.from_source(
        "<https://github.com/your-username/your-repo>",  # YOUR REPO HERE
        entrypoint="flows/main.py:my_flow",
    ).serve()bash
docker compose upyour_github_token_heremain.py.envPREFECT_GITHUB_TOKEN=your_github_token_hereyaml
services:
  prefect:
    image: prefecthq/prefect:3-python3.12
    command: prefect server start --host 0.0.0.0
    ports:
      - "4200:4200"
    volumes:
      - prefect-data:/root/.prefect
  flow:
    image: prefecthq/prefect:3-python3.12
    environment:
      - PREFECT_API_URL=<http://prefect:4200/api>
    env_file:
      - .env
    command: python flows/main.py
    volumes:
      - ./flows:/opt/prefect/flows
    depends_on:
      - prefect
volumes:
  prefect-data: {}bash
docker compose upNideesh
12/26/2024, 5:05 AMMarvin
12/26/2024, 5:05 AMdocker-compose.ymlyaml
services:
  prefect:
    image: prefecthq/prefect:3-python3.12
    command: prefect server start --host 0.0.0.0
    ports:
      - "4200:4200"
    volumes:
      - ./flows:/opt/prefect/flows  # Mount your local flows directory
      - prefect-data:/root/.prefect
volumes:
  prefect-data: {}flows/main.pypython
from prefect import flow
@flow
def my_flow(name: str = "world"):
    print(f"Hello {name}!")
    return "Success!"
if __name__ == "__main__":
    my_flow.serve()  # Simple local servebash
# Add Prefect's helm repo
helm repo add prefect <https://prefecthq.github.io/prefect-helm>
helm repo update
# Create GitHub token secret
kubectl create secret generic github-creds \
  --from-literal=token=your_github_token
# Install Prefect with GitHub sync
helm install prefect prefect/prefect \
  --set "prefect.env[0].name=PREFECT_GITHUB_TOKEN" \
  --set "prefect.env[0].valueFrom.secretKeyRef.name=github-creds" \
  --set "prefect.env[0].valueFrom.secretKeyRef.key=token"flows/k8s_deploy.pypython
from prefect import flow
@flow
def my_flow(name: str = "world"):
    print(f"Hello {name}!")
    return "Success!"
if __name__ == "__main__":
    my_flow.from_source(
        "<https://github.com/your-username/your-repo>",
        entrypoint="flows/main.py:my_flow",
    ).serve()bash
# Start local server and run flows
docker compose up
# Test your flows at <http://localhost:4200>bash
git add flows/
git commit -m "update flows"
git pushk8s_deploy.pyNideesh
12/26/2024, 5:11 AMMarvin
12/26/2024, 5:11 AMbash
# Save as flows/main.py and run
python flows/main.pyyaml
services:
  prefect:
    image: prefecthq/prefect:3-python3.12
    command: prefect server start --host 0.0.0.0
    ports:
      - "4200:4200"
    volumes:
      - ./flows:/opt/prefect/flows
      - prefect-data:/root/.prefect
  flow:
    image: prefecthq/prefect:3-python3.12
    environment:
      - PREFECT_API_URL=<http://prefect:4200/api>
    command: python flows/main.py
    volumes:
      - ./flows:/opt/prefect/flows
    depends_on:
      - prefect
volumes:
  prefect-data: {}bash
docker compose upbash
# CLI
prefect deployment run 'my-flow/my-deployment'
# Or with parameters
prefect deployment run 'my-flow/my-deployment' --params '{"name":"Marvin"}'serve()python
if __name__ == "__main__":
    my_flow.serve(interval=300)  # Runs every 5 minutesNideesh
12/26/2024, 5:13 AMMarvin
12/26/2024, 5:13 AMNideesh
12/26/2024, 5:13 AMMarvin
12/26/2024, 5:13 AMpython
from prefect import flow
@flow
def my_flow(name: str = "world"):
    print(f"Hello {name}!")
    return "Success!"
if __name__ == "__main__":
    my_flow()  # Just call it directly!bash
python flow.pybash
# Change the main block to:
if __name__ == "__main__":
    my_flow(name="Marvin")Nideesh
12/26/2024, 5:15 AMMarvin
12/26/2024, 5:16 AMpython
from prefect import flow, get_run_logger
@flow
def my_flow(name: str = "world"):
    # Get a logger for this flow run
    logger = get_run_logger()
    
    # Use the logger instead of print
    <http://logger.info|logger.info>(f"Hello {name}!")
    return "Success!"
if __name__ == "__main__":
    my_flow()bash
python flow.pyprint()python
@flow
def my_flow(name: str = "world"):
    logger = get_run_logger()
    <http://logger.info|logger.info>(f"Starting flow with name: {name}")
    logger.debug("This is a debug message")
    logger.warning("This is a warning")
    return "Success!"Nideesh
12/26/2024, 5:17 AMMarvin
12/26/2024, 5:17 AMpython
from prefect import flow, task, get_run_logger
@task
def say_hello(name: str) -> str:
    logger = get_run_logger()
    <http://logger.info|logger.info>(f"Saying hello to {name}")
    return f"Hello {name}!"
@task
def make_greeting(message: str) -> str:
    logger = get_run_logger()
    <http://logger.info|logger.info>(f"Making greeting: {message}")
    return f"{message} How are you?"
@flow
def my_flow(name: str = "world"):
    logger = get_run_logger()
    
    # Now we have tasks that will show up in the graph
    hello_msg = say_hello(name)
    greeting = make_greeting(hello_msg)
    
    <http://logger.info|logger.info>(f"Final message: {greeting}")
    return greeting
if __name__ == "__main__":
    my_flow()bash
python flow.pymake_greetingsay_hellopython
from prefect import flow, task, get_run_logger
@task
def say_hello(name: str) -> str:
    logger = get_run_logger()
    <http://logger.info|logger.info>(f"Saying hello to {name}")
    return f"Hello {name}!"
@task
def make_greeting(message: str) -> str:
    logger = get_run_logger()
    <http://logger.info|logger.info>(f"Making greeting: {message}")
    return f"{message} How are you?"
@task
def format_greeting(greeting: str) -> str:
    logger = get_run_logger()
    <http://logger.info|logger.info>("Formatting greeting")
    return f"✨ {greeting} ✨"
@flow
def my_flow(name: str = "world"):
    logger = get_run_logger()
    
    hello_msg = say_hello(name)
    greeting = make_greeting(hello_msg)
    final = format_greeting(greeting)
    
    <http://logger.info|logger.info>(f"Final message: {final}")
    return final
if __name__ == "__main__":
    my_flow()Nideesh
12/26/2024, 5:18 AMMarvin
12/26/2024, 5:18 AMflows/main.pypython
from prefect import flow, task, get_run_logger
from time import sleep  # Adding small delays can help with visualization
@task
def say_hello(name: str) -> str:
    logger = get_run_logger()
    sleep(1)  # Small delay to ensure task execution is visible
    <http://logger.info|logger.info>(f"Saying hello to {name}")
    return f"Hello {name}!"
@task
def make_greeting(message: str) -> str:
    logger = get_run_logger()
    sleep(1)
    <http://logger.info|logger.info>(f"Making greeting: {message}")
    return f"{message} How are you?"
@flow(log_prints=True)  # Enable print logging too
def my_flow(name: str = "world"):
    logger = get_run_logger()
    
    hello_msg = say_hello(name)
    greeting = make_greeting(hello_msg)
    
    <http://logger.info|logger.info>(f"Final message: {greeting}")
    return greetingbash
# Create a new repo on GitHub, then:
git init
git add flows/
git commit -m "initial flow commit"
git branch -M main
git remote add origin <https://github.com/your-username/your-repo.git>
git push -u origin mainbash
# Add Prefect's helm repo
helm repo add prefect <https://prefecthq.github.io/prefect-helm>
helm repo update
# Create GitHub token secret (needed to pull from GitHub)
kubectl create secret generic github-creds \
  --from-literal=token=your_github_personal_access_token
# Install Prefect
helm install prefect prefect/prefect \
  --set "prefect.server.enabled=true" \
  --set "prefect.env[0].name=PREFECT_GITHUB_TOKEN" \
  --set "prefect.env[0].valueFrom.secretKeyRef.name=github-creds" \
  --set "prefect.env[0].valueFrom.secretKeyRef.key=token"flows/k8s_deploy.pypython
from prefect import flow, task, get_run_logger
from time import sleep
@task
def say_hello(name: str) -> str:
    logger = get_run_logger()
    sleep(1)
    <http://logger.info|logger.info>(f"Saying hello to {name}")
    return f"Hello {name}!"
@task
def make_greeting(message: str) -> str:
    logger = get_run_logger()
    sleep(1)
    <http://logger.info|logger.info>(f"Making greeting: {message}")
    return f"{message} How are you?"
@flow(log_prints=True)
def my_flow(name: str = "world"):
    logger = get_run_logger()
    
    hello_msg = say_hello(name)
    greeting = make_greeting(hello_msg)
    
    <http://logger.info|logger.info>(f"Final message: {greeting}")
    return greeting
if __name__ == "__main__":
    my_flow.from_source(
        "<https://github.com/your-username/your-repo>",
        entrypoint="flows/main.py:my_flow",
    ).serve()bash
kubectl port-forward svc/prefect 4200:4200log_prints=Trueyour-username/your-repoNideesh
12/26/2024, 5:21 AMNideesh
12/26/2024, 5:22 AMMarvin
12/26/2024, 5:23 AMpython
from prefect import flow, task, get_run_logger
from time import sleep
@task
def say_hello(name: str) -> str:
    logger = get_run_logger()
    sleep(1)
    <http://logger.info|logger.info>(f"Saying hello to {name}")
    return f"Hello {name}!"
@task
def make_greeting(message: str) -> str:
    logger = get_run_logger()
    sleep(1)
    <http://logger.info|logger.info>(f"Making greeting: {message}")
    return f"{message} How are you?"
@flow(log_prints=True)
def my_flow(name: str = "world"):
    logger = get_run_logger()
    
    hello_msg = say_hello(name)
    greeting = make_greeting(hello_msg)
    
    <http://logger.info|logger.info>(f"Final message: {greeting}")
    return greeting
if __name__ == "__main__":
    # For local development, just run the flow directly
    if not os.getenv("KUBERNETES_SERVICE_HOST"):
        my_flow()
    # In K8s, pull from GitHub
    else:
        my_flow.from_source(
            "<https://github.com/your-username/your-repo>",
            entrypoint="flows/main.py:my_flow",
        ).serve()bash
python flows/main.pybash
git add flows/main.py
git commit -m "update flow"
git pushbash
# Add Prefect's helm repo
helm repo add prefect <https://prefecthq.github.io/prefect-helm>
helm repo update
# Create GitHub token secret
kubectl create secret generic github-creds \
  --from-literal=token=your_github_personal_access_token
# Install Prefect
helm install prefect prefect/prefect \
  --set "prefect.server.enabled=true" \
  --set "prefect.env[0].name=PREFECT_GITHUB_TOKEN" \
  --set "prefect.env[0].valueFrom.secretKeyRef.name=github-creds" \
  --set "prefect.env[0].valueFrom.secretKeyRef.key=token"Nideesh
12/26/2024, 5:24 AMMarvin
12/26/2024, 5:24 AMtxt
pandas
requests
# any other packages you needdockerfile
FROM prefecthq/prefect:3-python3.12
COPY requirements.txt .
RUN pip install -r requirements.txtbash
docker build -t your-registry/prefect-custom:latest .
docker push your-registry/prefect-custom:latestbash
helm upgrade prefect prefect/prefect \
  --set "prefect.image.repository=your-registry/prefect-custom" \
  --set "prefect.image.tag=latest" \
  --set "prefect.env[0].name=PREFECT_GITHUB_TOKEN" \
  --set "prefect.env[0].valueFrom.secretKeyRef.name=github-creds" \
  --set "prefect.env[0].valueFrom.secretKeyRef.key=token"bash
# Create registry secret
kubectl create secret docker-registry regcred \
  --docker-server=your-registry \
  --docker-username=your-username \
  --docker-password=your-password
# Update Helm with registry secret
helm upgrade prefect prefect/prefect \
  --set "prefect.image.repository=your-registry/prefect-custom" \
  --set "prefect.image.tag=latest" \
  --set "prefect.image.pullSecrets[0]=regcred" \
  --set "prefect.env[0].name=PREFECT_GITHUB_TOKEN" \
  --set "prefect.env[0].valueFrom.secretKeyRef.name=github-creds" \
  --set "prefect.env[0].valueFrom.secretKeyRef.key=token"Nideesh
12/26/2024, 5:27 AMMarvin
12/26/2024, 5:27 AM.github/workflows/docker-build.ymlyaml
name: Build and Push Docker Image
on:
  push:
    branches: [ main ]
    paths:
      - 'requirements.txt'
      - 'Dockerfile'
      - '.github/workflows/docker-build.yml'
jobs:
  docker:
    runs-on: ubuntu-latest
    steps:
      - name: Checkout code
        uses: actions/checkout@v3
      - name: Login to Docker Hub  # or your registry
        uses: docker/login-action@v3
        with:
          username: ${{ secrets.DOCKER_USERNAME }}
          password: ${{ secrets.DOCKER_TOKEN }}
          # For GitHub Container Registry, use:
          # registry: <http://ghcr.io|ghcr.io>
          # username: ${{ github.actor }}
          # password: ${{ secrets.GITHUB_TOKEN }}
      - name: Build and push
        uses: docker/build-push-action@v5
        with:
          push: true
          tags: your-username/prefect-custom:latestDOCKER_USERNAMEDOCKER_TOKENbash
helm upgrade prefect prefect/prefect \
  --set "prefect.image.repository=your-username/prefect-custom" \
  --set "prefect.image.tag=latest" \
  --set "prefect.image.pullPolicy=Always" \
  --set "prefect.env[0].name=PREFECT_GITHUB_TOKEN" \
  --set "prefect.env[0].valueFrom.secretKeyRef.name=github-creds" \
  --set "prefect.env[0].valueFrom.secretKeyRef.key=token"requirements.txtpullPolicy=Alwaysyaml
name: Build and Push Docker Image
on:
  push:
    branches: [ main ]
    paths:
      - 'requirements.txt'
      - 'Dockerfile'
      - '.github/workflows/docker-build.yml'
jobs:
  docker:
    runs-on: ubuntu-latest
    permissions:
      contents: read
      packages: write
    steps:
      - name: Checkout code
        uses: actions/checkout@v3
      - name: Login to GitHub Container Registry
        uses: docker/login-action@v3
        with:
          registry: <http://ghcr.io|ghcr.io>
          username: ${{ github.actor }}
          password: ${{ secrets.GITHUB_TOKEN }}
      - name: Build and push
        uses: docker/build-push-action@v5
        with:
          push: true
          tags: <http://ghcr.io/${{|ghcr.io/${{> github.repository_owner }}/prefect-custom:latestbash
helm upgrade prefect prefect/prefect \
  --set "prefect.image.repository=<http://ghcr.io/your-username/prefect-custom|ghcr.io/your-username/prefect-custom>" \
  --set "prefect.image.tag=latest" \
  --set "prefect.image.pullPolicy=Always" \
  --set "prefect.env[0].name=PREFECT_GITHUB_TOKEN" \
  --set "prefect.env[0].valueFrom.secretKeyRef.name=github-creds" \
  --set "prefect.env[0].valueFrom.secretKeyRef.key=token"Nideesh
12/26/2024, 5:30 AMMarvin
12/26/2024, 5:30 AMbash
helm repo add prefect <https://prefecthq.github.io/prefect-helm>
helm repo updatebash
kubectl create secret generic github-creds \
  --from-literal=token=your_github_personal_access_tokenbash
helm install prefect prefect/prefect \
  --set "prefect.server.enabled=true" \
  --set "prefect.env[0].name=PREFECT_GITHUB_TOKEN" \
  --set "prefect.env[0].valueFrom.secretKeyRef.name=github-creds" \
  --set "prefect.env[0].valueFrom.secretKeyRef.key=token"bash
kubectl get pods   # Should see prefect pods running
kubectl get svc    # Should see prefect service
# Access the UI
kubectl port-forward svc/prefect 4200:4200bash
# See the default values
helm show values prefect/prefectyaml
prefect:
  server:
    enabled: true
  env:
    - name: PREFECT_GITHUB_TOKEN
      valueFrom:
        secretKeyRef:
          name: github-creds
          key: tokenbash
helm install prefect prefect/prefect -f values.yamlbash
kubectl logs -l <http://app.kubernetes.io/name=prefect|app.kubernetes.io/name=prefect>Nideesh
12/26/2024, 5:30 AMMarvin
12/26/2024, 5:31 AMfrom_sourcepython
from prefect import flow, task, get_run_logger
from time import sleep
@task
def say_hello(name: str) -> str:
    logger = get_run_logger()
    sleep(1)
    <http://logger.info|logger.info>(f"Saying hello to {name}")
    return f"Hello {name}!"
@task
def make_greeting(message: str) -> str:
    logger = get_run_logger()
    sleep(1)
    <http://logger.info|logger.info>(f"Making greeting: {message}")
    return f"{message} How are you?"
@flow(log_prints=True)
def my_flow(name: str = "world"):
    logger = get_run_logger()
    
    hello_msg = say_hello(name)
    greeting = make_greeting(hello_msg)
    
    <http://logger.info|logger.info>(f"Final message: {greeting}")
    return greeting
if __name__ == "__main__":
    my_flow.from_source(
        source="<https://github.com/your-username/your-repo>",  # YOUR REPO HERE
        entrypoint="flows/main.py:my_flow"
    ).serve()python
from prefect import flow
from prefect.deployments import Deployment
def deploy():
    Deployment.build_from_flow(
        flow_name="my-flow",
        name="k8s-deployment",
        storage={"type": "github", "repository": "<https://github.com/your-username/your-repo>"},
        entrypoint="flows/main.py:my_flow"
    ).apply()
if __name__ == "__main__":
    deploy()bash
# Port-forward to access Prefect API
kubectl port-forward svc/prefect 4200:4200
# In a new terminal, set API URL and run deployment
export PREFECT_API_URL=<http://localhost:4200/api>
python deploy.pybash
prefect deployment run my-flow/k8s-deploymentfrom_sourceNideesh
12/26/2024, 5:33 AMMarvin
12/26/2024, 5:33 AMflows/main.pypython
import os
from prefect import flow, task, get_run_logger
from time import sleep
@task
def say_hello(name: str) -> str:
    logger = get_run_logger()
    sleep(1)
    <http://logger.info|logger.info>(f"Saying hello to {name}")
    return f"Hello {name}!"
@task
def make_greeting(message: str) -> str:
    logger = get_run_logger()
    sleep(1)
    <http://logger.info|logger.info>(f"Making greeting: {message}")
    return f"{message} How are you?"
@flow(log_prints=True)
def my_flow(name: str = "world"):
    logger = get_run_logger()
    
    hello_msg = say_hello(name)
    greeting = make_greeting(hello_msg)
    
    <http://logger.info|logger.info>(f"Final message: {greeting}")
    return greeting
if __name__ == "__main__":
    # If GITHUB_REPO is set, pull from GitHub
    github_repo = os.getenv("GITHUB_REPO")
    if github_repo:
        my_flow.from_source(
            source=f"<https://github.com/{github_repo}>",
            entrypoint="flows/main.py:my_flow"
        ).serve()
    else:
        # Local development
        my_flow()yaml
services:
  prefect:
    image: prefecthq/prefect:3-python3.12
    command: prefect server start --host 0.0.0.0
    ports:
      - "4200:4200"
    volumes:
      - ./flows:/opt/prefect/flows
      - prefect-data:/root/.prefect
  flow:
    image: prefecthq/prefect:3-python3.12
    environment:
      - PREFECT_API_URL=<http://prefect:4200/api>
    command: python flows/main.py
    volumes:
      - ./flows:/opt/prefect/flows
    depends_on:
      - prefect
volumes:
  prefect-data: {}bash
helm install prefect prefect/prefect \
  --set "prefect.server.enabled=true" \
  --set "prefect.env[0].name=PREFECT_GITHUB_TOKEN" \
  --set "prefect.env[0].valueFrom.secretKeyRef.name=github-creds" \
  --set "prefect.env[0].valueFrom.secretKeyRef.key=token" \
  --set "prefect.env[1].name=GITHUB_REPO" \
  --set "prefect.env[1].value=your-username/your-repo"bash
docker compose upbash
# Access UI
kubectl port-forward svc/prefect 4200:4200flows/main.pydocker compose upNideesh
12/27/2024, 7:09 PMMarvin
12/27/2024, 7:10 PMbash
helm repo add prefect <https://prefecthq.github.io/prefect-helm>bash
helm repo updatebash
helm install prefect-worker prefect/prefect-worker \
  --namespace prefect \
  -f values.yamlkubectl create namespace prefectvalues.yamlvalues.yamlNideesh
12/27/2024, 7:15 PMMarvin
12/27/2024, 7:16 PMbash
kubectl create secret generic prefect-api-key \
  --namespace=prefect \
  --from-literal=key=your-prefect-cloud-api-keyvalues.yamlNideesh
12/27/2024, 7:16 PMMarvin
12/27/2024, 7:16 PMbash
helm repo add prefect <https://prefecthq.github.io/prefect-helm>
helm repo update
helm install prefect-server prefect/prefect-server \
  --namespace prefect \
  --create-namespaceyaml
worker:
  config:
    PREFECT_API_URL: "<http://prefect-server:4200/api>"PREFECT_API_URL<http://prefect-server:4200/api>prefect-serverNideesh
12/27/2024, 7:18 PMprefectMarvin
12/27/2024, 7:18 PMvalues.yamlvalues.yamlyaml
# Server configuration
server:
  # Enable persistence for the server database
  database:
    enabled: true
    type: postgresql
    # If using internal PostgreSQL (recommended for simple setups)
    postgresql:
      enabled: true
      persistence:
        enabled: true
        size: 8Gi
    
  # Configure service
  service:
    type: ClusterIP  # Or LoadBalancer if you need external access
  # Resource requests/limits
  resources:
    requests:
      memory: "512Mi"
      cpu: "250m"
    limits:
      memory: "1Gi"
      cpu: "500m"
# UI configuration
ui:
  enabled: true
  service:
    type: ClusterIP  # Or LoadBalancer if you need external access
    
# If you're behind a reverse proxy/ingress, set the external URL
# ui:
#   apiUrl: "<https://your-prefect-domain.com/api>"
# Configure ingress if needed
# ingress:
#   enabled: true
#   className: nginx
#   hosts:
#     - host: <http://prefect.your-domain.com|prefect.your-domain.com>
#       paths:
#         - path: /
#           pathType: PrefixClusterIPLoadBalancerbash
helm install prefect-server prefect/prefect-server \
  --namespace prefect \
  -f values.yamlyaml
postgresql:
  primary:
    persistence:
      storageClass: "your-storage-class"  # Specify your storage class
  auth:
    postgresPassword: "your-secure-password"  # Please use a proper secret management solutionyaml
server:
  database:
    postgresql:
      enabled: false
    secret:
      create: true
      url: "<postgresql://user:password@external-db:5432/prefect>"Nideesh
12/27/2024, 7:19 PMMarvin
12/27/2024, 7:20 PMyaml
server:
  database:
    enabled: true
    type: postgresql
    postgresql:
      enabled: true  # This will auto-deploy PostgreSQL in your prefect namespace
      persistence:
        enabled: true
        size: 8Gi
        # storageClass: "your-storage-class"  # Uncomment if you have a specific storage class
  
  # Configure server service for MetalLB
  service:
    type: LoadBalancer
    port: 4200
    annotations: {}
    # Add any MetalLB-specific annotations if needed
    # annotations:
    #   <http://metallb.universe.tf/address-pool|metallb.universe.tf/address-pool>: default
ui:
  enabled: true
  # Configure UI service for MetalLB
  service:
    type: LoadBalancer
    port: 4200
    annotations: {}
# PostgreSQL configuration (these are the sub-chart settings)
postgresql:
  primary:
    persistence:
      enabled: true
      size: 8Gi
  auth:
    username: prefect
    database: prefect
    # It's recommended to set your own password
    password: "prefect-pass"  # Please change this!postgresql.enabled: trueprefectprefect-server-postgresql-0LoadBalancerbash
     kubectl get svc -n prefectbash
helm install prefect-server prefect/prefect-server \
  --namespace prefect \
  -f values.yamlNideesh
12/27/2024, 7:23 PMMarvin
12/27/2024, 7:23 PMvalues.yamlyaml
server:
  # Previous database and service config remains the same...
  # Environment variables for the server
  env:
    - name: PREFECT_UI_API_URL
      value: "<http://your-external-ip:4200/api>"  # Replace with your MetalLB IP
    # Add any other server-specific env vars here
# Worker configuration (this is where most env vars will go)
worker:
  enabled: true  # Enable worker alongside server
  env:
    # GitHub-related variables
    - name: GITHUB_TOKEN
      valueFrom:
        secretKeyRef:
          name: github-secret
          key: token
    - name: GITHUB_REPOSITORY
      value: "your-org/your-repo"
    # Add other environment variables as needed
    - name: PYTHONPATH
      value: "/opt/prefect/flows"
    # Add any custom environment variables
    - name: CUSTOM_VAR
      value: "custom-value"
  # Optional: Mount additional volumes for your flows
  volumes:
    - name: flow-storage
      persistentVolumeClaim:
        claimName: flow-storage-pvc
  volumeMounts:
    - name: flow-storage
      mountPath: /opt/prefect/flows
# Previous PostgreSQL and UI config remains the same...bash
kubectl create secret generic github-secret \
  --namespace prefect \
  --from-literal=token='your-github-token'yaml
worker:
  env:
    # Git access
    - name: GITHUB_TOKEN
      valueFrom:
        secretKeyRef:
          name: github-secret
          key: token
    - name: GITHUB_REPOSITORY
      value: "your-org/your-repo"
    
    # Python/Flow configuration
    - name: PYTHONPATH
      value: "/opt/prefect/flows"
    - name: PREFECT_LOGGING_LEVEL
      value: "INFO"
    
    # Custom dependencies
    - name: POETRY_VERSION
      value: "1.4.2"
    - name: PIP_INDEX_URL
      value: "<https://your-private-pypi/simple>"bash
# Create secrets for sensitive data
kubectl create secret generic prefect-secrets \
  --namespace prefect \
  --from-literal=aws-key='your-aws-key' \
  --from-literal=aws-secret='your-aws-secret'yaml
worker:
  env:
    - name: AWS_ACCESS_KEY_ID
      valueFrom:
        secretKeyRef:
          name: prefect-secrets
          key: aws-keyNideesh
12/27/2024, 7:27 PMNideesh
12/27/2024, 7:30 PMMarvin
12/27/2024, 7:30 PMyaml
# Combined values.yaml for Prefect server and worker
server:
  database:
    enabled: true
    type: postgresql
    postgresql:
      enabled: true
      persistence:
        enabled: true
        size: 8Gi
  service:
    type: LoadBalancer  # For MetalLB
    port: 4200
  # Server resources
  resources:
    requests:
      memory: "512Mi"
      cpu: "250m"
    limits:
      memory: "1Gi"
      cpu: "500m"
  # Server-specific environment variables
  env:
    - name: PREFECT_UI_API_URL
      value: "<http://your-external-ip:4200/api>"  # Replace with your MetalLB IP when you get it
# PostgreSQL configuration (sub-chart settings)
postgresql:
  primary:
    persistence:
      enabled: true
      size: 8Gi
  auth:
    username: prefect
    database: prefect
    password: "change-me-please"  # Please change this!
# UI configuration
ui:
  enabled: true
  service:
    type: LoadBalancer  # For MetalLB
    port: 4200
# Worker configuration
worker:
  enabled: true  # Enable worker alongside server
  
  # Worker resources
  resources:
    requests:
      memory: "512Mi"
      cpu: "250m"
    limits:
      memory: "1Gi"
      cpu: "500m"
  # Worker environment variables
  env:
    # GitHub configuration
    - name: GITHUB_TOKEN
      valueFrom:
        secretKeyRef:
          name: github-secret
          key: token
    - name: GITHUB_REPOSITORY
      value: "your-org/your-repo"  # Replace with your repo
    
    # Python configuration
    - name: PYTHONPATH
      value: "/opt/prefect/flows"
    - name: PREFECT_LOGGING_LEVEL
      value: "INFO"
    
    # Prefect configuration
    - name: PREFECT_API_URL
      value: "<http://prefect-server:4200/api>"
    - name: PREFECT_SERVER_API_HOST
      value: "0.0.0.0"
    - name: PREFECT_SERVER_API_PORT
      value: "4200"
  # Optional: Worker storage configuration
  volumes:
    - name: flow-storage
      persistentVolumeClaim:
        claimName: flow-storage-pvc  # You'll need to create this PVC if you want to use it
  volumeMounts:
    - name: flow-storage
      mountPath: /opt/prefect/flows
# Security context
securityContext:
  runAsUser: 1000
  runAsGroup: 1000
  fsGroup: 1000
# Service account configuration
serviceAccount:
  create: true
  annotations: {}bash
kubectl create secret generic github-secret \
  --namespace prefect \
  --from-literal=token='your-github-token'yaml
# flow-storage-pvc.yaml
apiVersion: v1
kind: PersistentVolumeClaim
metadata:
  name: flow-storage-pvc
  namespace: prefect
spec:
  accessModes:
    - ReadWriteOnce
  resources:
    requests:
      storage: 10Gibash
# Apply the PVC if you're using it
kubectl apply -f flow-storage-pvc.yaml
# Install Prefect with the combined configuration
helm install prefect-server prefect/prefect-server \
  --namespace prefect \
  -f values.yamlNideesh
12/27/2024, 7:32 PMMarvin
12/27/2024, 7:32 PMyaml
# Combined values.yaml for Prefect server and worker
server:
  database:
    enabled: true
    type: postgresql
    postgresql:
      enabled: true
      persistence:
        enabled: true
        size: 8Gi
  service:
    type: LoadBalancer  # For MetalLB
    port: 4200
  resources:
    requests:
      memory: "512Mi"
      cpu: "250m"
    limits:
      memory: "1Gi"
      cpu: "500m"
  env:
    - name: PREFECT_UI_API_URL
      value: "<http://your-external-ip:4200/api>"  # You'll replace this with MetalLB IP
postgresql:
  primary:
    persistence:
      enabled: true
      size: 8Gi
  auth:
    username: prefect
    database: prefect
    password: "prefect-pass"  # Please change this in production
ui:
  enabled: true
  service:
    type: LoadBalancer
    port: 4200
worker:
  enabled: true
  
  resources:
    requests:
      memory: "512Mi"
      cpu: "250m"
    limits:
      memory: "1Gi"
      cpu: "500m"
  env:
    # GitHub specific configuration for your repo
    - name: GITHUB_TOKEN
      valueFrom:
        secretKeyRef:
          name: github-secret
          key: token
    - name: GITHUB_REPOSITORY
      value: "Nideesh1/AI_ORCHESTRATION"
    
    # Python/Prefect configuration
    - name: PYTHONPATH
      value: "/opt/prefect/flows"
    - name: PREFECT_LOGGING_LEVEL
      value: "INFO"
    - name: PREFECT_API_URL
      value: "<http://prefect-server:4200/api>"
    - name: PREFECT_SERVER_API_HOST
      value: "0.0.0.0"
    - name: PREFECT_SERVER_API_PORT
      value: "4200"
  # Storage for flows
  volumes:
    - name: flow-storage
      persistentVolumeClaim:
        claimName: flow-storage-pvc
  volumeMounts:
    - name: flow-storage
      mountPath: /opt/prefect/flows
securityContext:
  runAsUser: 1000
  runAsGroup: 1000
  fsGroup: 1000
serviceAccount:
  create: true
  annotations: {}your-github-tokenbash
kubectl create secret generic github-secret \
  --namespace prefect \
  --from-literal=token='your-github-token'yaml
# flow-storage-pvc.yaml
apiVersion: v1
kind: PersistentVolumeClaim
metadata:
  name: flow-storage-pvc
  namespace: prefect
spec:
  accessModes:
    - ReadWriteOnce
  resources:
    requests:
      storage: 10Gibash
# Create the PVC
kubectl apply -f flow-storage-pvc.yaml
# Install Prefect
helm install prefect-server prefect/prefect-server \
  --namespace prefect \
  -f values.yamlbash
kubectl get svc -n prefectPREFECT_UI_API_URLbash
helm upgrade prefect-server prefect/prefect-server \
  --namespace prefect \
  -f values.yamlNideesh
12/27/2024, 7:36 PMMarvin
12/27/2024, 7:36 PMyaml
# Combined values.yaml for Prefect server and worker
server:
  database:
    enabled: true
    type: postgresql
    postgresql:
      enabled: true
      persistence:
        enabled: true
        size: 8Gi
  service:
    type: LoadBalancer
    port: 4200
    loadBalancerIP: "192.168.10.38"
    annotations:
      <http://metallb.universe.tf/allow-shared-ip|metallb.universe.tf/allow-shared-ip>: "true"
  resources:
    requests:
      memory: "512Mi"
      cpu: "250m"
    limits:
      memory: "1Gi"
      cpu: "500m"
  env:
    - name: PREFECT_UI_API_URL
      value: "<http://192.168.10.38:4200/api>"
postgresql:
  primary:
    persistence:
      enabled: true
      size: 8Gi
  auth:
    username: prefect
    database: prefect
    password: "prefect-pass"  # Change this in production
ui:
  enabled: true
  service:
    type: LoadBalancer
    port: 4200
    loadBalancerIP: "192.168.10.38"
    annotations:
      <http://metallb.universe.tf/allow-shared-ip|metallb.universe.tf/allow-shared-ip>: "true"
worker:
  enabled: true
  
  resources:
    requests:
      memory: "512Mi"
      cpu: "250m"
    limits:
      memory: "1Gi"
      cpu: "500m"
  env:
    # GitHub configuration
    - name: GITHUB_TOKEN
      valueFrom:
        secretKeyRef:
          name: github-secret
          key: token
    - name: GITHUB_REPOSITORY
      value: "Nideesh1/AI_ORCHESTRATION"
    
    # Python/Prefect configuration
    - name: PYTHONPATH
      value: "/opt/prefect/flows"
    - name: PREFECT_LOGGING_LEVEL
      value: "INFO"
    - name: PREFECT_API_URL
      value: "<http://192.168.10.38:4200/api>"
    - name: PREFECT_SERVER_API_HOST
      value: "0.0.0.0"
    - name: PREFECT_SERVER_API_PORT
      value: "4200"
  # Storage for flows
  volumes:
    - name: flow-storage
      persistentVolumeClaim:
        claimName: flow-storage-pvc
  volumeMounts:
    - name: flow-storage
      mountPath: /opt/prefect/flows
securityContext:
  runAsUser: 1000
  runAsGroup: 1000
  fsGroup: 1000
serviceAccount:
  create: true
  annotations: {}loadBalancerIP: "192.168.10.38"bash
kubectl create secret generic github-secret \
  --namespace prefect \
  --from-literal=token='your-github-token'yaml
# flow-storage-pvc.yaml
apiVersion: v1
kind: PersistentVolumeClaim
metadata:
  name: flow-storage-pvc
  namespace: prefect
spec:
  accessModes:
    - ReadWriteOnce
  resources:
    requests:
      storage: 10Gibash
# Create the PVC
kubectl apply -f flow-storage-pvc.yaml
# Install Prefect
helm install prefect-server prefect/prefect-server \
  --namespace prefect \
  -f values.yamlNideesh
12/27/2024, 7:37 PMMarvin
12/27/2024, 7:38 PMyaml
# Combined values.yaml for Prefect server and worker
server:
  database:
    enabled: true
    type: postgresql
    postgresql:
      enabled: true
      persistence:
        enabled: true
        size: 8Gi
        storageClass: "longhorn"  # Longhorn storage class
  service:
    type: LoadBalancer
    port: 4200
    loadBalancerIP: "192.168.10.38"
    annotations:
      <http://metallb.universe.tf/allow-shared-ip|metallb.universe.tf/allow-shared-ip>: "true"
  resources:
    requests:
      memory: "512Mi"
      cpu: "250m"
    limits:
      memory: "1Gi"
      cpu: "500m"
  env:
    - name: PREFECT_UI_API_URL
      value: "<http://192.168.10.38:4200/api>"
postgresql:
  primary:
    persistence:
      enabled: true
      size: 8Gi
      storageClass: "longhorn"  # Longhorn storage class
  auth:
    username: prefect
    database: prefect
    password: "prefect-pass"  # Change this in production
ui:
  enabled: true
  service:
    type: LoadBalancer
    port: 4200
    loadBalancerIP: "192.168.10.38"
    annotations:
      <http://metallb.universe.tf/allow-shared-ip|metallb.universe.tf/allow-shared-ip>: "true"
worker:
  enabled: true
  
  resources:
    requests:
      memory: "512Mi"
      cpu: "250m"
    limits:
      memory: "1Gi"
      cpu: "500m"
  env:
    # GitHub configuration - token directly in env var
    - name: GITHUB_TOKEN
      value: "your-github-token-here"  # Replace with your actual token
    - name: GITHUB_REPOSITORY
      value: "Nideesh1/AI_ORCHESTRATION"
    
    # Python/Prefect configuration
    - name: PYTHONPATH
      value: "/opt/prefect/flows"
    - name: PREFECT_LOGGING_LEVEL
      value: "INFO"
    - name: PREFECT_API_URL
      value: "<http://192.168.10.38:4200/api>"
    - name: PREFECT_SERVER_API_HOST
      value: "0.0.0.0"
    - name: PREFECT_SERVER_API_PORT
      value: "4200"
  # Storage for flows using Longhorn
  volumes:
    - name: flow-storage
      persistentVolumeClaim:
        claimName: prefect-flow-storage  # This will be auto-created
  volumeMounts:
    - name: flow-storage
      mountPath: /opt/prefect/flows
  # Add PVC template for Longhorn
  persistence:
    enabled: true
    storageClass: "longhorn"
    size: 10Gi
    accessModes:
      - ReadWriteOnce
    annotations:
      <http://longhorn.io/backup|longhorn.io/backup>: "true"  # Optional: enables Longhorn backup feature
securityContext:
  runAsUser: 1000
  runAsGroup: 1000
  fsGroup: 1000
serviceAccount:
  create: true
  annotations: {}bash
helm install prefect-server prefect/prefect-server \
  --namespace prefect \
  -f values.yamlyour-github-token-hereNideesh
01/02/2025, 4:16 AMMarvin
01/02/2025, 4:16 AMCrashLoopBackOffdb-upgradedb-upgradebash
   kubectl logs pod/prefect-server-graphql-7b88f5464c-dc9rn -c db-upgradedb-upgradedb-upgradeprefecthq/server:2022.09.23Nideesh
01/04/2025, 11:29 AMMarvin
01/04/2025, 11:29 AM<http://localhost:4200/graphql><http://localhost:4200/graphqlRequest>values.yamlNideesh
01/04/2025, 11:33 AMMarvin
01/04/2025, 11:33 AMprefect server startprefect server startNideesh
01/04/2025, 11:34 AMMarvin
01/04/2025, 11:34 AMprefect-server-graphql-846b76b5f8-blm96prefecthq/serverprefect-server-graphqlbash
   kubectl logs prefect-server-graphql-846b76b5f8-blm96bash
   kubectl describe pod prefect-server-graphql-846b76b5f8-blm96bash
   kubectl port-forward pod/prefect-server-graphql-846b76b5f8-blm96 4200:4200<http://localhost:4200/graphql>prefect-server-graphqlNideesh
01/04/2025, 11:35 AMMarvin
01/04/2025, 11:35 AMprefecthq/apolloprefect-server-apollobash
   kubectl logs prefect-server-apollo-57c4788c5-wcsl5bash
   kubectl describe pod prefect-server-apollo-57c4788c5-wcsl5prefect-server-apolloNideesh
01/04/2025, 11:37 AMMarvin
01/04/2025, 11:37 AMdocker-compose.ymlvalues.yamlNideesh
01/04/2025, 11:38 AMMarvin
01/04/2025, 11:38 AMDockerfiledockerfile
     FROM python:3.9
     RUN pip install prefect
     COPY . /app
     WORKDIR /app
     # Install additional dependencies if neededvalues.yamlNideesh
01/04/2025, 11:38 AMMarvin
01/04/2025, 11:39 AMprefect.registerNideesh
01/04/2025, 11:41 AMMarvin
01/04/2025, 11:41 AMDockerfiledockerfile
     FROM python:3.9
     WORKDIR /app
     COPY . .
     RUN pip install prefect
     # Install additional dependencies if neededvalues.yamlbash
  helm upgrade [release_name] [chart_path] --values values.yamlprefect.registerpython
    from prefect import flow
    from my_flows import my_flow  # Import your flow
    if __name__ == "__main__":
        my_flow.register(project_name="my_project")Nideesh
01/04/2025, 11:41 AMMarvin
01/04/2025, 11:42 AMvalues.yamlpython
  from prefect import flow
  from prefect.filesystems import GitHub
  github_block = GitHub.load("my-github-repo")  # Ensure this block is configured in your Prefect account
  @flow
  def my_flow():
      print("Hello from GitHub!")
  if __name__ == "__main__":
      my_flow.with_options(storage=github_block).register(project_name="my_project")Nideesh
01/04/2025, 11:42 AMMarvin
01/04/2025, 11:42 AMpython
   from prefect import flow
   from prefect.filesystems import GitHub
   github_block = GitHub(repository="your-username/your-repo")  # Replace with your GitHub repo
   @flow
   def my_flow():
       print("Hello from GitHub!")
   if __name__ == "__main__":
       my_flow.with_options(storage=github_block).register(project_name="my_project")bash
  prefect deployment build my_flow.py:my_flow -n "My Flow" -sb github/my-github-block
  prefect deployment apply my_flow-deployment.yamlNideesh
01/04/2025, 11:44 AMMarvin
01/04/2025, 11:44 AMprefect deployment buildprefect deployment applybash
     prefect deployment build my_flow.py:my_flow -n "My Flow" -sb github/my-github-block
     prefect deployment apply my_flow-deployment.yamlNideesh
01/04/2025, 11:46 AMMarvin
01/04/2025, 11:46 AMdocker-compose.ymldocker-compose.ymldocker-compose uphelm installNideesh
01/04/2025, 11:47 AMMarvin
01/04/2025, 11:47 AMpython
   from prefect import flow
   @flow
   def my_flow():
       print("Hello, Prefect!")
   if __name__ == "__main__":
       my_flow()bash
     pip install prefectbash
   prefect deployment build my_flow.py:my_flow -n "My Flow" -sb github/my-github-block
   prefect deployment apply my_flow-deployment.yamlNideesh
01/04/2025, 11:48 AMMarvin
01/04/2025, 11:48 AMdockerfile
     FROM python:3.9
     WORKDIR /app
     COPY . .
     RUN pip install prefectyaml
     apiVersion: batch/v1
     kind: Job
     metadata:
       name: prefect-flow-register
     spec:
       template:
         spec:
           containers:
           - name: flow-register
             image: your-registry/your-image:latest
             command: ["python", "-c", "from my_flow import my_flow; my_flow.register(project_name='my_project')"]
           restartPolicy: Never
       backoffLimit: 4bash
     kubectl apply -f prefect-flow-register-job.yamlNideesh
01/04/2025, 11:49 AMMarvin
01/04/2025, 11:49 AMpython
   from prefect import flow
   from prefect.filesystems import GitHub
   github_block = GitHub.load("your-github-block-name")  # Ensure this block is configured in your Prefect account
   @flow
   def my_flow():
       print("Hello from GitHub!")
   if __name__ == "__main__":
       my_flow.with_options(storage=github_block).register(project_name="my_project")Nideesh
01/04/2025, 11:49 AMMarvin
01/04/2025, 11:49 AMpython
     from prefect import flow
     from prefect.filesystems import GitHub
     github_block = GitHub.load("your-github-block-name")  # Replace with your block's name
     @flow
     def my_flow():
         print("Hello from GitHub!")
     if __name__ == "__main__":
         my_flow.with_options(storage=github_block).register(project_name="my_project")Nideesh
01/04/2025, 11:53 AMMarvin
01/04/2025, 11:53 AMNideesh
01/04/2025, 11:53 AMMarvin
01/04/2025, 11:53 AMbash
     prefect versionkubectlbash
     kubectl exec -it <prefect-pod-name> -- prefect versionvalues.yamlNideesh
01/04/2025, 11:54 AMMarvin
01/04/2025, 11:54 AMbash
   helm repo add prefecthq <https://prefecthq.github.io/prefect-helm>
   helm repo updatebash
     helm search repo prefecthq/prefect-server --versionshelm upgrade[release_name][chart_version]bash
     helm upgrade [release_name] prefecthq/prefect-server --namespace [your-namespace] --version [chart_version]bash
     kubectl get pods -n [your-namespace]bash
     kubectl exec -it [prefect-pod-name] -- prefect versionNideesh
01/04/2025, 11:57 AMMarvin
01/04/2025, 11:57 AMrelease_nameprefectbash
     helm list --namespace prefectrelease_namemy-prefect-releasebash
helm upgrade my-prefect-release prefecthq/prefect-server --namespace prefect --version 2025.1.2233807my-prefect-release2025.1.2233807helm search repo prefecthq/prefect-server --versionsNideesh
01/04/2025, 11:57 AMMarvin
01/04/2025, 11:57 AMrelease_nameprefectbash
     helm list --namespace prefectrelease_nameprefect-serverdata-orchestrationprefectbash
  helm install my-prefect-release prefecthq/prefect-server --namespace prefectbash
  helm upgrade my-prefect-release prefecthq/prefect-server --namespace prefect --version 2025.1.2233807my-prefect-releaseNideesh
01/04/2025, 11:58 AMMarvin
01/04/2025, 11:58 AMdatabaseservicevalues.yamlvalues.yamldatabaseservicevalues.yamlvalues.yamldatabaseservicehelm templatebash
     helm template my-prefect-release prefecthq/prefect-server --namespace prefect --version 2025.1.2233807 -f values.yamlvalues.yamlyaml
# Example of a simplified values.yaml
server:
  # Remove or update any unsupported properties here
  # e.g., remove database and service if they're not part of the schema
  image:
    repository: prefecthq/prefect-server
    tag: "2025.1.2233807"values.yamlNideesh
01/04/2025, 12:00 PMMarvin
01/04/2025, 12:00 PMvalues.yamlvalues.yamlyaml
server:
  image:
    repository: prefecthq/prefect-server
    tag: "latest"  # Ensure you replace this with the correct version if needed
  service:
    type: LoadBalancer
    loadBalancerIP: "192.168.10.38"
  storage:
    # Assuming Longhorn is set up as a default StorageClass
    persistentVolume:
      storageClass: longhorn
      size: 10Gi
agent:
  enabled: true
  image:
    repository: prefecthq/prefect-agent
    tag: "latest"
  # Configure agent settings as needed
  config:
    PREFECT_API_URL: "<http://prefect-server:4200>"  # Adjust if necessary
# Additional configurations for other components can be added herebash
   kubectl create namespace prefectbash
   helm repo add prefecthq <https://prefecthq.github.io/prefect-helm>
   helm repo updatebash
   helm install prefect-server prefecthq/prefect-server --namespace prefect -f values.yamlstorageClassloadBalancerIPNideesh
01/04/2025, 12:08 PMMarvin
01/04/2025, 12:08 PMservicestorageservervalues.yamlbash
     helm show values prefecthq/prefect-server --version [your-chart-version]values.yamlservicestorageyaml
server:
  image:
    repository: prefecthq/prefect-server
    tag: "latest"  # Ensure this is the correct version
  # Other server configurations go here
agent:
  enabled: true
  image:
    repository: prefecthq/prefect-agent
    tag: "latest"
  # Configure agent settings as needed
  config:
    PREFECT_API_URL: "<http://prefect-server:4200>"  # Adjust if necessary
# Service and storage configurations might need to be set elsewhere or differentlyServicevalues.yamlNideesh
01/04/2025, 12:13 PMMarvin
01/04/2025, 12:13 PMImagePullBackOffprefecthq/prefect-server:3.1.9-python3.11bash
     docker pull prefecthq/prefect-server:3.1.9-python3.11bash
     kubectl describe pod [pod-name] -n [namespace]values.yamlbash
     helm upgrade prefect-server prefecthq/prefect-server --namespace prefect -f values.yamlImagePullBackOffNideesh
01/04/2025, 12:18 PMMarvin
01/04/2025, 12:18 PMvalues.yamlvalues.yamlyaml
server:
  image:
    repository: prefecthq/prefect-server
    tag: "3.1.9"  # Use a valid tag without specifying Python version
agent:
  enabled: true
  image:
    repository: prefecthq/prefect-agent
    tag: "3.1.9"  # Ensure this matches the server version
  config:
    PREFECT_API_URL: "<http://prefect-server:4200>"  # Adjust if necessarybash
     helm upgrade prefect-server prefecthq/prefect-server --namespace prefect -f values.yamlbash
     kubectl get pods -n prefectImagePullBackOffNideesh
01/04/2025, 12:23 PMMarvin
01/04/2025, 12:23 PMprefecthq/prefect-serveryaml
     server:
       image:
         repository: prefecthq/prefect-server
         tag: "3.1.9"  # Replace with the latest stable version if neededprefecthq/prefect-agentyaml
     agent:
       enabled: true
       image:
         repository: prefecthq/prefect-agent
         tag: "3.1.9"  # Replace with the latest stable version if neededvalues.yamlvalues.yamlvalues.yamlbash
     helm upgrade prefect-server prefecthq/prefect-server --namespace prefect -f values.yamlbash
     kubectl get pods -n prefectNideesh
01/04/2025, 12:24 PMMarvin
01/04/2025, 12:24 PMvalues.yamlNideesh
01/04/2025, 12:25 PMMarvin
01/04/2025, 12:25 PMvalues.yamlprefecthq/prefect:3-python3.12values.yamlyaml
server:
  image:
    repository: prefecthq/prefect
    tag: "3-python3.12"
  service:
    type: LoadBalancer
    loadBalancerIP: "192.168.10.38"  # Adjust based on your MetalLB configuration
  # Add any additional server configurations here
agent:
  enabled: true
  image:
    repository: prefecthq/prefect
    tag: "3-python3.12"
  config:
    PREFECT_API_URL: "<http://prefect-server:4200>"  # Adjust if necessary
  # Add any additional agent configurations herebash
   kubectl create namespace prefectbash
   helm repo add prefecthq <https://prefecthq.github.io/prefect-helm>
   helm repo updatebash
   helm install prefect-server prefecthq/prefect-server --namespace prefect -f values.yamlloadBalancerIPLoadBalancerprefecthq/prefect:3-python3.12Nideesh
01/04/2025, 12:25 PMMarvin
01/04/2025, 12:25 PMvalues.yamlprefecthq/prefectvalues.yamlyaml
server:
  image:
    repository: prefecthq/prefect
    tag: "latest"  # Use the latest tag or specify a specific version if needed
  service:
    type: LoadBalancer
    loadBalancerIP: "192.168.10.38"  # Ensure this is within your MetalLB IP range
agent:
  enabled: true
  image:
    repository: prefecthq/prefect
    tag: "latest"  # Use the latest tag or specify a specific version if needed
  config:
    PREFECT_API_URL: "<http://prefect-server:4200>"  # Adjust based on your setupbash
   kubectl create namespace prefectbash
   helm repo add prefecthq <https://prefecthq.github.io/prefect-helm>
   helm repo updatebash
   helm install prefect-server prefecthq/prefect-server --namespace prefect -f values.yamlloadBalancerIPLoadBalancerlatestNideesh
01/04/2025, 12:26 PMMarvin
01/04/2025, 12:26 PMvalues.yamlserviceprefecthq/prefectvalues.yamlyaml
server:
  image:
    repository: prefecthq/prefect
    tag: "latest"  # Specify a specific version if needed
agent:
  enabled: true
  image:
    repository: prefecthq/prefect
    tag: "latest"  # Specify a specific version if needed
  config:
    PREFECT_API_URL: "<http://prefect-server:4200>"  # Adjust based on your setupbash
   kubectl create namespace prefectbash
   helm repo add prefecthq <https://prefecthq.github.io/prefect-helm>
   helm repo updatebash
   helm install prefect-server prefecthq/prefect-server --namespace prefect -f values.yamllatestPREFECT_API_URLNideesh
01/04/2025, 12:39 PMMarvin
01/04/2025, 12:39 PMvalues.yamlvalues.yamlyaml
server:
  image:
    repository: prefecthq/prefect
    tag: "latest"  # Use the latest tag or specify a specific version if needed
  service:
    type: LoadBalancer
    loadBalancerIP: "192.168.10.38"  # Ensure this IP is within your MetalLB IP range
agent:
  enabled: true
  image:
    repository: prefecthq/prefect
    tag: "latest"  # Use the latest tag or specify a specific version if needed
  config:
    PREFECT_API_URL: "<http://prefect-server:4200>"  # Adjust based on your setupbash
   kubectl create namespace prefectbash
   helm repo add prefecthq <https://prefecthq.github.io/prefect-helm>
   helm repo updatebash
   helm install prefect-server prefecthq/prefect-server --namespace prefect -f values.yamlloadBalancerIPLoadBalancerPREFECT_API_URLvalues.yamlNideesh
01/04/2025, 12:40 PMMarvin
01/04/2025, 12:40 PMvalues.yamlvalues.yamlbash
   helm install prefect-server prefecthq/prefect-server --namespace prefect -f values.yamlLoadBalancerbash
   kubectl patch svc prefect-server -n prefect -p '{"spec": {"type": "LoadBalancer", "loadBalancerIP": "192.168.10.38"}}'LoadBalancerNideesh
01/04/2025, 12:40 PMMarvin
01/04/2025, 12:40 PMhelm templatebash
   helm template prefect-server prefecthq/prefect-server --namespace prefect -f values.yaml > prefect-deployment.yamlprefect-deployment.yamlServiceLoadBalanceryaml
   apiVersion: v1
   kind: Service
   metadata:
     name: prefect-server
     namespace: prefect
   spec:
     type: LoadBalancer
     loadBalancerIP: "192.168.10.38"
     ports:
       - port: 4200
         targetPort: 4200
     selector:
       app: prefect-serverbash
   kubectl apply -f prefect-deployment.yamlLoadBalancerNideesh
01/04/2025, 12:41 PMMarvin
01/04/2025, 12:41 PMvalues.yamlkubectl editbash
     kubectl get svc -n prefectkubectl editbash
     kubectl edit svc [service-name] -n prefect[service-name]specLoadBalanceryaml
   spec:
     type: LoadBalancer
     loadBalancerIP: "192.168.10.38"
     ports:
       - port: 4200
         targetPort: 4200
     selector:
       app: prefect-servervalues.yamlNideesh
01/04/2025, 12:50 PMMarvin
01/04/2025, 12:50 PMNideesh
01/04/2025, 12:50 PMMarvin
01/04/2025, 12:50 PMprefect-server-service.yamlyaml
apiVersion: v1
kind: Service
metadata:
  name: prefect-server
  namespace: prefect
spec:
  type: LoadBalancer
  loadBalancerIP: "192.168.10.38"  # Ensure this IP is within your MetalLB IP range
  ports:
    - port: 4200
      targetPort: 4200
  selector:
    app: prefect-serverkubectlbash
   kubectl apply -f prefect-server-service.yamlbash
   kubectl get svc -n prefectLoadBalancerselectorNideesh
01/06/2025, 2:15 AMMarvin
01/06/2025, 2:15 AMNideesh
01/06/2025, 4:27 AMMarvin
01/06/2025, 4:28 AMhelm upgradehelm upgradehelm upgradeprefectbash
     helm list --namespace prefectbash
     helm upgrade [release-name] prefecthq/prefect-server --namespace prefect -f values.yaml[release-name]prefect-serverbash
helm upgrade prefect-server prefecthq/prefect-server --namespace prefect -f values.yamlprefecthq/prefect-serverNideesh
01/06/2025, 5:05 AMMarvin
01/06/2025, 5:06 AMI have no name!/etc/passwdPREFECT_API_URLlocalhostI have no name!/etc/passwdPREFECT_API_URLPREFECT_API_URLPREFECT_API_URLvalues.yamlyaml
     agent:
       config:
         PREFECT_API_URL: "<http://your-external-ip:4200>"bash
     helm upgrade prefect-server prefecthq/prefect-server --namespace prefect -f values.yamlPREFECT_API_URLI have no name!Nideesh
01/06/2025, 5:13 AMMarvin
01/06/2025, 5:13 AMI have no name!I have no name!/etc/passwdPREFECT_API_URLPREFECT_API_URLPREFECT_API_URLPREFECT_API_URLvalues.yamlyaml
agent:
  enabled: true
  image:
    repository: prefecthq/prefect
    tag: "latest"
  config:
    PREFECT_API_URL: "<http://192.168.10.38:4200>"  # Replace with your actual external IPbash
     helm upgrade prefect-server prefecthq/prefect-server --namespace prefect -f values.yamlbash
     kubectl logs [pod-name] -n prefectbash
    kubectl exec -it [pod-name] -n prefect -- printenv | grep PREFECT_API_URLNideesh
01/06/2025, 5:14 AMMarvin
01/06/2025, 5:15 AMLoadBalanceryaml
apiVersion: v1
kind: Service
metadata:
  name: prefect-server
  namespace: prefect
spec:
  type: LoadBalancer
  loadBalancerIP: "192.168.10.38"  # Ensure this IP is within your MetalLB range
  ports:
    - port: 4200
      targetPort: 4200
  selector:
    app: prefect-serverprefect-server-service.yamlbash
  kubectl apply -f prefect-server-service.yamlbash
  kubectl get svc -n prefectLoadBalancervalues.yamlvalues.yamlbash
  helm upgrade prefect-server prefecthq/prefect-server --namespace prefect -f values.yamlNideesh
01/06/2025, 5:15 AMMarvin
01/06/2025, 5:15 AMLoadBalancer192.168.10.38LoadBalancerbash
     kubectl get svc prefect-server -n prefect -o yamlspec.typeLoadBalancerloadBalancerIPkubectl describebash
     kubectl describe svc prefect-server -n prefectbash
     kubectl logs -l app=metallb -n metallb-systembash
     kubectl edit svc prefect-server -n prefectloadBalancerIPyaml
apiVersion: v1
kind: Service
metadata:
  name: prefect-server
  namespace: prefect
spec:
  type: LoadBalancer
  loadBalancerIP: "192.168.10.38"
  ports:
    - port: 4200
      targetPort: 4200
  selector:
    app: prefect-serverNideesh
01/08/2025, 6:34 AMMarvin
01/08/2025, 6:34 AMconfigvalues.yamlconfigprefect initprefect.yamlNideesh
01/08/2025, 6:36 AMMarvin
01/08/2025, 6:36 AMbash
   helm repo add prefect <https://prefecthq.github.io/prefect-helm>
   helm repo updatebash
   kubectl create namespace prefectyour-prefect-cloud-api-keybash
   kubectl create secret generic prefect-api-key \
   --namespace=prefect --from-literal=key=your-prefect-cloud-api-keyvalues.yamlyaml
   worker:
     image:
       repository: prefecthq/prefect
       tag: 3.0.0
     env:
       PREFECT_API_URL: "<https://api.prefect.io>"
       PREFECT_API_KEY: "<Your API Key>"
     resources:
       limits:
         cpu: "500m"
         memory: "512Mi"
       requests:
         cpu: "250m"
         memory: "256Mi"bash
   helm install prefect-worker prefect/prefect-worker \
     --namespace prefect \
     -f values.yamlNideesh
01/08/2025, 6:40 AMMarvin
01/08/2025, 6:40 AMPREFECT_API_KEYbash
   helm repo add prefect <https://prefecthq.github.io/prefect-helm>
   helm repo updatebash
   kubectl create namespace prefectvalues.yamlyaml
   server:
     image:
       repository: prefecthq/prefect-server
       tag: 3.0.0
     resources:
       limits:
         cpu: "500m"
         memory: "512Mi"
       requests:
         cpu: "250m"
         memory: "256Mi"bash
   helm install prefect-server prefect/prefect-server \
     --namespace prefect \
     -f values.yamlvalues.yamlNideesh
01/08/2025, 6:41 AMNideesh
01/08/2025, 6:41 AMMarvin
01/08/2025, 6:41 AMservicevalues.yamlvalues.yamlservicetypeLoadBalancerexternalIPsyaml
   server:
     service:
       type: LoadBalancer
       externalIPs:
         - <Your-External-IP><Your-External-IP>values.yamlbash
   helm upgrade prefect-server prefect/prefect-server \
     --namespace prefect \
     -f values.yamlNideesh
01/08/2025, 6:42 AMMarvin
01/08/2025, 6:42 AMvalues.yamlyaml
server:
  image:
    repository: prefecthq/prefect-server
    tag: 3.0.0
  resources:
    limits:
      cpu: "500m"
      memory: "512Mi"
    requests:
      cpu: "250m"
      memory: "256Mi"
  service:
    type: LoadBalancer
    externalIPs:
      - <Your-External-IP>  # Replace with your actual external IP
worker:
  image:
    repository: prefecthq/prefect
    tag: 3.0.0
  env:
    PREFECT_API_URL: "http://<Your-External-IP>:4200"  # Point to your Prefect server
  resources:
    limits:
      cpu: "500m"
      memory: "512Mi"
    requests:
      cpu: "250m"
      memory: "256Mi"<Your-External-IP>Nideesh
01/08/2025, 6:44 AMMarvin
01/08/2025, 6:45 AMserviceservervalues.yamlyaml
service:
  type: LoadBalancer
  externalIPs:
    - <Your-External-IP>  # Replace with your actual external IP
server:
  image:
    repository: prefecthq/prefect-server
    tag: 3.0.0
  resources:
    limits:
      cpu: "500m"
      memory: "512Mi"
    requests:
      cpu: "250m"
      memory: "256Mi"
worker:
  image:
    repository: prefecthq/prefect
    tag: 3.0.0
  env:
    PREFECT_API_URL: "http://<Your-External-IP>:4200"  # Point to your Prefect server
  resources:
    limits:
      cpu: "500m"
      memory: "512Mi"
    requests:
      cpu: "250m"
      memory: "256Mi"servicevalues.yamlPREFECT_API_URLNideesh
01/08/2025, 6:46 AMMarvin
01/08/2025, 6:47 AMexternalIPsserviceyaml
   server:
     service:
       type: LoadBalancer
       annotations:
         <http://service.beta.kubernetes.io/aws-load-balancer-eip-allocations|service.beta.kubernetes.io/aws-load-balancer-eip-allocations>: "eipalloc-0123456789abcdef0"
       loadBalancerIP: <Your-External-IP>  # Use this if your provider supports it<Your-External-IP>loadBalancerIPNideesh
01/08/2025, 6:47 AMMarvin
01/08/2025, 6:48 AMloadBalancerIPvalues.yamlyaml
   server:
     service:
       type: LoadBalancerNideesh
01/08/2025, 6:48 AMMarvin
01/08/2025, 6:48 AMvalues.yamlyaml
server:
  image:
    repository: prefecthq/prefect-server
    tag: 3.0.0
  resources:
    limits:
      cpu: "500m"
      memory: "512Mi"
    requests:
      cpu: "250m"
      memory: "256Mi"
  service:
    type: LoadBalancer
worker:
  image:
    repository: prefecthq/prefect
    tag: 3.0.0
  env:
    PREFECT_API_URL: "http://<Automatically-Assigned-IP>:4200"  # Update this after deployment
  resources:
    limits:
      cpu: "500m"
      memory: "512Mi"
    requests:
      cpu: "250m"
      memory: "256Mi"bash
   helm upgrade --install prefect-server prefecthq/prefect-server \
     --namespace prefect \
     -f values.yamlbash
   kubectl get services -n prefectPREFECT_API_URLNideesh
01/08/2025, 6:49 AMMarvin
01/08/2025, 6:49 AMvalues.yamlyaml
server:
  image:
    repository: prefecthq/prefect-server
    tag: 3.0.0
  service:
    type: LoadBalancer
worker:
  image:
    repository: prefecthq/prefect
    tag: 3.0.0
  env:
    PREFECT_API_URL: "http://<Automatically-Assigned-IP>:4200"  # Update this after deploymentbash
   helm upgrade --install prefect-server prefecthq/prefect-server \
     --namespace prefect \
     -f values.yamlbash
   kubectl get services -n prefectPREFECT_API_URLNideesh
01/08/2025, 6:50 AMMarvin
01/08/2025, 6:50 AMserviceservervalues.yamlserviceyaml
server:
  image:
    repository: prefecthq/prefect-server
worker:
  image:
    repository: prefecthq/prefect
  env:
    PREFECT_API_URL: "http://<Automatically-Assigned-IP>:4200"  # Update this after deploymentbash
   helm upgrade --install prefect-server prefecthq/prefect-server \
     --namespace prefect \
     -f values.yamlkubectl editbash
   kubectl get services -n prefectPREFECT_API_URLNideesh
01/08/2025, 7:12 AMMarvin
01/08/2025, 7:12 AMrequirements.txtbash
   python3 -m venv prefect-env
   source prefect-env/bin/activatebash
   pip install prefectpiprequirements.txtbash
   pip install -r requirements.txtbash
   prefect server startrequirements.txtNideesh
01/08/2025, 7:12 AMMarvin
01/08/2025, 7:13 AMrequirements.txtDockerfiledockerfile
   FROM prefecthq/prefect:latest
   COPY requirements.txt .
   RUN pip install --no-cache-dir -r requirements.txtbash
   docker build -t your-registry/prefect-custom:latest .
   docker push your-registry/prefect-custom:latestvalues.yamlvalues.yamlyaml
   server:
     image:
       repository: your-registry/prefect-custom
       tag: latest
   worker:
     image:
       repository: your-registry/prefect-custom
       tag: latestbash
   helm upgrade --install prefect-server prefecthq/prefect-server \
     --namespace prefect \
     -f values.yamlNideesh
01/08/2025, 7:14 AMMarvin
01/08/2025, 7:14 AMprefect-githubprefect-githubbash
   pip install -U prefect-githubprefect-githubbash
   prefect block register -m prefect_githubpython
   from prefect_github import GitHubCredentials
   github_credentials = GitHubCredentials(
       access_token="your_github_access_token"
   )
   github_credentials.save(name="my-github-creds", overwrite=True)prefect.yamlprefect.yamlyaml
   pull:
     - prefect_github.GitHubCredentials:
         name: my-github-creds
         repository: "your-repo-name"
         branch: "main"Nideesh
01/08/2025, 7:15 AMMarvin
01/08/2025, 7:15 AMpython
   from prefect_github import GitHubCredentials
   # Create GitHub credentials block
   github_credentials = GitHubCredentials(
       access_token="your_github_access_token"
   )
   
   # Save the credentials block for later use
   github_credentials.save(name="my-github-creds", overwrite=True)python
   from prefect.deployments import Deployment
   from prefect_github import GitHubCredentials
   # Load the GitHub credentials block
   github_credentials = GitHubCredentials.load("my-github-creds")
   # Create a deployment with the GitHub credentials
   deployment = Deployment.build_from_flow(
       flow=my_flow_function,  # replace with your flow function
       name="my-github-deployment",
       parameters={"param1": "value1"},  # replace with actual parameters
       pull=[
           {
               "prefect_github.GitHubCredentials": {
                   "name": "my-github-creds",
                   "repository": "your-repo-name",
                   "branch": "main"
               }
           }
       ]
   )
   # Apply the deployment
   deployment.apply()Nideesh
01/08/2025, 7:19 AMMarvin
01/08/2025, 7:19 AMbash
   python3 -m venv prefect-env
   source prefect-env/bin/activate
   pip install -U prefectPREFECT_API_URLbash
   prefect config set PREFECT_API_URL=http://<Your-Prefect-Server-IP>:4200/apipython
   from prefect import flow, task
   @task
   def say_hello():
       print("Hello, world!")
   @flow
   def hello_flow():
       say_hello()
   if __name__ == "__main__":
       hello_flow()bash
   prefect deployment build -n hello-flow-deployment hello_flow.py:hello_flow
   prefect deployment apply hello_flow-deployment.yamlbash
   prefect deployment run hello-flow-deploymentPREFECT_API_URLNideesh
01/08/2025, 7:26 AMMarvin
01/08/2025, 7:26 AMprefect-githubbash
     pip install -U prefect-githubbash
     prefect block register -m prefect_githubNideesh
01/08/2025, 7:28 AMMarvin
01/08/2025, 7:28 AMpython
   from prefect_github import GitHubCredentials
   # Register GitHub credentials block
   github_credentials = GitHubCredentials(
       access_token="your_github_access_token"
   )
   github_credentials.save(name="my-github-creds", overwrite=True)
   # Register other blocks as neededNideesh
01/08/2025, 7:29 AMMarvin
01/08/2025, 7:29 AMprefect-githubbash
   pip install -U prefect-githubbash
   prefect block register -m prefect_githubpython
from prefect_github import GitHubCredentials
# Create and register GitHub credentials block
github_credentials = GitHubCredentials(
    access_token="your_github_access_token"
)
github_credentials.save(name="my-github-creds", overwrite=True)Nideesh
01/08/2025, 7:29 AMMarvin
01/08/2025, 7:29 AMBring your towel and join one of the fastest growing data communities. Welcome to our second-generation open source orchestration platform, a completely rethought approach to dataflow automation.
Powered by