urbit/pkg/hs/urbit-king/lib/Urbit/Vere/Pier.hs

538 lines
16 KiB
Haskell
Raw Normal View History

2020-01-23 07:16:09 +03:00
{-|
2020-05-22 21:12:28 +03:00
Top-Level Pier Management
2020-01-23 07:16:09 +03:00
This is the code that starts the IO drivers and deals with communication
between the serf, the event log, and the IO drivers.
2020-01-23 07:16:09 +03:00
-}
module Urbit.Vere.Pier
( booted
, runSerf
, resumed
, getSnapshot
, pier
, runPersist
, runCompute
2020-06-07 02:34:27 +03:00
, genBootSeq
)
where
import Urbit.Prelude
2020-05-13 22:35:57 +03:00
import Control.Monad.Trans.Maybe
import RIO.Directory
import Urbit.Arvo
import Urbit.King.Config
import Urbit.Vere.Pier.Types
import System.Posix.Files (ownerModes, setFileMode)
import Urbit.King.App (HasKingEnv, HasPierEnv(..), PierEnv)
import Urbit.King.App (onKillPierSigL)
import Urbit.Noun.Time (Wen)
import Urbit.Vere.Ames (ames)
import Urbit.Vere.Behn (behn)
import Urbit.Vere.Clay (clay)
2020-05-08 21:29:18 +03:00
import Urbit.Vere.Eyre (eyre)
import Urbit.Vere.Eyre.Multi (MultiEyreApi)
import Urbit.Vere.Http.Client (client)
import Urbit.Vere.Log (EventLog)
import Urbit.Vere.Serf (Serf)
import qualified System.Entropy as Ent
import qualified Urbit.King.API as King
import qualified Urbit.Noun.Time as Time
import qualified Urbit.Vere.Log as Log
import qualified Urbit.Vere.Serf as Serf
import qualified Urbit.Vere.Term as Term
import qualified Urbit.Vere.Term.API as Term
import qualified Urbit.Vere.Term.Demux as Term
import qualified Urbit.Vere.Term.Render as Term
2020-06-07 02:34:27 +03:00
-- Initialize pier directory. --------------------------------------------------
2020-06-08 02:35:54 +03:00
data PierDirectoryAlreadyExists = PierDirectoryAlreadyExists
deriving (Show, Exception)
2019-08-28 14:45:49 +03:00
setupPierDirectory :: FilePath -> RIO e ()
2019-08-15 05:42:48 +03:00
setupPierDirectory shipPath = do
2020-06-08 02:35:54 +03:00
-- shipPath will already exist because we put a lock file there.
alreadyExists <- doesPathExist (shipPath </> ".urb")
when alreadyExists $ do
throwIO PierDirectoryAlreadyExists
2020-05-22 21:12:28 +03:00
for_ ["put", "get", "log", "chk"] $ \seg -> do
2020-06-08 02:35:54 +03:00
let pax = shipPath </> ".urb" </> seg
2020-05-22 21:12:28 +03:00
createDirectoryIfMissing True pax
io $ setFileMode pax ownerModes
-- Load pill into boot sequence. -----------------------------------------------
2019-07-16 03:01:45 +03:00
genEntropy :: MonadIO m => m Word512
genEntropy = fromIntegral . bytesAtom <$> io (Ent.getEntropy 64)
2019-07-16 03:01:45 +03:00
genBootSeq :: MonadIO m => Ship -> Pill -> Bool -> LegacyBootEvent -> m BootSeq
genBootSeq ship Pill {..} lite boot = io $ do
2020-05-22 21:12:28 +03:00
ent <- genEntropy
let ovums = preKern ent <> pKernelOvums <> postKern <> pUserspaceOvums
pure $ BootSeq ident pBootFormulas ovums
where
ident = LogIdentity ship isFake (fromIntegral $ length pBootFormulas)
preKern ent =
[ EvBlip $ BlipEvArvo $ ArvoEvWhom () ship
, EvBlip $ BlipEvArvo $ ArvoEvWack () ent
]
postKern = [EvBlip $ BlipEvTerm $ TermEvBoot (1, ()) lite boot]
isFake = case boot of
Fake _ -> True
_ -> False
2019-07-16 03:01:45 +03:00
-- Write a batch of jobs into the event log ------------------------------------
2019-08-28 14:45:49 +03:00
writeJobs :: EventLog -> Vector Job -> RIO e ()
writeJobs log !jobs = do
expect <- atomically (Log.nextEv log)
2020-05-22 21:12:28 +03:00
events <- fmap fromList $ traverse fromJob (zip [expect ..] $ toList jobs)
Log.appendEvents log events
where
fromJob :: (EventId, Job) -> RIO e ByteString
fromJob (expectedId, job) = do
unless (expectedId == jobId job) $ error $ show
("bad job id!", expectedId, jobId job)
pure $ jamBS $ jobPayload job
2020-05-22 21:12:28 +03:00
jobPayload :: Job -> Noun
jobPayload (RunNok (LifeCyc _ m n)) = toNoun (m, n)
jobPayload (DoWork (Work _ m d o )) = toNoun (m, d, o)
2020-06-07 02:34:27 +03:00
-- Acquire a running serf. -----------------------------------------------------
printTank :: (Text -> IO ()) -> Atom -> Tank -> IO ()
printTank f _ = io . f . unlines . fmap unTape . wash (WashCfg 0 80)
runSerf
:: HasLogFunc e
=> TVar (Text -> IO ())
-> FilePath
-> [Serf.Flag]
-> RAcquire e Serf
runSerf vSlog pax fax = do
env <- ask
Serf.withSerf (config env)
where
slog txt = join $ atomically (readTVar vSlog >>= pure . ($ txt))
config env = Serf.Config
{ scSerf = "urbit-worker" -- TODO Find the executable in some proper way.
, scPier = pax
, scFlag = fax
, scSlog = \(pri, tank) -> printTank slog pri tank
, scStdr = \line -> runRIO env $ logTrace (display ("SERF: " <> line))
, scDead = pure () -- TODO: What can be done?
}
2020-06-07 02:34:27 +03:00
-- Boot a new ship. ------------------------------------------------------------
2020-05-22 21:12:28 +03:00
booted
:: TVar (Text -> IO ())
-> Pill
2020-05-22 21:12:28 +03:00
-> Bool
-> [Serf.Flag]
2020-05-22 21:12:28 +03:00
-> Ship
-> LegacyBootEvent
-> RAcquire PierEnv (Serf, EventLog)
booted vSlog pill lite flags ship boot = do
rio $ bootNewShip pill lite flags ship boot
resumed vSlog Nothing flags
2019-08-15 05:42:48 +03:00
bootSeqJobs :: Time.Wen -> BootSeq -> [Job]
bootSeqJobs now (BootSeq ident nocks ovums) = zipWith ($) bootSeqFns [1 ..]
where
wen :: EventId -> Time.Wen
wen off = Time.addGap now ((fromIntegral off - 1) ^. from Time.microSecs)
bootSeqFns :: [EventId -> Job]
bootSeqFns = fmap muckNock nocks <> fmap muckOvum ovums
where
muckNock nok eId = RunNok $ LifeCyc eId 0 nok
muckOvum ov eId = DoWork $ Work eId 0 (wen eId) ov
bootNewShip
:: HasPierEnv e
=> Pill
-> Bool
-> [Serf.Flag]
-> Ship
-> LegacyBootEvent
-> RIO e ()
bootNewShip pill lite flags ship bootEv = do
2020-06-07 02:34:27 +03:00
seq@(BootSeq ident x y) <- genBootSeq ship pill lite bootEv
logTrace "BootSeq Computed"
2019-08-15 05:42:48 +03:00
pierPath <- view pierPathL
2019-10-18 01:32:06 +03:00
2019-08-28 14:45:49 +03:00
liftRIO (setupPierDirectory pierPath)
logTrace "Directory setup."
2019-08-15 05:42:48 +03:00
rwith (Log.new (pierPath <> "/.urb/log") ident) $ \log -> do
logTrace "Event log initialized."
jobs <- (\now -> bootSeqJobs now seq) <$> io Time.now
writeJobs log (fromList jobs)
logTrace "Finsihed populating event log with boot sequence"
2019-08-15 05:42:48 +03:00
-- Resume an existing ship. ----------------------------------------------------
resumed
:: TVar (Text -> IO ())
-> Maybe Word64
-> [Serf.Flag]
-> RAcquire PierEnv (Serf, EventLog)
2020-06-07 03:26:59 +03:00
resumed vSlog replayUntil flags = do
rio $ logTrace "Resuming ship"
top <- view pierPathL
tap <- fmap (fromMaybe top) $ rio $ runMaybeT $ do
ev <- MaybeT (pure replayUntil)
MaybeT (getSnapshot top ev)
2020-02-06 02:20:32 +03:00
rio $ logTrace $ display @Text ("pier: " <> pack top)
rio $ logTrace $ display @Text ("running serf in: " <> pack tap)
2020-02-06 02:20:32 +03:00
log <- Log.existing (top <> "/.urb/log")
serf <- runSerf vSlog tap flags
rio $ do
logTrace "Replaying events"
Serf.execReplay serf log replayUntil >>= \case
Left err -> error (show err)
Right 0 -> do
logTrace "No work during replay so no snapshot"
pure ()
Right _ -> do
logTrace "Taking snapshot"
io (Serf.snapshot serf)
pure (serf, log)
2020-06-07 02:34:27 +03:00
getSnapshot :: forall e . FilePath -> Word64 -> RIO e (Maybe FilePath)
getSnapshot top last = do
2020-06-07 02:34:27 +03:00
lastSnapshot <- lastMay <$> listReplays
pure (replayToPath <$> lastSnapshot)
where
replayDir = top </> ".partial-replay"
replayToPath eId = replayDir </> show eId
2020-01-25 03:20:13 +03:00
2020-06-07 02:34:27 +03:00
listReplays :: RIO e [Word64]
listReplays = do
createDirectoryIfMissing True replayDir
snapshotNums <- mapMaybe readMay <$> listDirectory replayDir
pure $ sort (filter (<= fromIntegral last) snapshotNums)
2020-06-07 02:34:27 +03:00
-- Utils for Spawning Worker Threads -------------------------------------------
acquireWorker :: HasLogFunc e => Text -> RIO e () -> RAcquire e (Async ())
acquireWorker nam act = mkRAcquire (async act) kill
where
kill tid = do
logTrace ("Killing worker thread: " <> display nam)
cancel tid
acquireWorkerBound :: HasLogFunc e => Text -> RIO e () -> RAcquire e (Async ())
acquireWorkerBound nam act = mkRAcquire (asyncBound act) kill
where
kill tid = do
logTrace ("Killing worker thread: " <> display nam)
cancel tid
2020-06-07 02:34:27 +03:00
-- Run Pier --------------------------------------------------------------------
2020-05-13 22:35:57 +03:00
pier
:: (Serf, EventLog)
-> TVar (Text -> IO ())
2020-05-13 22:35:57 +03:00
-> MVar ()
-> MultiEyreApi
-> RAcquire PierEnv ()
pier (serf, log) vSlog mStart multi = do
2020-06-07 02:34:27 +03:00
computeQ <- newTQueueIO @_ @Serf.EvErr
2020-06-09 00:22:04 +03:00
persistQ <- newTQueueIO @_ @(Fact, FX)
executeQ <- newTQueueIO @_ @FX
saveM <- newEmptyTMVarIO @_ @()
2020-06-07 02:34:27 +03:00
kingApi <- King.kingAPI
termApiQ <- atomically $ do
q <- newTQueue
writeTVar (King.kTermConn kingApi) (Just $ writeTQueue q)
pure q
(demux, muxed) <- atomically $ do
res <- Term.mkDemux
pure (res, Term.useDemux res)
acquireWorker "TERMSERV" $ forever $ do
logTrace "TERMSERV Waiting for external terminal."
atomically $ do
2020-06-07 02:34:27 +03:00
ext <- Term.connClient <$> readTQueue termApiQ
Term.addDemux ext demux
logTrace "TERMSERV External terminal connected."
-- Slogs go to both stderr and to the terminal.
atomically $ do
oldSlog <- readTVar vSlog
writeTVar vSlog $ \txt -> do
atomically $ Term.trace muxed txt
oldSlog txt
2020-06-09 00:22:04 +03:00
let logId = Log.identity log :: LogIdentity
let ship = who logId :: Ship
2020-06-07 02:34:27 +03:00
-- Our call above to set the logging function which echos errors from the
-- Serf doesn't have the appended \r\n because those \r\n s are added in
-- the c serf code. Logging output from our haskell process must manually
-- add them.
2020-06-09 00:22:04 +03:00
let showErr = atomically . Term.trace muxed . (<> "\r\n")
2020-05-13 22:35:57 +03:00
2020-06-07 02:34:27 +03:00
env <- ask
2020-05-13 22:35:57 +03:00
2020-06-07 02:34:27 +03:00
let (bootEvents, startDrivers) = drivers
env
multi
ship
(isFake logId)
(writeTQueue computeQ)
(Term.TSize { tsWide = 80, tsTall = 24 }, muxed)
showErr
2020-06-07 02:34:27 +03:00
io $ atomically $ for_ bootEvents (writeTQueue computeQ)
2020-06-07 02:34:27 +03:00
scryM <- newEmptyTMVarIO
onKill <- view onKillPierSigL
2020-06-07 02:34:27 +03:00
let computeConfig = ComputeConfig { ccOnWork = readTQueue computeQ
, ccOnKill = onKill
, ccOnSave = takeTMVar saveM
, ccOnScry = takeTMVar scryM
, ccPutResult = writeTQueue persistQ
, ccShowSpinner = Term.spin muxed
, ccHideSpinner = Term.stopSpin muxed
, ccLastEvInLog = Log.lastEv log
}
2020-05-28 21:21:43 +03:00
2020-06-07 02:34:27 +03:00
let plan = writeTQueue executeQ
2020-06-07 02:34:27 +03:00
drivz <- startDrivers
tExec <- acquireWorker "Effects" (router (readTQueue executeQ) drivz)
tDisk <- acquireWorkerBound "Persist" (runPersist log persistQ plan)
tSerf <- acquireWorker "Serf" (runCompute serf computeConfig)
tSaveSignal <- saveSignalThread saveM
2020-06-07 02:34:27 +03:00
-- TODO bullshit scry tester
void $ acquireWorker "bullshit scry tester" $ forever $ do
env <- ask
2020-06-08 02:35:54 +03:00
threadDelay 15_000_000
2020-06-07 02:34:27 +03:00
wen <- io Time.now
let kal = \mTermNoun -> runRIO env $ do
logTrace $ displayShow ("scry result: ", mTermNoun)
let nkt = MkKnot $ tshow $ Time.MkDate wen
let pax = Path ["j", "~zod", "life", nkt, "~zod"]
atomically $ putTMVar scryM (wen, Nothing, pax, kal)
2020-06-07 02:34:27 +03:00
putMVar mStart ()
2020-06-07 02:34:27 +03:00
-- Wait for something to die.
2019-07-20 06:00:23 +03:00
2020-06-07 02:34:27 +03:00
let ded = asum
[ death "effects thread" tExec
, death "persist thread" tDisk
, death "compute thread" tSerf
]
2020-06-07 02:34:27 +03:00
atomically ded >>= \case
Left (txt, exn) -> logError $ displayShow ("Somthing died", txt, exn)
Right tag -> logError $ displayShow ("Something simply exited", tag)
2020-06-07 02:34:27 +03:00
atomically $ (Term.spin muxed) (Just "shutdown")
death :: Text -> Async () -> STM (Either (Text, SomeException) Text)
death tag tid = do
waitCatchSTM tid <&> \case
Left exn -> Left (tag, exn)
Right () -> Right tag
saveSignalThread :: TMVar () -> RAcquire e (Async ())
saveSignalThread tm = mkRAcquire start cancel
where
start = async $ forever $ do
threadDelay (120 * 1000000) -- 120 seconds
atomically $ putTMVar tm ()
-- Start All Drivers -----------------------------------------------------------
2019-08-29 03:26:59 +03:00
data Drivers e = Drivers
2020-06-07 02:34:27 +03:00
{ dAmes :: AmesEf -> IO ()
, dBehn :: BehnEf -> IO ()
, dIris :: HttpClientEf -> IO ()
, dEyre :: HttpServerEf -> IO ()
, dNewt :: NewtEf -> IO ()
, dSync :: SyncEf -> IO ()
, dTerm :: TermEf -> IO ()
}
drivers
2020-05-22 21:12:28 +03:00
:: HasPierEnv e
2020-05-13 22:35:57 +03:00
=> e
-> MultiEyreApi
-> Ship
-> Bool
-> (EvErr -> STM ())
-> (Term.TSize, Term.Client)
-> (Text -> RIO e ())
-> ([EvErr], RAcquire e (Drivers e))
drivers env multi who isFake plan termSys stderr =
2020-06-07 02:34:27 +03:00
(initialEvents, runDrivers)
where
(behnBorn, runBehn) = behn env plan
(amesBorn, runAmes) = ames env who isFake plan stderr
(httpBorn, runEyre) = eyre env multi who plan isFake
(clayBorn, runClay) = clay env plan
(irisBorn, runIris) = client env plan
(termBorn, runTerm) = Term.term env termSys plan
initialEvents = mconcat [behnBorn, clayBorn, amesBorn, httpBorn,
termBorn, irisBorn]
runDrivers = do
dNewt <- runAmes
dBehn <- liftAcquire $ runBehn
dAmes <- pure $ const $ pure ()
dIris <- runIris
dEyre <- runEyre
dSync <- runClay
dTerm <- runTerm
pure (Drivers{..})
-- Route Effects to Drivers ----------------------------------------------------
2020-05-28 21:21:43 +03:00
router :: HasLogFunc e => STM FX -> Drivers e -> RIO e ()
router waitFx Drivers {..} = forever $ do
fx <- atomically waitFx
for_ fx $ \ef -> do
logEffect ef
case ef of
GoodParse (EfVega _ _ ) -> error "TODO"
GoodParse (EfExit _ _ ) -> error "TODO"
2020-06-07 02:34:27 +03:00
GoodParse (EfVane (VEAmes ef)) -> io (dAmes ef)
GoodParse (EfVane (VEBehn ef)) -> io (dBehn ef)
GoodParse (EfVane (VEBoat ef)) -> io (dSync ef)
GoodParse (EfVane (VEClay ef)) -> io (dSync ef)
GoodParse (EfVane (VEHttpClient ef)) -> io (dIris ef)
GoodParse (EfVane (VEHttpServer ef)) -> io (dEyre ef)
GoodParse (EfVane (VENewt ef)) -> io (dNewt ef)
GoodParse (EfVane (VESync ef)) -> io (dSync ef)
GoodParse (EfVane (VETerm ef)) -> io (dTerm ef)
2020-05-28 21:21:43 +03:00
FailParse n -> logError $ display $ pack @Text (ppShow n)
2020-06-07 02:34:27 +03:00
-- Compute (Serf) Thread -------------------------------------------------------
2019-08-28 14:45:49 +03:00
logEvent :: HasLogFunc e => Ev -> RIO e ()
logEvent ev = logDebug $ display $ "[EVENT]\n" <> pretty
where
pretty :: Text
pretty = pack $ unlines $ fmap ("\t" <>) $ lines $ ppShow ev
2019-08-28 14:45:49 +03:00
logEffect :: HasLogFunc e => Lenient Ef -> RIO e ()
logEffect ef = logDebug $ display $ "[EFFECT]\n" <> pretty ef
where
pretty :: Lenient Ef -> Text
pretty = \case
GoodParse e -> pack $ unlines $ fmap ("\t" <>) $ lines $ ppShow e
FailParse n -> pack $ unlines $ fmap ("\t" <>) $ lines $ ppShow n
2019-08-28 14:45:49 +03:00
data ComputeConfig = ComputeConfig
{ ccOnWork :: STM Serf.EvErr
, ccOnKill :: STM ()
, ccOnSave :: STM ()
, ccOnScry :: STM (Wen, Gang, Path, Maybe (Term, Noun) -> IO ())
, ccPutResult :: (Fact, FX) -> STM ()
, ccShowSpinner :: Maybe Text -> STM ()
, ccHideSpinner :: STM ()
, ccLastEvInLog :: STM EventId
}
runCompute :: forall e . HasKingEnv e => Serf.Serf -> ComputeConfig -> RIO e ()
2020-05-28 21:21:43 +03:00
runCompute serf ComputeConfig {..} = do
logTrace "runCompute"
let onCR = asum [ ccOnKill <&> Serf.RRKill
, ccOnSave <&> Serf.RRSave
, ccOnWork <&> Serf.RRWork
, ccOnScry <&> \(w,g,p,k) -> Serf.RRScry w g p k
]
vEvProcessing :: TMVar Ev <- newEmptyTMVarIO
void $ async $ forever (atomically (takeTMVar vEvProcessing) >>= logEvent)
let onSpin :: Maybe Ev -> STM ()
2020-06-07 02:34:27 +03:00
onSpin = \case
Nothing -> ccHideSpinner
Just ev -> do
ccShowSpinner (getSpinnerNameForEvent ev)
putTMVar vEvProcessing ev
let maxBatchSize = 10
io (Serf.run serf maxBatchSize ccLastEvInLog onCR ccPutResult onSpin)
2020-06-07 02:34:27 +03:00
-- Event-Log Persistence Thread ------------------------------------------------
2019-07-20 06:00:23 +03:00
data PersistExn = BadEventId EventId EventId
deriving Show
instance Exception PersistExn where
displayException (BadEventId expected got) =
unlines [ "Out-of-order event id send to persist thread."
, "\tExpected " <> show expected <> " but got " <> show got
]
runPersist
:: forall e
. HasPierEnv e
=> EventLog
-> TQueue (Fact, FX)
-> (FX -> STM ())
2020-05-28 21:21:43 +03:00
-> RIO e ()
runPersist log inpQ out = do
dryRun <- view dryRunL
forever $ do
writs <- atomically getBatchFromQueue
events <- validateFactsAndGetBytes (fst <$> toNullable writs)
unless dryRun (Log.appendEvents log events)
atomically $ for_ writs $ \(_, fx) -> do
out fx
2020-05-28 21:21:43 +03:00
where
validateFactsAndGetBytes :: [Fact] -> RIO e (Vector ByteString)
validateFactsAndGetBytes facts = do
expect <- atomically (Log.nextEv log)
lis <- for (zip [expect ..] facts) $ \(expectedId, Fact eve mug wen non) ->
do
unless (expectedId == eve) $ do
throwIO (BadEventId expectedId eve)
pure $ jamBS $ toNoun (mug, wen, non)
pure (fromList lis)
getBatchFromQueue :: STM (NonNull [(Fact, FX)])
getBatchFromQueue = readTQueue inpQ >>= go . singleton
where
go acc = tryReadTQueue inpQ >>= \case
Nothing -> pure (reverse acc)
Just item -> go (item <| acc)