graphql-engine/server/src-lib/Hasura/Backends/BigQuery/Execute.hs

Ignoring revisions in .git-blame-ignore-revs. Click here to bypass and see the normal blame view.

914 lines
30 KiB
Haskell
Raw Normal View History

{-# LANGUAGE DuplicateRecordFields #-}
{-# LANGUAGE ExtendedDefaultRules #-}
{-# OPTIONS_GHC -fno-warn-type-defaults #-}
-- | Execute a Select query against the BigQuery REST API.
module Hasura.Backends.BigQuery.Execute
( executeSelect,
runExecute,
streamBigQuery,
executeBigQuery,
executeProblemMessage,
insertDataset,
deleteDataset,
BigQuery (..),
Execute,
ExecuteProblem (..),
FieldNameText (..),
OutputValue (..),
RecordSet (..),
ShowDetails (..),
Value (..),
)
where
import Control.Applicative
import Control.Concurrent.Extended (sleep)
import Control.Monad.Except
import Control.Monad.Reader
import Data.Aeson ((.!=), (.:), (.:?), (.=))
import Data.Aeson qualified as Aeson
import Data.Aeson.Types qualified as Aeson
import Data.ByteString.Lazy qualified as BL
import Data.Foldable
import Data.HashMap.Strict.InsOrd qualified as OMap
import Data.Maybe
import Data.Text qualified as T
import Data.Text.Lazy qualified as LT
import Data.Text.Lazy.Builder qualified as LT
import Data.Text.Lazy.Encoding qualified as LT
import Data.Text.Read qualified as TR
import Data.Time
import Data.Time.Format.ISO8601 (iso8601Show)
import Data.Vector (Vector)
import Data.Vector qualified as V
import GHC.Generics
import Hasura.Backends.BigQuery.Connection
import Hasura.Backends.BigQuery.Source
import Hasura.Backends.BigQuery.ToQuery qualified as ToQuery
import Hasura.Backends.BigQuery.Types as BigQuery
import Hasura.Prelude hiding (head, state, tail)
import Network.HTTP.Simple
import Network.HTTP.Types
--------------------------------------------------------------------------------
-- Types
-- | A set of records produced by the database. These are joined
-- together. There are all sorts of optimizations possible here, from
-- using a matrix/flat vector, unboxed sums for Value, etc. Presently
-- we choose a naive implementation in the interest of getting other
-- work done.
data RecordSet = RecordSet
{ rows :: !(Vector (InsOrdHashMap FieldNameText OutputValue)),
wantedFields :: !(Maybe [Text])
}
deriving (Show)
-- | As opposed to BigQuery.FieldName which is a qualified name, this
-- is just the unqualified text name itself.
newtype FieldNameText
= FieldNameText Text
deriving (Show, Ord, Eq, Hashable, Aeson.FromJSON, Aeson.ToJSONKey, IsString)
data OutputValue
= DecimalOutputValue !Decimal
| BigDecimalOutputValue !BigDecimal
| IntegerOutputValue !Int64
| FloatOutputValue !Float64
| GeographyOutputValue !Geography
| TextOutputValue !Text
| TimestampOutputValue !Timestamp
| DateOutputValue !Date
| TimeOutputValue !Time
| DatetimeOutputValue !Datetime
| BytesOutputValue !Base64
| BoolOutputValue !Bool
| ArrayOutputValue !(Vector OutputValue)
| RecordOutputValue !(InsOrdHashMap FieldNameText OutputValue)
| NullOutputValue -- TODO: Consider implications.
deriving (Show, Eq, Generic)
instance Hashable OutputValue
instance Aeson.ToJSON OutputValue where
toJSON = \case
NullOutputValue -> Aeson.toJSON Aeson.Null
DecimalOutputValue !i -> Aeson.toJSON i
BigDecimalOutputValue !i -> Aeson.toJSON i
FloatOutputValue !i -> Aeson.toJSON i
TextOutputValue !i -> Aeson.toJSON i
BytesOutputValue !i -> Aeson.toJSON i
DateOutputValue !i -> Aeson.toJSON i
TimestampOutputValue !i -> Aeson.toJSON i
TimeOutputValue !i -> Aeson.toJSON i
DatetimeOutputValue !i -> Aeson.toJSON i
GeographyOutputValue !i -> Aeson.toJSON i
BoolOutputValue !i -> Aeson.toJSON i
IntegerOutputValue !i -> Aeson.toJSON i
ArrayOutputValue !vector -> Aeson.toJSON vector
RecordOutputValue !record -> Aeson.toJSON record
data ExecuteReader = ExecuteReader
{ sourceConfig :: !BigQuerySourceConfig
}
data ExecuteProblem
= GetJobDecodeProblem String
| CreateQueryJobDecodeProblem String
| InsertDatasetDecodeProblem String
| ExecuteRunBigQueryProblem BigQueryProblem
| RESTRequestNonOK Status Aeson.Value
deriving (Generic)
-- | We use this to hide certain details from the front-end, while allowing
-- them in tests. We have not actually decided whether showing the details is
-- insecure, but until we decide otherwise, it's probably best to err on the side
-- of caution.
data ShowDetails = HideDetails | InsecurelyShowDetails
instance Aeson.ToJSON ExecuteProblem where
toJSON =
Aeson.object . \case
GetJobDecodeProblem err -> ["get_job_decode_problem" Aeson..= err]
CreateQueryJobDecodeProblem err -> ["create_query_job_decode_problem" Aeson..= err]
ExecuteRunBigQueryProblem problem -> ["execute_run_bigquery_problem" Aeson..= problem]
InsertDatasetDecodeProblem problem -> ["insert_dataset__bigquery_problem" Aeson..= problem]
RESTRequestNonOK _ resp -> ["rest_request_non_ok" Aeson..= resp]
executeProblemMessage :: ShowDetails -> ExecuteProblem -> Text
executeProblemMessage showDetails = \case
GetJobDecodeProblem err -> "Fetching BigQuery job status, cannot decode HTTP response; " <> tshow err
CreateQueryJobDecodeProblem err -> "Creating BigQuery job, cannot decode HTTP response: " <> tshow err
ExecuteRunBigQueryProblem _ -> "Cannot execute BigQuery request"
InsertDatasetDecodeProblem _ -> "Cannot create BigQuery dataset"
RESTRequestNonOK status body ->
let summary = "BigQuery HTTP request failed with status " <> tshow (statusCode status) <> " " <> tshow (statusMessage status)
in case showDetails of
HideDetails -> summary
InsecurelyShowDetails -> summary <> " and body:\n" <> LT.toStrict (LT.decodeUtf8 (Aeson.encode body))
-- | Execute monad; as queries are performed, the record sets are
-- stored in the map.
newtype Execute a = Execute
{ unExecute :: ReaderT ExecuteReader (ExceptT ExecuteProblem IO) a
}
deriving
( Functor,
Applicative,
Monad,
MonadReader ExecuteReader,
MonadIO,
MonadError ExecuteProblem
)
-- | Big query parameters must be accompanied by an explicit type
-- signature.
data BigQueryType
= DECIMAL
| INTEGER
| FLOAT
| BYTES
| STRING
| BOOL
| ARRAY BigQueryType
| GEOGRAPHY
| DATE
| TIMESTAMP
| DATETIME
| TIME
| BIGDECIMAL
deriving (Show, Eq)
data BigQuery = BigQuery
{ query :: !LT.Text,
parameters :: !(InsOrdHashMap ParameterName Parameter)
}
deriving (Show)
data Parameter = Parameter
{ typ :: !BigQueryType,
value :: !Value
}
deriving (Show)
newtype ParameterName
= ParameterName LT.Text
deriving (Show, Aeson.ToJSON, Ord, Eq, Hashable)
data BigQueryField = BigQueryField
{ name :: !FieldNameText,
typ :: !BigQueryFieldType,
mode :: !Mode
}
deriving (Show)
data BigQueryFieldType
= FieldSTRING
| FieldBYTES
| FieldINTEGER
| FieldFLOAT
| FieldBOOL
| FieldTIMESTAMP
| FieldDATE
| FieldTIME
| FieldDATETIME
| FieldGEOGRAPHY
| FieldDECIMAL
| FieldBIGDECIMAL
| FieldSTRUCT (Vector BigQueryField)
deriving (Show)
data Mode
= Nullable
| NotNullable
| Repeated
deriving (Show)
data IsNullable
= IsNullable
| IsRequired
--------------------------------------------------------------------------------
-- Constants
-- | Delay between attempts to get job results if the job is incomplete.
streamDelaySeconds :: DiffTime
streamDelaySeconds = 1
bigQueryProjectUrl :: Text -> String
bigQueryProjectUrl projectId =
"https://bigquery.googleapis.com/bigquery/v2/projects/" <> T.unpack projectId
--------------------------------------------------------------------------------
-- Executing the planned actions forest
runExecute ::
MonadIO m =>
BigQuerySourceConfig ->
Execute RecordSet ->
m (Either ExecuteProblem RecordSet)
runExecute sourceConfig m =
liftIO
( runExceptT
( runReaderT
(unExecute (m >>= getFinalRecordSet))
(ExecuteReader {sourceConfig})
)
)
executeSelect :: Select -> Execute RecordSet
executeSelect select = do
conn <- asks (_scConnection . sourceConfig)
recordSet <-
streamBigQuery conn (selectToBigQuery select) >>= liftEither
pure recordSet {wantedFields = selectFinalWantedFields select}
-- | This is needed to strip out unneeded fields (join keys) in the
-- final query. This is a relic of the data loader approach. A later
-- improvement would be to update the FromIr code to explicitly
-- reselect the query. But the purpose of this commit is to drop the
-- dataloader code and not modify the from IR code which is more
-- delicate.
getFinalRecordSet :: RecordSet -> Execute RecordSet
getFinalRecordSet recordSet =
pure
recordSet
{ rows =
fmap
( OMap.filterWithKey
( \(FieldNameText k) _ ->
maybe True (elem k) (wantedFields recordSet)
)
)
(rows recordSet)
}
--------------------------------------------------------------------------------
-- Make a big query from a select
selectToBigQuery :: Select -> BigQuery
selectToBigQuery select =
BigQuery
{ query = LT.toLazyText query,
parameters =
OMap.fromList
( map
( \(int, value) ->
( ParameterName (LT.toLazyText (ToQuery.paramName int)),
Parameter {typ = valueType value, value}
)
)
(OMap.toList params)
)
}
where
(query, params) =
ToQuery.renderBuilderPretty (ToQuery.fromSelect select)
--------------------------------------------------------------------------------
-- Type system
-- | Make a BigQuery type for the given value.
valueType :: Value -> BigQueryType
valueType =
\case
DecimalValue {} -> DECIMAL
BigDecimalValue {} -> BIGDECIMAL
IntegerValue {} -> INTEGER
FloatValue {} -> FLOAT
GeographyValue {} -> GEOGRAPHY
StringValue {} -> STRING
BytesValue {} -> BYTES
BoolValue {} -> BOOL
DatetimeValue {} -> DATETIME
TimeValue {} -> TIME
DateValue {} -> DATE
TimestampValue {} -> TIMESTAMP
ArrayValue values ->
ARRAY
( maybe
STRING
-- Above: If the array is null, it doesn't matter what type
-- the element is. So we put STRING.
valueType
(values V.!? 0)
-- Above: We base the type from the first element. Later,
-- we could add some kind of sanity check that they are all
-- the same type.
)
NullValue -> STRING
-- Above: If the value is null, it doesn't matter what type
-- the element is. So we put STRING.
--------------------------------------------------------------------------------
-- JSON serialization
-- | Make a JSON representation of the type of the given value.
valueToBigQueryJson :: Value -> Aeson.Value
valueToBigQueryJson = go
where
go =
\case
NullValue -> Aeson.Null -- TODO: I haven't tested whether BigQuery is happy with this null value.
DecimalValue i -> Aeson.object ["value" .= i]
BigDecimalValue i -> Aeson.object ["value" .= i]
IntegerValue i -> Aeson.object ["value" .= i]
FloatValue i -> Aeson.object ["value" .= i]
TimestampValue i -> Aeson.object ["value" .= i]
DateValue (Date i) -> Aeson.object ["value" .= i]
TimeValue (Time i) -> Aeson.object ["value" .= i]
DatetimeValue (Datetime i) -> Aeson.object ["value" .= i]
GeographyValue (Geography i) -> Aeson.object ["value" .= i]
StringValue i -> Aeson.object ["value" .= Aeson.String i]
BytesValue i -> Aeson.object ["value" .= i]
BoolValue i ->
Aeson.object
[ "value"
.= Aeson.String
( if i
then "true"
else "false"
)
]
ArrayValue vs ->
Aeson.object ["array_values" .= Aeson.Array (fmap go vs)]
--------------------------------------------------------------------------------
-- Execute a query as a job and stream the results into a record set
-- | TODO: WARNING: This function hasn't been tested on Big Data(tm),
-- and therefore I was unable to get BigQuery to produce paginated
-- results that would contain the 'pageToken' field in the JSON
-- response. Until that test has been done, we should consider this a
-- preliminary implementation.
streamBigQuery ::
(MonadIO m) => BigQueryConnection -> BigQuery -> m (Either ExecuteProblem RecordSet)
streamBigQuery conn bigquery = do
jobResult <- runExceptT $ createQueryJob conn bigquery
case jobResult of
Right job -> loop Nothing Nothing
where
loop pageToken mrecordSet = do
results <- getJobResults conn job Fetch {pageToken}
case results of
Left problem -> pure (Left problem)
Right
( JobComplete
JobResults
{ pageToken = mpageToken',
recordSet = recordSet'@RecordSet {rows = rows'}
}
) -> do
let extendedRecordSet =
case mrecordSet of
Nothing -> recordSet'
Just recordSet@RecordSet {rows} ->
(recordSet {rows = rows <> rows'})
case mpageToken' of
Nothing -> pure (Right extendedRecordSet)
Just pageToken' ->
loop (pure pageToken') (pure extendedRecordSet)
Right JobIncomplete {} -> do
liftIO (sleep streamDelaySeconds)
loop pageToken mrecordSet
Left e -> pure (Left e)
-- | Execute a query without expecting any output (e.g. CREATE TABLE or INSERT)
executeBigQuery :: MonadIO m => BigQueryConnection -> BigQuery -> m (Either ExecuteProblem ())
executeBigQuery conn bigquery = do
jobResult <- runExceptT $ createQueryJob conn bigquery
case jobResult of
Right job -> loop Nothing
where
loop mrecordSet = do
results <- getJobResults conn job Fetch {pageToken = Nothing}
case results of
Left problem -> pure (Left problem)
Right (JobComplete _) -> pure (Right ())
Right JobIncomplete {} -> do
liftIO (sleep streamDelaySeconds)
loop mrecordSet
Left e -> pure (Left e)
--------------------------------------------------------------------------------
-- Querying results from a job
data JobResults = JobResults
{ pageToken :: Maybe Text,
recordSet :: RecordSet
}
deriving (Show)
instance Aeson.FromJSON JobResults where
parseJSON =
Aeson.withObject
"JobResults"
( \o -> do
recordSet <- parseRecordSetPayload o
pageToken <-
fmap
( \mtoken -> do
token <- mtoken
guard (not (T.null token))
pure token
)
(o .:? "pageToken")
pure JobResults {..}
)
data JobResultsResponse
= JobIncomplete
| JobComplete JobResults
deriving (Show)
instance Aeson.FromJSON JobResultsResponse where
parseJSON j =
Aeson.withObject
"JobResultsResponse"
( \o -> do
kind <- o .: "kind"
if kind == ("bigquery#getQueryResultsResponse" :: Text)
then do
complete <- o .: "jobComplete"
if complete
then fmap JobComplete (Aeson.parseJSON j)
else pure JobIncomplete
else fail ("Invalid kind: " <> show kind)
)
j
data Fetch = Fetch
{ pageToken :: Maybe Text
}
deriving (Show)
-- | Get results of a job.
getJobResults ::
(MonadIO m) =>
BigQueryConnection ->
Job ->
Fetch ->
m (Either ExecuteProblem JobResultsResponse)
getJobResults conn Job {jobId, location} Fetch {pageToken} = runExceptT $ do
-- https://cloud.google.com/bigquery/docs/reference/rest/v2/jobs/get#query-parameters
let url =
"GET " <> bigQueryProjectUrl (_bqProjectId conn)
<> "/queries/"
<> T.unpack jobId
<> "?alt=json&prettyPrint=false"
<> "&location="
<> T.unpack location
<> "&"
<> T.unpack (encodeParams extraParameters)
req =
jsonRequestHeader (parseRequest_ url)
extraParameters = pageTokenParam
where
pageTokenParam =
case pageToken of
Nothing -> []
Just token -> [("pageToken", token)]
encodeParams = T.intercalate "&" . map (\(k, v) -> k <> "=" <> v)
resp <- runBigQueryExcept conn req
case getResponseStatusCode resp of
200 ->
Aeson.eitherDecode (getResponseBody resp)
`onLeft` (throwError . GetJobDecodeProblem)
_ ->
throwError $
RESTRequestNonOK
(getResponseStatus resp)
$ parseAsJsonOrText $ getResponseBody resp
--------------------------------------------------------------------------------
-- Creating jobs
data Job = Job
{ state :: !Text,
jobId :: !Text,
location :: !Text
}
deriving (Show)
instance Aeson.FromJSON Job where
parseJSON =
Aeson.withObject
"Job"
( \o -> do
kind <- o .: "kind"
if kind == ("bigquery#job" :: Text)
then do
state <- do
status <- o .: "status"
status .: "state"
(jobId, location) <- do
ref <- o .: "jobReference"
-- 'location' is needed in addition to 'jobId' to query a job's
-- status
(,) <$> ref .: "jobId" <*> ref .: "location"
pure Job {state, jobId, location}
else fail ("Invalid kind: " <> show kind)
)
-- | Make a Request return `JSON`
jsonRequestHeader :: Request -> Request
jsonRequestHeader =
setRequestHeader "Content-Type" ["application/json"]
-- | Create a job asynchronously.
createQueryJob :: (MonadError ExecuteProblem m, MonadIO m) => BigQueryConnection -> BigQuery -> m Job
createQueryJob conn BigQuery {..} = do
let url =
"POST " <> bigQueryProjectUrl (_bqProjectId conn)
<> "/jobs?alt=json&prettyPrint=false"
req =
jsonRequestHeader $
setRequestBodyLBS body $
parseRequest_ url
body =
Aeson.encode
( Aeson.object
[ "configuration"
.= Aeson.object
[ "jobType" .= "QUERY",
"query"
.= Aeson.object
[ "query" .= query,
"useLegacySql" .= False, -- Important, it makes `quotes` work properly.
"parameterMode" .= "NAMED",
"queryParameters"
.= map
( \(name, Parameter {..}) ->
Aeson.object
[ "name" .= Aeson.toJSON name,
"parameterType" .= Aeson.toJSON typ,
"parameterValue" .= valueToBigQueryJson value
]
)
(OMap.toList parameters)
]
]
]
)
resp <- runBigQueryExcept conn req
case getResponseStatusCode resp of
200 ->
Aeson.eitherDecode (getResponseBody resp)
`onLeft` (throwError . CreateQueryJobDecodeProblem)
_ ->
throwError $
RESTRequestNonOK
(getResponseStatus resp)
$ parseAsJsonOrText $ getResponseBody resp
data Dataset = Dataset
{ datasetId :: Text
}
deriving (Show)
instance Aeson.FromJSON Dataset where
parseJSON =
Aeson.withObject
"Dataset"
( \o -> do
datasetId <- o .: "id"
pure (Dataset datasetId)
)
-- | Delete a dataset
deleteDataset :: (MonadError ExecuteProblem m, MonadIO m) => BigQueryConnection -> Text -> m ()
deleteDataset conn datasetId = do
let url =
"DELETE " <> bigQueryProjectUrl (_bqProjectId conn)
<> "/datasets/"
<> T.unpack datasetId
let req = jsonRequestHeader (parseRequest_ url)
resp <- runBigQueryExcept conn req
case getResponseStatusCode resp of
204 -> pure ()
_ ->
throwError $
RESTRequestNonOK
(getResponseStatus resp)
$ parseAsJsonOrText $ getResponseBody resp
-- | Run request and map errors into ExecuteProblem
runBigQueryExcept ::
(MonadError ExecuteProblem m, MonadIO m) =>
BigQueryConnection ->
Request ->
m (Response BL.ByteString)
runBigQueryExcept conn req = do
runBigQuery conn req >>= \case
Right a -> pure a
Left e -> throwError (ExecuteRunBigQueryProblem e)
-- | Insert a new dataset
insertDataset :: (MonadError ExecuteProblem m, MonadIO m) => BigQueryConnection -> Text -> m Dataset
insertDataset conn datasetId =
do
let url =
"POST " <> bigQueryProjectUrl (_bqProjectId conn)
<> "/datasets?alt=json&prettyPrint=false"
req =
jsonRequestHeader $
setRequestBodyLBS body $
parseRequest_ url
body =
Aeson.encode
( Aeson.object
[ "id" .= datasetId,
"datasetReference"
.= Aeson.object
[ "datasetId" .= datasetId,
"projectId" .= _bqProjectId conn
]
]
)
resp <- runBigQueryExcept conn req
case getResponseStatusCode resp of
200 ->
Aeson.eitherDecode (getResponseBody resp)
`onLeft` (throwError . InsertDatasetDecodeProblem)
_ ->
throwError $
RESTRequestNonOK
(getResponseStatus resp)
$ parseAsJsonOrText $ getResponseBody resp
-- | Parse given @'ByteString' as JSON value. If not a valid JSON, encode to plain text.
parseAsJsonOrText :: BL.ByteString -> Aeson.Value
parseAsJsonOrText bytestring =
fromMaybe (Aeson.String $ lbsToTxt bytestring) $ Aeson.decode bytestring
--------------------------------------------------------------------------------
-- Consuming recordset from big query
parseRecordSetPayload :: Aeson.Object -> Aeson.Parser RecordSet
parseRecordSetPayload resp = do
mSchema <- resp .:? "schema"
columns <- maybe (pure V.empty) (.: "fields") mSchema :: Aeson.Parser (Vector BigQueryField)
rowsJSON <- fmap (fromMaybe V.empty) (resp .:? "rows" :: Aeson.Parser (Maybe (Vector Aeson.Value)))
rows <-
V.imapM
(\i row -> parseRow columns row Aeson.<?> Aeson.Index i)
rowsJSON
Aeson.<?> Aeson.Key "rows"
pure RecordSet {wantedFields = Nothing, rows}
--------------------------------------------------------------------------------
-- Schema-driven JSON deserialization
parseRow :: Vector BigQueryField -> Aeson.Value -> Aeson.Parser (InsOrdHashMap FieldNameText OutputValue)
parseRow columnTypes value = do
result <- parseBigQueryRow columnTypes value
case result of
RecordOutputValue row -> pure row
_ -> fail ("Expected a record when parsing a top-level row: " ++ show value)
-- | Parse a row, which at the top-level of the "rows" output has no
-- {"v":..} wrapper. But when appearing nestedly, does have the
-- wrapper. See 'parseBigQueryValue'.
parseBigQueryRow :: Vector BigQueryField -> Aeson.Value -> Aeson.Parser OutputValue
parseBigQueryRow columnTypes =
Aeson.withObject
"RECORD"
( \o -> do
fields <- o .: "f" Aeson.<?> Aeson.Key "RECORD"
values <-
sequence
( V.izipWith
( \i typ field ->
parseBigQueryField typ field Aeson.<?> Aeson.Index i
)
columnTypes
fields
)
Aeson.<?> Aeson.Key "f"
pure (RecordOutputValue (OMap.fromList (V.toList values)))
)
parseBigQueryValue :: IsNullable -> BigQueryFieldType -> Aeson.Value -> Aeson.Parser OutputValue
parseBigQueryValue isNullable fieldType object =
case fieldType of
FieldSTRUCT types ->
has_v isNullable (parseBigQueryRow types) object Aeson.<?> Aeson.Key "RECORD"
FieldDECIMAL ->
has_v isNullable (fmap DecimalOutputValue . Aeson.parseJSON) object
Aeson.<?> Aeson.Key "DECIMAL"
FieldBIGDECIMAL ->
has_v isNullable (fmap BigDecimalOutputValue . Aeson.parseJSON) object
Aeson.<?> Aeson.Key "BIGDECIMAL"
FieldINTEGER ->
has_v isNullable (fmap IntegerOutputValue . Aeson.parseJSON) object
Aeson.<?> Aeson.Key "INTEGER"
FieldDATE ->
has_v isNullable (fmap DateOutputValue . Aeson.parseJSON) object
Aeson.<?> Aeson.Key "DATE"
FieldTIME ->
has_v isNullable (fmap TimeOutputValue . Aeson.parseJSON) object
Aeson.<?> Aeson.Key "TIME"
FieldDATETIME ->
has_v isNullable (fmap DatetimeOutputValue . Aeson.parseJSON) object
Aeson.<?> Aeson.Key "DATETIME"
FieldTIMESTAMP ->
has_v isNullable (fmap TimestampOutputValue . parseTimestamp) object
Aeson.<?> Aeson.Key "TIMESTAMP"
FieldGEOGRAPHY ->
has_v isNullable (fmap GeographyOutputValue . Aeson.parseJSON) object
Aeson.<?> Aeson.Key "GEOGRAPHY"
FieldFLOAT ->
has_v isNullable (fmap FloatOutputValue . Aeson.parseJSON) object
Aeson.<?> Aeson.Key "FLOAT"
FieldBOOL ->
has_v isNullable (fmap (BoolOutputValue . (== "true")) . Aeson.parseJSON) object
Aeson.<?> Aeson.Key "BOOL"
FieldSTRING ->
has_v isNullable (fmap TextOutputValue . Aeson.parseJSON) object
Aeson.<?> Aeson.Key "STRING"
FieldBYTES ->
has_v isNullable (fmap BytesOutputValue . Aeson.parseJSON) object
Aeson.<?> Aeson.Key "BYTES"
-- | Parse upstream timestamp value in epoch milliseconds and convert it to calendar date time format
-- https://cloud.google.com/bigquery/docs/reference/standard-sql/data-types#timestamp_type
parseTimestamp :: Aeson.Value -> Aeson.Parser Timestamp
parseTimestamp =
fmap (Timestamp . utctimeToISO8601Text) . Aeson.withText "FieldTIMESTAMP" textToUTCTime
where
textToUTCTime :: Text -> Aeson.Parser UTCTime
textToUTCTime =
either fail (pure . flip addUTCTime (UTCTime (fromGregorian 1970 0 0) 0) . fst)
. (TR.rational :: TR.Reader NominalDiffTime)
utctimeToISO8601Text :: UTCTime -> Text
utctimeToISO8601Text = T.pack . iso8601Show
parseBigQueryField :: BigQueryField -> Aeson.Value -> Aeson.Parser (FieldNameText, OutputValue)
parseBigQueryField BigQueryField {name, typ, mode} value1 =
case mode of
Repeated ->
( do
values <- has_v_generic Aeson.parseJSON value1
outputs <-
V.imapM
( \i value2 ->
parseBigQueryValue IsRequired typ value2
Aeson.<?> Aeson.Index i
)
values
pure (name, ArrayOutputValue outputs)
)
Aeson.<?> Aeson.Key "REPEATED"
Nullable -> do
output <-
parseBigQueryValue IsNullable typ value1 Aeson.<?> Aeson.Key "NULLABLE"
pure (name, output)
NotNullable -> do
output <-
parseBigQueryValue IsRequired typ value1 Aeson.<?> Aeson.Key "REQUIRED"
pure (name, output)
-- Every value, after the top-level row, is wrapped in this.
has_v ::
IsNullable ->
(Aeson.Value -> Aeson.Parser OutputValue) ->
Aeson.Value ->
Aeson.Parser OutputValue
has_v isNullable f =
Aeson.withObject
"HAS_V"
( \o ->
o .: "v" >>= \v ->
case v of
Aeson.Null
| IsNullable <- isNullable -> pure NullOutputValue
_ -> f v Aeson.<?> Aeson.Key "v"
)
-- Every value, after the top-level row, is wrapped in this.
has_v_generic ::
(Aeson.Value -> Aeson.Parser a) ->
Aeson.Value ->
Aeson.Parser a
has_v_generic f =
Aeson.withObject
"HAS_V"
(\o -> o .: "v" >>= \v -> (f v Aeson.<?> Aeson.Key "v"))
--------------------------------------------------------------------------------
-- Generic JSON deserialization
instance Aeson.ToJSON BigQueryType where
toJSON =
\case
ARRAY t -> Aeson.object ["type" .= ("ARRAY" :: Text), "arrayType" .= t]
DECIMAL -> atomic "NUMERIC"
BIGDECIMAL -> atomic "BIGNUMERIC"
INTEGER -> atomic "INTEGER"
DATE -> atomic "DATE"
TIME -> atomic "TIME"
DATETIME -> atomic "DATETIME"
TIMESTAMP -> atomic "TIMESTAMP"
FLOAT -> atomic "FLOAT"
GEOGRAPHY -> atomic "GEOGRAPHY"
STRING -> atomic "STRING"
BYTES -> atomic "BYTES"
BOOL -> atomic "BOOL"
where
atomic ty = Aeson.object ["type" .= (ty :: Text)]
instance Aeson.FromJSON BigQueryField where
parseJSON =
Aeson.withObject
"BigQueryField"
( \o -> do
name <- o .: "name"
typ <-
do
flag :: Text <- o .: "type"
if
| flag == "NUMERIC" || flag == "DECIMAL" -> pure FieldDECIMAL
| flag == "BIGNUMERIC" || flag == "BIGDECIMAL" ->
pure FieldBIGDECIMAL
| flag == "INT64" || flag == "INTEGER" -> pure FieldINTEGER
| flag == "FLOAT64" || flag == "FLOAT" -> pure FieldFLOAT
| flag == "BOOLEAN" || flag == "BOOL" -> pure FieldBOOL
| flag == "STRING" -> pure FieldSTRING
| flag == "DATE" -> pure FieldDATE
| flag == "TIME" -> pure FieldTIME
| flag == "DATETIME" -> pure FieldDATETIME
| flag == "TIMESTAMP" -> pure FieldTIMESTAMP
| flag == "GEOGRAPHY" -> pure FieldGEOGRAPHY
| flag == "BYTES" -> pure FieldBYTES
| flag == "RECORD" || flag == "STRUCT" ->
do
fields <- o .: "fields"
pure (FieldSTRUCT fields)
| otherwise -> fail ("Unsupported field type: " ++ show flag)
mode <- o .:? "mode" .!= Nullable
pure BigQueryField {..}
)
instance Aeson.FromJSON Mode where
parseJSON j = do
s <- Aeson.parseJSON j
case s :: Text of
"NULLABLE" -> pure Nullable
"REPEATED" -> pure Repeated
_ -> pure NotNullable