Firely PubSub
Firely offers the PubSub plugin to enable other services to communicate with Firely Server on data changes asynchronously. Specifically, other applications can send commands to update FHIR resources in the database and subscribe to events published by the server whenever resources change. Both commands and events get communicated as messages via a message broker (RabbitMQ).
Using PubSub might provide several advantages:
It is quicker than communicating via the REST API as it does not involve authorization/authentication, and resource validation. PubSub assumes that all services communicating with Firely Server are internal and secure and the resources posted using ExecuteStorePlanCommand are correct FHIR resources, so they do not get validated.
This set-up also enables easy integration with other applications which can be written using technologies other than .NET. As long as these applications correctly implement communication via the message broker, they are able to communicate with Firely Server.
Having a message broker in the middle allows for building topologies where multiple applications can send commands and/or subscribe to events.
If Firely Server or any of the other applications communicating with it is down, the messages will aggregate in the message broker and get processed as soon as the service is up again.
Attention
Correct configuration and maintenance of the message broker is not part of the service provided by Firely. We strongly advise you to consider this setup carefully in order to prevent data loss.
Note
PubSub currently supports only RabbitMQ. AzureServiceBus support is coming later.
Note
PubSub can be tested using the evaluation license for Firely Server. It is also included in the enterprise license for Firely Server. Your license allows the use of PubSub if “http://fire.ly/vonk/plugins/pubsub” is included in the plugins list of the license file.
Configuration
You can enable PubSub by including the plugin in the pipeline options of the Firely Server appsettings.instance.json file:
"PipelineOptions": {
"PluginDirectory": "./plugins",
"Branches": [
{
"Path": "/",
"Include": [
...
"Vonk.Plugin.PubSub"
]
}
]
},
You can further adjust PubSub in the PubSub section of the appsettings.instance.json file:
"PubSub": {
"MessageBroker": {
"Host": "localhost", // The URL where the message broker can be found
"Username": "guest", // RabbitMQ username
"Password": "guest", // RabbitMQ password
"ApplicationQueueName": "FirelyServer", // The name of the message queue used by Firely Server
"VirtualHost": "/" // RabbitMQ virtual host; see https://www.rabbitmq.com/vhosts.html for details
},
// The section below contains configuration related to publishing events when data gets changed in Firely Server
// so that other services can sync with Firely Server. Note that this is only available for Firely Server
// instances that use SQL server (2016 and newer) as a repository database.
// As of yet, it cannot work in combination with MongoDB or SQLite.
"ResourceChangeNotifications": {
"SendLightEvents": false, // If enabled, FS will send out events on changes. These events will not contain the complete resource
"SendFullEvents": false, // If enabled, FS will send out events on changes. These events will contain the complete resource
"PollingIntervalSeconds": 5, // How often Firely Server will be polling the DB for changes
"MaxPublishBatchSize": 1000 // The maximum amount of resource changes that can be sent in a single message
}
},
Note
Enabling ResourceChangeNotifications requires one-time DB configuration to enable changes tracking. See SQL Server Tracking Initialization for the instructions.
Message types and formats
To establish communication between Firely Server and other applications the parties must share the same contract. Every message in PubSub contains data that can logically be split into two groups: an envelope and the actual payload. This section describes both parts.
Message Envelope
Firely Server uses a framework called MassTransit to interact with a message broker. If you want to integrate with Firely Server using PubSub, it is important that your messages are compatible with MassTransit. You can achieve this either by using a MassTransit library for your programming language (available for .NET) or by making sure the messages your application sends and consumes use the same schema as messages created by MassTransit.
MassTransit envelops the original domain-specific message payload and adds extra service information required for the proper routing of messages and some other helpful features.
For additional documentation on enveloping, please refer to the MassTransit documentation page.
See an example of a complete enveloped ExecuteStorePlanCommand
message that was sent to RabbitMQ below
Click to expand
At least the following fields must be included:
messageType - contains a message type (see below for the list of message types)
message - contains the original domain-specific message payload
headers - a list of message headers
responseAddress - optional, but if present for commands, specifies what exchange FS will use to communicate a result of the command
{
"messageId": "ea230000-90d6-1865-57a4-08dbd54cb610",
"requestId": "ea230000-90d6-1865-e314-08dbd54cb610",
"correlationId": null,
"conversationId": "ea230000-90d6-1865-c4a8-08dbd54cb810",
"initiatorId": null,
"sourceAddress": "rabbitmq://rabbitmq-host/source?temporary=true",
"destinationAddress": "rabbitmq://rabbitmq-host/Firely.Server.Contracts.Messages.V1:ExecuteStorePlanCommand",
"responseAddress": "rabbitmq://rabbitmq-host/response?temporary=true",
"faultAddress": null,
"messageType": [
"urn:message:Firely.Server.Contracts.Messages.V1:ExecuteStorePlanCommand"
],
"message": {
"instructions": [
{
"itemId": "Patient/1",
"resource": "{\"resourceType\":\"Patient\",\"id\":\"1\",\"meta\":{\"versionId\":\"1\"},\"name\":[{\"family\":\"Smith\"}]}",
"resourceType": null,
"resourceId": null,
"currentVersion": null,
"operation": "create"
}
]
},
"headers": {
"MT-Request-AcceptType": [
"urn:message:Firely.Server.Contracts.Messages.V1:ExecuteStorePlanResponse"
],
"fhir-release": "STU3"
}
}
ExecuteStorePlanCommand
This command can be sent to the message broker by your client to let Firely Server execute a batch of instructions to create, update, upsert, or delete resources that should be processed as a transaction, so either all of the instructions are performed, or none.
Note that this message should only contain one operation per resource (so per resource type + id) as the operations in the message are supposed to bring each resource involved to its desired final state, rather than reflect a set of operations that would present a history of operations on a resource.
Command
{
"messageType": [
"urn:message:Firely.Server.Contracts.Messages.V1:ExecuteStorePlanCommand"
],
"headers": {
"fhir-release": "R4"
},
"responseAddress": "rabbitmq://rabbitmq-host/response-exchange?temporary=true",
"message": {
"instructions": [
{
"itemId": "example-operation",
"resource": "{\"resourceType\":\"Patient\",\"id\":\"testid\",\"meta\":{\"versionId\":\"test\",\"lastUpdated\":\"2023-10-09T12:00:22.8990506+02:00\"},\"name\":[{\"family\":\"id=test\"}]}",
"resourceType": "Patient",
"resourceId": "testid",
"currentVersion": "test",
"operation": "create"
}
]
},
...
}
Metadata
messageType
- always[ "urn:message:Firely.Server.Contracts.Messages.V1:ExecuteStorePlanCommand" ]
headers.fhir-release
specifies the FHIR version, eitherSTU3
,R4
, orR5
responseAddress
- exchange that is going to be used by FS to communicate the result of the command (optional)
Message body
The ExecuteStorePlanCommand
message contains an array of instructions, where each instruction can contain the following fields:
itemId
- An identifier for this line in the plan. It is used to correlate the returned results of executing the plan to the item within the planresource
- The complete resource as a json string, this needs to be added in case of acreate
,update
, orupsert
eventresourceType
- The type of the resource you want to execute the operation onresourceId
- The id of the resource you want to execute the operation oncurrentVersion
- The optional expected current version (forupdate
,upsert
anddelete
operations)operation
- The operation to execute with the payload. The following operations can be used:create
- Request to create a new resource. The resource, including its id and metadata, is stored exactly as provided in the propertyResource
. Theid
,versionId
andlastUpdated
must be present. A resource with the same id should not yet exist for this operation to succeed.update
- Request to update an existing resource. The resource, including its id and metadata, is stored exactly as provided in the propertyResource
. Theid
,versionId
andlastUpdated
must be present. Optionally, acurrentVersion
can be provided for optimistic concurrency. A resource with the given id should already exist for this operation to succeed.upsert
- Request to upsert a resource. If the resource already exists, this operation is exactly the same as theupdate
above. Otherwise, this operation acts as acreate
.delete
- Requests to delete a resource referred to by the propertiesresourceType
andresourceId
if it exists, or nothing otherwise. Optionally, aCurrentVersion
can be provided for optimistic concurrency.
Response
If a client sending a ExecuteStorePlanCommand
message also specified a responseAddress
value, Firely Server will generate a response of type ExecuteStorePlanResponse
.
{
"messageType": [
"urn:message:Firely.Server.Contracts.Messages.V1:ExecuteStorePlanResponse"
],
"headers": {
"fhir-release": "R4"
},
"message": {
"errors": [
{
"itemId": "example-operation",
"status": {
"code": "badRequest",
"details": "BadRequestPayloadMissingLastUpdated"
},
"message": "No lastUpdated provided"
}
]
},
...
}
If Firely Server encounters errors when processing an ExecuteStorePlan
message, it will respond with the result of this processing by sending an ExecuteStorePlanResponse
message. This message will contain a list of StorePlanResultItems
, each containing the following fields:
Metadata
messageType
- always[ "urn:message:Firely.Server.Contracts.Messages.V1:ExecuteStorePlanResponse" ]
headers.fhir-release
specifies the FHIR version, eitherSTU3
,R4
, orR5
Message body
itemId
- Theitemid
of the instruction in the earlier sentExecuteStorePlan
that caused errorsstatus
- The outcome of the processing, together with details on the error:code
- a high-level indication of the result. Can contain one of the following values:success
- Operation has been completed successfullybadRequest
- The command contained an error. Refer tooperationStatus.details
for a more specific descriptionerror
- Operation failed because some business rules might have been violatedinternalServerError
- Operation failed due to an unexpected error in Firely Server
details
- a more detailed description of what went wrong. Possible values:BadRequestMissingItemId
BadRequestMissingResourceId
BadRequestPayloadMissingResourceId
BadRequestPayloadMissingVersionId
BadRequestPayloadMissingLastUpdated
BadRequestMissingResourceType
BadRequestMissingResourcePayload
BadRequestWrongPayloadFormat
BadRequestOperationNotSupported
CreationSucceeded
CreationFailedResourceAlreadyExists
CreationFailedVersionIdCannotBeReused
UpdateSucceeded
UpdateFailedResourceNotFound
UpdateFailedVersionIdMismatch
UpdateFailedVersionIdCannotBeReused
DeletionSucceeded
DeletionFailedVersionIdMismatch
message
- a human-readable string containing information about the outcome
RetrievePlanCommand
As opposed to the ExecuteStorePlanCommand
, which can only be used for create, update, upsert, or delete operations, the RetrievePlanCommand
can be sent by the client to retrieve a resource from Firely Server:
Command
{
"messageType": [
"urn:message:Firely.Server.Contracts.Messages.V1:RetrievePlanCommand"
],
"headers": {
"fhir-release": "R4"
},
"responseAddress": "rabbitmq://rabbitmq-host/response-exchange?temporary=true",
"message": {
"instructions": [
{
"itemId": "example-operation",
"reference": {
"resourceType": "Patient",
"resourceId": "test",
"version": null
}
}
]
},
...
}
Metadata
messageType
- always[ "urn:message:Firely.Server.Contracts.Messages.V1:RetrievePlanCommand" ]
headers.fhir-release
specifies the FHIR version, eitherSTU3
,R4
, orR5
responseAddress
- exchange that is going to be used by FS to communicate the result of the command
Message body
itemId
- An identifier for this line in the plan. Is used to correlate the retrieved resource in the result to this item within the planreference
- A reference to the resource that is to be retrievedresourceType
- The type of the resource that is to be retrievedresourceId
- The id of the resource that is to be retrievedversion
- Optionally the version of the resource that is to be retrieved
Response
If a client sending a RetrievePlanCommand
message also specified a responseAddress
value, Firely Server will generate a response of type RetrievePlanResponse
.
{
"messageType": [
"urn:message:Firely.Server.Contracts.Messages.V1:RetrievePlanResponse"
],
"headers": {
"fhir-release": "R4"
},
"message": {
"items": [
{
"itemId": "example-operation",
"resource": "{\"resourceType\":\"Patient\",\"id\":\"1\",\"meta\":{\"versionId\":\"2\",\"lastUpdated\":\"2023-01-01T00:00:00Z\"},\"name\":[{\"family\":\"Smith\"}]}",
"status": {
"code": "success",
"details": "Ok"
},
"message": "Retrieved."
}
]
},
...
}
Metadata
messageType
- always[ "urn:message:Firely.Server.Contracts.Messages.V1:RetrievePlanResponse" ]
headers.fhir-release
specifies the FHIR version, eitherSTU3
,R4
, orR5
Message body
This message type is the result that Firely Server sends to the message broker after ingesting a RetrievePlanCommand
. It contains the following fields:
itemId
- The itemid corresponding to the itemid in the originalRetrievePlanCommand
.resource
- If the ingestion of theRetrievePlanCommand
was successful this field will contain a flattened json of the resource that is to be retrieved.status
- The outcome of the processing, together with details on the error:code
- a high-level indication of the result. Can contain one of the following values:success
- Operation has been completed successfullybadRequest
- The command contained an error. Refer tooperationStatus.details
for a more specific descriptionerror
- Operation failed because some business rules might have been violatedinternalServerError
- Operation failed due to an unexpected error in Firely Server
details
- a more detailed description of what went wrong. Possible values:BadRequestMissingItemId
BadRequestMissingReference
ResourceNotFound
MatchingVersionNotFound
Ok
message
- Optional, this field may contain additional human-readable diagnostic information on the retrieve
ResourcesChangedEvent
If enabled, Firely Server can publish a ResourcesChangedEvent
when one or more resources get changed. Other clients can then subscribe to this event.
Attention
This functionality is not yet supported for SQLite or MongoDB.
Note
Publishing of this event is disabled by default and must be enabled in the configuration.
Event
{
"messageType": [
"urn:message:Firely.Server.Contracts.Messages.V1:ResourcesChangedEvent"
],
"headers": {
"fhir-release": "R4"
},
"message": {
"changes": [
{
"reference": {
"resourceType": "Patient",
"resourceId": "example-id",
"version": "59f47104-395a-4883-9689-259651939ca2"
},
"resource": "{\n \"resourceType\": \"Patient\",\n \"id\": \"example-id\",\n \"meta\": {\n \"versionId\": \"59f47104-395a-4883-9689-259651939ca2\",\n \"lastUpdated\": \"2023-10-26T15:39:44.319+00:00\"\n }\n}",
"changeType": "create"
}
]
},
...
}
Metadata
messageType
- alwaysurn:message:Firely.Server.Contracts.Messages.V1:ResourcesChangedEvent
headers.fhir-release
specifies the FHIR version, eitherSTU3
,R4
, orR5
Message body
reference
- A reference to the resource for which the change is communicatedresource
- A flattened json of the resource reflecting its state after the change was madechangeType
- The kind of change that was made, either acreate
,update
, ordelete
ResourcesChangedLightEvent
If enabled, Firely Server can also publish ResourcesChangedLightEvent
messages. This message type will contain information on the resource change but will not include the entire resource resource body. As it is with the ResourcesChangedEvent
, clients can subscribe to the corresponding message type ResourcesChangedLightEvent
.
Attention
This functionality is not yet supported for SQLite or MongoDB.
Note
Publishing of this event is disabled by default and must be enabled in the configuration.
Event
{
"messageType": [
"urn:message:Firely.Server.Contracts.Messages.V1:ResourcesChangedLightEvent"
],
"headers": {
"fhir-release": "R4"
},
"message": {
"changes": [
{
"reference": {
"resourceType": "Patient",
"resourceId": "fsiTestingPatient",
"version": "41098b04-68ce-4b04-bce2-2d3c738d24f7"
},
"changeType": "create"
}
]
},
...
}
Metadata
messageType
- alwaysurn:message:Firely.Server.Contracts.Messages.V1:ResourcesChangedLightEvent
headers.fhir-release
specifies the FHIR version, eitherSTU3
,R4
, orR5
Message body
reference
- A reference to the resource for which the change is communicatedchangeType
- The kind of change that was made, either acreate
,update
, ordelete
Message Routing
RabbitMQ
All applications involved in message exchange are connected to the same message broker. Hypothetically, every party can publish and consume messages of any type. However, in practice, it is far more common that applications are only interested in consuming specific types of messages. Scenarios covered by PubSub are no exception. RabbitMQ allows for flexible configuration of message routing by decoupling message producers from message consumers using primitives such as exchanges and queues. You can read more about them in the RabbitMQ documentation.
Events
If you want to subscribe to events from Firely Server, your application will need to create a queue bound to either or both of these exchanges:
Firely.Server.Contracts.Messages.V1:ResourcesChangedEvent
Firely.Server.Contracts.Messages.V1:ResourcesChangedLightEvent
Commands
Likewise, to send a command to Firely Server, your application needs to publish it to the corresponding exchange:
Firely.Server.Contracts.Messages.V1:ExecuteStorePlanCommand
Firely.Server.Contracts.Messages.V1:RetrievePlanCommand
If you are interested in the result of a command execution, your application should:
Create an exchange for capturing the response
Bind the exchange to the incoming queue of your application
Specify the exchange name in the
responseAddress
header of the command message (e.g.rabbitmq://rabbitmq-host/response-exchange-name?temporary=true
whereresponse-exchange-name
is a name of your exchange)Send the command
Listen for the response published by Firey Server
Database Tracking Initialization
SQL Server
If you want to enable publishing notifications whenever resources get changed in Firely Server and you use SQL Server, some initial configuration is required to enable tracking of changes in the DB. This can be done automatically by Firely Server or manually.
Automatic initialization
If you want Firely Server to do that configuration for you, based on your settings:
{
"SqlDbOptions": {
"ConnectionString": "...",
"AutoUpdateDatabase": true,
"AutoUpdateConnectionString" : "..."
},
...
}
The user mentioned in
ConnectionString
needs to have enough permissions toALTER DATABASE
, orAutoUpdateDatabase
is set totrue
andAutoUpdateConnectionString
user canALTER DATABASE
.
Manual initialization
Alternatively, you can initialize the tracking manually using the following script:
USE %YOUR_DB_NAME%
ALTER DATABASE %YOUR_DB_NAME%
SET CHANGE_TRACKING = ON
(CHANGE_RETENTION = 2 DAYS, AUTO_CLEANUP = ON)
ALTER TABLE vonk.entry
ENABLE CHANGE_TRACKING
CREATE TABLE vonk.ctdata
(
syncversion bigint
)
INSERT INTO vonk.ctdata (SYNCVERSION) VALUES (NULL)
Logging
To enable logging for PubSub, you can add the PubSub plugin to the override section of your logsettings.json file:
{
"Serilog": {
"Using": [ "Firely.Server" ],
"MinimumLevel": {
"Default": "Error",
"Override": {
...
"Vonk.Plugin.PubSub": "Information"
}
},
...
}