Compare commits
13 Commits
2b4e34ec2f
...
67a7e2dacf
| Author | SHA1 | Date | |
|---|---|---|---|
| 67a7e2dacf | |||
| fc6f120c53 | |||
| 55e8b31223 | |||
| 1d9bd68612 | |||
| e0cda85d20 | |||
| da55030498 | |||
| 316fe03be9 | |||
| bf537c86a4 | |||
| d2e34bca1c | |||
| 65593e5421 | |||
| 4242638818 | |||
| 4593b97bc2 | |||
| a0a0bbd110 |
11
apps/backup/Dockerfile
Normal file
11
apps/backup/Dockerfile
Normal file
@@ -0,0 +1,11 @@
|
||||
FROM dagster-code-backup-base
|
||||
|
||||
RUN apt-get update \
|
||||
&& apt-get install --no-install-recommends --yes \
|
||||
borgbackup openssh-client \
|
||||
&& apt-get clean \
|
||||
&& rm -rf /var/lib/apt/lists/*
|
||||
|
||||
RUN mkdir -p /root/.ssh && chmod 0700 /root/.ssh/
|
||||
COPY --chmod=0600 id_rsa /root/.ssh/
|
||||
ADD --chmod=0600 ssh_config /root/.ssh/config
|
||||
146
apps/backup/src/assets.py
Normal file
146
apps/backup/src/assets.py
Normal file
@@ -0,0 +1,146 @@
|
||||
import json
|
||||
import os
|
||||
import subprocess
|
||||
import sys
|
||||
from datetime import datetime
|
||||
from functools import partial
|
||||
from zoneinfo import ZoneInfo
|
||||
|
||||
import structlog
|
||||
from config import APP, BORG_HOST, BORG_ROOT
|
||||
from partitions import borg_repo_partitions_def, daily_partitions_def
|
||||
from shared.utils import get_partition_keys
|
||||
|
||||
import dagster as dg
|
||||
|
||||
asset = partial(dg.asset, key_prefix=APP)
|
||||
logger = structlog.get_logger()
|
||||
|
||||
|
||||
@asset(
|
||||
partitions_def=dg.MultiPartitionsDefinition(
|
||||
{
|
||||
"date": daily_partitions_def,
|
||||
"repo": borg_repo_partitions_def,
|
||||
}
|
||||
)
|
||||
)
|
||||
def borg_archive(context: dg.AssetExecutionContext) -> None:
|
||||
pass
|
||||
|
||||
|
||||
@asset(
|
||||
deps=[borg_archive],
|
||||
partitions_def=dg.MultiPartitionsDefinition(
|
||||
{
|
||||
"date": daily_partitions_def,
|
||||
"repo": borg_repo_partitions_def,
|
||||
}
|
||||
),
|
||||
automation_condition=dg.AutomationCondition.eager(),
|
||||
)
|
||||
def borg_archive_info(context: dg.AssetExecutionContext) -> dg.Output[None]:
|
||||
partition_keys = get_partition_keys(context)
|
||||
ic(partition_keys)
|
||||
|
||||
location = f"ssh://{BORG_HOST}{BORG_ROOT}{partition_keys['repo']}::{partition_keys['date']}"
|
||||
ic(location)
|
||||
try:
|
||||
result = subprocess.run(
|
||||
["borg", "info", "--json", location],
|
||||
capture_output=True,
|
||||
text=True,
|
||||
check=True,
|
||||
env={"BORG_UNKNOWN_UNENCRYPTED_REPO_ACCESS_IS_OK": "yes"},
|
||||
)
|
||||
except subprocess.CalledProcessError as e:
|
||||
logger.error("borg list failed", exc_info=e, code=e.returncode)
|
||||
sys.stderr.write("borg list failed\n" + e.stderr)
|
||||
data = json.loads(result.stdout)
|
||||
ic(data)
|
||||
tmp = data["archives"][0]
|
||||
|
||||
def parse_date(date_str, tz: str | None = None) -> dg.MetadataValue.timestamp:
|
||||
return dg.MetadataValue.timestamp(
|
||||
datetime.fromisoformat(date_str).replace(
|
||||
tzinfo=ZoneInfo(tz or os.environ.get("TZ", "CET"))
|
||||
)
|
||||
)
|
||||
|
||||
return dg.Output(
|
||||
None,
|
||||
metadata={
|
||||
"start": parse_date(tmp["start"]),
|
||||
"end": parse_date(tmp["end"]),
|
||||
"duration": dg.MetadataValue.float(tmp["duration"]),
|
||||
"compressed_size": dg.MetadataValue.int(tmp["stats"]["compressed_size"]),
|
||||
"deduplicated_size": dg.MetadataValue.int(
|
||||
tmp["stats"]["deduplicated_size"]
|
||||
),
|
||||
"nfiles": dg.MetadataValue.int(tmp["stats"]["nfiles"]),
|
||||
"original_size": dg.MetadataValue.int(tmp["stats"]["original_size"]),
|
||||
},
|
||||
)
|
||||
|
||||
# now run borg info ssh://shuttle/mnt/yotta/xenon/borg/opt/::2025-07-27 --json and register info
|
||||
|
||||
|
||||
@asset(
|
||||
partitions_def=borg_repo_partitions_def,
|
||||
)
|
||||
def borg_repo(context: dg.AssetExecutionContext) -> None:
|
||||
location = f"ssh://{BORG_HOST}{BORG_ROOT}{context.partition_key}"
|
||||
ic(location)
|
||||
repo = context.partition_key
|
||||
|
||||
# Get Borg backup list
|
||||
try:
|
||||
result = subprocess.run(
|
||||
["borg", "list", "--json", location],
|
||||
capture_output=True,
|
||||
text=True,
|
||||
check=True,
|
||||
env={"BORG_UNKNOWN_UNENCRYPTED_REPO_ACCESS_IS_OK": "yes"},
|
||||
)
|
||||
except subprocess.CalledProcessError as e:
|
||||
logger.error("borg list failed", exc_info=e, code=e.returncode)
|
||||
sys.stderr.write("borg list failed\n" + e.stderr)
|
||||
data = json.loads(result.stdout)
|
||||
ic(data)
|
||||
|
||||
for entry in data.get("archives", []):
|
||||
partition = f"{entry['archive']}|{repo}"
|
||||
context.log_event(
|
||||
dg.AssetMaterialization(
|
||||
asset_key=borg_archive.key,
|
||||
partition=partition,
|
||||
metadata={
|
||||
"id": dg.MetadataValue.text(entry["id"]),
|
||||
},
|
||||
)
|
||||
)
|
||||
# context.
|
||||
|
||||
# snapshots = data.get("archives", [])
|
||||
#
|
||||
# # Find latest backup for this day
|
||||
# match = next(
|
||||
# (s for s in reversed(snapshots)
|
||||
# if datetime.fromisoformat(s["end"]).date() == expected_date),
|
||||
# None
|
||||
# )
|
||||
#
|
||||
# if match:
|
||||
# context.log_event(
|
||||
# dg.AssetMaterialization(
|
||||
# asset_key=one.key, partition="2025-07-27"
|
||||
# ) # this works!
|
||||
# )
|
||||
#
|
||||
# return {
|
||||
# "name": match["name"],
|
||||
# "end": match["end"],
|
||||
# "size": match.get("size", 0)
|
||||
# }
|
||||
# else:
|
||||
# raise Exception(f"No backup found for {expected_date}")
|
||||
7
apps/backup/src/config.py
Normal file
7
apps/backup/src/config.py
Normal file
@@ -0,0 +1,7 @@
|
||||
import os
|
||||
from pathlib import Path
|
||||
|
||||
APP = os.environ.get("APP", Path(__file__).parent.parent.name)
|
||||
|
||||
BORG_HOST = "backup"
|
||||
BORG_ROOT: str = "/mnt/yotta/xenon/borg/"
|
||||
22
apps/backup/src/definitions.py
Normal file
22
apps/backup/src/definitions.py
Normal file
@@ -0,0 +1,22 @@
|
||||
import assets
|
||||
import sensors
|
||||
from config import APP
|
||||
from icecream import install
|
||||
|
||||
import dagster as dg
|
||||
|
||||
install()
|
||||
|
||||
definitions = dg.Definitions(
|
||||
assets=[
|
||||
asset.with_attributes(
|
||||
group_names_by_key={asset.key: APP},
|
||||
tags_by_key={asset.key: {"app": APP}},
|
||||
)
|
||||
for asset in dg.load_assets_from_modules([assets])
|
||||
],
|
||||
resources={},
|
||||
jobs=[],
|
||||
schedules=[],
|
||||
sensors=[sensors.borg_repos],
|
||||
)
|
||||
0
apps/backup/src/jobs.py
Normal file
0
apps/backup/src/jobs.py
Normal file
8
apps/backup/src/partitions.py
Normal file
8
apps/backup/src/partitions.py
Normal file
@@ -0,0 +1,8 @@
|
||||
import os
|
||||
|
||||
import dagster as dg
|
||||
|
||||
borg_repo_partitions_def = dg.DynamicPartitionsDefinition(name="borg_repo")
|
||||
daily_partitions_def = dg.DailyPartitionsDefinition(
|
||||
start_date="2025-01-01", end_offset=1, timezone=os.environ.get("TZ", "UTC")
|
||||
)
|
||||
103
apps/backup/src/sensors.py
Normal file
103
apps/backup/src/sensors.py
Normal file
@@ -0,0 +1,103 @@
|
||||
import structlog
|
||||
from partitions import borg_repo_partitions_def
|
||||
from utils.borg import get_ssh_client, list_repos
|
||||
|
||||
import dagster as dg
|
||||
|
||||
logger = structlog.get_logger()
|
||||
|
||||
|
||||
@dg.sensor()
|
||||
def borg_repos(context: dg.SensorEvaluationContext) -> dg.SensorResult:
|
||||
existing_repos = set(
|
||||
context.instance.get_dynamic_partitions(borg_repo_partitions_def.name)
|
||||
)
|
||||
|
||||
with get_ssh_client() as client:
|
||||
parent = "/mnt/yotta/xenon/borg/"
|
||||
repos = set(list_repos(client, parent))
|
||||
|
||||
new_repos = list(set(repos) - existing_repos)
|
||||
return dg.SensorResult(
|
||||
run_requests=[dg.RunRequest(partition_key=repo) for repo in new_repos],
|
||||
dynamic_partitions_requests=[
|
||||
borg_repo_partitions_def.build_add_request(new_repos),
|
||||
],
|
||||
)
|
||||
|
||||
|
||||
# @dg.sensor(job=jobs.raw_html_job, minimum_interval_seconds=4 * 60 * 60)
|
||||
# def list_archives(context: dg.SensorEvaluationContext) -> Iterator[dg.RunRequest]:
|
||||
# ic(context.cursor)
|
||||
#
|
||||
# response = requests.get(URL)
|
||||
# response.raise_for_status()
|
||||
#
|
||||
# try:
|
||||
# date_obj = next(extract_date(response.text))
|
||||
# date_str = date_obj.strftime("%Y-%m-%d")
|
||||
# context.log.info(f"Found date: {date_str}")
|
||||
# if date_str > context.cursor:
|
||||
# context.update_cursor(date_str)
|
||||
# yield dg.RunRequest()
|
||||
# return
|
||||
# except Exception as e:
|
||||
# context.log.error(f"Parsing error: {e}")
|
||||
#
|
||||
# now_str = datetime.now().strftime("%Y-%m-%d %H:%M:%S")
|
||||
# file = f"{now_str} stocks.html"
|
||||
# context.log.info(f"Saving file: {file}")
|
||||
# with open(f"/cache/{file}", "w") as fp:
|
||||
# fp.write(response.text)
|
||||
#
|
||||
#
|
||||
# @dg.sensor(job=jobs.extract_job, minimum_interval_seconds=2 * 60 * 60)
|
||||
# def parse_raw(context: dg.SensorEvaluationContext):
|
||||
# # TODO: use cursor from sensor to filter materialization events
|
||||
#
|
||||
# # Get the known materialized partitions of daily_tables
|
||||
# daily_partitions = context.instance.get_materialized_partitions(
|
||||
# assets.daily_table.key
|
||||
# )
|
||||
# dates = [x.split("|")[0] for x in daily_partitions]
|
||||
# ic(daily_partitions, dates)
|
||||
#
|
||||
# # Get metadata for the raw asset (assumes it's tracked or logged with metadata)
|
||||
# events = list(
|
||||
# context.instance.get_event_records(
|
||||
# event_records_filter=dg.EventRecordsFilter(
|
||||
# event_type=dg.DagsterEventType.ASSET_MATERIALIZATION,
|
||||
# asset_key=assets.raw_html.key,
|
||||
# ),
|
||||
# limit=100,
|
||||
# )
|
||||
# )
|
||||
#
|
||||
# # Track unique dates found in raw that are not materialized in daily_tables
|
||||
# unknown_dates = set()
|
||||
# for event in events:
|
||||
# metadata = event.event_log_entry.asset_materialization.metadata
|
||||
# date_str = None
|
||||
# ic(metadata)
|
||||
# for key, entry in metadata.items():
|
||||
# # TODO: move this general logic
|
||||
# if key.lower() in {"date", "partition", "partition_date"}:
|
||||
# date_str = entry.value
|
||||
# break
|
||||
# if not date_str:
|
||||
# continue
|
||||
#
|
||||
# # Normalize and validate the date
|
||||
# try:
|
||||
# dt = pendulum.from_timestamp(int(date_str))
|
||||
# date_str = dt.strftime("%Y-%m-%d")
|
||||
# except Exception as e:
|
||||
# logger.error(f"Failed to parse date: {date_str}", input=date_str, e=e)
|
||||
# continue
|
||||
#
|
||||
# if date_str not in dates:
|
||||
# unknown_dates.add(date_str)
|
||||
#
|
||||
# ic(unknown_dates)
|
||||
# for date_str in sorted(unknown_dates):
|
||||
# yield dg.RunRequest(partition_key=date_str)
|
||||
0
apps/backup/src/utils/__init__.py
Normal file
0
apps/backup/src/utils/__init__.py
Normal file
59
apps/backup/src/utils/borg.py
Normal file
59
apps/backup/src/utils/borg.py
Normal file
@@ -0,0 +1,59 @@
|
||||
from collections.abc import Iterator
|
||||
from configparser import ConfigParser
|
||||
from contextlib import contextmanager
|
||||
from io import StringIO
|
||||
from pathlib import Path
|
||||
|
||||
import paramiko
|
||||
import structlog
|
||||
|
||||
logger = structlog.get_logger(__name__)
|
||||
|
||||
|
||||
@contextmanager
|
||||
def get_ssh_client():
|
||||
ssh_config_file = Path.home() / ".ssh/config"
|
||||
|
||||
with open(ssh_config_file) as f:
|
||||
ssh_config = paramiko.SSHConfig()
|
||||
ssh_config.parse(f)
|
||||
|
||||
host_config = ssh_config.lookup("backup") # the host alias in ~/.ssh/config
|
||||
|
||||
hostname = host_config.get("hostname", "localhost")
|
||||
port = int(host_config.get("port", 22))
|
||||
username = host_config.get("user")
|
||||
key_filename = host_config.get("identityfile", [None])[0]
|
||||
|
||||
# Connect using Paramiko
|
||||
client = paramiko.SSHClient()
|
||||
client.set_missing_host_key_policy(paramiko.AutoAddPolicy())
|
||||
client.connect(
|
||||
hostname=hostname, port=port, username=username, key_filename=key_filename
|
||||
)
|
||||
|
||||
yield client
|
||||
|
||||
client.close()
|
||||
|
||||
|
||||
def list_repos(client, parent) -> Iterator[str]:
|
||||
command = f"ls {parent}*/config"
|
||||
stdin, stdout, stderr = client.exec_command(command)
|
||||
paths = [line.strip() for line in stdout.readlines()]
|
||||
|
||||
sftp = client.open_sftp()
|
||||
for path in paths:
|
||||
name = Path(path).parent.name
|
||||
logger.info("Opening path", name=name)
|
||||
with sftp.open(path, "r") as f:
|
||||
try:
|
||||
content = f.read().decode()
|
||||
config = ConfigParser()
|
||||
config.read_file(StringIO(content))
|
||||
config.get("repository", "version")
|
||||
yield name
|
||||
except Exception as e:
|
||||
logger.warning("Not a borg repository!", e=e)
|
||||
|
||||
sftp.close()
|
||||
4
apps/backup/ssh_config
Normal file
4
apps/backup/ssh_config
Normal file
@@ -0,0 +1,4 @@
|
||||
Host backup
|
||||
HostName rik.veenboer.xyz
|
||||
User backup
|
||||
StrictHostKeyChecking no
|
||||
@@ -12,17 +12,20 @@ from dagster_polars.patito import patito_model_to_dagster_type
|
||||
from jinja2 import Environment, FileSystemLoader
|
||||
from models import Deal
|
||||
from partitions import daily_partitions_def, multi_partitions_def
|
||||
from plato.fetch import scrape_plato
|
||||
from platenzaak.parse import parse as parse_platenzaak
|
||||
from platenzaak.scrape import scrape as scrape_platenzaak
|
||||
from plato.parse import parse as parse_plato
|
||||
from plato.scrape import scrape as scrape_plato
|
||||
from shared.utils import get_partition_keys, parse_partition_keys
|
||||
from sounds.fetch import fetch_deals
|
||||
from sounds.parse import parse as parse_sounds
|
||||
from sounds.scrape import scrape as scrape_sounds
|
||||
from structlog.stdlib import BoundLogger
|
||||
from utils.email import EmailService
|
||||
|
||||
import dagster as dg
|
||||
|
||||
asset = partial(dg.asset, key_prefix=APP)
|
||||
logger = structlog.get_logger()
|
||||
logger: BoundLogger = structlog.get_logger()
|
||||
|
||||
|
||||
@asset(
|
||||
@@ -63,22 +66,24 @@ def deals(context: dg.AssetExecutionContext) -> pl.DataFrame:
|
||||
logger.error("Failed to load CSV file!", error=e)
|
||||
raise dg.Failure(f"Cannot materialize for the past: {date.date()}")
|
||||
|
||||
if source == "plato":
|
||||
logger.info("Scraping Plato")
|
||||
df = scrape_plato()
|
||||
logger.info("Scraped Plato", rows=len(df), head=df.head().to_markdown())
|
||||
ic(df.columns)
|
||||
return pl.from_pandas(df.assign(**partition_key))
|
||||
if source == "sounds":
|
||||
logger.info("Scraping Sounds")
|
||||
df = fetch_deals()
|
||||
ic(df.columns)
|
||||
logger.info("Scraped Sounds", rows=len(df), head=df.head().to_markdown())
|
||||
return pl.from_pandas(df.assign(**partition_key))
|
||||
match source:
|
||||
case "plato":
|
||||
logger.info("Scraping Plato")
|
||||
df = scrape_plato()
|
||||
logger.info("Scraped Plato", rows=len(df), head=df.head().to_markdown())
|
||||
case "sounds":
|
||||
logger.info("Scraping Sounds")
|
||||
df = scrape_sounds()
|
||||
logger.info("Scraped Sounds", rows=len(df), head=df.head().to_markdown())
|
||||
case "platenzaak":
|
||||
logger.info("Scraping Platenzaak")
|
||||
df = scrape_platenzaak(logger=logger)
|
||||
logger.info("Scraped Sounds", rows=len(df), head=df.head().to_markdown())
|
||||
case _:
|
||||
raise ValueError(f"Unknown source: {source}!")
|
||||
|
||||
return pl.DataFrame(
|
||||
[{"date": context.partition_key, "data": f"Data for {context.partition_key}"}]
|
||||
)
|
||||
ic(df.columns)
|
||||
return pl.from_pandas(df.assign(**partition_key))
|
||||
|
||||
|
||||
@asset(
|
||||
@@ -105,9 +110,10 @@ def cleaned_deals(
|
||||
parsed_df = parse_plato(df)
|
||||
case "sounds":
|
||||
parsed_df = parse_sounds(df)
|
||||
case "platenzaak":
|
||||
parsed_df = parse_platenzaak(df)
|
||||
case _:
|
||||
context.log.warning(f"Unknown source: {source}!")
|
||||
return
|
||||
raise ValueError(f"Unknown source: {source}!")
|
||||
|
||||
ic(parsed_df.collect_schema())
|
||||
|
||||
|
||||
@@ -2,7 +2,7 @@ import os
|
||||
|
||||
import dagster as dg
|
||||
|
||||
SOURCES = ["plato", "sounds"]
|
||||
SOURCES = ["plato", "sounds", "platenzaak"]
|
||||
daily_partitions_def = dg.DailyPartitionsDefinition(
|
||||
start_date="2024-09-01", end_offset=1, timezone=os.environ.get("TZ", "UTC")
|
||||
)
|
||||
|
||||
0
apps/vinyl/src/platenzaak/__init__.py
Normal file
0
apps/vinyl/src/platenzaak/__init__.py
Normal file
13
apps/vinyl/src/platenzaak/parse.py
Normal file
13
apps/vinyl/src/platenzaak/parse.py
Normal file
@@ -0,0 +1,13 @@
|
||||
import polars as pl
|
||||
|
||||
|
||||
def parse(df: pl.LazyFrame) -> pl.LazyFrame:
|
||||
"""Parse the Platenzaak DataFrame."""
|
||||
return df.with_columns(
|
||||
date=pl.col("date").cast(pl.Date),
|
||||
artist=pl.col("artist").str.strip_chars().str.to_lowercase(),
|
||||
title=pl.col("album").str.strip_chars().str.to_lowercase(),
|
||||
release=pl.lit(None),
|
||||
price=pl.col("current_price").cast(pl.Float64),
|
||||
url=pl.format("https://platenzaak.nl{}", pl.col("id")),
|
||||
)
|
||||
90
apps/vinyl/src/platenzaak/scrape.py
Normal file
90
apps/vinyl/src/platenzaak/scrape.py
Normal file
@@ -0,0 +1,90 @@
|
||||
from collections.abc import Iterator
|
||||
|
||||
import pandas as pd
|
||||
import requests
|
||||
from bs4 import BeautifulSoup
|
||||
from structlog.stdlib import BoundLogger
|
||||
|
||||
|
||||
def parse_price(price_block):
|
||||
"""
|
||||
Convert a price block like:
|
||||
<span class="amount theme-money">€ 30<sup>99</sup></span>
|
||||
into a float: 30.99
|
||||
"""
|
||||
if not price_block:
|
||||
return None
|
||||
|
||||
# Extract the main number (before <sup>)
|
||||
main = price_block.find(string=True, recursive=False)
|
||||
main = main.strip().replace("€", "").replace(",", ".").strip()
|
||||
|
||||
# Extract the <sup> part (cents)
|
||||
sup = price_block.find("sup")
|
||||
cents = sup.get_text(strip=True) if sup else "00"
|
||||
|
||||
try:
|
||||
return float(f"{main}.{cents}")
|
||||
except ValueError:
|
||||
return None
|
||||
|
||||
|
||||
def parse_page(html) -> Iterator[dict]:
|
||||
soup = BeautifulSoup(html, "html.parser")
|
||||
|
||||
for block in soup.select("div.product-block__inner"):
|
||||
# Wishlist button holds most metadata
|
||||
wishlist = block.select_one("[data-wlh-id]")
|
||||
if not wishlist:
|
||||
continue
|
||||
|
||||
product = {
|
||||
"id": wishlist.get("data-wlh-id"),
|
||||
"variant_id": wishlist.get("data-wlh-variantid"),
|
||||
"name": wishlist.get("data-wlh-name"),
|
||||
"price": wishlist.get("data-wlh-price"),
|
||||
"url": wishlist.get("data-wlh-link"),
|
||||
"image": wishlist.get("data-wlh-image"),
|
||||
}
|
||||
|
||||
# Artist + Title (in the title link)
|
||||
title_block = block.select_one(".product-block__title-price .title")
|
||||
if title_block:
|
||||
artist = title_block.find("span")
|
||||
if artist:
|
||||
product["artist"] = artist.get_text(strip=True)
|
||||
# The text after <br> is the album title
|
||||
product["album"] = (
|
||||
title_block.get_text(separator="|").split("|")[-1].strip()
|
||||
)
|
||||
|
||||
# Current price (might include discounts)
|
||||
price_block = block.select_one(".price .amount")
|
||||
product["current_price"] = parse_price(price_block)
|
||||
|
||||
# Original price if on sale
|
||||
old_price_block = block.select_one(".price del .theme-money")
|
||||
product["original_price"] = parse_price(old_price_block)
|
||||
|
||||
# Sale label
|
||||
sale_label = block.select_one(".product-label--sale")
|
||||
product["on_sale"] = bool(sale_label)
|
||||
|
||||
yield product
|
||||
|
||||
|
||||
def scrape(logger: BoundLogger) -> pd.DataFrame:
|
||||
page = 1
|
||||
products = []
|
||||
while True:
|
||||
response = requests.get(
|
||||
f"https://www.platenzaak.nl/collections/sale?filter.p.m.custom.config_group=Vinyl&page={page}"
|
||||
)
|
||||
response.raise_for_status()
|
||||
page_products = list(parse_page(response.text))
|
||||
logger.info("Scraped page", page=page, products=len(page_products))
|
||||
if not page_products:
|
||||
break
|
||||
products.extend(page_products)
|
||||
page += 1
|
||||
return pd.DataFrame(products)
|
||||
@@ -1,154 +0,0 @@
|
||||
import os
|
||||
|
||||
import boto3
|
||||
import pandas as pd
|
||||
from botocore.exceptions import NoCredentialsError, PartialCredentialsError
|
||||
from dotenv import load_dotenv
|
||||
from fetch import scrape_plato
|
||||
from utils import get
|
||||
|
||||
|
||||
def update_database(articles_df=None, database_file="/home/user/plato.parquet"):
|
||||
if os.path.exists(database_file):
|
||||
database_df = pd.read_parquet(database_file)
|
||||
else:
|
||||
database_df = None
|
||||
|
||||
if articles_df is None:
|
||||
new_df = None if database_df is None else database_df.head(0)
|
||||
else:
|
||||
if database_df is None:
|
||||
articles_df.to_parquet(database_file)
|
||||
return articles_df, articles_df
|
||||
|
||||
compare = ["ean", "_price"]
|
||||
check_df = pd.merge(
|
||||
database_df[compare], articles_df[compare], how="right", indicator=True
|
||||
)
|
||||
new_df = (
|
||||
check_df[check_df["_merge"] == "right_only"]
|
||||
.drop(columns="_merge")
|
||||
.merge(articles_df)
|
||||
)
|
||||
database_df = (
|
||||
pd.concat([database_df, new_df])
|
||||
.sort_values("_date")
|
||||
.groupby("ean")
|
||||
.last()
|
||||
.reset_index()
|
||||
)
|
||||
database_df.to_parquet(database_file)
|
||||
|
||||
return database_df, new_df
|
||||
|
||||
|
||||
def send_email(lines):
|
||||
# Define the email parameters
|
||||
SENDER = "mail@veenboer.xyz"
|
||||
RECIPIENT = "rik.veenboer@gmail.com"
|
||||
SUBJECT = "Aanbieding op plato!"
|
||||
|
||||
# The email body for recipients with non-HTML email clients
|
||||
BODY_TEXT = ""
|
||||
|
||||
# The HTML body of the email
|
||||
tmp = "\n".join(lines)
|
||||
BODY_HTML = f"""<html>
|
||||
<head></head>
|
||||
<body>
|
||||
{tmp}
|
||||
</html>
|
||||
"""
|
||||
|
||||
# The character encoding for the email
|
||||
CHARSET = "UTF-8"
|
||||
|
||||
# Try to send the email
|
||||
try:
|
||||
client = boto3.client(
|
||||
"ses", region_name="eu-west-1"
|
||||
) # Change the region as needed
|
||||
|
||||
# Provide the contents of the email
|
||||
response = client.send_email(
|
||||
Destination={
|
||||
"ToAddresses": [
|
||||
RECIPIENT,
|
||||
],
|
||||
},
|
||||
Message={
|
||||
"Body": {
|
||||
"Html": {
|
||||
"Charset": CHARSET,
|
||||
"Data": BODY_HTML,
|
||||
},
|
||||
"Text": {
|
||||
"Charset": CHARSET,
|
||||
"Data": BODY_TEXT,
|
||||
},
|
||||
},
|
||||
"Subject": {
|
||||
"Charset": CHARSET,
|
||||
"Data": SUBJECT,
|
||||
},
|
||||
},
|
||||
Source=SENDER,
|
||||
)
|
||||
# Display an error if something goes wrong.
|
||||
except NoCredentialsError:
|
||||
print("Credentials not available")
|
||||
except PartialCredentialsError:
|
||||
print("Incomplete credentials provided")
|
||||
except Exception as e:
|
||||
print(f"Error: {e}")
|
||||
else:
|
||||
print("Email sent! Message ID:"),
|
||||
print(response["MessageId"])
|
||||
|
||||
|
||||
def main(dry=False):
|
||||
load_dotenv("/opt/.env")
|
||||
|
||||
local_ip = get("http://ifconfig.me", False).text
|
||||
get_ip = get("http://ifconfig.me").text
|
||||
print(f"Local IP = {local_ip}")
|
||||
print(f"Request IP = {get_ip}")
|
||||
assert local_ip != get_ip
|
||||
|
||||
artists = open("/home/user/artists.txt").read().strip().splitlines()
|
||||
print(f"Number of known artists = {len(artists)}")
|
||||
|
||||
if dry:
|
||||
articles_df = None
|
||||
else:
|
||||
articles_df = scrape_plato(get=get)
|
||||
database_df, new_df = update_database(articles_df)
|
||||
|
||||
if dry:
|
||||
new_df = database_df.sample(20)
|
||||
|
||||
print(f"Database size = {len(database_df)}")
|
||||
print(f"New = {len(new_df)}")
|
||||
|
||||
# new_df = new_df[new_df['_artist'].isin(artists)].query('_price <= 25')
|
||||
new_df = new_df.query('_price <= 25 and ean != ""')
|
||||
print(f"Interesting = {len(new_df)}")
|
||||
|
||||
if new_df is not None and len(new_df):
|
||||
message = []
|
||||
for _, row in new_df.head(10).iterrows():
|
||||
message.append(
|
||||
f'<a href="https://www.platomania.nl{row.url}"><h1>NEW</h1></a>'
|
||||
)
|
||||
message.append("<ul>")
|
||||
message.append(f"<li>[artist] {row.artist}</li>")
|
||||
message.append(f"<li>[title] {row.title}</li>")
|
||||
message.append(f"<li>[price] {row.price}</li>")
|
||||
message.append(f"<li>[release] {row.release_date}</li>")
|
||||
message.append("</ul>")
|
||||
send_email(message)
|
||||
|
||||
|
||||
if __name__ == "__main__":
|
||||
cwd = os.path.dirname(__file__)
|
||||
main(dry=False)
|
||||
@@ -1,52 +0,0 @@
|
||||
#!/root/.pyenv/versions/dev/bin/python
|
||||
|
||||
import re
|
||||
from datetime import datetime
|
||||
|
||||
import pandas as pd
|
||||
|
||||
from .scrape import get_soup, scrape_page, scrape_page_links
|
||||
|
||||
|
||||
def scrape_plato(get=None):
|
||||
ic()
|
||||
url = "https://www.platomania.nl/vinyl-aanbiedingen?page=1"
|
||||
|
||||
ic(url)
|
||||
soup = get_soup(url=url, get=get)
|
||||
articles_info = scrape_page(soup)
|
||||
ic(len(articles_info))
|
||||
|
||||
links = sorted(set(scrape_page_links(soup)), key=lambda x: int(x.split("=")[-1]))
|
||||
for link in links:
|
||||
ic(link)
|
||||
soup = get_soup(url=link, get=get)
|
||||
tmp = scrape_page(soup)
|
||||
ic(len(tmp))
|
||||
articles_info.extend(tmp)
|
||||
|
||||
def clean(name):
|
||||
tmp = " ".join(reversed(name.split(", ")))
|
||||
tmp = tmp.lower()
|
||||
tmp = re.sub(r"\s+\([^)]*\)", "", tmp)
|
||||
return tmp
|
||||
|
||||
articles_df = pd.DataFrame(articles_info).reindex(
|
||||
columns=[
|
||||
"artist",
|
||||
"title",
|
||||
"url",
|
||||
"label",
|
||||
"release_date",
|
||||
"origin",
|
||||
"item_number",
|
||||
"ean",
|
||||
"delivery_info",
|
||||
"price",
|
||||
]
|
||||
)
|
||||
articles_df["_artist"] = articles_df["artist"].map(clean)
|
||||
articles_df["_price"] = articles_df["price"].map(lambda x: float(x.split(" ")[-1]))
|
||||
articles_df["_date"] = datetime.now()
|
||||
|
||||
return articles_df
|
||||
60
apps/vinyl/src/plato/scrape.py
Normal file → Executable file
60
apps/vinyl/src/plato/scrape.py
Normal file → Executable file
@@ -1,21 +1,61 @@
|
||||
import re
|
||||
from datetime import datetime
|
||||
|
||||
import pandas as pd
|
||||
import requests
|
||||
from bs4 import BeautifulSoup
|
||||
|
||||
|
||||
def scrape(get=None):
|
||||
ic()
|
||||
url = "https://www.platomania.nl/vinyl-aanbiedingen?page=1"
|
||||
|
||||
ic(url)
|
||||
soup = get_soup(url=url, get=get)
|
||||
articles_info = scrape_page(soup)
|
||||
ic(len(articles_info))
|
||||
|
||||
links = sorted(set(scrape_page_links(soup)), key=lambda x: int(x.split("=")[-1]))
|
||||
for link in links:
|
||||
ic(link)
|
||||
soup = get_soup(url=link, get=get)
|
||||
tmp = scrape_page(soup)
|
||||
ic(len(tmp))
|
||||
articles_info.extend(tmp)
|
||||
|
||||
def clean(name):
|
||||
tmp = " ".join(reversed(name.split(", ")))
|
||||
tmp = tmp.lower()
|
||||
tmp = re.sub(r"\s+\([^)]*\)", "", tmp)
|
||||
return tmp
|
||||
|
||||
articles_df = pd.DataFrame(articles_info).reindex(
|
||||
columns=[
|
||||
"artist",
|
||||
"title",
|
||||
"url",
|
||||
"label",
|
||||
"release_date",
|
||||
"origin",
|
||||
"item_number",
|
||||
"ean",
|
||||
"delivery_info",
|
||||
"price",
|
||||
]
|
||||
)
|
||||
articles_df["_artist"] = articles_df["artist"].map(clean)
|
||||
articles_df["_price"] = articles_df["price"].map(lambda x: float(x.split(" ")[-1]))
|
||||
articles_df["_date"] = datetime.now()
|
||||
|
||||
return articles_df
|
||||
|
||||
|
||||
def get_soup(url, get=None):
|
||||
# Send a GET request to the specified URL
|
||||
if get is None:
|
||||
get = requests.get
|
||||
response = get(url)
|
||||
|
||||
# Check if the request was successful
|
||||
if response.status_code == 200:
|
||||
# Parse the HTML content of the page
|
||||
return BeautifulSoup(response.content, "html.parser")
|
||||
else:
|
||||
raise ValueError(
|
||||
f"Failed to retrieve the page. Status code: {response.status_code}"
|
||||
)
|
||||
response.raise_for_status()
|
||||
return BeautifulSoup(response.content, "html.parser")
|
||||
|
||||
|
||||
def scrape_page_links(soup):
|
||||
|
||||
@@ -1,80 +0,0 @@
|
||||
#!/usr/bin/python3
|
||||
|
||||
import glob
|
||||
import os
|
||||
from datetime import datetime
|
||||
|
||||
import pandas as pd
|
||||
|
||||
|
||||
def get_csvs(directory, n):
|
||||
# List all files matching the pattern *_sounds.csv
|
||||
suffix = "_sounds.csv"
|
||||
files = glob.glob(os.path.join(directory, f"*{suffix}"))
|
||||
|
||||
# Function to extract date from filename
|
||||
def extract_date_from_filename(filename):
|
||||
# Extract the date string
|
||||
basename = os.path.basename(filename)
|
||||
date_str = basename.split(suffix)[0]
|
||||
try:
|
||||
return datetime.strptime(date_str, "%Y-%m-%d_%H:%M:%S")
|
||||
except ValueError:
|
||||
# The date string cannot be parsed
|
||||
return None
|
||||
|
||||
# Create a list of tuples (date, filename), ignoring files with unparsable dates
|
||||
result = [(extract_date_from_filename(file), file) for file in files]
|
||||
result = [item for item in result if item[0] is not None]
|
||||
|
||||
# Sort the list by date in descending order (most recent first)
|
||||
result.sort(key=lambda x: x[0], reverse=True)
|
||||
|
||||
# Return the two most recent files
|
||||
return [x[1] for x in result[:n]]
|
||||
|
||||
|
||||
def analyze(df1, df2):
|
||||
df1 = df1.drop_duplicates(subset="id")
|
||||
df2 = df2.drop_duplicates(subset="id")
|
||||
combined_df = pd.merge(
|
||||
df1[["id", "price"]], df2, on="id", how="right", indicator=True
|
||||
)
|
||||
combined_df["discount"] = combined_df.price_y - combined_df.price_x
|
||||
combined_df.drop(columns=["price_x"], inplace=True)
|
||||
combined_df.rename(columns={"price_y": "price"}, inplace=True)
|
||||
|
||||
deals = combined_df.query("discount < 0").sort_values(by="discount")[
|
||||
["id", "name", "price", "discount"]
|
||||
]
|
||||
new = combined_df.query("_merge == 'right_only'").sort_values(by="price")[
|
||||
["id", "name", "price"]
|
||||
]
|
||||
return deals, new
|
||||
|
||||
|
||||
if __name__ == "__main__":
|
||||
csvs = get_csvs(".", 100)
|
||||
|
||||
for i in range(1, len(csvs)):
|
||||
print(f"Comparing {csvs[i]} with {csvs[0]}")
|
||||
df_previous = pd.read_csv(csvs[i], index_col=0)
|
||||
df_latest = pd.read_csv(csvs[0], index_col=0)
|
||||
deals, new = analyze(df_previous, df_latest)
|
||||
|
||||
done = False
|
||||
|
||||
if len(deals) > 0:
|
||||
print()
|
||||
print("New items:")
|
||||
print(new)
|
||||
print()
|
||||
done = True
|
||||
|
||||
if len(deals) > 0:
|
||||
print("Discounted items:")
|
||||
print(deals)
|
||||
done = True
|
||||
|
||||
if done:
|
||||
break
|
||||
@@ -3,7 +3,7 @@ from utils.parse import parse_date
|
||||
|
||||
|
||||
def parse(df: pl.LazyFrame) -> pl.LazyFrame:
|
||||
"""Parse the Plato DataFrame."""
|
||||
"""Parse the Sounds DataFrame."""
|
||||
return df.with_columns(
|
||||
date=pl.col("date").cast(pl.Date),
|
||||
artist=pl.coalesce(pl.col("artist"), pl.col("name").str.split("-").list.get(1))
|
||||
|
||||
@@ -1,7 +1,4 @@
|
||||
#!/usr/bin/python3
|
||||
|
||||
import time
|
||||
from datetime import datetime
|
||||
|
||||
import pandas as pd
|
||||
import requests
|
||||
@@ -74,11 +71,11 @@ def parse_page(html_content):
|
||||
)
|
||||
|
||||
|
||||
def fetch_deals():
|
||||
def scrape():
|
||||
# Get page count
|
||||
page_count = get_page_count(
|
||||
requests.get("https://www.sounds.nl/uitverkoop/1/lp/all/art").text
|
||||
)
|
||||
response = requests.get("https://www.sounds.nl/uitverkoop/1/lp/all/art")
|
||||
response.raise_for_status()
|
||||
page_count = get_page_count(response.text)
|
||||
time.sleep(1)
|
||||
print(f"Number of pages: {page_count}")
|
||||
|
||||
@@ -86,25 +83,11 @@ def fetch_deals():
|
||||
base_url = "https://www.sounds.nl/uitverkoop/{page_number}/lp/all"
|
||||
dfs = []
|
||||
for i in tqdm(range(page_count)):
|
||||
df = parse_page(requests.get(base_url.format(page_number=i)).text)
|
||||
response = requests.get(base_url.format(page_number=i))
|
||||
response.raise_for_status()
|
||||
df = parse_page(response.text)
|
||||
dfs.append(df)
|
||||
time.sleep(2)
|
||||
|
||||
# Combine dfs
|
||||
return pd.concat(dfs) if dfs else pd.DataFrame(columns=["id", "name", "price"])
|
||||
|
||||
|
||||
if __name__ == "__main__":
|
||||
df = fetch_deals()
|
||||
print(f"Found {len(df)} deals")
|
||||
|
||||
# Show current deals
|
||||
print(df.sort_values(by="price").head(10))
|
||||
|
||||
# Write to file
|
||||
now = datetime.now()
|
||||
prefix = now.strftime("%Y-%m-%d_%H:%M:%S")
|
||||
directory = "/home/bram/src/python"
|
||||
filepath = f"{directory}/{prefix}_sounds.csv"
|
||||
print(f"Writing data to {filepath}")
|
||||
df.to_csv(filepath)
|
||||
@@ -144,6 +144,7 @@ def raw_weather_batch_latitude(context: dg.AssetExecutionContext) -> None:
|
||||
|
||||
fetcher = WeatherFetcher()
|
||||
latitude, longitude = parse_coordinate_str(location)
|
||||
ic(latitude, longitude)
|
||||
data = fetcher.fetch(latitude=latitude, longitude=longitude)
|
||||
|
||||
now = datetime.now(tz=timezone.utc)
|
||||
@@ -176,6 +177,7 @@ def raw_weather_batch_latitude(context: dg.AssetExecutionContext) -> None:
|
||||
io_manager_key="polars_parquet_io_manager",
|
||||
partitions_def=daily_partitions_def,
|
||||
output_required=False,
|
||||
automation_condition=dg.AutomationCondition.eager(),
|
||||
)
|
||||
def parsed_weather(
|
||||
context: dg.AssetExecutionContext,
|
||||
|
||||
@@ -64,12 +64,21 @@ services:
|
||||
dagster-code-stocks-playwright:
|
||||
build:
|
||||
context: apps/stocks
|
||||
dockerfile: ../../Dockerfile.code.playwright
|
||||
dockerfile: Dockerfile.code.playwright
|
||||
args:
|
||||
- APP=stocks
|
||||
image: dagster-code-stocks-playwright
|
||||
profiles: [ "never" ]
|
||||
|
||||
dagster-code-backup-base:
|
||||
build:
|
||||
context: apps/backup
|
||||
dockerfile: ../../Dockerfile.code
|
||||
args:
|
||||
- APP=backup
|
||||
image: dagster-code-backup-base
|
||||
profiles: [ "never" ]
|
||||
|
||||
dagster-code-tesla:
|
||||
build:
|
||||
context: apps/tesla
|
||||
@@ -108,6 +117,22 @@ services:
|
||||
networks:
|
||||
- dagster
|
||||
|
||||
dagster-code-backup:
|
||||
build:
|
||||
context: apps/backup
|
||||
container_name: dagster-code-backup
|
||||
image: dagster-code-backup
|
||||
restart: always
|
||||
environment:
|
||||
<<: [ *dagster_env ]
|
||||
DAGSTER_CURRENT_IMAGE: dagster-code-backup
|
||||
volumes:
|
||||
- /opt/dagster/apps/:/code/apps/:ro
|
||||
- /opt/dagster/shared/:/code/shared/:ro
|
||||
- /opt/dagster/logs/:/logs:rw
|
||||
networks:
|
||||
- dagster
|
||||
|
||||
dagster-code-other:
|
||||
build:
|
||||
context: apps/other
|
||||
|
||||
@@ -40,6 +40,8 @@ services:
|
||||
<<: *postgres_env
|
||||
networks:
|
||||
- dagster
|
||||
ports:
|
||||
- '15432:5432'
|
||||
volumes:
|
||||
- /opt/dagster/db/:/var/lib/postgresql/data/
|
||||
|
||||
|
||||
@@ -15,6 +15,7 @@ run_launcher:
|
||||
class: CustomDockerRunLauncher
|
||||
config:
|
||||
env_vars:
|
||||
- TZ
|
||||
- DAGSTER_POSTGRES_HOST
|
||||
- DAGSTER_POSTGRES_PORT
|
||||
- DAGSTER_POSTGRES_USER
|
||||
|
||||
@@ -16,6 +16,7 @@ dependencies = [
|
||||
"openpyxl",
|
||||
"pandas",
|
||||
"patito",
|
||||
"polars==1.32.0",
|
||||
"pyarrow",
|
||||
"pydantic[email]",
|
||||
"pydantic-settings",
|
||||
@@ -43,12 +44,12 @@ local = [
|
||||
"ipywidgets"
|
||||
]
|
||||
dagster = [
|
||||
"dagster",
|
||||
"dagster==1.11.4",
|
||||
"dagster-graphql",
|
||||
"dagster-postgres",
|
||||
"dagster-docker",
|
||||
"dagster-aws",
|
||||
"dagster-polars[patito]",
|
||||
"dagster-polars[patito]==0.27.4",
|
||||
"dagster-duckdb",
|
||||
"dagster-duckdb-pandas",
|
||||
"dagit"
|
||||
@@ -65,6 +66,9 @@ weather = [
|
||||
"requests_cache",
|
||||
"retry_requests"
|
||||
]
|
||||
backup = [
|
||||
"paramiko"
|
||||
]
|
||||
other = [
|
||||
# "deltalake>=1.0.0",
|
||||
# "dagster-deltalake-pandas",
|
||||
|
||||
@@ -5,4 +5,5 @@ uv pip compile pyproject.toml --extra=dagster --extra=vinyl > apps/vinyl/require
|
||||
uv pip compile pyproject.toml --extra=dagster --extra=stocks > apps/stocks/requirements.txt
|
||||
uv pip compile pyproject.toml --extra=dagster --extra=tesla > apps/tesla/requirements.txt
|
||||
uv pip compile pyproject.toml --extra=dagster --extra=weather > apps/weather/requirements.txt
|
||||
uv pip compile pyproject.toml --extra=dagster --extra=backup > apps/backup/requirements.txt
|
||||
uv pip compile pyproject.toml --extra=dagster --extra=other > apps/other/requirements.txt
|
||||
|
||||
@@ -15,6 +15,10 @@ load_from:
|
||||
location_name: weather
|
||||
host: dagster-code-weather
|
||||
port: 4000
|
||||
- grpc_server:
|
||||
location_name: backup
|
||||
host: dagster-code-backup
|
||||
port: 4000
|
||||
- grpc_server:
|
||||
location_name: other
|
||||
host: dagster-code-other
|
||||
|
||||
Reference in New Issue
Block a user