mirror of
https://github.com/9ParsonsB/Pulsar.git
synced 2025-04-05 17:39:39 -04:00
Cleanup & Start Journal work
Got in-memory DB working now displays recents journals to frontend
This commit is contained in:
parent
235cb2401a
commit
ed39900d53
@ -89,6 +89,6 @@ public class FileHandlerService(
|
||||
}
|
||||
|
||||
logger.LogInformation("Handling file {FileName} with Type {Type}", fileName, handler.GetType().ToString());
|
||||
await handler.HandleFile(path);
|
||||
Task.Run(() => handler.HandleFile(path));
|
||||
}
|
||||
}
|
@ -9,28 +9,42 @@ public class JournalService
|
||||
(
|
||||
ILogger<JournalService> logger,
|
||||
IOptions<PulsarConfiguration> options,
|
||||
IEventHubContext hub
|
||||
IEventHubContext hub,
|
||||
PulsarContext context
|
||||
) : IJournalService
|
||||
{
|
||||
public string FileName => FileHandlerService.JournalLogFileName;
|
||||
|
||||
public async Task HandleFile(string filePath)
|
||||
public Task HandleFile(string filePath) => HandleFile(filePath, CancellationToken.None);
|
||||
public async Task HandleFile(string filePath, CancellationToken token)
|
||||
{
|
||||
if (!FileHelper.ValidateFile(filePath))
|
||||
{
|
||||
return;
|
||||
}
|
||||
|
||||
var file = File.Open(filePath, FileMode.Open, FileAccess.Read, FileShare.ReadWrite);
|
||||
var journals = await JsonSerializer.DeserializeAsync<List<JournalBase>>(file);
|
||||
var file = await File.ReadAllLinesAsync(filePath, Encoding.UTF8, token);
|
||||
var journals = file.Select(line => JsonSerializer.Deserialize<JournalBase>(line)).ToList();
|
||||
|
||||
if (journals == null)
|
||||
|
||||
var newJournals = new List<JournalBase>();
|
||||
var notBefore = DateTimeOffset.UtcNow.Subtract(TimeSpan.FromHours(6));
|
||||
foreach (var journal in journals)
|
||||
{
|
||||
logger.LogWarning("Failed to deserialize status file {FilePath}", filePath);
|
||||
return;
|
||||
if (context.Journals.Any(j => j.Timestamp == journal.Timestamp && j.Event == journal.Event))
|
||||
{
|
||||
continue;
|
||||
}
|
||||
|
||||
context.Journals.Add(journal);
|
||||
|
||||
if (journal.Timestamp > notBefore)
|
||||
{
|
||||
newJournals.Add(journal);
|
||||
}
|
||||
}
|
||||
|
||||
await hub.Clients.All.JournalUpdated(journals);
|
||||
await hub.Clients.All.JournalUpdated(newJournals);
|
||||
}
|
||||
|
||||
public async Task<List<JournalBase>> Get()
|
||||
|
@ -1,8 +1,25 @@
|
||||
using Microsoft.Data.Sqlite;
|
||||
using Microsoft.EntityFrameworkCore;
|
||||
using Observatory.Framework.Files.Journal;
|
||||
|
||||
/// <summary>
|
||||
/// An in-memory database context for Pulsar.
|
||||
/// </summary>
|
||||
public class PulsarContext : DbContext
|
||||
{
|
||||
public SqliteConnection Connection { get; private set; }
|
||||
|
||||
public DbSet<JournalBase> Journals { get; set; }
|
||||
|
||||
protected override void OnConfiguring(DbContextOptionsBuilder optionsBuilder)
|
||||
{
|
||||
Connection = new SqliteConnection("Data Source=:memory:");
|
||||
optionsBuilder.UseSqlite(Connection);
|
||||
}
|
||||
|
||||
public override void Dispose()
|
||||
{
|
||||
Connection.Dispose();
|
||||
base.Dispose();
|
||||
}
|
||||
}
|
2
Pulsar/WebApp/src/lib/Fuel.svelte
Normal file
2
Pulsar/WebApp/src/lib/Fuel.svelte
Normal file
@ -0,0 +1,2 @@
|
||||
|
||||
<!-- show a horizontal line representing current amount of fuel vs max (default is 32) -->
|
17
Pulsar/WebApp/src/lib/JournalLog.svelte
Normal file
17
Pulsar/WebApp/src/lib/JournalLog.svelte
Normal file
@ -0,0 +1,17 @@
|
||||
<script lang="ts">
|
||||
import connection from "./stores/Connection.store";
|
||||
|
||||
let value = $state('');
|
||||
|
||||
|
||||
$connection.on("JournalUpdated", (journals) => {
|
||||
console.log(journals);
|
||||
value += `${JSON.stringify(journals)}\n`;
|
||||
});
|
||||
|
||||
</script>
|
||||
|
||||
<h1>Journals:</h1>
|
||||
|
||||
<textarea bind:value ></textarea>
|
||||
|
@ -8,7 +8,7 @@
|
||||
return response.json();
|
||||
};
|
||||
|
||||
const query = useQuery("journal", getData, { staleTime: Infinity });
|
||||
const query = useQuery("journal", getData, { staleTime: Number.POSITIVE_INFINITY });
|
||||
</script>
|
||||
|
||||
<h1>Mission Stack</h1>
|
||||
@ -26,7 +26,7 @@
|
||||
{/if}
|
||||
{/each}
|
||||
{/if}
|
||||
|
||||
|
||||
<style>
|
||||
table {
|
||||
table-layout: fixed;
|
||||
|
@ -10,7 +10,7 @@
|
||||
return response.json();
|
||||
};
|
||||
|
||||
const query = useQuery("modulesinfo", getData, { staleTime: Infinity });
|
||||
const query = useQuery("modulesinfo", getData, { staleTime: Number.POSITIVE_INFINITY });
|
||||
</script>
|
||||
|
||||
<h1>Ship</h1>
|
||||
|
@ -1,86 +1,44 @@
|
||||
<script lang="ts">
|
||||
import * as signalR from "@microsoft/signalr"
|
||||
import {onMount} from "svelte";
|
||||
import { useQueryClient } from "@sveltestack/svelte-query";
|
||||
let x: string | null = $state(null);
|
||||
let textarea = $state("");
|
||||
import { onMount } from "svelte";
|
||||
import { statusStore } from "./stores/Status.store";
|
||||
import connection from "./stores/Connection.store";
|
||||
|
||||
interface Welcome {
|
||||
flags: number;
|
||||
flags2: number;
|
||||
pips: number[];
|
||||
guiFocus: number;
|
||||
fuel: Fuel;
|
||||
cargo: number;
|
||||
legalState: string;
|
||||
balance: number;
|
||||
destination: Destination;
|
||||
timestamp: Date;
|
||||
event: string;
|
||||
FireGroup: number;
|
||||
}
|
||||
|
||||
interface Destination {
|
||||
system: number;
|
||||
body: number;
|
||||
name: string;
|
||||
}
|
||||
|
||||
interface Fuel {
|
||||
fuelMain: number;
|
||||
fuelReservoir: number;
|
||||
}
|
||||
|
||||
const queryClient = useQueryClient();
|
||||
|
||||
let status: Welcome | null = $state(null);
|
||||
|
||||
const connection = new signalR.HubConnectionBuilder()
|
||||
.withUrl("http://localhost:5000/api/events")
|
||||
.configureLogging(signalR.LogLevel.Information)
|
||||
.build();
|
||||
const x: string | null = $state(null);
|
||||
|
||||
onMount(async () => {
|
||||
connection.onclose(async () => {
|
||||
console.log(
|
||||
"Lost connection to Event Hub. Attempting to reconnect...",
|
||||
);
|
||||
await connection.start();
|
||||
});
|
||||
await $connection.start();
|
||||
|
||||
connection.on("StatusUpdated", (message) => {
|
||||
status = message as Welcome;
|
||||
console.log(status);
|
||||
$connection.on("StatusUpdated", (message) => {
|
||||
statusStore.update((s) => {
|
||||
return { ...s, ...message };
|
||||
});
|
||||
console.log($statusStore);
|
||||
});
|
||||
|
||||
await connection.start();
|
||||
});
|
||||
|
||||
const getStatus = async () => {
|
||||
const response = await fetch("http://localhost:5000/api/status/");
|
||||
status = await response.json() as Welcome
|
||||
textarea = status.event;
|
||||
};
|
||||
|
||||
|
||||
|
||||
</script>
|
||||
|
||||
<h1>Status</h1>
|
||||
|
||||
<button on:click={getStatus}> GetStatus </button>
|
||||
<br />
|
||||
|
||||
<div>
|
||||
{#if status}
|
||||
<span>{status.event}</span>
|
||||
<span>{status.pips.join(',')}</span>
|
||||
<span>{status.destination.name}</span>
|
||||
<span>{status.guiFocus}</span>
|
||||
<span>{status.cargo}</span>
|
||||
<div>
|
||||
{#if $statusStore}
|
||||
<span>{$statusStore.event}</span>
|
||||
<span>{(($statusStore.fuel?.fuelMain ?? 0) / 32) * 100}%</span>
|
||||
<span>{$statusStore?.pips?.join(',')}</span>
|
||||
<span>{$statusStore?.destination?.name}</span>
|
||||
<span>{$statusStore.guiFocus}</span>
|
||||
<span>{$statusStore.cargo}</span>
|
||||
{:else}
|
||||
<span>No data :(</span>
|
||||
{/if}
|
||||
</div>
|
||||
|
||||
<style>
|
||||
<style>
|
||||
div {
|
||||
display: flex;
|
||||
flex-direction: column;
|
||||
|
100
Pulsar/WebApp/src/lib/stores/Connection.store.ts
Normal file
100
Pulsar/WebApp/src/lib/stores/Connection.store.ts
Normal file
@ -0,0 +1,100 @@
|
||||
import type {
|
||||
StartStopNotifier,
|
||||
Subscriber,
|
||||
Unsubscriber,
|
||||
Updater,
|
||||
Writable,
|
||||
} from "svelte/store";
|
||||
import type { HubConnection } from "@microsoft/signalr";
|
||||
import {
|
||||
HubConnectionBuilder,
|
||||
HubConnectionState,
|
||||
LogLevel,
|
||||
} from "@microsoft/signalr";
|
||||
|
||||
type SignalRPayload = { name: string; data: unknown[] };
|
||||
type Invalidator<T> = (value?: T) => void;
|
||||
type SubscribeInvalidateTuple<T> = [Subscriber<T>, Invalidator<T>];
|
||||
type T = HubConnection;
|
||||
const noop = () => {};
|
||||
|
||||
class ConnectionStore implements Writable<HubConnection> {
|
||||
readonly hub: HubConnection;
|
||||
readonly subscribers: Array<SubscribeInvalidateTuple<T>> = [];
|
||||
|
||||
public ready = false;
|
||||
isLoading: Promise<void> | undefined;
|
||||
|
||||
private start: StartStopNotifier<HubConnection>;
|
||||
private stop: Unsubscriber | undefined | null;
|
||||
|
||||
constructor(
|
||||
value: HubConnection,
|
||||
start: StartStopNotifier<HubConnection> = noop,
|
||||
) {
|
||||
this.hub = value;
|
||||
this.start = start;
|
||||
this.hub.onclose(async () => {
|
||||
console.log("Lost connection to Event Hub. Attempting to reconnect...");
|
||||
await this.hub.start();
|
||||
});
|
||||
}
|
||||
|
||||
public connect() {
|
||||
if (this.hub.state !== HubConnectionState.Disconnected) return;
|
||||
this.isLoading = this.hub.start();
|
||||
this.isLoading
|
||||
.then(() => {
|
||||
this.ready = true;
|
||||
})
|
||||
.catch((e) => {
|
||||
console.log(e);
|
||||
});
|
||||
}
|
||||
|
||||
public set(value: SignalRPayload | HubConnection): Promise<void> {
|
||||
if ("name" in value) {
|
||||
return this.hub.send(value.name, value.data);
|
||||
}
|
||||
return Promise.reject();
|
||||
}
|
||||
|
||||
public update(updater: Updater<HubConnection>): void {
|
||||
updater(this.hub);
|
||||
}
|
||||
|
||||
public subscribe(
|
||||
run: Subscriber<T>,
|
||||
invalidate: Invalidator<T>,
|
||||
): Unsubscriber {
|
||||
const subscriber: SubscribeInvalidateTuple<T> = [run, invalidate];
|
||||
this.subscribers.push(subscriber);
|
||||
|
||||
if (this.subscribers.length === 1) {
|
||||
this.stop = this.start ? this.start(this.set, this.update) ?? noop : noop;
|
||||
}
|
||||
|
||||
run(this.hub);
|
||||
|
||||
return () => {
|
||||
const index = this.subscribers.indexOf(subscriber);
|
||||
if (index !== -1) {
|
||||
this.subscribers.splice(index, 1);
|
||||
}
|
||||
if (this.subscribers.length === 0) {
|
||||
if (this.stop) this.stop();
|
||||
this.stop = null;
|
||||
}
|
||||
};
|
||||
}
|
||||
}
|
||||
|
||||
const conn = new HubConnectionBuilder()
|
||||
.withUrl("http://localhost:5000/api/events")
|
||||
.configureLogging(LogLevel.Information)
|
||||
.withAutomaticReconnect()
|
||||
.build();
|
||||
|
||||
export const connection = new ConnectionStore(conn);
|
||||
|
||||
export default connection;
|
5
Pulsar/WebApp/src/lib/stores/Status.store.ts
Normal file
5
Pulsar/WebApp/src/lib/stores/Status.store.ts
Normal file
@ -0,0 +1,5 @@
|
||||
|
||||
import { writable } from "svelte/store";
|
||||
import type Status from "../../types/api/Status";
|
||||
|
||||
export const statusStore = writable<Partial<Status>>({});
|
@ -1,4 +1,5 @@
|
||||
<script>
|
||||
import Fuel from "$lib/Fuel.svelte";
|
||||
import {
|
||||
QueryClient,
|
||||
QueryClientProvider,
|
||||
@ -13,6 +14,7 @@
|
||||
<!--<li><a href="/settings">Settings</a></li>-->
|
||||
</ul>
|
||||
</nav>
|
||||
<Fuel />
|
||||
</header>
|
||||
|
||||
<QueryClientProvider client={queryClient}>
|
||||
|
@ -2,13 +2,17 @@
|
||||
import Status from "$lib/Status.svelte";
|
||||
import Ship from "$lib/Ship.svelte";
|
||||
import Debug from "$lib/Debug.svelte";
|
||||
import MissionStack from "$lib/MissionStack.svelte";
|
||||
import MissionStack from "$lib/MissionStack.svelte";
|
||||
import JournalLog from "$lib/JournalLog.svelte";
|
||||
</script>
|
||||
|
||||
<section>
|
||||
<div>
|
||||
<Status />
|
||||
</div>
|
||||
<div>
|
||||
<JournalLog />
|
||||
</div>
|
||||
<div>
|
||||
<!-- <Ship /> -->
|
||||
</div>
|
||||
|
7
Pulsar/WebApp/src/types/api/Destination.ts
Normal file
7
Pulsar/WebApp/src/types/api/Destination.ts
Normal file
@ -0,0 +1,7 @@
|
||||
|
||||
export default interface Destination {
|
||||
system: number;
|
||||
body: number;
|
||||
name: string;
|
||||
}
|
||||
|
5
Pulsar/WebApp/src/types/api/Fuel.ts
Normal file
5
Pulsar/WebApp/src/types/api/Fuel.ts
Normal file
@ -0,0 +1,5 @@
|
||||
|
||||
export default interface Fuel {
|
||||
fuelMain: number;
|
||||
fuelReservoir: number;
|
||||
}
|
17
Pulsar/WebApp/src/types/api/Status.ts
Normal file
17
Pulsar/WebApp/src/types/api/Status.ts
Normal file
@ -0,0 +1,17 @@
|
||||
import type Destination from "./Destination";
|
||||
import type Fuel from "./Fuel";
|
||||
|
||||
export default interface Status {
|
||||
flags: number;
|
||||
flags2: number;
|
||||
pips: number[];
|
||||
guiFocus: number;
|
||||
fuel: Fuel;
|
||||
cargo: number;
|
||||
legalState: string;
|
||||
balance: number;
|
||||
destination: Destination;
|
||||
timestamp: Date;
|
||||
event: string;
|
||||
FireGroup: number;
|
||||
}
|
Loading…
x
Reference in New Issue
Block a user