server_pubsub.h 21 KB

123456789101112131415161718192021222324252627282930313233343536373839404142434445464748495051525354555657585960616263646566676869707172737475767778798081828384858687888990919293949596979899100101102103104105106107108109110111112113114115116117118119120121122123124125126127128129130131132133134135136137138139140141142143144145146147148149150151152153154155156157158159160161162163164165166167168169170171172173174175176177178179180181182183184185186187188189190191192193194195196197198199200201202203204205206207208209210211212213214215216217218219220221222223224225226227228229230231232233234235236237238239240241242243244245246247248249250251252253254255256257258259260261262263264265266267268269270271272273274275276277278279280281282283284285286287288289290291292293294295296297298299300301302303304305306307308309310311312313314315316317318319320321322323324325326327328329330331332333334335336337338339340341342343344345346347348349350351352353354355356357358359360361362363364365366367368369370371372373374375376377378379380381382383384385386387388389390391392393394395396397398399400401402403404405406407408409410411412413414415416417418419420421422423424425426427428429430431432433434435436437438439440441442443444445446447448449450451452453454455456457458459460461462463464465466467468469470471472473474475476477478479480481482483484485486487488489490491492493494495496497498499500501502503504505506507508509510511512513514515516517518519520521522523524525526527528529530531532533534535536537538539540
  1. /* This Source Code Form is subject to the terms of the Mozilla Public
  2. * License, v. 2.0. If a copy of the MPL was not distributed with this
  3. * file, You can obtain one at http://mozilla.org/MPL/2.0/.
  4. *
  5. * Copyright (c) 2017-2018 Fraunhofer IOSB (Author: Andreas Ebner)
  6. * Copyright (c) 2019 Kalycito Infotech Private Limited
  7. */
  8. #ifndef UA_SERVER_PUBSUB_H
  9. #define UA_SERVER_PUBSUB_H
  10. #include <open62541/server.h>
  11. _UA_BEGIN_DECLS
  12. #ifdef UA_ENABLE_PUBSUB
  13. /**
  14. * .. _pubsub:
  15. *
  16. * Publish/Subscribe
  17. * =================
  18. *
  19. * Work in progress!
  20. * This part will be a new chapter later.
  21. *
  22. * TODO: write general PubSub introduction
  23. *
  24. * The Publish/Subscribe (PubSub) extension for OPC UA enables fast and efficient
  25. * 1:m communication. The PubSub extension is protocol agnostic and can be used
  26. * with broker based protocols like MQTT and AMQP or brokerless implementations like UDP-Multicasting.
  27. *
  28. * The PubSub API uses the following scheme:
  29. *
  30. * 1. Create a configuration for the needed PubSub element.
  31. *
  32. * 2. Call the add[element] function and pass in the configuration.
  33. *
  34. * 3. The add[element] function returns the unique nodeId of the internally created element.
  35. *
  36. * Take a look on the PubSub Tutorials for mor details about the API usage.::
  37. *
  38. * +-----------+
  39. * | UA_Server |
  40. * +-----------+
  41. * | |
  42. * | |
  43. * | |
  44. * | | +----------------------+
  45. * | +--> UA_PubSubConnection | UA_Server_addPubSubConnection
  46. * | +----------------------+
  47. * | | |
  48. * | | | +----------------+
  49. * | | +----> UA_WriterGroup | UA_PubSubConnection_addWriterGroup
  50. * | | +----------------+
  51. * | | |
  52. * | | | +------------------+
  53. * | | +----> UA_DataSetWriter | UA_WriterGroup_addDataSetWriter +-+
  54. * | | +------------------+ |
  55. * | | |
  56. * | | +----------------+ | r
  57. * | +---------> UA_ReaderGroup | | e
  58. * | +----------------+ | f
  59. * | |
  60. * | +---------------------------+ |
  61. * +-------> UA_PubSubPublishedDataSet | UA_Server_addPublishedDataSet <-+
  62. * +---------------------------+
  63. * |
  64. * | +-----------------+
  65. * +----> UA_DataSetField | UA_PublishedDataSet_addDataSetField
  66. * +-----------------+
  67. *
  68. * PubSub compile flags
  69. * --------------------
  70. *
  71. * **UA_ENABLE_PUBSUB**
  72. * Enable the experimental OPC UA PubSub support. The option will include the PubSub UDP multicast plugin. Disabled by default.
  73. * **UA_ENABLE_PUBSUB_DELTAFRAMES**
  74. * The PubSub messages differentiate between keyframe (all published values contained) and deltaframe (only changed values contained) messages.
  75. * Deltaframe messages creation consumes some additional ressources and can be disabled with this flag. Disabled by default.
  76. * Compile the human-readable name of the StatusCodes into the binary. Disabled by default.
  77. * **UA_ENABLE_PUBSUB_INFORMATIONMODEL**
  78. * Enable the information model representation of the PubSub configuration. For more details take a look at the following section `PubSub Information Model Representation`. Disabled by default.
  79. *
  80. * PubSub Information Model Representation
  81. * ---------------------------------------
  82. * .. _pubsub_informationmodel:
  83. *
  84. * The complete PubSub configuration is available inside the information model.
  85. * The entry point is the node 'PublishSubscribe, located under the Server node.
  86. * The standard defines for PubSub no new Service set. The configuration can optionally
  87. * done over methods inside the information model. The information model representation
  88. * of the current PubSub configuration is generated automatically. This feature
  89. * can enabled/disable by changing the UA_ENABLE_PUBSUB_INFORMATIONMODEL option.
  90. *
  91. * Connections
  92. * -----------
  93. * The PubSub connections are the abstraction between the concrete transport protocol
  94. * and the PubSub functionality. It is possible to create multiple connections with
  95. * different transport protocols at runtime.
  96. *
  97. * Take a look on the PubSub Tutorials for mor details about the API usage.
  98. */
  99. typedef enum {
  100. UA_PUBSUB_PUBLISHERID_NUMERIC,
  101. UA_PUBSUB_PUBLISHERID_STRING
  102. } UA_PublisherIdType;
  103. typedef struct {
  104. UA_String name;
  105. UA_Boolean enabled;
  106. UA_PublisherIdType publisherIdType;
  107. union { /* std: valid types UInt or String */
  108. UA_UInt32 numeric;
  109. UA_String string;
  110. } publisherId;
  111. UA_String transportProfileUri;
  112. UA_Variant address;
  113. size_t connectionPropertiesSize;
  114. UA_KeyValuePair *connectionProperties;
  115. UA_Variant connectionTransportSettings;
  116. /* This flag is 'read only' and is set internally based on the PubSub state. */
  117. UA_Boolean configurationFrozen;
  118. } UA_PubSubConnectionConfig;
  119. UA_StatusCode UA_EXPORT
  120. UA_Server_addPubSubConnection(UA_Server *server,
  121. const UA_PubSubConnectionConfig *connectionConfig,
  122. UA_NodeId *connectionIdentifier);
  123. /* Returns a deep copy of the config */
  124. UA_StatusCode UA_EXPORT
  125. UA_Server_getPubSubConnectionConfig(UA_Server *server,
  126. const UA_NodeId connection,
  127. UA_PubSubConnectionConfig *config);
  128. /* Remove Connection, identified by the NodeId. Deletion of Connection
  129. * removes all contained WriterGroups and Writers. */
  130. UA_StatusCode UA_EXPORT
  131. UA_Server_removePubSubConnection(UA_Server *server, const UA_NodeId connection);
  132. /**
  133. * PublishedDataSets
  134. * -----------------
  135. * The PublishedDataSets (PDS) are containers for the published information. The
  136. * PDS contain the published variables and meta informations. The metadata is
  137. * commonly autogenerated or given as constant argument as part of the template
  138. * functions. The template functions are standard defined and intended for
  139. * configuration tools. You should normally create a empty PDS and call the
  140. * functions to add new fields. */
  141. /* The UA_PUBSUB_DATASET_PUBLISHEDITEMS has currently no additional members and
  142. * thus no dedicated config structure. */
  143. typedef enum {
  144. UA_PUBSUB_DATASET_PUBLISHEDITEMS,
  145. UA_PUBSUB_DATASET_PUBLISHEDEVENTS,
  146. UA_PUBSUB_DATASET_PUBLISHEDITEMS_TEMPLATE,
  147. UA_PUBSUB_DATASET_PUBLISHEDEVENTS_TEMPLATE,
  148. } UA_PublishedDataSetType;
  149. typedef struct {
  150. UA_DataSetMetaDataType metaData;
  151. size_t variablesToAddSize;
  152. UA_PublishedVariableDataType *variablesToAdd;
  153. } UA_PublishedDataItemsTemplateConfig;
  154. typedef struct {
  155. UA_NodeId eventNotfier;
  156. UA_ContentFilter filter;
  157. } UA_PublishedEventConfig;
  158. typedef struct {
  159. UA_DataSetMetaDataType metaData;
  160. UA_NodeId eventNotfier;
  161. size_t selectedFieldsSize;
  162. UA_SimpleAttributeOperand *selectedFields;
  163. UA_ContentFilter filter;
  164. } UA_PublishedEventTemplateConfig;
  165. /* Configuration structure for PublishedDataSet */
  166. typedef struct {
  167. UA_String name;
  168. UA_PublishedDataSetType publishedDataSetType;
  169. union {
  170. /* The UA_PUBSUB_DATASET_PUBLISHEDITEMS has currently no additional members
  171. * and thus no dedicated config structure.*/
  172. UA_PublishedDataItemsTemplateConfig itemsTemplate;
  173. UA_PublishedEventConfig event;
  174. UA_PublishedEventTemplateConfig eventTemplate;
  175. } config;
  176. /* This flag is 'read only' and is set internally based on the PubSub state. */
  177. UA_Boolean configurationFrozen;
  178. } UA_PublishedDataSetConfig;
  179. void UA_EXPORT
  180. UA_PublishedDataSetConfig_clear(UA_PublishedDataSetConfig *pdsConfig);
  181. typedef struct {
  182. UA_StatusCode addResult;
  183. size_t fieldAddResultsSize;
  184. UA_StatusCode *fieldAddResults;
  185. UA_ConfigurationVersionDataType configurationVersion;
  186. } UA_AddPublishedDataSetResult;
  187. UA_AddPublishedDataSetResult UA_EXPORT
  188. UA_Server_addPublishedDataSet(UA_Server *server,
  189. const UA_PublishedDataSetConfig *publishedDataSetConfig,
  190. UA_NodeId *pdsIdentifier);
  191. /* Returns a deep copy of the config */
  192. UA_StatusCode UA_EXPORT
  193. UA_Server_getPublishedDataSetConfig(UA_Server *server, const UA_NodeId pds,
  194. UA_PublishedDataSetConfig *config);
  195. /* Returns a deep copy of the DataSetMetaData for an specific PDS */
  196. UA_StatusCode UA_EXPORT
  197. UA_Server_getPublishedDataSetMetaData(UA_Server *server, const UA_NodeId pds,
  198. UA_DataSetMetaDataType *metaData);
  199. /* Remove PublishedDataSet, identified by the NodeId. Deletion of PDS removes
  200. * all contained and linked PDS Fields. Connected WriterGroups will be also
  201. * removed. */
  202. UA_StatusCode UA_EXPORT
  203. UA_Server_removePublishedDataSet(UA_Server *server, const UA_NodeId pds);
  204. /**
  205. * DataSetFields
  206. * -------------
  207. * The description of published variables is named DataSetField. Each
  208. * DataSetField contains the selection of one information model node. The
  209. * DataSetField has additional parameters for the publishing, sampling and error
  210. * handling process. */
  211. typedef struct{
  212. UA_ConfigurationVersionDataType configurationVersion;
  213. UA_String fieldNameAlias;
  214. UA_Boolean promotedField;
  215. UA_PublishedVariableDataType publishParameters;
  216. /* non std. field */
  217. UA_Boolean staticValueSourceEnabled;
  218. UA_DataValue staticValueSource;
  219. } UA_DataSetVariableConfig;
  220. typedef enum {
  221. UA_PUBSUB_DATASETFIELD_VARIABLE,
  222. UA_PUBSUB_DATASETFIELD_EVENT
  223. } UA_DataSetFieldType;
  224. typedef struct {
  225. UA_DataSetFieldType dataSetFieldType;
  226. union {
  227. /* events need other config later */
  228. UA_DataSetVariableConfig variable;
  229. } field;
  230. /* This flag is 'read only' and is set internally based on the PubSub state. */
  231. UA_Boolean configurationFrozen;
  232. } UA_DataSetFieldConfig;
  233. void UA_EXPORT
  234. UA_DataSetFieldConfig_clear(UA_DataSetFieldConfig *dataSetFieldConfig);
  235. typedef struct {
  236. UA_StatusCode result;
  237. UA_ConfigurationVersionDataType configurationVersion;
  238. } UA_DataSetFieldResult;
  239. UA_DataSetFieldResult UA_EXPORT
  240. UA_Server_addDataSetField(UA_Server *server,
  241. const UA_NodeId publishedDataSet,
  242. const UA_DataSetFieldConfig *fieldConfig,
  243. UA_NodeId *fieldIdentifier);
  244. /* Returns a deep copy of the config */
  245. UA_StatusCode UA_EXPORT
  246. UA_Server_getDataSetFieldConfig(UA_Server *server, const UA_NodeId dsf,
  247. UA_DataSetFieldConfig *config);
  248. UA_DataSetFieldResult UA_EXPORT
  249. UA_Server_removeDataSetField(UA_Server *server, const UA_NodeId dsf);
  250. /**
  251. * WriterGroup
  252. * -----------
  253. * All WriterGroups are created within a PubSubConnection and automatically
  254. * deleted if the connection is removed. The WriterGroup is primary used as
  255. * container for :ref:`dsw` and network message settings. The WriterGroup can be
  256. * imagined as producer of the network messages. The creation of network
  257. * messages is controlled by parameters like the publish interval, which is e.g.
  258. * contained in the WriterGroup. */
  259. typedef enum {
  260. UA_PUBSUB_ENCODING_BINARY,
  261. UA_PUBSUB_ENCODING_JSON,
  262. UA_PUBSUB_ENCODING_UADP
  263. } UA_PubSubEncodingType;
  264. /**
  265. * WriterGroup
  266. * -----------
  267. * The message publishing can be configured for realtime requirements. The RT-levels
  268. * go along with different requirements. The below listed levels can be configured:
  269. *
  270. * UA_PUBSUB_RT_NONE -
  271. * ---> Description: Default "none-RT" Mode
  272. * ---> Requirements: -
  273. * ---> Restrictions: -
  274. * UA_PUBSUB_RT_DIRECT_VALUE_ACCESS (Preview - not implemented)
  275. * ---> Description: Normally, the latest value for each DataSetField is read out of the information model. Within this RT-mode, the
  276. * value source of each field configured as static pointer to an DataValue. The publish cycle won't use call the server read function.
  277. * ---> Requirements: All fields must be configured with a 'staticValueSource'.
  278. * ---> Restrictions: -
  279. * UA_PUBSUB_RT_FIXED_LENGTH (Preview - not implemented)
  280. * ---> Description: All DataSetFields have a known, non-changing length. The server will pre-generate some
  281. * buffers and use only memcopy operations to generate requested PubSub packages.
  282. * ---> Requirements: DataSetFields with variable size can't be used within this mode.
  283. * ---> Restrictions: The configuration must be frozen and changes are not allowed while the WriterGroup is 'Operational'.
  284. * UA_PUBSUB_RT_DETERMINISTIC (Preview - not implemented)
  285. * ---> Description: -
  286. * ---> Requirements: -
  287. * ---> Restrictions: -
  288. *
  289. * WARNING! For hard real time requirements the underlying system must be rt-capable.
  290. *
  291. */
  292. typedef enum {
  293. UA_PUBSUB_RT_NONE = 0,
  294. UA_PUBSUB_RT_DIRECT_VALUE_ACCESS = 1,
  295. UA_PUBSUB_RT_FIXED_SIZE = 2,
  296. UA_PUBSUB_RT_DETERMINISTIC = 4,
  297. } UA_PubSubRTLevel;
  298. typedef struct {
  299. UA_String name;
  300. UA_Boolean enabled;
  301. UA_UInt16 writerGroupId;
  302. UA_Duration publishingInterval;
  303. UA_Double keepAliveTime;
  304. UA_Byte priority;
  305. UA_MessageSecurityMode securityMode;
  306. UA_ExtensionObject transportSettings;
  307. UA_ExtensionObject messageSettings;
  308. size_t groupPropertiesSize;
  309. UA_KeyValuePair *groupProperties;
  310. UA_PubSubEncodingType encodingMimeType;
  311. /* non std. config parameter. maximum count of embedded DataSetMessage in
  312. * one NetworkMessage */
  313. UA_UInt16 maxEncapsulatedDataSetMessageCount;
  314. /* This flag is 'read only' and is set internally based on the PubSub state. */
  315. UA_Boolean configurationFrozen;
  316. /* non std. field */
  317. UA_PubSubRTLevel rtLevel;
  318. } UA_WriterGroupConfig;
  319. void UA_EXPORT
  320. UA_WriterGroupConfig_clear(UA_WriterGroupConfig *writerGroupConfig);
  321. /* Add a new WriterGroup to an existing Connection */
  322. UA_StatusCode UA_EXPORT
  323. UA_Server_addWriterGroup(UA_Server *server, const UA_NodeId connection,
  324. const UA_WriterGroupConfig *writerGroupConfig,
  325. UA_NodeId *writerGroupIdentifier);
  326. /* Returns a deep copy of the config */
  327. UA_StatusCode UA_EXPORT
  328. UA_Server_getWriterGroupConfig(UA_Server *server, const UA_NodeId writerGroup,
  329. UA_WriterGroupConfig *config);
  330. UA_StatusCode UA_EXPORT
  331. UA_Server_updateWriterGroupConfig(UA_Server *server, UA_NodeId writerGroupIdentifier,
  332. const UA_WriterGroupConfig *config);
  333. UA_StatusCode UA_EXPORT
  334. UA_Server_removeWriterGroup(UA_Server *server, const UA_NodeId writerGroup);
  335. UA_StatusCode UA_EXPORT
  336. UA_Server_freezeWriterGroupConfiguration(UA_Server *server, const UA_NodeId writerGroup);
  337. UA_StatusCode UA_EXPORT
  338. UA_Server_unfreezeWriterGroupConfiguration(UA_Server *server, const UA_NodeId writerGroup);
  339. UA_StatusCode UA_EXPORT
  340. UA_Server_setWriterGroupOperational(UA_Server *server, const UA_NodeId writerGroup);
  341. UA_StatusCode UA_EXPORT
  342. UA_Server_setWriterGroupDisabled(UA_Server *server, const UA_NodeId writerGroup);
  343. /**
  344. * .. _dsw: UA_Boolean configurationFrozen;
  345. *
  346. * DataSetWriter
  347. * -------------
  348. * The DataSetWriters are the glue between the WriterGroups and the
  349. * PublishedDataSets. The DataSetWriter contain configuration parameters and
  350. * flags which influence the creation of DataSet messages. These messages are
  351. * encapsulated inside the network message. The DataSetWriter must be linked
  352. * with an existing PublishedDataSet and be contained within a WriterGroup. */
  353. typedef struct {
  354. UA_String name;
  355. UA_UInt16 dataSetWriterId;
  356. UA_DataSetFieldContentMask dataSetFieldContentMask;
  357. UA_UInt32 keyFrameCount;
  358. UA_ExtensionObject messageSettings;
  359. UA_ExtensionObject transportSettings;
  360. UA_String dataSetName;
  361. size_t dataSetWriterPropertiesSize;
  362. UA_KeyValuePair *dataSetWriterProperties;
  363. /* This flag is 'read only' and is set internally based on the PubSub state. */
  364. UA_Boolean configurationFrozen;
  365. } UA_DataSetWriterConfig;
  366. void UA_EXPORT
  367. UA_DataSetWriterConfig_clear(UA_DataSetWriterConfig *pdsConfig);
  368. /* Add a new DataSetWriter to a existing WriterGroup. The DataSetWriter must be
  369. * coupled with a PublishedDataSet on creation.
  370. *
  371. * Part 14, 7.1.5.2.1 defines: The link between the PublishedDataSet and
  372. * DataSetWriter shall be created when an instance of the DataSetWriterType is
  373. * created. */
  374. UA_StatusCode UA_EXPORT
  375. UA_Server_addDataSetWriter(UA_Server *server,
  376. const UA_NodeId writerGroup, const UA_NodeId dataSet,
  377. const UA_DataSetWriterConfig *dataSetWriterConfig,
  378. UA_NodeId *writerIdentifier);
  379. /* Returns a deep copy of the config */
  380. UA_StatusCode UA_EXPORT
  381. UA_Server_getDataSetWriterConfig(UA_Server *server, const UA_NodeId dsw,
  382. UA_DataSetWriterConfig *config);
  383. UA_StatusCode UA_EXPORT
  384. UA_Server_removeDataSetWriter(UA_Server *server, const UA_NodeId dsw);
  385. /**
  386. * DataSetReader
  387. * -------------
  388. * DataSetReader can receive NetworkMessages with the DataSet
  389. * of interest sent by the Publisher. DataSetReaders represent
  390. * the configuration necessary to receive and process DataSetMessages
  391. * on the Subscriber side */
  392. /* Parameters for PubSubSecurity */
  393. typedef struct {
  394. UA_Int32 securityMode; /* placeholder datatype 'MessageSecurityMode' */
  395. UA_String securityGroupId;
  396. size_t keyServersSize;
  397. UA_Int32 *keyServers;
  398. } UA_PubSubSecurityParameters;
  399. /* Parameters for PubSub DataSetReader Configuration */
  400. typedef struct {
  401. UA_String name;
  402. UA_Variant publisherId;
  403. UA_UInt16 writerGroupId;
  404. UA_UInt16 dataSetWriterId;
  405. UA_DataSetMetaDataType dataSetMetaData;
  406. UA_DataSetFieldContentMask dataSetFieldContentMask;
  407. UA_Double messageReceiveTimeout;
  408. UA_PubSubSecurityParameters securityParameters;
  409. UA_UadpDataSetReaderMessageDataType messageSettings;
  410. UA_TargetVariablesDataType subscribedDataSetTarget;
  411. } UA_DataSetReaderConfig;
  412. /* Update configuration to the dataSetReader */
  413. UA_StatusCode
  414. UA_Server_DataSetReader_updateConfig(UA_Server *server, UA_NodeId dataSetReaderIdentifier,
  415. UA_NodeId readerGroupIdentifier, const UA_DataSetReaderConfig *config);
  416. /* Get configuration of the dataSetReader */
  417. UA_StatusCode
  418. UA_Server_DataSetReader_getConfig(UA_Server *server, UA_NodeId dataSetReaderIdentifier,
  419. UA_DataSetReaderConfig *config);
  420. /* Return Status Code after creating TargetVariables in Subscriber AddressSpace
  421. * TargetVariables define a list of variable mappings between received DataSet fields
  422. * and the TargetVariables in the Subscriber AddressSpace */
  423. UA_StatusCode
  424. UA_Server_DataSetReader_createTargetVariables(UA_Server *server, UA_NodeId dataSetReaderIdentifier,
  425. UA_TargetVariablesDataType* targetVariables);
  426. /* To Do:Implementation of SubscribedDataSetMirrorType
  427. * UA_StatusCode
  428. * A_PubSubDataSetReader_createDataSetMirror(UA_Server *server, UA_NodeId dataSetReaderIdentifier,
  429. * UA_SubscribedDataSetMirrorDataType* mirror) */
  430. /**
  431. * ReaderGroup
  432. * -----------
  433. * All ReaderGroups are created within a PubSubConnection and automatically
  434. * deleted if the connection is removed. */
  435. /* ReaderGroup configuration */
  436. typedef struct {
  437. UA_String name;
  438. UA_PubSubSecurityParameters securityParameters;
  439. } UA_ReaderGroupConfig;
  440. /* Add DataSetReader to the ReaderGroup */
  441. UA_StatusCode
  442. UA_Server_addDataSetReader(UA_Server *server, UA_NodeId readerGroupIdentifier,
  443. const UA_DataSetReaderConfig *dataSetReaderConfig,
  444. UA_NodeId *readerIdentifier);
  445. /* Remove DataSetReader from ReaderGroup */
  446. UA_StatusCode
  447. UA_Server_removeDataSetReader(UA_Server *server, UA_NodeId readerIdentifier);
  448. /* To Do: Update Configuration of ReaderGroup
  449. * UA_StatusCode
  450. * UA_Server_ReaderGroup_updateConfig(UA_Server *server, UA_NodeId readerGroupIdentifier,
  451. * const UA_ReaderGroupConfig *config);
  452. */
  453. /* Get configuraiton of ReaderGroup */
  454. UA_StatusCode
  455. UA_Server_ReaderGroup_getConfig(UA_Server *server, UA_NodeId readerGroupIdentifier,
  456. UA_ReaderGroupConfig *config);
  457. /* Add ReaderGroup to the created connection */
  458. UA_StatusCode
  459. UA_Server_addReaderGroup(UA_Server *server, UA_NodeId connectionIdentifier,
  460. const UA_ReaderGroupConfig *readerGroupConfig,
  461. UA_NodeId *readerGroupIdentifier);
  462. /* Remove ReaderGroup from connection */
  463. UA_StatusCode
  464. UA_Server_removeReaderGroup(UA_Server *server, UA_NodeId groupIdentifier);
  465. #endif /* UA_ENABLE_PUBSUB */
  466. _UA_END_DECLS
  467. #endif /* UA_SERVER_PUBSUB_H */