2022-03-16 03:39:21 +03:00
|
|
|
{-# LANGUAGE TemplateHaskell #-}
|
|
|
|
|
2019-08-28 15:19:21 +03:00
|
|
|
-- | Top-level management of live query poller threads. The implementation of the polling itself is
|
|
|
|
-- in "Hasura.GraphQL.Execute.LiveQuery.Poll". See "Hasura.GraphQL.Execute.LiveQuery" for high-level
|
|
|
|
-- details.
|
|
|
|
module Hasura.GraphQL.Execute.LiveQuery.State
|
2021-09-24 01:56:37 +03:00
|
|
|
( LiveQueriesState (..),
|
|
|
|
initLiveQueriesState,
|
|
|
|
dumpLiveQueriesState,
|
|
|
|
LiveQueryId,
|
|
|
|
LiveQueryPostPollHook,
|
|
|
|
addLiveQuery,
|
|
|
|
removeLiveQuery,
|
|
|
|
LiveAsyncActionQueryOnSource (..),
|
|
|
|
LiveAsyncActionQueryWithNoRelationships (..),
|
|
|
|
LiveAsyncActionQuery (..),
|
|
|
|
AsyncActionQueryLive (..),
|
|
|
|
AsyncActionSubscriptionState,
|
|
|
|
addAsyncActionLiveQuery,
|
|
|
|
removeAsyncActionLiveQuery,
|
|
|
|
)
|
|
|
|
where
|
|
|
|
|
|
|
|
import Control.Concurrent.Extended (forkImmortal, sleep)
|
|
|
|
import Control.Concurrent.STM qualified as STM
|
|
|
|
import Control.Exception (mask_)
|
|
|
|
import Control.Immortal qualified as Immortal
|
|
|
|
import Data.Aeson.Extended qualified as J
|
|
|
|
import Data.String
|
|
|
|
import Data.Text.Extended
|
|
|
|
import Data.UUID.V4 qualified as UUID
|
|
|
|
import GHC.AssertNF.CPP
|
|
|
|
import Hasura.Base.Error
|
|
|
|
import Hasura.GraphQL.Execute.Backend
|
|
|
|
import Hasura.GraphQL.Execute.LiveQuery.Options
|
|
|
|
import Hasura.GraphQL.Execute.LiveQuery.Plan
|
|
|
|
import Hasura.GraphQL.Execute.LiveQuery.Poll
|
|
|
|
import Hasura.GraphQL.Execute.LiveQuery.TMap qualified as TMap
|
|
|
|
import Hasura.GraphQL.ParameterizedQueryHash (ParameterizedQueryHash)
|
|
|
|
import Hasura.GraphQL.Transport.Backend
|
|
|
|
import Hasura.GraphQL.Transport.HTTP.Protocol (OperationName)
|
|
|
|
import Hasura.GraphQL.Transport.WebSocket.Protocol (OperationId)
|
|
|
|
import Hasura.Logging qualified as L
|
|
|
|
import Hasura.Prelude
|
|
|
|
import Hasura.RQL.Types.Action
|
|
|
|
import Hasura.RQL.Types.Common (SourceName, unNonNegativeDiffTime)
|
|
|
|
import Hasura.Server.Metrics (ServerMetrics (..))
|
|
|
|
import Hasura.Server.Types (RequestId)
|
|
|
|
import StmContainers.Map qualified as STMMap
|
|
|
|
import System.Metrics.Gauge qualified as EKG.Gauge
|
2021-05-11 18:18:31 +03:00
|
|
|
|
2019-08-28 15:19:21 +03:00
|
|
|
-- | The top-level datatype that holds the state for all active live queries.
|
2020-03-05 20:59:26 +03:00
|
|
|
--
|
2020-06-04 20:25:21 +03:00
|
|
|
-- NOTE!: This must be kept consistent with a websocket connection's
|
|
|
|
-- 'OperationMap', in 'onClose' and 'onStart'.
|
2021-09-24 01:56:37 +03:00
|
|
|
data LiveQueriesState = LiveQueriesState
|
|
|
|
{ _lqsOptions :: !LiveQueriesOptions,
|
|
|
|
_lqsLiveQueryMap :: !PollerMap,
|
|
|
|
-- | A hook function which is run after each fetch cycle
|
|
|
|
_lqsPostPollHook :: !LiveQueryPostPollHook,
|
|
|
|
_lqsAsyncActions :: !AsyncActionSubscriptionState
|
2019-08-28 15:19:21 +03:00
|
|
|
}
|
|
|
|
|
2021-09-24 01:56:37 +03:00
|
|
|
initLiveQueriesState ::
|
|
|
|
LiveQueriesOptions -> LiveQueryPostPollHook -> IO LiveQueriesState
|
|
|
|
initLiveQueriesState options pollHook =
|
|
|
|
STM.atomically $
|
|
|
|
LiveQueriesState options <$> STMMap.new <*> pure pollHook <*> TMap.new
|
2019-08-28 15:19:21 +03:00
|
|
|
|
|
|
|
dumpLiveQueriesState :: Bool -> LiveQueriesState -> IO J.Value
|
2021-03-31 13:39:01 +03:00
|
|
|
dumpLiveQueriesState extended (LiveQueriesState opts lqMap _ _) = do
|
2019-08-28 15:19:21 +03:00
|
|
|
lqMapJ <- dumpPollerMap extended lqMap
|
2021-09-24 01:56:37 +03:00
|
|
|
return $
|
|
|
|
J.object
|
|
|
|
[ "options" J..= opts,
|
|
|
|
"live_queries_map" J..= lqMapJ
|
|
|
|
]
|
|
|
|
|
|
|
|
data LiveQueryId = LiveQueryId
|
|
|
|
{ _lqiPoller :: !PollerKey,
|
|
|
|
_lqiCohort :: !CohortKey,
|
|
|
|
_lqiSubscriber :: !SubscriberId
|
|
|
|
}
|
|
|
|
deriving (Show)
|
|
|
|
|
|
|
|
addLiveQuery ::
|
|
|
|
forall b.
|
|
|
|
BackendTransport b =>
|
|
|
|
L.Logger L.Hasura ->
|
|
|
|
ServerMetrics ->
|
|
|
|
SubscriberMetadata ->
|
|
|
|
LiveQueriesState ->
|
|
|
|
SourceName ->
|
|
|
|
ParameterizedQueryHash ->
|
|
|
|
-- | operation name of the query
|
|
|
|
Maybe OperationName ->
|
|
|
|
RequestId ->
|
|
|
|
LiveQueryPlan b (MultiplexedQuery b) ->
|
|
|
|
-- | the action to be executed when result changes
|
|
|
|
OnChange ->
|
|
|
|
IO LiveQueryId
|
2019-08-28 15:19:21 +03:00
|
|
|
addLiveQuery
|
2021-09-24 01:56:37 +03:00
|
|
|
logger
|
|
|
|
serverMetrics
|
|
|
|
subscriberMetadata
|
|
|
|
lqState
|
|
|
|
source
|
|
|
|
parameterizedQueryHash
|
|
|
|
operationName
|
|
|
|
requestId
|
|
|
|
plan
|
|
|
|
onResultAction = do
|
|
|
|
-- CAREFUL!: It's absolutely crucial that we can't throw any exceptions here!
|
|
|
|
|
|
|
|
-- disposable UUIDs:
|
|
|
|
cohortId <- newCohortId
|
|
|
|
subscriberId <- newSubscriberId
|
|
|
|
|
|
|
|
let !subscriber = Subscriber subscriberId subscriberMetadata requestId operationName onResultAction
|
|
|
|
|
|
|
|
$assertNFHere subscriber -- so we don't write thunks to mutable vars
|
|
|
|
|
|
|
|
-- a handler is returned only when it is newly created
|
|
|
|
handlerM <-
|
|
|
|
STM.atomically $
|
|
|
|
STMMap.lookup handlerId lqMap >>= \case
|
|
|
|
Just handler -> do
|
|
|
|
TMap.lookup cohortKey (_pCohorts handler) >>= \case
|
|
|
|
Just cohort -> addToCohort subscriber cohort
|
|
|
|
Nothing -> addToPoller subscriber cohortId handler
|
|
|
|
return Nothing
|
|
|
|
Nothing -> do
|
|
|
|
!poller <- newPoller
|
|
|
|
addToPoller subscriber cohortId poller
|
|
|
|
STMMap.insert poller handlerId lqMap
|
|
|
|
return $ Just poller
|
|
|
|
|
|
|
|
-- we can then attach a polling thread if it is new the livequery can only be
|
|
|
|
-- cancelled after putTMVar
|
|
|
|
onJust handlerM $ \handler -> do
|
|
|
|
pollerId <- PollerId <$> UUID.nextRandom
|
|
|
|
threadRef <- forkImmortal ("pollQuery." <> show pollerId) logger $
|
|
|
|
forever $ do
|
|
|
|
pollQuery @b pollerId lqOpts (source, sourceConfig) role parameterizedQueryHash query (_pCohorts handler) postPollHook
|
|
|
|
sleep $ unNonNegativeDiffTime $ unRefetchInterval refetchInterval
|
|
|
|
let !pState = PollerIOState threadRef pollerId
|
|
|
|
$assertNFHere pState -- so we don't write thunks to mutable vars
|
|
|
|
STM.atomically $ STM.putTMVar (_pIOState handler) pState
|
|
|
|
|
|
|
|
liftIO $ EKG.Gauge.inc $ smActiveSubscriptions serverMetrics
|
|
|
|
|
|
|
|
pure $ LiveQueryId handlerId cohortKey subscriberId
|
|
|
|
where
|
|
|
|
LiveQueriesState lqOpts lqMap postPollHook _ = lqState
|
|
|
|
LiveQueriesOptions _ refetchInterval = lqOpts
|
2021-10-29 17:42:07 +03:00
|
|
|
LiveQueryPlan (ParameterizedLiveQueryPlan role query) sourceConfig cohortKey _ = plan
|
2021-09-24 01:56:37 +03:00
|
|
|
|
|
|
|
handlerId = PollerKey source role $ toTxt query
|
|
|
|
|
|
|
|
addToCohort subscriber handlerC =
|
|
|
|
TMap.insert subscriber (_sId subscriber) $ _cNewSubscribers handlerC
|
|
|
|
|
|
|
|
addToPoller subscriber cohortId handler = do
|
|
|
|
!newCohort <- Cohort cohortId <$> STM.newTVar Nothing <*> TMap.new <*> TMap.new
|
|
|
|
addToCohort subscriber newCohort
|
|
|
|
TMap.insert newCohort cohortKey $ _pCohorts handler
|
|
|
|
|
|
|
|
newPoller = Poller <$> TMap.new <*> STM.newEmptyTMVar
|
|
|
|
|
|
|
|
removeLiveQuery ::
|
|
|
|
L.Logger L.Hasura ->
|
|
|
|
ServerMetrics ->
|
|
|
|
LiveQueriesState ->
|
2019-08-28 15:19:21 +03:00
|
|
|
-- the query and the associated operation
|
2021-09-24 01:56:37 +03:00
|
|
|
LiveQueryId ->
|
|
|
|
IO ()
|
2021-05-05 07:24:12 +03:00
|
|
|
removeLiveQuery logger serverMetrics lqState lqId@(LiveQueryId handlerId cohortId sinkId) = mask_ $ do
|
2020-03-05 20:59:26 +03:00
|
|
|
mbCleanupIO <- STM.atomically $ do
|
2019-08-28 15:19:21 +03:00
|
|
|
detM <- getQueryDet
|
2021-09-24 01:56:37 +03:00
|
|
|
fmap join $
|
|
|
|
forM detM $ \(Poller cohorts ioState, cohort) ->
|
|
|
|
cleanHandlerC cohorts ioState cohort
|
2020-03-05 20:59:26 +03:00
|
|
|
sequence_ mbCleanupIO
|
2021-05-05 07:24:12 +03:00
|
|
|
liftIO $ EKG.Gauge.dec $ smActiveSubscriptions serverMetrics
|
2019-08-28 15:19:21 +03:00
|
|
|
where
|
|
|
|
lqMap = _lqsLiveQueryMap lqState
|
|
|
|
|
|
|
|
getQueryDet = do
|
|
|
|
pollerM <- STMMap.lookup handlerId lqMap
|
2021-09-24 01:56:37 +03:00
|
|
|
fmap join $
|
|
|
|
forM pollerM $ \poller -> do
|
|
|
|
cohortM <- TMap.lookup cohortId (_pCohorts poller)
|
|
|
|
return $ (poller,) <$> cohortM
|
2019-08-28 15:19:21 +03:00
|
|
|
|
|
|
|
cleanHandlerC cohortMap ioState handlerC = do
|
|
|
|
let curOps = _cExistingSubscribers handlerC
|
|
|
|
newOps = _cNewSubscribers handlerC
|
|
|
|
TMap.delete sinkId curOps
|
|
|
|
TMap.delete sinkId newOps
|
2021-09-24 01:56:37 +03:00
|
|
|
cohortIsEmpty <-
|
|
|
|
(&&)
|
|
|
|
<$> TMap.null curOps
|
|
|
|
<*> TMap.null newOps
|
2019-08-28 15:19:21 +03:00
|
|
|
when cohortIsEmpty $ TMap.delete cohortId cohortMap
|
|
|
|
handlerIsEmpty <- TMap.null cohortMap
|
2020-03-05 20:59:26 +03:00
|
|
|
-- when there is no need for handler i.e, this happens to be the last
|
|
|
|
-- operation, take the ref for the polling thread to cancel it
|
2019-08-28 15:19:21 +03:00
|
|
|
if handlerIsEmpty
|
|
|
|
then do
|
|
|
|
STMMap.delete handlerId lqMap
|
2020-03-05 20:59:26 +03:00
|
|
|
threadRefM <- fmap _pThread <$> STM.tryReadTMVar ioState
|
2021-09-24 01:56:37 +03:00
|
|
|
return $
|
|
|
|
Just $ -- deferred IO:
|
|
|
|
case threadRefM of
|
|
|
|
Just threadRef -> Immortal.stop threadRef
|
|
|
|
-- This would seem to imply addLiveQuery broke or a bug
|
|
|
|
-- elsewhere. Be paranoid and log:
|
|
|
|
Nothing ->
|
|
|
|
L.unLogger logger $
|
|
|
|
L.UnstructuredLog L.LevelError $
|
|
|
|
fromString $
|
|
|
|
"In removeLiveQuery no worker thread installed. Please report this as a bug: "
|
|
|
|
<> show lqId
|
2019-08-28 15:19:21 +03:00
|
|
|
else return Nothing
|
2021-03-31 13:39:01 +03:00
|
|
|
|
|
|
|
-- | An async action query whose relationships are refered to table in a source.
|
|
|
|
-- We need to generate an SQL statement with the action response and execute it
|
|
|
|
-- in the source database so as to fetch response joined with relationship rows.
|
|
|
|
-- For more details see Note [Resolving async action query]
|
2021-09-24 01:56:37 +03:00
|
|
|
data LiveAsyncActionQueryOnSource = LiveAsyncActionQueryOnSource
|
|
|
|
{ _laaqpCurrentLqId :: !LiveQueryId,
|
|
|
|
_laaqpPrevActionLogMap :: !ActionLogResponseMap,
|
|
|
|
-- | An IO action to restart the live query poller with updated action log responses fetched from metadata storage
|
|
|
|
-- Restarting a live query re-generates the SQL statement with new action log responses to send latest action
|
|
|
|
-- response to the client.
|
|
|
|
_laaqpRestartLq :: !(LiveQueryId -> ActionLogResponseMap -> IO (Maybe LiveQueryId))
|
2021-03-31 13:39:01 +03:00
|
|
|
}
|
|
|
|
|
2021-09-24 01:56:37 +03:00
|
|
|
data LiveAsyncActionQueryWithNoRelationships = LiveAsyncActionQueryWithNoRelationships
|
|
|
|
{ -- | An IO action to send response to the websocket client
|
|
|
|
_laaqwnrSendResponse :: !(ActionLogResponseMap -> IO ()),
|
|
|
|
-- | An IO action to send "completed" message to the websocket client
|
|
|
|
_laaqwnrSendCompleted :: !(IO ())
|
2021-03-31 13:39:01 +03:00
|
|
|
}
|
|
|
|
|
|
|
|
data LiveAsyncActionQuery
|
|
|
|
= LAAQNoRelationships !LiveAsyncActionQueryWithNoRelationships
|
|
|
|
| LAAQOnSourceDB !LiveAsyncActionQueryOnSource
|
|
|
|
|
2021-09-24 01:56:37 +03:00
|
|
|
data AsyncActionQueryLive = AsyncActionQueryLive
|
|
|
|
{ _aaqlActionIds :: !(NonEmpty ActionId),
|
|
|
|
-- | An IO action to send error message (in case of any exception) to the websocket client
|
|
|
|
_aaqlOnException :: !(QErr -> IO ()),
|
|
|
|
_aaqlLiveExecution :: !LiveAsyncActionQuery
|
2021-03-31 13:39:01 +03:00
|
|
|
}
|
|
|
|
|
|
|
|
-- | A share-able state map which stores an async action live query with it's subscription operation id
|
|
|
|
type AsyncActionSubscriptionState = TMap.TMap OperationId AsyncActionQueryLive
|
|
|
|
|
2021-09-24 01:56:37 +03:00
|
|
|
addAsyncActionLiveQuery ::
|
|
|
|
AsyncActionSubscriptionState ->
|
|
|
|
OperationId ->
|
|
|
|
NonEmpty ActionId ->
|
|
|
|
(QErr -> IO ()) ->
|
|
|
|
LiveAsyncActionQuery ->
|
|
|
|
IO ()
|
2021-03-31 13:39:01 +03:00
|
|
|
addAsyncActionLiveQuery queriesState opId actionIds onException liveQuery =
|
|
|
|
STM.atomically $
|
2021-09-24 01:56:37 +03:00
|
|
|
TMap.insert (AsyncActionQueryLive actionIds onException liveQuery) opId queriesState
|
2021-03-31 13:39:01 +03:00
|
|
|
|
2021-09-24 01:56:37 +03:00
|
|
|
removeAsyncActionLiveQuery ::
|
|
|
|
AsyncActionSubscriptionState -> OperationId -> IO ()
|
2021-03-31 13:39:01 +03:00
|
|
|
removeAsyncActionLiveQuery queriesState opId =
|
|
|
|
STM.atomically $ TMap.delete opId queriesState
|