GET Get Basic User Information
{{baseUrl}}/auth/:token/basicuserinformation
QUERY PARAMS

token
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/auth/:token/basicuserinformation");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/auth/:token/basicuserinformation")
require "http/client"

url = "{{baseUrl}}/auth/:token/basicuserinformation"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/auth/:token/basicuserinformation"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/auth/:token/basicuserinformation");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/auth/:token/basicuserinformation"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/auth/:token/basicuserinformation HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/auth/:token/basicuserinformation")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/auth/:token/basicuserinformation"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/auth/:token/basicuserinformation")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/auth/:token/basicuserinformation")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/auth/:token/basicuserinformation');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/auth/:token/basicuserinformation'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/auth/:token/basicuserinformation';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/auth/:token/basicuserinformation',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/auth/:token/basicuserinformation")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/auth/:token/basicuserinformation',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/auth/:token/basicuserinformation'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/auth/:token/basicuserinformation');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/auth/:token/basicuserinformation'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/auth/:token/basicuserinformation';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/auth/:token/basicuserinformation"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/auth/:token/basicuserinformation" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/auth/:token/basicuserinformation",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/auth/:token/basicuserinformation');

echo $response->getBody();
setUrl('{{baseUrl}}/auth/:token/basicuserinformation');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/auth/:token/basicuserinformation');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/auth/:token/basicuserinformation' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/auth/:token/basicuserinformation' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/auth/:token/basicuserinformation")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/auth/:token/basicuserinformation"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/auth/:token/basicuserinformation"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/auth/:token/basicuserinformation")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/auth/:token/basicuserinformation') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/auth/:token/basicuserinformation";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/auth/:token/basicuserinformation
http GET {{baseUrl}}/auth/:token/basicuserinformation
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/auth/:token/basicuserinformation
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/auth/:token/basicuserinformation")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST Log In
{{baseUrl}}/auth/login
BODY json

{
  "apiKey": "",
  "password": "",
  "username": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/auth/login");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"apiKey\": \"\",\n  \"password\": \"\",\n  \"username\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/auth/login" {:content-type :json
                                                       :form-params {:apiKey ""
                                                                     :password ""
                                                                     :username ""}})
require "http/client"

url = "{{baseUrl}}/auth/login"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"apiKey\": \"\",\n  \"password\": \"\",\n  \"username\": \"\"\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/auth/login"),
    Content = new StringContent("{\n  \"apiKey\": \"\",\n  \"password\": \"\",\n  \"username\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/auth/login");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"apiKey\": \"\",\n  \"password\": \"\",\n  \"username\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/auth/login"

	payload := strings.NewReader("{\n  \"apiKey\": \"\",\n  \"password\": \"\",\n  \"username\": \"\"\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/auth/login HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 54

{
  "apiKey": "",
  "password": "",
  "username": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/auth/login")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"apiKey\": \"\",\n  \"password\": \"\",\n  \"username\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/auth/login"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"apiKey\": \"\",\n  \"password\": \"\",\n  \"username\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"apiKey\": \"\",\n  \"password\": \"\",\n  \"username\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/auth/login")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/auth/login")
  .header("content-type", "application/json")
  .body("{\n  \"apiKey\": \"\",\n  \"password\": \"\",\n  \"username\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  apiKey: '',
  password: '',
  username: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/auth/login');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/auth/login',
  headers: {'content-type': 'application/json'},
  data: {apiKey: '', password: '', username: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/auth/login';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"apiKey":"","password":"","username":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/auth/login',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "apiKey": "",\n  "password": "",\n  "username": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"apiKey\": \"\",\n  \"password\": \"\",\n  \"username\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/auth/login")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/auth/login',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({apiKey: '', password: '', username: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/auth/login',
  headers: {'content-type': 'application/json'},
  body: {apiKey: '', password: '', username: ''},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/auth/login');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  apiKey: '',
  password: '',
  username: ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'POST',
  url: '{{baseUrl}}/auth/login',
  headers: {'content-type': 'application/json'},
  data: {apiKey: '', password: '', username: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/auth/login';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"apiKey":"","password":"","username":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"apiKey": @"",
                              @"password": @"",
                              @"username": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/auth/login"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/auth/login" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"apiKey\": \"\",\n  \"password\": \"\",\n  \"username\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/auth/login",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'apiKey' => '',
    'password' => '',
    'username' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/auth/login', [
  'body' => '{
  "apiKey": "",
  "password": "",
  "username": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/auth/login');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'apiKey' => '',
  'password' => '',
  'username' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'apiKey' => '',
  'password' => '',
  'username' => ''
]));
$request->setRequestUrl('{{baseUrl}}/auth/login');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/auth/login' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "apiKey": "",
  "password": "",
  "username": ""
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/auth/login' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "apiKey": "",
  "password": "",
  "username": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"apiKey\": \"\",\n  \"password\": \"\",\n  \"username\": \"\"\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/auth/login", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/auth/login"

payload = {
    "apiKey": "",
    "password": "",
    "username": ""
}
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/auth/login"

payload <- "{\n  \"apiKey\": \"\",\n  \"password\": \"\",\n  \"username\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/auth/login")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"apiKey\": \"\",\n  \"password\": \"\",\n  \"username\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/auth/login') do |req|
  req.body = "{\n  \"apiKey\": \"\",\n  \"password\": \"\",\n  \"username\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/auth/login";

    let payload = json!({
        "apiKey": "",
        "password": "",
        "username": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/auth/login \
  --header 'content-type: application/json' \
  --data '{
  "apiKey": "",
  "password": "",
  "username": ""
}'
echo '{
  "apiKey": "",
  "password": "",
  "username": ""
}' |  \
  http POST {{baseUrl}}/auth/login \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "apiKey": "",\n  "password": "",\n  "username": ""\n}' \
  --output-document \
  - {{baseUrl}}/auth/login
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "apiKey": "",
  "password": "",
  "username": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/auth/login")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
DELETE Log Out
{{baseUrl}}/auth/logout/:token
QUERY PARAMS

token
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/auth/logout/:token");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/auth/logout/:token")
require "http/client"

url = "{{baseUrl}}/auth/logout/:token"

response = HTTP::Client.delete url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Delete,
    RequestUri = new Uri("{{baseUrl}}/auth/logout/:token"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/auth/logout/:token");
var request = new RestRequest("", Method.Delete);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/auth/logout/:token"

	req, _ := http.NewRequest("DELETE", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/auth/logout/:token HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/auth/logout/:token")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/auth/logout/:token"))
    .method("DELETE", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/auth/logout/:token")
  .delete(null)
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/auth/logout/:token")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('DELETE', '{{baseUrl}}/auth/logout/:token');

xhr.send(data);
import axios from 'axios';

const options = {method: 'DELETE', url: '{{baseUrl}}/auth/logout/:token'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/auth/logout/:token';
const options = {method: 'DELETE'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/auth/logout/:token',
  method: 'DELETE',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/auth/logout/:token")
  .delete(null)
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/auth/logout/:token',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'DELETE', url: '{{baseUrl}}/auth/logout/:token'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('DELETE', '{{baseUrl}}/auth/logout/:token');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {method: 'DELETE', url: '{{baseUrl}}/auth/logout/:token'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/auth/logout/:token';
const options = {method: 'DELETE'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/auth/logout/:token"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"DELETE"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/auth/logout/:token" in

Client.call `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/auth/logout/:token",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/auth/logout/:token');

echo $response->getBody();
setUrl('{{baseUrl}}/auth/logout/:token');
$request->setMethod(HTTP_METH_DELETE);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/auth/logout/:token');
$request->setRequestMethod('DELETE');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/auth/logout/:token' -Method DELETE 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/auth/logout/:token' -Method DELETE 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("DELETE", "/baseUrl/auth/logout/:token")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/auth/logout/:token"

response = requests.delete(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/auth/logout/:token"

response <- VERB("DELETE", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/auth/logout/:token")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/auth/logout/:token') do |req|
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/auth/logout/:token";

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("DELETE").unwrap(), url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request DELETE \
  --url {{baseUrl}}/auth/logout/:token
http DELETE {{baseUrl}}/auth/logout/:token
wget --quiet \
  --method DELETE \
  --output-document \
  - {{baseUrl}}/auth/logout/:token
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/auth/logout/:token")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "DELETE"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET Get Observations of Multiple Types For a User
{{baseUrl}}/user/:userId/observations
QUERY PARAMS

code
limit
offset
orderDirection
userId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userId/observations?code=&limit=&offset=&orderDirection=");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userId/observations" {:query-params {:code ""
                                                                                    :limit ""
                                                                                    :offset ""
                                                                                    :orderDirection ""}})
require "http/client"

url = "{{baseUrl}}/user/:userId/observations?code=&limit=&offset=&orderDirection="

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userId/observations?code=&limit=&offset=&orderDirection="),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userId/observations?code=&limit=&offset=&orderDirection=");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userId/observations?code=&limit=&offset=&orderDirection="

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userId/observations?code=&limit=&offset=&orderDirection= HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userId/observations?code=&limit=&offset=&orderDirection=")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userId/observations?code=&limit=&offset=&orderDirection="))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userId/observations?code=&limit=&offset=&orderDirection=")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userId/observations?code=&limit=&offset=&orderDirection=")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userId/observations?code=&limit=&offset=&orderDirection=');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userId/observations',
  params: {code: '', limit: '', offset: '', orderDirection: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userId/observations?code=&limit=&offset=&orderDirection=';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userId/observations?code=&limit=&offset=&orderDirection=',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userId/observations?code=&limit=&offset=&orderDirection=")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userId/observations?code=&limit=&offset=&orderDirection=',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userId/observations',
  qs: {code: '', limit: '', offset: '', orderDirection: ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userId/observations');

req.query({
  code: '',
  limit: '',
  offset: '',
  orderDirection: ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userId/observations',
  params: {code: '', limit: '', offset: '', orderDirection: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userId/observations?code=&limit=&offset=&orderDirection=';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userId/observations?code=&limit=&offset=&orderDirection="]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userId/observations?code=&limit=&offset=&orderDirection=" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userId/observations?code=&limit=&offset=&orderDirection=",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userId/observations?code=&limit=&offset=&orderDirection=');

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userId/observations');
$request->setMethod(HTTP_METH_GET);

$request->setQueryData([
  'code' => '',
  'limit' => '',
  'offset' => '',
  'orderDirection' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userId/observations');
$request->setRequestMethod('GET');
$request->setQuery(new http\QueryString([
  'code' => '',
  'limit' => '',
  'offset' => '',
  'orderDirection' => ''
]));

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userId/observations?code=&limit=&offset=&orderDirection=' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userId/observations?code=&limit=&offset=&orderDirection=' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/user/:userId/observations?code=&limit=&offset=&orderDirection=")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userId/observations"

querystring = {"code":"","limit":"","offset":"","orderDirection":""}

response = requests.get(url, params=querystring)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userId/observations"

queryString <- list(
  code = "",
  limit = "",
  offset = "",
  orderDirection = ""
)

response <- VERB("GET", url, query = queryString, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userId/observations?code=&limit=&offset=&orderDirection=")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userId/observations') do |req|
  req.params['code'] = ''
  req.params['limit'] = ''
  req.params['offset'] = ''
  req.params['orderDirection'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userId/observations";

    let querystring = [
        ("code", ""),
        ("limit", ""),
        ("offset", ""),
        ("orderDirection", ""),
    ];

    let client = reqwest::Client::new();
    let response = client.get(url)
        .query(&querystring)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url '{{baseUrl}}/user/:userId/observations?code=&limit=&offset=&orderDirection='
http GET '{{baseUrl}}/user/:userId/observations?code=&limit=&offset=&orderDirection='
wget --quiet \
  --method GET \
  --output-document \
  - '{{baseUrl}}/user/:userId/observations?code=&limit=&offset=&orderDirection='
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userId/observations?code=&limit=&offset=&orderDirection=")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET Get Observations of a Certain Type For a User
{{baseUrl}}/user/:userId/observations/:code
QUERY PARAMS

userId
code
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userId/observations/:code");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userId/observations/:code")
require "http/client"

url = "{{baseUrl}}/user/:userId/observations/:code"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userId/observations/:code"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userId/observations/:code");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userId/observations/:code"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userId/observations/:code HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userId/observations/:code")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userId/observations/:code"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userId/observations/:code")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userId/observations/:code")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userId/observations/:code');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userId/observations/:code'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userId/observations/:code';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userId/observations/:code',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userId/observations/:code")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userId/observations/:code',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userId/observations/:code'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userId/observations/:code');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userId/observations/:code'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userId/observations/:code';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userId/observations/:code"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userId/observations/:code" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userId/observations/:code",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userId/observations/:code');

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userId/observations/:code');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userId/observations/:code');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userId/observations/:code' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userId/observations/:code' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/user/:userId/observations/:code")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userId/observations/:code"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userId/observations/:code"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userId/observations/:code")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userId/observations/:code') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userId/observations/:code";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userId/observations/:code
http GET {{baseUrl}}/user/:userId/observations/:code
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/user/:userId/observations/:code
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userId/observations/:code")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET Get patient entered Observations of a Certain Type For a User
{{baseUrl}}/user/:userId/observations/:code/patiententered
QUERY PARAMS

userId
code
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userId/observations/:code/patiententered");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userId/observations/:code/patiententered")
require "http/client"

url = "{{baseUrl}}/user/:userId/observations/:code/patiententered"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userId/observations/:code/patiententered"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userId/observations/:code/patiententered");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userId/observations/:code/patiententered"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userId/observations/:code/patiententered HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userId/observations/:code/patiententered")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userId/observations/:code/patiententered"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userId/observations/:code/patiententered")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userId/observations/:code/patiententered")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userId/observations/:code/patiententered');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userId/observations/:code/patiententered'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userId/observations/:code/patiententered';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userId/observations/:code/patiententered',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userId/observations/:code/patiententered")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userId/observations/:code/patiententered',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userId/observations/:code/patiententered'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userId/observations/:code/patiententered');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userId/observations/:code/patiententered'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userId/observations/:code/patiententered';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userId/observations/:code/patiententered"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userId/observations/:code/patiententered" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userId/observations/:code/patiententered",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userId/observations/:code/patiententered');

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userId/observations/:code/patiententered');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userId/observations/:code/patiententered');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userId/observations/:code/patiententered' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userId/observations/:code/patiententered' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/user/:userId/observations/:code/patiententered")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userId/observations/:code/patiententered"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userId/observations/:code/patiententered"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userId/observations/:code/patiententered")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userId/observations/:code/patiententered') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userId/observations/:code/patiententered";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userId/observations/:code/patiententered
http GET {{baseUrl}}/user/:userId/observations/:code/patiententered
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/user/:userId/observations/:code/patiententered
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userId/observations/:code/patiententered")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET Get Available Observations Types For a User
{{baseUrl}}/user/:userId/availableobservationheadings
QUERY PARAMS

userId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userId/availableobservationheadings");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userId/availableobservationheadings")
require "http/client"

url = "{{baseUrl}}/user/:userId/availableobservationheadings"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userId/availableobservationheadings"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userId/availableobservationheadings");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userId/availableobservationheadings"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userId/availableobservationheadings HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userId/availableobservationheadings")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userId/availableobservationheadings"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userId/availableobservationheadings")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userId/availableobservationheadings")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userId/availableobservationheadings');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userId/availableobservationheadings'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userId/availableobservationheadings';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userId/availableobservationheadings',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userId/availableobservationheadings")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userId/availableobservationheadings',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userId/availableobservationheadings'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userId/availableobservationheadings');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userId/availableobservationheadings'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userId/availableobservationheadings';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userId/availableobservationheadings"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userId/availableobservationheadings" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userId/availableobservationheadings",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userId/availableobservationheadings');

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userId/availableobservationheadings');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userId/availableobservationheadings');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userId/availableobservationheadings' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userId/availableobservationheadings' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/user/:userId/availableobservationheadings")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userId/availableobservationheadings"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userId/availableobservationheadings"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userId/availableobservationheadings")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userId/availableobservationheadings') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userId/availableobservationheadings";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userId/availableobservationheadings
http GET {{baseUrl}}/user/:userId/availableobservationheadings
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/user/:userId/availableobservationheadings
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userId/availableobservationheadings")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET Get Available Patient Entered Observations Types For a User
{{baseUrl}}/user/:userId/patiententeredobservationheadings
QUERY PARAMS

userId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userId/patiententeredobservationheadings");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userId/patiententeredobservationheadings")
require "http/client"

url = "{{baseUrl}}/user/:userId/patiententeredobservationheadings"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userId/patiententeredobservationheadings"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userId/patiententeredobservationheadings");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userId/patiententeredobservationheadings"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userId/patiententeredobservationheadings HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userId/patiententeredobservationheadings")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userId/patiententeredobservationheadings"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userId/patiententeredobservationheadings")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userId/patiententeredobservationheadings")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userId/patiententeredobservationheadings');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userId/patiententeredobservationheadings'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userId/patiententeredobservationheadings';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userId/patiententeredobservationheadings',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userId/patiententeredobservationheadings")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userId/patiententeredobservationheadings',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userId/patiententeredobservationheadings'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userId/patiententeredobservationheadings');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userId/patiententeredobservationheadings'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userId/patiententeredobservationheadings';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userId/patiententeredobservationheadings"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userId/patiententeredobservationheadings" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userId/patiententeredobservationheadings",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userId/patiententeredobservationheadings');

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userId/patiententeredobservationheadings');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userId/patiententeredobservationheadings');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userId/patiententeredobservationheadings' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userId/patiententeredobservationheadings' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/user/:userId/patiententeredobservationheadings")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userId/patiententeredobservationheadings"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userId/patiententeredobservationheadings"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userId/patiententeredobservationheadings")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userId/patiententeredobservationheadings') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userId/patiententeredobservationheadings";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userId/patiententeredobservationheadings
http GET {{baseUrl}}/user/:userId/patiententeredobservationheadings
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/user/:userId/patiententeredobservationheadings
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userId/patiententeredobservationheadings")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET Get Basic Patient Information
{{baseUrl}}/patient/:userId/basic
QUERY PARAMS

userId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/patient/:userId/basic");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/patient/:userId/basic")
require "http/client"

url = "{{baseUrl}}/patient/:userId/basic"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/patient/:userId/basic"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/patient/:userId/basic");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/patient/:userId/basic"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/patient/:userId/basic HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/patient/:userId/basic")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/patient/:userId/basic"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/patient/:userId/basic")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/patient/:userId/basic")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/patient/:userId/basic');

xhr.send(data);
import axios from 'axios';

const options = {method: 'GET', url: '{{baseUrl}}/patient/:userId/basic'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/patient/:userId/basic';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/patient/:userId/basic',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/patient/:userId/basic")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/patient/:userId/basic',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'GET', url: '{{baseUrl}}/patient/:userId/basic'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/patient/:userId/basic');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {method: 'GET', url: '{{baseUrl}}/patient/:userId/basic'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/patient/:userId/basic';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/patient/:userId/basic"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/patient/:userId/basic" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/patient/:userId/basic",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/patient/:userId/basic');

echo $response->getBody();
setUrl('{{baseUrl}}/patient/:userId/basic');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/patient/:userId/basic');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/patient/:userId/basic' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/patient/:userId/basic' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/patient/:userId/basic")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/patient/:userId/basic"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/patient/:userId/basic"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/patient/:userId/basic")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/patient/:userId/basic') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/patient/:userId/basic";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/patient/:userId/basic
http GET {{baseUrl}}/patient/:userId/basic
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/patient/:userId/basic
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/patient/:userId/basic")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET getPatientManagement
{{baseUrl}}/patientmanagement/:userId/group/:groupId/identifier/:identifierId
QUERY PARAMS

userId
groupId
identifierId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/patientmanagement/:userId/group/:groupId/identifier/:identifierId");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/patientmanagement/:userId/group/:groupId/identifier/:identifierId")
require "http/client"

url = "{{baseUrl}}/patientmanagement/:userId/group/:groupId/identifier/:identifierId"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/patientmanagement/:userId/group/:groupId/identifier/:identifierId"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/patientmanagement/:userId/group/:groupId/identifier/:identifierId");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/patientmanagement/:userId/group/:groupId/identifier/:identifierId"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/patientmanagement/:userId/group/:groupId/identifier/:identifierId HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/patientmanagement/:userId/group/:groupId/identifier/:identifierId")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/patientmanagement/:userId/group/:groupId/identifier/:identifierId"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/patientmanagement/:userId/group/:groupId/identifier/:identifierId")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/patientmanagement/:userId/group/:groupId/identifier/:identifierId")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/patientmanagement/:userId/group/:groupId/identifier/:identifierId');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/patientmanagement/:userId/group/:groupId/identifier/:identifierId'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/patientmanagement/:userId/group/:groupId/identifier/:identifierId';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/patientmanagement/:userId/group/:groupId/identifier/:identifierId',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/patientmanagement/:userId/group/:groupId/identifier/:identifierId")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/patientmanagement/:userId/group/:groupId/identifier/:identifierId',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/patientmanagement/:userId/group/:groupId/identifier/:identifierId'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/patientmanagement/:userId/group/:groupId/identifier/:identifierId');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/patientmanagement/:userId/group/:groupId/identifier/:identifierId'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/patientmanagement/:userId/group/:groupId/identifier/:identifierId';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/patientmanagement/:userId/group/:groupId/identifier/:identifierId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/patientmanagement/:userId/group/:groupId/identifier/:identifierId" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/patientmanagement/:userId/group/:groupId/identifier/:identifierId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/patientmanagement/:userId/group/:groupId/identifier/:identifierId');

echo $response->getBody();
setUrl('{{baseUrl}}/patientmanagement/:userId/group/:groupId/identifier/:identifierId');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/patientmanagement/:userId/group/:groupId/identifier/:identifierId');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/patientmanagement/:userId/group/:groupId/identifier/:identifierId' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/patientmanagement/:userId/group/:groupId/identifier/:identifierId' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/patientmanagement/:userId/group/:groupId/identifier/:identifierId")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/patientmanagement/:userId/group/:groupId/identifier/:identifierId"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/patientmanagement/:userId/group/:groupId/identifier/:identifierId"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/patientmanagement/:userId/group/:groupId/identifier/:identifierId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/patientmanagement/:userId/group/:groupId/identifier/:identifierId') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/patientmanagement/:userId/group/:groupId/identifier/:identifierId";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/patientmanagement/:userId/group/:groupId/identifier/:identifierId
http GET {{baseUrl}}/patientmanagement/:userId/group/:groupId/identifier/:identifierId
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/patientmanagement/:userId/group/:groupId/identifier/:identifierId
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/patientmanagement/:userId/group/:groupId/identifier/:identifierId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET getPatientManagementDiagnoses
{{baseUrl}}/patientmanagement/diagnoses
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/patientmanagement/diagnoses");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/patientmanagement/diagnoses")
require "http/client"

url = "{{baseUrl}}/patientmanagement/diagnoses"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/patientmanagement/diagnoses"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/patientmanagement/diagnoses");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/patientmanagement/diagnoses"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/patientmanagement/diagnoses HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/patientmanagement/diagnoses")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/patientmanagement/diagnoses"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/patientmanagement/diagnoses")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/patientmanagement/diagnoses")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/patientmanagement/diagnoses');

xhr.send(data);
import axios from 'axios';

const options = {method: 'GET', url: '{{baseUrl}}/patientmanagement/diagnoses'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/patientmanagement/diagnoses';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/patientmanagement/diagnoses',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/patientmanagement/diagnoses")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/patientmanagement/diagnoses',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'GET', url: '{{baseUrl}}/patientmanagement/diagnoses'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/patientmanagement/diagnoses');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {method: 'GET', url: '{{baseUrl}}/patientmanagement/diagnoses'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/patientmanagement/diagnoses';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/patientmanagement/diagnoses"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/patientmanagement/diagnoses" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/patientmanagement/diagnoses",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/patientmanagement/diagnoses');

echo $response->getBody();
setUrl('{{baseUrl}}/patientmanagement/diagnoses');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/patientmanagement/diagnoses');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/patientmanagement/diagnoses' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/patientmanagement/diagnoses' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/patientmanagement/diagnoses")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/patientmanagement/diagnoses"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/patientmanagement/diagnoses"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/patientmanagement/diagnoses")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/patientmanagement/diagnoses') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/patientmanagement/diagnoses";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/patientmanagement/diagnoses
http GET {{baseUrl}}/patientmanagement/diagnoses
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/patientmanagement/diagnoses
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/patientmanagement/diagnoses")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET getPatientManagementLookupTypes
{{baseUrl}}/patientmanagement/lookuptypes
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/patientmanagement/lookuptypes");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/patientmanagement/lookuptypes")
require "http/client"

url = "{{baseUrl}}/patientmanagement/lookuptypes"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/patientmanagement/lookuptypes"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/patientmanagement/lookuptypes");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/patientmanagement/lookuptypes"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/patientmanagement/lookuptypes HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/patientmanagement/lookuptypes")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/patientmanagement/lookuptypes"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/patientmanagement/lookuptypes")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/patientmanagement/lookuptypes")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/patientmanagement/lookuptypes');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/patientmanagement/lookuptypes'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/patientmanagement/lookuptypes';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/patientmanagement/lookuptypes',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/patientmanagement/lookuptypes")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/patientmanagement/lookuptypes',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/patientmanagement/lookuptypes'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/patientmanagement/lookuptypes');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/patientmanagement/lookuptypes'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/patientmanagement/lookuptypes';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/patientmanagement/lookuptypes"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/patientmanagement/lookuptypes" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/patientmanagement/lookuptypes",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/patientmanagement/lookuptypes');

echo $response->getBody();
setUrl('{{baseUrl}}/patientmanagement/lookuptypes');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/patientmanagement/lookuptypes');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/patientmanagement/lookuptypes' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/patientmanagement/lookuptypes' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/patientmanagement/lookuptypes")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/patientmanagement/lookuptypes"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/patientmanagement/lookuptypes"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/patientmanagement/lookuptypes")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/patientmanagement/lookuptypes') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/patientmanagement/lookuptypes";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/patientmanagement/lookuptypes
http GET {{baseUrl}}/patientmanagement/lookuptypes
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/patientmanagement/lookuptypes
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/patientmanagement/lookuptypes")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST savePatientManagement
{{baseUrl}}/patientmanagement/:userId/group/:groupId/identifier/:identifierId
QUERY PARAMS

userId
groupId
identifierId
BODY json

{
  "condition": {
    "asserter": "",
    "category": "",
    "code": "",
    "date": "",
    "description": "",
    "fullDescription": "",
    "group": {
      "address1": "",
      "address2": "",
      "address3": "",
      "childGroups": [],
      "code": "",
      "contactPoints": [
        {
          "contactPointType": {
            "description": "",
            "id": 0,
            "lookupType": {
              "created": "",
              "description": "",
              "id": 0,
              "lastUpdate": "",
              "type": ""
            },
            "value": ""
          },
          "content": "",
          "created": "",
          "id": 0,
          "lastUpdate": ""
        }
      ],
      "created": "",
      "fhirResourceId": "",
      "groupFeatures": [
        {
          "created": "",
          "feature": {
            "created": "",
            "description": "",
            "id": 0,
            "lastUpdate": "",
            "name": ""
          },
          "id": 0,
          "lastUpdate": ""
        }
      ],
      "groupType": {
        "created": "",
        "description": "",
        "descriptionFriendly": "",
        "displayOrder": 0,
        "id": 0,
        "lastUpdate": "",
        "lookupType": {},
        "value": ""
      },
      "id": 0,
      "lastImportDate": "",
      "lastUpdate": "",
      "links": [
        {
          "created": "",
          "displayOrder": 0,
          "id": 0,
          "lastUpdate": "",
          "link": "",
          "linkType": {},
          "name": ""
        }
      ],
      "locations": [
        {
          "address": "",
          "created": "",
          "email": "",
          "id": 0,
          "label": "",
          "lastUpdate": "",
          "name": "",
          "phone": "",
          "web": ""
        }
      ],
      "name": "",
      "parentGroups": [],
      "postcode": "",
      "sftpUser": "",
      "shortName": "",
      "visible": false,
      "visibleToJoin": false
    },
    "id": 0,
    "identifier": "",
    "links": [
      {}
    ],
    "notes": "",
    "severity": "",
    "status": ""
  },
  "encounters": [
    {
      "date": "",
      "encounterType": "",
      "group": {},
      "id": 0,
      "identifier": "",
      "links": [
        {}
      ],
      "observations": [
        {
          "applies": "",
          "bodySite": "",
          "comments": "",
          "comparator": "",
          "diagram": "",
          "group": {},
          "id": 0,
          "identifier": "",
          "location": "",
          "name": "",
          "temporaryUuid": "",
          "units": "",
          "value": ""
        }
      ],
      "procedures": [
        {
          "bodySite": "",
          "id": 0,
          "type": ""
        }
      ],
      "status": ""
    }
  ],
  "groupCode": "",
  "identifier": "",
  "observations": [
    {}
  ],
  "patient": {
    "address1": "",
    "address2": "",
    "address3": "",
    "address4": "",
    "contacts": [
      {
        "id": 0,
        "system": "",
        "use": "",
        "value": ""
      }
    ],
    "dateOfBirth": "",
    "dateOfBirthNoTime": "",
    "forename": "",
    "gender": "",
    "group": {},
    "groupCode": "",
    "identifier": "",
    "identifiers": [
      {
        "id": 0,
        "label": "",
        "value": ""
      }
    ],
    "postcode": "",
    "practitioners": [
      {
        "address1": "",
        "address2": "",
        "address3": "",
        "address4": "",
        "allowInviteGp": false,
        "contacts": [
          {}
        ],
        "gender": "",
        "groupCode": "",
        "identifier": "",
        "inviteDate": "",
        "name": "",
        "postcode": "",
        "role": ""
      }
    ],
    "surname": ""
  },
  "practitioners": [
    {}
  ]
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/patientmanagement/:userId/group/:groupId/identifier/:identifierId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"condition\": {\n    \"asserter\": \"\",\n    \"category\": \"\",\n    \"code\": \"\",\n    \"date\": \"\",\n    \"description\": \"\",\n    \"fullDescription\": \"\",\n    \"group\": {\n      \"address1\": \"\",\n      \"address2\": \"\",\n      \"address3\": \"\",\n      \"childGroups\": [],\n      \"code\": \"\",\n      \"contactPoints\": [\n        {\n          \"contactPointType\": {\n            \"description\": \"\",\n            \"id\": 0,\n            \"lookupType\": {\n              \"created\": \"\",\n              \"description\": \"\",\n              \"id\": 0,\n              \"lastUpdate\": \"\",\n              \"type\": \"\"\n            },\n            \"value\": \"\"\n          },\n          \"content\": \"\",\n          \"created\": \"\",\n          \"id\": 0,\n          \"lastUpdate\": \"\"\n        }\n      ],\n      \"created\": \"\",\n      \"fhirResourceId\": \"\",\n      \"groupFeatures\": [\n        {\n          \"created\": \"\",\n          \"feature\": {\n            \"created\": \"\",\n            \"description\": \"\",\n            \"id\": 0,\n            \"lastUpdate\": \"\",\n            \"name\": \"\"\n          },\n          \"id\": 0,\n          \"lastUpdate\": \"\"\n        }\n      ],\n      \"groupType\": {\n        \"created\": \"\",\n        \"description\": \"\",\n        \"descriptionFriendly\": \"\",\n        \"displayOrder\": 0,\n        \"id\": 0,\n        \"lastUpdate\": \"\",\n        \"lookupType\": {},\n        \"value\": \"\"\n      },\n      \"id\": 0,\n      \"lastImportDate\": \"\",\n      \"lastUpdate\": \"\",\n      \"links\": [\n        {\n          \"created\": \"\",\n          \"displayOrder\": 0,\n          \"id\": 0,\n          \"lastUpdate\": \"\",\n          \"link\": \"\",\n          \"linkType\": {},\n          \"name\": \"\"\n        }\n      ],\n      \"locations\": [\n        {\n          \"address\": \"\",\n          \"created\": \"\",\n          \"email\": \"\",\n          \"id\": 0,\n          \"label\": \"\",\n          \"lastUpdate\": \"\",\n          \"name\": \"\",\n          \"phone\": \"\",\n          \"web\": \"\"\n        }\n      ],\n      \"name\": \"\",\n      \"parentGroups\": [],\n      \"postcode\": \"\",\n      \"sftpUser\": \"\",\n      \"shortName\": \"\",\n      \"visible\": false,\n      \"visibleToJoin\": false\n    },\n    \"id\": 0,\n    \"identifier\": \"\",\n    \"links\": [\n      {}\n    ],\n    \"notes\": \"\",\n    \"severity\": \"\",\n    \"status\": \"\"\n  },\n  \"encounters\": [\n    {\n      \"date\": \"\",\n      \"encounterType\": \"\",\n      \"group\": {},\n      \"id\": 0,\n      \"identifier\": \"\",\n      \"links\": [\n        {}\n      ],\n      \"observations\": [\n        {\n          \"applies\": \"\",\n          \"bodySite\": \"\",\n          \"comments\": \"\",\n          \"comparator\": \"\",\n          \"diagram\": \"\",\n          \"group\": {},\n          \"id\": 0,\n          \"identifier\": \"\",\n          \"location\": \"\",\n          \"name\": \"\",\n          \"temporaryUuid\": \"\",\n          \"units\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"procedures\": [\n        {\n          \"bodySite\": \"\",\n          \"id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"status\": \"\"\n    }\n  ],\n  \"groupCode\": \"\",\n  \"identifier\": \"\",\n  \"observations\": [\n    {}\n  ],\n  \"patient\": {\n    \"address1\": \"\",\n    \"address2\": \"\",\n    \"address3\": \"\",\n    \"address4\": \"\",\n    \"contacts\": [\n      {\n        \"id\": 0,\n        \"system\": \"\",\n        \"use\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"dateOfBirth\": \"\",\n    \"dateOfBirthNoTime\": \"\",\n    \"forename\": \"\",\n    \"gender\": \"\",\n    \"group\": {},\n    \"groupCode\": \"\",\n    \"identifier\": \"\",\n    \"identifiers\": [\n      {\n        \"id\": 0,\n        \"label\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"postcode\": \"\",\n    \"practitioners\": [\n      {\n        \"address1\": \"\",\n        \"address2\": \"\",\n        \"address3\": \"\",\n        \"address4\": \"\",\n        \"allowInviteGp\": false,\n        \"contacts\": [\n          {}\n        ],\n        \"gender\": \"\",\n        \"groupCode\": \"\",\n        \"identifier\": \"\",\n        \"inviteDate\": \"\",\n        \"name\": \"\",\n        \"postcode\": \"\",\n        \"role\": \"\"\n      }\n    ],\n    \"surname\": \"\"\n  },\n  \"practitioners\": [\n    {}\n  ]\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/patientmanagement/:userId/group/:groupId/identifier/:identifierId" {:content-type :json
                                                                                                              :form-params {:condition {:asserter ""
                                                                                                                                        :category ""
                                                                                                                                        :code ""
                                                                                                                                        :date ""
                                                                                                                                        :description ""
                                                                                                                                        :fullDescription ""
                                                                                                                                        :group {:address1 ""
                                                                                                                                                :address2 ""
                                                                                                                                                :address3 ""
                                                                                                                                                :childGroups []
                                                                                                                                                :code ""
                                                                                                                                                :contactPoints [{:contactPointType {:description ""
                                                                                                                                                                                    :id 0
                                                                                                                                                                                    :lookupType {:created ""
                                                                                                                                                                                                 :description ""
                                                                                                                                                                                                 :id 0
                                                                                                                                                                                                 :lastUpdate ""
                                                                                                                                                                                                 :type ""}
                                                                                                                                                                                    :value ""}
                                                                                                                                                                 :content ""
                                                                                                                                                                 :created ""
                                                                                                                                                                 :id 0
                                                                                                                                                                 :lastUpdate ""}]
                                                                                                                                                :created ""
                                                                                                                                                :fhirResourceId ""
                                                                                                                                                :groupFeatures [{:created ""
                                                                                                                                                                 :feature {:created ""
                                                                                                                                                                           :description ""
                                                                                                                                                                           :id 0
                                                                                                                                                                           :lastUpdate ""
                                                                                                                                                                           :name ""}
                                                                                                                                                                 :id 0
                                                                                                                                                                 :lastUpdate ""}]
                                                                                                                                                :groupType {:created ""
                                                                                                                                                            :description ""
                                                                                                                                                            :descriptionFriendly ""
                                                                                                                                                            :displayOrder 0
                                                                                                                                                            :id 0
                                                                                                                                                            :lastUpdate ""
                                                                                                                                                            :lookupType {}
                                                                                                                                                            :value ""}
                                                                                                                                                :id 0
                                                                                                                                                :lastImportDate ""
                                                                                                                                                :lastUpdate ""
                                                                                                                                                :links [{:created ""
                                                                                                                                                         :displayOrder 0
                                                                                                                                                         :id 0
                                                                                                                                                         :lastUpdate ""
                                                                                                                                                         :link ""
                                                                                                                                                         :linkType {}
                                                                                                                                                         :name ""}]
                                                                                                                                                :locations [{:address ""
                                                                                                                                                             :created ""
                                                                                                                                                             :email ""
                                                                                                                                                             :id 0
                                                                                                                                                             :label ""
                                                                                                                                                             :lastUpdate ""
                                                                                                                                                             :name ""
                                                                                                                                                             :phone ""
                                                                                                                                                             :web ""}]
                                                                                                                                                :name ""
                                                                                                                                                :parentGroups []
                                                                                                                                                :postcode ""
                                                                                                                                                :sftpUser ""
                                                                                                                                                :shortName ""
                                                                                                                                                :visible false
                                                                                                                                                :visibleToJoin false}
                                                                                                                                        :id 0
                                                                                                                                        :identifier ""
                                                                                                                                        :links [{}]
                                                                                                                                        :notes ""
                                                                                                                                        :severity ""
                                                                                                                                        :status ""}
                                                                                                                            :encounters [{:date ""
                                                                                                                                          :encounterType ""
                                                                                                                                          :group {}
                                                                                                                                          :id 0
                                                                                                                                          :identifier ""
                                                                                                                                          :links [{}]
                                                                                                                                          :observations [{:applies ""
                                                                                                                                                          :bodySite ""
                                                                                                                                                          :comments ""
                                                                                                                                                          :comparator ""
                                                                                                                                                          :diagram ""
                                                                                                                                                          :group {}
                                                                                                                                                          :id 0
                                                                                                                                                          :identifier ""
                                                                                                                                                          :location ""
                                                                                                                                                          :name ""
                                                                                                                                                          :temporaryUuid ""
                                                                                                                                                          :units ""
                                                                                                                                                          :value ""}]
                                                                                                                                          :procedures [{:bodySite ""
                                                                                                                                                        :id 0
                                                                                                                                                        :type ""}]
                                                                                                                                          :status ""}]
                                                                                                                            :groupCode ""
                                                                                                                            :identifier ""
                                                                                                                            :observations [{}]
                                                                                                                            :patient {:address1 ""
                                                                                                                                      :address2 ""
                                                                                                                                      :address3 ""
                                                                                                                                      :address4 ""
                                                                                                                                      :contacts [{:id 0
                                                                                                                                                  :system ""
                                                                                                                                                  :use ""
                                                                                                                                                  :value ""}]
                                                                                                                                      :dateOfBirth ""
                                                                                                                                      :dateOfBirthNoTime ""
                                                                                                                                      :forename ""
                                                                                                                                      :gender ""
                                                                                                                                      :group {}
                                                                                                                                      :groupCode ""
                                                                                                                                      :identifier ""
                                                                                                                                      :identifiers [{:id 0
                                                                                                                                                     :label ""
                                                                                                                                                     :value ""}]
                                                                                                                                      :postcode ""
                                                                                                                                      :practitioners [{:address1 ""
                                                                                                                                                       :address2 ""
                                                                                                                                                       :address3 ""
                                                                                                                                                       :address4 ""
                                                                                                                                                       :allowInviteGp false
                                                                                                                                                       :contacts [{}]
                                                                                                                                                       :gender ""
                                                                                                                                                       :groupCode ""
                                                                                                                                                       :identifier ""
                                                                                                                                                       :inviteDate ""
                                                                                                                                                       :name ""
                                                                                                                                                       :postcode ""
                                                                                                                                                       :role ""}]
                                                                                                                                      :surname ""}
                                                                                                                            :practitioners [{}]}})
require "http/client"

url = "{{baseUrl}}/patientmanagement/:userId/group/:groupId/identifier/:identifierId"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"condition\": {\n    \"asserter\": \"\",\n    \"category\": \"\",\n    \"code\": \"\",\n    \"date\": \"\",\n    \"description\": \"\",\n    \"fullDescription\": \"\",\n    \"group\": {\n      \"address1\": \"\",\n      \"address2\": \"\",\n      \"address3\": \"\",\n      \"childGroups\": [],\n      \"code\": \"\",\n      \"contactPoints\": [\n        {\n          \"contactPointType\": {\n            \"description\": \"\",\n            \"id\": 0,\n            \"lookupType\": {\n              \"created\": \"\",\n              \"description\": \"\",\n              \"id\": 0,\n              \"lastUpdate\": \"\",\n              \"type\": \"\"\n            },\n            \"value\": \"\"\n          },\n          \"content\": \"\",\n          \"created\": \"\",\n          \"id\": 0,\n          \"lastUpdate\": \"\"\n        }\n      ],\n      \"created\": \"\",\n      \"fhirResourceId\": \"\",\n      \"groupFeatures\": [\n        {\n          \"created\": \"\",\n          \"feature\": {\n            \"created\": \"\",\n            \"description\": \"\",\n            \"id\": 0,\n            \"lastUpdate\": \"\",\n            \"name\": \"\"\n          },\n          \"id\": 0,\n          \"lastUpdate\": \"\"\n        }\n      ],\n      \"groupType\": {\n        \"created\": \"\",\n        \"description\": \"\",\n        \"descriptionFriendly\": \"\",\n        \"displayOrder\": 0,\n        \"id\": 0,\n        \"lastUpdate\": \"\",\n        \"lookupType\": {},\n        \"value\": \"\"\n      },\n      \"id\": 0,\n      \"lastImportDate\": \"\",\n      \"lastUpdate\": \"\",\n      \"links\": [\n        {\n          \"created\": \"\",\n          \"displayOrder\": 0,\n          \"id\": 0,\n          \"lastUpdate\": \"\",\n          \"link\": \"\",\n          \"linkType\": {},\n          \"name\": \"\"\n        }\n      ],\n      \"locations\": [\n        {\n          \"address\": \"\",\n          \"created\": \"\",\n          \"email\": \"\",\n          \"id\": 0,\n          \"label\": \"\",\n          \"lastUpdate\": \"\",\n          \"name\": \"\",\n          \"phone\": \"\",\n          \"web\": \"\"\n        }\n      ],\n      \"name\": \"\",\n      \"parentGroups\": [],\n      \"postcode\": \"\",\n      \"sftpUser\": \"\",\n      \"shortName\": \"\",\n      \"visible\": false,\n      \"visibleToJoin\": false\n    },\n    \"id\": 0,\n    \"identifier\": \"\",\n    \"links\": [\n      {}\n    ],\n    \"notes\": \"\",\n    \"severity\": \"\",\n    \"status\": \"\"\n  },\n  \"encounters\": [\n    {\n      \"date\": \"\",\n      \"encounterType\": \"\",\n      \"group\": {},\n      \"id\": 0,\n      \"identifier\": \"\",\n      \"links\": [\n        {}\n      ],\n      \"observations\": [\n        {\n          \"applies\": \"\",\n          \"bodySite\": \"\",\n          \"comments\": \"\",\n          \"comparator\": \"\",\n          \"diagram\": \"\",\n          \"group\": {},\n          \"id\": 0,\n          \"identifier\": \"\",\n          \"location\": \"\",\n          \"name\": \"\",\n          \"temporaryUuid\": \"\",\n          \"units\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"procedures\": [\n        {\n          \"bodySite\": \"\",\n          \"id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"status\": \"\"\n    }\n  ],\n  \"groupCode\": \"\",\n  \"identifier\": \"\",\n  \"observations\": [\n    {}\n  ],\n  \"patient\": {\n    \"address1\": \"\",\n    \"address2\": \"\",\n    \"address3\": \"\",\n    \"address4\": \"\",\n    \"contacts\": [\n      {\n        \"id\": 0,\n        \"system\": \"\",\n        \"use\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"dateOfBirth\": \"\",\n    \"dateOfBirthNoTime\": \"\",\n    \"forename\": \"\",\n    \"gender\": \"\",\n    \"group\": {},\n    \"groupCode\": \"\",\n    \"identifier\": \"\",\n    \"identifiers\": [\n      {\n        \"id\": 0,\n        \"label\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"postcode\": \"\",\n    \"practitioners\": [\n      {\n        \"address1\": \"\",\n        \"address2\": \"\",\n        \"address3\": \"\",\n        \"address4\": \"\",\n        \"allowInviteGp\": false,\n        \"contacts\": [\n          {}\n        ],\n        \"gender\": \"\",\n        \"groupCode\": \"\",\n        \"identifier\": \"\",\n        \"inviteDate\": \"\",\n        \"name\": \"\",\n        \"postcode\": \"\",\n        \"role\": \"\"\n      }\n    ],\n    \"surname\": \"\"\n  },\n  \"practitioners\": [\n    {}\n  ]\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/patientmanagement/:userId/group/:groupId/identifier/:identifierId"),
    Content = new StringContent("{\n  \"condition\": {\n    \"asserter\": \"\",\n    \"category\": \"\",\n    \"code\": \"\",\n    \"date\": \"\",\n    \"description\": \"\",\n    \"fullDescription\": \"\",\n    \"group\": {\n      \"address1\": \"\",\n      \"address2\": \"\",\n      \"address3\": \"\",\n      \"childGroups\": [],\n      \"code\": \"\",\n      \"contactPoints\": [\n        {\n          \"contactPointType\": {\n            \"description\": \"\",\n            \"id\": 0,\n            \"lookupType\": {\n              \"created\": \"\",\n              \"description\": \"\",\n              \"id\": 0,\n              \"lastUpdate\": \"\",\n              \"type\": \"\"\n            },\n            \"value\": \"\"\n          },\n          \"content\": \"\",\n          \"created\": \"\",\n          \"id\": 0,\n          \"lastUpdate\": \"\"\n        }\n      ],\n      \"created\": \"\",\n      \"fhirResourceId\": \"\",\n      \"groupFeatures\": [\n        {\n          \"created\": \"\",\n          \"feature\": {\n            \"created\": \"\",\n            \"description\": \"\",\n            \"id\": 0,\n            \"lastUpdate\": \"\",\n            \"name\": \"\"\n          },\n          \"id\": 0,\n          \"lastUpdate\": \"\"\n        }\n      ],\n      \"groupType\": {\n        \"created\": \"\",\n        \"description\": \"\",\n        \"descriptionFriendly\": \"\",\n        \"displayOrder\": 0,\n        \"id\": 0,\n        \"lastUpdate\": \"\",\n        \"lookupType\": {},\n        \"value\": \"\"\n      },\n      \"id\": 0,\n      \"lastImportDate\": \"\",\n      \"lastUpdate\": \"\",\n      \"links\": [\n        {\n          \"created\": \"\",\n          \"displayOrder\": 0,\n          \"id\": 0,\n          \"lastUpdate\": \"\",\n          \"link\": \"\",\n          \"linkType\": {},\n          \"name\": \"\"\n        }\n      ],\n      \"locations\": [\n        {\n          \"address\": \"\",\n          \"created\": \"\",\n          \"email\": \"\",\n          \"id\": 0,\n          \"label\": \"\",\n          \"lastUpdate\": \"\",\n          \"name\": \"\",\n          \"phone\": \"\",\n          \"web\": \"\"\n        }\n      ],\n      \"name\": \"\",\n      \"parentGroups\": [],\n      \"postcode\": \"\",\n      \"sftpUser\": \"\",\n      \"shortName\": \"\",\n      \"visible\": false,\n      \"visibleToJoin\": false\n    },\n    \"id\": 0,\n    \"identifier\": \"\",\n    \"links\": [\n      {}\n    ],\n    \"notes\": \"\",\n    \"severity\": \"\",\n    \"status\": \"\"\n  },\n  \"encounters\": [\n    {\n      \"date\": \"\",\n      \"encounterType\": \"\",\n      \"group\": {},\n      \"id\": 0,\n      \"identifier\": \"\",\n      \"links\": [\n        {}\n      ],\n      \"observations\": [\n        {\n          \"applies\": \"\",\n          \"bodySite\": \"\",\n          \"comments\": \"\",\n          \"comparator\": \"\",\n          \"diagram\": \"\",\n          \"group\": {},\n          \"id\": 0,\n          \"identifier\": \"\",\n          \"location\": \"\",\n          \"name\": \"\",\n          \"temporaryUuid\": \"\",\n          \"units\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"procedures\": [\n        {\n          \"bodySite\": \"\",\n          \"id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"status\": \"\"\n    }\n  ],\n  \"groupCode\": \"\",\n  \"identifier\": \"\",\n  \"observations\": [\n    {}\n  ],\n  \"patient\": {\n    \"address1\": \"\",\n    \"address2\": \"\",\n    \"address3\": \"\",\n    \"address4\": \"\",\n    \"contacts\": [\n      {\n        \"id\": 0,\n        \"system\": \"\",\n        \"use\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"dateOfBirth\": \"\",\n    \"dateOfBirthNoTime\": \"\",\n    \"forename\": \"\",\n    \"gender\": \"\",\n    \"group\": {},\n    \"groupCode\": \"\",\n    \"identifier\": \"\",\n    \"identifiers\": [\n      {\n        \"id\": 0,\n        \"label\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"postcode\": \"\",\n    \"practitioners\": [\n      {\n        \"address1\": \"\",\n        \"address2\": \"\",\n        \"address3\": \"\",\n        \"address4\": \"\",\n        \"allowInviteGp\": false,\n        \"contacts\": [\n          {}\n        ],\n        \"gender\": \"\",\n        \"groupCode\": \"\",\n        \"identifier\": \"\",\n        \"inviteDate\": \"\",\n        \"name\": \"\",\n        \"postcode\": \"\",\n        \"role\": \"\"\n      }\n    ],\n    \"surname\": \"\"\n  },\n  \"practitioners\": [\n    {}\n  ]\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/patientmanagement/:userId/group/:groupId/identifier/:identifierId");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"condition\": {\n    \"asserter\": \"\",\n    \"category\": \"\",\n    \"code\": \"\",\n    \"date\": \"\",\n    \"description\": \"\",\n    \"fullDescription\": \"\",\n    \"group\": {\n      \"address1\": \"\",\n      \"address2\": \"\",\n      \"address3\": \"\",\n      \"childGroups\": [],\n      \"code\": \"\",\n      \"contactPoints\": [\n        {\n          \"contactPointType\": {\n            \"description\": \"\",\n            \"id\": 0,\n            \"lookupType\": {\n              \"created\": \"\",\n              \"description\": \"\",\n              \"id\": 0,\n              \"lastUpdate\": \"\",\n              \"type\": \"\"\n            },\n            \"value\": \"\"\n          },\n          \"content\": \"\",\n          \"created\": \"\",\n          \"id\": 0,\n          \"lastUpdate\": \"\"\n        }\n      ],\n      \"created\": \"\",\n      \"fhirResourceId\": \"\",\n      \"groupFeatures\": [\n        {\n          \"created\": \"\",\n          \"feature\": {\n            \"created\": \"\",\n            \"description\": \"\",\n            \"id\": 0,\n            \"lastUpdate\": \"\",\n            \"name\": \"\"\n          },\n          \"id\": 0,\n          \"lastUpdate\": \"\"\n        }\n      ],\n      \"groupType\": {\n        \"created\": \"\",\n        \"description\": \"\",\n        \"descriptionFriendly\": \"\",\n        \"displayOrder\": 0,\n        \"id\": 0,\n        \"lastUpdate\": \"\",\n        \"lookupType\": {},\n        \"value\": \"\"\n      },\n      \"id\": 0,\n      \"lastImportDate\": \"\",\n      \"lastUpdate\": \"\",\n      \"links\": [\n        {\n          \"created\": \"\",\n          \"displayOrder\": 0,\n          \"id\": 0,\n          \"lastUpdate\": \"\",\n          \"link\": \"\",\n          \"linkType\": {},\n          \"name\": \"\"\n        }\n      ],\n      \"locations\": [\n        {\n          \"address\": \"\",\n          \"created\": \"\",\n          \"email\": \"\",\n          \"id\": 0,\n          \"label\": \"\",\n          \"lastUpdate\": \"\",\n          \"name\": \"\",\n          \"phone\": \"\",\n          \"web\": \"\"\n        }\n      ],\n      \"name\": \"\",\n      \"parentGroups\": [],\n      \"postcode\": \"\",\n      \"sftpUser\": \"\",\n      \"shortName\": \"\",\n      \"visible\": false,\n      \"visibleToJoin\": false\n    },\n    \"id\": 0,\n    \"identifier\": \"\",\n    \"links\": [\n      {}\n    ],\n    \"notes\": \"\",\n    \"severity\": \"\",\n    \"status\": \"\"\n  },\n  \"encounters\": [\n    {\n      \"date\": \"\",\n      \"encounterType\": \"\",\n      \"group\": {},\n      \"id\": 0,\n      \"identifier\": \"\",\n      \"links\": [\n        {}\n      ],\n      \"observations\": [\n        {\n          \"applies\": \"\",\n          \"bodySite\": \"\",\n          \"comments\": \"\",\n          \"comparator\": \"\",\n          \"diagram\": \"\",\n          \"group\": {},\n          \"id\": 0,\n          \"identifier\": \"\",\n          \"location\": \"\",\n          \"name\": \"\",\n          \"temporaryUuid\": \"\",\n          \"units\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"procedures\": [\n        {\n          \"bodySite\": \"\",\n          \"id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"status\": \"\"\n    }\n  ],\n  \"groupCode\": \"\",\n  \"identifier\": \"\",\n  \"observations\": [\n    {}\n  ],\n  \"patient\": {\n    \"address1\": \"\",\n    \"address2\": \"\",\n    \"address3\": \"\",\n    \"address4\": \"\",\n    \"contacts\": [\n      {\n        \"id\": 0,\n        \"system\": \"\",\n        \"use\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"dateOfBirth\": \"\",\n    \"dateOfBirthNoTime\": \"\",\n    \"forename\": \"\",\n    \"gender\": \"\",\n    \"group\": {},\n    \"groupCode\": \"\",\n    \"identifier\": \"\",\n    \"identifiers\": [\n      {\n        \"id\": 0,\n        \"label\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"postcode\": \"\",\n    \"practitioners\": [\n      {\n        \"address1\": \"\",\n        \"address2\": \"\",\n        \"address3\": \"\",\n        \"address4\": \"\",\n        \"allowInviteGp\": false,\n        \"contacts\": [\n          {}\n        ],\n        \"gender\": \"\",\n        \"groupCode\": \"\",\n        \"identifier\": \"\",\n        \"inviteDate\": \"\",\n        \"name\": \"\",\n        \"postcode\": \"\",\n        \"role\": \"\"\n      }\n    ],\n    \"surname\": \"\"\n  },\n  \"practitioners\": [\n    {}\n  ]\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/patientmanagement/:userId/group/:groupId/identifier/:identifierId"

	payload := strings.NewReader("{\n  \"condition\": {\n    \"asserter\": \"\",\n    \"category\": \"\",\n    \"code\": \"\",\n    \"date\": \"\",\n    \"description\": \"\",\n    \"fullDescription\": \"\",\n    \"group\": {\n      \"address1\": \"\",\n      \"address2\": \"\",\n      \"address3\": \"\",\n      \"childGroups\": [],\n      \"code\": \"\",\n      \"contactPoints\": [\n        {\n          \"contactPointType\": {\n            \"description\": \"\",\n            \"id\": 0,\n            \"lookupType\": {\n              \"created\": \"\",\n              \"description\": \"\",\n              \"id\": 0,\n              \"lastUpdate\": \"\",\n              \"type\": \"\"\n            },\n            \"value\": \"\"\n          },\n          \"content\": \"\",\n          \"created\": \"\",\n          \"id\": 0,\n          \"lastUpdate\": \"\"\n        }\n      ],\n      \"created\": \"\",\n      \"fhirResourceId\": \"\",\n      \"groupFeatures\": [\n        {\n          \"created\": \"\",\n          \"feature\": {\n            \"created\": \"\",\n            \"description\": \"\",\n            \"id\": 0,\n            \"lastUpdate\": \"\",\n            \"name\": \"\"\n          },\n          \"id\": 0,\n          \"lastUpdate\": \"\"\n        }\n      ],\n      \"groupType\": {\n        \"created\": \"\",\n        \"description\": \"\",\n        \"descriptionFriendly\": \"\",\n        \"displayOrder\": 0,\n        \"id\": 0,\n        \"lastUpdate\": \"\",\n        \"lookupType\": {},\n        \"value\": \"\"\n      },\n      \"id\": 0,\n      \"lastImportDate\": \"\",\n      \"lastUpdate\": \"\",\n      \"links\": [\n        {\n          \"created\": \"\",\n          \"displayOrder\": 0,\n          \"id\": 0,\n          \"lastUpdate\": \"\",\n          \"link\": \"\",\n          \"linkType\": {},\n          \"name\": \"\"\n        }\n      ],\n      \"locations\": [\n        {\n          \"address\": \"\",\n          \"created\": \"\",\n          \"email\": \"\",\n          \"id\": 0,\n          \"label\": \"\",\n          \"lastUpdate\": \"\",\n          \"name\": \"\",\n          \"phone\": \"\",\n          \"web\": \"\"\n        }\n      ],\n      \"name\": \"\",\n      \"parentGroups\": [],\n      \"postcode\": \"\",\n      \"sftpUser\": \"\",\n      \"shortName\": \"\",\n      \"visible\": false,\n      \"visibleToJoin\": false\n    },\n    \"id\": 0,\n    \"identifier\": \"\",\n    \"links\": [\n      {}\n    ],\n    \"notes\": \"\",\n    \"severity\": \"\",\n    \"status\": \"\"\n  },\n  \"encounters\": [\n    {\n      \"date\": \"\",\n      \"encounterType\": \"\",\n      \"group\": {},\n      \"id\": 0,\n      \"identifier\": \"\",\n      \"links\": [\n        {}\n      ],\n      \"observations\": [\n        {\n          \"applies\": \"\",\n          \"bodySite\": \"\",\n          \"comments\": \"\",\n          \"comparator\": \"\",\n          \"diagram\": \"\",\n          \"group\": {},\n          \"id\": 0,\n          \"identifier\": \"\",\n          \"location\": \"\",\n          \"name\": \"\",\n          \"temporaryUuid\": \"\",\n          \"units\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"procedures\": [\n        {\n          \"bodySite\": \"\",\n          \"id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"status\": \"\"\n    }\n  ],\n  \"groupCode\": \"\",\n  \"identifier\": \"\",\n  \"observations\": [\n    {}\n  ],\n  \"patient\": {\n    \"address1\": \"\",\n    \"address2\": \"\",\n    \"address3\": \"\",\n    \"address4\": \"\",\n    \"contacts\": [\n      {\n        \"id\": 0,\n        \"system\": \"\",\n        \"use\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"dateOfBirth\": \"\",\n    \"dateOfBirthNoTime\": \"\",\n    \"forename\": \"\",\n    \"gender\": \"\",\n    \"group\": {},\n    \"groupCode\": \"\",\n    \"identifier\": \"\",\n    \"identifiers\": [\n      {\n        \"id\": 0,\n        \"label\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"postcode\": \"\",\n    \"practitioners\": [\n      {\n        \"address1\": \"\",\n        \"address2\": \"\",\n        \"address3\": \"\",\n        \"address4\": \"\",\n        \"allowInviteGp\": false,\n        \"contacts\": [\n          {}\n        ],\n        \"gender\": \"\",\n        \"groupCode\": \"\",\n        \"identifier\": \"\",\n        \"inviteDate\": \"\",\n        \"name\": \"\",\n        \"postcode\": \"\",\n        \"role\": \"\"\n      }\n    ],\n    \"surname\": \"\"\n  },\n  \"practitioners\": [\n    {}\n  ]\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/patientmanagement/:userId/group/:groupId/identifier/:identifierId HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 3814

{
  "condition": {
    "asserter": "",
    "category": "",
    "code": "",
    "date": "",
    "description": "",
    "fullDescription": "",
    "group": {
      "address1": "",
      "address2": "",
      "address3": "",
      "childGroups": [],
      "code": "",
      "contactPoints": [
        {
          "contactPointType": {
            "description": "",
            "id": 0,
            "lookupType": {
              "created": "",
              "description": "",
              "id": 0,
              "lastUpdate": "",
              "type": ""
            },
            "value": ""
          },
          "content": "",
          "created": "",
          "id": 0,
          "lastUpdate": ""
        }
      ],
      "created": "",
      "fhirResourceId": "",
      "groupFeatures": [
        {
          "created": "",
          "feature": {
            "created": "",
            "description": "",
            "id": 0,
            "lastUpdate": "",
            "name": ""
          },
          "id": 0,
          "lastUpdate": ""
        }
      ],
      "groupType": {
        "created": "",
        "description": "",
        "descriptionFriendly": "",
        "displayOrder": 0,
        "id": 0,
        "lastUpdate": "",
        "lookupType": {},
        "value": ""
      },
      "id": 0,
      "lastImportDate": "",
      "lastUpdate": "",
      "links": [
        {
          "created": "",
          "displayOrder": 0,
          "id": 0,
          "lastUpdate": "",
          "link": "",
          "linkType": {},
          "name": ""
        }
      ],
      "locations": [
        {
          "address": "",
          "created": "",
          "email": "",
          "id": 0,
          "label": "",
          "lastUpdate": "",
          "name": "",
          "phone": "",
          "web": ""
        }
      ],
      "name": "",
      "parentGroups": [],
      "postcode": "",
      "sftpUser": "",
      "shortName": "",
      "visible": false,
      "visibleToJoin": false
    },
    "id": 0,
    "identifier": "",
    "links": [
      {}
    ],
    "notes": "",
    "severity": "",
    "status": ""
  },
  "encounters": [
    {
      "date": "",
      "encounterType": "",
      "group": {},
      "id": 0,
      "identifier": "",
      "links": [
        {}
      ],
      "observations": [
        {
          "applies": "",
          "bodySite": "",
          "comments": "",
          "comparator": "",
          "diagram": "",
          "group": {},
          "id": 0,
          "identifier": "",
          "location": "",
          "name": "",
          "temporaryUuid": "",
          "units": "",
          "value": ""
        }
      ],
      "procedures": [
        {
          "bodySite": "",
          "id": 0,
          "type": ""
        }
      ],
      "status": ""
    }
  ],
  "groupCode": "",
  "identifier": "",
  "observations": [
    {}
  ],
  "patient": {
    "address1": "",
    "address2": "",
    "address3": "",
    "address4": "",
    "contacts": [
      {
        "id": 0,
        "system": "",
        "use": "",
        "value": ""
      }
    ],
    "dateOfBirth": "",
    "dateOfBirthNoTime": "",
    "forename": "",
    "gender": "",
    "group": {},
    "groupCode": "",
    "identifier": "",
    "identifiers": [
      {
        "id": 0,
        "label": "",
        "value": ""
      }
    ],
    "postcode": "",
    "practitioners": [
      {
        "address1": "",
        "address2": "",
        "address3": "",
        "address4": "",
        "allowInviteGp": false,
        "contacts": [
          {}
        ],
        "gender": "",
        "groupCode": "",
        "identifier": "",
        "inviteDate": "",
        "name": "",
        "postcode": "",
        "role": ""
      }
    ],
    "surname": ""
  },
  "practitioners": [
    {}
  ]
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/patientmanagement/:userId/group/:groupId/identifier/:identifierId")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"condition\": {\n    \"asserter\": \"\",\n    \"category\": \"\",\n    \"code\": \"\",\n    \"date\": \"\",\n    \"description\": \"\",\n    \"fullDescription\": \"\",\n    \"group\": {\n      \"address1\": \"\",\n      \"address2\": \"\",\n      \"address3\": \"\",\n      \"childGroups\": [],\n      \"code\": \"\",\n      \"contactPoints\": [\n        {\n          \"contactPointType\": {\n            \"description\": \"\",\n            \"id\": 0,\n            \"lookupType\": {\n              \"created\": \"\",\n              \"description\": \"\",\n              \"id\": 0,\n              \"lastUpdate\": \"\",\n              \"type\": \"\"\n            },\n            \"value\": \"\"\n          },\n          \"content\": \"\",\n          \"created\": \"\",\n          \"id\": 0,\n          \"lastUpdate\": \"\"\n        }\n      ],\n      \"created\": \"\",\n      \"fhirResourceId\": \"\",\n      \"groupFeatures\": [\n        {\n          \"created\": \"\",\n          \"feature\": {\n            \"created\": \"\",\n            \"description\": \"\",\n            \"id\": 0,\n            \"lastUpdate\": \"\",\n            \"name\": \"\"\n          },\n          \"id\": 0,\n          \"lastUpdate\": \"\"\n        }\n      ],\n      \"groupType\": {\n        \"created\": \"\",\n        \"description\": \"\",\n        \"descriptionFriendly\": \"\",\n        \"displayOrder\": 0,\n        \"id\": 0,\n        \"lastUpdate\": \"\",\n        \"lookupType\": {},\n        \"value\": \"\"\n      },\n      \"id\": 0,\n      \"lastImportDate\": \"\",\n      \"lastUpdate\": \"\",\n      \"links\": [\n        {\n          \"created\": \"\",\n          \"displayOrder\": 0,\n          \"id\": 0,\n          \"lastUpdate\": \"\",\n          \"link\": \"\",\n          \"linkType\": {},\n          \"name\": \"\"\n        }\n      ],\n      \"locations\": [\n        {\n          \"address\": \"\",\n          \"created\": \"\",\n          \"email\": \"\",\n          \"id\": 0,\n          \"label\": \"\",\n          \"lastUpdate\": \"\",\n          \"name\": \"\",\n          \"phone\": \"\",\n          \"web\": \"\"\n        }\n      ],\n      \"name\": \"\",\n      \"parentGroups\": [],\n      \"postcode\": \"\",\n      \"sftpUser\": \"\",\n      \"shortName\": \"\",\n      \"visible\": false,\n      \"visibleToJoin\": false\n    },\n    \"id\": 0,\n    \"identifier\": \"\",\n    \"links\": [\n      {}\n    ],\n    \"notes\": \"\",\n    \"severity\": \"\",\n    \"status\": \"\"\n  },\n  \"encounters\": [\n    {\n      \"date\": \"\",\n      \"encounterType\": \"\",\n      \"group\": {},\n      \"id\": 0,\n      \"identifier\": \"\",\n      \"links\": [\n        {}\n      ],\n      \"observations\": [\n        {\n          \"applies\": \"\",\n          \"bodySite\": \"\",\n          \"comments\": \"\",\n          \"comparator\": \"\",\n          \"diagram\": \"\",\n          \"group\": {},\n          \"id\": 0,\n          \"identifier\": \"\",\n          \"location\": \"\",\n          \"name\": \"\",\n          \"temporaryUuid\": \"\",\n          \"units\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"procedures\": [\n        {\n          \"bodySite\": \"\",\n          \"id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"status\": \"\"\n    }\n  ],\n  \"groupCode\": \"\",\n  \"identifier\": \"\",\n  \"observations\": [\n    {}\n  ],\n  \"patient\": {\n    \"address1\": \"\",\n    \"address2\": \"\",\n    \"address3\": \"\",\n    \"address4\": \"\",\n    \"contacts\": [\n      {\n        \"id\": 0,\n        \"system\": \"\",\n        \"use\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"dateOfBirth\": \"\",\n    \"dateOfBirthNoTime\": \"\",\n    \"forename\": \"\",\n    \"gender\": \"\",\n    \"group\": {},\n    \"groupCode\": \"\",\n    \"identifier\": \"\",\n    \"identifiers\": [\n      {\n        \"id\": 0,\n        \"label\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"postcode\": \"\",\n    \"practitioners\": [\n      {\n        \"address1\": \"\",\n        \"address2\": \"\",\n        \"address3\": \"\",\n        \"address4\": \"\",\n        \"allowInviteGp\": false,\n        \"contacts\": [\n          {}\n        ],\n        \"gender\": \"\",\n        \"groupCode\": \"\",\n        \"identifier\": \"\",\n        \"inviteDate\": \"\",\n        \"name\": \"\",\n        \"postcode\": \"\",\n        \"role\": \"\"\n      }\n    ],\n    \"surname\": \"\"\n  },\n  \"practitioners\": [\n    {}\n  ]\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/patientmanagement/:userId/group/:groupId/identifier/:identifierId"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"condition\": {\n    \"asserter\": \"\",\n    \"category\": \"\",\n    \"code\": \"\",\n    \"date\": \"\",\n    \"description\": \"\",\n    \"fullDescription\": \"\",\n    \"group\": {\n      \"address1\": \"\",\n      \"address2\": \"\",\n      \"address3\": \"\",\n      \"childGroups\": [],\n      \"code\": \"\",\n      \"contactPoints\": [\n        {\n          \"contactPointType\": {\n            \"description\": \"\",\n            \"id\": 0,\n            \"lookupType\": {\n              \"created\": \"\",\n              \"description\": \"\",\n              \"id\": 0,\n              \"lastUpdate\": \"\",\n              \"type\": \"\"\n            },\n            \"value\": \"\"\n          },\n          \"content\": \"\",\n          \"created\": \"\",\n          \"id\": 0,\n          \"lastUpdate\": \"\"\n        }\n      ],\n      \"created\": \"\",\n      \"fhirResourceId\": \"\",\n      \"groupFeatures\": [\n        {\n          \"created\": \"\",\n          \"feature\": {\n            \"created\": \"\",\n            \"description\": \"\",\n            \"id\": 0,\n            \"lastUpdate\": \"\",\n            \"name\": \"\"\n          },\n          \"id\": 0,\n          \"lastUpdate\": \"\"\n        }\n      ],\n      \"groupType\": {\n        \"created\": \"\",\n        \"description\": \"\",\n        \"descriptionFriendly\": \"\",\n        \"displayOrder\": 0,\n        \"id\": 0,\n        \"lastUpdate\": \"\",\n        \"lookupType\": {},\n        \"value\": \"\"\n      },\n      \"id\": 0,\n      \"lastImportDate\": \"\",\n      \"lastUpdate\": \"\",\n      \"links\": [\n        {\n          \"created\": \"\",\n          \"displayOrder\": 0,\n          \"id\": 0,\n          \"lastUpdate\": \"\",\n          \"link\": \"\",\n          \"linkType\": {},\n          \"name\": \"\"\n        }\n      ],\n      \"locations\": [\n        {\n          \"address\": \"\",\n          \"created\": \"\",\n          \"email\": \"\",\n          \"id\": 0,\n          \"label\": \"\",\n          \"lastUpdate\": \"\",\n          \"name\": \"\",\n          \"phone\": \"\",\n          \"web\": \"\"\n        }\n      ],\n      \"name\": \"\",\n      \"parentGroups\": [],\n      \"postcode\": \"\",\n      \"sftpUser\": \"\",\n      \"shortName\": \"\",\n      \"visible\": false,\n      \"visibleToJoin\": false\n    },\n    \"id\": 0,\n    \"identifier\": \"\",\n    \"links\": [\n      {}\n    ],\n    \"notes\": \"\",\n    \"severity\": \"\",\n    \"status\": \"\"\n  },\n  \"encounters\": [\n    {\n      \"date\": \"\",\n      \"encounterType\": \"\",\n      \"group\": {},\n      \"id\": 0,\n      \"identifier\": \"\",\n      \"links\": [\n        {}\n      ],\n      \"observations\": [\n        {\n          \"applies\": \"\",\n          \"bodySite\": \"\",\n          \"comments\": \"\",\n          \"comparator\": \"\",\n          \"diagram\": \"\",\n          \"group\": {},\n          \"id\": 0,\n          \"identifier\": \"\",\n          \"location\": \"\",\n          \"name\": \"\",\n          \"temporaryUuid\": \"\",\n          \"units\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"procedures\": [\n        {\n          \"bodySite\": \"\",\n          \"id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"status\": \"\"\n    }\n  ],\n  \"groupCode\": \"\",\n  \"identifier\": \"\",\n  \"observations\": [\n    {}\n  ],\n  \"patient\": {\n    \"address1\": \"\",\n    \"address2\": \"\",\n    \"address3\": \"\",\n    \"address4\": \"\",\n    \"contacts\": [\n      {\n        \"id\": 0,\n        \"system\": \"\",\n        \"use\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"dateOfBirth\": \"\",\n    \"dateOfBirthNoTime\": \"\",\n    \"forename\": \"\",\n    \"gender\": \"\",\n    \"group\": {},\n    \"groupCode\": \"\",\n    \"identifier\": \"\",\n    \"identifiers\": [\n      {\n        \"id\": 0,\n        \"label\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"postcode\": \"\",\n    \"practitioners\": [\n      {\n        \"address1\": \"\",\n        \"address2\": \"\",\n        \"address3\": \"\",\n        \"address4\": \"\",\n        \"allowInviteGp\": false,\n        \"contacts\": [\n          {}\n        ],\n        \"gender\": \"\",\n        \"groupCode\": \"\",\n        \"identifier\": \"\",\n        \"inviteDate\": \"\",\n        \"name\": \"\",\n        \"postcode\": \"\",\n        \"role\": \"\"\n      }\n    ],\n    \"surname\": \"\"\n  },\n  \"practitioners\": [\n    {}\n  ]\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"condition\": {\n    \"asserter\": \"\",\n    \"category\": \"\",\n    \"code\": \"\",\n    \"date\": \"\",\n    \"description\": \"\",\n    \"fullDescription\": \"\",\n    \"group\": {\n      \"address1\": \"\",\n      \"address2\": \"\",\n      \"address3\": \"\",\n      \"childGroups\": [],\n      \"code\": \"\",\n      \"contactPoints\": [\n        {\n          \"contactPointType\": {\n            \"description\": \"\",\n            \"id\": 0,\n            \"lookupType\": {\n              \"created\": \"\",\n              \"description\": \"\",\n              \"id\": 0,\n              \"lastUpdate\": \"\",\n              \"type\": \"\"\n            },\n            \"value\": \"\"\n          },\n          \"content\": \"\",\n          \"created\": \"\",\n          \"id\": 0,\n          \"lastUpdate\": \"\"\n        }\n      ],\n      \"created\": \"\",\n      \"fhirResourceId\": \"\",\n      \"groupFeatures\": [\n        {\n          \"created\": \"\",\n          \"feature\": {\n            \"created\": \"\",\n            \"description\": \"\",\n            \"id\": 0,\n            \"lastUpdate\": \"\",\n            \"name\": \"\"\n          },\n          \"id\": 0,\n          \"lastUpdate\": \"\"\n        }\n      ],\n      \"groupType\": {\n        \"created\": \"\",\n        \"description\": \"\",\n        \"descriptionFriendly\": \"\",\n        \"displayOrder\": 0,\n        \"id\": 0,\n        \"lastUpdate\": \"\",\n        \"lookupType\": {},\n        \"value\": \"\"\n      },\n      \"id\": 0,\n      \"lastImportDate\": \"\",\n      \"lastUpdate\": \"\",\n      \"links\": [\n        {\n          \"created\": \"\",\n          \"displayOrder\": 0,\n          \"id\": 0,\n          \"lastUpdate\": \"\",\n          \"link\": \"\",\n          \"linkType\": {},\n          \"name\": \"\"\n        }\n      ],\n      \"locations\": [\n        {\n          \"address\": \"\",\n          \"created\": \"\",\n          \"email\": \"\",\n          \"id\": 0,\n          \"label\": \"\",\n          \"lastUpdate\": \"\",\n          \"name\": \"\",\n          \"phone\": \"\",\n          \"web\": \"\"\n        }\n      ],\n      \"name\": \"\",\n      \"parentGroups\": [],\n      \"postcode\": \"\",\n      \"sftpUser\": \"\",\n      \"shortName\": \"\",\n      \"visible\": false,\n      \"visibleToJoin\": false\n    },\n    \"id\": 0,\n    \"identifier\": \"\",\n    \"links\": [\n      {}\n    ],\n    \"notes\": \"\",\n    \"severity\": \"\",\n    \"status\": \"\"\n  },\n  \"encounters\": [\n    {\n      \"date\": \"\",\n      \"encounterType\": \"\",\n      \"group\": {},\n      \"id\": 0,\n      \"identifier\": \"\",\n      \"links\": [\n        {}\n      ],\n      \"observations\": [\n        {\n          \"applies\": \"\",\n          \"bodySite\": \"\",\n          \"comments\": \"\",\n          \"comparator\": \"\",\n          \"diagram\": \"\",\n          \"group\": {},\n          \"id\": 0,\n          \"identifier\": \"\",\n          \"location\": \"\",\n          \"name\": \"\",\n          \"temporaryUuid\": \"\",\n          \"units\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"procedures\": [\n        {\n          \"bodySite\": \"\",\n          \"id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"status\": \"\"\n    }\n  ],\n  \"groupCode\": \"\",\n  \"identifier\": \"\",\n  \"observations\": [\n    {}\n  ],\n  \"patient\": {\n    \"address1\": \"\",\n    \"address2\": \"\",\n    \"address3\": \"\",\n    \"address4\": \"\",\n    \"contacts\": [\n      {\n        \"id\": 0,\n        \"system\": \"\",\n        \"use\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"dateOfBirth\": \"\",\n    \"dateOfBirthNoTime\": \"\",\n    \"forename\": \"\",\n    \"gender\": \"\",\n    \"group\": {},\n    \"groupCode\": \"\",\n    \"identifier\": \"\",\n    \"identifiers\": [\n      {\n        \"id\": 0,\n        \"label\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"postcode\": \"\",\n    \"practitioners\": [\n      {\n        \"address1\": \"\",\n        \"address2\": \"\",\n        \"address3\": \"\",\n        \"address4\": \"\",\n        \"allowInviteGp\": false,\n        \"contacts\": [\n          {}\n        ],\n        \"gender\": \"\",\n        \"groupCode\": \"\",\n        \"identifier\": \"\",\n        \"inviteDate\": \"\",\n        \"name\": \"\",\n        \"postcode\": \"\",\n        \"role\": \"\"\n      }\n    ],\n    \"surname\": \"\"\n  },\n  \"practitioners\": [\n    {}\n  ]\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/patientmanagement/:userId/group/:groupId/identifier/:identifierId")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/patientmanagement/:userId/group/:groupId/identifier/:identifierId")
  .header("content-type", "application/json")
  .body("{\n  \"condition\": {\n    \"asserter\": \"\",\n    \"category\": \"\",\n    \"code\": \"\",\n    \"date\": \"\",\n    \"description\": \"\",\n    \"fullDescription\": \"\",\n    \"group\": {\n      \"address1\": \"\",\n      \"address2\": \"\",\n      \"address3\": \"\",\n      \"childGroups\": [],\n      \"code\": \"\",\n      \"contactPoints\": [\n        {\n          \"contactPointType\": {\n            \"description\": \"\",\n            \"id\": 0,\n            \"lookupType\": {\n              \"created\": \"\",\n              \"description\": \"\",\n              \"id\": 0,\n              \"lastUpdate\": \"\",\n              \"type\": \"\"\n            },\n            \"value\": \"\"\n          },\n          \"content\": \"\",\n          \"created\": \"\",\n          \"id\": 0,\n          \"lastUpdate\": \"\"\n        }\n      ],\n      \"created\": \"\",\n      \"fhirResourceId\": \"\",\n      \"groupFeatures\": [\n        {\n          \"created\": \"\",\n          \"feature\": {\n            \"created\": \"\",\n            \"description\": \"\",\n            \"id\": 0,\n            \"lastUpdate\": \"\",\n            \"name\": \"\"\n          },\n          \"id\": 0,\n          \"lastUpdate\": \"\"\n        }\n      ],\n      \"groupType\": {\n        \"created\": \"\",\n        \"description\": \"\",\n        \"descriptionFriendly\": \"\",\n        \"displayOrder\": 0,\n        \"id\": 0,\n        \"lastUpdate\": \"\",\n        \"lookupType\": {},\n        \"value\": \"\"\n      },\n      \"id\": 0,\n      \"lastImportDate\": \"\",\n      \"lastUpdate\": \"\",\n      \"links\": [\n        {\n          \"created\": \"\",\n          \"displayOrder\": 0,\n          \"id\": 0,\n          \"lastUpdate\": \"\",\n          \"link\": \"\",\n          \"linkType\": {},\n          \"name\": \"\"\n        }\n      ],\n      \"locations\": [\n        {\n          \"address\": \"\",\n          \"created\": \"\",\n          \"email\": \"\",\n          \"id\": 0,\n          \"label\": \"\",\n          \"lastUpdate\": \"\",\n          \"name\": \"\",\n          \"phone\": \"\",\n          \"web\": \"\"\n        }\n      ],\n      \"name\": \"\",\n      \"parentGroups\": [],\n      \"postcode\": \"\",\n      \"sftpUser\": \"\",\n      \"shortName\": \"\",\n      \"visible\": false,\n      \"visibleToJoin\": false\n    },\n    \"id\": 0,\n    \"identifier\": \"\",\n    \"links\": [\n      {}\n    ],\n    \"notes\": \"\",\n    \"severity\": \"\",\n    \"status\": \"\"\n  },\n  \"encounters\": [\n    {\n      \"date\": \"\",\n      \"encounterType\": \"\",\n      \"group\": {},\n      \"id\": 0,\n      \"identifier\": \"\",\n      \"links\": [\n        {}\n      ],\n      \"observations\": [\n        {\n          \"applies\": \"\",\n          \"bodySite\": \"\",\n          \"comments\": \"\",\n          \"comparator\": \"\",\n          \"diagram\": \"\",\n          \"group\": {},\n          \"id\": 0,\n          \"identifier\": \"\",\n          \"location\": \"\",\n          \"name\": \"\",\n          \"temporaryUuid\": \"\",\n          \"units\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"procedures\": [\n        {\n          \"bodySite\": \"\",\n          \"id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"status\": \"\"\n    }\n  ],\n  \"groupCode\": \"\",\n  \"identifier\": \"\",\n  \"observations\": [\n    {}\n  ],\n  \"patient\": {\n    \"address1\": \"\",\n    \"address2\": \"\",\n    \"address3\": \"\",\n    \"address4\": \"\",\n    \"contacts\": [\n      {\n        \"id\": 0,\n        \"system\": \"\",\n        \"use\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"dateOfBirth\": \"\",\n    \"dateOfBirthNoTime\": \"\",\n    \"forename\": \"\",\n    \"gender\": \"\",\n    \"group\": {},\n    \"groupCode\": \"\",\n    \"identifier\": \"\",\n    \"identifiers\": [\n      {\n        \"id\": 0,\n        \"label\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"postcode\": \"\",\n    \"practitioners\": [\n      {\n        \"address1\": \"\",\n        \"address2\": \"\",\n        \"address3\": \"\",\n        \"address4\": \"\",\n        \"allowInviteGp\": false,\n        \"contacts\": [\n          {}\n        ],\n        \"gender\": \"\",\n        \"groupCode\": \"\",\n        \"identifier\": \"\",\n        \"inviteDate\": \"\",\n        \"name\": \"\",\n        \"postcode\": \"\",\n        \"role\": \"\"\n      }\n    ],\n    \"surname\": \"\"\n  },\n  \"practitioners\": [\n    {}\n  ]\n}")
  .asString();
const data = JSON.stringify({
  condition: {
    asserter: '',
    category: '',
    code: '',
    date: '',
    description: '',
    fullDescription: '',
    group: {
      address1: '',
      address2: '',
      address3: '',
      childGroups: [],
      code: '',
      contactPoints: [
        {
          contactPointType: {
            description: '',
            id: 0,
            lookupType: {
              created: '',
              description: '',
              id: 0,
              lastUpdate: '',
              type: ''
            },
            value: ''
          },
          content: '',
          created: '',
          id: 0,
          lastUpdate: ''
        }
      ],
      created: '',
      fhirResourceId: '',
      groupFeatures: [
        {
          created: '',
          feature: {
            created: '',
            description: '',
            id: 0,
            lastUpdate: '',
            name: ''
          },
          id: 0,
          lastUpdate: ''
        }
      ],
      groupType: {
        created: '',
        description: '',
        descriptionFriendly: '',
        displayOrder: 0,
        id: 0,
        lastUpdate: '',
        lookupType: {},
        value: ''
      },
      id: 0,
      lastImportDate: '',
      lastUpdate: '',
      links: [
        {
          created: '',
          displayOrder: 0,
          id: 0,
          lastUpdate: '',
          link: '',
          linkType: {},
          name: ''
        }
      ],
      locations: [
        {
          address: '',
          created: '',
          email: '',
          id: 0,
          label: '',
          lastUpdate: '',
          name: '',
          phone: '',
          web: ''
        }
      ],
      name: '',
      parentGroups: [],
      postcode: '',
      sftpUser: '',
      shortName: '',
      visible: false,
      visibleToJoin: false
    },
    id: 0,
    identifier: '',
    links: [
      {}
    ],
    notes: '',
    severity: '',
    status: ''
  },
  encounters: [
    {
      date: '',
      encounterType: '',
      group: {},
      id: 0,
      identifier: '',
      links: [
        {}
      ],
      observations: [
        {
          applies: '',
          bodySite: '',
          comments: '',
          comparator: '',
          diagram: '',
          group: {},
          id: 0,
          identifier: '',
          location: '',
          name: '',
          temporaryUuid: '',
          units: '',
          value: ''
        }
      ],
      procedures: [
        {
          bodySite: '',
          id: 0,
          type: ''
        }
      ],
      status: ''
    }
  ],
  groupCode: '',
  identifier: '',
  observations: [
    {}
  ],
  patient: {
    address1: '',
    address2: '',
    address3: '',
    address4: '',
    contacts: [
      {
        id: 0,
        system: '',
        use: '',
        value: ''
      }
    ],
    dateOfBirth: '',
    dateOfBirthNoTime: '',
    forename: '',
    gender: '',
    group: {},
    groupCode: '',
    identifier: '',
    identifiers: [
      {
        id: 0,
        label: '',
        value: ''
      }
    ],
    postcode: '',
    practitioners: [
      {
        address1: '',
        address2: '',
        address3: '',
        address4: '',
        allowInviteGp: false,
        contacts: [
          {}
        ],
        gender: '',
        groupCode: '',
        identifier: '',
        inviteDate: '',
        name: '',
        postcode: '',
        role: ''
      }
    ],
    surname: ''
  },
  practitioners: [
    {}
  ]
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/patientmanagement/:userId/group/:groupId/identifier/:identifierId');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/patientmanagement/:userId/group/:groupId/identifier/:identifierId',
  headers: {'content-type': 'application/json'},
  data: {
    condition: {
      asserter: '',
      category: '',
      code: '',
      date: '',
      description: '',
      fullDescription: '',
      group: {
        address1: '',
        address2: '',
        address3: '',
        childGroups: [],
        code: '',
        contactPoints: [
          {
            contactPointType: {
              description: '',
              id: 0,
              lookupType: {created: '', description: '', id: 0, lastUpdate: '', type: ''},
              value: ''
            },
            content: '',
            created: '',
            id: 0,
            lastUpdate: ''
          }
        ],
        created: '',
        fhirResourceId: '',
        groupFeatures: [
          {
            created: '',
            feature: {created: '', description: '', id: 0, lastUpdate: '', name: ''},
            id: 0,
            lastUpdate: ''
          }
        ],
        groupType: {
          created: '',
          description: '',
          descriptionFriendly: '',
          displayOrder: 0,
          id: 0,
          lastUpdate: '',
          lookupType: {},
          value: ''
        },
        id: 0,
        lastImportDate: '',
        lastUpdate: '',
        links: [
          {
            created: '',
            displayOrder: 0,
            id: 0,
            lastUpdate: '',
            link: '',
            linkType: {},
            name: ''
          }
        ],
        locations: [
          {
            address: '',
            created: '',
            email: '',
            id: 0,
            label: '',
            lastUpdate: '',
            name: '',
            phone: '',
            web: ''
          }
        ],
        name: '',
        parentGroups: [],
        postcode: '',
        sftpUser: '',
        shortName: '',
        visible: false,
        visibleToJoin: false
      },
      id: 0,
      identifier: '',
      links: [{}],
      notes: '',
      severity: '',
      status: ''
    },
    encounters: [
      {
        date: '',
        encounterType: '',
        group: {},
        id: 0,
        identifier: '',
        links: [{}],
        observations: [
          {
            applies: '',
            bodySite: '',
            comments: '',
            comparator: '',
            diagram: '',
            group: {},
            id: 0,
            identifier: '',
            location: '',
            name: '',
            temporaryUuid: '',
            units: '',
            value: ''
          }
        ],
        procedures: [{bodySite: '', id: 0, type: ''}],
        status: ''
      }
    ],
    groupCode: '',
    identifier: '',
    observations: [{}],
    patient: {
      address1: '',
      address2: '',
      address3: '',
      address4: '',
      contacts: [{id: 0, system: '', use: '', value: ''}],
      dateOfBirth: '',
      dateOfBirthNoTime: '',
      forename: '',
      gender: '',
      group: {},
      groupCode: '',
      identifier: '',
      identifiers: [{id: 0, label: '', value: ''}],
      postcode: '',
      practitioners: [
        {
          address1: '',
          address2: '',
          address3: '',
          address4: '',
          allowInviteGp: false,
          contacts: [{}],
          gender: '',
          groupCode: '',
          identifier: '',
          inviteDate: '',
          name: '',
          postcode: '',
          role: ''
        }
      ],
      surname: ''
    },
    practitioners: [{}]
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/patientmanagement/:userId/group/:groupId/identifier/:identifierId';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"condition":{"asserter":"","category":"","code":"","date":"","description":"","fullDescription":"","group":{"address1":"","address2":"","address3":"","childGroups":[],"code":"","contactPoints":[{"contactPointType":{"description":"","id":0,"lookupType":{"created":"","description":"","id":0,"lastUpdate":"","type":""},"value":""},"content":"","created":"","id":0,"lastUpdate":""}],"created":"","fhirResourceId":"","groupFeatures":[{"created":"","feature":{"created":"","description":"","id":0,"lastUpdate":"","name":""},"id":0,"lastUpdate":""}],"groupType":{"created":"","description":"","descriptionFriendly":"","displayOrder":0,"id":0,"lastUpdate":"","lookupType":{},"value":""},"id":0,"lastImportDate":"","lastUpdate":"","links":[{"created":"","displayOrder":0,"id":0,"lastUpdate":"","link":"","linkType":{},"name":""}],"locations":[{"address":"","created":"","email":"","id":0,"label":"","lastUpdate":"","name":"","phone":"","web":""}],"name":"","parentGroups":[],"postcode":"","sftpUser":"","shortName":"","visible":false,"visibleToJoin":false},"id":0,"identifier":"","links":[{}],"notes":"","severity":"","status":""},"encounters":[{"date":"","encounterType":"","group":{},"id":0,"identifier":"","links":[{}],"observations":[{"applies":"","bodySite":"","comments":"","comparator":"","diagram":"","group":{},"id":0,"identifier":"","location":"","name":"","temporaryUuid":"","units":"","value":""}],"procedures":[{"bodySite":"","id":0,"type":""}],"status":""}],"groupCode":"","identifier":"","observations":[{}],"patient":{"address1":"","address2":"","address3":"","address4":"","contacts":[{"id":0,"system":"","use":"","value":""}],"dateOfBirth":"","dateOfBirthNoTime":"","forename":"","gender":"","group":{},"groupCode":"","identifier":"","identifiers":[{"id":0,"label":"","value":""}],"postcode":"","practitioners":[{"address1":"","address2":"","address3":"","address4":"","allowInviteGp":false,"contacts":[{}],"gender":"","groupCode":"","identifier":"","inviteDate":"","name":"","postcode":"","role":""}],"surname":""},"practitioners":[{}]}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/patientmanagement/:userId/group/:groupId/identifier/:identifierId',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "condition": {\n    "asserter": "",\n    "category": "",\n    "code": "",\n    "date": "",\n    "description": "",\n    "fullDescription": "",\n    "group": {\n      "address1": "",\n      "address2": "",\n      "address3": "",\n      "childGroups": [],\n      "code": "",\n      "contactPoints": [\n        {\n          "contactPointType": {\n            "description": "",\n            "id": 0,\n            "lookupType": {\n              "created": "",\n              "description": "",\n              "id": 0,\n              "lastUpdate": "",\n              "type": ""\n            },\n            "value": ""\n          },\n          "content": "",\n          "created": "",\n          "id": 0,\n          "lastUpdate": ""\n        }\n      ],\n      "created": "",\n      "fhirResourceId": "",\n      "groupFeatures": [\n        {\n          "created": "",\n          "feature": {\n            "created": "",\n            "description": "",\n            "id": 0,\n            "lastUpdate": "",\n            "name": ""\n          },\n          "id": 0,\n          "lastUpdate": ""\n        }\n      ],\n      "groupType": {\n        "created": "",\n        "description": "",\n        "descriptionFriendly": "",\n        "displayOrder": 0,\n        "id": 0,\n        "lastUpdate": "",\n        "lookupType": {},\n        "value": ""\n      },\n      "id": 0,\n      "lastImportDate": "",\n      "lastUpdate": "",\n      "links": [\n        {\n          "created": "",\n          "displayOrder": 0,\n          "id": 0,\n          "lastUpdate": "",\n          "link": "",\n          "linkType": {},\n          "name": ""\n        }\n      ],\n      "locations": [\n        {\n          "address": "",\n          "created": "",\n          "email": "",\n          "id": 0,\n          "label": "",\n          "lastUpdate": "",\n          "name": "",\n          "phone": "",\n          "web": ""\n        }\n      ],\n      "name": "",\n      "parentGroups": [],\n      "postcode": "",\n      "sftpUser": "",\n      "shortName": "",\n      "visible": false,\n      "visibleToJoin": false\n    },\n    "id": 0,\n    "identifier": "",\n    "links": [\n      {}\n    ],\n    "notes": "",\n    "severity": "",\n    "status": ""\n  },\n  "encounters": [\n    {\n      "date": "",\n      "encounterType": "",\n      "group": {},\n      "id": 0,\n      "identifier": "",\n      "links": [\n        {}\n      ],\n      "observations": [\n        {\n          "applies": "",\n          "bodySite": "",\n          "comments": "",\n          "comparator": "",\n          "diagram": "",\n          "group": {},\n          "id": 0,\n          "identifier": "",\n          "location": "",\n          "name": "",\n          "temporaryUuid": "",\n          "units": "",\n          "value": ""\n        }\n      ],\n      "procedures": [\n        {\n          "bodySite": "",\n          "id": 0,\n          "type": ""\n        }\n      ],\n      "status": ""\n    }\n  ],\n  "groupCode": "",\n  "identifier": "",\n  "observations": [\n    {}\n  ],\n  "patient": {\n    "address1": "",\n    "address2": "",\n    "address3": "",\n    "address4": "",\n    "contacts": [\n      {\n        "id": 0,\n        "system": "",\n        "use": "",\n        "value": ""\n      }\n    ],\n    "dateOfBirth": "",\n    "dateOfBirthNoTime": "",\n    "forename": "",\n    "gender": "",\n    "group": {},\n    "groupCode": "",\n    "identifier": "",\n    "identifiers": [\n      {\n        "id": 0,\n        "label": "",\n        "value": ""\n      }\n    ],\n    "postcode": "",\n    "practitioners": [\n      {\n        "address1": "",\n        "address2": "",\n        "address3": "",\n        "address4": "",\n        "allowInviteGp": false,\n        "contacts": [\n          {}\n        ],\n        "gender": "",\n        "groupCode": "",\n        "identifier": "",\n        "inviteDate": "",\n        "name": "",\n        "postcode": "",\n        "role": ""\n      }\n    ],\n    "surname": ""\n  },\n  "practitioners": [\n    {}\n  ]\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"condition\": {\n    \"asserter\": \"\",\n    \"category\": \"\",\n    \"code\": \"\",\n    \"date\": \"\",\n    \"description\": \"\",\n    \"fullDescription\": \"\",\n    \"group\": {\n      \"address1\": \"\",\n      \"address2\": \"\",\n      \"address3\": \"\",\n      \"childGroups\": [],\n      \"code\": \"\",\n      \"contactPoints\": [\n        {\n          \"contactPointType\": {\n            \"description\": \"\",\n            \"id\": 0,\n            \"lookupType\": {\n              \"created\": \"\",\n              \"description\": \"\",\n              \"id\": 0,\n              \"lastUpdate\": \"\",\n              \"type\": \"\"\n            },\n            \"value\": \"\"\n          },\n          \"content\": \"\",\n          \"created\": \"\",\n          \"id\": 0,\n          \"lastUpdate\": \"\"\n        }\n      ],\n      \"created\": \"\",\n      \"fhirResourceId\": \"\",\n      \"groupFeatures\": [\n        {\n          \"created\": \"\",\n          \"feature\": {\n            \"created\": \"\",\n            \"description\": \"\",\n            \"id\": 0,\n            \"lastUpdate\": \"\",\n            \"name\": \"\"\n          },\n          \"id\": 0,\n          \"lastUpdate\": \"\"\n        }\n      ],\n      \"groupType\": {\n        \"created\": \"\",\n        \"description\": \"\",\n        \"descriptionFriendly\": \"\",\n        \"displayOrder\": 0,\n        \"id\": 0,\n        \"lastUpdate\": \"\",\n        \"lookupType\": {},\n        \"value\": \"\"\n      },\n      \"id\": 0,\n      \"lastImportDate\": \"\",\n      \"lastUpdate\": \"\",\n      \"links\": [\n        {\n          \"created\": \"\",\n          \"displayOrder\": 0,\n          \"id\": 0,\n          \"lastUpdate\": \"\",\n          \"link\": \"\",\n          \"linkType\": {},\n          \"name\": \"\"\n        }\n      ],\n      \"locations\": [\n        {\n          \"address\": \"\",\n          \"created\": \"\",\n          \"email\": \"\",\n          \"id\": 0,\n          \"label\": \"\",\n          \"lastUpdate\": \"\",\n          \"name\": \"\",\n          \"phone\": \"\",\n          \"web\": \"\"\n        }\n      ],\n      \"name\": \"\",\n      \"parentGroups\": [],\n      \"postcode\": \"\",\n      \"sftpUser\": \"\",\n      \"shortName\": \"\",\n      \"visible\": false,\n      \"visibleToJoin\": false\n    },\n    \"id\": 0,\n    \"identifier\": \"\",\n    \"links\": [\n      {}\n    ],\n    \"notes\": \"\",\n    \"severity\": \"\",\n    \"status\": \"\"\n  },\n  \"encounters\": [\n    {\n      \"date\": \"\",\n      \"encounterType\": \"\",\n      \"group\": {},\n      \"id\": 0,\n      \"identifier\": \"\",\n      \"links\": [\n        {}\n      ],\n      \"observations\": [\n        {\n          \"applies\": \"\",\n          \"bodySite\": \"\",\n          \"comments\": \"\",\n          \"comparator\": \"\",\n          \"diagram\": \"\",\n          \"group\": {},\n          \"id\": 0,\n          \"identifier\": \"\",\n          \"location\": \"\",\n          \"name\": \"\",\n          \"temporaryUuid\": \"\",\n          \"units\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"procedures\": [\n        {\n          \"bodySite\": \"\",\n          \"id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"status\": \"\"\n    }\n  ],\n  \"groupCode\": \"\",\n  \"identifier\": \"\",\n  \"observations\": [\n    {}\n  ],\n  \"patient\": {\n    \"address1\": \"\",\n    \"address2\": \"\",\n    \"address3\": \"\",\n    \"address4\": \"\",\n    \"contacts\": [\n      {\n        \"id\": 0,\n        \"system\": \"\",\n        \"use\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"dateOfBirth\": \"\",\n    \"dateOfBirthNoTime\": \"\",\n    \"forename\": \"\",\n    \"gender\": \"\",\n    \"group\": {},\n    \"groupCode\": \"\",\n    \"identifier\": \"\",\n    \"identifiers\": [\n      {\n        \"id\": 0,\n        \"label\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"postcode\": \"\",\n    \"practitioners\": [\n      {\n        \"address1\": \"\",\n        \"address2\": \"\",\n        \"address3\": \"\",\n        \"address4\": \"\",\n        \"allowInviteGp\": false,\n        \"contacts\": [\n          {}\n        ],\n        \"gender\": \"\",\n        \"groupCode\": \"\",\n        \"identifier\": \"\",\n        \"inviteDate\": \"\",\n        \"name\": \"\",\n        \"postcode\": \"\",\n        \"role\": \"\"\n      }\n    ],\n    \"surname\": \"\"\n  },\n  \"practitioners\": [\n    {}\n  ]\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/patientmanagement/:userId/group/:groupId/identifier/:identifierId")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/patientmanagement/:userId/group/:groupId/identifier/:identifierId',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  condition: {
    asserter: '',
    category: '',
    code: '',
    date: '',
    description: '',
    fullDescription: '',
    group: {
      address1: '',
      address2: '',
      address3: '',
      childGroups: [],
      code: '',
      contactPoints: [
        {
          contactPointType: {
            description: '',
            id: 0,
            lookupType: {created: '', description: '', id: 0, lastUpdate: '', type: ''},
            value: ''
          },
          content: '',
          created: '',
          id: 0,
          lastUpdate: ''
        }
      ],
      created: '',
      fhirResourceId: '',
      groupFeatures: [
        {
          created: '',
          feature: {created: '', description: '', id: 0, lastUpdate: '', name: ''},
          id: 0,
          lastUpdate: ''
        }
      ],
      groupType: {
        created: '',
        description: '',
        descriptionFriendly: '',
        displayOrder: 0,
        id: 0,
        lastUpdate: '',
        lookupType: {},
        value: ''
      },
      id: 0,
      lastImportDate: '',
      lastUpdate: '',
      links: [
        {
          created: '',
          displayOrder: 0,
          id: 0,
          lastUpdate: '',
          link: '',
          linkType: {},
          name: ''
        }
      ],
      locations: [
        {
          address: '',
          created: '',
          email: '',
          id: 0,
          label: '',
          lastUpdate: '',
          name: '',
          phone: '',
          web: ''
        }
      ],
      name: '',
      parentGroups: [],
      postcode: '',
      sftpUser: '',
      shortName: '',
      visible: false,
      visibleToJoin: false
    },
    id: 0,
    identifier: '',
    links: [{}],
    notes: '',
    severity: '',
    status: ''
  },
  encounters: [
    {
      date: '',
      encounterType: '',
      group: {},
      id: 0,
      identifier: '',
      links: [{}],
      observations: [
        {
          applies: '',
          bodySite: '',
          comments: '',
          comparator: '',
          diagram: '',
          group: {},
          id: 0,
          identifier: '',
          location: '',
          name: '',
          temporaryUuid: '',
          units: '',
          value: ''
        }
      ],
      procedures: [{bodySite: '', id: 0, type: ''}],
      status: ''
    }
  ],
  groupCode: '',
  identifier: '',
  observations: [{}],
  patient: {
    address1: '',
    address2: '',
    address3: '',
    address4: '',
    contacts: [{id: 0, system: '', use: '', value: ''}],
    dateOfBirth: '',
    dateOfBirthNoTime: '',
    forename: '',
    gender: '',
    group: {},
    groupCode: '',
    identifier: '',
    identifiers: [{id: 0, label: '', value: ''}],
    postcode: '',
    practitioners: [
      {
        address1: '',
        address2: '',
        address3: '',
        address4: '',
        allowInviteGp: false,
        contacts: [{}],
        gender: '',
        groupCode: '',
        identifier: '',
        inviteDate: '',
        name: '',
        postcode: '',
        role: ''
      }
    ],
    surname: ''
  },
  practitioners: [{}]
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/patientmanagement/:userId/group/:groupId/identifier/:identifierId',
  headers: {'content-type': 'application/json'},
  body: {
    condition: {
      asserter: '',
      category: '',
      code: '',
      date: '',
      description: '',
      fullDescription: '',
      group: {
        address1: '',
        address2: '',
        address3: '',
        childGroups: [],
        code: '',
        contactPoints: [
          {
            contactPointType: {
              description: '',
              id: 0,
              lookupType: {created: '', description: '', id: 0, lastUpdate: '', type: ''},
              value: ''
            },
            content: '',
            created: '',
            id: 0,
            lastUpdate: ''
          }
        ],
        created: '',
        fhirResourceId: '',
        groupFeatures: [
          {
            created: '',
            feature: {created: '', description: '', id: 0, lastUpdate: '', name: ''},
            id: 0,
            lastUpdate: ''
          }
        ],
        groupType: {
          created: '',
          description: '',
          descriptionFriendly: '',
          displayOrder: 0,
          id: 0,
          lastUpdate: '',
          lookupType: {},
          value: ''
        },
        id: 0,
        lastImportDate: '',
        lastUpdate: '',
        links: [
          {
            created: '',
            displayOrder: 0,
            id: 0,
            lastUpdate: '',
            link: '',
            linkType: {},
            name: ''
          }
        ],
        locations: [
          {
            address: '',
            created: '',
            email: '',
            id: 0,
            label: '',
            lastUpdate: '',
            name: '',
            phone: '',
            web: ''
          }
        ],
        name: '',
        parentGroups: [],
        postcode: '',
        sftpUser: '',
        shortName: '',
        visible: false,
        visibleToJoin: false
      },
      id: 0,
      identifier: '',
      links: [{}],
      notes: '',
      severity: '',
      status: ''
    },
    encounters: [
      {
        date: '',
        encounterType: '',
        group: {},
        id: 0,
        identifier: '',
        links: [{}],
        observations: [
          {
            applies: '',
            bodySite: '',
            comments: '',
            comparator: '',
            diagram: '',
            group: {},
            id: 0,
            identifier: '',
            location: '',
            name: '',
            temporaryUuid: '',
            units: '',
            value: ''
          }
        ],
        procedures: [{bodySite: '', id: 0, type: ''}],
        status: ''
      }
    ],
    groupCode: '',
    identifier: '',
    observations: [{}],
    patient: {
      address1: '',
      address2: '',
      address3: '',
      address4: '',
      contacts: [{id: 0, system: '', use: '', value: ''}],
      dateOfBirth: '',
      dateOfBirthNoTime: '',
      forename: '',
      gender: '',
      group: {},
      groupCode: '',
      identifier: '',
      identifiers: [{id: 0, label: '', value: ''}],
      postcode: '',
      practitioners: [
        {
          address1: '',
          address2: '',
          address3: '',
          address4: '',
          allowInviteGp: false,
          contacts: [{}],
          gender: '',
          groupCode: '',
          identifier: '',
          inviteDate: '',
          name: '',
          postcode: '',
          role: ''
        }
      ],
      surname: ''
    },
    practitioners: [{}]
  },
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/patientmanagement/:userId/group/:groupId/identifier/:identifierId');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  condition: {
    asserter: '',
    category: '',
    code: '',
    date: '',
    description: '',
    fullDescription: '',
    group: {
      address1: '',
      address2: '',
      address3: '',
      childGroups: [],
      code: '',
      contactPoints: [
        {
          contactPointType: {
            description: '',
            id: 0,
            lookupType: {
              created: '',
              description: '',
              id: 0,
              lastUpdate: '',
              type: ''
            },
            value: ''
          },
          content: '',
          created: '',
          id: 0,
          lastUpdate: ''
        }
      ],
      created: '',
      fhirResourceId: '',
      groupFeatures: [
        {
          created: '',
          feature: {
            created: '',
            description: '',
            id: 0,
            lastUpdate: '',
            name: ''
          },
          id: 0,
          lastUpdate: ''
        }
      ],
      groupType: {
        created: '',
        description: '',
        descriptionFriendly: '',
        displayOrder: 0,
        id: 0,
        lastUpdate: '',
        lookupType: {},
        value: ''
      },
      id: 0,
      lastImportDate: '',
      lastUpdate: '',
      links: [
        {
          created: '',
          displayOrder: 0,
          id: 0,
          lastUpdate: '',
          link: '',
          linkType: {},
          name: ''
        }
      ],
      locations: [
        {
          address: '',
          created: '',
          email: '',
          id: 0,
          label: '',
          lastUpdate: '',
          name: '',
          phone: '',
          web: ''
        }
      ],
      name: '',
      parentGroups: [],
      postcode: '',
      sftpUser: '',
      shortName: '',
      visible: false,
      visibleToJoin: false
    },
    id: 0,
    identifier: '',
    links: [
      {}
    ],
    notes: '',
    severity: '',
    status: ''
  },
  encounters: [
    {
      date: '',
      encounterType: '',
      group: {},
      id: 0,
      identifier: '',
      links: [
        {}
      ],
      observations: [
        {
          applies: '',
          bodySite: '',
          comments: '',
          comparator: '',
          diagram: '',
          group: {},
          id: 0,
          identifier: '',
          location: '',
          name: '',
          temporaryUuid: '',
          units: '',
          value: ''
        }
      ],
      procedures: [
        {
          bodySite: '',
          id: 0,
          type: ''
        }
      ],
      status: ''
    }
  ],
  groupCode: '',
  identifier: '',
  observations: [
    {}
  ],
  patient: {
    address1: '',
    address2: '',
    address3: '',
    address4: '',
    contacts: [
      {
        id: 0,
        system: '',
        use: '',
        value: ''
      }
    ],
    dateOfBirth: '',
    dateOfBirthNoTime: '',
    forename: '',
    gender: '',
    group: {},
    groupCode: '',
    identifier: '',
    identifiers: [
      {
        id: 0,
        label: '',
        value: ''
      }
    ],
    postcode: '',
    practitioners: [
      {
        address1: '',
        address2: '',
        address3: '',
        address4: '',
        allowInviteGp: false,
        contacts: [
          {}
        ],
        gender: '',
        groupCode: '',
        identifier: '',
        inviteDate: '',
        name: '',
        postcode: '',
        role: ''
      }
    ],
    surname: ''
  },
  practitioners: [
    {}
  ]
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'POST',
  url: '{{baseUrl}}/patientmanagement/:userId/group/:groupId/identifier/:identifierId',
  headers: {'content-type': 'application/json'},
  data: {
    condition: {
      asserter: '',
      category: '',
      code: '',
      date: '',
      description: '',
      fullDescription: '',
      group: {
        address1: '',
        address2: '',
        address3: '',
        childGroups: [],
        code: '',
        contactPoints: [
          {
            contactPointType: {
              description: '',
              id: 0,
              lookupType: {created: '', description: '', id: 0, lastUpdate: '', type: ''},
              value: ''
            },
            content: '',
            created: '',
            id: 0,
            lastUpdate: ''
          }
        ],
        created: '',
        fhirResourceId: '',
        groupFeatures: [
          {
            created: '',
            feature: {created: '', description: '', id: 0, lastUpdate: '', name: ''},
            id: 0,
            lastUpdate: ''
          }
        ],
        groupType: {
          created: '',
          description: '',
          descriptionFriendly: '',
          displayOrder: 0,
          id: 0,
          lastUpdate: '',
          lookupType: {},
          value: ''
        },
        id: 0,
        lastImportDate: '',
        lastUpdate: '',
        links: [
          {
            created: '',
            displayOrder: 0,
            id: 0,
            lastUpdate: '',
            link: '',
            linkType: {},
            name: ''
          }
        ],
        locations: [
          {
            address: '',
            created: '',
            email: '',
            id: 0,
            label: '',
            lastUpdate: '',
            name: '',
            phone: '',
            web: ''
          }
        ],
        name: '',
        parentGroups: [],
        postcode: '',
        sftpUser: '',
        shortName: '',
        visible: false,
        visibleToJoin: false
      },
      id: 0,
      identifier: '',
      links: [{}],
      notes: '',
      severity: '',
      status: ''
    },
    encounters: [
      {
        date: '',
        encounterType: '',
        group: {},
        id: 0,
        identifier: '',
        links: [{}],
        observations: [
          {
            applies: '',
            bodySite: '',
            comments: '',
            comparator: '',
            diagram: '',
            group: {},
            id: 0,
            identifier: '',
            location: '',
            name: '',
            temporaryUuid: '',
            units: '',
            value: ''
          }
        ],
        procedures: [{bodySite: '', id: 0, type: ''}],
        status: ''
      }
    ],
    groupCode: '',
    identifier: '',
    observations: [{}],
    patient: {
      address1: '',
      address2: '',
      address3: '',
      address4: '',
      contacts: [{id: 0, system: '', use: '', value: ''}],
      dateOfBirth: '',
      dateOfBirthNoTime: '',
      forename: '',
      gender: '',
      group: {},
      groupCode: '',
      identifier: '',
      identifiers: [{id: 0, label: '', value: ''}],
      postcode: '',
      practitioners: [
        {
          address1: '',
          address2: '',
          address3: '',
          address4: '',
          allowInviteGp: false,
          contacts: [{}],
          gender: '',
          groupCode: '',
          identifier: '',
          inviteDate: '',
          name: '',
          postcode: '',
          role: ''
        }
      ],
      surname: ''
    },
    practitioners: [{}]
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/patientmanagement/:userId/group/:groupId/identifier/:identifierId';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"condition":{"asserter":"","category":"","code":"","date":"","description":"","fullDescription":"","group":{"address1":"","address2":"","address3":"","childGroups":[],"code":"","contactPoints":[{"contactPointType":{"description":"","id":0,"lookupType":{"created":"","description":"","id":0,"lastUpdate":"","type":""},"value":""},"content":"","created":"","id":0,"lastUpdate":""}],"created":"","fhirResourceId":"","groupFeatures":[{"created":"","feature":{"created":"","description":"","id":0,"lastUpdate":"","name":""},"id":0,"lastUpdate":""}],"groupType":{"created":"","description":"","descriptionFriendly":"","displayOrder":0,"id":0,"lastUpdate":"","lookupType":{},"value":""},"id":0,"lastImportDate":"","lastUpdate":"","links":[{"created":"","displayOrder":0,"id":0,"lastUpdate":"","link":"","linkType":{},"name":""}],"locations":[{"address":"","created":"","email":"","id":0,"label":"","lastUpdate":"","name":"","phone":"","web":""}],"name":"","parentGroups":[],"postcode":"","sftpUser":"","shortName":"","visible":false,"visibleToJoin":false},"id":0,"identifier":"","links":[{}],"notes":"","severity":"","status":""},"encounters":[{"date":"","encounterType":"","group":{},"id":0,"identifier":"","links":[{}],"observations":[{"applies":"","bodySite":"","comments":"","comparator":"","diagram":"","group":{},"id":0,"identifier":"","location":"","name":"","temporaryUuid":"","units":"","value":""}],"procedures":[{"bodySite":"","id":0,"type":""}],"status":""}],"groupCode":"","identifier":"","observations":[{}],"patient":{"address1":"","address2":"","address3":"","address4":"","contacts":[{"id":0,"system":"","use":"","value":""}],"dateOfBirth":"","dateOfBirthNoTime":"","forename":"","gender":"","group":{},"groupCode":"","identifier":"","identifiers":[{"id":0,"label":"","value":""}],"postcode":"","practitioners":[{"address1":"","address2":"","address3":"","address4":"","allowInviteGp":false,"contacts":[{}],"gender":"","groupCode":"","identifier":"","inviteDate":"","name":"","postcode":"","role":""}],"surname":""},"practitioners":[{}]}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"condition": @{ @"asserter": @"", @"category": @"", @"code": @"", @"date": @"", @"description": @"", @"fullDescription": @"", @"group": @{ @"address1": @"", @"address2": @"", @"address3": @"", @"childGroups": @[  ], @"code": @"", @"contactPoints": @[ @{ @"contactPointType": @{ @"description": @"", @"id": @0, @"lookupType": @{ @"created": @"", @"description": @"", @"id": @0, @"lastUpdate": @"", @"type": @"" }, @"value": @"" }, @"content": @"", @"created": @"", @"id": @0, @"lastUpdate": @"" } ], @"created": @"", @"fhirResourceId": @"", @"groupFeatures": @[ @{ @"created": @"", @"feature": @{ @"created": @"", @"description": @"", @"id": @0, @"lastUpdate": @"", @"name": @"" }, @"id": @0, @"lastUpdate": @"" } ], @"groupType": @{ @"created": @"", @"description": @"", @"descriptionFriendly": @"", @"displayOrder": @0, @"id": @0, @"lastUpdate": @"", @"lookupType": @{  }, @"value": @"" }, @"id": @0, @"lastImportDate": @"", @"lastUpdate": @"", @"links": @[ @{ @"created": @"", @"displayOrder": @0, @"id": @0, @"lastUpdate": @"", @"link": @"", @"linkType": @{  }, @"name": @"" } ], @"locations": @[ @{ @"address": @"", @"created": @"", @"email": @"", @"id": @0, @"label": @"", @"lastUpdate": @"", @"name": @"", @"phone": @"", @"web": @"" } ], @"name": @"", @"parentGroups": @[  ], @"postcode": @"", @"sftpUser": @"", @"shortName": @"", @"visible": @NO, @"visibleToJoin": @NO }, @"id": @0, @"identifier": @"", @"links": @[ @{  } ], @"notes": @"", @"severity": @"", @"status": @"" },
                              @"encounters": @[ @{ @"date": @"", @"encounterType": @"", @"group": @{  }, @"id": @0, @"identifier": @"", @"links": @[ @{  } ], @"observations": @[ @{ @"applies": @"", @"bodySite": @"", @"comments": @"", @"comparator": @"", @"diagram": @"", @"group": @{  }, @"id": @0, @"identifier": @"", @"location": @"", @"name": @"", @"temporaryUuid": @"", @"units": @"", @"value": @"" } ], @"procedures": @[ @{ @"bodySite": @"", @"id": @0, @"type": @"" } ], @"status": @"" } ],
                              @"groupCode": @"",
                              @"identifier": @"",
                              @"observations": @[ @{  } ],
                              @"patient": @{ @"address1": @"", @"address2": @"", @"address3": @"", @"address4": @"", @"contacts": @[ @{ @"id": @0, @"system": @"", @"use": @"", @"value": @"" } ], @"dateOfBirth": @"", @"dateOfBirthNoTime": @"", @"forename": @"", @"gender": @"", @"group": @{  }, @"groupCode": @"", @"identifier": @"", @"identifiers": @[ @{ @"id": @0, @"label": @"", @"value": @"" } ], @"postcode": @"", @"practitioners": @[ @{ @"address1": @"", @"address2": @"", @"address3": @"", @"address4": @"", @"allowInviteGp": @NO, @"contacts": @[ @{  } ], @"gender": @"", @"groupCode": @"", @"identifier": @"", @"inviteDate": @"", @"name": @"", @"postcode": @"", @"role": @"" } ], @"surname": @"" },
                              @"practitioners": @[ @{  } ] };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/patientmanagement/:userId/group/:groupId/identifier/:identifierId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/patientmanagement/:userId/group/:groupId/identifier/:identifierId" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"condition\": {\n    \"asserter\": \"\",\n    \"category\": \"\",\n    \"code\": \"\",\n    \"date\": \"\",\n    \"description\": \"\",\n    \"fullDescription\": \"\",\n    \"group\": {\n      \"address1\": \"\",\n      \"address2\": \"\",\n      \"address3\": \"\",\n      \"childGroups\": [],\n      \"code\": \"\",\n      \"contactPoints\": [\n        {\n          \"contactPointType\": {\n            \"description\": \"\",\n            \"id\": 0,\n            \"lookupType\": {\n              \"created\": \"\",\n              \"description\": \"\",\n              \"id\": 0,\n              \"lastUpdate\": \"\",\n              \"type\": \"\"\n            },\n            \"value\": \"\"\n          },\n          \"content\": \"\",\n          \"created\": \"\",\n          \"id\": 0,\n          \"lastUpdate\": \"\"\n        }\n      ],\n      \"created\": \"\",\n      \"fhirResourceId\": \"\",\n      \"groupFeatures\": [\n        {\n          \"created\": \"\",\n          \"feature\": {\n            \"created\": \"\",\n            \"description\": \"\",\n            \"id\": 0,\n            \"lastUpdate\": \"\",\n            \"name\": \"\"\n          },\n          \"id\": 0,\n          \"lastUpdate\": \"\"\n        }\n      ],\n      \"groupType\": {\n        \"created\": \"\",\n        \"description\": \"\",\n        \"descriptionFriendly\": \"\",\n        \"displayOrder\": 0,\n        \"id\": 0,\n        \"lastUpdate\": \"\",\n        \"lookupType\": {},\n        \"value\": \"\"\n      },\n      \"id\": 0,\n      \"lastImportDate\": \"\",\n      \"lastUpdate\": \"\",\n      \"links\": [\n        {\n          \"created\": \"\",\n          \"displayOrder\": 0,\n          \"id\": 0,\n          \"lastUpdate\": \"\",\n          \"link\": \"\",\n          \"linkType\": {},\n          \"name\": \"\"\n        }\n      ],\n      \"locations\": [\n        {\n          \"address\": \"\",\n          \"created\": \"\",\n          \"email\": \"\",\n          \"id\": 0,\n          \"label\": \"\",\n          \"lastUpdate\": \"\",\n          \"name\": \"\",\n          \"phone\": \"\",\n          \"web\": \"\"\n        }\n      ],\n      \"name\": \"\",\n      \"parentGroups\": [],\n      \"postcode\": \"\",\n      \"sftpUser\": \"\",\n      \"shortName\": \"\",\n      \"visible\": false,\n      \"visibleToJoin\": false\n    },\n    \"id\": 0,\n    \"identifier\": \"\",\n    \"links\": [\n      {}\n    ],\n    \"notes\": \"\",\n    \"severity\": \"\",\n    \"status\": \"\"\n  },\n  \"encounters\": [\n    {\n      \"date\": \"\",\n      \"encounterType\": \"\",\n      \"group\": {},\n      \"id\": 0,\n      \"identifier\": \"\",\n      \"links\": [\n        {}\n      ],\n      \"observations\": [\n        {\n          \"applies\": \"\",\n          \"bodySite\": \"\",\n          \"comments\": \"\",\n          \"comparator\": \"\",\n          \"diagram\": \"\",\n          \"group\": {},\n          \"id\": 0,\n          \"identifier\": \"\",\n          \"location\": \"\",\n          \"name\": \"\",\n          \"temporaryUuid\": \"\",\n          \"units\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"procedures\": [\n        {\n          \"bodySite\": \"\",\n          \"id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"status\": \"\"\n    }\n  ],\n  \"groupCode\": \"\",\n  \"identifier\": \"\",\n  \"observations\": [\n    {}\n  ],\n  \"patient\": {\n    \"address1\": \"\",\n    \"address2\": \"\",\n    \"address3\": \"\",\n    \"address4\": \"\",\n    \"contacts\": [\n      {\n        \"id\": 0,\n        \"system\": \"\",\n        \"use\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"dateOfBirth\": \"\",\n    \"dateOfBirthNoTime\": \"\",\n    \"forename\": \"\",\n    \"gender\": \"\",\n    \"group\": {},\n    \"groupCode\": \"\",\n    \"identifier\": \"\",\n    \"identifiers\": [\n      {\n        \"id\": 0,\n        \"label\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"postcode\": \"\",\n    \"practitioners\": [\n      {\n        \"address1\": \"\",\n        \"address2\": \"\",\n        \"address3\": \"\",\n        \"address4\": \"\",\n        \"allowInviteGp\": false,\n        \"contacts\": [\n          {}\n        ],\n        \"gender\": \"\",\n        \"groupCode\": \"\",\n        \"identifier\": \"\",\n        \"inviteDate\": \"\",\n        \"name\": \"\",\n        \"postcode\": \"\",\n        \"role\": \"\"\n      }\n    ],\n    \"surname\": \"\"\n  },\n  \"practitioners\": [\n    {}\n  ]\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/patientmanagement/:userId/group/:groupId/identifier/:identifierId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'condition' => [
        'asserter' => '',
        'category' => '',
        'code' => '',
        'date' => '',
        'description' => '',
        'fullDescription' => '',
        'group' => [
                'address1' => '',
                'address2' => '',
                'address3' => '',
                'childGroups' => [
                                
                ],
                'code' => '',
                'contactPoints' => [
                                [
                                                                'contactPointType' => [
                                                                                                                                'description' => '',
                                                                                                                                'id' => 0,
                                                                                                                                'lookupType' => [
                                                                                                                                                                                                                                                                'created' => '',
                                                                                                                                                                                                                                                                'description' => '',
                                                                                                                                                                                                                                                                'id' => 0,
                                                                                                                                                                                                                                                                'lastUpdate' => '',
                                                                                                                                                                                                                                                                'type' => ''
                                                                                                                                ],
                                                                                                                                'value' => ''
                                                                ],
                                                                'content' => '',
                                                                'created' => '',
                                                                'id' => 0,
                                                                'lastUpdate' => ''
                                ]
                ],
                'created' => '',
                'fhirResourceId' => '',
                'groupFeatures' => [
                                [
                                                                'created' => '',
                                                                'feature' => [
                                                                                                                                'created' => '',
                                                                                                                                'description' => '',
                                                                                                                                'id' => 0,
                                                                                                                                'lastUpdate' => '',
                                                                                                                                'name' => ''
                                                                ],
                                                                'id' => 0,
                                                                'lastUpdate' => ''
                                ]
                ],
                'groupType' => [
                                'created' => '',
                                'description' => '',
                                'descriptionFriendly' => '',
                                'displayOrder' => 0,
                                'id' => 0,
                                'lastUpdate' => '',
                                'lookupType' => [
                                                                
                                ],
                                'value' => ''
                ],
                'id' => 0,
                'lastImportDate' => '',
                'lastUpdate' => '',
                'links' => [
                                [
                                                                'created' => '',
                                                                'displayOrder' => 0,
                                                                'id' => 0,
                                                                'lastUpdate' => '',
                                                                'link' => '',
                                                                'linkType' => [
                                                                                                                                
                                                                ],
                                                                'name' => ''
                                ]
                ],
                'locations' => [
                                [
                                                                'address' => '',
                                                                'created' => '',
                                                                'email' => '',
                                                                'id' => 0,
                                                                'label' => '',
                                                                'lastUpdate' => '',
                                                                'name' => '',
                                                                'phone' => '',
                                                                'web' => ''
                                ]
                ],
                'name' => '',
                'parentGroups' => [
                                
                ],
                'postcode' => '',
                'sftpUser' => '',
                'shortName' => '',
                'visible' => null,
                'visibleToJoin' => null
        ],
        'id' => 0,
        'identifier' => '',
        'links' => [
                [
                                
                ]
        ],
        'notes' => '',
        'severity' => '',
        'status' => ''
    ],
    'encounters' => [
        [
                'date' => '',
                'encounterType' => '',
                'group' => [
                                
                ],
                'id' => 0,
                'identifier' => '',
                'links' => [
                                [
                                                                
                                ]
                ],
                'observations' => [
                                [
                                                                'applies' => '',
                                                                'bodySite' => '',
                                                                'comments' => '',
                                                                'comparator' => '',
                                                                'diagram' => '',
                                                                'group' => [
                                                                                                                                
                                                                ],
                                                                'id' => 0,
                                                                'identifier' => '',
                                                                'location' => '',
                                                                'name' => '',
                                                                'temporaryUuid' => '',
                                                                'units' => '',
                                                                'value' => ''
                                ]
                ],
                'procedures' => [
                                [
                                                                'bodySite' => '',
                                                                'id' => 0,
                                                                'type' => ''
                                ]
                ],
                'status' => ''
        ]
    ],
    'groupCode' => '',
    'identifier' => '',
    'observations' => [
        [
                
        ]
    ],
    'patient' => [
        'address1' => '',
        'address2' => '',
        'address3' => '',
        'address4' => '',
        'contacts' => [
                [
                                'id' => 0,
                                'system' => '',
                                'use' => '',
                                'value' => ''
                ]
        ],
        'dateOfBirth' => '',
        'dateOfBirthNoTime' => '',
        'forename' => '',
        'gender' => '',
        'group' => [
                
        ],
        'groupCode' => '',
        'identifier' => '',
        'identifiers' => [
                [
                                'id' => 0,
                                'label' => '',
                                'value' => ''
                ]
        ],
        'postcode' => '',
        'practitioners' => [
                [
                                'address1' => '',
                                'address2' => '',
                                'address3' => '',
                                'address4' => '',
                                'allowInviteGp' => null,
                                'contacts' => [
                                                                [
                                                                                                                                
                                                                ]
                                ],
                                'gender' => '',
                                'groupCode' => '',
                                'identifier' => '',
                                'inviteDate' => '',
                                'name' => '',
                                'postcode' => '',
                                'role' => ''
                ]
        ],
        'surname' => ''
    ],
    'practitioners' => [
        [
                
        ]
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/patientmanagement/:userId/group/:groupId/identifier/:identifierId', [
  'body' => '{
  "condition": {
    "asserter": "",
    "category": "",
    "code": "",
    "date": "",
    "description": "",
    "fullDescription": "",
    "group": {
      "address1": "",
      "address2": "",
      "address3": "",
      "childGroups": [],
      "code": "",
      "contactPoints": [
        {
          "contactPointType": {
            "description": "",
            "id": 0,
            "lookupType": {
              "created": "",
              "description": "",
              "id": 0,
              "lastUpdate": "",
              "type": ""
            },
            "value": ""
          },
          "content": "",
          "created": "",
          "id": 0,
          "lastUpdate": ""
        }
      ],
      "created": "",
      "fhirResourceId": "",
      "groupFeatures": [
        {
          "created": "",
          "feature": {
            "created": "",
            "description": "",
            "id": 0,
            "lastUpdate": "",
            "name": ""
          },
          "id": 0,
          "lastUpdate": ""
        }
      ],
      "groupType": {
        "created": "",
        "description": "",
        "descriptionFriendly": "",
        "displayOrder": 0,
        "id": 0,
        "lastUpdate": "",
        "lookupType": {},
        "value": ""
      },
      "id": 0,
      "lastImportDate": "",
      "lastUpdate": "",
      "links": [
        {
          "created": "",
          "displayOrder": 0,
          "id": 0,
          "lastUpdate": "",
          "link": "",
          "linkType": {},
          "name": ""
        }
      ],
      "locations": [
        {
          "address": "",
          "created": "",
          "email": "",
          "id": 0,
          "label": "",
          "lastUpdate": "",
          "name": "",
          "phone": "",
          "web": ""
        }
      ],
      "name": "",
      "parentGroups": [],
      "postcode": "",
      "sftpUser": "",
      "shortName": "",
      "visible": false,
      "visibleToJoin": false
    },
    "id": 0,
    "identifier": "",
    "links": [
      {}
    ],
    "notes": "",
    "severity": "",
    "status": ""
  },
  "encounters": [
    {
      "date": "",
      "encounterType": "",
      "group": {},
      "id": 0,
      "identifier": "",
      "links": [
        {}
      ],
      "observations": [
        {
          "applies": "",
          "bodySite": "",
          "comments": "",
          "comparator": "",
          "diagram": "",
          "group": {},
          "id": 0,
          "identifier": "",
          "location": "",
          "name": "",
          "temporaryUuid": "",
          "units": "",
          "value": ""
        }
      ],
      "procedures": [
        {
          "bodySite": "",
          "id": 0,
          "type": ""
        }
      ],
      "status": ""
    }
  ],
  "groupCode": "",
  "identifier": "",
  "observations": [
    {}
  ],
  "patient": {
    "address1": "",
    "address2": "",
    "address3": "",
    "address4": "",
    "contacts": [
      {
        "id": 0,
        "system": "",
        "use": "",
        "value": ""
      }
    ],
    "dateOfBirth": "",
    "dateOfBirthNoTime": "",
    "forename": "",
    "gender": "",
    "group": {},
    "groupCode": "",
    "identifier": "",
    "identifiers": [
      {
        "id": 0,
        "label": "",
        "value": ""
      }
    ],
    "postcode": "",
    "practitioners": [
      {
        "address1": "",
        "address2": "",
        "address3": "",
        "address4": "",
        "allowInviteGp": false,
        "contacts": [
          {}
        ],
        "gender": "",
        "groupCode": "",
        "identifier": "",
        "inviteDate": "",
        "name": "",
        "postcode": "",
        "role": ""
      }
    ],
    "surname": ""
  },
  "practitioners": [
    {}
  ]
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/patientmanagement/:userId/group/:groupId/identifier/:identifierId');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'condition' => [
    'asserter' => '',
    'category' => '',
    'code' => '',
    'date' => '',
    'description' => '',
    'fullDescription' => '',
    'group' => [
        'address1' => '',
        'address2' => '',
        'address3' => '',
        'childGroups' => [
                
        ],
        'code' => '',
        'contactPoints' => [
                [
                                'contactPointType' => [
                                                                'description' => '',
                                                                'id' => 0,
                                                                'lookupType' => [
                                                                                                                                'created' => '',
                                                                                                                                'description' => '',
                                                                                                                                'id' => 0,
                                                                                                                                'lastUpdate' => '',
                                                                                                                                'type' => ''
                                                                ],
                                                                'value' => ''
                                ],
                                'content' => '',
                                'created' => '',
                                'id' => 0,
                                'lastUpdate' => ''
                ]
        ],
        'created' => '',
        'fhirResourceId' => '',
        'groupFeatures' => [
                [
                                'created' => '',
                                'feature' => [
                                                                'created' => '',
                                                                'description' => '',
                                                                'id' => 0,
                                                                'lastUpdate' => '',
                                                                'name' => ''
                                ],
                                'id' => 0,
                                'lastUpdate' => ''
                ]
        ],
        'groupType' => [
                'created' => '',
                'description' => '',
                'descriptionFriendly' => '',
                'displayOrder' => 0,
                'id' => 0,
                'lastUpdate' => '',
                'lookupType' => [
                                
                ],
                'value' => ''
        ],
        'id' => 0,
        'lastImportDate' => '',
        'lastUpdate' => '',
        'links' => [
                [
                                'created' => '',
                                'displayOrder' => 0,
                                'id' => 0,
                                'lastUpdate' => '',
                                'link' => '',
                                'linkType' => [
                                                                
                                ],
                                'name' => ''
                ]
        ],
        'locations' => [
                [
                                'address' => '',
                                'created' => '',
                                'email' => '',
                                'id' => 0,
                                'label' => '',
                                'lastUpdate' => '',
                                'name' => '',
                                'phone' => '',
                                'web' => ''
                ]
        ],
        'name' => '',
        'parentGroups' => [
                
        ],
        'postcode' => '',
        'sftpUser' => '',
        'shortName' => '',
        'visible' => null,
        'visibleToJoin' => null
    ],
    'id' => 0,
    'identifier' => '',
    'links' => [
        [
                
        ]
    ],
    'notes' => '',
    'severity' => '',
    'status' => ''
  ],
  'encounters' => [
    [
        'date' => '',
        'encounterType' => '',
        'group' => [
                
        ],
        'id' => 0,
        'identifier' => '',
        'links' => [
                [
                                
                ]
        ],
        'observations' => [
                [
                                'applies' => '',
                                'bodySite' => '',
                                'comments' => '',
                                'comparator' => '',
                                'diagram' => '',
                                'group' => [
                                                                
                                ],
                                'id' => 0,
                                'identifier' => '',
                                'location' => '',
                                'name' => '',
                                'temporaryUuid' => '',
                                'units' => '',
                                'value' => ''
                ]
        ],
        'procedures' => [
                [
                                'bodySite' => '',
                                'id' => 0,
                                'type' => ''
                ]
        ],
        'status' => ''
    ]
  ],
  'groupCode' => '',
  'identifier' => '',
  'observations' => [
    [
        
    ]
  ],
  'patient' => [
    'address1' => '',
    'address2' => '',
    'address3' => '',
    'address4' => '',
    'contacts' => [
        [
                'id' => 0,
                'system' => '',
                'use' => '',
                'value' => ''
        ]
    ],
    'dateOfBirth' => '',
    'dateOfBirthNoTime' => '',
    'forename' => '',
    'gender' => '',
    'group' => [
        
    ],
    'groupCode' => '',
    'identifier' => '',
    'identifiers' => [
        [
                'id' => 0,
                'label' => '',
                'value' => ''
        ]
    ],
    'postcode' => '',
    'practitioners' => [
        [
                'address1' => '',
                'address2' => '',
                'address3' => '',
                'address4' => '',
                'allowInviteGp' => null,
                'contacts' => [
                                [
                                                                
                                ]
                ],
                'gender' => '',
                'groupCode' => '',
                'identifier' => '',
                'inviteDate' => '',
                'name' => '',
                'postcode' => '',
                'role' => ''
        ]
    ],
    'surname' => ''
  ],
  'practitioners' => [
    [
        
    ]
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'condition' => [
    'asserter' => '',
    'category' => '',
    'code' => '',
    'date' => '',
    'description' => '',
    'fullDescription' => '',
    'group' => [
        'address1' => '',
        'address2' => '',
        'address3' => '',
        'childGroups' => [
                
        ],
        'code' => '',
        'contactPoints' => [
                [
                                'contactPointType' => [
                                                                'description' => '',
                                                                'id' => 0,
                                                                'lookupType' => [
                                                                                                                                'created' => '',
                                                                                                                                'description' => '',
                                                                                                                                'id' => 0,
                                                                                                                                'lastUpdate' => '',
                                                                                                                                'type' => ''
                                                                ],
                                                                'value' => ''
                                ],
                                'content' => '',
                                'created' => '',
                                'id' => 0,
                                'lastUpdate' => ''
                ]
        ],
        'created' => '',
        'fhirResourceId' => '',
        'groupFeatures' => [
                [
                                'created' => '',
                                'feature' => [
                                                                'created' => '',
                                                                'description' => '',
                                                                'id' => 0,
                                                                'lastUpdate' => '',
                                                                'name' => ''
                                ],
                                'id' => 0,
                                'lastUpdate' => ''
                ]
        ],
        'groupType' => [
                'created' => '',
                'description' => '',
                'descriptionFriendly' => '',
                'displayOrder' => 0,
                'id' => 0,
                'lastUpdate' => '',
                'lookupType' => [
                                
                ],
                'value' => ''
        ],
        'id' => 0,
        'lastImportDate' => '',
        'lastUpdate' => '',
        'links' => [
                [
                                'created' => '',
                                'displayOrder' => 0,
                                'id' => 0,
                                'lastUpdate' => '',
                                'link' => '',
                                'linkType' => [
                                                                
                                ],
                                'name' => ''
                ]
        ],
        'locations' => [
                [
                                'address' => '',
                                'created' => '',
                                'email' => '',
                                'id' => 0,
                                'label' => '',
                                'lastUpdate' => '',
                                'name' => '',
                                'phone' => '',
                                'web' => ''
                ]
        ],
        'name' => '',
        'parentGroups' => [
                
        ],
        'postcode' => '',
        'sftpUser' => '',
        'shortName' => '',
        'visible' => null,
        'visibleToJoin' => null
    ],
    'id' => 0,
    'identifier' => '',
    'links' => [
        [
                
        ]
    ],
    'notes' => '',
    'severity' => '',
    'status' => ''
  ],
  'encounters' => [
    [
        'date' => '',
        'encounterType' => '',
        'group' => [
                
        ],
        'id' => 0,
        'identifier' => '',
        'links' => [
                [
                                
                ]
        ],
        'observations' => [
                [
                                'applies' => '',
                                'bodySite' => '',
                                'comments' => '',
                                'comparator' => '',
                                'diagram' => '',
                                'group' => [
                                                                
                                ],
                                'id' => 0,
                                'identifier' => '',
                                'location' => '',
                                'name' => '',
                                'temporaryUuid' => '',
                                'units' => '',
                                'value' => ''
                ]
        ],
        'procedures' => [
                [
                                'bodySite' => '',
                                'id' => 0,
                                'type' => ''
                ]
        ],
        'status' => ''
    ]
  ],
  'groupCode' => '',
  'identifier' => '',
  'observations' => [
    [
        
    ]
  ],
  'patient' => [
    'address1' => '',
    'address2' => '',
    'address3' => '',
    'address4' => '',
    'contacts' => [
        [
                'id' => 0,
                'system' => '',
                'use' => '',
                'value' => ''
        ]
    ],
    'dateOfBirth' => '',
    'dateOfBirthNoTime' => '',
    'forename' => '',
    'gender' => '',
    'group' => [
        
    ],
    'groupCode' => '',
    'identifier' => '',
    'identifiers' => [
        [
                'id' => 0,
                'label' => '',
                'value' => ''
        ]
    ],
    'postcode' => '',
    'practitioners' => [
        [
                'address1' => '',
                'address2' => '',
                'address3' => '',
                'address4' => '',
                'allowInviteGp' => null,
                'contacts' => [
                                [
                                                                
                                ]
                ],
                'gender' => '',
                'groupCode' => '',
                'identifier' => '',
                'inviteDate' => '',
                'name' => '',
                'postcode' => '',
                'role' => ''
        ]
    ],
    'surname' => ''
  ],
  'practitioners' => [
    [
        
    ]
  ]
]));
$request->setRequestUrl('{{baseUrl}}/patientmanagement/:userId/group/:groupId/identifier/:identifierId');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/patientmanagement/:userId/group/:groupId/identifier/:identifierId' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "condition": {
    "asserter": "",
    "category": "",
    "code": "",
    "date": "",
    "description": "",
    "fullDescription": "",
    "group": {
      "address1": "",
      "address2": "",
      "address3": "",
      "childGroups": [],
      "code": "",
      "contactPoints": [
        {
          "contactPointType": {
            "description": "",
            "id": 0,
            "lookupType": {
              "created": "",
              "description": "",
              "id": 0,
              "lastUpdate": "",
              "type": ""
            },
            "value": ""
          },
          "content": "",
          "created": "",
          "id": 0,
          "lastUpdate": ""
        }
      ],
      "created": "",
      "fhirResourceId": "",
      "groupFeatures": [
        {
          "created": "",
          "feature": {
            "created": "",
            "description": "",
            "id": 0,
            "lastUpdate": "",
            "name": ""
          },
          "id": 0,
          "lastUpdate": ""
        }
      ],
      "groupType": {
        "created": "",
        "description": "",
        "descriptionFriendly": "",
        "displayOrder": 0,
        "id": 0,
        "lastUpdate": "",
        "lookupType": {},
        "value": ""
      },
      "id": 0,
      "lastImportDate": "",
      "lastUpdate": "",
      "links": [
        {
          "created": "",
          "displayOrder": 0,
          "id": 0,
          "lastUpdate": "",
          "link": "",
          "linkType": {},
          "name": ""
        }
      ],
      "locations": [
        {
          "address": "",
          "created": "",
          "email": "",
          "id": 0,
          "label": "",
          "lastUpdate": "",
          "name": "",
          "phone": "",
          "web": ""
        }
      ],
      "name": "",
      "parentGroups": [],
      "postcode": "",
      "sftpUser": "",
      "shortName": "",
      "visible": false,
      "visibleToJoin": false
    },
    "id": 0,
    "identifier": "",
    "links": [
      {}
    ],
    "notes": "",
    "severity": "",
    "status": ""
  },
  "encounters": [
    {
      "date": "",
      "encounterType": "",
      "group": {},
      "id": 0,
      "identifier": "",
      "links": [
        {}
      ],
      "observations": [
        {
          "applies": "",
          "bodySite": "",
          "comments": "",
          "comparator": "",
          "diagram": "",
          "group": {},
          "id": 0,
          "identifier": "",
          "location": "",
          "name": "",
          "temporaryUuid": "",
          "units": "",
          "value": ""
        }
      ],
      "procedures": [
        {
          "bodySite": "",
          "id": 0,
          "type": ""
        }
      ],
      "status": ""
    }
  ],
  "groupCode": "",
  "identifier": "",
  "observations": [
    {}
  ],
  "patient": {
    "address1": "",
    "address2": "",
    "address3": "",
    "address4": "",
    "contacts": [
      {
        "id": 0,
        "system": "",
        "use": "",
        "value": ""
      }
    ],
    "dateOfBirth": "",
    "dateOfBirthNoTime": "",
    "forename": "",
    "gender": "",
    "group": {},
    "groupCode": "",
    "identifier": "",
    "identifiers": [
      {
        "id": 0,
        "label": "",
        "value": ""
      }
    ],
    "postcode": "",
    "practitioners": [
      {
        "address1": "",
        "address2": "",
        "address3": "",
        "address4": "",
        "allowInviteGp": false,
        "contacts": [
          {}
        ],
        "gender": "",
        "groupCode": "",
        "identifier": "",
        "inviteDate": "",
        "name": "",
        "postcode": "",
        "role": ""
      }
    ],
    "surname": ""
  },
  "practitioners": [
    {}
  ]
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/patientmanagement/:userId/group/:groupId/identifier/:identifierId' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "condition": {
    "asserter": "",
    "category": "",
    "code": "",
    "date": "",
    "description": "",
    "fullDescription": "",
    "group": {
      "address1": "",
      "address2": "",
      "address3": "",
      "childGroups": [],
      "code": "",
      "contactPoints": [
        {
          "contactPointType": {
            "description": "",
            "id": 0,
            "lookupType": {
              "created": "",
              "description": "",
              "id": 0,
              "lastUpdate": "",
              "type": ""
            },
            "value": ""
          },
          "content": "",
          "created": "",
          "id": 0,
          "lastUpdate": ""
        }
      ],
      "created": "",
      "fhirResourceId": "",
      "groupFeatures": [
        {
          "created": "",
          "feature": {
            "created": "",
            "description": "",
            "id": 0,
            "lastUpdate": "",
            "name": ""
          },
          "id": 0,
          "lastUpdate": ""
        }
      ],
      "groupType": {
        "created": "",
        "description": "",
        "descriptionFriendly": "",
        "displayOrder": 0,
        "id": 0,
        "lastUpdate": "",
        "lookupType": {},
        "value": ""
      },
      "id": 0,
      "lastImportDate": "",
      "lastUpdate": "",
      "links": [
        {
          "created": "",
          "displayOrder": 0,
          "id": 0,
          "lastUpdate": "",
          "link": "",
          "linkType": {},
          "name": ""
        }
      ],
      "locations": [
        {
          "address": "",
          "created": "",
          "email": "",
          "id": 0,
          "label": "",
          "lastUpdate": "",
          "name": "",
          "phone": "",
          "web": ""
        }
      ],
      "name": "",
      "parentGroups": [],
      "postcode": "",
      "sftpUser": "",
      "shortName": "",
      "visible": false,
      "visibleToJoin": false
    },
    "id": 0,
    "identifier": "",
    "links": [
      {}
    ],
    "notes": "",
    "severity": "",
    "status": ""
  },
  "encounters": [
    {
      "date": "",
      "encounterType": "",
      "group": {},
      "id": 0,
      "identifier": "",
      "links": [
        {}
      ],
      "observations": [
        {
          "applies": "",
          "bodySite": "",
          "comments": "",
          "comparator": "",
          "diagram": "",
          "group": {},
          "id": 0,
          "identifier": "",
          "location": "",
          "name": "",
          "temporaryUuid": "",
          "units": "",
          "value": ""
        }
      ],
      "procedures": [
        {
          "bodySite": "",
          "id": 0,
          "type": ""
        }
      ],
      "status": ""
    }
  ],
  "groupCode": "",
  "identifier": "",
  "observations": [
    {}
  ],
  "patient": {
    "address1": "",
    "address2": "",
    "address3": "",
    "address4": "",
    "contacts": [
      {
        "id": 0,
        "system": "",
        "use": "",
        "value": ""
      }
    ],
    "dateOfBirth": "",
    "dateOfBirthNoTime": "",
    "forename": "",
    "gender": "",
    "group": {},
    "groupCode": "",
    "identifier": "",
    "identifiers": [
      {
        "id": 0,
        "label": "",
        "value": ""
      }
    ],
    "postcode": "",
    "practitioners": [
      {
        "address1": "",
        "address2": "",
        "address3": "",
        "address4": "",
        "allowInviteGp": false,
        "contacts": [
          {}
        ],
        "gender": "",
        "groupCode": "",
        "identifier": "",
        "inviteDate": "",
        "name": "",
        "postcode": "",
        "role": ""
      }
    ],
    "surname": ""
  },
  "practitioners": [
    {}
  ]
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"condition\": {\n    \"asserter\": \"\",\n    \"category\": \"\",\n    \"code\": \"\",\n    \"date\": \"\",\n    \"description\": \"\",\n    \"fullDescription\": \"\",\n    \"group\": {\n      \"address1\": \"\",\n      \"address2\": \"\",\n      \"address3\": \"\",\n      \"childGroups\": [],\n      \"code\": \"\",\n      \"contactPoints\": [\n        {\n          \"contactPointType\": {\n            \"description\": \"\",\n            \"id\": 0,\n            \"lookupType\": {\n              \"created\": \"\",\n              \"description\": \"\",\n              \"id\": 0,\n              \"lastUpdate\": \"\",\n              \"type\": \"\"\n            },\n            \"value\": \"\"\n          },\n          \"content\": \"\",\n          \"created\": \"\",\n          \"id\": 0,\n          \"lastUpdate\": \"\"\n        }\n      ],\n      \"created\": \"\",\n      \"fhirResourceId\": \"\",\n      \"groupFeatures\": [\n        {\n          \"created\": \"\",\n          \"feature\": {\n            \"created\": \"\",\n            \"description\": \"\",\n            \"id\": 0,\n            \"lastUpdate\": \"\",\n            \"name\": \"\"\n          },\n          \"id\": 0,\n          \"lastUpdate\": \"\"\n        }\n      ],\n      \"groupType\": {\n        \"created\": \"\",\n        \"description\": \"\",\n        \"descriptionFriendly\": \"\",\n        \"displayOrder\": 0,\n        \"id\": 0,\n        \"lastUpdate\": \"\",\n        \"lookupType\": {},\n        \"value\": \"\"\n      },\n      \"id\": 0,\n      \"lastImportDate\": \"\",\n      \"lastUpdate\": \"\",\n      \"links\": [\n        {\n          \"created\": \"\",\n          \"displayOrder\": 0,\n          \"id\": 0,\n          \"lastUpdate\": \"\",\n          \"link\": \"\",\n          \"linkType\": {},\n          \"name\": \"\"\n        }\n      ],\n      \"locations\": [\n        {\n          \"address\": \"\",\n          \"created\": \"\",\n          \"email\": \"\",\n          \"id\": 0,\n          \"label\": \"\",\n          \"lastUpdate\": \"\",\n          \"name\": \"\",\n          \"phone\": \"\",\n          \"web\": \"\"\n        }\n      ],\n      \"name\": \"\",\n      \"parentGroups\": [],\n      \"postcode\": \"\",\n      \"sftpUser\": \"\",\n      \"shortName\": \"\",\n      \"visible\": false,\n      \"visibleToJoin\": false\n    },\n    \"id\": 0,\n    \"identifier\": \"\",\n    \"links\": [\n      {}\n    ],\n    \"notes\": \"\",\n    \"severity\": \"\",\n    \"status\": \"\"\n  },\n  \"encounters\": [\n    {\n      \"date\": \"\",\n      \"encounterType\": \"\",\n      \"group\": {},\n      \"id\": 0,\n      \"identifier\": \"\",\n      \"links\": [\n        {}\n      ],\n      \"observations\": [\n        {\n          \"applies\": \"\",\n          \"bodySite\": \"\",\n          \"comments\": \"\",\n          \"comparator\": \"\",\n          \"diagram\": \"\",\n          \"group\": {},\n          \"id\": 0,\n          \"identifier\": \"\",\n          \"location\": \"\",\n          \"name\": \"\",\n          \"temporaryUuid\": \"\",\n          \"units\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"procedures\": [\n        {\n          \"bodySite\": \"\",\n          \"id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"status\": \"\"\n    }\n  ],\n  \"groupCode\": \"\",\n  \"identifier\": \"\",\n  \"observations\": [\n    {}\n  ],\n  \"patient\": {\n    \"address1\": \"\",\n    \"address2\": \"\",\n    \"address3\": \"\",\n    \"address4\": \"\",\n    \"contacts\": [\n      {\n        \"id\": 0,\n        \"system\": \"\",\n        \"use\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"dateOfBirth\": \"\",\n    \"dateOfBirthNoTime\": \"\",\n    \"forename\": \"\",\n    \"gender\": \"\",\n    \"group\": {},\n    \"groupCode\": \"\",\n    \"identifier\": \"\",\n    \"identifiers\": [\n      {\n        \"id\": 0,\n        \"label\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"postcode\": \"\",\n    \"practitioners\": [\n      {\n        \"address1\": \"\",\n        \"address2\": \"\",\n        \"address3\": \"\",\n        \"address4\": \"\",\n        \"allowInviteGp\": false,\n        \"contacts\": [\n          {}\n        ],\n        \"gender\": \"\",\n        \"groupCode\": \"\",\n        \"identifier\": \"\",\n        \"inviteDate\": \"\",\n        \"name\": \"\",\n        \"postcode\": \"\",\n        \"role\": \"\"\n      }\n    ],\n    \"surname\": \"\"\n  },\n  \"practitioners\": [\n    {}\n  ]\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/patientmanagement/:userId/group/:groupId/identifier/:identifierId", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/patientmanagement/:userId/group/:groupId/identifier/:identifierId"

payload = {
    "condition": {
        "asserter": "",
        "category": "",
        "code": "",
        "date": "",
        "description": "",
        "fullDescription": "",
        "group": {
            "address1": "",
            "address2": "",
            "address3": "",
            "childGroups": [],
            "code": "",
            "contactPoints": [
                {
                    "contactPointType": {
                        "description": "",
                        "id": 0,
                        "lookupType": {
                            "created": "",
                            "description": "",
                            "id": 0,
                            "lastUpdate": "",
                            "type": ""
                        },
                        "value": ""
                    },
                    "content": "",
                    "created": "",
                    "id": 0,
                    "lastUpdate": ""
                }
            ],
            "created": "",
            "fhirResourceId": "",
            "groupFeatures": [
                {
                    "created": "",
                    "feature": {
                        "created": "",
                        "description": "",
                        "id": 0,
                        "lastUpdate": "",
                        "name": ""
                    },
                    "id": 0,
                    "lastUpdate": ""
                }
            ],
            "groupType": {
                "created": "",
                "description": "",
                "descriptionFriendly": "",
                "displayOrder": 0,
                "id": 0,
                "lastUpdate": "",
                "lookupType": {},
                "value": ""
            },
            "id": 0,
            "lastImportDate": "",
            "lastUpdate": "",
            "links": [
                {
                    "created": "",
                    "displayOrder": 0,
                    "id": 0,
                    "lastUpdate": "",
                    "link": "",
                    "linkType": {},
                    "name": ""
                }
            ],
            "locations": [
                {
                    "address": "",
                    "created": "",
                    "email": "",
                    "id": 0,
                    "label": "",
                    "lastUpdate": "",
                    "name": "",
                    "phone": "",
                    "web": ""
                }
            ],
            "name": "",
            "parentGroups": [],
            "postcode": "",
            "sftpUser": "",
            "shortName": "",
            "visible": False,
            "visibleToJoin": False
        },
        "id": 0,
        "identifier": "",
        "links": [{}],
        "notes": "",
        "severity": "",
        "status": ""
    },
    "encounters": [
        {
            "date": "",
            "encounterType": "",
            "group": {},
            "id": 0,
            "identifier": "",
            "links": [{}],
            "observations": [
                {
                    "applies": "",
                    "bodySite": "",
                    "comments": "",
                    "comparator": "",
                    "diagram": "",
                    "group": {},
                    "id": 0,
                    "identifier": "",
                    "location": "",
                    "name": "",
                    "temporaryUuid": "",
                    "units": "",
                    "value": ""
                }
            ],
            "procedures": [
                {
                    "bodySite": "",
                    "id": 0,
                    "type": ""
                }
            ],
            "status": ""
        }
    ],
    "groupCode": "",
    "identifier": "",
    "observations": [{}],
    "patient": {
        "address1": "",
        "address2": "",
        "address3": "",
        "address4": "",
        "contacts": [
            {
                "id": 0,
                "system": "",
                "use": "",
                "value": ""
            }
        ],
        "dateOfBirth": "",
        "dateOfBirthNoTime": "",
        "forename": "",
        "gender": "",
        "group": {},
        "groupCode": "",
        "identifier": "",
        "identifiers": [
            {
                "id": 0,
                "label": "",
                "value": ""
            }
        ],
        "postcode": "",
        "practitioners": [
            {
                "address1": "",
                "address2": "",
                "address3": "",
                "address4": "",
                "allowInviteGp": False,
                "contacts": [{}],
                "gender": "",
                "groupCode": "",
                "identifier": "",
                "inviteDate": "",
                "name": "",
                "postcode": "",
                "role": ""
            }
        ],
        "surname": ""
    },
    "practitioners": [{}]
}
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/patientmanagement/:userId/group/:groupId/identifier/:identifierId"

payload <- "{\n  \"condition\": {\n    \"asserter\": \"\",\n    \"category\": \"\",\n    \"code\": \"\",\n    \"date\": \"\",\n    \"description\": \"\",\n    \"fullDescription\": \"\",\n    \"group\": {\n      \"address1\": \"\",\n      \"address2\": \"\",\n      \"address3\": \"\",\n      \"childGroups\": [],\n      \"code\": \"\",\n      \"contactPoints\": [\n        {\n          \"contactPointType\": {\n            \"description\": \"\",\n            \"id\": 0,\n            \"lookupType\": {\n              \"created\": \"\",\n              \"description\": \"\",\n              \"id\": 0,\n              \"lastUpdate\": \"\",\n              \"type\": \"\"\n            },\n            \"value\": \"\"\n          },\n          \"content\": \"\",\n          \"created\": \"\",\n          \"id\": 0,\n          \"lastUpdate\": \"\"\n        }\n      ],\n      \"created\": \"\",\n      \"fhirResourceId\": \"\",\n      \"groupFeatures\": [\n        {\n          \"created\": \"\",\n          \"feature\": {\n            \"created\": \"\",\n            \"description\": \"\",\n            \"id\": 0,\n            \"lastUpdate\": \"\",\n            \"name\": \"\"\n          },\n          \"id\": 0,\n          \"lastUpdate\": \"\"\n        }\n      ],\n      \"groupType\": {\n        \"created\": \"\",\n        \"description\": \"\",\n        \"descriptionFriendly\": \"\",\n        \"displayOrder\": 0,\n        \"id\": 0,\n        \"lastUpdate\": \"\",\n        \"lookupType\": {},\n        \"value\": \"\"\n      },\n      \"id\": 0,\n      \"lastImportDate\": \"\",\n      \"lastUpdate\": \"\",\n      \"links\": [\n        {\n          \"created\": \"\",\n          \"displayOrder\": 0,\n          \"id\": 0,\n          \"lastUpdate\": \"\",\n          \"link\": \"\",\n          \"linkType\": {},\n          \"name\": \"\"\n        }\n      ],\n      \"locations\": [\n        {\n          \"address\": \"\",\n          \"created\": \"\",\n          \"email\": \"\",\n          \"id\": 0,\n          \"label\": \"\",\n          \"lastUpdate\": \"\",\n          \"name\": \"\",\n          \"phone\": \"\",\n          \"web\": \"\"\n        }\n      ],\n      \"name\": \"\",\n      \"parentGroups\": [],\n      \"postcode\": \"\",\n      \"sftpUser\": \"\",\n      \"shortName\": \"\",\n      \"visible\": false,\n      \"visibleToJoin\": false\n    },\n    \"id\": 0,\n    \"identifier\": \"\",\n    \"links\": [\n      {}\n    ],\n    \"notes\": \"\",\n    \"severity\": \"\",\n    \"status\": \"\"\n  },\n  \"encounters\": [\n    {\n      \"date\": \"\",\n      \"encounterType\": \"\",\n      \"group\": {},\n      \"id\": 0,\n      \"identifier\": \"\",\n      \"links\": [\n        {}\n      ],\n      \"observations\": [\n        {\n          \"applies\": \"\",\n          \"bodySite\": \"\",\n          \"comments\": \"\",\n          \"comparator\": \"\",\n          \"diagram\": \"\",\n          \"group\": {},\n          \"id\": 0,\n          \"identifier\": \"\",\n          \"location\": \"\",\n          \"name\": \"\",\n          \"temporaryUuid\": \"\",\n          \"units\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"procedures\": [\n        {\n          \"bodySite\": \"\",\n          \"id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"status\": \"\"\n    }\n  ],\n  \"groupCode\": \"\",\n  \"identifier\": \"\",\n  \"observations\": [\n    {}\n  ],\n  \"patient\": {\n    \"address1\": \"\",\n    \"address2\": \"\",\n    \"address3\": \"\",\n    \"address4\": \"\",\n    \"contacts\": [\n      {\n        \"id\": 0,\n        \"system\": \"\",\n        \"use\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"dateOfBirth\": \"\",\n    \"dateOfBirthNoTime\": \"\",\n    \"forename\": \"\",\n    \"gender\": \"\",\n    \"group\": {},\n    \"groupCode\": \"\",\n    \"identifier\": \"\",\n    \"identifiers\": [\n      {\n        \"id\": 0,\n        \"label\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"postcode\": \"\",\n    \"practitioners\": [\n      {\n        \"address1\": \"\",\n        \"address2\": \"\",\n        \"address3\": \"\",\n        \"address4\": \"\",\n        \"allowInviteGp\": false,\n        \"contacts\": [\n          {}\n        ],\n        \"gender\": \"\",\n        \"groupCode\": \"\",\n        \"identifier\": \"\",\n        \"inviteDate\": \"\",\n        \"name\": \"\",\n        \"postcode\": \"\",\n        \"role\": \"\"\n      }\n    ],\n    \"surname\": \"\"\n  },\n  \"practitioners\": [\n    {}\n  ]\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/patientmanagement/:userId/group/:groupId/identifier/:identifierId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"condition\": {\n    \"asserter\": \"\",\n    \"category\": \"\",\n    \"code\": \"\",\n    \"date\": \"\",\n    \"description\": \"\",\n    \"fullDescription\": \"\",\n    \"group\": {\n      \"address1\": \"\",\n      \"address2\": \"\",\n      \"address3\": \"\",\n      \"childGroups\": [],\n      \"code\": \"\",\n      \"contactPoints\": [\n        {\n          \"contactPointType\": {\n            \"description\": \"\",\n            \"id\": 0,\n            \"lookupType\": {\n              \"created\": \"\",\n              \"description\": \"\",\n              \"id\": 0,\n              \"lastUpdate\": \"\",\n              \"type\": \"\"\n            },\n            \"value\": \"\"\n          },\n          \"content\": \"\",\n          \"created\": \"\",\n          \"id\": 0,\n          \"lastUpdate\": \"\"\n        }\n      ],\n      \"created\": \"\",\n      \"fhirResourceId\": \"\",\n      \"groupFeatures\": [\n        {\n          \"created\": \"\",\n          \"feature\": {\n            \"created\": \"\",\n            \"description\": \"\",\n            \"id\": 0,\n            \"lastUpdate\": \"\",\n            \"name\": \"\"\n          },\n          \"id\": 0,\n          \"lastUpdate\": \"\"\n        }\n      ],\n      \"groupType\": {\n        \"created\": \"\",\n        \"description\": \"\",\n        \"descriptionFriendly\": \"\",\n        \"displayOrder\": 0,\n        \"id\": 0,\n        \"lastUpdate\": \"\",\n        \"lookupType\": {},\n        \"value\": \"\"\n      },\n      \"id\": 0,\n      \"lastImportDate\": \"\",\n      \"lastUpdate\": \"\",\n      \"links\": [\n        {\n          \"created\": \"\",\n          \"displayOrder\": 0,\n          \"id\": 0,\n          \"lastUpdate\": \"\",\n          \"link\": \"\",\n          \"linkType\": {},\n          \"name\": \"\"\n        }\n      ],\n      \"locations\": [\n        {\n          \"address\": \"\",\n          \"created\": \"\",\n          \"email\": \"\",\n          \"id\": 0,\n          \"label\": \"\",\n          \"lastUpdate\": \"\",\n          \"name\": \"\",\n          \"phone\": \"\",\n          \"web\": \"\"\n        }\n      ],\n      \"name\": \"\",\n      \"parentGroups\": [],\n      \"postcode\": \"\",\n      \"sftpUser\": \"\",\n      \"shortName\": \"\",\n      \"visible\": false,\n      \"visibleToJoin\": false\n    },\n    \"id\": 0,\n    \"identifier\": \"\",\n    \"links\": [\n      {}\n    ],\n    \"notes\": \"\",\n    \"severity\": \"\",\n    \"status\": \"\"\n  },\n  \"encounters\": [\n    {\n      \"date\": \"\",\n      \"encounterType\": \"\",\n      \"group\": {},\n      \"id\": 0,\n      \"identifier\": \"\",\n      \"links\": [\n        {}\n      ],\n      \"observations\": [\n        {\n          \"applies\": \"\",\n          \"bodySite\": \"\",\n          \"comments\": \"\",\n          \"comparator\": \"\",\n          \"diagram\": \"\",\n          \"group\": {},\n          \"id\": 0,\n          \"identifier\": \"\",\n          \"location\": \"\",\n          \"name\": \"\",\n          \"temporaryUuid\": \"\",\n          \"units\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"procedures\": [\n        {\n          \"bodySite\": \"\",\n          \"id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"status\": \"\"\n    }\n  ],\n  \"groupCode\": \"\",\n  \"identifier\": \"\",\n  \"observations\": [\n    {}\n  ],\n  \"patient\": {\n    \"address1\": \"\",\n    \"address2\": \"\",\n    \"address3\": \"\",\n    \"address4\": \"\",\n    \"contacts\": [\n      {\n        \"id\": 0,\n        \"system\": \"\",\n        \"use\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"dateOfBirth\": \"\",\n    \"dateOfBirthNoTime\": \"\",\n    \"forename\": \"\",\n    \"gender\": \"\",\n    \"group\": {},\n    \"groupCode\": \"\",\n    \"identifier\": \"\",\n    \"identifiers\": [\n      {\n        \"id\": 0,\n        \"label\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"postcode\": \"\",\n    \"practitioners\": [\n      {\n        \"address1\": \"\",\n        \"address2\": \"\",\n        \"address3\": \"\",\n        \"address4\": \"\",\n        \"allowInviteGp\": false,\n        \"contacts\": [\n          {}\n        ],\n        \"gender\": \"\",\n        \"groupCode\": \"\",\n        \"identifier\": \"\",\n        \"inviteDate\": \"\",\n        \"name\": \"\",\n        \"postcode\": \"\",\n        \"role\": \"\"\n      }\n    ],\n    \"surname\": \"\"\n  },\n  \"practitioners\": [\n    {}\n  ]\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/patientmanagement/:userId/group/:groupId/identifier/:identifierId') do |req|
  req.body = "{\n  \"condition\": {\n    \"asserter\": \"\",\n    \"category\": \"\",\n    \"code\": \"\",\n    \"date\": \"\",\n    \"description\": \"\",\n    \"fullDescription\": \"\",\n    \"group\": {\n      \"address1\": \"\",\n      \"address2\": \"\",\n      \"address3\": \"\",\n      \"childGroups\": [],\n      \"code\": \"\",\n      \"contactPoints\": [\n        {\n          \"contactPointType\": {\n            \"description\": \"\",\n            \"id\": 0,\n            \"lookupType\": {\n              \"created\": \"\",\n              \"description\": \"\",\n              \"id\": 0,\n              \"lastUpdate\": \"\",\n              \"type\": \"\"\n            },\n            \"value\": \"\"\n          },\n          \"content\": \"\",\n          \"created\": \"\",\n          \"id\": 0,\n          \"lastUpdate\": \"\"\n        }\n      ],\n      \"created\": \"\",\n      \"fhirResourceId\": \"\",\n      \"groupFeatures\": [\n        {\n          \"created\": \"\",\n          \"feature\": {\n            \"created\": \"\",\n            \"description\": \"\",\n            \"id\": 0,\n            \"lastUpdate\": \"\",\n            \"name\": \"\"\n          },\n          \"id\": 0,\n          \"lastUpdate\": \"\"\n        }\n      ],\n      \"groupType\": {\n        \"created\": \"\",\n        \"description\": \"\",\n        \"descriptionFriendly\": \"\",\n        \"displayOrder\": 0,\n        \"id\": 0,\n        \"lastUpdate\": \"\",\n        \"lookupType\": {},\n        \"value\": \"\"\n      },\n      \"id\": 0,\n      \"lastImportDate\": \"\",\n      \"lastUpdate\": \"\",\n      \"links\": [\n        {\n          \"created\": \"\",\n          \"displayOrder\": 0,\n          \"id\": 0,\n          \"lastUpdate\": \"\",\n          \"link\": \"\",\n          \"linkType\": {},\n          \"name\": \"\"\n        }\n      ],\n      \"locations\": [\n        {\n          \"address\": \"\",\n          \"created\": \"\",\n          \"email\": \"\",\n          \"id\": 0,\n          \"label\": \"\",\n          \"lastUpdate\": \"\",\n          \"name\": \"\",\n          \"phone\": \"\",\n          \"web\": \"\"\n        }\n      ],\n      \"name\": \"\",\n      \"parentGroups\": [],\n      \"postcode\": \"\",\n      \"sftpUser\": \"\",\n      \"shortName\": \"\",\n      \"visible\": false,\n      \"visibleToJoin\": false\n    },\n    \"id\": 0,\n    \"identifier\": \"\",\n    \"links\": [\n      {}\n    ],\n    \"notes\": \"\",\n    \"severity\": \"\",\n    \"status\": \"\"\n  },\n  \"encounters\": [\n    {\n      \"date\": \"\",\n      \"encounterType\": \"\",\n      \"group\": {},\n      \"id\": 0,\n      \"identifier\": \"\",\n      \"links\": [\n        {}\n      ],\n      \"observations\": [\n        {\n          \"applies\": \"\",\n          \"bodySite\": \"\",\n          \"comments\": \"\",\n          \"comparator\": \"\",\n          \"diagram\": \"\",\n          \"group\": {},\n          \"id\": 0,\n          \"identifier\": \"\",\n          \"location\": \"\",\n          \"name\": \"\",\n          \"temporaryUuid\": \"\",\n          \"units\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"procedures\": [\n        {\n          \"bodySite\": \"\",\n          \"id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"status\": \"\"\n    }\n  ],\n  \"groupCode\": \"\",\n  \"identifier\": \"\",\n  \"observations\": [\n    {}\n  ],\n  \"patient\": {\n    \"address1\": \"\",\n    \"address2\": \"\",\n    \"address3\": \"\",\n    \"address4\": \"\",\n    \"contacts\": [\n      {\n        \"id\": 0,\n        \"system\": \"\",\n        \"use\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"dateOfBirth\": \"\",\n    \"dateOfBirthNoTime\": \"\",\n    \"forename\": \"\",\n    \"gender\": \"\",\n    \"group\": {},\n    \"groupCode\": \"\",\n    \"identifier\": \"\",\n    \"identifiers\": [\n      {\n        \"id\": 0,\n        \"label\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"postcode\": \"\",\n    \"practitioners\": [\n      {\n        \"address1\": \"\",\n        \"address2\": \"\",\n        \"address3\": \"\",\n        \"address4\": \"\",\n        \"allowInviteGp\": false,\n        \"contacts\": [\n          {}\n        ],\n        \"gender\": \"\",\n        \"groupCode\": \"\",\n        \"identifier\": \"\",\n        \"inviteDate\": \"\",\n        \"name\": \"\",\n        \"postcode\": \"\",\n        \"role\": \"\"\n      }\n    ],\n    \"surname\": \"\"\n  },\n  \"practitioners\": [\n    {}\n  ]\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/patientmanagement/:userId/group/:groupId/identifier/:identifierId";

    let payload = json!({
        "condition": json!({
            "asserter": "",
            "category": "",
            "code": "",
            "date": "",
            "description": "",
            "fullDescription": "",
            "group": json!({
                "address1": "",
                "address2": "",
                "address3": "",
                "childGroups": (),
                "code": "",
                "contactPoints": (
                    json!({
                        "contactPointType": json!({
                            "description": "",
                            "id": 0,
                            "lookupType": json!({
                                "created": "",
                                "description": "",
                                "id": 0,
                                "lastUpdate": "",
                                "type": ""
                            }),
                            "value": ""
                        }),
                        "content": "",
                        "created": "",
                        "id": 0,
                        "lastUpdate": ""
                    })
                ),
                "created": "",
                "fhirResourceId": "",
                "groupFeatures": (
                    json!({
                        "created": "",
                        "feature": json!({
                            "created": "",
                            "description": "",
                            "id": 0,
                            "lastUpdate": "",
                            "name": ""
                        }),
                        "id": 0,
                        "lastUpdate": ""
                    })
                ),
                "groupType": json!({
                    "created": "",
                    "description": "",
                    "descriptionFriendly": "",
                    "displayOrder": 0,
                    "id": 0,
                    "lastUpdate": "",
                    "lookupType": json!({}),
                    "value": ""
                }),
                "id": 0,
                "lastImportDate": "",
                "lastUpdate": "",
                "links": (
                    json!({
                        "created": "",
                        "displayOrder": 0,
                        "id": 0,
                        "lastUpdate": "",
                        "link": "",
                        "linkType": json!({}),
                        "name": ""
                    })
                ),
                "locations": (
                    json!({
                        "address": "",
                        "created": "",
                        "email": "",
                        "id": 0,
                        "label": "",
                        "lastUpdate": "",
                        "name": "",
                        "phone": "",
                        "web": ""
                    })
                ),
                "name": "",
                "parentGroups": (),
                "postcode": "",
                "sftpUser": "",
                "shortName": "",
                "visible": false,
                "visibleToJoin": false
            }),
            "id": 0,
            "identifier": "",
            "links": (json!({})),
            "notes": "",
            "severity": "",
            "status": ""
        }),
        "encounters": (
            json!({
                "date": "",
                "encounterType": "",
                "group": json!({}),
                "id": 0,
                "identifier": "",
                "links": (json!({})),
                "observations": (
                    json!({
                        "applies": "",
                        "bodySite": "",
                        "comments": "",
                        "comparator": "",
                        "diagram": "",
                        "group": json!({}),
                        "id": 0,
                        "identifier": "",
                        "location": "",
                        "name": "",
                        "temporaryUuid": "",
                        "units": "",
                        "value": ""
                    })
                ),
                "procedures": (
                    json!({
                        "bodySite": "",
                        "id": 0,
                        "type": ""
                    })
                ),
                "status": ""
            })
        ),
        "groupCode": "",
        "identifier": "",
        "observations": (json!({})),
        "patient": json!({
            "address1": "",
            "address2": "",
            "address3": "",
            "address4": "",
            "contacts": (
                json!({
                    "id": 0,
                    "system": "",
                    "use": "",
                    "value": ""
                })
            ),
            "dateOfBirth": "",
            "dateOfBirthNoTime": "",
            "forename": "",
            "gender": "",
            "group": json!({}),
            "groupCode": "",
            "identifier": "",
            "identifiers": (
                json!({
                    "id": 0,
                    "label": "",
                    "value": ""
                })
            ),
            "postcode": "",
            "practitioners": (
                json!({
                    "address1": "",
                    "address2": "",
                    "address3": "",
                    "address4": "",
                    "allowInviteGp": false,
                    "contacts": (json!({})),
                    "gender": "",
                    "groupCode": "",
                    "identifier": "",
                    "inviteDate": "",
                    "name": "",
                    "postcode": "",
                    "role": ""
                })
            ),
            "surname": ""
        }),
        "practitioners": (json!({}))
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/patientmanagement/:userId/group/:groupId/identifier/:identifierId \
  --header 'content-type: application/json' \
  --data '{
  "condition": {
    "asserter": "",
    "category": "",
    "code": "",
    "date": "",
    "description": "",
    "fullDescription": "",
    "group": {
      "address1": "",
      "address2": "",
      "address3": "",
      "childGroups": [],
      "code": "",
      "contactPoints": [
        {
          "contactPointType": {
            "description": "",
            "id": 0,
            "lookupType": {
              "created": "",
              "description": "",
              "id": 0,
              "lastUpdate": "",
              "type": ""
            },
            "value": ""
          },
          "content": "",
          "created": "",
          "id": 0,
          "lastUpdate": ""
        }
      ],
      "created": "",
      "fhirResourceId": "",
      "groupFeatures": [
        {
          "created": "",
          "feature": {
            "created": "",
            "description": "",
            "id": 0,
            "lastUpdate": "",
            "name": ""
          },
          "id": 0,
          "lastUpdate": ""
        }
      ],
      "groupType": {
        "created": "",
        "description": "",
        "descriptionFriendly": "",
        "displayOrder": 0,
        "id": 0,
        "lastUpdate": "",
        "lookupType": {},
        "value": ""
      },
      "id": 0,
      "lastImportDate": "",
      "lastUpdate": "",
      "links": [
        {
          "created": "",
          "displayOrder": 0,
          "id": 0,
          "lastUpdate": "",
          "link": "",
          "linkType": {},
          "name": ""
        }
      ],
      "locations": [
        {
          "address": "",
          "created": "",
          "email": "",
          "id": 0,
          "label": "",
          "lastUpdate": "",
          "name": "",
          "phone": "",
          "web": ""
        }
      ],
      "name": "",
      "parentGroups": [],
      "postcode": "",
      "sftpUser": "",
      "shortName": "",
      "visible": false,
      "visibleToJoin": false
    },
    "id": 0,
    "identifier": "",
    "links": [
      {}
    ],
    "notes": "",
    "severity": "",
    "status": ""
  },
  "encounters": [
    {
      "date": "",
      "encounterType": "",
      "group": {},
      "id": 0,
      "identifier": "",
      "links": [
        {}
      ],
      "observations": [
        {
          "applies": "",
          "bodySite": "",
          "comments": "",
          "comparator": "",
          "diagram": "",
          "group": {},
          "id": 0,
          "identifier": "",
          "location": "",
          "name": "",
          "temporaryUuid": "",
          "units": "",
          "value": ""
        }
      ],
      "procedures": [
        {
          "bodySite": "",
          "id": 0,
          "type": ""
        }
      ],
      "status": ""
    }
  ],
  "groupCode": "",
  "identifier": "",
  "observations": [
    {}
  ],
  "patient": {
    "address1": "",
    "address2": "",
    "address3": "",
    "address4": "",
    "contacts": [
      {
        "id": 0,
        "system": "",
        "use": "",
        "value": ""
      }
    ],
    "dateOfBirth": "",
    "dateOfBirthNoTime": "",
    "forename": "",
    "gender": "",
    "group": {},
    "groupCode": "",
    "identifier": "",
    "identifiers": [
      {
        "id": 0,
        "label": "",
        "value": ""
      }
    ],
    "postcode": "",
    "practitioners": [
      {
        "address1": "",
        "address2": "",
        "address3": "",
        "address4": "",
        "allowInviteGp": false,
        "contacts": [
          {}
        ],
        "gender": "",
        "groupCode": "",
        "identifier": "",
        "inviteDate": "",
        "name": "",
        "postcode": "",
        "role": ""
      }
    ],
    "surname": ""
  },
  "practitioners": [
    {}
  ]
}'
echo '{
  "condition": {
    "asserter": "",
    "category": "",
    "code": "",
    "date": "",
    "description": "",
    "fullDescription": "",
    "group": {
      "address1": "",
      "address2": "",
      "address3": "",
      "childGroups": [],
      "code": "",
      "contactPoints": [
        {
          "contactPointType": {
            "description": "",
            "id": 0,
            "lookupType": {
              "created": "",
              "description": "",
              "id": 0,
              "lastUpdate": "",
              "type": ""
            },
            "value": ""
          },
          "content": "",
          "created": "",
          "id": 0,
          "lastUpdate": ""
        }
      ],
      "created": "",
      "fhirResourceId": "",
      "groupFeatures": [
        {
          "created": "",
          "feature": {
            "created": "",
            "description": "",
            "id": 0,
            "lastUpdate": "",
            "name": ""
          },
          "id": 0,
          "lastUpdate": ""
        }
      ],
      "groupType": {
        "created": "",
        "description": "",
        "descriptionFriendly": "",
        "displayOrder": 0,
        "id": 0,
        "lastUpdate": "",
        "lookupType": {},
        "value": ""
      },
      "id": 0,
      "lastImportDate": "",
      "lastUpdate": "",
      "links": [
        {
          "created": "",
          "displayOrder": 0,
          "id": 0,
          "lastUpdate": "",
          "link": "",
          "linkType": {},
          "name": ""
        }
      ],
      "locations": [
        {
          "address": "",
          "created": "",
          "email": "",
          "id": 0,
          "label": "",
          "lastUpdate": "",
          "name": "",
          "phone": "",
          "web": ""
        }
      ],
      "name": "",
      "parentGroups": [],
      "postcode": "",
      "sftpUser": "",
      "shortName": "",
      "visible": false,
      "visibleToJoin": false
    },
    "id": 0,
    "identifier": "",
    "links": [
      {}
    ],
    "notes": "",
    "severity": "",
    "status": ""
  },
  "encounters": [
    {
      "date": "",
      "encounterType": "",
      "group": {},
      "id": 0,
      "identifier": "",
      "links": [
        {}
      ],
      "observations": [
        {
          "applies": "",
          "bodySite": "",
          "comments": "",
          "comparator": "",
          "diagram": "",
          "group": {},
          "id": 0,
          "identifier": "",
          "location": "",
          "name": "",
          "temporaryUuid": "",
          "units": "",
          "value": ""
        }
      ],
      "procedures": [
        {
          "bodySite": "",
          "id": 0,
          "type": ""
        }
      ],
      "status": ""
    }
  ],
  "groupCode": "",
  "identifier": "",
  "observations": [
    {}
  ],
  "patient": {
    "address1": "",
    "address2": "",
    "address3": "",
    "address4": "",
    "contacts": [
      {
        "id": 0,
        "system": "",
        "use": "",
        "value": ""
      }
    ],
    "dateOfBirth": "",
    "dateOfBirthNoTime": "",
    "forename": "",
    "gender": "",
    "group": {},
    "groupCode": "",
    "identifier": "",
    "identifiers": [
      {
        "id": 0,
        "label": "",
        "value": ""
      }
    ],
    "postcode": "",
    "practitioners": [
      {
        "address1": "",
        "address2": "",
        "address3": "",
        "address4": "",
        "allowInviteGp": false,
        "contacts": [
          {}
        ],
        "gender": "",
        "groupCode": "",
        "identifier": "",
        "inviteDate": "",
        "name": "",
        "postcode": "",
        "role": ""
      }
    ],
    "surname": ""
  },
  "practitioners": [
    {}
  ]
}' |  \
  http POST {{baseUrl}}/patientmanagement/:userId/group/:groupId/identifier/:identifierId \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "condition": {\n    "asserter": "",\n    "category": "",\n    "code": "",\n    "date": "",\n    "description": "",\n    "fullDescription": "",\n    "group": {\n      "address1": "",\n      "address2": "",\n      "address3": "",\n      "childGroups": [],\n      "code": "",\n      "contactPoints": [\n        {\n          "contactPointType": {\n            "description": "",\n            "id": 0,\n            "lookupType": {\n              "created": "",\n              "description": "",\n              "id": 0,\n              "lastUpdate": "",\n              "type": ""\n            },\n            "value": ""\n          },\n          "content": "",\n          "created": "",\n          "id": 0,\n          "lastUpdate": ""\n        }\n      ],\n      "created": "",\n      "fhirResourceId": "",\n      "groupFeatures": [\n        {\n          "created": "",\n          "feature": {\n            "created": "",\n            "description": "",\n            "id": 0,\n            "lastUpdate": "",\n            "name": ""\n          },\n          "id": 0,\n          "lastUpdate": ""\n        }\n      ],\n      "groupType": {\n        "created": "",\n        "description": "",\n        "descriptionFriendly": "",\n        "displayOrder": 0,\n        "id": 0,\n        "lastUpdate": "",\n        "lookupType": {},\n        "value": ""\n      },\n      "id": 0,\n      "lastImportDate": "",\n      "lastUpdate": "",\n      "links": [\n        {\n          "created": "",\n          "displayOrder": 0,\n          "id": 0,\n          "lastUpdate": "",\n          "link": "",\n          "linkType": {},\n          "name": ""\n        }\n      ],\n      "locations": [\n        {\n          "address": "",\n          "created": "",\n          "email": "",\n          "id": 0,\n          "label": "",\n          "lastUpdate": "",\n          "name": "",\n          "phone": "",\n          "web": ""\n        }\n      ],\n      "name": "",\n      "parentGroups": [],\n      "postcode": "",\n      "sftpUser": "",\n      "shortName": "",\n      "visible": false,\n      "visibleToJoin": false\n    },\n    "id": 0,\n    "identifier": "",\n    "links": [\n      {}\n    ],\n    "notes": "",\n    "severity": "",\n    "status": ""\n  },\n  "encounters": [\n    {\n      "date": "",\n      "encounterType": "",\n      "group": {},\n      "id": 0,\n      "identifier": "",\n      "links": [\n        {}\n      ],\n      "observations": [\n        {\n          "applies": "",\n          "bodySite": "",\n          "comments": "",\n          "comparator": "",\n          "diagram": "",\n          "group": {},\n          "id": 0,\n          "identifier": "",\n          "location": "",\n          "name": "",\n          "temporaryUuid": "",\n          "units": "",\n          "value": ""\n        }\n      ],\n      "procedures": [\n        {\n          "bodySite": "",\n          "id": 0,\n          "type": ""\n        }\n      ],\n      "status": ""\n    }\n  ],\n  "groupCode": "",\n  "identifier": "",\n  "observations": [\n    {}\n  ],\n  "patient": {\n    "address1": "",\n    "address2": "",\n    "address3": "",\n    "address4": "",\n    "contacts": [\n      {\n        "id": 0,\n        "system": "",\n        "use": "",\n        "value": ""\n      }\n    ],\n    "dateOfBirth": "",\n    "dateOfBirthNoTime": "",\n    "forename": "",\n    "gender": "",\n    "group": {},\n    "groupCode": "",\n    "identifier": "",\n    "identifiers": [\n      {\n        "id": 0,\n        "label": "",\n        "value": ""\n      }\n    ],\n    "postcode": "",\n    "practitioners": [\n      {\n        "address1": "",\n        "address2": "",\n        "address3": "",\n        "address4": "",\n        "allowInviteGp": false,\n        "contacts": [\n          {}\n        ],\n        "gender": "",\n        "groupCode": "",\n        "identifier": "",\n        "inviteDate": "",\n        "name": "",\n        "postcode": "",\n        "role": ""\n      }\n    ],\n    "surname": ""\n  },\n  "practitioners": [\n    {}\n  ]\n}' \
  --output-document \
  - {{baseUrl}}/patientmanagement/:userId/group/:groupId/identifier/:identifierId
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "condition": [
    "asserter": "",
    "category": "",
    "code": "",
    "date": "",
    "description": "",
    "fullDescription": "",
    "group": [
      "address1": "",
      "address2": "",
      "address3": "",
      "childGroups": [],
      "code": "",
      "contactPoints": [
        [
          "contactPointType": [
            "description": "",
            "id": 0,
            "lookupType": [
              "created": "",
              "description": "",
              "id": 0,
              "lastUpdate": "",
              "type": ""
            ],
            "value": ""
          ],
          "content": "",
          "created": "",
          "id": 0,
          "lastUpdate": ""
        ]
      ],
      "created": "",
      "fhirResourceId": "",
      "groupFeatures": [
        [
          "created": "",
          "feature": [
            "created": "",
            "description": "",
            "id": 0,
            "lastUpdate": "",
            "name": ""
          ],
          "id": 0,
          "lastUpdate": ""
        ]
      ],
      "groupType": [
        "created": "",
        "description": "",
        "descriptionFriendly": "",
        "displayOrder": 0,
        "id": 0,
        "lastUpdate": "",
        "lookupType": [],
        "value": ""
      ],
      "id": 0,
      "lastImportDate": "",
      "lastUpdate": "",
      "links": [
        [
          "created": "",
          "displayOrder": 0,
          "id": 0,
          "lastUpdate": "",
          "link": "",
          "linkType": [],
          "name": ""
        ]
      ],
      "locations": [
        [
          "address": "",
          "created": "",
          "email": "",
          "id": 0,
          "label": "",
          "lastUpdate": "",
          "name": "",
          "phone": "",
          "web": ""
        ]
      ],
      "name": "",
      "parentGroups": [],
      "postcode": "",
      "sftpUser": "",
      "shortName": "",
      "visible": false,
      "visibleToJoin": false
    ],
    "id": 0,
    "identifier": "",
    "links": [[]],
    "notes": "",
    "severity": "",
    "status": ""
  ],
  "encounters": [
    [
      "date": "",
      "encounterType": "",
      "group": [],
      "id": 0,
      "identifier": "",
      "links": [[]],
      "observations": [
        [
          "applies": "",
          "bodySite": "",
          "comments": "",
          "comparator": "",
          "diagram": "",
          "group": [],
          "id": 0,
          "identifier": "",
          "location": "",
          "name": "",
          "temporaryUuid": "",
          "units": "",
          "value": ""
        ]
      ],
      "procedures": [
        [
          "bodySite": "",
          "id": 0,
          "type": ""
        ]
      ],
      "status": ""
    ]
  ],
  "groupCode": "",
  "identifier": "",
  "observations": [[]],
  "patient": [
    "address1": "",
    "address2": "",
    "address3": "",
    "address4": "",
    "contacts": [
      [
        "id": 0,
        "system": "",
        "use": "",
        "value": ""
      ]
    ],
    "dateOfBirth": "",
    "dateOfBirthNoTime": "",
    "forename": "",
    "gender": "",
    "group": [],
    "groupCode": "",
    "identifier": "",
    "identifiers": [
      [
        "id": 0,
        "label": "",
        "value": ""
      ]
    ],
    "postcode": "",
    "practitioners": [
      [
        "address1": "",
        "address2": "",
        "address3": "",
        "address4": "",
        "allowInviteGp": false,
        "contacts": [[]],
        "gender": "",
        "groupCode": "",
        "identifier": "",
        "inviteDate": "",
        "name": "",
        "postcode": "",
        "role": ""
      ]
    ],
    "surname": ""
  ],
  "practitioners": [[]]
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/patientmanagement/:userId/group/:groupId/identifier/:identifierId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST savePatientManagementSurgeries
{{baseUrl}}/patientmanagement/:userId/group/:groupId/identifier/:identifierId/surgeries
QUERY PARAMS

userId
groupId
identifierId
BODY json

{
  "condition": {
    "asserter": "",
    "category": "",
    "code": "",
    "date": "",
    "description": "",
    "fullDescription": "",
    "group": {
      "address1": "",
      "address2": "",
      "address3": "",
      "childGroups": [],
      "code": "",
      "contactPoints": [
        {
          "contactPointType": {
            "description": "",
            "id": 0,
            "lookupType": {
              "created": "",
              "description": "",
              "id": 0,
              "lastUpdate": "",
              "type": ""
            },
            "value": ""
          },
          "content": "",
          "created": "",
          "id": 0,
          "lastUpdate": ""
        }
      ],
      "created": "",
      "fhirResourceId": "",
      "groupFeatures": [
        {
          "created": "",
          "feature": {
            "created": "",
            "description": "",
            "id": 0,
            "lastUpdate": "",
            "name": ""
          },
          "id": 0,
          "lastUpdate": ""
        }
      ],
      "groupType": {
        "created": "",
        "description": "",
        "descriptionFriendly": "",
        "displayOrder": 0,
        "id": 0,
        "lastUpdate": "",
        "lookupType": {},
        "value": ""
      },
      "id": 0,
      "lastImportDate": "",
      "lastUpdate": "",
      "links": [
        {
          "created": "",
          "displayOrder": 0,
          "id": 0,
          "lastUpdate": "",
          "link": "",
          "linkType": {},
          "name": ""
        }
      ],
      "locations": [
        {
          "address": "",
          "created": "",
          "email": "",
          "id": 0,
          "label": "",
          "lastUpdate": "",
          "name": "",
          "phone": "",
          "web": ""
        }
      ],
      "name": "",
      "parentGroups": [],
      "postcode": "",
      "sftpUser": "",
      "shortName": "",
      "visible": false,
      "visibleToJoin": false
    },
    "id": 0,
    "identifier": "",
    "links": [
      {}
    ],
    "notes": "",
    "severity": "",
    "status": ""
  },
  "encounters": [
    {
      "date": "",
      "encounterType": "",
      "group": {},
      "id": 0,
      "identifier": "",
      "links": [
        {}
      ],
      "observations": [
        {
          "applies": "",
          "bodySite": "",
          "comments": "",
          "comparator": "",
          "diagram": "",
          "group": {},
          "id": 0,
          "identifier": "",
          "location": "",
          "name": "",
          "temporaryUuid": "",
          "units": "",
          "value": ""
        }
      ],
      "procedures": [
        {
          "bodySite": "",
          "id": 0,
          "type": ""
        }
      ],
      "status": ""
    }
  ],
  "groupCode": "",
  "identifier": "",
  "observations": [
    {}
  ],
  "patient": {
    "address1": "",
    "address2": "",
    "address3": "",
    "address4": "",
    "contacts": [
      {
        "id": 0,
        "system": "",
        "use": "",
        "value": ""
      }
    ],
    "dateOfBirth": "",
    "dateOfBirthNoTime": "",
    "forename": "",
    "gender": "",
    "group": {},
    "groupCode": "",
    "identifier": "",
    "identifiers": [
      {
        "id": 0,
        "label": "",
        "value": ""
      }
    ],
    "postcode": "",
    "practitioners": [
      {
        "address1": "",
        "address2": "",
        "address3": "",
        "address4": "",
        "allowInviteGp": false,
        "contacts": [
          {}
        ],
        "gender": "",
        "groupCode": "",
        "identifier": "",
        "inviteDate": "",
        "name": "",
        "postcode": "",
        "role": ""
      }
    ],
    "surname": ""
  },
  "practitioners": [
    {}
  ]
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/patientmanagement/:userId/group/:groupId/identifier/:identifierId/surgeries");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"condition\": {\n    \"asserter\": \"\",\n    \"category\": \"\",\n    \"code\": \"\",\n    \"date\": \"\",\n    \"description\": \"\",\n    \"fullDescription\": \"\",\n    \"group\": {\n      \"address1\": \"\",\n      \"address2\": \"\",\n      \"address3\": \"\",\n      \"childGroups\": [],\n      \"code\": \"\",\n      \"contactPoints\": [\n        {\n          \"contactPointType\": {\n            \"description\": \"\",\n            \"id\": 0,\n            \"lookupType\": {\n              \"created\": \"\",\n              \"description\": \"\",\n              \"id\": 0,\n              \"lastUpdate\": \"\",\n              \"type\": \"\"\n            },\n            \"value\": \"\"\n          },\n          \"content\": \"\",\n          \"created\": \"\",\n          \"id\": 0,\n          \"lastUpdate\": \"\"\n        }\n      ],\n      \"created\": \"\",\n      \"fhirResourceId\": \"\",\n      \"groupFeatures\": [\n        {\n          \"created\": \"\",\n          \"feature\": {\n            \"created\": \"\",\n            \"description\": \"\",\n            \"id\": 0,\n            \"lastUpdate\": \"\",\n            \"name\": \"\"\n          },\n          \"id\": 0,\n          \"lastUpdate\": \"\"\n        }\n      ],\n      \"groupType\": {\n        \"created\": \"\",\n        \"description\": \"\",\n        \"descriptionFriendly\": \"\",\n        \"displayOrder\": 0,\n        \"id\": 0,\n        \"lastUpdate\": \"\",\n        \"lookupType\": {},\n        \"value\": \"\"\n      },\n      \"id\": 0,\n      \"lastImportDate\": \"\",\n      \"lastUpdate\": \"\",\n      \"links\": [\n        {\n          \"created\": \"\",\n          \"displayOrder\": 0,\n          \"id\": 0,\n          \"lastUpdate\": \"\",\n          \"link\": \"\",\n          \"linkType\": {},\n          \"name\": \"\"\n        }\n      ],\n      \"locations\": [\n        {\n          \"address\": \"\",\n          \"created\": \"\",\n          \"email\": \"\",\n          \"id\": 0,\n          \"label\": \"\",\n          \"lastUpdate\": \"\",\n          \"name\": \"\",\n          \"phone\": \"\",\n          \"web\": \"\"\n        }\n      ],\n      \"name\": \"\",\n      \"parentGroups\": [],\n      \"postcode\": \"\",\n      \"sftpUser\": \"\",\n      \"shortName\": \"\",\n      \"visible\": false,\n      \"visibleToJoin\": false\n    },\n    \"id\": 0,\n    \"identifier\": \"\",\n    \"links\": [\n      {}\n    ],\n    \"notes\": \"\",\n    \"severity\": \"\",\n    \"status\": \"\"\n  },\n  \"encounters\": [\n    {\n      \"date\": \"\",\n      \"encounterType\": \"\",\n      \"group\": {},\n      \"id\": 0,\n      \"identifier\": \"\",\n      \"links\": [\n        {}\n      ],\n      \"observations\": [\n        {\n          \"applies\": \"\",\n          \"bodySite\": \"\",\n          \"comments\": \"\",\n          \"comparator\": \"\",\n          \"diagram\": \"\",\n          \"group\": {},\n          \"id\": 0,\n          \"identifier\": \"\",\n          \"location\": \"\",\n          \"name\": \"\",\n          \"temporaryUuid\": \"\",\n          \"units\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"procedures\": [\n        {\n          \"bodySite\": \"\",\n          \"id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"status\": \"\"\n    }\n  ],\n  \"groupCode\": \"\",\n  \"identifier\": \"\",\n  \"observations\": [\n    {}\n  ],\n  \"patient\": {\n    \"address1\": \"\",\n    \"address2\": \"\",\n    \"address3\": \"\",\n    \"address4\": \"\",\n    \"contacts\": [\n      {\n        \"id\": 0,\n        \"system\": \"\",\n        \"use\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"dateOfBirth\": \"\",\n    \"dateOfBirthNoTime\": \"\",\n    \"forename\": \"\",\n    \"gender\": \"\",\n    \"group\": {},\n    \"groupCode\": \"\",\n    \"identifier\": \"\",\n    \"identifiers\": [\n      {\n        \"id\": 0,\n        \"label\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"postcode\": \"\",\n    \"practitioners\": [\n      {\n        \"address1\": \"\",\n        \"address2\": \"\",\n        \"address3\": \"\",\n        \"address4\": \"\",\n        \"allowInviteGp\": false,\n        \"contacts\": [\n          {}\n        ],\n        \"gender\": \"\",\n        \"groupCode\": \"\",\n        \"identifier\": \"\",\n        \"inviteDate\": \"\",\n        \"name\": \"\",\n        \"postcode\": \"\",\n        \"role\": \"\"\n      }\n    ],\n    \"surname\": \"\"\n  },\n  \"practitioners\": [\n    {}\n  ]\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/patientmanagement/:userId/group/:groupId/identifier/:identifierId/surgeries" {:content-type :json
                                                                                                                        :form-params {:condition {:asserter ""
                                                                                                                                                  :category ""
                                                                                                                                                  :code ""
                                                                                                                                                  :date ""
                                                                                                                                                  :description ""
                                                                                                                                                  :fullDescription ""
                                                                                                                                                  :group {:address1 ""
                                                                                                                                                          :address2 ""
                                                                                                                                                          :address3 ""
                                                                                                                                                          :childGroups []
                                                                                                                                                          :code ""
                                                                                                                                                          :contactPoints [{:contactPointType {:description ""
                                                                                                                                                                                              :id 0
                                                                                                                                                                                              :lookupType {:created ""
                                                                                                                                                                                                           :description ""
                                                                                                                                                                                                           :id 0
                                                                                                                                                                                                           :lastUpdate ""
                                                                                                                                                                                                           :type ""}
                                                                                                                                                                                              :value ""}
                                                                                                                                                                           :content ""
                                                                                                                                                                           :created ""
                                                                                                                                                                           :id 0
                                                                                                                                                                           :lastUpdate ""}]
                                                                                                                                                          :created ""
                                                                                                                                                          :fhirResourceId ""
                                                                                                                                                          :groupFeatures [{:created ""
                                                                                                                                                                           :feature {:created ""
                                                                                                                                                                                     :description ""
                                                                                                                                                                                     :id 0
                                                                                                                                                                                     :lastUpdate ""
                                                                                                                                                                                     :name ""}
                                                                                                                                                                           :id 0
                                                                                                                                                                           :lastUpdate ""}]
                                                                                                                                                          :groupType {:created ""
                                                                                                                                                                      :description ""
                                                                                                                                                                      :descriptionFriendly ""
                                                                                                                                                                      :displayOrder 0
                                                                                                                                                                      :id 0
                                                                                                                                                                      :lastUpdate ""
                                                                                                                                                                      :lookupType {}
                                                                                                                                                                      :value ""}
                                                                                                                                                          :id 0
                                                                                                                                                          :lastImportDate ""
                                                                                                                                                          :lastUpdate ""
                                                                                                                                                          :links [{:created ""
                                                                                                                                                                   :displayOrder 0
                                                                                                                                                                   :id 0
                                                                                                                                                                   :lastUpdate ""
                                                                                                                                                                   :link ""
                                                                                                                                                                   :linkType {}
                                                                                                                                                                   :name ""}]
                                                                                                                                                          :locations [{:address ""
                                                                                                                                                                       :created ""
                                                                                                                                                                       :email ""
                                                                                                                                                                       :id 0
                                                                                                                                                                       :label ""
                                                                                                                                                                       :lastUpdate ""
                                                                                                                                                                       :name ""
                                                                                                                                                                       :phone ""
                                                                                                                                                                       :web ""}]
                                                                                                                                                          :name ""
                                                                                                                                                          :parentGroups []
                                                                                                                                                          :postcode ""
                                                                                                                                                          :sftpUser ""
                                                                                                                                                          :shortName ""
                                                                                                                                                          :visible false
                                                                                                                                                          :visibleToJoin false}
                                                                                                                                                  :id 0
                                                                                                                                                  :identifier ""
                                                                                                                                                  :links [{}]
                                                                                                                                                  :notes ""
                                                                                                                                                  :severity ""
                                                                                                                                                  :status ""}
                                                                                                                                      :encounters [{:date ""
                                                                                                                                                    :encounterType ""
                                                                                                                                                    :group {}
                                                                                                                                                    :id 0
                                                                                                                                                    :identifier ""
                                                                                                                                                    :links [{}]
                                                                                                                                                    :observations [{:applies ""
                                                                                                                                                                    :bodySite ""
                                                                                                                                                                    :comments ""
                                                                                                                                                                    :comparator ""
                                                                                                                                                                    :diagram ""
                                                                                                                                                                    :group {}
                                                                                                                                                                    :id 0
                                                                                                                                                                    :identifier ""
                                                                                                                                                                    :location ""
                                                                                                                                                                    :name ""
                                                                                                                                                                    :temporaryUuid ""
                                                                                                                                                                    :units ""
                                                                                                                                                                    :value ""}]
                                                                                                                                                    :procedures [{:bodySite ""
                                                                                                                                                                  :id 0
                                                                                                                                                                  :type ""}]
                                                                                                                                                    :status ""}]
                                                                                                                                      :groupCode ""
                                                                                                                                      :identifier ""
                                                                                                                                      :observations [{}]
                                                                                                                                      :patient {:address1 ""
                                                                                                                                                :address2 ""
                                                                                                                                                :address3 ""
                                                                                                                                                :address4 ""
                                                                                                                                                :contacts [{:id 0
                                                                                                                                                            :system ""
                                                                                                                                                            :use ""
                                                                                                                                                            :value ""}]
                                                                                                                                                :dateOfBirth ""
                                                                                                                                                :dateOfBirthNoTime ""
                                                                                                                                                :forename ""
                                                                                                                                                :gender ""
                                                                                                                                                :group {}
                                                                                                                                                :groupCode ""
                                                                                                                                                :identifier ""
                                                                                                                                                :identifiers [{:id 0
                                                                                                                                                               :label ""
                                                                                                                                                               :value ""}]
                                                                                                                                                :postcode ""
                                                                                                                                                :practitioners [{:address1 ""
                                                                                                                                                                 :address2 ""
                                                                                                                                                                 :address3 ""
                                                                                                                                                                 :address4 ""
                                                                                                                                                                 :allowInviteGp false
                                                                                                                                                                 :contacts [{}]
                                                                                                                                                                 :gender ""
                                                                                                                                                                 :groupCode ""
                                                                                                                                                                 :identifier ""
                                                                                                                                                                 :inviteDate ""
                                                                                                                                                                 :name ""
                                                                                                                                                                 :postcode ""
                                                                                                                                                                 :role ""}]
                                                                                                                                                :surname ""}
                                                                                                                                      :practitioners [{}]}})
require "http/client"

url = "{{baseUrl}}/patientmanagement/:userId/group/:groupId/identifier/:identifierId/surgeries"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"condition\": {\n    \"asserter\": \"\",\n    \"category\": \"\",\n    \"code\": \"\",\n    \"date\": \"\",\n    \"description\": \"\",\n    \"fullDescription\": \"\",\n    \"group\": {\n      \"address1\": \"\",\n      \"address2\": \"\",\n      \"address3\": \"\",\n      \"childGroups\": [],\n      \"code\": \"\",\n      \"contactPoints\": [\n        {\n          \"contactPointType\": {\n            \"description\": \"\",\n            \"id\": 0,\n            \"lookupType\": {\n              \"created\": \"\",\n              \"description\": \"\",\n              \"id\": 0,\n              \"lastUpdate\": \"\",\n              \"type\": \"\"\n            },\n            \"value\": \"\"\n          },\n          \"content\": \"\",\n          \"created\": \"\",\n          \"id\": 0,\n          \"lastUpdate\": \"\"\n        }\n      ],\n      \"created\": \"\",\n      \"fhirResourceId\": \"\",\n      \"groupFeatures\": [\n        {\n          \"created\": \"\",\n          \"feature\": {\n            \"created\": \"\",\n            \"description\": \"\",\n            \"id\": 0,\n            \"lastUpdate\": \"\",\n            \"name\": \"\"\n          },\n          \"id\": 0,\n          \"lastUpdate\": \"\"\n        }\n      ],\n      \"groupType\": {\n        \"created\": \"\",\n        \"description\": \"\",\n        \"descriptionFriendly\": \"\",\n        \"displayOrder\": 0,\n        \"id\": 0,\n        \"lastUpdate\": \"\",\n        \"lookupType\": {},\n        \"value\": \"\"\n      },\n      \"id\": 0,\n      \"lastImportDate\": \"\",\n      \"lastUpdate\": \"\",\n      \"links\": [\n        {\n          \"created\": \"\",\n          \"displayOrder\": 0,\n          \"id\": 0,\n          \"lastUpdate\": \"\",\n          \"link\": \"\",\n          \"linkType\": {},\n          \"name\": \"\"\n        }\n      ],\n      \"locations\": [\n        {\n          \"address\": \"\",\n          \"created\": \"\",\n          \"email\": \"\",\n          \"id\": 0,\n          \"label\": \"\",\n          \"lastUpdate\": \"\",\n          \"name\": \"\",\n          \"phone\": \"\",\n          \"web\": \"\"\n        }\n      ],\n      \"name\": \"\",\n      \"parentGroups\": [],\n      \"postcode\": \"\",\n      \"sftpUser\": \"\",\n      \"shortName\": \"\",\n      \"visible\": false,\n      \"visibleToJoin\": false\n    },\n    \"id\": 0,\n    \"identifier\": \"\",\n    \"links\": [\n      {}\n    ],\n    \"notes\": \"\",\n    \"severity\": \"\",\n    \"status\": \"\"\n  },\n  \"encounters\": [\n    {\n      \"date\": \"\",\n      \"encounterType\": \"\",\n      \"group\": {},\n      \"id\": 0,\n      \"identifier\": \"\",\n      \"links\": [\n        {}\n      ],\n      \"observations\": [\n        {\n          \"applies\": \"\",\n          \"bodySite\": \"\",\n          \"comments\": \"\",\n          \"comparator\": \"\",\n          \"diagram\": \"\",\n          \"group\": {},\n          \"id\": 0,\n          \"identifier\": \"\",\n          \"location\": \"\",\n          \"name\": \"\",\n          \"temporaryUuid\": \"\",\n          \"units\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"procedures\": [\n        {\n          \"bodySite\": \"\",\n          \"id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"status\": \"\"\n    }\n  ],\n  \"groupCode\": \"\",\n  \"identifier\": \"\",\n  \"observations\": [\n    {}\n  ],\n  \"patient\": {\n    \"address1\": \"\",\n    \"address2\": \"\",\n    \"address3\": \"\",\n    \"address4\": \"\",\n    \"contacts\": [\n      {\n        \"id\": 0,\n        \"system\": \"\",\n        \"use\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"dateOfBirth\": \"\",\n    \"dateOfBirthNoTime\": \"\",\n    \"forename\": \"\",\n    \"gender\": \"\",\n    \"group\": {},\n    \"groupCode\": \"\",\n    \"identifier\": \"\",\n    \"identifiers\": [\n      {\n        \"id\": 0,\n        \"label\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"postcode\": \"\",\n    \"practitioners\": [\n      {\n        \"address1\": \"\",\n        \"address2\": \"\",\n        \"address3\": \"\",\n        \"address4\": \"\",\n        \"allowInviteGp\": false,\n        \"contacts\": [\n          {}\n        ],\n        \"gender\": \"\",\n        \"groupCode\": \"\",\n        \"identifier\": \"\",\n        \"inviteDate\": \"\",\n        \"name\": \"\",\n        \"postcode\": \"\",\n        \"role\": \"\"\n      }\n    ],\n    \"surname\": \"\"\n  },\n  \"practitioners\": [\n    {}\n  ]\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/patientmanagement/:userId/group/:groupId/identifier/:identifierId/surgeries"),
    Content = new StringContent("{\n  \"condition\": {\n    \"asserter\": \"\",\n    \"category\": \"\",\n    \"code\": \"\",\n    \"date\": \"\",\n    \"description\": \"\",\n    \"fullDescription\": \"\",\n    \"group\": {\n      \"address1\": \"\",\n      \"address2\": \"\",\n      \"address3\": \"\",\n      \"childGroups\": [],\n      \"code\": \"\",\n      \"contactPoints\": [\n        {\n          \"contactPointType\": {\n            \"description\": \"\",\n            \"id\": 0,\n            \"lookupType\": {\n              \"created\": \"\",\n              \"description\": \"\",\n              \"id\": 0,\n              \"lastUpdate\": \"\",\n              \"type\": \"\"\n            },\n            \"value\": \"\"\n          },\n          \"content\": \"\",\n          \"created\": \"\",\n          \"id\": 0,\n          \"lastUpdate\": \"\"\n        }\n      ],\n      \"created\": \"\",\n      \"fhirResourceId\": \"\",\n      \"groupFeatures\": [\n        {\n          \"created\": \"\",\n          \"feature\": {\n            \"created\": \"\",\n            \"description\": \"\",\n            \"id\": 0,\n            \"lastUpdate\": \"\",\n            \"name\": \"\"\n          },\n          \"id\": 0,\n          \"lastUpdate\": \"\"\n        }\n      ],\n      \"groupType\": {\n        \"created\": \"\",\n        \"description\": \"\",\n        \"descriptionFriendly\": \"\",\n        \"displayOrder\": 0,\n        \"id\": 0,\n        \"lastUpdate\": \"\",\n        \"lookupType\": {},\n        \"value\": \"\"\n      },\n      \"id\": 0,\n      \"lastImportDate\": \"\",\n      \"lastUpdate\": \"\",\n      \"links\": [\n        {\n          \"created\": \"\",\n          \"displayOrder\": 0,\n          \"id\": 0,\n          \"lastUpdate\": \"\",\n          \"link\": \"\",\n          \"linkType\": {},\n          \"name\": \"\"\n        }\n      ],\n      \"locations\": [\n        {\n          \"address\": \"\",\n          \"created\": \"\",\n          \"email\": \"\",\n          \"id\": 0,\n          \"label\": \"\",\n          \"lastUpdate\": \"\",\n          \"name\": \"\",\n          \"phone\": \"\",\n          \"web\": \"\"\n        }\n      ],\n      \"name\": \"\",\n      \"parentGroups\": [],\n      \"postcode\": \"\",\n      \"sftpUser\": \"\",\n      \"shortName\": \"\",\n      \"visible\": false,\n      \"visibleToJoin\": false\n    },\n    \"id\": 0,\n    \"identifier\": \"\",\n    \"links\": [\n      {}\n    ],\n    \"notes\": \"\",\n    \"severity\": \"\",\n    \"status\": \"\"\n  },\n  \"encounters\": [\n    {\n      \"date\": \"\",\n      \"encounterType\": \"\",\n      \"group\": {},\n      \"id\": 0,\n      \"identifier\": \"\",\n      \"links\": [\n        {}\n      ],\n      \"observations\": [\n        {\n          \"applies\": \"\",\n          \"bodySite\": \"\",\n          \"comments\": \"\",\n          \"comparator\": \"\",\n          \"diagram\": \"\",\n          \"group\": {},\n          \"id\": 0,\n          \"identifier\": \"\",\n          \"location\": \"\",\n          \"name\": \"\",\n          \"temporaryUuid\": \"\",\n          \"units\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"procedures\": [\n        {\n          \"bodySite\": \"\",\n          \"id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"status\": \"\"\n    }\n  ],\n  \"groupCode\": \"\",\n  \"identifier\": \"\",\n  \"observations\": [\n    {}\n  ],\n  \"patient\": {\n    \"address1\": \"\",\n    \"address2\": \"\",\n    \"address3\": \"\",\n    \"address4\": \"\",\n    \"contacts\": [\n      {\n        \"id\": 0,\n        \"system\": \"\",\n        \"use\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"dateOfBirth\": \"\",\n    \"dateOfBirthNoTime\": \"\",\n    \"forename\": \"\",\n    \"gender\": \"\",\n    \"group\": {},\n    \"groupCode\": \"\",\n    \"identifier\": \"\",\n    \"identifiers\": [\n      {\n        \"id\": 0,\n        \"label\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"postcode\": \"\",\n    \"practitioners\": [\n      {\n        \"address1\": \"\",\n        \"address2\": \"\",\n        \"address3\": \"\",\n        \"address4\": \"\",\n        \"allowInviteGp\": false,\n        \"contacts\": [\n          {}\n        ],\n        \"gender\": \"\",\n        \"groupCode\": \"\",\n        \"identifier\": \"\",\n        \"inviteDate\": \"\",\n        \"name\": \"\",\n        \"postcode\": \"\",\n        \"role\": \"\"\n      }\n    ],\n    \"surname\": \"\"\n  },\n  \"practitioners\": [\n    {}\n  ]\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/patientmanagement/:userId/group/:groupId/identifier/:identifierId/surgeries");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"condition\": {\n    \"asserter\": \"\",\n    \"category\": \"\",\n    \"code\": \"\",\n    \"date\": \"\",\n    \"description\": \"\",\n    \"fullDescription\": \"\",\n    \"group\": {\n      \"address1\": \"\",\n      \"address2\": \"\",\n      \"address3\": \"\",\n      \"childGroups\": [],\n      \"code\": \"\",\n      \"contactPoints\": [\n        {\n          \"contactPointType\": {\n            \"description\": \"\",\n            \"id\": 0,\n            \"lookupType\": {\n              \"created\": \"\",\n              \"description\": \"\",\n              \"id\": 0,\n              \"lastUpdate\": \"\",\n              \"type\": \"\"\n            },\n            \"value\": \"\"\n          },\n          \"content\": \"\",\n          \"created\": \"\",\n          \"id\": 0,\n          \"lastUpdate\": \"\"\n        }\n      ],\n      \"created\": \"\",\n      \"fhirResourceId\": \"\",\n      \"groupFeatures\": [\n        {\n          \"created\": \"\",\n          \"feature\": {\n            \"created\": \"\",\n            \"description\": \"\",\n            \"id\": 0,\n            \"lastUpdate\": \"\",\n            \"name\": \"\"\n          },\n          \"id\": 0,\n          \"lastUpdate\": \"\"\n        }\n      ],\n      \"groupType\": {\n        \"created\": \"\",\n        \"description\": \"\",\n        \"descriptionFriendly\": \"\",\n        \"displayOrder\": 0,\n        \"id\": 0,\n        \"lastUpdate\": \"\",\n        \"lookupType\": {},\n        \"value\": \"\"\n      },\n      \"id\": 0,\n      \"lastImportDate\": \"\",\n      \"lastUpdate\": \"\",\n      \"links\": [\n        {\n          \"created\": \"\",\n          \"displayOrder\": 0,\n          \"id\": 0,\n          \"lastUpdate\": \"\",\n          \"link\": \"\",\n          \"linkType\": {},\n          \"name\": \"\"\n        }\n      ],\n      \"locations\": [\n        {\n          \"address\": \"\",\n          \"created\": \"\",\n          \"email\": \"\",\n          \"id\": 0,\n          \"label\": \"\",\n          \"lastUpdate\": \"\",\n          \"name\": \"\",\n          \"phone\": \"\",\n          \"web\": \"\"\n        }\n      ],\n      \"name\": \"\",\n      \"parentGroups\": [],\n      \"postcode\": \"\",\n      \"sftpUser\": \"\",\n      \"shortName\": \"\",\n      \"visible\": false,\n      \"visibleToJoin\": false\n    },\n    \"id\": 0,\n    \"identifier\": \"\",\n    \"links\": [\n      {}\n    ],\n    \"notes\": \"\",\n    \"severity\": \"\",\n    \"status\": \"\"\n  },\n  \"encounters\": [\n    {\n      \"date\": \"\",\n      \"encounterType\": \"\",\n      \"group\": {},\n      \"id\": 0,\n      \"identifier\": \"\",\n      \"links\": [\n        {}\n      ],\n      \"observations\": [\n        {\n          \"applies\": \"\",\n          \"bodySite\": \"\",\n          \"comments\": \"\",\n          \"comparator\": \"\",\n          \"diagram\": \"\",\n          \"group\": {},\n          \"id\": 0,\n          \"identifier\": \"\",\n          \"location\": \"\",\n          \"name\": \"\",\n          \"temporaryUuid\": \"\",\n          \"units\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"procedures\": [\n        {\n          \"bodySite\": \"\",\n          \"id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"status\": \"\"\n    }\n  ],\n  \"groupCode\": \"\",\n  \"identifier\": \"\",\n  \"observations\": [\n    {}\n  ],\n  \"patient\": {\n    \"address1\": \"\",\n    \"address2\": \"\",\n    \"address3\": \"\",\n    \"address4\": \"\",\n    \"contacts\": [\n      {\n        \"id\": 0,\n        \"system\": \"\",\n        \"use\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"dateOfBirth\": \"\",\n    \"dateOfBirthNoTime\": \"\",\n    \"forename\": \"\",\n    \"gender\": \"\",\n    \"group\": {},\n    \"groupCode\": \"\",\n    \"identifier\": \"\",\n    \"identifiers\": [\n      {\n        \"id\": 0,\n        \"label\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"postcode\": \"\",\n    \"practitioners\": [\n      {\n        \"address1\": \"\",\n        \"address2\": \"\",\n        \"address3\": \"\",\n        \"address4\": \"\",\n        \"allowInviteGp\": false,\n        \"contacts\": [\n          {}\n        ],\n        \"gender\": \"\",\n        \"groupCode\": \"\",\n        \"identifier\": \"\",\n        \"inviteDate\": \"\",\n        \"name\": \"\",\n        \"postcode\": \"\",\n        \"role\": \"\"\n      }\n    ],\n    \"surname\": \"\"\n  },\n  \"practitioners\": [\n    {}\n  ]\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/patientmanagement/:userId/group/:groupId/identifier/:identifierId/surgeries"

	payload := strings.NewReader("{\n  \"condition\": {\n    \"asserter\": \"\",\n    \"category\": \"\",\n    \"code\": \"\",\n    \"date\": \"\",\n    \"description\": \"\",\n    \"fullDescription\": \"\",\n    \"group\": {\n      \"address1\": \"\",\n      \"address2\": \"\",\n      \"address3\": \"\",\n      \"childGroups\": [],\n      \"code\": \"\",\n      \"contactPoints\": [\n        {\n          \"contactPointType\": {\n            \"description\": \"\",\n            \"id\": 0,\n            \"lookupType\": {\n              \"created\": \"\",\n              \"description\": \"\",\n              \"id\": 0,\n              \"lastUpdate\": \"\",\n              \"type\": \"\"\n            },\n            \"value\": \"\"\n          },\n          \"content\": \"\",\n          \"created\": \"\",\n          \"id\": 0,\n          \"lastUpdate\": \"\"\n        }\n      ],\n      \"created\": \"\",\n      \"fhirResourceId\": \"\",\n      \"groupFeatures\": [\n        {\n          \"created\": \"\",\n          \"feature\": {\n            \"created\": \"\",\n            \"description\": \"\",\n            \"id\": 0,\n            \"lastUpdate\": \"\",\n            \"name\": \"\"\n          },\n          \"id\": 0,\n          \"lastUpdate\": \"\"\n        }\n      ],\n      \"groupType\": {\n        \"created\": \"\",\n        \"description\": \"\",\n        \"descriptionFriendly\": \"\",\n        \"displayOrder\": 0,\n        \"id\": 0,\n        \"lastUpdate\": \"\",\n        \"lookupType\": {},\n        \"value\": \"\"\n      },\n      \"id\": 0,\n      \"lastImportDate\": \"\",\n      \"lastUpdate\": \"\",\n      \"links\": [\n        {\n          \"created\": \"\",\n          \"displayOrder\": 0,\n          \"id\": 0,\n          \"lastUpdate\": \"\",\n          \"link\": \"\",\n          \"linkType\": {},\n          \"name\": \"\"\n        }\n      ],\n      \"locations\": [\n        {\n          \"address\": \"\",\n          \"created\": \"\",\n          \"email\": \"\",\n          \"id\": 0,\n          \"label\": \"\",\n          \"lastUpdate\": \"\",\n          \"name\": \"\",\n          \"phone\": \"\",\n          \"web\": \"\"\n        }\n      ],\n      \"name\": \"\",\n      \"parentGroups\": [],\n      \"postcode\": \"\",\n      \"sftpUser\": \"\",\n      \"shortName\": \"\",\n      \"visible\": false,\n      \"visibleToJoin\": false\n    },\n    \"id\": 0,\n    \"identifier\": \"\",\n    \"links\": [\n      {}\n    ],\n    \"notes\": \"\",\n    \"severity\": \"\",\n    \"status\": \"\"\n  },\n  \"encounters\": [\n    {\n      \"date\": \"\",\n      \"encounterType\": \"\",\n      \"group\": {},\n      \"id\": 0,\n      \"identifier\": \"\",\n      \"links\": [\n        {}\n      ],\n      \"observations\": [\n        {\n          \"applies\": \"\",\n          \"bodySite\": \"\",\n          \"comments\": \"\",\n          \"comparator\": \"\",\n          \"diagram\": \"\",\n          \"group\": {},\n          \"id\": 0,\n          \"identifier\": \"\",\n          \"location\": \"\",\n          \"name\": \"\",\n          \"temporaryUuid\": \"\",\n          \"units\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"procedures\": [\n        {\n          \"bodySite\": \"\",\n          \"id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"status\": \"\"\n    }\n  ],\n  \"groupCode\": \"\",\n  \"identifier\": \"\",\n  \"observations\": [\n    {}\n  ],\n  \"patient\": {\n    \"address1\": \"\",\n    \"address2\": \"\",\n    \"address3\": \"\",\n    \"address4\": \"\",\n    \"contacts\": [\n      {\n        \"id\": 0,\n        \"system\": \"\",\n        \"use\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"dateOfBirth\": \"\",\n    \"dateOfBirthNoTime\": \"\",\n    \"forename\": \"\",\n    \"gender\": \"\",\n    \"group\": {},\n    \"groupCode\": \"\",\n    \"identifier\": \"\",\n    \"identifiers\": [\n      {\n        \"id\": 0,\n        \"label\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"postcode\": \"\",\n    \"practitioners\": [\n      {\n        \"address1\": \"\",\n        \"address2\": \"\",\n        \"address3\": \"\",\n        \"address4\": \"\",\n        \"allowInviteGp\": false,\n        \"contacts\": [\n          {}\n        ],\n        \"gender\": \"\",\n        \"groupCode\": \"\",\n        \"identifier\": \"\",\n        \"inviteDate\": \"\",\n        \"name\": \"\",\n        \"postcode\": \"\",\n        \"role\": \"\"\n      }\n    ],\n    \"surname\": \"\"\n  },\n  \"practitioners\": [\n    {}\n  ]\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/patientmanagement/:userId/group/:groupId/identifier/:identifierId/surgeries HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 3814

{
  "condition": {
    "asserter": "",
    "category": "",
    "code": "",
    "date": "",
    "description": "",
    "fullDescription": "",
    "group": {
      "address1": "",
      "address2": "",
      "address3": "",
      "childGroups": [],
      "code": "",
      "contactPoints": [
        {
          "contactPointType": {
            "description": "",
            "id": 0,
            "lookupType": {
              "created": "",
              "description": "",
              "id": 0,
              "lastUpdate": "",
              "type": ""
            },
            "value": ""
          },
          "content": "",
          "created": "",
          "id": 0,
          "lastUpdate": ""
        }
      ],
      "created": "",
      "fhirResourceId": "",
      "groupFeatures": [
        {
          "created": "",
          "feature": {
            "created": "",
            "description": "",
            "id": 0,
            "lastUpdate": "",
            "name": ""
          },
          "id": 0,
          "lastUpdate": ""
        }
      ],
      "groupType": {
        "created": "",
        "description": "",
        "descriptionFriendly": "",
        "displayOrder": 0,
        "id": 0,
        "lastUpdate": "",
        "lookupType": {},
        "value": ""
      },
      "id": 0,
      "lastImportDate": "",
      "lastUpdate": "",
      "links": [
        {
          "created": "",
          "displayOrder": 0,
          "id": 0,
          "lastUpdate": "",
          "link": "",
          "linkType": {},
          "name": ""
        }
      ],
      "locations": [
        {
          "address": "",
          "created": "",
          "email": "",
          "id": 0,
          "label": "",
          "lastUpdate": "",
          "name": "",
          "phone": "",
          "web": ""
        }
      ],
      "name": "",
      "parentGroups": [],
      "postcode": "",
      "sftpUser": "",
      "shortName": "",
      "visible": false,
      "visibleToJoin": false
    },
    "id": 0,
    "identifier": "",
    "links": [
      {}
    ],
    "notes": "",
    "severity": "",
    "status": ""
  },
  "encounters": [
    {
      "date": "",
      "encounterType": "",
      "group": {},
      "id": 0,
      "identifier": "",
      "links": [
        {}
      ],
      "observations": [
        {
          "applies": "",
          "bodySite": "",
          "comments": "",
          "comparator": "",
          "diagram": "",
          "group": {},
          "id": 0,
          "identifier": "",
          "location": "",
          "name": "",
          "temporaryUuid": "",
          "units": "",
          "value": ""
        }
      ],
      "procedures": [
        {
          "bodySite": "",
          "id": 0,
          "type": ""
        }
      ],
      "status": ""
    }
  ],
  "groupCode": "",
  "identifier": "",
  "observations": [
    {}
  ],
  "patient": {
    "address1": "",
    "address2": "",
    "address3": "",
    "address4": "",
    "contacts": [
      {
        "id": 0,
        "system": "",
        "use": "",
        "value": ""
      }
    ],
    "dateOfBirth": "",
    "dateOfBirthNoTime": "",
    "forename": "",
    "gender": "",
    "group": {},
    "groupCode": "",
    "identifier": "",
    "identifiers": [
      {
        "id": 0,
        "label": "",
        "value": ""
      }
    ],
    "postcode": "",
    "practitioners": [
      {
        "address1": "",
        "address2": "",
        "address3": "",
        "address4": "",
        "allowInviteGp": false,
        "contacts": [
          {}
        ],
        "gender": "",
        "groupCode": "",
        "identifier": "",
        "inviteDate": "",
        "name": "",
        "postcode": "",
        "role": ""
      }
    ],
    "surname": ""
  },
  "practitioners": [
    {}
  ]
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/patientmanagement/:userId/group/:groupId/identifier/:identifierId/surgeries")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"condition\": {\n    \"asserter\": \"\",\n    \"category\": \"\",\n    \"code\": \"\",\n    \"date\": \"\",\n    \"description\": \"\",\n    \"fullDescription\": \"\",\n    \"group\": {\n      \"address1\": \"\",\n      \"address2\": \"\",\n      \"address3\": \"\",\n      \"childGroups\": [],\n      \"code\": \"\",\n      \"contactPoints\": [\n        {\n          \"contactPointType\": {\n            \"description\": \"\",\n            \"id\": 0,\n            \"lookupType\": {\n              \"created\": \"\",\n              \"description\": \"\",\n              \"id\": 0,\n              \"lastUpdate\": \"\",\n              \"type\": \"\"\n            },\n            \"value\": \"\"\n          },\n          \"content\": \"\",\n          \"created\": \"\",\n          \"id\": 0,\n          \"lastUpdate\": \"\"\n        }\n      ],\n      \"created\": \"\",\n      \"fhirResourceId\": \"\",\n      \"groupFeatures\": [\n        {\n          \"created\": \"\",\n          \"feature\": {\n            \"created\": \"\",\n            \"description\": \"\",\n            \"id\": 0,\n            \"lastUpdate\": \"\",\n            \"name\": \"\"\n          },\n          \"id\": 0,\n          \"lastUpdate\": \"\"\n        }\n      ],\n      \"groupType\": {\n        \"created\": \"\",\n        \"description\": \"\",\n        \"descriptionFriendly\": \"\",\n        \"displayOrder\": 0,\n        \"id\": 0,\n        \"lastUpdate\": \"\",\n        \"lookupType\": {},\n        \"value\": \"\"\n      },\n      \"id\": 0,\n      \"lastImportDate\": \"\",\n      \"lastUpdate\": \"\",\n      \"links\": [\n        {\n          \"created\": \"\",\n          \"displayOrder\": 0,\n          \"id\": 0,\n          \"lastUpdate\": \"\",\n          \"link\": \"\",\n          \"linkType\": {},\n          \"name\": \"\"\n        }\n      ],\n      \"locations\": [\n        {\n          \"address\": \"\",\n          \"created\": \"\",\n          \"email\": \"\",\n          \"id\": 0,\n          \"label\": \"\",\n          \"lastUpdate\": \"\",\n          \"name\": \"\",\n          \"phone\": \"\",\n          \"web\": \"\"\n        }\n      ],\n      \"name\": \"\",\n      \"parentGroups\": [],\n      \"postcode\": \"\",\n      \"sftpUser\": \"\",\n      \"shortName\": \"\",\n      \"visible\": false,\n      \"visibleToJoin\": false\n    },\n    \"id\": 0,\n    \"identifier\": \"\",\n    \"links\": [\n      {}\n    ],\n    \"notes\": \"\",\n    \"severity\": \"\",\n    \"status\": \"\"\n  },\n  \"encounters\": [\n    {\n      \"date\": \"\",\n      \"encounterType\": \"\",\n      \"group\": {},\n      \"id\": 0,\n      \"identifier\": \"\",\n      \"links\": [\n        {}\n      ],\n      \"observations\": [\n        {\n          \"applies\": \"\",\n          \"bodySite\": \"\",\n          \"comments\": \"\",\n          \"comparator\": \"\",\n          \"diagram\": \"\",\n          \"group\": {},\n          \"id\": 0,\n          \"identifier\": \"\",\n          \"location\": \"\",\n          \"name\": \"\",\n          \"temporaryUuid\": \"\",\n          \"units\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"procedures\": [\n        {\n          \"bodySite\": \"\",\n          \"id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"status\": \"\"\n    }\n  ],\n  \"groupCode\": \"\",\n  \"identifier\": \"\",\n  \"observations\": [\n    {}\n  ],\n  \"patient\": {\n    \"address1\": \"\",\n    \"address2\": \"\",\n    \"address3\": \"\",\n    \"address4\": \"\",\n    \"contacts\": [\n      {\n        \"id\": 0,\n        \"system\": \"\",\n        \"use\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"dateOfBirth\": \"\",\n    \"dateOfBirthNoTime\": \"\",\n    \"forename\": \"\",\n    \"gender\": \"\",\n    \"group\": {},\n    \"groupCode\": \"\",\n    \"identifier\": \"\",\n    \"identifiers\": [\n      {\n        \"id\": 0,\n        \"label\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"postcode\": \"\",\n    \"practitioners\": [\n      {\n        \"address1\": \"\",\n        \"address2\": \"\",\n        \"address3\": \"\",\n        \"address4\": \"\",\n        \"allowInviteGp\": false,\n        \"contacts\": [\n          {}\n        ],\n        \"gender\": \"\",\n        \"groupCode\": \"\",\n        \"identifier\": \"\",\n        \"inviteDate\": \"\",\n        \"name\": \"\",\n        \"postcode\": \"\",\n        \"role\": \"\"\n      }\n    ],\n    \"surname\": \"\"\n  },\n  \"practitioners\": [\n    {}\n  ]\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/patientmanagement/:userId/group/:groupId/identifier/:identifierId/surgeries"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"condition\": {\n    \"asserter\": \"\",\n    \"category\": \"\",\n    \"code\": \"\",\n    \"date\": \"\",\n    \"description\": \"\",\n    \"fullDescription\": \"\",\n    \"group\": {\n      \"address1\": \"\",\n      \"address2\": \"\",\n      \"address3\": \"\",\n      \"childGroups\": [],\n      \"code\": \"\",\n      \"contactPoints\": [\n        {\n          \"contactPointType\": {\n            \"description\": \"\",\n            \"id\": 0,\n            \"lookupType\": {\n              \"created\": \"\",\n              \"description\": \"\",\n              \"id\": 0,\n              \"lastUpdate\": \"\",\n              \"type\": \"\"\n            },\n            \"value\": \"\"\n          },\n          \"content\": \"\",\n          \"created\": \"\",\n          \"id\": 0,\n          \"lastUpdate\": \"\"\n        }\n      ],\n      \"created\": \"\",\n      \"fhirResourceId\": \"\",\n      \"groupFeatures\": [\n        {\n          \"created\": \"\",\n          \"feature\": {\n            \"created\": \"\",\n            \"description\": \"\",\n            \"id\": 0,\n            \"lastUpdate\": \"\",\n            \"name\": \"\"\n          },\n          \"id\": 0,\n          \"lastUpdate\": \"\"\n        }\n      ],\n      \"groupType\": {\n        \"created\": \"\",\n        \"description\": \"\",\n        \"descriptionFriendly\": \"\",\n        \"displayOrder\": 0,\n        \"id\": 0,\n        \"lastUpdate\": \"\",\n        \"lookupType\": {},\n        \"value\": \"\"\n      },\n      \"id\": 0,\n      \"lastImportDate\": \"\",\n      \"lastUpdate\": \"\",\n      \"links\": [\n        {\n          \"created\": \"\",\n          \"displayOrder\": 0,\n          \"id\": 0,\n          \"lastUpdate\": \"\",\n          \"link\": \"\",\n          \"linkType\": {},\n          \"name\": \"\"\n        }\n      ],\n      \"locations\": [\n        {\n          \"address\": \"\",\n          \"created\": \"\",\n          \"email\": \"\",\n          \"id\": 0,\n          \"label\": \"\",\n          \"lastUpdate\": \"\",\n          \"name\": \"\",\n          \"phone\": \"\",\n          \"web\": \"\"\n        }\n      ],\n      \"name\": \"\",\n      \"parentGroups\": [],\n      \"postcode\": \"\",\n      \"sftpUser\": \"\",\n      \"shortName\": \"\",\n      \"visible\": false,\n      \"visibleToJoin\": false\n    },\n    \"id\": 0,\n    \"identifier\": \"\",\n    \"links\": [\n      {}\n    ],\n    \"notes\": \"\",\n    \"severity\": \"\",\n    \"status\": \"\"\n  },\n  \"encounters\": [\n    {\n      \"date\": \"\",\n      \"encounterType\": \"\",\n      \"group\": {},\n      \"id\": 0,\n      \"identifier\": \"\",\n      \"links\": [\n        {}\n      ],\n      \"observations\": [\n        {\n          \"applies\": \"\",\n          \"bodySite\": \"\",\n          \"comments\": \"\",\n          \"comparator\": \"\",\n          \"diagram\": \"\",\n          \"group\": {},\n          \"id\": 0,\n          \"identifier\": \"\",\n          \"location\": \"\",\n          \"name\": \"\",\n          \"temporaryUuid\": \"\",\n          \"units\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"procedures\": [\n        {\n          \"bodySite\": \"\",\n          \"id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"status\": \"\"\n    }\n  ],\n  \"groupCode\": \"\",\n  \"identifier\": \"\",\n  \"observations\": [\n    {}\n  ],\n  \"patient\": {\n    \"address1\": \"\",\n    \"address2\": \"\",\n    \"address3\": \"\",\n    \"address4\": \"\",\n    \"contacts\": [\n      {\n        \"id\": 0,\n        \"system\": \"\",\n        \"use\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"dateOfBirth\": \"\",\n    \"dateOfBirthNoTime\": \"\",\n    \"forename\": \"\",\n    \"gender\": \"\",\n    \"group\": {},\n    \"groupCode\": \"\",\n    \"identifier\": \"\",\n    \"identifiers\": [\n      {\n        \"id\": 0,\n        \"label\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"postcode\": \"\",\n    \"practitioners\": [\n      {\n        \"address1\": \"\",\n        \"address2\": \"\",\n        \"address3\": \"\",\n        \"address4\": \"\",\n        \"allowInviteGp\": false,\n        \"contacts\": [\n          {}\n        ],\n        \"gender\": \"\",\n        \"groupCode\": \"\",\n        \"identifier\": \"\",\n        \"inviteDate\": \"\",\n        \"name\": \"\",\n        \"postcode\": \"\",\n        \"role\": \"\"\n      }\n    ],\n    \"surname\": \"\"\n  },\n  \"practitioners\": [\n    {}\n  ]\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"condition\": {\n    \"asserter\": \"\",\n    \"category\": \"\",\n    \"code\": \"\",\n    \"date\": \"\",\n    \"description\": \"\",\n    \"fullDescription\": \"\",\n    \"group\": {\n      \"address1\": \"\",\n      \"address2\": \"\",\n      \"address3\": \"\",\n      \"childGroups\": [],\n      \"code\": \"\",\n      \"contactPoints\": [\n        {\n          \"contactPointType\": {\n            \"description\": \"\",\n            \"id\": 0,\n            \"lookupType\": {\n              \"created\": \"\",\n              \"description\": \"\",\n              \"id\": 0,\n              \"lastUpdate\": \"\",\n              \"type\": \"\"\n            },\n            \"value\": \"\"\n          },\n          \"content\": \"\",\n          \"created\": \"\",\n          \"id\": 0,\n          \"lastUpdate\": \"\"\n        }\n      ],\n      \"created\": \"\",\n      \"fhirResourceId\": \"\",\n      \"groupFeatures\": [\n        {\n          \"created\": \"\",\n          \"feature\": {\n            \"created\": \"\",\n            \"description\": \"\",\n            \"id\": 0,\n            \"lastUpdate\": \"\",\n            \"name\": \"\"\n          },\n          \"id\": 0,\n          \"lastUpdate\": \"\"\n        }\n      ],\n      \"groupType\": {\n        \"created\": \"\",\n        \"description\": \"\",\n        \"descriptionFriendly\": \"\",\n        \"displayOrder\": 0,\n        \"id\": 0,\n        \"lastUpdate\": \"\",\n        \"lookupType\": {},\n        \"value\": \"\"\n      },\n      \"id\": 0,\n      \"lastImportDate\": \"\",\n      \"lastUpdate\": \"\",\n      \"links\": [\n        {\n          \"created\": \"\",\n          \"displayOrder\": 0,\n          \"id\": 0,\n          \"lastUpdate\": \"\",\n          \"link\": \"\",\n          \"linkType\": {},\n          \"name\": \"\"\n        }\n      ],\n      \"locations\": [\n        {\n          \"address\": \"\",\n          \"created\": \"\",\n          \"email\": \"\",\n          \"id\": 0,\n          \"label\": \"\",\n          \"lastUpdate\": \"\",\n          \"name\": \"\",\n          \"phone\": \"\",\n          \"web\": \"\"\n        }\n      ],\n      \"name\": \"\",\n      \"parentGroups\": [],\n      \"postcode\": \"\",\n      \"sftpUser\": \"\",\n      \"shortName\": \"\",\n      \"visible\": false,\n      \"visibleToJoin\": false\n    },\n    \"id\": 0,\n    \"identifier\": \"\",\n    \"links\": [\n      {}\n    ],\n    \"notes\": \"\",\n    \"severity\": \"\",\n    \"status\": \"\"\n  },\n  \"encounters\": [\n    {\n      \"date\": \"\",\n      \"encounterType\": \"\",\n      \"group\": {},\n      \"id\": 0,\n      \"identifier\": \"\",\n      \"links\": [\n        {}\n      ],\n      \"observations\": [\n        {\n          \"applies\": \"\",\n          \"bodySite\": \"\",\n          \"comments\": \"\",\n          \"comparator\": \"\",\n          \"diagram\": \"\",\n          \"group\": {},\n          \"id\": 0,\n          \"identifier\": \"\",\n          \"location\": \"\",\n          \"name\": \"\",\n          \"temporaryUuid\": \"\",\n          \"units\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"procedures\": [\n        {\n          \"bodySite\": \"\",\n          \"id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"status\": \"\"\n    }\n  ],\n  \"groupCode\": \"\",\n  \"identifier\": \"\",\n  \"observations\": [\n    {}\n  ],\n  \"patient\": {\n    \"address1\": \"\",\n    \"address2\": \"\",\n    \"address3\": \"\",\n    \"address4\": \"\",\n    \"contacts\": [\n      {\n        \"id\": 0,\n        \"system\": \"\",\n        \"use\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"dateOfBirth\": \"\",\n    \"dateOfBirthNoTime\": \"\",\n    \"forename\": \"\",\n    \"gender\": \"\",\n    \"group\": {},\n    \"groupCode\": \"\",\n    \"identifier\": \"\",\n    \"identifiers\": [\n      {\n        \"id\": 0,\n        \"label\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"postcode\": \"\",\n    \"practitioners\": [\n      {\n        \"address1\": \"\",\n        \"address2\": \"\",\n        \"address3\": \"\",\n        \"address4\": \"\",\n        \"allowInviteGp\": false,\n        \"contacts\": [\n          {}\n        ],\n        \"gender\": \"\",\n        \"groupCode\": \"\",\n        \"identifier\": \"\",\n        \"inviteDate\": \"\",\n        \"name\": \"\",\n        \"postcode\": \"\",\n        \"role\": \"\"\n      }\n    ],\n    \"surname\": \"\"\n  },\n  \"practitioners\": [\n    {}\n  ]\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/patientmanagement/:userId/group/:groupId/identifier/:identifierId/surgeries")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/patientmanagement/:userId/group/:groupId/identifier/:identifierId/surgeries")
  .header("content-type", "application/json")
  .body("{\n  \"condition\": {\n    \"asserter\": \"\",\n    \"category\": \"\",\n    \"code\": \"\",\n    \"date\": \"\",\n    \"description\": \"\",\n    \"fullDescription\": \"\",\n    \"group\": {\n      \"address1\": \"\",\n      \"address2\": \"\",\n      \"address3\": \"\",\n      \"childGroups\": [],\n      \"code\": \"\",\n      \"contactPoints\": [\n        {\n          \"contactPointType\": {\n            \"description\": \"\",\n            \"id\": 0,\n            \"lookupType\": {\n              \"created\": \"\",\n              \"description\": \"\",\n              \"id\": 0,\n              \"lastUpdate\": \"\",\n              \"type\": \"\"\n            },\n            \"value\": \"\"\n          },\n          \"content\": \"\",\n          \"created\": \"\",\n          \"id\": 0,\n          \"lastUpdate\": \"\"\n        }\n      ],\n      \"created\": \"\",\n      \"fhirResourceId\": \"\",\n      \"groupFeatures\": [\n        {\n          \"created\": \"\",\n          \"feature\": {\n            \"created\": \"\",\n            \"description\": \"\",\n            \"id\": 0,\n            \"lastUpdate\": \"\",\n            \"name\": \"\"\n          },\n          \"id\": 0,\n          \"lastUpdate\": \"\"\n        }\n      ],\n      \"groupType\": {\n        \"created\": \"\",\n        \"description\": \"\",\n        \"descriptionFriendly\": \"\",\n        \"displayOrder\": 0,\n        \"id\": 0,\n        \"lastUpdate\": \"\",\n        \"lookupType\": {},\n        \"value\": \"\"\n      },\n      \"id\": 0,\n      \"lastImportDate\": \"\",\n      \"lastUpdate\": \"\",\n      \"links\": [\n        {\n          \"created\": \"\",\n          \"displayOrder\": 0,\n          \"id\": 0,\n          \"lastUpdate\": \"\",\n          \"link\": \"\",\n          \"linkType\": {},\n          \"name\": \"\"\n        }\n      ],\n      \"locations\": [\n        {\n          \"address\": \"\",\n          \"created\": \"\",\n          \"email\": \"\",\n          \"id\": 0,\n          \"label\": \"\",\n          \"lastUpdate\": \"\",\n          \"name\": \"\",\n          \"phone\": \"\",\n          \"web\": \"\"\n        }\n      ],\n      \"name\": \"\",\n      \"parentGroups\": [],\n      \"postcode\": \"\",\n      \"sftpUser\": \"\",\n      \"shortName\": \"\",\n      \"visible\": false,\n      \"visibleToJoin\": false\n    },\n    \"id\": 0,\n    \"identifier\": \"\",\n    \"links\": [\n      {}\n    ],\n    \"notes\": \"\",\n    \"severity\": \"\",\n    \"status\": \"\"\n  },\n  \"encounters\": [\n    {\n      \"date\": \"\",\n      \"encounterType\": \"\",\n      \"group\": {},\n      \"id\": 0,\n      \"identifier\": \"\",\n      \"links\": [\n        {}\n      ],\n      \"observations\": [\n        {\n          \"applies\": \"\",\n          \"bodySite\": \"\",\n          \"comments\": \"\",\n          \"comparator\": \"\",\n          \"diagram\": \"\",\n          \"group\": {},\n          \"id\": 0,\n          \"identifier\": \"\",\n          \"location\": \"\",\n          \"name\": \"\",\n          \"temporaryUuid\": \"\",\n          \"units\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"procedures\": [\n        {\n          \"bodySite\": \"\",\n          \"id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"status\": \"\"\n    }\n  ],\n  \"groupCode\": \"\",\n  \"identifier\": \"\",\n  \"observations\": [\n    {}\n  ],\n  \"patient\": {\n    \"address1\": \"\",\n    \"address2\": \"\",\n    \"address3\": \"\",\n    \"address4\": \"\",\n    \"contacts\": [\n      {\n        \"id\": 0,\n        \"system\": \"\",\n        \"use\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"dateOfBirth\": \"\",\n    \"dateOfBirthNoTime\": \"\",\n    \"forename\": \"\",\n    \"gender\": \"\",\n    \"group\": {},\n    \"groupCode\": \"\",\n    \"identifier\": \"\",\n    \"identifiers\": [\n      {\n        \"id\": 0,\n        \"label\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"postcode\": \"\",\n    \"practitioners\": [\n      {\n        \"address1\": \"\",\n        \"address2\": \"\",\n        \"address3\": \"\",\n        \"address4\": \"\",\n        \"allowInviteGp\": false,\n        \"contacts\": [\n          {}\n        ],\n        \"gender\": \"\",\n        \"groupCode\": \"\",\n        \"identifier\": \"\",\n        \"inviteDate\": \"\",\n        \"name\": \"\",\n        \"postcode\": \"\",\n        \"role\": \"\"\n      }\n    ],\n    \"surname\": \"\"\n  },\n  \"practitioners\": [\n    {}\n  ]\n}")
  .asString();
const data = JSON.stringify({
  condition: {
    asserter: '',
    category: '',
    code: '',
    date: '',
    description: '',
    fullDescription: '',
    group: {
      address1: '',
      address2: '',
      address3: '',
      childGroups: [],
      code: '',
      contactPoints: [
        {
          contactPointType: {
            description: '',
            id: 0,
            lookupType: {
              created: '',
              description: '',
              id: 0,
              lastUpdate: '',
              type: ''
            },
            value: ''
          },
          content: '',
          created: '',
          id: 0,
          lastUpdate: ''
        }
      ],
      created: '',
      fhirResourceId: '',
      groupFeatures: [
        {
          created: '',
          feature: {
            created: '',
            description: '',
            id: 0,
            lastUpdate: '',
            name: ''
          },
          id: 0,
          lastUpdate: ''
        }
      ],
      groupType: {
        created: '',
        description: '',
        descriptionFriendly: '',
        displayOrder: 0,
        id: 0,
        lastUpdate: '',
        lookupType: {},
        value: ''
      },
      id: 0,
      lastImportDate: '',
      lastUpdate: '',
      links: [
        {
          created: '',
          displayOrder: 0,
          id: 0,
          lastUpdate: '',
          link: '',
          linkType: {},
          name: ''
        }
      ],
      locations: [
        {
          address: '',
          created: '',
          email: '',
          id: 0,
          label: '',
          lastUpdate: '',
          name: '',
          phone: '',
          web: ''
        }
      ],
      name: '',
      parentGroups: [],
      postcode: '',
      sftpUser: '',
      shortName: '',
      visible: false,
      visibleToJoin: false
    },
    id: 0,
    identifier: '',
    links: [
      {}
    ],
    notes: '',
    severity: '',
    status: ''
  },
  encounters: [
    {
      date: '',
      encounterType: '',
      group: {},
      id: 0,
      identifier: '',
      links: [
        {}
      ],
      observations: [
        {
          applies: '',
          bodySite: '',
          comments: '',
          comparator: '',
          diagram: '',
          group: {},
          id: 0,
          identifier: '',
          location: '',
          name: '',
          temporaryUuid: '',
          units: '',
          value: ''
        }
      ],
      procedures: [
        {
          bodySite: '',
          id: 0,
          type: ''
        }
      ],
      status: ''
    }
  ],
  groupCode: '',
  identifier: '',
  observations: [
    {}
  ],
  patient: {
    address1: '',
    address2: '',
    address3: '',
    address4: '',
    contacts: [
      {
        id: 0,
        system: '',
        use: '',
        value: ''
      }
    ],
    dateOfBirth: '',
    dateOfBirthNoTime: '',
    forename: '',
    gender: '',
    group: {},
    groupCode: '',
    identifier: '',
    identifiers: [
      {
        id: 0,
        label: '',
        value: ''
      }
    ],
    postcode: '',
    practitioners: [
      {
        address1: '',
        address2: '',
        address3: '',
        address4: '',
        allowInviteGp: false,
        contacts: [
          {}
        ],
        gender: '',
        groupCode: '',
        identifier: '',
        inviteDate: '',
        name: '',
        postcode: '',
        role: ''
      }
    ],
    surname: ''
  },
  practitioners: [
    {}
  ]
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/patientmanagement/:userId/group/:groupId/identifier/:identifierId/surgeries');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/patientmanagement/:userId/group/:groupId/identifier/:identifierId/surgeries',
  headers: {'content-type': 'application/json'},
  data: {
    condition: {
      asserter: '',
      category: '',
      code: '',
      date: '',
      description: '',
      fullDescription: '',
      group: {
        address1: '',
        address2: '',
        address3: '',
        childGroups: [],
        code: '',
        contactPoints: [
          {
            contactPointType: {
              description: '',
              id: 0,
              lookupType: {created: '', description: '', id: 0, lastUpdate: '', type: ''},
              value: ''
            },
            content: '',
            created: '',
            id: 0,
            lastUpdate: ''
          }
        ],
        created: '',
        fhirResourceId: '',
        groupFeatures: [
          {
            created: '',
            feature: {created: '', description: '', id: 0, lastUpdate: '', name: ''},
            id: 0,
            lastUpdate: ''
          }
        ],
        groupType: {
          created: '',
          description: '',
          descriptionFriendly: '',
          displayOrder: 0,
          id: 0,
          lastUpdate: '',
          lookupType: {},
          value: ''
        },
        id: 0,
        lastImportDate: '',
        lastUpdate: '',
        links: [
          {
            created: '',
            displayOrder: 0,
            id: 0,
            lastUpdate: '',
            link: '',
            linkType: {},
            name: ''
          }
        ],
        locations: [
          {
            address: '',
            created: '',
            email: '',
            id: 0,
            label: '',
            lastUpdate: '',
            name: '',
            phone: '',
            web: ''
          }
        ],
        name: '',
        parentGroups: [],
        postcode: '',
        sftpUser: '',
        shortName: '',
        visible: false,
        visibleToJoin: false
      },
      id: 0,
      identifier: '',
      links: [{}],
      notes: '',
      severity: '',
      status: ''
    },
    encounters: [
      {
        date: '',
        encounterType: '',
        group: {},
        id: 0,
        identifier: '',
        links: [{}],
        observations: [
          {
            applies: '',
            bodySite: '',
            comments: '',
            comparator: '',
            diagram: '',
            group: {},
            id: 0,
            identifier: '',
            location: '',
            name: '',
            temporaryUuid: '',
            units: '',
            value: ''
          }
        ],
        procedures: [{bodySite: '', id: 0, type: ''}],
        status: ''
      }
    ],
    groupCode: '',
    identifier: '',
    observations: [{}],
    patient: {
      address1: '',
      address2: '',
      address3: '',
      address4: '',
      contacts: [{id: 0, system: '', use: '', value: ''}],
      dateOfBirth: '',
      dateOfBirthNoTime: '',
      forename: '',
      gender: '',
      group: {},
      groupCode: '',
      identifier: '',
      identifiers: [{id: 0, label: '', value: ''}],
      postcode: '',
      practitioners: [
        {
          address1: '',
          address2: '',
          address3: '',
          address4: '',
          allowInviteGp: false,
          contacts: [{}],
          gender: '',
          groupCode: '',
          identifier: '',
          inviteDate: '',
          name: '',
          postcode: '',
          role: ''
        }
      ],
      surname: ''
    },
    practitioners: [{}]
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/patientmanagement/:userId/group/:groupId/identifier/:identifierId/surgeries';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"condition":{"asserter":"","category":"","code":"","date":"","description":"","fullDescription":"","group":{"address1":"","address2":"","address3":"","childGroups":[],"code":"","contactPoints":[{"contactPointType":{"description":"","id":0,"lookupType":{"created":"","description":"","id":0,"lastUpdate":"","type":""},"value":""},"content":"","created":"","id":0,"lastUpdate":""}],"created":"","fhirResourceId":"","groupFeatures":[{"created":"","feature":{"created":"","description":"","id":0,"lastUpdate":"","name":""},"id":0,"lastUpdate":""}],"groupType":{"created":"","description":"","descriptionFriendly":"","displayOrder":0,"id":0,"lastUpdate":"","lookupType":{},"value":""},"id":0,"lastImportDate":"","lastUpdate":"","links":[{"created":"","displayOrder":0,"id":0,"lastUpdate":"","link":"","linkType":{},"name":""}],"locations":[{"address":"","created":"","email":"","id":0,"label":"","lastUpdate":"","name":"","phone":"","web":""}],"name":"","parentGroups":[],"postcode":"","sftpUser":"","shortName":"","visible":false,"visibleToJoin":false},"id":0,"identifier":"","links":[{}],"notes":"","severity":"","status":""},"encounters":[{"date":"","encounterType":"","group":{},"id":0,"identifier":"","links":[{}],"observations":[{"applies":"","bodySite":"","comments":"","comparator":"","diagram":"","group":{},"id":0,"identifier":"","location":"","name":"","temporaryUuid":"","units":"","value":""}],"procedures":[{"bodySite":"","id":0,"type":""}],"status":""}],"groupCode":"","identifier":"","observations":[{}],"patient":{"address1":"","address2":"","address3":"","address4":"","contacts":[{"id":0,"system":"","use":"","value":""}],"dateOfBirth":"","dateOfBirthNoTime":"","forename":"","gender":"","group":{},"groupCode":"","identifier":"","identifiers":[{"id":0,"label":"","value":""}],"postcode":"","practitioners":[{"address1":"","address2":"","address3":"","address4":"","allowInviteGp":false,"contacts":[{}],"gender":"","groupCode":"","identifier":"","inviteDate":"","name":"","postcode":"","role":""}],"surname":""},"practitioners":[{}]}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/patientmanagement/:userId/group/:groupId/identifier/:identifierId/surgeries',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "condition": {\n    "asserter": "",\n    "category": "",\n    "code": "",\n    "date": "",\n    "description": "",\n    "fullDescription": "",\n    "group": {\n      "address1": "",\n      "address2": "",\n      "address3": "",\n      "childGroups": [],\n      "code": "",\n      "contactPoints": [\n        {\n          "contactPointType": {\n            "description": "",\n            "id": 0,\n            "lookupType": {\n              "created": "",\n              "description": "",\n              "id": 0,\n              "lastUpdate": "",\n              "type": ""\n            },\n            "value": ""\n          },\n          "content": "",\n          "created": "",\n          "id": 0,\n          "lastUpdate": ""\n        }\n      ],\n      "created": "",\n      "fhirResourceId": "",\n      "groupFeatures": [\n        {\n          "created": "",\n          "feature": {\n            "created": "",\n            "description": "",\n            "id": 0,\n            "lastUpdate": "",\n            "name": ""\n          },\n          "id": 0,\n          "lastUpdate": ""\n        }\n      ],\n      "groupType": {\n        "created": "",\n        "description": "",\n        "descriptionFriendly": "",\n        "displayOrder": 0,\n        "id": 0,\n        "lastUpdate": "",\n        "lookupType": {},\n        "value": ""\n      },\n      "id": 0,\n      "lastImportDate": "",\n      "lastUpdate": "",\n      "links": [\n        {\n          "created": "",\n          "displayOrder": 0,\n          "id": 0,\n          "lastUpdate": "",\n          "link": "",\n          "linkType": {},\n          "name": ""\n        }\n      ],\n      "locations": [\n        {\n          "address": "",\n          "created": "",\n          "email": "",\n          "id": 0,\n          "label": "",\n          "lastUpdate": "",\n          "name": "",\n          "phone": "",\n          "web": ""\n        }\n      ],\n      "name": "",\n      "parentGroups": [],\n      "postcode": "",\n      "sftpUser": "",\n      "shortName": "",\n      "visible": false,\n      "visibleToJoin": false\n    },\n    "id": 0,\n    "identifier": "",\n    "links": [\n      {}\n    ],\n    "notes": "",\n    "severity": "",\n    "status": ""\n  },\n  "encounters": [\n    {\n      "date": "",\n      "encounterType": "",\n      "group": {},\n      "id": 0,\n      "identifier": "",\n      "links": [\n        {}\n      ],\n      "observations": [\n        {\n          "applies": "",\n          "bodySite": "",\n          "comments": "",\n          "comparator": "",\n          "diagram": "",\n          "group": {},\n          "id": 0,\n          "identifier": "",\n          "location": "",\n          "name": "",\n          "temporaryUuid": "",\n          "units": "",\n          "value": ""\n        }\n      ],\n      "procedures": [\n        {\n          "bodySite": "",\n          "id": 0,\n          "type": ""\n        }\n      ],\n      "status": ""\n    }\n  ],\n  "groupCode": "",\n  "identifier": "",\n  "observations": [\n    {}\n  ],\n  "patient": {\n    "address1": "",\n    "address2": "",\n    "address3": "",\n    "address4": "",\n    "contacts": [\n      {\n        "id": 0,\n        "system": "",\n        "use": "",\n        "value": ""\n      }\n    ],\n    "dateOfBirth": "",\n    "dateOfBirthNoTime": "",\n    "forename": "",\n    "gender": "",\n    "group": {},\n    "groupCode": "",\n    "identifier": "",\n    "identifiers": [\n      {\n        "id": 0,\n        "label": "",\n        "value": ""\n      }\n    ],\n    "postcode": "",\n    "practitioners": [\n      {\n        "address1": "",\n        "address2": "",\n        "address3": "",\n        "address4": "",\n        "allowInviteGp": false,\n        "contacts": [\n          {}\n        ],\n        "gender": "",\n        "groupCode": "",\n        "identifier": "",\n        "inviteDate": "",\n        "name": "",\n        "postcode": "",\n        "role": ""\n      }\n    ],\n    "surname": ""\n  },\n  "practitioners": [\n    {}\n  ]\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"condition\": {\n    \"asserter\": \"\",\n    \"category\": \"\",\n    \"code\": \"\",\n    \"date\": \"\",\n    \"description\": \"\",\n    \"fullDescription\": \"\",\n    \"group\": {\n      \"address1\": \"\",\n      \"address2\": \"\",\n      \"address3\": \"\",\n      \"childGroups\": [],\n      \"code\": \"\",\n      \"contactPoints\": [\n        {\n          \"contactPointType\": {\n            \"description\": \"\",\n            \"id\": 0,\n            \"lookupType\": {\n              \"created\": \"\",\n              \"description\": \"\",\n              \"id\": 0,\n              \"lastUpdate\": \"\",\n              \"type\": \"\"\n            },\n            \"value\": \"\"\n          },\n          \"content\": \"\",\n          \"created\": \"\",\n          \"id\": 0,\n          \"lastUpdate\": \"\"\n        }\n      ],\n      \"created\": \"\",\n      \"fhirResourceId\": \"\",\n      \"groupFeatures\": [\n        {\n          \"created\": \"\",\n          \"feature\": {\n            \"created\": \"\",\n            \"description\": \"\",\n            \"id\": 0,\n            \"lastUpdate\": \"\",\n            \"name\": \"\"\n          },\n          \"id\": 0,\n          \"lastUpdate\": \"\"\n        }\n      ],\n      \"groupType\": {\n        \"created\": \"\",\n        \"description\": \"\",\n        \"descriptionFriendly\": \"\",\n        \"displayOrder\": 0,\n        \"id\": 0,\n        \"lastUpdate\": \"\",\n        \"lookupType\": {},\n        \"value\": \"\"\n      },\n      \"id\": 0,\n      \"lastImportDate\": \"\",\n      \"lastUpdate\": \"\",\n      \"links\": [\n        {\n          \"created\": \"\",\n          \"displayOrder\": 0,\n          \"id\": 0,\n          \"lastUpdate\": \"\",\n          \"link\": \"\",\n          \"linkType\": {},\n          \"name\": \"\"\n        }\n      ],\n      \"locations\": [\n        {\n          \"address\": \"\",\n          \"created\": \"\",\n          \"email\": \"\",\n          \"id\": 0,\n          \"label\": \"\",\n          \"lastUpdate\": \"\",\n          \"name\": \"\",\n          \"phone\": \"\",\n          \"web\": \"\"\n        }\n      ],\n      \"name\": \"\",\n      \"parentGroups\": [],\n      \"postcode\": \"\",\n      \"sftpUser\": \"\",\n      \"shortName\": \"\",\n      \"visible\": false,\n      \"visibleToJoin\": false\n    },\n    \"id\": 0,\n    \"identifier\": \"\",\n    \"links\": [\n      {}\n    ],\n    \"notes\": \"\",\n    \"severity\": \"\",\n    \"status\": \"\"\n  },\n  \"encounters\": [\n    {\n      \"date\": \"\",\n      \"encounterType\": \"\",\n      \"group\": {},\n      \"id\": 0,\n      \"identifier\": \"\",\n      \"links\": [\n        {}\n      ],\n      \"observations\": [\n        {\n          \"applies\": \"\",\n          \"bodySite\": \"\",\n          \"comments\": \"\",\n          \"comparator\": \"\",\n          \"diagram\": \"\",\n          \"group\": {},\n          \"id\": 0,\n          \"identifier\": \"\",\n          \"location\": \"\",\n          \"name\": \"\",\n          \"temporaryUuid\": \"\",\n          \"units\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"procedures\": [\n        {\n          \"bodySite\": \"\",\n          \"id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"status\": \"\"\n    }\n  ],\n  \"groupCode\": \"\",\n  \"identifier\": \"\",\n  \"observations\": [\n    {}\n  ],\n  \"patient\": {\n    \"address1\": \"\",\n    \"address2\": \"\",\n    \"address3\": \"\",\n    \"address4\": \"\",\n    \"contacts\": [\n      {\n        \"id\": 0,\n        \"system\": \"\",\n        \"use\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"dateOfBirth\": \"\",\n    \"dateOfBirthNoTime\": \"\",\n    \"forename\": \"\",\n    \"gender\": \"\",\n    \"group\": {},\n    \"groupCode\": \"\",\n    \"identifier\": \"\",\n    \"identifiers\": [\n      {\n        \"id\": 0,\n        \"label\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"postcode\": \"\",\n    \"practitioners\": [\n      {\n        \"address1\": \"\",\n        \"address2\": \"\",\n        \"address3\": \"\",\n        \"address4\": \"\",\n        \"allowInviteGp\": false,\n        \"contacts\": [\n          {}\n        ],\n        \"gender\": \"\",\n        \"groupCode\": \"\",\n        \"identifier\": \"\",\n        \"inviteDate\": \"\",\n        \"name\": \"\",\n        \"postcode\": \"\",\n        \"role\": \"\"\n      }\n    ],\n    \"surname\": \"\"\n  },\n  \"practitioners\": [\n    {}\n  ]\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/patientmanagement/:userId/group/:groupId/identifier/:identifierId/surgeries")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/patientmanagement/:userId/group/:groupId/identifier/:identifierId/surgeries',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  condition: {
    asserter: '',
    category: '',
    code: '',
    date: '',
    description: '',
    fullDescription: '',
    group: {
      address1: '',
      address2: '',
      address3: '',
      childGroups: [],
      code: '',
      contactPoints: [
        {
          contactPointType: {
            description: '',
            id: 0,
            lookupType: {created: '', description: '', id: 0, lastUpdate: '', type: ''},
            value: ''
          },
          content: '',
          created: '',
          id: 0,
          lastUpdate: ''
        }
      ],
      created: '',
      fhirResourceId: '',
      groupFeatures: [
        {
          created: '',
          feature: {created: '', description: '', id: 0, lastUpdate: '', name: ''},
          id: 0,
          lastUpdate: ''
        }
      ],
      groupType: {
        created: '',
        description: '',
        descriptionFriendly: '',
        displayOrder: 0,
        id: 0,
        lastUpdate: '',
        lookupType: {},
        value: ''
      },
      id: 0,
      lastImportDate: '',
      lastUpdate: '',
      links: [
        {
          created: '',
          displayOrder: 0,
          id: 0,
          lastUpdate: '',
          link: '',
          linkType: {},
          name: ''
        }
      ],
      locations: [
        {
          address: '',
          created: '',
          email: '',
          id: 0,
          label: '',
          lastUpdate: '',
          name: '',
          phone: '',
          web: ''
        }
      ],
      name: '',
      parentGroups: [],
      postcode: '',
      sftpUser: '',
      shortName: '',
      visible: false,
      visibleToJoin: false
    },
    id: 0,
    identifier: '',
    links: [{}],
    notes: '',
    severity: '',
    status: ''
  },
  encounters: [
    {
      date: '',
      encounterType: '',
      group: {},
      id: 0,
      identifier: '',
      links: [{}],
      observations: [
        {
          applies: '',
          bodySite: '',
          comments: '',
          comparator: '',
          diagram: '',
          group: {},
          id: 0,
          identifier: '',
          location: '',
          name: '',
          temporaryUuid: '',
          units: '',
          value: ''
        }
      ],
      procedures: [{bodySite: '', id: 0, type: ''}],
      status: ''
    }
  ],
  groupCode: '',
  identifier: '',
  observations: [{}],
  patient: {
    address1: '',
    address2: '',
    address3: '',
    address4: '',
    contacts: [{id: 0, system: '', use: '', value: ''}],
    dateOfBirth: '',
    dateOfBirthNoTime: '',
    forename: '',
    gender: '',
    group: {},
    groupCode: '',
    identifier: '',
    identifiers: [{id: 0, label: '', value: ''}],
    postcode: '',
    practitioners: [
      {
        address1: '',
        address2: '',
        address3: '',
        address4: '',
        allowInviteGp: false,
        contacts: [{}],
        gender: '',
        groupCode: '',
        identifier: '',
        inviteDate: '',
        name: '',
        postcode: '',
        role: ''
      }
    ],
    surname: ''
  },
  practitioners: [{}]
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/patientmanagement/:userId/group/:groupId/identifier/:identifierId/surgeries',
  headers: {'content-type': 'application/json'},
  body: {
    condition: {
      asserter: '',
      category: '',
      code: '',
      date: '',
      description: '',
      fullDescription: '',
      group: {
        address1: '',
        address2: '',
        address3: '',
        childGroups: [],
        code: '',
        contactPoints: [
          {
            contactPointType: {
              description: '',
              id: 0,
              lookupType: {created: '', description: '', id: 0, lastUpdate: '', type: ''},
              value: ''
            },
            content: '',
            created: '',
            id: 0,
            lastUpdate: ''
          }
        ],
        created: '',
        fhirResourceId: '',
        groupFeatures: [
          {
            created: '',
            feature: {created: '', description: '', id: 0, lastUpdate: '', name: ''},
            id: 0,
            lastUpdate: ''
          }
        ],
        groupType: {
          created: '',
          description: '',
          descriptionFriendly: '',
          displayOrder: 0,
          id: 0,
          lastUpdate: '',
          lookupType: {},
          value: ''
        },
        id: 0,
        lastImportDate: '',
        lastUpdate: '',
        links: [
          {
            created: '',
            displayOrder: 0,
            id: 0,
            lastUpdate: '',
            link: '',
            linkType: {},
            name: ''
          }
        ],
        locations: [
          {
            address: '',
            created: '',
            email: '',
            id: 0,
            label: '',
            lastUpdate: '',
            name: '',
            phone: '',
            web: ''
          }
        ],
        name: '',
        parentGroups: [],
        postcode: '',
        sftpUser: '',
        shortName: '',
        visible: false,
        visibleToJoin: false
      },
      id: 0,
      identifier: '',
      links: [{}],
      notes: '',
      severity: '',
      status: ''
    },
    encounters: [
      {
        date: '',
        encounterType: '',
        group: {},
        id: 0,
        identifier: '',
        links: [{}],
        observations: [
          {
            applies: '',
            bodySite: '',
            comments: '',
            comparator: '',
            diagram: '',
            group: {},
            id: 0,
            identifier: '',
            location: '',
            name: '',
            temporaryUuid: '',
            units: '',
            value: ''
          }
        ],
        procedures: [{bodySite: '', id: 0, type: ''}],
        status: ''
      }
    ],
    groupCode: '',
    identifier: '',
    observations: [{}],
    patient: {
      address1: '',
      address2: '',
      address3: '',
      address4: '',
      contacts: [{id: 0, system: '', use: '', value: ''}],
      dateOfBirth: '',
      dateOfBirthNoTime: '',
      forename: '',
      gender: '',
      group: {},
      groupCode: '',
      identifier: '',
      identifiers: [{id: 0, label: '', value: ''}],
      postcode: '',
      practitioners: [
        {
          address1: '',
          address2: '',
          address3: '',
          address4: '',
          allowInviteGp: false,
          contacts: [{}],
          gender: '',
          groupCode: '',
          identifier: '',
          inviteDate: '',
          name: '',
          postcode: '',
          role: ''
        }
      ],
      surname: ''
    },
    practitioners: [{}]
  },
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/patientmanagement/:userId/group/:groupId/identifier/:identifierId/surgeries');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  condition: {
    asserter: '',
    category: '',
    code: '',
    date: '',
    description: '',
    fullDescription: '',
    group: {
      address1: '',
      address2: '',
      address3: '',
      childGroups: [],
      code: '',
      contactPoints: [
        {
          contactPointType: {
            description: '',
            id: 0,
            lookupType: {
              created: '',
              description: '',
              id: 0,
              lastUpdate: '',
              type: ''
            },
            value: ''
          },
          content: '',
          created: '',
          id: 0,
          lastUpdate: ''
        }
      ],
      created: '',
      fhirResourceId: '',
      groupFeatures: [
        {
          created: '',
          feature: {
            created: '',
            description: '',
            id: 0,
            lastUpdate: '',
            name: ''
          },
          id: 0,
          lastUpdate: ''
        }
      ],
      groupType: {
        created: '',
        description: '',
        descriptionFriendly: '',
        displayOrder: 0,
        id: 0,
        lastUpdate: '',
        lookupType: {},
        value: ''
      },
      id: 0,
      lastImportDate: '',
      lastUpdate: '',
      links: [
        {
          created: '',
          displayOrder: 0,
          id: 0,
          lastUpdate: '',
          link: '',
          linkType: {},
          name: ''
        }
      ],
      locations: [
        {
          address: '',
          created: '',
          email: '',
          id: 0,
          label: '',
          lastUpdate: '',
          name: '',
          phone: '',
          web: ''
        }
      ],
      name: '',
      parentGroups: [],
      postcode: '',
      sftpUser: '',
      shortName: '',
      visible: false,
      visibleToJoin: false
    },
    id: 0,
    identifier: '',
    links: [
      {}
    ],
    notes: '',
    severity: '',
    status: ''
  },
  encounters: [
    {
      date: '',
      encounterType: '',
      group: {},
      id: 0,
      identifier: '',
      links: [
        {}
      ],
      observations: [
        {
          applies: '',
          bodySite: '',
          comments: '',
          comparator: '',
          diagram: '',
          group: {},
          id: 0,
          identifier: '',
          location: '',
          name: '',
          temporaryUuid: '',
          units: '',
          value: ''
        }
      ],
      procedures: [
        {
          bodySite: '',
          id: 0,
          type: ''
        }
      ],
      status: ''
    }
  ],
  groupCode: '',
  identifier: '',
  observations: [
    {}
  ],
  patient: {
    address1: '',
    address2: '',
    address3: '',
    address4: '',
    contacts: [
      {
        id: 0,
        system: '',
        use: '',
        value: ''
      }
    ],
    dateOfBirth: '',
    dateOfBirthNoTime: '',
    forename: '',
    gender: '',
    group: {},
    groupCode: '',
    identifier: '',
    identifiers: [
      {
        id: 0,
        label: '',
        value: ''
      }
    ],
    postcode: '',
    practitioners: [
      {
        address1: '',
        address2: '',
        address3: '',
        address4: '',
        allowInviteGp: false,
        contacts: [
          {}
        ],
        gender: '',
        groupCode: '',
        identifier: '',
        inviteDate: '',
        name: '',
        postcode: '',
        role: ''
      }
    ],
    surname: ''
  },
  practitioners: [
    {}
  ]
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'POST',
  url: '{{baseUrl}}/patientmanagement/:userId/group/:groupId/identifier/:identifierId/surgeries',
  headers: {'content-type': 'application/json'},
  data: {
    condition: {
      asserter: '',
      category: '',
      code: '',
      date: '',
      description: '',
      fullDescription: '',
      group: {
        address1: '',
        address2: '',
        address3: '',
        childGroups: [],
        code: '',
        contactPoints: [
          {
            contactPointType: {
              description: '',
              id: 0,
              lookupType: {created: '', description: '', id: 0, lastUpdate: '', type: ''},
              value: ''
            },
            content: '',
            created: '',
            id: 0,
            lastUpdate: ''
          }
        ],
        created: '',
        fhirResourceId: '',
        groupFeatures: [
          {
            created: '',
            feature: {created: '', description: '', id: 0, lastUpdate: '', name: ''},
            id: 0,
            lastUpdate: ''
          }
        ],
        groupType: {
          created: '',
          description: '',
          descriptionFriendly: '',
          displayOrder: 0,
          id: 0,
          lastUpdate: '',
          lookupType: {},
          value: ''
        },
        id: 0,
        lastImportDate: '',
        lastUpdate: '',
        links: [
          {
            created: '',
            displayOrder: 0,
            id: 0,
            lastUpdate: '',
            link: '',
            linkType: {},
            name: ''
          }
        ],
        locations: [
          {
            address: '',
            created: '',
            email: '',
            id: 0,
            label: '',
            lastUpdate: '',
            name: '',
            phone: '',
            web: ''
          }
        ],
        name: '',
        parentGroups: [],
        postcode: '',
        sftpUser: '',
        shortName: '',
        visible: false,
        visibleToJoin: false
      },
      id: 0,
      identifier: '',
      links: [{}],
      notes: '',
      severity: '',
      status: ''
    },
    encounters: [
      {
        date: '',
        encounterType: '',
        group: {},
        id: 0,
        identifier: '',
        links: [{}],
        observations: [
          {
            applies: '',
            bodySite: '',
            comments: '',
            comparator: '',
            diagram: '',
            group: {},
            id: 0,
            identifier: '',
            location: '',
            name: '',
            temporaryUuid: '',
            units: '',
            value: ''
          }
        ],
        procedures: [{bodySite: '', id: 0, type: ''}],
        status: ''
      }
    ],
    groupCode: '',
    identifier: '',
    observations: [{}],
    patient: {
      address1: '',
      address2: '',
      address3: '',
      address4: '',
      contacts: [{id: 0, system: '', use: '', value: ''}],
      dateOfBirth: '',
      dateOfBirthNoTime: '',
      forename: '',
      gender: '',
      group: {},
      groupCode: '',
      identifier: '',
      identifiers: [{id: 0, label: '', value: ''}],
      postcode: '',
      practitioners: [
        {
          address1: '',
          address2: '',
          address3: '',
          address4: '',
          allowInviteGp: false,
          contacts: [{}],
          gender: '',
          groupCode: '',
          identifier: '',
          inviteDate: '',
          name: '',
          postcode: '',
          role: ''
        }
      ],
      surname: ''
    },
    practitioners: [{}]
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/patientmanagement/:userId/group/:groupId/identifier/:identifierId/surgeries';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"condition":{"asserter":"","category":"","code":"","date":"","description":"","fullDescription":"","group":{"address1":"","address2":"","address3":"","childGroups":[],"code":"","contactPoints":[{"contactPointType":{"description":"","id":0,"lookupType":{"created":"","description":"","id":0,"lastUpdate":"","type":""},"value":""},"content":"","created":"","id":0,"lastUpdate":""}],"created":"","fhirResourceId":"","groupFeatures":[{"created":"","feature":{"created":"","description":"","id":0,"lastUpdate":"","name":""},"id":0,"lastUpdate":""}],"groupType":{"created":"","description":"","descriptionFriendly":"","displayOrder":0,"id":0,"lastUpdate":"","lookupType":{},"value":""},"id":0,"lastImportDate":"","lastUpdate":"","links":[{"created":"","displayOrder":0,"id":0,"lastUpdate":"","link":"","linkType":{},"name":""}],"locations":[{"address":"","created":"","email":"","id":0,"label":"","lastUpdate":"","name":"","phone":"","web":""}],"name":"","parentGroups":[],"postcode":"","sftpUser":"","shortName":"","visible":false,"visibleToJoin":false},"id":0,"identifier":"","links":[{}],"notes":"","severity":"","status":""},"encounters":[{"date":"","encounterType":"","group":{},"id":0,"identifier":"","links":[{}],"observations":[{"applies":"","bodySite":"","comments":"","comparator":"","diagram":"","group":{},"id":0,"identifier":"","location":"","name":"","temporaryUuid":"","units":"","value":""}],"procedures":[{"bodySite":"","id":0,"type":""}],"status":""}],"groupCode":"","identifier":"","observations":[{}],"patient":{"address1":"","address2":"","address3":"","address4":"","contacts":[{"id":0,"system":"","use":"","value":""}],"dateOfBirth":"","dateOfBirthNoTime":"","forename":"","gender":"","group":{},"groupCode":"","identifier":"","identifiers":[{"id":0,"label":"","value":""}],"postcode":"","practitioners":[{"address1":"","address2":"","address3":"","address4":"","allowInviteGp":false,"contacts":[{}],"gender":"","groupCode":"","identifier":"","inviteDate":"","name":"","postcode":"","role":""}],"surname":""},"practitioners":[{}]}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"condition": @{ @"asserter": @"", @"category": @"", @"code": @"", @"date": @"", @"description": @"", @"fullDescription": @"", @"group": @{ @"address1": @"", @"address2": @"", @"address3": @"", @"childGroups": @[  ], @"code": @"", @"contactPoints": @[ @{ @"contactPointType": @{ @"description": @"", @"id": @0, @"lookupType": @{ @"created": @"", @"description": @"", @"id": @0, @"lastUpdate": @"", @"type": @"" }, @"value": @"" }, @"content": @"", @"created": @"", @"id": @0, @"lastUpdate": @"" } ], @"created": @"", @"fhirResourceId": @"", @"groupFeatures": @[ @{ @"created": @"", @"feature": @{ @"created": @"", @"description": @"", @"id": @0, @"lastUpdate": @"", @"name": @"" }, @"id": @0, @"lastUpdate": @"" } ], @"groupType": @{ @"created": @"", @"description": @"", @"descriptionFriendly": @"", @"displayOrder": @0, @"id": @0, @"lastUpdate": @"", @"lookupType": @{  }, @"value": @"" }, @"id": @0, @"lastImportDate": @"", @"lastUpdate": @"", @"links": @[ @{ @"created": @"", @"displayOrder": @0, @"id": @0, @"lastUpdate": @"", @"link": @"", @"linkType": @{  }, @"name": @"" } ], @"locations": @[ @{ @"address": @"", @"created": @"", @"email": @"", @"id": @0, @"label": @"", @"lastUpdate": @"", @"name": @"", @"phone": @"", @"web": @"" } ], @"name": @"", @"parentGroups": @[  ], @"postcode": @"", @"sftpUser": @"", @"shortName": @"", @"visible": @NO, @"visibleToJoin": @NO }, @"id": @0, @"identifier": @"", @"links": @[ @{  } ], @"notes": @"", @"severity": @"", @"status": @"" },
                              @"encounters": @[ @{ @"date": @"", @"encounterType": @"", @"group": @{  }, @"id": @0, @"identifier": @"", @"links": @[ @{  } ], @"observations": @[ @{ @"applies": @"", @"bodySite": @"", @"comments": @"", @"comparator": @"", @"diagram": @"", @"group": @{  }, @"id": @0, @"identifier": @"", @"location": @"", @"name": @"", @"temporaryUuid": @"", @"units": @"", @"value": @"" } ], @"procedures": @[ @{ @"bodySite": @"", @"id": @0, @"type": @"" } ], @"status": @"" } ],
                              @"groupCode": @"",
                              @"identifier": @"",
                              @"observations": @[ @{  } ],
                              @"patient": @{ @"address1": @"", @"address2": @"", @"address3": @"", @"address4": @"", @"contacts": @[ @{ @"id": @0, @"system": @"", @"use": @"", @"value": @"" } ], @"dateOfBirth": @"", @"dateOfBirthNoTime": @"", @"forename": @"", @"gender": @"", @"group": @{  }, @"groupCode": @"", @"identifier": @"", @"identifiers": @[ @{ @"id": @0, @"label": @"", @"value": @"" } ], @"postcode": @"", @"practitioners": @[ @{ @"address1": @"", @"address2": @"", @"address3": @"", @"address4": @"", @"allowInviteGp": @NO, @"contacts": @[ @{  } ], @"gender": @"", @"groupCode": @"", @"identifier": @"", @"inviteDate": @"", @"name": @"", @"postcode": @"", @"role": @"" } ], @"surname": @"" },
                              @"practitioners": @[ @{  } ] };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/patientmanagement/:userId/group/:groupId/identifier/:identifierId/surgeries"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/patientmanagement/:userId/group/:groupId/identifier/:identifierId/surgeries" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"condition\": {\n    \"asserter\": \"\",\n    \"category\": \"\",\n    \"code\": \"\",\n    \"date\": \"\",\n    \"description\": \"\",\n    \"fullDescription\": \"\",\n    \"group\": {\n      \"address1\": \"\",\n      \"address2\": \"\",\n      \"address3\": \"\",\n      \"childGroups\": [],\n      \"code\": \"\",\n      \"contactPoints\": [\n        {\n          \"contactPointType\": {\n            \"description\": \"\",\n            \"id\": 0,\n            \"lookupType\": {\n              \"created\": \"\",\n              \"description\": \"\",\n              \"id\": 0,\n              \"lastUpdate\": \"\",\n              \"type\": \"\"\n            },\n            \"value\": \"\"\n          },\n          \"content\": \"\",\n          \"created\": \"\",\n          \"id\": 0,\n          \"lastUpdate\": \"\"\n        }\n      ],\n      \"created\": \"\",\n      \"fhirResourceId\": \"\",\n      \"groupFeatures\": [\n        {\n          \"created\": \"\",\n          \"feature\": {\n            \"created\": \"\",\n            \"description\": \"\",\n            \"id\": 0,\n            \"lastUpdate\": \"\",\n            \"name\": \"\"\n          },\n          \"id\": 0,\n          \"lastUpdate\": \"\"\n        }\n      ],\n      \"groupType\": {\n        \"created\": \"\",\n        \"description\": \"\",\n        \"descriptionFriendly\": \"\",\n        \"displayOrder\": 0,\n        \"id\": 0,\n        \"lastUpdate\": \"\",\n        \"lookupType\": {},\n        \"value\": \"\"\n      },\n      \"id\": 0,\n      \"lastImportDate\": \"\",\n      \"lastUpdate\": \"\",\n      \"links\": [\n        {\n          \"created\": \"\",\n          \"displayOrder\": 0,\n          \"id\": 0,\n          \"lastUpdate\": \"\",\n          \"link\": \"\",\n          \"linkType\": {},\n          \"name\": \"\"\n        }\n      ],\n      \"locations\": [\n        {\n          \"address\": \"\",\n          \"created\": \"\",\n          \"email\": \"\",\n          \"id\": 0,\n          \"label\": \"\",\n          \"lastUpdate\": \"\",\n          \"name\": \"\",\n          \"phone\": \"\",\n          \"web\": \"\"\n        }\n      ],\n      \"name\": \"\",\n      \"parentGroups\": [],\n      \"postcode\": \"\",\n      \"sftpUser\": \"\",\n      \"shortName\": \"\",\n      \"visible\": false,\n      \"visibleToJoin\": false\n    },\n    \"id\": 0,\n    \"identifier\": \"\",\n    \"links\": [\n      {}\n    ],\n    \"notes\": \"\",\n    \"severity\": \"\",\n    \"status\": \"\"\n  },\n  \"encounters\": [\n    {\n      \"date\": \"\",\n      \"encounterType\": \"\",\n      \"group\": {},\n      \"id\": 0,\n      \"identifier\": \"\",\n      \"links\": [\n        {}\n      ],\n      \"observations\": [\n        {\n          \"applies\": \"\",\n          \"bodySite\": \"\",\n          \"comments\": \"\",\n          \"comparator\": \"\",\n          \"diagram\": \"\",\n          \"group\": {},\n          \"id\": 0,\n          \"identifier\": \"\",\n          \"location\": \"\",\n          \"name\": \"\",\n          \"temporaryUuid\": \"\",\n          \"units\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"procedures\": [\n        {\n          \"bodySite\": \"\",\n          \"id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"status\": \"\"\n    }\n  ],\n  \"groupCode\": \"\",\n  \"identifier\": \"\",\n  \"observations\": [\n    {}\n  ],\n  \"patient\": {\n    \"address1\": \"\",\n    \"address2\": \"\",\n    \"address3\": \"\",\n    \"address4\": \"\",\n    \"contacts\": [\n      {\n        \"id\": 0,\n        \"system\": \"\",\n        \"use\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"dateOfBirth\": \"\",\n    \"dateOfBirthNoTime\": \"\",\n    \"forename\": \"\",\n    \"gender\": \"\",\n    \"group\": {},\n    \"groupCode\": \"\",\n    \"identifier\": \"\",\n    \"identifiers\": [\n      {\n        \"id\": 0,\n        \"label\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"postcode\": \"\",\n    \"practitioners\": [\n      {\n        \"address1\": \"\",\n        \"address2\": \"\",\n        \"address3\": \"\",\n        \"address4\": \"\",\n        \"allowInviteGp\": false,\n        \"contacts\": [\n          {}\n        ],\n        \"gender\": \"\",\n        \"groupCode\": \"\",\n        \"identifier\": \"\",\n        \"inviteDate\": \"\",\n        \"name\": \"\",\n        \"postcode\": \"\",\n        \"role\": \"\"\n      }\n    ],\n    \"surname\": \"\"\n  },\n  \"practitioners\": [\n    {}\n  ]\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/patientmanagement/:userId/group/:groupId/identifier/:identifierId/surgeries",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'condition' => [
        'asserter' => '',
        'category' => '',
        'code' => '',
        'date' => '',
        'description' => '',
        'fullDescription' => '',
        'group' => [
                'address1' => '',
                'address2' => '',
                'address3' => '',
                'childGroups' => [
                                
                ],
                'code' => '',
                'contactPoints' => [
                                [
                                                                'contactPointType' => [
                                                                                                                                'description' => '',
                                                                                                                                'id' => 0,
                                                                                                                                'lookupType' => [
                                                                                                                                                                                                                                                                'created' => '',
                                                                                                                                                                                                                                                                'description' => '',
                                                                                                                                                                                                                                                                'id' => 0,
                                                                                                                                                                                                                                                                'lastUpdate' => '',
                                                                                                                                                                                                                                                                'type' => ''
                                                                                                                                ],
                                                                                                                                'value' => ''
                                                                ],
                                                                'content' => '',
                                                                'created' => '',
                                                                'id' => 0,
                                                                'lastUpdate' => ''
                                ]
                ],
                'created' => '',
                'fhirResourceId' => '',
                'groupFeatures' => [
                                [
                                                                'created' => '',
                                                                'feature' => [
                                                                                                                                'created' => '',
                                                                                                                                'description' => '',
                                                                                                                                'id' => 0,
                                                                                                                                'lastUpdate' => '',
                                                                                                                                'name' => ''
                                                                ],
                                                                'id' => 0,
                                                                'lastUpdate' => ''
                                ]
                ],
                'groupType' => [
                                'created' => '',
                                'description' => '',
                                'descriptionFriendly' => '',
                                'displayOrder' => 0,
                                'id' => 0,
                                'lastUpdate' => '',
                                'lookupType' => [
                                                                
                                ],
                                'value' => ''
                ],
                'id' => 0,
                'lastImportDate' => '',
                'lastUpdate' => '',
                'links' => [
                                [
                                                                'created' => '',
                                                                'displayOrder' => 0,
                                                                'id' => 0,
                                                                'lastUpdate' => '',
                                                                'link' => '',
                                                                'linkType' => [
                                                                                                                                
                                                                ],
                                                                'name' => ''
                                ]
                ],
                'locations' => [
                                [
                                                                'address' => '',
                                                                'created' => '',
                                                                'email' => '',
                                                                'id' => 0,
                                                                'label' => '',
                                                                'lastUpdate' => '',
                                                                'name' => '',
                                                                'phone' => '',
                                                                'web' => ''
                                ]
                ],
                'name' => '',
                'parentGroups' => [
                                
                ],
                'postcode' => '',
                'sftpUser' => '',
                'shortName' => '',
                'visible' => null,
                'visibleToJoin' => null
        ],
        'id' => 0,
        'identifier' => '',
        'links' => [
                [
                                
                ]
        ],
        'notes' => '',
        'severity' => '',
        'status' => ''
    ],
    'encounters' => [
        [
                'date' => '',
                'encounterType' => '',
                'group' => [
                                
                ],
                'id' => 0,
                'identifier' => '',
                'links' => [
                                [
                                                                
                                ]
                ],
                'observations' => [
                                [
                                                                'applies' => '',
                                                                'bodySite' => '',
                                                                'comments' => '',
                                                                'comparator' => '',
                                                                'diagram' => '',
                                                                'group' => [
                                                                                                                                
                                                                ],
                                                                'id' => 0,
                                                                'identifier' => '',
                                                                'location' => '',
                                                                'name' => '',
                                                                'temporaryUuid' => '',
                                                                'units' => '',
                                                                'value' => ''
                                ]
                ],
                'procedures' => [
                                [
                                                                'bodySite' => '',
                                                                'id' => 0,
                                                                'type' => ''
                                ]
                ],
                'status' => ''
        ]
    ],
    'groupCode' => '',
    'identifier' => '',
    'observations' => [
        [
                
        ]
    ],
    'patient' => [
        'address1' => '',
        'address2' => '',
        'address3' => '',
        'address4' => '',
        'contacts' => [
                [
                                'id' => 0,
                                'system' => '',
                                'use' => '',
                                'value' => ''
                ]
        ],
        'dateOfBirth' => '',
        'dateOfBirthNoTime' => '',
        'forename' => '',
        'gender' => '',
        'group' => [
                
        ],
        'groupCode' => '',
        'identifier' => '',
        'identifiers' => [
                [
                                'id' => 0,
                                'label' => '',
                                'value' => ''
                ]
        ],
        'postcode' => '',
        'practitioners' => [
                [
                                'address1' => '',
                                'address2' => '',
                                'address3' => '',
                                'address4' => '',
                                'allowInviteGp' => null,
                                'contacts' => [
                                                                [
                                                                                                                                
                                                                ]
                                ],
                                'gender' => '',
                                'groupCode' => '',
                                'identifier' => '',
                                'inviteDate' => '',
                                'name' => '',
                                'postcode' => '',
                                'role' => ''
                ]
        ],
        'surname' => ''
    ],
    'practitioners' => [
        [
                
        ]
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/patientmanagement/:userId/group/:groupId/identifier/:identifierId/surgeries', [
  'body' => '{
  "condition": {
    "asserter": "",
    "category": "",
    "code": "",
    "date": "",
    "description": "",
    "fullDescription": "",
    "group": {
      "address1": "",
      "address2": "",
      "address3": "",
      "childGroups": [],
      "code": "",
      "contactPoints": [
        {
          "contactPointType": {
            "description": "",
            "id": 0,
            "lookupType": {
              "created": "",
              "description": "",
              "id": 0,
              "lastUpdate": "",
              "type": ""
            },
            "value": ""
          },
          "content": "",
          "created": "",
          "id": 0,
          "lastUpdate": ""
        }
      ],
      "created": "",
      "fhirResourceId": "",
      "groupFeatures": [
        {
          "created": "",
          "feature": {
            "created": "",
            "description": "",
            "id": 0,
            "lastUpdate": "",
            "name": ""
          },
          "id": 0,
          "lastUpdate": ""
        }
      ],
      "groupType": {
        "created": "",
        "description": "",
        "descriptionFriendly": "",
        "displayOrder": 0,
        "id": 0,
        "lastUpdate": "",
        "lookupType": {},
        "value": ""
      },
      "id": 0,
      "lastImportDate": "",
      "lastUpdate": "",
      "links": [
        {
          "created": "",
          "displayOrder": 0,
          "id": 0,
          "lastUpdate": "",
          "link": "",
          "linkType": {},
          "name": ""
        }
      ],
      "locations": [
        {
          "address": "",
          "created": "",
          "email": "",
          "id": 0,
          "label": "",
          "lastUpdate": "",
          "name": "",
          "phone": "",
          "web": ""
        }
      ],
      "name": "",
      "parentGroups": [],
      "postcode": "",
      "sftpUser": "",
      "shortName": "",
      "visible": false,
      "visibleToJoin": false
    },
    "id": 0,
    "identifier": "",
    "links": [
      {}
    ],
    "notes": "",
    "severity": "",
    "status": ""
  },
  "encounters": [
    {
      "date": "",
      "encounterType": "",
      "group": {},
      "id": 0,
      "identifier": "",
      "links": [
        {}
      ],
      "observations": [
        {
          "applies": "",
          "bodySite": "",
          "comments": "",
          "comparator": "",
          "diagram": "",
          "group": {},
          "id": 0,
          "identifier": "",
          "location": "",
          "name": "",
          "temporaryUuid": "",
          "units": "",
          "value": ""
        }
      ],
      "procedures": [
        {
          "bodySite": "",
          "id": 0,
          "type": ""
        }
      ],
      "status": ""
    }
  ],
  "groupCode": "",
  "identifier": "",
  "observations": [
    {}
  ],
  "patient": {
    "address1": "",
    "address2": "",
    "address3": "",
    "address4": "",
    "contacts": [
      {
        "id": 0,
        "system": "",
        "use": "",
        "value": ""
      }
    ],
    "dateOfBirth": "",
    "dateOfBirthNoTime": "",
    "forename": "",
    "gender": "",
    "group": {},
    "groupCode": "",
    "identifier": "",
    "identifiers": [
      {
        "id": 0,
        "label": "",
        "value": ""
      }
    ],
    "postcode": "",
    "practitioners": [
      {
        "address1": "",
        "address2": "",
        "address3": "",
        "address4": "",
        "allowInviteGp": false,
        "contacts": [
          {}
        ],
        "gender": "",
        "groupCode": "",
        "identifier": "",
        "inviteDate": "",
        "name": "",
        "postcode": "",
        "role": ""
      }
    ],
    "surname": ""
  },
  "practitioners": [
    {}
  ]
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/patientmanagement/:userId/group/:groupId/identifier/:identifierId/surgeries');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'condition' => [
    'asserter' => '',
    'category' => '',
    'code' => '',
    'date' => '',
    'description' => '',
    'fullDescription' => '',
    'group' => [
        'address1' => '',
        'address2' => '',
        'address3' => '',
        'childGroups' => [
                
        ],
        'code' => '',
        'contactPoints' => [
                [
                                'contactPointType' => [
                                                                'description' => '',
                                                                'id' => 0,
                                                                'lookupType' => [
                                                                                                                                'created' => '',
                                                                                                                                'description' => '',
                                                                                                                                'id' => 0,
                                                                                                                                'lastUpdate' => '',
                                                                                                                                'type' => ''
                                                                ],
                                                                'value' => ''
                                ],
                                'content' => '',
                                'created' => '',
                                'id' => 0,
                                'lastUpdate' => ''
                ]
        ],
        'created' => '',
        'fhirResourceId' => '',
        'groupFeatures' => [
                [
                                'created' => '',
                                'feature' => [
                                                                'created' => '',
                                                                'description' => '',
                                                                'id' => 0,
                                                                'lastUpdate' => '',
                                                                'name' => ''
                                ],
                                'id' => 0,
                                'lastUpdate' => ''
                ]
        ],
        'groupType' => [
                'created' => '',
                'description' => '',
                'descriptionFriendly' => '',
                'displayOrder' => 0,
                'id' => 0,
                'lastUpdate' => '',
                'lookupType' => [
                                
                ],
                'value' => ''
        ],
        'id' => 0,
        'lastImportDate' => '',
        'lastUpdate' => '',
        'links' => [
                [
                                'created' => '',
                                'displayOrder' => 0,
                                'id' => 0,
                                'lastUpdate' => '',
                                'link' => '',
                                'linkType' => [
                                                                
                                ],
                                'name' => ''
                ]
        ],
        'locations' => [
                [
                                'address' => '',
                                'created' => '',
                                'email' => '',
                                'id' => 0,
                                'label' => '',
                                'lastUpdate' => '',
                                'name' => '',
                                'phone' => '',
                                'web' => ''
                ]
        ],
        'name' => '',
        'parentGroups' => [
                
        ],
        'postcode' => '',
        'sftpUser' => '',
        'shortName' => '',
        'visible' => null,
        'visibleToJoin' => null
    ],
    'id' => 0,
    'identifier' => '',
    'links' => [
        [
                
        ]
    ],
    'notes' => '',
    'severity' => '',
    'status' => ''
  ],
  'encounters' => [
    [
        'date' => '',
        'encounterType' => '',
        'group' => [
                
        ],
        'id' => 0,
        'identifier' => '',
        'links' => [
                [
                                
                ]
        ],
        'observations' => [
                [
                                'applies' => '',
                                'bodySite' => '',
                                'comments' => '',
                                'comparator' => '',
                                'diagram' => '',
                                'group' => [
                                                                
                                ],
                                'id' => 0,
                                'identifier' => '',
                                'location' => '',
                                'name' => '',
                                'temporaryUuid' => '',
                                'units' => '',
                                'value' => ''
                ]
        ],
        'procedures' => [
                [
                                'bodySite' => '',
                                'id' => 0,
                                'type' => ''
                ]
        ],
        'status' => ''
    ]
  ],
  'groupCode' => '',
  'identifier' => '',
  'observations' => [
    [
        
    ]
  ],
  'patient' => [
    'address1' => '',
    'address2' => '',
    'address3' => '',
    'address4' => '',
    'contacts' => [
        [
                'id' => 0,
                'system' => '',
                'use' => '',
                'value' => ''
        ]
    ],
    'dateOfBirth' => '',
    'dateOfBirthNoTime' => '',
    'forename' => '',
    'gender' => '',
    'group' => [
        
    ],
    'groupCode' => '',
    'identifier' => '',
    'identifiers' => [
        [
                'id' => 0,
                'label' => '',
                'value' => ''
        ]
    ],
    'postcode' => '',
    'practitioners' => [
        [
                'address1' => '',
                'address2' => '',
                'address3' => '',
                'address4' => '',
                'allowInviteGp' => null,
                'contacts' => [
                                [
                                                                
                                ]
                ],
                'gender' => '',
                'groupCode' => '',
                'identifier' => '',
                'inviteDate' => '',
                'name' => '',
                'postcode' => '',
                'role' => ''
        ]
    ],
    'surname' => ''
  ],
  'practitioners' => [
    [
        
    ]
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'condition' => [
    'asserter' => '',
    'category' => '',
    'code' => '',
    'date' => '',
    'description' => '',
    'fullDescription' => '',
    'group' => [
        'address1' => '',
        'address2' => '',
        'address3' => '',
        'childGroups' => [
                
        ],
        'code' => '',
        'contactPoints' => [
                [
                                'contactPointType' => [
                                                                'description' => '',
                                                                'id' => 0,
                                                                'lookupType' => [
                                                                                                                                'created' => '',
                                                                                                                                'description' => '',
                                                                                                                                'id' => 0,
                                                                                                                                'lastUpdate' => '',
                                                                                                                                'type' => ''
                                                                ],
                                                                'value' => ''
                                ],
                                'content' => '',
                                'created' => '',
                                'id' => 0,
                                'lastUpdate' => ''
                ]
        ],
        'created' => '',
        'fhirResourceId' => '',
        'groupFeatures' => [
                [
                                'created' => '',
                                'feature' => [
                                                                'created' => '',
                                                                'description' => '',
                                                                'id' => 0,
                                                                'lastUpdate' => '',
                                                                'name' => ''
                                ],
                                'id' => 0,
                                'lastUpdate' => ''
                ]
        ],
        'groupType' => [
                'created' => '',
                'description' => '',
                'descriptionFriendly' => '',
                'displayOrder' => 0,
                'id' => 0,
                'lastUpdate' => '',
                'lookupType' => [
                                
                ],
                'value' => ''
        ],
        'id' => 0,
        'lastImportDate' => '',
        'lastUpdate' => '',
        'links' => [
                [
                                'created' => '',
                                'displayOrder' => 0,
                                'id' => 0,
                                'lastUpdate' => '',
                                'link' => '',
                                'linkType' => [
                                                                
                                ],
                                'name' => ''
                ]
        ],
        'locations' => [
                [
                                'address' => '',
                                'created' => '',
                                'email' => '',
                                'id' => 0,
                                'label' => '',
                                'lastUpdate' => '',
                                'name' => '',
                                'phone' => '',
                                'web' => ''
                ]
        ],
        'name' => '',
        'parentGroups' => [
                
        ],
        'postcode' => '',
        'sftpUser' => '',
        'shortName' => '',
        'visible' => null,
        'visibleToJoin' => null
    ],
    'id' => 0,
    'identifier' => '',
    'links' => [
        [
                
        ]
    ],
    'notes' => '',
    'severity' => '',
    'status' => ''
  ],
  'encounters' => [
    [
        'date' => '',
        'encounterType' => '',
        'group' => [
                
        ],
        'id' => 0,
        'identifier' => '',
        'links' => [
                [
                                
                ]
        ],
        'observations' => [
                [
                                'applies' => '',
                                'bodySite' => '',
                                'comments' => '',
                                'comparator' => '',
                                'diagram' => '',
                                'group' => [
                                                                
                                ],
                                'id' => 0,
                                'identifier' => '',
                                'location' => '',
                                'name' => '',
                                'temporaryUuid' => '',
                                'units' => '',
                                'value' => ''
                ]
        ],
        'procedures' => [
                [
                                'bodySite' => '',
                                'id' => 0,
                                'type' => ''
                ]
        ],
        'status' => ''
    ]
  ],
  'groupCode' => '',
  'identifier' => '',
  'observations' => [
    [
        
    ]
  ],
  'patient' => [
    'address1' => '',
    'address2' => '',
    'address3' => '',
    'address4' => '',
    'contacts' => [
        [
                'id' => 0,
                'system' => '',
                'use' => '',
                'value' => ''
        ]
    ],
    'dateOfBirth' => '',
    'dateOfBirthNoTime' => '',
    'forename' => '',
    'gender' => '',
    'group' => [
        
    ],
    'groupCode' => '',
    'identifier' => '',
    'identifiers' => [
        [
                'id' => 0,
                'label' => '',
                'value' => ''
        ]
    ],
    'postcode' => '',
    'practitioners' => [
        [
                'address1' => '',
                'address2' => '',
                'address3' => '',
                'address4' => '',
                'allowInviteGp' => null,
                'contacts' => [
                                [
                                                                
                                ]
                ],
                'gender' => '',
                'groupCode' => '',
                'identifier' => '',
                'inviteDate' => '',
                'name' => '',
                'postcode' => '',
                'role' => ''
        ]
    ],
    'surname' => ''
  ],
  'practitioners' => [
    [
        
    ]
  ]
]));
$request->setRequestUrl('{{baseUrl}}/patientmanagement/:userId/group/:groupId/identifier/:identifierId/surgeries');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/patientmanagement/:userId/group/:groupId/identifier/:identifierId/surgeries' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "condition": {
    "asserter": "",
    "category": "",
    "code": "",
    "date": "",
    "description": "",
    "fullDescription": "",
    "group": {
      "address1": "",
      "address2": "",
      "address3": "",
      "childGroups": [],
      "code": "",
      "contactPoints": [
        {
          "contactPointType": {
            "description": "",
            "id": 0,
            "lookupType": {
              "created": "",
              "description": "",
              "id": 0,
              "lastUpdate": "",
              "type": ""
            },
            "value": ""
          },
          "content": "",
          "created": "",
          "id": 0,
          "lastUpdate": ""
        }
      ],
      "created": "",
      "fhirResourceId": "",
      "groupFeatures": [
        {
          "created": "",
          "feature": {
            "created": "",
            "description": "",
            "id": 0,
            "lastUpdate": "",
            "name": ""
          },
          "id": 0,
          "lastUpdate": ""
        }
      ],
      "groupType": {
        "created": "",
        "description": "",
        "descriptionFriendly": "",
        "displayOrder": 0,
        "id": 0,
        "lastUpdate": "",
        "lookupType": {},
        "value": ""
      },
      "id": 0,
      "lastImportDate": "",
      "lastUpdate": "",
      "links": [
        {
          "created": "",
          "displayOrder": 0,
          "id": 0,
          "lastUpdate": "",
          "link": "",
          "linkType": {},
          "name": ""
        }
      ],
      "locations": [
        {
          "address": "",
          "created": "",
          "email": "",
          "id": 0,
          "label": "",
          "lastUpdate": "",
          "name": "",
          "phone": "",
          "web": ""
        }
      ],
      "name": "",
      "parentGroups": [],
      "postcode": "",
      "sftpUser": "",
      "shortName": "",
      "visible": false,
      "visibleToJoin": false
    },
    "id": 0,
    "identifier": "",
    "links": [
      {}
    ],
    "notes": "",
    "severity": "",
    "status": ""
  },
  "encounters": [
    {
      "date": "",
      "encounterType": "",
      "group": {},
      "id": 0,
      "identifier": "",
      "links": [
        {}
      ],
      "observations": [
        {
          "applies": "",
          "bodySite": "",
          "comments": "",
          "comparator": "",
          "diagram": "",
          "group": {},
          "id": 0,
          "identifier": "",
          "location": "",
          "name": "",
          "temporaryUuid": "",
          "units": "",
          "value": ""
        }
      ],
      "procedures": [
        {
          "bodySite": "",
          "id": 0,
          "type": ""
        }
      ],
      "status": ""
    }
  ],
  "groupCode": "",
  "identifier": "",
  "observations": [
    {}
  ],
  "patient": {
    "address1": "",
    "address2": "",
    "address3": "",
    "address4": "",
    "contacts": [
      {
        "id": 0,
        "system": "",
        "use": "",
        "value": ""
      }
    ],
    "dateOfBirth": "",
    "dateOfBirthNoTime": "",
    "forename": "",
    "gender": "",
    "group": {},
    "groupCode": "",
    "identifier": "",
    "identifiers": [
      {
        "id": 0,
        "label": "",
        "value": ""
      }
    ],
    "postcode": "",
    "practitioners": [
      {
        "address1": "",
        "address2": "",
        "address3": "",
        "address4": "",
        "allowInviteGp": false,
        "contacts": [
          {}
        ],
        "gender": "",
        "groupCode": "",
        "identifier": "",
        "inviteDate": "",
        "name": "",
        "postcode": "",
        "role": ""
      }
    ],
    "surname": ""
  },
  "practitioners": [
    {}
  ]
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/patientmanagement/:userId/group/:groupId/identifier/:identifierId/surgeries' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "condition": {
    "asserter": "",
    "category": "",
    "code": "",
    "date": "",
    "description": "",
    "fullDescription": "",
    "group": {
      "address1": "",
      "address2": "",
      "address3": "",
      "childGroups": [],
      "code": "",
      "contactPoints": [
        {
          "contactPointType": {
            "description": "",
            "id": 0,
            "lookupType": {
              "created": "",
              "description": "",
              "id": 0,
              "lastUpdate": "",
              "type": ""
            },
            "value": ""
          },
          "content": "",
          "created": "",
          "id": 0,
          "lastUpdate": ""
        }
      ],
      "created": "",
      "fhirResourceId": "",
      "groupFeatures": [
        {
          "created": "",
          "feature": {
            "created": "",
            "description": "",
            "id": 0,
            "lastUpdate": "",
            "name": ""
          },
          "id": 0,
          "lastUpdate": ""
        }
      ],
      "groupType": {
        "created": "",
        "description": "",
        "descriptionFriendly": "",
        "displayOrder": 0,
        "id": 0,
        "lastUpdate": "",
        "lookupType": {},
        "value": ""
      },
      "id": 0,
      "lastImportDate": "",
      "lastUpdate": "",
      "links": [
        {
          "created": "",
          "displayOrder": 0,
          "id": 0,
          "lastUpdate": "",
          "link": "",
          "linkType": {},
          "name": ""
        }
      ],
      "locations": [
        {
          "address": "",
          "created": "",
          "email": "",
          "id": 0,
          "label": "",
          "lastUpdate": "",
          "name": "",
          "phone": "",
          "web": ""
        }
      ],
      "name": "",
      "parentGroups": [],
      "postcode": "",
      "sftpUser": "",
      "shortName": "",
      "visible": false,
      "visibleToJoin": false
    },
    "id": 0,
    "identifier": "",
    "links": [
      {}
    ],
    "notes": "",
    "severity": "",
    "status": ""
  },
  "encounters": [
    {
      "date": "",
      "encounterType": "",
      "group": {},
      "id": 0,
      "identifier": "",
      "links": [
        {}
      ],
      "observations": [
        {
          "applies": "",
          "bodySite": "",
          "comments": "",
          "comparator": "",
          "diagram": "",
          "group": {},
          "id": 0,
          "identifier": "",
          "location": "",
          "name": "",
          "temporaryUuid": "",
          "units": "",
          "value": ""
        }
      ],
      "procedures": [
        {
          "bodySite": "",
          "id": 0,
          "type": ""
        }
      ],
      "status": ""
    }
  ],
  "groupCode": "",
  "identifier": "",
  "observations": [
    {}
  ],
  "patient": {
    "address1": "",
    "address2": "",
    "address3": "",
    "address4": "",
    "contacts": [
      {
        "id": 0,
        "system": "",
        "use": "",
        "value": ""
      }
    ],
    "dateOfBirth": "",
    "dateOfBirthNoTime": "",
    "forename": "",
    "gender": "",
    "group": {},
    "groupCode": "",
    "identifier": "",
    "identifiers": [
      {
        "id": 0,
        "label": "",
        "value": ""
      }
    ],
    "postcode": "",
    "practitioners": [
      {
        "address1": "",
        "address2": "",
        "address3": "",
        "address4": "",
        "allowInviteGp": false,
        "contacts": [
          {}
        ],
        "gender": "",
        "groupCode": "",
        "identifier": "",
        "inviteDate": "",
        "name": "",
        "postcode": "",
        "role": ""
      }
    ],
    "surname": ""
  },
  "practitioners": [
    {}
  ]
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"condition\": {\n    \"asserter\": \"\",\n    \"category\": \"\",\n    \"code\": \"\",\n    \"date\": \"\",\n    \"description\": \"\",\n    \"fullDescription\": \"\",\n    \"group\": {\n      \"address1\": \"\",\n      \"address2\": \"\",\n      \"address3\": \"\",\n      \"childGroups\": [],\n      \"code\": \"\",\n      \"contactPoints\": [\n        {\n          \"contactPointType\": {\n            \"description\": \"\",\n            \"id\": 0,\n            \"lookupType\": {\n              \"created\": \"\",\n              \"description\": \"\",\n              \"id\": 0,\n              \"lastUpdate\": \"\",\n              \"type\": \"\"\n            },\n            \"value\": \"\"\n          },\n          \"content\": \"\",\n          \"created\": \"\",\n          \"id\": 0,\n          \"lastUpdate\": \"\"\n        }\n      ],\n      \"created\": \"\",\n      \"fhirResourceId\": \"\",\n      \"groupFeatures\": [\n        {\n          \"created\": \"\",\n          \"feature\": {\n            \"created\": \"\",\n            \"description\": \"\",\n            \"id\": 0,\n            \"lastUpdate\": \"\",\n            \"name\": \"\"\n          },\n          \"id\": 0,\n          \"lastUpdate\": \"\"\n        }\n      ],\n      \"groupType\": {\n        \"created\": \"\",\n        \"description\": \"\",\n        \"descriptionFriendly\": \"\",\n        \"displayOrder\": 0,\n        \"id\": 0,\n        \"lastUpdate\": \"\",\n        \"lookupType\": {},\n        \"value\": \"\"\n      },\n      \"id\": 0,\n      \"lastImportDate\": \"\",\n      \"lastUpdate\": \"\",\n      \"links\": [\n        {\n          \"created\": \"\",\n          \"displayOrder\": 0,\n          \"id\": 0,\n          \"lastUpdate\": \"\",\n          \"link\": \"\",\n          \"linkType\": {},\n          \"name\": \"\"\n        }\n      ],\n      \"locations\": [\n        {\n          \"address\": \"\",\n          \"created\": \"\",\n          \"email\": \"\",\n          \"id\": 0,\n          \"label\": \"\",\n          \"lastUpdate\": \"\",\n          \"name\": \"\",\n          \"phone\": \"\",\n          \"web\": \"\"\n        }\n      ],\n      \"name\": \"\",\n      \"parentGroups\": [],\n      \"postcode\": \"\",\n      \"sftpUser\": \"\",\n      \"shortName\": \"\",\n      \"visible\": false,\n      \"visibleToJoin\": false\n    },\n    \"id\": 0,\n    \"identifier\": \"\",\n    \"links\": [\n      {}\n    ],\n    \"notes\": \"\",\n    \"severity\": \"\",\n    \"status\": \"\"\n  },\n  \"encounters\": [\n    {\n      \"date\": \"\",\n      \"encounterType\": \"\",\n      \"group\": {},\n      \"id\": 0,\n      \"identifier\": \"\",\n      \"links\": [\n        {}\n      ],\n      \"observations\": [\n        {\n          \"applies\": \"\",\n          \"bodySite\": \"\",\n          \"comments\": \"\",\n          \"comparator\": \"\",\n          \"diagram\": \"\",\n          \"group\": {},\n          \"id\": 0,\n          \"identifier\": \"\",\n          \"location\": \"\",\n          \"name\": \"\",\n          \"temporaryUuid\": \"\",\n          \"units\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"procedures\": [\n        {\n          \"bodySite\": \"\",\n          \"id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"status\": \"\"\n    }\n  ],\n  \"groupCode\": \"\",\n  \"identifier\": \"\",\n  \"observations\": [\n    {}\n  ],\n  \"patient\": {\n    \"address1\": \"\",\n    \"address2\": \"\",\n    \"address3\": \"\",\n    \"address4\": \"\",\n    \"contacts\": [\n      {\n        \"id\": 0,\n        \"system\": \"\",\n        \"use\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"dateOfBirth\": \"\",\n    \"dateOfBirthNoTime\": \"\",\n    \"forename\": \"\",\n    \"gender\": \"\",\n    \"group\": {},\n    \"groupCode\": \"\",\n    \"identifier\": \"\",\n    \"identifiers\": [\n      {\n        \"id\": 0,\n        \"label\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"postcode\": \"\",\n    \"practitioners\": [\n      {\n        \"address1\": \"\",\n        \"address2\": \"\",\n        \"address3\": \"\",\n        \"address4\": \"\",\n        \"allowInviteGp\": false,\n        \"contacts\": [\n          {}\n        ],\n        \"gender\": \"\",\n        \"groupCode\": \"\",\n        \"identifier\": \"\",\n        \"inviteDate\": \"\",\n        \"name\": \"\",\n        \"postcode\": \"\",\n        \"role\": \"\"\n      }\n    ],\n    \"surname\": \"\"\n  },\n  \"practitioners\": [\n    {}\n  ]\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/patientmanagement/:userId/group/:groupId/identifier/:identifierId/surgeries", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/patientmanagement/:userId/group/:groupId/identifier/:identifierId/surgeries"

payload = {
    "condition": {
        "asserter": "",
        "category": "",
        "code": "",
        "date": "",
        "description": "",
        "fullDescription": "",
        "group": {
            "address1": "",
            "address2": "",
            "address3": "",
            "childGroups": [],
            "code": "",
            "contactPoints": [
                {
                    "contactPointType": {
                        "description": "",
                        "id": 0,
                        "lookupType": {
                            "created": "",
                            "description": "",
                            "id": 0,
                            "lastUpdate": "",
                            "type": ""
                        },
                        "value": ""
                    },
                    "content": "",
                    "created": "",
                    "id": 0,
                    "lastUpdate": ""
                }
            ],
            "created": "",
            "fhirResourceId": "",
            "groupFeatures": [
                {
                    "created": "",
                    "feature": {
                        "created": "",
                        "description": "",
                        "id": 0,
                        "lastUpdate": "",
                        "name": ""
                    },
                    "id": 0,
                    "lastUpdate": ""
                }
            ],
            "groupType": {
                "created": "",
                "description": "",
                "descriptionFriendly": "",
                "displayOrder": 0,
                "id": 0,
                "lastUpdate": "",
                "lookupType": {},
                "value": ""
            },
            "id": 0,
            "lastImportDate": "",
            "lastUpdate": "",
            "links": [
                {
                    "created": "",
                    "displayOrder": 0,
                    "id": 0,
                    "lastUpdate": "",
                    "link": "",
                    "linkType": {},
                    "name": ""
                }
            ],
            "locations": [
                {
                    "address": "",
                    "created": "",
                    "email": "",
                    "id": 0,
                    "label": "",
                    "lastUpdate": "",
                    "name": "",
                    "phone": "",
                    "web": ""
                }
            ],
            "name": "",
            "parentGroups": [],
            "postcode": "",
            "sftpUser": "",
            "shortName": "",
            "visible": False,
            "visibleToJoin": False
        },
        "id": 0,
        "identifier": "",
        "links": [{}],
        "notes": "",
        "severity": "",
        "status": ""
    },
    "encounters": [
        {
            "date": "",
            "encounterType": "",
            "group": {},
            "id": 0,
            "identifier": "",
            "links": [{}],
            "observations": [
                {
                    "applies": "",
                    "bodySite": "",
                    "comments": "",
                    "comparator": "",
                    "diagram": "",
                    "group": {},
                    "id": 0,
                    "identifier": "",
                    "location": "",
                    "name": "",
                    "temporaryUuid": "",
                    "units": "",
                    "value": ""
                }
            ],
            "procedures": [
                {
                    "bodySite": "",
                    "id": 0,
                    "type": ""
                }
            ],
            "status": ""
        }
    ],
    "groupCode": "",
    "identifier": "",
    "observations": [{}],
    "patient": {
        "address1": "",
        "address2": "",
        "address3": "",
        "address4": "",
        "contacts": [
            {
                "id": 0,
                "system": "",
                "use": "",
                "value": ""
            }
        ],
        "dateOfBirth": "",
        "dateOfBirthNoTime": "",
        "forename": "",
        "gender": "",
        "group": {},
        "groupCode": "",
        "identifier": "",
        "identifiers": [
            {
                "id": 0,
                "label": "",
                "value": ""
            }
        ],
        "postcode": "",
        "practitioners": [
            {
                "address1": "",
                "address2": "",
                "address3": "",
                "address4": "",
                "allowInviteGp": False,
                "contacts": [{}],
                "gender": "",
                "groupCode": "",
                "identifier": "",
                "inviteDate": "",
                "name": "",
                "postcode": "",
                "role": ""
            }
        ],
        "surname": ""
    },
    "practitioners": [{}]
}
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/patientmanagement/:userId/group/:groupId/identifier/:identifierId/surgeries"

payload <- "{\n  \"condition\": {\n    \"asserter\": \"\",\n    \"category\": \"\",\n    \"code\": \"\",\n    \"date\": \"\",\n    \"description\": \"\",\n    \"fullDescription\": \"\",\n    \"group\": {\n      \"address1\": \"\",\n      \"address2\": \"\",\n      \"address3\": \"\",\n      \"childGroups\": [],\n      \"code\": \"\",\n      \"contactPoints\": [\n        {\n          \"contactPointType\": {\n            \"description\": \"\",\n            \"id\": 0,\n            \"lookupType\": {\n              \"created\": \"\",\n              \"description\": \"\",\n              \"id\": 0,\n              \"lastUpdate\": \"\",\n              \"type\": \"\"\n            },\n            \"value\": \"\"\n          },\n          \"content\": \"\",\n          \"created\": \"\",\n          \"id\": 0,\n          \"lastUpdate\": \"\"\n        }\n      ],\n      \"created\": \"\",\n      \"fhirResourceId\": \"\",\n      \"groupFeatures\": [\n        {\n          \"created\": \"\",\n          \"feature\": {\n            \"created\": \"\",\n            \"description\": \"\",\n            \"id\": 0,\n            \"lastUpdate\": \"\",\n            \"name\": \"\"\n          },\n          \"id\": 0,\n          \"lastUpdate\": \"\"\n        }\n      ],\n      \"groupType\": {\n        \"created\": \"\",\n        \"description\": \"\",\n        \"descriptionFriendly\": \"\",\n        \"displayOrder\": 0,\n        \"id\": 0,\n        \"lastUpdate\": \"\",\n        \"lookupType\": {},\n        \"value\": \"\"\n      },\n      \"id\": 0,\n      \"lastImportDate\": \"\",\n      \"lastUpdate\": \"\",\n      \"links\": [\n        {\n          \"created\": \"\",\n          \"displayOrder\": 0,\n          \"id\": 0,\n          \"lastUpdate\": \"\",\n          \"link\": \"\",\n          \"linkType\": {},\n          \"name\": \"\"\n        }\n      ],\n      \"locations\": [\n        {\n          \"address\": \"\",\n          \"created\": \"\",\n          \"email\": \"\",\n          \"id\": 0,\n          \"label\": \"\",\n          \"lastUpdate\": \"\",\n          \"name\": \"\",\n          \"phone\": \"\",\n          \"web\": \"\"\n        }\n      ],\n      \"name\": \"\",\n      \"parentGroups\": [],\n      \"postcode\": \"\",\n      \"sftpUser\": \"\",\n      \"shortName\": \"\",\n      \"visible\": false,\n      \"visibleToJoin\": false\n    },\n    \"id\": 0,\n    \"identifier\": \"\",\n    \"links\": [\n      {}\n    ],\n    \"notes\": \"\",\n    \"severity\": \"\",\n    \"status\": \"\"\n  },\n  \"encounters\": [\n    {\n      \"date\": \"\",\n      \"encounterType\": \"\",\n      \"group\": {},\n      \"id\": 0,\n      \"identifier\": \"\",\n      \"links\": [\n        {}\n      ],\n      \"observations\": [\n        {\n          \"applies\": \"\",\n          \"bodySite\": \"\",\n          \"comments\": \"\",\n          \"comparator\": \"\",\n          \"diagram\": \"\",\n          \"group\": {},\n          \"id\": 0,\n          \"identifier\": \"\",\n          \"location\": \"\",\n          \"name\": \"\",\n          \"temporaryUuid\": \"\",\n          \"units\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"procedures\": [\n        {\n          \"bodySite\": \"\",\n          \"id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"status\": \"\"\n    }\n  ],\n  \"groupCode\": \"\",\n  \"identifier\": \"\",\n  \"observations\": [\n    {}\n  ],\n  \"patient\": {\n    \"address1\": \"\",\n    \"address2\": \"\",\n    \"address3\": \"\",\n    \"address4\": \"\",\n    \"contacts\": [\n      {\n        \"id\": 0,\n        \"system\": \"\",\n        \"use\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"dateOfBirth\": \"\",\n    \"dateOfBirthNoTime\": \"\",\n    \"forename\": \"\",\n    \"gender\": \"\",\n    \"group\": {},\n    \"groupCode\": \"\",\n    \"identifier\": \"\",\n    \"identifiers\": [\n      {\n        \"id\": 0,\n        \"label\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"postcode\": \"\",\n    \"practitioners\": [\n      {\n        \"address1\": \"\",\n        \"address2\": \"\",\n        \"address3\": \"\",\n        \"address4\": \"\",\n        \"allowInviteGp\": false,\n        \"contacts\": [\n          {}\n        ],\n        \"gender\": \"\",\n        \"groupCode\": \"\",\n        \"identifier\": \"\",\n        \"inviteDate\": \"\",\n        \"name\": \"\",\n        \"postcode\": \"\",\n        \"role\": \"\"\n      }\n    ],\n    \"surname\": \"\"\n  },\n  \"practitioners\": [\n    {}\n  ]\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/patientmanagement/:userId/group/:groupId/identifier/:identifierId/surgeries")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"condition\": {\n    \"asserter\": \"\",\n    \"category\": \"\",\n    \"code\": \"\",\n    \"date\": \"\",\n    \"description\": \"\",\n    \"fullDescription\": \"\",\n    \"group\": {\n      \"address1\": \"\",\n      \"address2\": \"\",\n      \"address3\": \"\",\n      \"childGroups\": [],\n      \"code\": \"\",\n      \"contactPoints\": [\n        {\n          \"contactPointType\": {\n            \"description\": \"\",\n            \"id\": 0,\n            \"lookupType\": {\n              \"created\": \"\",\n              \"description\": \"\",\n              \"id\": 0,\n              \"lastUpdate\": \"\",\n              \"type\": \"\"\n            },\n            \"value\": \"\"\n          },\n          \"content\": \"\",\n          \"created\": \"\",\n          \"id\": 0,\n          \"lastUpdate\": \"\"\n        }\n      ],\n      \"created\": \"\",\n      \"fhirResourceId\": \"\",\n      \"groupFeatures\": [\n        {\n          \"created\": \"\",\n          \"feature\": {\n            \"created\": \"\",\n            \"description\": \"\",\n            \"id\": 0,\n            \"lastUpdate\": \"\",\n            \"name\": \"\"\n          },\n          \"id\": 0,\n          \"lastUpdate\": \"\"\n        }\n      ],\n      \"groupType\": {\n        \"created\": \"\",\n        \"description\": \"\",\n        \"descriptionFriendly\": \"\",\n        \"displayOrder\": 0,\n        \"id\": 0,\n        \"lastUpdate\": \"\",\n        \"lookupType\": {},\n        \"value\": \"\"\n      },\n      \"id\": 0,\n      \"lastImportDate\": \"\",\n      \"lastUpdate\": \"\",\n      \"links\": [\n        {\n          \"created\": \"\",\n          \"displayOrder\": 0,\n          \"id\": 0,\n          \"lastUpdate\": \"\",\n          \"link\": \"\",\n          \"linkType\": {},\n          \"name\": \"\"\n        }\n      ],\n      \"locations\": [\n        {\n          \"address\": \"\",\n          \"created\": \"\",\n          \"email\": \"\",\n          \"id\": 0,\n          \"label\": \"\",\n          \"lastUpdate\": \"\",\n          \"name\": \"\",\n          \"phone\": \"\",\n          \"web\": \"\"\n        }\n      ],\n      \"name\": \"\",\n      \"parentGroups\": [],\n      \"postcode\": \"\",\n      \"sftpUser\": \"\",\n      \"shortName\": \"\",\n      \"visible\": false,\n      \"visibleToJoin\": false\n    },\n    \"id\": 0,\n    \"identifier\": \"\",\n    \"links\": [\n      {}\n    ],\n    \"notes\": \"\",\n    \"severity\": \"\",\n    \"status\": \"\"\n  },\n  \"encounters\": [\n    {\n      \"date\": \"\",\n      \"encounterType\": \"\",\n      \"group\": {},\n      \"id\": 0,\n      \"identifier\": \"\",\n      \"links\": [\n        {}\n      ],\n      \"observations\": [\n        {\n          \"applies\": \"\",\n          \"bodySite\": \"\",\n          \"comments\": \"\",\n          \"comparator\": \"\",\n          \"diagram\": \"\",\n          \"group\": {},\n          \"id\": 0,\n          \"identifier\": \"\",\n          \"location\": \"\",\n          \"name\": \"\",\n          \"temporaryUuid\": \"\",\n          \"units\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"procedures\": [\n        {\n          \"bodySite\": \"\",\n          \"id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"status\": \"\"\n    }\n  ],\n  \"groupCode\": \"\",\n  \"identifier\": \"\",\n  \"observations\": [\n    {}\n  ],\n  \"patient\": {\n    \"address1\": \"\",\n    \"address2\": \"\",\n    \"address3\": \"\",\n    \"address4\": \"\",\n    \"contacts\": [\n      {\n        \"id\": 0,\n        \"system\": \"\",\n        \"use\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"dateOfBirth\": \"\",\n    \"dateOfBirthNoTime\": \"\",\n    \"forename\": \"\",\n    \"gender\": \"\",\n    \"group\": {},\n    \"groupCode\": \"\",\n    \"identifier\": \"\",\n    \"identifiers\": [\n      {\n        \"id\": 0,\n        \"label\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"postcode\": \"\",\n    \"practitioners\": [\n      {\n        \"address1\": \"\",\n        \"address2\": \"\",\n        \"address3\": \"\",\n        \"address4\": \"\",\n        \"allowInviteGp\": false,\n        \"contacts\": [\n          {}\n        ],\n        \"gender\": \"\",\n        \"groupCode\": \"\",\n        \"identifier\": \"\",\n        \"inviteDate\": \"\",\n        \"name\": \"\",\n        \"postcode\": \"\",\n        \"role\": \"\"\n      }\n    ],\n    \"surname\": \"\"\n  },\n  \"practitioners\": [\n    {}\n  ]\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/patientmanagement/:userId/group/:groupId/identifier/:identifierId/surgeries') do |req|
  req.body = "{\n  \"condition\": {\n    \"asserter\": \"\",\n    \"category\": \"\",\n    \"code\": \"\",\n    \"date\": \"\",\n    \"description\": \"\",\n    \"fullDescription\": \"\",\n    \"group\": {\n      \"address1\": \"\",\n      \"address2\": \"\",\n      \"address3\": \"\",\n      \"childGroups\": [],\n      \"code\": \"\",\n      \"contactPoints\": [\n        {\n          \"contactPointType\": {\n            \"description\": \"\",\n            \"id\": 0,\n            \"lookupType\": {\n              \"created\": \"\",\n              \"description\": \"\",\n              \"id\": 0,\n              \"lastUpdate\": \"\",\n              \"type\": \"\"\n            },\n            \"value\": \"\"\n          },\n          \"content\": \"\",\n          \"created\": \"\",\n          \"id\": 0,\n          \"lastUpdate\": \"\"\n        }\n      ],\n      \"created\": \"\",\n      \"fhirResourceId\": \"\",\n      \"groupFeatures\": [\n        {\n          \"created\": \"\",\n          \"feature\": {\n            \"created\": \"\",\n            \"description\": \"\",\n            \"id\": 0,\n            \"lastUpdate\": \"\",\n            \"name\": \"\"\n          },\n          \"id\": 0,\n          \"lastUpdate\": \"\"\n        }\n      ],\n      \"groupType\": {\n        \"created\": \"\",\n        \"description\": \"\",\n        \"descriptionFriendly\": \"\",\n        \"displayOrder\": 0,\n        \"id\": 0,\n        \"lastUpdate\": \"\",\n        \"lookupType\": {},\n        \"value\": \"\"\n      },\n      \"id\": 0,\n      \"lastImportDate\": \"\",\n      \"lastUpdate\": \"\",\n      \"links\": [\n        {\n          \"created\": \"\",\n          \"displayOrder\": 0,\n          \"id\": 0,\n          \"lastUpdate\": \"\",\n          \"link\": \"\",\n          \"linkType\": {},\n          \"name\": \"\"\n        }\n      ],\n      \"locations\": [\n        {\n          \"address\": \"\",\n          \"created\": \"\",\n          \"email\": \"\",\n          \"id\": 0,\n          \"label\": \"\",\n          \"lastUpdate\": \"\",\n          \"name\": \"\",\n          \"phone\": \"\",\n          \"web\": \"\"\n        }\n      ],\n      \"name\": \"\",\n      \"parentGroups\": [],\n      \"postcode\": \"\",\n      \"sftpUser\": \"\",\n      \"shortName\": \"\",\n      \"visible\": false,\n      \"visibleToJoin\": false\n    },\n    \"id\": 0,\n    \"identifier\": \"\",\n    \"links\": [\n      {}\n    ],\n    \"notes\": \"\",\n    \"severity\": \"\",\n    \"status\": \"\"\n  },\n  \"encounters\": [\n    {\n      \"date\": \"\",\n      \"encounterType\": \"\",\n      \"group\": {},\n      \"id\": 0,\n      \"identifier\": \"\",\n      \"links\": [\n        {}\n      ],\n      \"observations\": [\n        {\n          \"applies\": \"\",\n          \"bodySite\": \"\",\n          \"comments\": \"\",\n          \"comparator\": \"\",\n          \"diagram\": \"\",\n          \"group\": {},\n          \"id\": 0,\n          \"identifier\": \"\",\n          \"location\": \"\",\n          \"name\": \"\",\n          \"temporaryUuid\": \"\",\n          \"units\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"procedures\": [\n        {\n          \"bodySite\": \"\",\n          \"id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"status\": \"\"\n    }\n  ],\n  \"groupCode\": \"\",\n  \"identifier\": \"\",\n  \"observations\": [\n    {}\n  ],\n  \"patient\": {\n    \"address1\": \"\",\n    \"address2\": \"\",\n    \"address3\": \"\",\n    \"address4\": \"\",\n    \"contacts\": [\n      {\n        \"id\": 0,\n        \"system\": \"\",\n        \"use\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"dateOfBirth\": \"\",\n    \"dateOfBirthNoTime\": \"\",\n    \"forename\": \"\",\n    \"gender\": \"\",\n    \"group\": {},\n    \"groupCode\": \"\",\n    \"identifier\": \"\",\n    \"identifiers\": [\n      {\n        \"id\": 0,\n        \"label\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"postcode\": \"\",\n    \"practitioners\": [\n      {\n        \"address1\": \"\",\n        \"address2\": \"\",\n        \"address3\": \"\",\n        \"address4\": \"\",\n        \"allowInviteGp\": false,\n        \"contacts\": [\n          {}\n        ],\n        \"gender\": \"\",\n        \"groupCode\": \"\",\n        \"identifier\": \"\",\n        \"inviteDate\": \"\",\n        \"name\": \"\",\n        \"postcode\": \"\",\n        \"role\": \"\"\n      }\n    ],\n    \"surname\": \"\"\n  },\n  \"practitioners\": [\n    {}\n  ]\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/patientmanagement/:userId/group/:groupId/identifier/:identifierId/surgeries";

    let payload = json!({
        "condition": json!({
            "asserter": "",
            "category": "",
            "code": "",
            "date": "",
            "description": "",
            "fullDescription": "",
            "group": json!({
                "address1": "",
                "address2": "",
                "address3": "",
                "childGroups": (),
                "code": "",
                "contactPoints": (
                    json!({
                        "contactPointType": json!({
                            "description": "",
                            "id": 0,
                            "lookupType": json!({
                                "created": "",
                                "description": "",
                                "id": 0,
                                "lastUpdate": "",
                                "type": ""
                            }),
                            "value": ""
                        }),
                        "content": "",
                        "created": "",
                        "id": 0,
                        "lastUpdate": ""
                    })
                ),
                "created": "",
                "fhirResourceId": "",
                "groupFeatures": (
                    json!({
                        "created": "",
                        "feature": json!({
                            "created": "",
                            "description": "",
                            "id": 0,
                            "lastUpdate": "",
                            "name": ""
                        }),
                        "id": 0,
                        "lastUpdate": ""
                    })
                ),
                "groupType": json!({
                    "created": "",
                    "description": "",
                    "descriptionFriendly": "",
                    "displayOrder": 0,
                    "id": 0,
                    "lastUpdate": "",
                    "lookupType": json!({}),
                    "value": ""
                }),
                "id": 0,
                "lastImportDate": "",
                "lastUpdate": "",
                "links": (
                    json!({
                        "created": "",
                        "displayOrder": 0,
                        "id": 0,
                        "lastUpdate": "",
                        "link": "",
                        "linkType": json!({}),
                        "name": ""
                    })
                ),
                "locations": (
                    json!({
                        "address": "",
                        "created": "",
                        "email": "",
                        "id": 0,
                        "label": "",
                        "lastUpdate": "",
                        "name": "",
                        "phone": "",
                        "web": ""
                    })
                ),
                "name": "",
                "parentGroups": (),
                "postcode": "",
                "sftpUser": "",
                "shortName": "",
                "visible": false,
                "visibleToJoin": false
            }),
            "id": 0,
            "identifier": "",
            "links": (json!({})),
            "notes": "",
            "severity": "",
            "status": ""
        }),
        "encounters": (
            json!({
                "date": "",
                "encounterType": "",
                "group": json!({}),
                "id": 0,
                "identifier": "",
                "links": (json!({})),
                "observations": (
                    json!({
                        "applies": "",
                        "bodySite": "",
                        "comments": "",
                        "comparator": "",
                        "diagram": "",
                        "group": json!({}),
                        "id": 0,
                        "identifier": "",
                        "location": "",
                        "name": "",
                        "temporaryUuid": "",
                        "units": "",
                        "value": ""
                    })
                ),
                "procedures": (
                    json!({
                        "bodySite": "",
                        "id": 0,
                        "type": ""
                    })
                ),
                "status": ""
            })
        ),
        "groupCode": "",
        "identifier": "",
        "observations": (json!({})),
        "patient": json!({
            "address1": "",
            "address2": "",
            "address3": "",
            "address4": "",
            "contacts": (
                json!({
                    "id": 0,
                    "system": "",
                    "use": "",
                    "value": ""
                })
            ),
            "dateOfBirth": "",
            "dateOfBirthNoTime": "",
            "forename": "",
            "gender": "",
            "group": json!({}),
            "groupCode": "",
            "identifier": "",
            "identifiers": (
                json!({
                    "id": 0,
                    "label": "",
                    "value": ""
                })
            ),
            "postcode": "",
            "practitioners": (
                json!({
                    "address1": "",
                    "address2": "",
                    "address3": "",
                    "address4": "",
                    "allowInviteGp": false,
                    "contacts": (json!({})),
                    "gender": "",
                    "groupCode": "",
                    "identifier": "",
                    "inviteDate": "",
                    "name": "",
                    "postcode": "",
                    "role": ""
                })
            ),
            "surname": ""
        }),
        "practitioners": (json!({}))
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/patientmanagement/:userId/group/:groupId/identifier/:identifierId/surgeries \
  --header 'content-type: application/json' \
  --data '{
  "condition": {
    "asserter": "",
    "category": "",
    "code": "",
    "date": "",
    "description": "",
    "fullDescription": "",
    "group": {
      "address1": "",
      "address2": "",
      "address3": "",
      "childGroups": [],
      "code": "",
      "contactPoints": [
        {
          "contactPointType": {
            "description": "",
            "id": 0,
            "lookupType": {
              "created": "",
              "description": "",
              "id": 0,
              "lastUpdate": "",
              "type": ""
            },
            "value": ""
          },
          "content": "",
          "created": "",
          "id": 0,
          "lastUpdate": ""
        }
      ],
      "created": "",
      "fhirResourceId": "",
      "groupFeatures": [
        {
          "created": "",
          "feature": {
            "created": "",
            "description": "",
            "id": 0,
            "lastUpdate": "",
            "name": ""
          },
          "id": 0,
          "lastUpdate": ""
        }
      ],
      "groupType": {
        "created": "",
        "description": "",
        "descriptionFriendly": "",
        "displayOrder": 0,
        "id": 0,
        "lastUpdate": "",
        "lookupType": {},
        "value": ""
      },
      "id": 0,
      "lastImportDate": "",
      "lastUpdate": "",
      "links": [
        {
          "created": "",
          "displayOrder": 0,
          "id": 0,
          "lastUpdate": "",
          "link": "",
          "linkType": {},
          "name": ""
        }
      ],
      "locations": [
        {
          "address": "",
          "created": "",
          "email": "",
          "id": 0,
          "label": "",
          "lastUpdate": "",
          "name": "",
          "phone": "",
          "web": ""
        }
      ],
      "name": "",
      "parentGroups": [],
      "postcode": "",
      "sftpUser": "",
      "shortName": "",
      "visible": false,
      "visibleToJoin": false
    },
    "id": 0,
    "identifier": "",
    "links": [
      {}
    ],
    "notes": "",
    "severity": "",
    "status": ""
  },
  "encounters": [
    {
      "date": "",
      "encounterType": "",
      "group": {},
      "id": 0,
      "identifier": "",
      "links": [
        {}
      ],
      "observations": [
        {
          "applies": "",
          "bodySite": "",
          "comments": "",
          "comparator": "",
          "diagram": "",
          "group": {},
          "id": 0,
          "identifier": "",
          "location": "",
          "name": "",
          "temporaryUuid": "",
          "units": "",
          "value": ""
        }
      ],
      "procedures": [
        {
          "bodySite": "",
          "id": 0,
          "type": ""
        }
      ],
      "status": ""
    }
  ],
  "groupCode": "",
  "identifier": "",
  "observations": [
    {}
  ],
  "patient": {
    "address1": "",
    "address2": "",
    "address3": "",
    "address4": "",
    "contacts": [
      {
        "id": 0,
        "system": "",
        "use": "",
        "value": ""
      }
    ],
    "dateOfBirth": "",
    "dateOfBirthNoTime": "",
    "forename": "",
    "gender": "",
    "group": {},
    "groupCode": "",
    "identifier": "",
    "identifiers": [
      {
        "id": 0,
        "label": "",
        "value": ""
      }
    ],
    "postcode": "",
    "practitioners": [
      {
        "address1": "",
        "address2": "",
        "address3": "",
        "address4": "",
        "allowInviteGp": false,
        "contacts": [
          {}
        ],
        "gender": "",
        "groupCode": "",
        "identifier": "",
        "inviteDate": "",
        "name": "",
        "postcode": "",
        "role": ""
      }
    ],
    "surname": ""
  },
  "practitioners": [
    {}
  ]
}'
echo '{
  "condition": {
    "asserter": "",
    "category": "",
    "code": "",
    "date": "",
    "description": "",
    "fullDescription": "",
    "group": {
      "address1": "",
      "address2": "",
      "address3": "",
      "childGroups": [],
      "code": "",
      "contactPoints": [
        {
          "contactPointType": {
            "description": "",
            "id": 0,
            "lookupType": {
              "created": "",
              "description": "",
              "id": 0,
              "lastUpdate": "",
              "type": ""
            },
            "value": ""
          },
          "content": "",
          "created": "",
          "id": 0,
          "lastUpdate": ""
        }
      ],
      "created": "",
      "fhirResourceId": "",
      "groupFeatures": [
        {
          "created": "",
          "feature": {
            "created": "",
            "description": "",
            "id": 0,
            "lastUpdate": "",
            "name": ""
          },
          "id": 0,
          "lastUpdate": ""
        }
      ],
      "groupType": {
        "created": "",
        "description": "",
        "descriptionFriendly": "",
        "displayOrder": 0,
        "id": 0,
        "lastUpdate": "",
        "lookupType": {},
        "value": ""
      },
      "id": 0,
      "lastImportDate": "",
      "lastUpdate": "",
      "links": [
        {
          "created": "",
          "displayOrder": 0,
          "id": 0,
          "lastUpdate": "",
          "link": "",
          "linkType": {},
          "name": ""
        }
      ],
      "locations": [
        {
          "address": "",
          "created": "",
          "email": "",
          "id": 0,
          "label": "",
          "lastUpdate": "",
          "name": "",
          "phone": "",
          "web": ""
        }
      ],
      "name": "",
      "parentGroups": [],
      "postcode": "",
      "sftpUser": "",
      "shortName": "",
      "visible": false,
      "visibleToJoin": false
    },
    "id": 0,
    "identifier": "",
    "links": [
      {}
    ],
    "notes": "",
    "severity": "",
    "status": ""
  },
  "encounters": [
    {
      "date": "",
      "encounterType": "",
      "group": {},
      "id": 0,
      "identifier": "",
      "links": [
        {}
      ],
      "observations": [
        {
          "applies": "",
          "bodySite": "",
          "comments": "",
          "comparator": "",
          "diagram": "",
          "group": {},
          "id": 0,
          "identifier": "",
          "location": "",
          "name": "",
          "temporaryUuid": "",
          "units": "",
          "value": ""
        }
      ],
      "procedures": [
        {
          "bodySite": "",
          "id": 0,
          "type": ""
        }
      ],
      "status": ""
    }
  ],
  "groupCode": "",
  "identifier": "",
  "observations": [
    {}
  ],
  "patient": {
    "address1": "",
    "address2": "",
    "address3": "",
    "address4": "",
    "contacts": [
      {
        "id": 0,
        "system": "",
        "use": "",
        "value": ""
      }
    ],
    "dateOfBirth": "",
    "dateOfBirthNoTime": "",
    "forename": "",
    "gender": "",
    "group": {},
    "groupCode": "",
    "identifier": "",
    "identifiers": [
      {
        "id": 0,
        "label": "",
        "value": ""
      }
    ],
    "postcode": "",
    "practitioners": [
      {
        "address1": "",
        "address2": "",
        "address3": "",
        "address4": "",
        "allowInviteGp": false,
        "contacts": [
          {}
        ],
        "gender": "",
        "groupCode": "",
        "identifier": "",
        "inviteDate": "",
        "name": "",
        "postcode": "",
        "role": ""
      }
    ],
    "surname": ""
  },
  "practitioners": [
    {}
  ]
}' |  \
  http POST {{baseUrl}}/patientmanagement/:userId/group/:groupId/identifier/:identifierId/surgeries \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "condition": {\n    "asserter": "",\n    "category": "",\n    "code": "",\n    "date": "",\n    "description": "",\n    "fullDescription": "",\n    "group": {\n      "address1": "",\n      "address2": "",\n      "address3": "",\n      "childGroups": [],\n      "code": "",\n      "contactPoints": [\n        {\n          "contactPointType": {\n            "description": "",\n            "id": 0,\n            "lookupType": {\n              "created": "",\n              "description": "",\n              "id": 0,\n              "lastUpdate": "",\n              "type": ""\n            },\n            "value": ""\n          },\n          "content": "",\n          "created": "",\n          "id": 0,\n          "lastUpdate": ""\n        }\n      ],\n      "created": "",\n      "fhirResourceId": "",\n      "groupFeatures": [\n        {\n          "created": "",\n          "feature": {\n            "created": "",\n            "description": "",\n            "id": 0,\n            "lastUpdate": "",\n            "name": ""\n          },\n          "id": 0,\n          "lastUpdate": ""\n        }\n      ],\n      "groupType": {\n        "created": "",\n        "description": "",\n        "descriptionFriendly": "",\n        "displayOrder": 0,\n        "id": 0,\n        "lastUpdate": "",\n        "lookupType": {},\n        "value": ""\n      },\n      "id": 0,\n      "lastImportDate": "",\n      "lastUpdate": "",\n      "links": [\n        {\n          "created": "",\n          "displayOrder": 0,\n          "id": 0,\n          "lastUpdate": "",\n          "link": "",\n          "linkType": {},\n          "name": ""\n        }\n      ],\n      "locations": [\n        {\n          "address": "",\n          "created": "",\n          "email": "",\n          "id": 0,\n          "label": "",\n          "lastUpdate": "",\n          "name": "",\n          "phone": "",\n          "web": ""\n        }\n      ],\n      "name": "",\n      "parentGroups": [],\n      "postcode": "",\n      "sftpUser": "",\n      "shortName": "",\n      "visible": false,\n      "visibleToJoin": false\n    },\n    "id": 0,\n    "identifier": "",\n    "links": [\n      {}\n    ],\n    "notes": "",\n    "severity": "",\n    "status": ""\n  },\n  "encounters": [\n    {\n      "date": "",\n      "encounterType": "",\n      "group": {},\n      "id": 0,\n      "identifier": "",\n      "links": [\n        {}\n      ],\n      "observations": [\n        {\n          "applies": "",\n          "bodySite": "",\n          "comments": "",\n          "comparator": "",\n          "diagram": "",\n          "group": {},\n          "id": 0,\n          "identifier": "",\n          "location": "",\n          "name": "",\n          "temporaryUuid": "",\n          "units": "",\n          "value": ""\n        }\n      ],\n      "procedures": [\n        {\n          "bodySite": "",\n          "id": 0,\n          "type": ""\n        }\n      ],\n      "status": ""\n    }\n  ],\n  "groupCode": "",\n  "identifier": "",\n  "observations": [\n    {}\n  ],\n  "patient": {\n    "address1": "",\n    "address2": "",\n    "address3": "",\n    "address4": "",\n    "contacts": [\n      {\n        "id": 0,\n        "system": "",\n        "use": "",\n        "value": ""\n      }\n    ],\n    "dateOfBirth": "",\n    "dateOfBirthNoTime": "",\n    "forename": "",\n    "gender": "",\n    "group": {},\n    "groupCode": "",\n    "identifier": "",\n    "identifiers": [\n      {\n        "id": 0,\n        "label": "",\n        "value": ""\n      }\n    ],\n    "postcode": "",\n    "practitioners": [\n      {\n        "address1": "",\n        "address2": "",\n        "address3": "",\n        "address4": "",\n        "allowInviteGp": false,\n        "contacts": [\n          {}\n        ],\n        "gender": "",\n        "groupCode": "",\n        "identifier": "",\n        "inviteDate": "",\n        "name": "",\n        "postcode": "",\n        "role": ""\n      }\n    ],\n    "surname": ""\n  },\n  "practitioners": [\n    {}\n  ]\n}' \
  --output-document \
  - {{baseUrl}}/patientmanagement/:userId/group/:groupId/identifier/:identifierId/surgeries
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "condition": [
    "asserter": "",
    "category": "",
    "code": "",
    "date": "",
    "description": "",
    "fullDescription": "",
    "group": [
      "address1": "",
      "address2": "",
      "address3": "",
      "childGroups": [],
      "code": "",
      "contactPoints": [
        [
          "contactPointType": [
            "description": "",
            "id": 0,
            "lookupType": [
              "created": "",
              "description": "",
              "id": 0,
              "lastUpdate": "",
              "type": ""
            ],
            "value": ""
          ],
          "content": "",
          "created": "",
          "id": 0,
          "lastUpdate": ""
        ]
      ],
      "created": "",
      "fhirResourceId": "",
      "groupFeatures": [
        [
          "created": "",
          "feature": [
            "created": "",
            "description": "",
            "id": 0,
            "lastUpdate": "",
            "name": ""
          ],
          "id": 0,
          "lastUpdate": ""
        ]
      ],
      "groupType": [
        "created": "",
        "description": "",
        "descriptionFriendly": "",
        "displayOrder": 0,
        "id": 0,
        "lastUpdate": "",
        "lookupType": [],
        "value": ""
      ],
      "id": 0,
      "lastImportDate": "",
      "lastUpdate": "",
      "links": [
        [
          "created": "",
          "displayOrder": 0,
          "id": 0,
          "lastUpdate": "",
          "link": "",
          "linkType": [],
          "name": ""
        ]
      ],
      "locations": [
        [
          "address": "",
          "created": "",
          "email": "",
          "id": 0,
          "label": "",
          "lastUpdate": "",
          "name": "",
          "phone": "",
          "web": ""
        ]
      ],
      "name": "",
      "parentGroups": [],
      "postcode": "",
      "sftpUser": "",
      "shortName": "",
      "visible": false,
      "visibleToJoin": false
    ],
    "id": 0,
    "identifier": "",
    "links": [[]],
    "notes": "",
    "severity": "",
    "status": ""
  ],
  "encounters": [
    [
      "date": "",
      "encounterType": "",
      "group": [],
      "id": 0,
      "identifier": "",
      "links": [[]],
      "observations": [
        [
          "applies": "",
          "bodySite": "",
          "comments": "",
          "comparator": "",
          "diagram": "",
          "group": [],
          "id": 0,
          "identifier": "",
          "location": "",
          "name": "",
          "temporaryUuid": "",
          "units": "",
          "value": ""
        ]
      ],
      "procedures": [
        [
          "bodySite": "",
          "id": 0,
          "type": ""
        ]
      ],
      "status": ""
    ]
  ],
  "groupCode": "",
  "identifier": "",
  "observations": [[]],
  "patient": [
    "address1": "",
    "address2": "",
    "address3": "",
    "address4": "",
    "contacts": [
      [
        "id": 0,
        "system": "",
        "use": "",
        "value": ""
      ]
    ],
    "dateOfBirth": "",
    "dateOfBirthNoTime": "",
    "forename": "",
    "gender": "",
    "group": [],
    "groupCode": "",
    "identifier": "",
    "identifiers": [
      [
        "id": 0,
        "label": "",
        "value": ""
      ]
    ],
    "postcode": "",
    "practitioners": [
      [
        "address1": "",
        "address2": "",
        "address3": "",
        "address4": "",
        "allowInviteGp": false,
        "contacts": [[]],
        "gender": "",
        "groupCode": "",
        "identifier": "",
        "inviteDate": "",
        "name": "",
        "postcode": "",
        "role": ""
      ]
    ],
    "surname": ""
  ],
  "practitioners": [[]]
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/patientmanagement/:userId/group/:groupId/identifier/:identifierId/surgeries")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST validatePatientManagement
{{baseUrl}}/patientmanagement/validate
BODY json

{
  "condition": {
    "asserter": "",
    "category": "",
    "code": "",
    "date": "",
    "description": "",
    "fullDescription": "",
    "group": {
      "address1": "",
      "address2": "",
      "address3": "",
      "childGroups": [],
      "code": "",
      "contactPoints": [
        {
          "contactPointType": {
            "description": "",
            "id": 0,
            "lookupType": {
              "created": "",
              "description": "",
              "id": 0,
              "lastUpdate": "",
              "type": ""
            },
            "value": ""
          },
          "content": "",
          "created": "",
          "id": 0,
          "lastUpdate": ""
        }
      ],
      "created": "",
      "fhirResourceId": "",
      "groupFeatures": [
        {
          "created": "",
          "feature": {
            "created": "",
            "description": "",
            "id": 0,
            "lastUpdate": "",
            "name": ""
          },
          "id": 0,
          "lastUpdate": ""
        }
      ],
      "groupType": {
        "created": "",
        "description": "",
        "descriptionFriendly": "",
        "displayOrder": 0,
        "id": 0,
        "lastUpdate": "",
        "lookupType": {},
        "value": ""
      },
      "id": 0,
      "lastImportDate": "",
      "lastUpdate": "",
      "links": [
        {
          "created": "",
          "displayOrder": 0,
          "id": 0,
          "lastUpdate": "",
          "link": "",
          "linkType": {},
          "name": ""
        }
      ],
      "locations": [
        {
          "address": "",
          "created": "",
          "email": "",
          "id": 0,
          "label": "",
          "lastUpdate": "",
          "name": "",
          "phone": "",
          "web": ""
        }
      ],
      "name": "",
      "parentGroups": [],
      "postcode": "",
      "sftpUser": "",
      "shortName": "",
      "visible": false,
      "visibleToJoin": false
    },
    "id": 0,
    "identifier": "",
    "links": [
      {}
    ],
    "notes": "",
    "severity": "",
    "status": ""
  },
  "encounters": [
    {
      "date": "",
      "encounterType": "",
      "group": {},
      "id": 0,
      "identifier": "",
      "links": [
        {}
      ],
      "observations": [
        {
          "applies": "",
          "bodySite": "",
          "comments": "",
          "comparator": "",
          "diagram": "",
          "group": {},
          "id": 0,
          "identifier": "",
          "location": "",
          "name": "",
          "temporaryUuid": "",
          "units": "",
          "value": ""
        }
      ],
      "procedures": [
        {
          "bodySite": "",
          "id": 0,
          "type": ""
        }
      ],
      "status": ""
    }
  ],
  "groupCode": "",
  "identifier": "",
  "observations": [
    {}
  ],
  "patient": {
    "address1": "",
    "address2": "",
    "address3": "",
    "address4": "",
    "contacts": [
      {
        "id": 0,
        "system": "",
        "use": "",
        "value": ""
      }
    ],
    "dateOfBirth": "",
    "dateOfBirthNoTime": "",
    "forename": "",
    "gender": "",
    "group": {},
    "groupCode": "",
    "identifier": "",
    "identifiers": [
      {
        "id": 0,
        "label": "",
        "value": ""
      }
    ],
    "postcode": "",
    "practitioners": [
      {
        "address1": "",
        "address2": "",
        "address3": "",
        "address4": "",
        "allowInviteGp": false,
        "contacts": [
          {}
        ],
        "gender": "",
        "groupCode": "",
        "identifier": "",
        "inviteDate": "",
        "name": "",
        "postcode": "",
        "role": ""
      }
    ],
    "surname": ""
  },
  "practitioners": [
    {}
  ]
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/patientmanagement/validate");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"condition\": {\n    \"asserter\": \"\",\n    \"category\": \"\",\n    \"code\": \"\",\n    \"date\": \"\",\n    \"description\": \"\",\n    \"fullDescription\": \"\",\n    \"group\": {\n      \"address1\": \"\",\n      \"address2\": \"\",\n      \"address3\": \"\",\n      \"childGroups\": [],\n      \"code\": \"\",\n      \"contactPoints\": [\n        {\n          \"contactPointType\": {\n            \"description\": \"\",\n            \"id\": 0,\n            \"lookupType\": {\n              \"created\": \"\",\n              \"description\": \"\",\n              \"id\": 0,\n              \"lastUpdate\": \"\",\n              \"type\": \"\"\n            },\n            \"value\": \"\"\n          },\n          \"content\": \"\",\n          \"created\": \"\",\n          \"id\": 0,\n          \"lastUpdate\": \"\"\n        }\n      ],\n      \"created\": \"\",\n      \"fhirResourceId\": \"\",\n      \"groupFeatures\": [\n        {\n          \"created\": \"\",\n          \"feature\": {\n            \"created\": \"\",\n            \"description\": \"\",\n            \"id\": 0,\n            \"lastUpdate\": \"\",\n            \"name\": \"\"\n          },\n          \"id\": 0,\n          \"lastUpdate\": \"\"\n        }\n      ],\n      \"groupType\": {\n        \"created\": \"\",\n        \"description\": \"\",\n        \"descriptionFriendly\": \"\",\n        \"displayOrder\": 0,\n        \"id\": 0,\n        \"lastUpdate\": \"\",\n        \"lookupType\": {},\n        \"value\": \"\"\n      },\n      \"id\": 0,\n      \"lastImportDate\": \"\",\n      \"lastUpdate\": \"\",\n      \"links\": [\n        {\n          \"created\": \"\",\n          \"displayOrder\": 0,\n          \"id\": 0,\n          \"lastUpdate\": \"\",\n          \"link\": \"\",\n          \"linkType\": {},\n          \"name\": \"\"\n        }\n      ],\n      \"locations\": [\n        {\n          \"address\": \"\",\n          \"created\": \"\",\n          \"email\": \"\",\n          \"id\": 0,\n          \"label\": \"\",\n          \"lastUpdate\": \"\",\n          \"name\": \"\",\n          \"phone\": \"\",\n          \"web\": \"\"\n        }\n      ],\n      \"name\": \"\",\n      \"parentGroups\": [],\n      \"postcode\": \"\",\n      \"sftpUser\": \"\",\n      \"shortName\": \"\",\n      \"visible\": false,\n      \"visibleToJoin\": false\n    },\n    \"id\": 0,\n    \"identifier\": \"\",\n    \"links\": [\n      {}\n    ],\n    \"notes\": \"\",\n    \"severity\": \"\",\n    \"status\": \"\"\n  },\n  \"encounters\": [\n    {\n      \"date\": \"\",\n      \"encounterType\": \"\",\n      \"group\": {},\n      \"id\": 0,\n      \"identifier\": \"\",\n      \"links\": [\n        {}\n      ],\n      \"observations\": [\n        {\n          \"applies\": \"\",\n          \"bodySite\": \"\",\n          \"comments\": \"\",\n          \"comparator\": \"\",\n          \"diagram\": \"\",\n          \"group\": {},\n          \"id\": 0,\n          \"identifier\": \"\",\n          \"location\": \"\",\n          \"name\": \"\",\n          \"temporaryUuid\": \"\",\n          \"units\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"procedures\": [\n        {\n          \"bodySite\": \"\",\n          \"id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"status\": \"\"\n    }\n  ],\n  \"groupCode\": \"\",\n  \"identifier\": \"\",\n  \"observations\": [\n    {}\n  ],\n  \"patient\": {\n    \"address1\": \"\",\n    \"address2\": \"\",\n    \"address3\": \"\",\n    \"address4\": \"\",\n    \"contacts\": [\n      {\n        \"id\": 0,\n        \"system\": \"\",\n        \"use\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"dateOfBirth\": \"\",\n    \"dateOfBirthNoTime\": \"\",\n    \"forename\": \"\",\n    \"gender\": \"\",\n    \"group\": {},\n    \"groupCode\": \"\",\n    \"identifier\": \"\",\n    \"identifiers\": [\n      {\n        \"id\": 0,\n        \"label\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"postcode\": \"\",\n    \"practitioners\": [\n      {\n        \"address1\": \"\",\n        \"address2\": \"\",\n        \"address3\": \"\",\n        \"address4\": \"\",\n        \"allowInviteGp\": false,\n        \"contacts\": [\n          {}\n        ],\n        \"gender\": \"\",\n        \"groupCode\": \"\",\n        \"identifier\": \"\",\n        \"inviteDate\": \"\",\n        \"name\": \"\",\n        \"postcode\": \"\",\n        \"role\": \"\"\n      }\n    ],\n    \"surname\": \"\"\n  },\n  \"practitioners\": [\n    {}\n  ]\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/patientmanagement/validate" {:content-type :json
                                                                       :form-params {:condition {:asserter ""
                                                                                                 :category ""
                                                                                                 :code ""
                                                                                                 :date ""
                                                                                                 :description ""
                                                                                                 :fullDescription ""
                                                                                                 :group {:address1 ""
                                                                                                         :address2 ""
                                                                                                         :address3 ""
                                                                                                         :childGroups []
                                                                                                         :code ""
                                                                                                         :contactPoints [{:contactPointType {:description ""
                                                                                                                                             :id 0
                                                                                                                                             :lookupType {:created ""
                                                                                                                                                          :description ""
                                                                                                                                                          :id 0
                                                                                                                                                          :lastUpdate ""
                                                                                                                                                          :type ""}
                                                                                                                                             :value ""}
                                                                                                                          :content ""
                                                                                                                          :created ""
                                                                                                                          :id 0
                                                                                                                          :lastUpdate ""}]
                                                                                                         :created ""
                                                                                                         :fhirResourceId ""
                                                                                                         :groupFeatures [{:created ""
                                                                                                                          :feature {:created ""
                                                                                                                                    :description ""
                                                                                                                                    :id 0
                                                                                                                                    :lastUpdate ""
                                                                                                                                    :name ""}
                                                                                                                          :id 0
                                                                                                                          :lastUpdate ""}]
                                                                                                         :groupType {:created ""
                                                                                                                     :description ""
                                                                                                                     :descriptionFriendly ""
                                                                                                                     :displayOrder 0
                                                                                                                     :id 0
                                                                                                                     :lastUpdate ""
                                                                                                                     :lookupType {}
                                                                                                                     :value ""}
                                                                                                         :id 0
                                                                                                         :lastImportDate ""
                                                                                                         :lastUpdate ""
                                                                                                         :links [{:created ""
                                                                                                                  :displayOrder 0
                                                                                                                  :id 0
                                                                                                                  :lastUpdate ""
                                                                                                                  :link ""
                                                                                                                  :linkType {}
                                                                                                                  :name ""}]
                                                                                                         :locations [{:address ""
                                                                                                                      :created ""
                                                                                                                      :email ""
                                                                                                                      :id 0
                                                                                                                      :label ""
                                                                                                                      :lastUpdate ""
                                                                                                                      :name ""
                                                                                                                      :phone ""
                                                                                                                      :web ""}]
                                                                                                         :name ""
                                                                                                         :parentGroups []
                                                                                                         :postcode ""
                                                                                                         :sftpUser ""
                                                                                                         :shortName ""
                                                                                                         :visible false
                                                                                                         :visibleToJoin false}
                                                                                                 :id 0
                                                                                                 :identifier ""
                                                                                                 :links [{}]
                                                                                                 :notes ""
                                                                                                 :severity ""
                                                                                                 :status ""}
                                                                                     :encounters [{:date ""
                                                                                                   :encounterType ""
                                                                                                   :group {}
                                                                                                   :id 0
                                                                                                   :identifier ""
                                                                                                   :links [{}]
                                                                                                   :observations [{:applies ""
                                                                                                                   :bodySite ""
                                                                                                                   :comments ""
                                                                                                                   :comparator ""
                                                                                                                   :diagram ""
                                                                                                                   :group {}
                                                                                                                   :id 0
                                                                                                                   :identifier ""
                                                                                                                   :location ""
                                                                                                                   :name ""
                                                                                                                   :temporaryUuid ""
                                                                                                                   :units ""
                                                                                                                   :value ""}]
                                                                                                   :procedures [{:bodySite ""
                                                                                                                 :id 0
                                                                                                                 :type ""}]
                                                                                                   :status ""}]
                                                                                     :groupCode ""
                                                                                     :identifier ""
                                                                                     :observations [{}]
                                                                                     :patient {:address1 ""
                                                                                               :address2 ""
                                                                                               :address3 ""
                                                                                               :address4 ""
                                                                                               :contacts [{:id 0
                                                                                                           :system ""
                                                                                                           :use ""
                                                                                                           :value ""}]
                                                                                               :dateOfBirth ""
                                                                                               :dateOfBirthNoTime ""
                                                                                               :forename ""
                                                                                               :gender ""
                                                                                               :group {}
                                                                                               :groupCode ""
                                                                                               :identifier ""
                                                                                               :identifiers [{:id 0
                                                                                                              :label ""
                                                                                                              :value ""}]
                                                                                               :postcode ""
                                                                                               :practitioners [{:address1 ""
                                                                                                                :address2 ""
                                                                                                                :address3 ""
                                                                                                                :address4 ""
                                                                                                                :allowInviteGp false
                                                                                                                :contacts [{}]
                                                                                                                :gender ""
                                                                                                                :groupCode ""
                                                                                                                :identifier ""
                                                                                                                :inviteDate ""
                                                                                                                :name ""
                                                                                                                :postcode ""
                                                                                                                :role ""}]
                                                                                               :surname ""}
                                                                                     :practitioners [{}]}})
require "http/client"

url = "{{baseUrl}}/patientmanagement/validate"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"condition\": {\n    \"asserter\": \"\",\n    \"category\": \"\",\n    \"code\": \"\",\n    \"date\": \"\",\n    \"description\": \"\",\n    \"fullDescription\": \"\",\n    \"group\": {\n      \"address1\": \"\",\n      \"address2\": \"\",\n      \"address3\": \"\",\n      \"childGroups\": [],\n      \"code\": \"\",\n      \"contactPoints\": [\n        {\n          \"contactPointType\": {\n            \"description\": \"\",\n            \"id\": 0,\n            \"lookupType\": {\n              \"created\": \"\",\n              \"description\": \"\",\n              \"id\": 0,\n              \"lastUpdate\": \"\",\n              \"type\": \"\"\n            },\n            \"value\": \"\"\n          },\n          \"content\": \"\",\n          \"created\": \"\",\n          \"id\": 0,\n          \"lastUpdate\": \"\"\n        }\n      ],\n      \"created\": \"\",\n      \"fhirResourceId\": \"\",\n      \"groupFeatures\": [\n        {\n          \"created\": \"\",\n          \"feature\": {\n            \"created\": \"\",\n            \"description\": \"\",\n            \"id\": 0,\n            \"lastUpdate\": \"\",\n            \"name\": \"\"\n          },\n          \"id\": 0,\n          \"lastUpdate\": \"\"\n        }\n      ],\n      \"groupType\": {\n        \"created\": \"\",\n        \"description\": \"\",\n        \"descriptionFriendly\": \"\",\n        \"displayOrder\": 0,\n        \"id\": 0,\n        \"lastUpdate\": \"\",\n        \"lookupType\": {},\n        \"value\": \"\"\n      },\n      \"id\": 0,\n      \"lastImportDate\": \"\",\n      \"lastUpdate\": \"\",\n      \"links\": [\n        {\n          \"created\": \"\",\n          \"displayOrder\": 0,\n          \"id\": 0,\n          \"lastUpdate\": \"\",\n          \"link\": \"\",\n          \"linkType\": {},\n          \"name\": \"\"\n        }\n      ],\n      \"locations\": [\n        {\n          \"address\": \"\",\n          \"created\": \"\",\n          \"email\": \"\",\n          \"id\": 0,\n          \"label\": \"\",\n          \"lastUpdate\": \"\",\n          \"name\": \"\",\n          \"phone\": \"\",\n          \"web\": \"\"\n        }\n      ],\n      \"name\": \"\",\n      \"parentGroups\": [],\n      \"postcode\": \"\",\n      \"sftpUser\": \"\",\n      \"shortName\": \"\",\n      \"visible\": false,\n      \"visibleToJoin\": false\n    },\n    \"id\": 0,\n    \"identifier\": \"\",\n    \"links\": [\n      {}\n    ],\n    \"notes\": \"\",\n    \"severity\": \"\",\n    \"status\": \"\"\n  },\n  \"encounters\": [\n    {\n      \"date\": \"\",\n      \"encounterType\": \"\",\n      \"group\": {},\n      \"id\": 0,\n      \"identifier\": \"\",\n      \"links\": [\n        {}\n      ],\n      \"observations\": [\n        {\n          \"applies\": \"\",\n          \"bodySite\": \"\",\n          \"comments\": \"\",\n          \"comparator\": \"\",\n          \"diagram\": \"\",\n          \"group\": {},\n          \"id\": 0,\n          \"identifier\": \"\",\n          \"location\": \"\",\n          \"name\": \"\",\n          \"temporaryUuid\": \"\",\n          \"units\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"procedures\": [\n        {\n          \"bodySite\": \"\",\n          \"id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"status\": \"\"\n    }\n  ],\n  \"groupCode\": \"\",\n  \"identifier\": \"\",\n  \"observations\": [\n    {}\n  ],\n  \"patient\": {\n    \"address1\": \"\",\n    \"address2\": \"\",\n    \"address3\": \"\",\n    \"address4\": \"\",\n    \"contacts\": [\n      {\n        \"id\": 0,\n        \"system\": \"\",\n        \"use\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"dateOfBirth\": \"\",\n    \"dateOfBirthNoTime\": \"\",\n    \"forename\": \"\",\n    \"gender\": \"\",\n    \"group\": {},\n    \"groupCode\": \"\",\n    \"identifier\": \"\",\n    \"identifiers\": [\n      {\n        \"id\": 0,\n        \"label\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"postcode\": \"\",\n    \"practitioners\": [\n      {\n        \"address1\": \"\",\n        \"address2\": \"\",\n        \"address3\": \"\",\n        \"address4\": \"\",\n        \"allowInviteGp\": false,\n        \"contacts\": [\n          {}\n        ],\n        \"gender\": \"\",\n        \"groupCode\": \"\",\n        \"identifier\": \"\",\n        \"inviteDate\": \"\",\n        \"name\": \"\",\n        \"postcode\": \"\",\n        \"role\": \"\"\n      }\n    ],\n    \"surname\": \"\"\n  },\n  \"practitioners\": [\n    {}\n  ]\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/patientmanagement/validate"),
    Content = new StringContent("{\n  \"condition\": {\n    \"asserter\": \"\",\n    \"category\": \"\",\n    \"code\": \"\",\n    \"date\": \"\",\n    \"description\": \"\",\n    \"fullDescription\": \"\",\n    \"group\": {\n      \"address1\": \"\",\n      \"address2\": \"\",\n      \"address3\": \"\",\n      \"childGroups\": [],\n      \"code\": \"\",\n      \"contactPoints\": [\n        {\n          \"contactPointType\": {\n            \"description\": \"\",\n            \"id\": 0,\n            \"lookupType\": {\n              \"created\": \"\",\n              \"description\": \"\",\n              \"id\": 0,\n              \"lastUpdate\": \"\",\n              \"type\": \"\"\n            },\n            \"value\": \"\"\n          },\n          \"content\": \"\",\n          \"created\": \"\",\n          \"id\": 0,\n          \"lastUpdate\": \"\"\n        }\n      ],\n      \"created\": \"\",\n      \"fhirResourceId\": \"\",\n      \"groupFeatures\": [\n        {\n          \"created\": \"\",\n          \"feature\": {\n            \"created\": \"\",\n            \"description\": \"\",\n            \"id\": 0,\n            \"lastUpdate\": \"\",\n            \"name\": \"\"\n          },\n          \"id\": 0,\n          \"lastUpdate\": \"\"\n        }\n      ],\n      \"groupType\": {\n        \"created\": \"\",\n        \"description\": \"\",\n        \"descriptionFriendly\": \"\",\n        \"displayOrder\": 0,\n        \"id\": 0,\n        \"lastUpdate\": \"\",\n        \"lookupType\": {},\n        \"value\": \"\"\n      },\n      \"id\": 0,\n      \"lastImportDate\": \"\",\n      \"lastUpdate\": \"\",\n      \"links\": [\n        {\n          \"created\": \"\",\n          \"displayOrder\": 0,\n          \"id\": 0,\n          \"lastUpdate\": \"\",\n          \"link\": \"\",\n          \"linkType\": {},\n          \"name\": \"\"\n        }\n      ],\n      \"locations\": [\n        {\n          \"address\": \"\",\n          \"created\": \"\",\n          \"email\": \"\",\n          \"id\": 0,\n          \"label\": \"\",\n          \"lastUpdate\": \"\",\n          \"name\": \"\",\n          \"phone\": \"\",\n          \"web\": \"\"\n        }\n      ],\n      \"name\": \"\",\n      \"parentGroups\": [],\n      \"postcode\": \"\",\n      \"sftpUser\": \"\",\n      \"shortName\": \"\",\n      \"visible\": false,\n      \"visibleToJoin\": false\n    },\n    \"id\": 0,\n    \"identifier\": \"\",\n    \"links\": [\n      {}\n    ],\n    \"notes\": \"\",\n    \"severity\": \"\",\n    \"status\": \"\"\n  },\n  \"encounters\": [\n    {\n      \"date\": \"\",\n      \"encounterType\": \"\",\n      \"group\": {},\n      \"id\": 0,\n      \"identifier\": \"\",\n      \"links\": [\n        {}\n      ],\n      \"observations\": [\n        {\n          \"applies\": \"\",\n          \"bodySite\": \"\",\n          \"comments\": \"\",\n          \"comparator\": \"\",\n          \"diagram\": \"\",\n          \"group\": {},\n          \"id\": 0,\n          \"identifier\": \"\",\n          \"location\": \"\",\n          \"name\": \"\",\n          \"temporaryUuid\": \"\",\n          \"units\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"procedures\": [\n        {\n          \"bodySite\": \"\",\n          \"id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"status\": \"\"\n    }\n  ],\n  \"groupCode\": \"\",\n  \"identifier\": \"\",\n  \"observations\": [\n    {}\n  ],\n  \"patient\": {\n    \"address1\": \"\",\n    \"address2\": \"\",\n    \"address3\": \"\",\n    \"address4\": \"\",\n    \"contacts\": [\n      {\n        \"id\": 0,\n        \"system\": \"\",\n        \"use\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"dateOfBirth\": \"\",\n    \"dateOfBirthNoTime\": \"\",\n    \"forename\": \"\",\n    \"gender\": \"\",\n    \"group\": {},\n    \"groupCode\": \"\",\n    \"identifier\": \"\",\n    \"identifiers\": [\n      {\n        \"id\": 0,\n        \"label\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"postcode\": \"\",\n    \"practitioners\": [\n      {\n        \"address1\": \"\",\n        \"address2\": \"\",\n        \"address3\": \"\",\n        \"address4\": \"\",\n        \"allowInviteGp\": false,\n        \"contacts\": [\n          {}\n        ],\n        \"gender\": \"\",\n        \"groupCode\": \"\",\n        \"identifier\": \"\",\n        \"inviteDate\": \"\",\n        \"name\": \"\",\n        \"postcode\": \"\",\n        \"role\": \"\"\n      }\n    ],\n    \"surname\": \"\"\n  },\n  \"practitioners\": [\n    {}\n  ]\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/patientmanagement/validate");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"condition\": {\n    \"asserter\": \"\",\n    \"category\": \"\",\n    \"code\": \"\",\n    \"date\": \"\",\n    \"description\": \"\",\n    \"fullDescription\": \"\",\n    \"group\": {\n      \"address1\": \"\",\n      \"address2\": \"\",\n      \"address3\": \"\",\n      \"childGroups\": [],\n      \"code\": \"\",\n      \"contactPoints\": [\n        {\n          \"contactPointType\": {\n            \"description\": \"\",\n            \"id\": 0,\n            \"lookupType\": {\n              \"created\": \"\",\n              \"description\": \"\",\n              \"id\": 0,\n              \"lastUpdate\": \"\",\n              \"type\": \"\"\n            },\n            \"value\": \"\"\n          },\n          \"content\": \"\",\n          \"created\": \"\",\n          \"id\": 0,\n          \"lastUpdate\": \"\"\n        }\n      ],\n      \"created\": \"\",\n      \"fhirResourceId\": \"\",\n      \"groupFeatures\": [\n        {\n          \"created\": \"\",\n          \"feature\": {\n            \"created\": \"\",\n            \"description\": \"\",\n            \"id\": 0,\n            \"lastUpdate\": \"\",\n            \"name\": \"\"\n          },\n          \"id\": 0,\n          \"lastUpdate\": \"\"\n        }\n      ],\n      \"groupType\": {\n        \"created\": \"\",\n        \"description\": \"\",\n        \"descriptionFriendly\": \"\",\n        \"displayOrder\": 0,\n        \"id\": 0,\n        \"lastUpdate\": \"\",\n        \"lookupType\": {},\n        \"value\": \"\"\n      },\n      \"id\": 0,\n      \"lastImportDate\": \"\",\n      \"lastUpdate\": \"\",\n      \"links\": [\n        {\n          \"created\": \"\",\n          \"displayOrder\": 0,\n          \"id\": 0,\n          \"lastUpdate\": \"\",\n          \"link\": \"\",\n          \"linkType\": {},\n          \"name\": \"\"\n        }\n      ],\n      \"locations\": [\n        {\n          \"address\": \"\",\n          \"created\": \"\",\n          \"email\": \"\",\n          \"id\": 0,\n          \"label\": \"\",\n          \"lastUpdate\": \"\",\n          \"name\": \"\",\n          \"phone\": \"\",\n          \"web\": \"\"\n        }\n      ],\n      \"name\": \"\",\n      \"parentGroups\": [],\n      \"postcode\": \"\",\n      \"sftpUser\": \"\",\n      \"shortName\": \"\",\n      \"visible\": false,\n      \"visibleToJoin\": false\n    },\n    \"id\": 0,\n    \"identifier\": \"\",\n    \"links\": [\n      {}\n    ],\n    \"notes\": \"\",\n    \"severity\": \"\",\n    \"status\": \"\"\n  },\n  \"encounters\": [\n    {\n      \"date\": \"\",\n      \"encounterType\": \"\",\n      \"group\": {},\n      \"id\": 0,\n      \"identifier\": \"\",\n      \"links\": [\n        {}\n      ],\n      \"observations\": [\n        {\n          \"applies\": \"\",\n          \"bodySite\": \"\",\n          \"comments\": \"\",\n          \"comparator\": \"\",\n          \"diagram\": \"\",\n          \"group\": {},\n          \"id\": 0,\n          \"identifier\": \"\",\n          \"location\": \"\",\n          \"name\": \"\",\n          \"temporaryUuid\": \"\",\n          \"units\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"procedures\": [\n        {\n          \"bodySite\": \"\",\n          \"id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"status\": \"\"\n    }\n  ],\n  \"groupCode\": \"\",\n  \"identifier\": \"\",\n  \"observations\": [\n    {}\n  ],\n  \"patient\": {\n    \"address1\": \"\",\n    \"address2\": \"\",\n    \"address3\": \"\",\n    \"address4\": \"\",\n    \"contacts\": [\n      {\n        \"id\": 0,\n        \"system\": \"\",\n        \"use\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"dateOfBirth\": \"\",\n    \"dateOfBirthNoTime\": \"\",\n    \"forename\": \"\",\n    \"gender\": \"\",\n    \"group\": {},\n    \"groupCode\": \"\",\n    \"identifier\": \"\",\n    \"identifiers\": [\n      {\n        \"id\": 0,\n        \"label\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"postcode\": \"\",\n    \"practitioners\": [\n      {\n        \"address1\": \"\",\n        \"address2\": \"\",\n        \"address3\": \"\",\n        \"address4\": \"\",\n        \"allowInviteGp\": false,\n        \"contacts\": [\n          {}\n        ],\n        \"gender\": \"\",\n        \"groupCode\": \"\",\n        \"identifier\": \"\",\n        \"inviteDate\": \"\",\n        \"name\": \"\",\n        \"postcode\": \"\",\n        \"role\": \"\"\n      }\n    ],\n    \"surname\": \"\"\n  },\n  \"practitioners\": [\n    {}\n  ]\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/patientmanagement/validate"

	payload := strings.NewReader("{\n  \"condition\": {\n    \"asserter\": \"\",\n    \"category\": \"\",\n    \"code\": \"\",\n    \"date\": \"\",\n    \"description\": \"\",\n    \"fullDescription\": \"\",\n    \"group\": {\n      \"address1\": \"\",\n      \"address2\": \"\",\n      \"address3\": \"\",\n      \"childGroups\": [],\n      \"code\": \"\",\n      \"contactPoints\": [\n        {\n          \"contactPointType\": {\n            \"description\": \"\",\n            \"id\": 0,\n            \"lookupType\": {\n              \"created\": \"\",\n              \"description\": \"\",\n              \"id\": 0,\n              \"lastUpdate\": \"\",\n              \"type\": \"\"\n            },\n            \"value\": \"\"\n          },\n          \"content\": \"\",\n          \"created\": \"\",\n          \"id\": 0,\n          \"lastUpdate\": \"\"\n        }\n      ],\n      \"created\": \"\",\n      \"fhirResourceId\": \"\",\n      \"groupFeatures\": [\n        {\n          \"created\": \"\",\n          \"feature\": {\n            \"created\": \"\",\n            \"description\": \"\",\n            \"id\": 0,\n            \"lastUpdate\": \"\",\n            \"name\": \"\"\n          },\n          \"id\": 0,\n          \"lastUpdate\": \"\"\n        }\n      ],\n      \"groupType\": {\n        \"created\": \"\",\n        \"description\": \"\",\n        \"descriptionFriendly\": \"\",\n        \"displayOrder\": 0,\n        \"id\": 0,\n        \"lastUpdate\": \"\",\n        \"lookupType\": {},\n        \"value\": \"\"\n      },\n      \"id\": 0,\n      \"lastImportDate\": \"\",\n      \"lastUpdate\": \"\",\n      \"links\": [\n        {\n          \"created\": \"\",\n          \"displayOrder\": 0,\n          \"id\": 0,\n          \"lastUpdate\": \"\",\n          \"link\": \"\",\n          \"linkType\": {},\n          \"name\": \"\"\n        }\n      ],\n      \"locations\": [\n        {\n          \"address\": \"\",\n          \"created\": \"\",\n          \"email\": \"\",\n          \"id\": 0,\n          \"label\": \"\",\n          \"lastUpdate\": \"\",\n          \"name\": \"\",\n          \"phone\": \"\",\n          \"web\": \"\"\n        }\n      ],\n      \"name\": \"\",\n      \"parentGroups\": [],\n      \"postcode\": \"\",\n      \"sftpUser\": \"\",\n      \"shortName\": \"\",\n      \"visible\": false,\n      \"visibleToJoin\": false\n    },\n    \"id\": 0,\n    \"identifier\": \"\",\n    \"links\": [\n      {}\n    ],\n    \"notes\": \"\",\n    \"severity\": \"\",\n    \"status\": \"\"\n  },\n  \"encounters\": [\n    {\n      \"date\": \"\",\n      \"encounterType\": \"\",\n      \"group\": {},\n      \"id\": 0,\n      \"identifier\": \"\",\n      \"links\": [\n        {}\n      ],\n      \"observations\": [\n        {\n          \"applies\": \"\",\n          \"bodySite\": \"\",\n          \"comments\": \"\",\n          \"comparator\": \"\",\n          \"diagram\": \"\",\n          \"group\": {},\n          \"id\": 0,\n          \"identifier\": \"\",\n          \"location\": \"\",\n          \"name\": \"\",\n          \"temporaryUuid\": \"\",\n          \"units\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"procedures\": [\n        {\n          \"bodySite\": \"\",\n          \"id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"status\": \"\"\n    }\n  ],\n  \"groupCode\": \"\",\n  \"identifier\": \"\",\n  \"observations\": [\n    {}\n  ],\n  \"patient\": {\n    \"address1\": \"\",\n    \"address2\": \"\",\n    \"address3\": \"\",\n    \"address4\": \"\",\n    \"contacts\": [\n      {\n        \"id\": 0,\n        \"system\": \"\",\n        \"use\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"dateOfBirth\": \"\",\n    \"dateOfBirthNoTime\": \"\",\n    \"forename\": \"\",\n    \"gender\": \"\",\n    \"group\": {},\n    \"groupCode\": \"\",\n    \"identifier\": \"\",\n    \"identifiers\": [\n      {\n        \"id\": 0,\n        \"label\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"postcode\": \"\",\n    \"practitioners\": [\n      {\n        \"address1\": \"\",\n        \"address2\": \"\",\n        \"address3\": \"\",\n        \"address4\": \"\",\n        \"allowInviteGp\": false,\n        \"contacts\": [\n          {}\n        ],\n        \"gender\": \"\",\n        \"groupCode\": \"\",\n        \"identifier\": \"\",\n        \"inviteDate\": \"\",\n        \"name\": \"\",\n        \"postcode\": \"\",\n        \"role\": \"\"\n      }\n    ],\n    \"surname\": \"\"\n  },\n  \"practitioners\": [\n    {}\n  ]\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/patientmanagement/validate HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 3814

{
  "condition": {
    "asserter": "",
    "category": "",
    "code": "",
    "date": "",
    "description": "",
    "fullDescription": "",
    "group": {
      "address1": "",
      "address2": "",
      "address3": "",
      "childGroups": [],
      "code": "",
      "contactPoints": [
        {
          "contactPointType": {
            "description": "",
            "id": 0,
            "lookupType": {
              "created": "",
              "description": "",
              "id": 0,
              "lastUpdate": "",
              "type": ""
            },
            "value": ""
          },
          "content": "",
          "created": "",
          "id": 0,
          "lastUpdate": ""
        }
      ],
      "created": "",
      "fhirResourceId": "",
      "groupFeatures": [
        {
          "created": "",
          "feature": {
            "created": "",
            "description": "",
            "id": 0,
            "lastUpdate": "",
            "name": ""
          },
          "id": 0,
          "lastUpdate": ""
        }
      ],
      "groupType": {
        "created": "",
        "description": "",
        "descriptionFriendly": "",
        "displayOrder": 0,
        "id": 0,
        "lastUpdate": "",
        "lookupType": {},
        "value": ""
      },
      "id": 0,
      "lastImportDate": "",
      "lastUpdate": "",
      "links": [
        {
          "created": "",
          "displayOrder": 0,
          "id": 0,
          "lastUpdate": "",
          "link": "",
          "linkType": {},
          "name": ""
        }
      ],
      "locations": [
        {
          "address": "",
          "created": "",
          "email": "",
          "id": 0,
          "label": "",
          "lastUpdate": "",
          "name": "",
          "phone": "",
          "web": ""
        }
      ],
      "name": "",
      "parentGroups": [],
      "postcode": "",
      "sftpUser": "",
      "shortName": "",
      "visible": false,
      "visibleToJoin": false
    },
    "id": 0,
    "identifier": "",
    "links": [
      {}
    ],
    "notes": "",
    "severity": "",
    "status": ""
  },
  "encounters": [
    {
      "date": "",
      "encounterType": "",
      "group": {},
      "id": 0,
      "identifier": "",
      "links": [
        {}
      ],
      "observations": [
        {
          "applies": "",
          "bodySite": "",
          "comments": "",
          "comparator": "",
          "diagram": "",
          "group": {},
          "id": 0,
          "identifier": "",
          "location": "",
          "name": "",
          "temporaryUuid": "",
          "units": "",
          "value": ""
        }
      ],
      "procedures": [
        {
          "bodySite": "",
          "id": 0,
          "type": ""
        }
      ],
      "status": ""
    }
  ],
  "groupCode": "",
  "identifier": "",
  "observations": [
    {}
  ],
  "patient": {
    "address1": "",
    "address2": "",
    "address3": "",
    "address4": "",
    "contacts": [
      {
        "id": 0,
        "system": "",
        "use": "",
        "value": ""
      }
    ],
    "dateOfBirth": "",
    "dateOfBirthNoTime": "",
    "forename": "",
    "gender": "",
    "group": {},
    "groupCode": "",
    "identifier": "",
    "identifiers": [
      {
        "id": 0,
        "label": "",
        "value": ""
      }
    ],
    "postcode": "",
    "practitioners": [
      {
        "address1": "",
        "address2": "",
        "address3": "",
        "address4": "",
        "allowInviteGp": false,
        "contacts": [
          {}
        ],
        "gender": "",
        "groupCode": "",
        "identifier": "",
        "inviteDate": "",
        "name": "",
        "postcode": "",
        "role": ""
      }
    ],
    "surname": ""
  },
  "practitioners": [
    {}
  ]
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/patientmanagement/validate")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"condition\": {\n    \"asserter\": \"\",\n    \"category\": \"\",\n    \"code\": \"\",\n    \"date\": \"\",\n    \"description\": \"\",\n    \"fullDescription\": \"\",\n    \"group\": {\n      \"address1\": \"\",\n      \"address2\": \"\",\n      \"address3\": \"\",\n      \"childGroups\": [],\n      \"code\": \"\",\n      \"contactPoints\": [\n        {\n          \"contactPointType\": {\n            \"description\": \"\",\n            \"id\": 0,\n            \"lookupType\": {\n              \"created\": \"\",\n              \"description\": \"\",\n              \"id\": 0,\n              \"lastUpdate\": \"\",\n              \"type\": \"\"\n            },\n            \"value\": \"\"\n          },\n          \"content\": \"\",\n          \"created\": \"\",\n          \"id\": 0,\n          \"lastUpdate\": \"\"\n        }\n      ],\n      \"created\": \"\",\n      \"fhirResourceId\": \"\",\n      \"groupFeatures\": [\n        {\n          \"created\": \"\",\n          \"feature\": {\n            \"created\": \"\",\n            \"description\": \"\",\n            \"id\": 0,\n            \"lastUpdate\": \"\",\n            \"name\": \"\"\n          },\n          \"id\": 0,\n          \"lastUpdate\": \"\"\n        }\n      ],\n      \"groupType\": {\n        \"created\": \"\",\n        \"description\": \"\",\n        \"descriptionFriendly\": \"\",\n        \"displayOrder\": 0,\n        \"id\": 0,\n        \"lastUpdate\": \"\",\n        \"lookupType\": {},\n        \"value\": \"\"\n      },\n      \"id\": 0,\n      \"lastImportDate\": \"\",\n      \"lastUpdate\": \"\",\n      \"links\": [\n        {\n          \"created\": \"\",\n          \"displayOrder\": 0,\n          \"id\": 0,\n          \"lastUpdate\": \"\",\n          \"link\": \"\",\n          \"linkType\": {},\n          \"name\": \"\"\n        }\n      ],\n      \"locations\": [\n        {\n          \"address\": \"\",\n          \"created\": \"\",\n          \"email\": \"\",\n          \"id\": 0,\n          \"label\": \"\",\n          \"lastUpdate\": \"\",\n          \"name\": \"\",\n          \"phone\": \"\",\n          \"web\": \"\"\n        }\n      ],\n      \"name\": \"\",\n      \"parentGroups\": [],\n      \"postcode\": \"\",\n      \"sftpUser\": \"\",\n      \"shortName\": \"\",\n      \"visible\": false,\n      \"visibleToJoin\": false\n    },\n    \"id\": 0,\n    \"identifier\": \"\",\n    \"links\": [\n      {}\n    ],\n    \"notes\": \"\",\n    \"severity\": \"\",\n    \"status\": \"\"\n  },\n  \"encounters\": [\n    {\n      \"date\": \"\",\n      \"encounterType\": \"\",\n      \"group\": {},\n      \"id\": 0,\n      \"identifier\": \"\",\n      \"links\": [\n        {}\n      ],\n      \"observations\": [\n        {\n          \"applies\": \"\",\n          \"bodySite\": \"\",\n          \"comments\": \"\",\n          \"comparator\": \"\",\n          \"diagram\": \"\",\n          \"group\": {},\n          \"id\": 0,\n          \"identifier\": \"\",\n          \"location\": \"\",\n          \"name\": \"\",\n          \"temporaryUuid\": \"\",\n          \"units\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"procedures\": [\n        {\n          \"bodySite\": \"\",\n          \"id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"status\": \"\"\n    }\n  ],\n  \"groupCode\": \"\",\n  \"identifier\": \"\",\n  \"observations\": [\n    {}\n  ],\n  \"patient\": {\n    \"address1\": \"\",\n    \"address2\": \"\",\n    \"address3\": \"\",\n    \"address4\": \"\",\n    \"contacts\": [\n      {\n        \"id\": 0,\n        \"system\": \"\",\n        \"use\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"dateOfBirth\": \"\",\n    \"dateOfBirthNoTime\": \"\",\n    \"forename\": \"\",\n    \"gender\": \"\",\n    \"group\": {},\n    \"groupCode\": \"\",\n    \"identifier\": \"\",\n    \"identifiers\": [\n      {\n        \"id\": 0,\n        \"label\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"postcode\": \"\",\n    \"practitioners\": [\n      {\n        \"address1\": \"\",\n        \"address2\": \"\",\n        \"address3\": \"\",\n        \"address4\": \"\",\n        \"allowInviteGp\": false,\n        \"contacts\": [\n          {}\n        ],\n        \"gender\": \"\",\n        \"groupCode\": \"\",\n        \"identifier\": \"\",\n        \"inviteDate\": \"\",\n        \"name\": \"\",\n        \"postcode\": \"\",\n        \"role\": \"\"\n      }\n    ],\n    \"surname\": \"\"\n  },\n  \"practitioners\": [\n    {}\n  ]\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/patientmanagement/validate"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"condition\": {\n    \"asserter\": \"\",\n    \"category\": \"\",\n    \"code\": \"\",\n    \"date\": \"\",\n    \"description\": \"\",\n    \"fullDescription\": \"\",\n    \"group\": {\n      \"address1\": \"\",\n      \"address2\": \"\",\n      \"address3\": \"\",\n      \"childGroups\": [],\n      \"code\": \"\",\n      \"contactPoints\": [\n        {\n          \"contactPointType\": {\n            \"description\": \"\",\n            \"id\": 0,\n            \"lookupType\": {\n              \"created\": \"\",\n              \"description\": \"\",\n              \"id\": 0,\n              \"lastUpdate\": \"\",\n              \"type\": \"\"\n            },\n            \"value\": \"\"\n          },\n          \"content\": \"\",\n          \"created\": \"\",\n          \"id\": 0,\n          \"lastUpdate\": \"\"\n        }\n      ],\n      \"created\": \"\",\n      \"fhirResourceId\": \"\",\n      \"groupFeatures\": [\n        {\n          \"created\": \"\",\n          \"feature\": {\n            \"created\": \"\",\n            \"description\": \"\",\n            \"id\": 0,\n            \"lastUpdate\": \"\",\n            \"name\": \"\"\n          },\n          \"id\": 0,\n          \"lastUpdate\": \"\"\n        }\n      ],\n      \"groupType\": {\n        \"created\": \"\",\n        \"description\": \"\",\n        \"descriptionFriendly\": \"\",\n        \"displayOrder\": 0,\n        \"id\": 0,\n        \"lastUpdate\": \"\",\n        \"lookupType\": {},\n        \"value\": \"\"\n      },\n      \"id\": 0,\n      \"lastImportDate\": \"\",\n      \"lastUpdate\": \"\",\n      \"links\": [\n        {\n          \"created\": \"\",\n          \"displayOrder\": 0,\n          \"id\": 0,\n          \"lastUpdate\": \"\",\n          \"link\": \"\",\n          \"linkType\": {},\n          \"name\": \"\"\n        }\n      ],\n      \"locations\": [\n        {\n          \"address\": \"\",\n          \"created\": \"\",\n          \"email\": \"\",\n          \"id\": 0,\n          \"label\": \"\",\n          \"lastUpdate\": \"\",\n          \"name\": \"\",\n          \"phone\": \"\",\n          \"web\": \"\"\n        }\n      ],\n      \"name\": \"\",\n      \"parentGroups\": [],\n      \"postcode\": \"\",\n      \"sftpUser\": \"\",\n      \"shortName\": \"\",\n      \"visible\": false,\n      \"visibleToJoin\": false\n    },\n    \"id\": 0,\n    \"identifier\": \"\",\n    \"links\": [\n      {}\n    ],\n    \"notes\": \"\",\n    \"severity\": \"\",\n    \"status\": \"\"\n  },\n  \"encounters\": [\n    {\n      \"date\": \"\",\n      \"encounterType\": \"\",\n      \"group\": {},\n      \"id\": 0,\n      \"identifier\": \"\",\n      \"links\": [\n        {}\n      ],\n      \"observations\": [\n        {\n          \"applies\": \"\",\n          \"bodySite\": \"\",\n          \"comments\": \"\",\n          \"comparator\": \"\",\n          \"diagram\": \"\",\n          \"group\": {},\n          \"id\": 0,\n          \"identifier\": \"\",\n          \"location\": \"\",\n          \"name\": \"\",\n          \"temporaryUuid\": \"\",\n          \"units\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"procedures\": [\n        {\n          \"bodySite\": \"\",\n          \"id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"status\": \"\"\n    }\n  ],\n  \"groupCode\": \"\",\n  \"identifier\": \"\",\n  \"observations\": [\n    {}\n  ],\n  \"patient\": {\n    \"address1\": \"\",\n    \"address2\": \"\",\n    \"address3\": \"\",\n    \"address4\": \"\",\n    \"contacts\": [\n      {\n        \"id\": 0,\n        \"system\": \"\",\n        \"use\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"dateOfBirth\": \"\",\n    \"dateOfBirthNoTime\": \"\",\n    \"forename\": \"\",\n    \"gender\": \"\",\n    \"group\": {},\n    \"groupCode\": \"\",\n    \"identifier\": \"\",\n    \"identifiers\": [\n      {\n        \"id\": 0,\n        \"label\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"postcode\": \"\",\n    \"practitioners\": [\n      {\n        \"address1\": \"\",\n        \"address2\": \"\",\n        \"address3\": \"\",\n        \"address4\": \"\",\n        \"allowInviteGp\": false,\n        \"contacts\": [\n          {}\n        ],\n        \"gender\": \"\",\n        \"groupCode\": \"\",\n        \"identifier\": \"\",\n        \"inviteDate\": \"\",\n        \"name\": \"\",\n        \"postcode\": \"\",\n        \"role\": \"\"\n      }\n    ],\n    \"surname\": \"\"\n  },\n  \"practitioners\": [\n    {}\n  ]\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"condition\": {\n    \"asserter\": \"\",\n    \"category\": \"\",\n    \"code\": \"\",\n    \"date\": \"\",\n    \"description\": \"\",\n    \"fullDescription\": \"\",\n    \"group\": {\n      \"address1\": \"\",\n      \"address2\": \"\",\n      \"address3\": \"\",\n      \"childGroups\": [],\n      \"code\": \"\",\n      \"contactPoints\": [\n        {\n          \"contactPointType\": {\n            \"description\": \"\",\n            \"id\": 0,\n            \"lookupType\": {\n              \"created\": \"\",\n              \"description\": \"\",\n              \"id\": 0,\n              \"lastUpdate\": \"\",\n              \"type\": \"\"\n            },\n            \"value\": \"\"\n          },\n          \"content\": \"\",\n          \"created\": \"\",\n          \"id\": 0,\n          \"lastUpdate\": \"\"\n        }\n      ],\n      \"created\": \"\",\n      \"fhirResourceId\": \"\",\n      \"groupFeatures\": [\n        {\n          \"created\": \"\",\n          \"feature\": {\n            \"created\": \"\",\n            \"description\": \"\",\n            \"id\": 0,\n            \"lastUpdate\": \"\",\n            \"name\": \"\"\n          },\n          \"id\": 0,\n          \"lastUpdate\": \"\"\n        }\n      ],\n      \"groupType\": {\n        \"created\": \"\",\n        \"description\": \"\",\n        \"descriptionFriendly\": \"\",\n        \"displayOrder\": 0,\n        \"id\": 0,\n        \"lastUpdate\": \"\",\n        \"lookupType\": {},\n        \"value\": \"\"\n      },\n      \"id\": 0,\n      \"lastImportDate\": \"\",\n      \"lastUpdate\": \"\",\n      \"links\": [\n        {\n          \"created\": \"\",\n          \"displayOrder\": 0,\n          \"id\": 0,\n          \"lastUpdate\": \"\",\n          \"link\": \"\",\n          \"linkType\": {},\n          \"name\": \"\"\n        }\n      ],\n      \"locations\": [\n        {\n          \"address\": \"\",\n          \"created\": \"\",\n          \"email\": \"\",\n          \"id\": 0,\n          \"label\": \"\",\n          \"lastUpdate\": \"\",\n          \"name\": \"\",\n          \"phone\": \"\",\n          \"web\": \"\"\n        }\n      ],\n      \"name\": \"\",\n      \"parentGroups\": [],\n      \"postcode\": \"\",\n      \"sftpUser\": \"\",\n      \"shortName\": \"\",\n      \"visible\": false,\n      \"visibleToJoin\": false\n    },\n    \"id\": 0,\n    \"identifier\": \"\",\n    \"links\": [\n      {}\n    ],\n    \"notes\": \"\",\n    \"severity\": \"\",\n    \"status\": \"\"\n  },\n  \"encounters\": [\n    {\n      \"date\": \"\",\n      \"encounterType\": \"\",\n      \"group\": {},\n      \"id\": 0,\n      \"identifier\": \"\",\n      \"links\": [\n        {}\n      ],\n      \"observations\": [\n        {\n          \"applies\": \"\",\n          \"bodySite\": \"\",\n          \"comments\": \"\",\n          \"comparator\": \"\",\n          \"diagram\": \"\",\n          \"group\": {},\n          \"id\": 0,\n          \"identifier\": \"\",\n          \"location\": \"\",\n          \"name\": \"\",\n          \"temporaryUuid\": \"\",\n          \"units\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"procedures\": [\n        {\n          \"bodySite\": \"\",\n          \"id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"status\": \"\"\n    }\n  ],\n  \"groupCode\": \"\",\n  \"identifier\": \"\",\n  \"observations\": [\n    {}\n  ],\n  \"patient\": {\n    \"address1\": \"\",\n    \"address2\": \"\",\n    \"address3\": \"\",\n    \"address4\": \"\",\n    \"contacts\": [\n      {\n        \"id\": 0,\n        \"system\": \"\",\n        \"use\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"dateOfBirth\": \"\",\n    \"dateOfBirthNoTime\": \"\",\n    \"forename\": \"\",\n    \"gender\": \"\",\n    \"group\": {},\n    \"groupCode\": \"\",\n    \"identifier\": \"\",\n    \"identifiers\": [\n      {\n        \"id\": 0,\n        \"label\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"postcode\": \"\",\n    \"practitioners\": [\n      {\n        \"address1\": \"\",\n        \"address2\": \"\",\n        \"address3\": \"\",\n        \"address4\": \"\",\n        \"allowInviteGp\": false,\n        \"contacts\": [\n          {}\n        ],\n        \"gender\": \"\",\n        \"groupCode\": \"\",\n        \"identifier\": \"\",\n        \"inviteDate\": \"\",\n        \"name\": \"\",\n        \"postcode\": \"\",\n        \"role\": \"\"\n      }\n    ],\n    \"surname\": \"\"\n  },\n  \"practitioners\": [\n    {}\n  ]\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/patientmanagement/validate")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/patientmanagement/validate")
  .header("content-type", "application/json")
  .body("{\n  \"condition\": {\n    \"asserter\": \"\",\n    \"category\": \"\",\n    \"code\": \"\",\n    \"date\": \"\",\n    \"description\": \"\",\n    \"fullDescription\": \"\",\n    \"group\": {\n      \"address1\": \"\",\n      \"address2\": \"\",\n      \"address3\": \"\",\n      \"childGroups\": [],\n      \"code\": \"\",\n      \"contactPoints\": [\n        {\n          \"contactPointType\": {\n            \"description\": \"\",\n            \"id\": 0,\n            \"lookupType\": {\n              \"created\": \"\",\n              \"description\": \"\",\n              \"id\": 0,\n              \"lastUpdate\": \"\",\n              \"type\": \"\"\n            },\n            \"value\": \"\"\n          },\n          \"content\": \"\",\n          \"created\": \"\",\n          \"id\": 0,\n          \"lastUpdate\": \"\"\n        }\n      ],\n      \"created\": \"\",\n      \"fhirResourceId\": \"\",\n      \"groupFeatures\": [\n        {\n          \"created\": \"\",\n          \"feature\": {\n            \"created\": \"\",\n            \"description\": \"\",\n            \"id\": 0,\n            \"lastUpdate\": \"\",\n            \"name\": \"\"\n          },\n          \"id\": 0,\n          \"lastUpdate\": \"\"\n        }\n      ],\n      \"groupType\": {\n        \"created\": \"\",\n        \"description\": \"\",\n        \"descriptionFriendly\": \"\",\n        \"displayOrder\": 0,\n        \"id\": 0,\n        \"lastUpdate\": \"\",\n        \"lookupType\": {},\n        \"value\": \"\"\n      },\n      \"id\": 0,\n      \"lastImportDate\": \"\",\n      \"lastUpdate\": \"\",\n      \"links\": [\n        {\n          \"created\": \"\",\n          \"displayOrder\": 0,\n          \"id\": 0,\n          \"lastUpdate\": \"\",\n          \"link\": \"\",\n          \"linkType\": {},\n          \"name\": \"\"\n        }\n      ],\n      \"locations\": [\n        {\n          \"address\": \"\",\n          \"created\": \"\",\n          \"email\": \"\",\n          \"id\": 0,\n          \"label\": \"\",\n          \"lastUpdate\": \"\",\n          \"name\": \"\",\n          \"phone\": \"\",\n          \"web\": \"\"\n        }\n      ],\n      \"name\": \"\",\n      \"parentGroups\": [],\n      \"postcode\": \"\",\n      \"sftpUser\": \"\",\n      \"shortName\": \"\",\n      \"visible\": false,\n      \"visibleToJoin\": false\n    },\n    \"id\": 0,\n    \"identifier\": \"\",\n    \"links\": [\n      {}\n    ],\n    \"notes\": \"\",\n    \"severity\": \"\",\n    \"status\": \"\"\n  },\n  \"encounters\": [\n    {\n      \"date\": \"\",\n      \"encounterType\": \"\",\n      \"group\": {},\n      \"id\": 0,\n      \"identifier\": \"\",\n      \"links\": [\n        {}\n      ],\n      \"observations\": [\n        {\n          \"applies\": \"\",\n          \"bodySite\": \"\",\n          \"comments\": \"\",\n          \"comparator\": \"\",\n          \"diagram\": \"\",\n          \"group\": {},\n          \"id\": 0,\n          \"identifier\": \"\",\n          \"location\": \"\",\n          \"name\": \"\",\n          \"temporaryUuid\": \"\",\n          \"units\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"procedures\": [\n        {\n          \"bodySite\": \"\",\n          \"id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"status\": \"\"\n    }\n  ],\n  \"groupCode\": \"\",\n  \"identifier\": \"\",\n  \"observations\": [\n    {}\n  ],\n  \"patient\": {\n    \"address1\": \"\",\n    \"address2\": \"\",\n    \"address3\": \"\",\n    \"address4\": \"\",\n    \"contacts\": [\n      {\n        \"id\": 0,\n        \"system\": \"\",\n        \"use\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"dateOfBirth\": \"\",\n    \"dateOfBirthNoTime\": \"\",\n    \"forename\": \"\",\n    \"gender\": \"\",\n    \"group\": {},\n    \"groupCode\": \"\",\n    \"identifier\": \"\",\n    \"identifiers\": [\n      {\n        \"id\": 0,\n        \"label\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"postcode\": \"\",\n    \"practitioners\": [\n      {\n        \"address1\": \"\",\n        \"address2\": \"\",\n        \"address3\": \"\",\n        \"address4\": \"\",\n        \"allowInviteGp\": false,\n        \"contacts\": [\n          {}\n        ],\n        \"gender\": \"\",\n        \"groupCode\": \"\",\n        \"identifier\": \"\",\n        \"inviteDate\": \"\",\n        \"name\": \"\",\n        \"postcode\": \"\",\n        \"role\": \"\"\n      }\n    ],\n    \"surname\": \"\"\n  },\n  \"practitioners\": [\n    {}\n  ]\n}")
  .asString();
const data = JSON.stringify({
  condition: {
    asserter: '',
    category: '',
    code: '',
    date: '',
    description: '',
    fullDescription: '',
    group: {
      address1: '',
      address2: '',
      address3: '',
      childGroups: [],
      code: '',
      contactPoints: [
        {
          contactPointType: {
            description: '',
            id: 0,
            lookupType: {
              created: '',
              description: '',
              id: 0,
              lastUpdate: '',
              type: ''
            },
            value: ''
          },
          content: '',
          created: '',
          id: 0,
          lastUpdate: ''
        }
      ],
      created: '',
      fhirResourceId: '',
      groupFeatures: [
        {
          created: '',
          feature: {
            created: '',
            description: '',
            id: 0,
            lastUpdate: '',
            name: ''
          },
          id: 0,
          lastUpdate: ''
        }
      ],
      groupType: {
        created: '',
        description: '',
        descriptionFriendly: '',
        displayOrder: 0,
        id: 0,
        lastUpdate: '',
        lookupType: {},
        value: ''
      },
      id: 0,
      lastImportDate: '',
      lastUpdate: '',
      links: [
        {
          created: '',
          displayOrder: 0,
          id: 0,
          lastUpdate: '',
          link: '',
          linkType: {},
          name: ''
        }
      ],
      locations: [
        {
          address: '',
          created: '',
          email: '',
          id: 0,
          label: '',
          lastUpdate: '',
          name: '',
          phone: '',
          web: ''
        }
      ],
      name: '',
      parentGroups: [],
      postcode: '',
      sftpUser: '',
      shortName: '',
      visible: false,
      visibleToJoin: false
    },
    id: 0,
    identifier: '',
    links: [
      {}
    ],
    notes: '',
    severity: '',
    status: ''
  },
  encounters: [
    {
      date: '',
      encounterType: '',
      group: {},
      id: 0,
      identifier: '',
      links: [
        {}
      ],
      observations: [
        {
          applies: '',
          bodySite: '',
          comments: '',
          comparator: '',
          diagram: '',
          group: {},
          id: 0,
          identifier: '',
          location: '',
          name: '',
          temporaryUuid: '',
          units: '',
          value: ''
        }
      ],
      procedures: [
        {
          bodySite: '',
          id: 0,
          type: ''
        }
      ],
      status: ''
    }
  ],
  groupCode: '',
  identifier: '',
  observations: [
    {}
  ],
  patient: {
    address1: '',
    address2: '',
    address3: '',
    address4: '',
    contacts: [
      {
        id: 0,
        system: '',
        use: '',
        value: ''
      }
    ],
    dateOfBirth: '',
    dateOfBirthNoTime: '',
    forename: '',
    gender: '',
    group: {},
    groupCode: '',
    identifier: '',
    identifiers: [
      {
        id: 0,
        label: '',
        value: ''
      }
    ],
    postcode: '',
    practitioners: [
      {
        address1: '',
        address2: '',
        address3: '',
        address4: '',
        allowInviteGp: false,
        contacts: [
          {}
        ],
        gender: '',
        groupCode: '',
        identifier: '',
        inviteDate: '',
        name: '',
        postcode: '',
        role: ''
      }
    ],
    surname: ''
  },
  practitioners: [
    {}
  ]
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/patientmanagement/validate');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/patientmanagement/validate',
  headers: {'content-type': 'application/json'},
  data: {
    condition: {
      asserter: '',
      category: '',
      code: '',
      date: '',
      description: '',
      fullDescription: '',
      group: {
        address1: '',
        address2: '',
        address3: '',
        childGroups: [],
        code: '',
        contactPoints: [
          {
            contactPointType: {
              description: '',
              id: 0,
              lookupType: {created: '', description: '', id: 0, lastUpdate: '', type: ''},
              value: ''
            },
            content: '',
            created: '',
            id: 0,
            lastUpdate: ''
          }
        ],
        created: '',
        fhirResourceId: '',
        groupFeatures: [
          {
            created: '',
            feature: {created: '', description: '', id: 0, lastUpdate: '', name: ''},
            id: 0,
            lastUpdate: ''
          }
        ],
        groupType: {
          created: '',
          description: '',
          descriptionFriendly: '',
          displayOrder: 0,
          id: 0,
          lastUpdate: '',
          lookupType: {},
          value: ''
        },
        id: 0,
        lastImportDate: '',
        lastUpdate: '',
        links: [
          {
            created: '',
            displayOrder: 0,
            id: 0,
            lastUpdate: '',
            link: '',
            linkType: {},
            name: ''
          }
        ],
        locations: [
          {
            address: '',
            created: '',
            email: '',
            id: 0,
            label: '',
            lastUpdate: '',
            name: '',
            phone: '',
            web: ''
          }
        ],
        name: '',
        parentGroups: [],
        postcode: '',
        sftpUser: '',
        shortName: '',
        visible: false,
        visibleToJoin: false
      },
      id: 0,
      identifier: '',
      links: [{}],
      notes: '',
      severity: '',
      status: ''
    },
    encounters: [
      {
        date: '',
        encounterType: '',
        group: {},
        id: 0,
        identifier: '',
        links: [{}],
        observations: [
          {
            applies: '',
            bodySite: '',
            comments: '',
            comparator: '',
            diagram: '',
            group: {},
            id: 0,
            identifier: '',
            location: '',
            name: '',
            temporaryUuid: '',
            units: '',
            value: ''
          }
        ],
        procedures: [{bodySite: '', id: 0, type: ''}],
        status: ''
      }
    ],
    groupCode: '',
    identifier: '',
    observations: [{}],
    patient: {
      address1: '',
      address2: '',
      address3: '',
      address4: '',
      contacts: [{id: 0, system: '', use: '', value: ''}],
      dateOfBirth: '',
      dateOfBirthNoTime: '',
      forename: '',
      gender: '',
      group: {},
      groupCode: '',
      identifier: '',
      identifiers: [{id: 0, label: '', value: ''}],
      postcode: '',
      practitioners: [
        {
          address1: '',
          address2: '',
          address3: '',
          address4: '',
          allowInviteGp: false,
          contacts: [{}],
          gender: '',
          groupCode: '',
          identifier: '',
          inviteDate: '',
          name: '',
          postcode: '',
          role: ''
        }
      ],
      surname: ''
    },
    practitioners: [{}]
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/patientmanagement/validate';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"condition":{"asserter":"","category":"","code":"","date":"","description":"","fullDescription":"","group":{"address1":"","address2":"","address3":"","childGroups":[],"code":"","contactPoints":[{"contactPointType":{"description":"","id":0,"lookupType":{"created":"","description":"","id":0,"lastUpdate":"","type":""},"value":""},"content":"","created":"","id":0,"lastUpdate":""}],"created":"","fhirResourceId":"","groupFeatures":[{"created":"","feature":{"created":"","description":"","id":0,"lastUpdate":"","name":""},"id":0,"lastUpdate":""}],"groupType":{"created":"","description":"","descriptionFriendly":"","displayOrder":0,"id":0,"lastUpdate":"","lookupType":{},"value":""},"id":0,"lastImportDate":"","lastUpdate":"","links":[{"created":"","displayOrder":0,"id":0,"lastUpdate":"","link":"","linkType":{},"name":""}],"locations":[{"address":"","created":"","email":"","id":0,"label":"","lastUpdate":"","name":"","phone":"","web":""}],"name":"","parentGroups":[],"postcode":"","sftpUser":"","shortName":"","visible":false,"visibleToJoin":false},"id":0,"identifier":"","links":[{}],"notes":"","severity":"","status":""},"encounters":[{"date":"","encounterType":"","group":{},"id":0,"identifier":"","links":[{}],"observations":[{"applies":"","bodySite":"","comments":"","comparator":"","diagram":"","group":{},"id":0,"identifier":"","location":"","name":"","temporaryUuid":"","units":"","value":""}],"procedures":[{"bodySite":"","id":0,"type":""}],"status":""}],"groupCode":"","identifier":"","observations":[{}],"patient":{"address1":"","address2":"","address3":"","address4":"","contacts":[{"id":0,"system":"","use":"","value":""}],"dateOfBirth":"","dateOfBirthNoTime":"","forename":"","gender":"","group":{},"groupCode":"","identifier":"","identifiers":[{"id":0,"label":"","value":""}],"postcode":"","practitioners":[{"address1":"","address2":"","address3":"","address4":"","allowInviteGp":false,"contacts":[{}],"gender":"","groupCode":"","identifier":"","inviteDate":"","name":"","postcode":"","role":""}],"surname":""},"practitioners":[{}]}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/patientmanagement/validate',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "condition": {\n    "asserter": "",\n    "category": "",\n    "code": "",\n    "date": "",\n    "description": "",\n    "fullDescription": "",\n    "group": {\n      "address1": "",\n      "address2": "",\n      "address3": "",\n      "childGroups": [],\n      "code": "",\n      "contactPoints": [\n        {\n          "contactPointType": {\n            "description": "",\n            "id": 0,\n            "lookupType": {\n              "created": "",\n              "description": "",\n              "id": 0,\n              "lastUpdate": "",\n              "type": ""\n            },\n            "value": ""\n          },\n          "content": "",\n          "created": "",\n          "id": 0,\n          "lastUpdate": ""\n        }\n      ],\n      "created": "",\n      "fhirResourceId": "",\n      "groupFeatures": [\n        {\n          "created": "",\n          "feature": {\n            "created": "",\n            "description": "",\n            "id": 0,\n            "lastUpdate": "",\n            "name": ""\n          },\n          "id": 0,\n          "lastUpdate": ""\n        }\n      ],\n      "groupType": {\n        "created": "",\n        "description": "",\n        "descriptionFriendly": "",\n        "displayOrder": 0,\n        "id": 0,\n        "lastUpdate": "",\n        "lookupType": {},\n        "value": ""\n      },\n      "id": 0,\n      "lastImportDate": "",\n      "lastUpdate": "",\n      "links": [\n        {\n          "created": "",\n          "displayOrder": 0,\n          "id": 0,\n          "lastUpdate": "",\n          "link": "",\n          "linkType": {},\n          "name": ""\n        }\n      ],\n      "locations": [\n        {\n          "address": "",\n          "created": "",\n          "email": "",\n          "id": 0,\n          "label": "",\n          "lastUpdate": "",\n          "name": "",\n          "phone": "",\n          "web": ""\n        }\n      ],\n      "name": "",\n      "parentGroups": [],\n      "postcode": "",\n      "sftpUser": "",\n      "shortName": "",\n      "visible": false,\n      "visibleToJoin": false\n    },\n    "id": 0,\n    "identifier": "",\n    "links": [\n      {}\n    ],\n    "notes": "",\n    "severity": "",\n    "status": ""\n  },\n  "encounters": [\n    {\n      "date": "",\n      "encounterType": "",\n      "group": {},\n      "id": 0,\n      "identifier": "",\n      "links": [\n        {}\n      ],\n      "observations": [\n        {\n          "applies": "",\n          "bodySite": "",\n          "comments": "",\n          "comparator": "",\n          "diagram": "",\n          "group": {},\n          "id": 0,\n          "identifier": "",\n          "location": "",\n          "name": "",\n          "temporaryUuid": "",\n          "units": "",\n          "value": ""\n        }\n      ],\n      "procedures": [\n        {\n          "bodySite": "",\n          "id": 0,\n          "type": ""\n        }\n      ],\n      "status": ""\n    }\n  ],\n  "groupCode": "",\n  "identifier": "",\n  "observations": [\n    {}\n  ],\n  "patient": {\n    "address1": "",\n    "address2": "",\n    "address3": "",\n    "address4": "",\n    "contacts": [\n      {\n        "id": 0,\n        "system": "",\n        "use": "",\n        "value": ""\n      }\n    ],\n    "dateOfBirth": "",\n    "dateOfBirthNoTime": "",\n    "forename": "",\n    "gender": "",\n    "group": {},\n    "groupCode": "",\n    "identifier": "",\n    "identifiers": [\n      {\n        "id": 0,\n        "label": "",\n        "value": ""\n      }\n    ],\n    "postcode": "",\n    "practitioners": [\n      {\n        "address1": "",\n        "address2": "",\n        "address3": "",\n        "address4": "",\n        "allowInviteGp": false,\n        "contacts": [\n          {}\n        ],\n        "gender": "",\n        "groupCode": "",\n        "identifier": "",\n        "inviteDate": "",\n        "name": "",\n        "postcode": "",\n        "role": ""\n      }\n    ],\n    "surname": ""\n  },\n  "practitioners": [\n    {}\n  ]\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"condition\": {\n    \"asserter\": \"\",\n    \"category\": \"\",\n    \"code\": \"\",\n    \"date\": \"\",\n    \"description\": \"\",\n    \"fullDescription\": \"\",\n    \"group\": {\n      \"address1\": \"\",\n      \"address2\": \"\",\n      \"address3\": \"\",\n      \"childGroups\": [],\n      \"code\": \"\",\n      \"contactPoints\": [\n        {\n          \"contactPointType\": {\n            \"description\": \"\",\n            \"id\": 0,\n            \"lookupType\": {\n              \"created\": \"\",\n              \"description\": \"\",\n              \"id\": 0,\n              \"lastUpdate\": \"\",\n              \"type\": \"\"\n            },\n            \"value\": \"\"\n          },\n          \"content\": \"\",\n          \"created\": \"\",\n          \"id\": 0,\n          \"lastUpdate\": \"\"\n        }\n      ],\n      \"created\": \"\",\n      \"fhirResourceId\": \"\",\n      \"groupFeatures\": [\n        {\n          \"created\": \"\",\n          \"feature\": {\n            \"created\": \"\",\n            \"description\": \"\",\n            \"id\": 0,\n            \"lastUpdate\": \"\",\n            \"name\": \"\"\n          },\n          \"id\": 0,\n          \"lastUpdate\": \"\"\n        }\n      ],\n      \"groupType\": {\n        \"created\": \"\",\n        \"description\": \"\",\n        \"descriptionFriendly\": \"\",\n        \"displayOrder\": 0,\n        \"id\": 0,\n        \"lastUpdate\": \"\",\n        \"lookupType\": {},\n        \"value\": \"\"\n      },\n      \"id\": 0,\n      \"lastImportDate\": \"\",\n      \"lastUpdate\": \"\",\n      \"links\": [\n        {\n          \"created\": \"\",\n          \"displayOrder\": 0,\n          \"id\": 0,\n          \"lastUpdate\": \"\",\n          \"link\": \"\",\n          \"linkType\": {},\n          \"name\": \"\"\n        }\n      ],\n      \"locations\": [\n        {\n          \"address\": \"\",\n          \"created\": \"\",\n          \"email\": \"\",\n          \"id\": 0,\n          \"label\": \"\",\n          \"lastUpdate\": \"\",\n          \"name\": \"\",\n          \"phone\": \"\",\n          \"web\": \"\"\n        }\n      ],\n      \"name\": \"\",\n      \"parentGroups\": [],\n      \"postcode\": \"\",\n      \"sftpUser\": \"\",\n      \"shortName\": \"\",\n      \"visible\": false,\n      \"visibleToJoin\": false\n    },\n    \"id\": 0,\n    \"identifier\": \"\",\n    \"links\": [\n      {}\n    ],\n    \"notes\": \"\",\n    \"severity\": \"\",\n    \"status\": \"\"\n  },\n  \"encounters\": [\n    {\n      \"date\": \"\",\n      \"encounterType\": \"\",\n      \"group\": {},\n      \"id\": 0,\n      \"identifier\": \"\",\n      \"links\": [\n        {}\n      ],\n      \"observations\": [\n        {\n          \"applies\": \"\",\n          \"bodySite\": \"\",\n          \"comments\": \"\",\n          \"comparator\": \"\",\n          \"diagram\": \"\",\n          \"group\": {},\n          \"id\": 0,\n          \"identifier\": \"\",\n          \"location\": \"\",\n          \"name\": \"\",\n          \"temporaryUuid\": \"\",\n          \"units\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"procedures\": [\n        {\n          \"bodySite\": \"\",\n          \"id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"status\": \"\"\n    }\n  ],\n  \"groupCode\": \"\",\n  \"identifier\": \"\",\n  \"observations\": [\n    {}\n  ],\n  \"patient\": {\n    \"address1\": \"\",\n    \"address2\": \"\",\n    \"address3\": \"\",\n    \"address4\": \"\",\n    \"contacts\": [\n      {\n        \"id\": 0,\n        \"system\": \"\",\n        \"use\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"dateOfBirth\": \"\",\n    \"dateOfBirthNoTime\": \"\",\n    \"forename\": \"\",\n    \"gender\": \"\",\n    \"group\": {},\n    \"groupCode\": \"\",\n    \"identifier\": \"\",\n    \"identifiers\": [\n      {\n        \"id\": 0,\n        \"label\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"postcode\": \"\",\n    \"practitioners\": [\n      {\n        \"address1\": \"\",\n        \"address2\": \"\",\n        \"address3\": \"\",\n        \"address4\": \"\",\n        \"allowInviteGp\": false,\n        \"contacts\": [\n          {}\n        ],\n        \"gender\": \"\",\n        \"groupCode\": \"\",\n        \"identifier\": \"\",\n        \"inviteDate\": \"\",\n        \"name\": \"\",\n        \"postcode\": \"\",\n        \"role\": \"\"\n      }\n    ],\n    \"surname\": \"\"\n  },\n  \"practitioners\": [\n    {}\n  ]\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/patientmanagement/validate")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/patientmanagement/validate',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  condition: {
    asserter: '',
    category: '',
    code: '',
    date: '',
    description: '',
    fullDescription: '',
    group: {
      address1: '',
      address2: '',
      address3: '',
      childGroups: [],
      code: '',
      contactPoints: [
        {
          contactPointType: {
            description: '',
            id: 0,
            lookupType: {created: '', description: '', id: 0, lastUpdate: '', type: ''},
            value: ''
          },
          content: '',
          created: '',
          id: 0,
          lastUpdate: ''
        }
      ],
      created: '',
      fhirResourceId: '',
      groupFeatures: [
        {
          created: '',
          feature: {created: '', description: '', id: 0, lastUpdate: '', name: ''},
          id: 0,
          lastUpdate: ''
        }
      ],
      groupType: {
        created: '',
        description: '',
        descriptionFriendly: '',
        displayOrder: 0,
        id: 0,
        lastUpdate: '',
        lookupType: {},
        value: ''
      },
      id: 0,
      lastImportDate: '',
      lastUpdate: '',
      links: [
        {
          created: '',
          displayOrder: 0,
          id: 0,
          lastUpdate: '',
          link: '',
          linkType: {},
          name: ''
        }
      ],
      locations: [
        {
          address: '',
          created: '',
          email: '',
          id: 0,
          label: '',
          lastUpdate: '',
          name: '',
          phone: '',
          web: ''
        }
      ],
      name: '',
      parentGroups: [],
      postcode: '',
      sftpUser: '',
      shortName: '',
      visible: false,
      visibleToJoin: false
    },
    id: 0,
    identifier: '',
    links: [{}],
    notes: '',
    severity: '',
    status: ''
  },
  encounters: [
    {
      date: '',
      encounterType: '',
      group: {},
      id: 0,
      identifier: '',
      links: [{}],
      observations: [
        {
          applies: '',
          bodySite: '',
          comments: '',
          comparator: '',
          diagram: '',
          group: {},
          id: 0,
          identifier: '',
          location: '',
          name: '',
          temporaryUuid: '',
          units: '',
          value: ''
        }
      ],
      procedures: [{bodySite: '', id: 0, type: ''}],
      status: ''
    }
  ],
  groupCode: '',
  identifier: '',
  observations: [{}],
  patient: {
    address1: '',
    address2: '',
    address3: '',
    address4: '',
    contacts: [{id: 0, system: '', use: '', value: ''}],
    dateOfBirth: '',
    dateOfBirthNoTime: '',
    forename: '',
    gender: '',
    group: {},
    groupCode: '',
    identifier: '',
    identifiers: [{id: 0, label: '', value: ''}],
    postcode: '',
    practitioners: [
      {
        address1: '',
        address2: '',
        address3: '',
        address4: '',
        allowInviteGp: false,
        contacts: [{}],
        gender: '',
        groupCode: '',
        identifier: '',
        inviteDate: '',
        name: '',
        postcode: '',
        role: ''
      }
    ],
    surname: ''
  },
  practitioners: [{}]
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/patientmanagement/validate',
  headers: {'content-type': 'application/json'},
  body: {
    condition: {
      asserter: '',
      category: '',
      code: '',
      date: '',
      description: '',
      fullDescription: '',
      group: {
        address1: '',
        address2: '',
        address3: '',
        childGroups: [],
        code: '',
        contactPoints: [
          {
            contactPointType: {
              description: '',
              id: 0,
              lookupType: {created: '', description: '', id: 0, lastUpdate: '', type: ''},
              value: ''
            },
            content: '',
            created: '',
            id: 0,
            lastUpdate: ''
          }
        ],
        created: '',
        fhirResourceId: '',
        groupFeatures: [
          {
            created: '',
            feature: {created: '', description: '', id: 0, lastUpdate: '', name: ''},
            id: 0,
            lastUpdate: ''
          }
        ],
        groupType: {
          created: '',
          description: '',
          descriptionFriendly: '',
          displayOrder: 0,
          id: 0,
          lastUpdate: '',
          lookupType: {},
          value: ''
        },
        id: 0,
        lastImportDate: '',
        lastUpdate: '',
        links: [
          {
            created: '',
            displayOrder: 0,
            id: 0,
            lastUpdate: '',
            link: '',
            linkType: {},
            name: ''
          }
        ],
        locations: [
          {
            address: '',
            created: '',
            email: '',
            id: 0,
            label: '',
            lastUpdate: '',
            name: '',
            phone: '',
            web: ''
          }
        ],
        name: '',
        parentGroups: [],
        postcode: '',
        sftpUser: '',
        shortName: '',
        visible: false,
        visibleToJoin: false
      },
      id: 0,
      identifier: '',
      links: [{}],
      notes: '',
      severity: '',
      status: ''
    },
    encounters: [
      {
        date: '',
        encounterType: '',
        group: {},
        id: 0,
        identifier: '',
        links: [{}],
        observations: [
          {
            applies: '',
            bodySite: '',
            comments: '',
            comparator: '',
            diagram: '',
            group: {},
            id: 0,
            identifier: '',
            location: '',
            name: '',
            temporaryUuid: '',
            units: '',
            value: ''
          }
        ],
        procedures: [{bodySite: '', id: 0, type: ''}],
        status: ''
      }
    ],
    groupCode: '',
    identifier: '',
    observations: [{}],
    patient: {
      address1: '',
      address2: '',
      address3: '',
      address4: '',
      contacts: [{id: 0, system: '', use: '', value: ''}],
      dateOfBirth: '',
      dateOfBirthNoTime: '',
      forename: '',
      gender: '',
      group: {},
      groupCode: '',
      identifier: '',
      identifiers: [{id: 0, label: '', value: ''}],
      postcode: '',
      practitioners: [
        {
          address1: '',
          address2: '',
          address3: '',
          address4: '',
          allowInviteGp: false,
          contacts: [{}],
          gender: '',
          groupCode: '',
          identifier: '',
          inviteDate: '',
          name: '',
          postcode: '',
          role: ''
        }
      ],
      surname: ''
    },
    practitioners: [{}]
  },
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/patientmanagement/validate');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  condition: {
    asserter: '',
    category: '',
    code: '',
    date: '',
    description: '',
    fullDescription: '',
    group: {
      address1: '',
      address2: '',
      address3: '',
      childGroups: [],
      code: '',
      contactPoints: [
        {
          contactPointType: {
            description: '',
            id: 0,
            lookupType: {
              created: '',
              description: '',
              id: 0,
              lastUpdate: '',
              type: ''
            },
            value: ''
          },
          content: '',
          created: '',
          id: 0,
          lastUpdate: ''
        }
      ],
      created: '',
      fhirResourceId: '',
      groupFeatures: [
        {
          created: '',
          feature: {
            created: '',
            description: '',
            id: 0,
            lastUpdate: '',
            name: ''
          },
          id: 0,
          lastUpdate: ''
        }
      ],
      groupType: {
        created: '',
        description: '',
        descriptionFriendly: '',
        displayOrder: 0,
        id: 0,
        lastUpdate: '',
        lookupType: {},
        value: ''
      },
      id: 0,
      lastImportDate: '',
      lastUpdate: '',
      links: [
        {
          created: '',
          displayOrder: 0,
          id: 0,
          lastUpdate: '',
          link: '',
          linkType: {},
          name: ''
        }
      ],
      locations: [
        {
          address: '',
          created: '',
          email: '',
          id: 0,
          label: '',
          lastUpdate: '',
          name: '',
          phone: '',
          web: ''
        }
      ],
      name: '',
      parentGroups: [],
      postcode: '',
      sftpUser: '',
      shortName: '',
      visible: false,
      visibleToJoin: false
    },
    id: 0,
    identifier: '',
    links: [
      {}
    ],
    notes: '',
    severity: '',
    status: ''
  },
  encounters: [
    {
      date: '',
      encounterType: '',
      group: {},
      id: 0,
      identifier: '',
      links: [
        {}
      ],
      observations: [
        {
          applies: '',
          bodySite: '',
          comments: '',
          comparator: '',
          diagram: '',
          group: {},
          id: 0,
          identifier: '',
          location: '',
          name: '',
          temporaryUuid: '',
          units: '',
          value: ''
        }
      ],
      procedures: [
        {
          bodySite: '',
          id: 0,
          type: ''
        }
      ],
      status: ''
    }
  ],
  groupCode: '',
  identifier: '',
  observations: [
    {}
  ],
  patient: {
    address1: '',
    address2: '',
    address3: '',
    address4: '',
    contacts: [
      {
        id: 0,
        system: '',
        use: '',
        value: ''
      }
    ],
    dateOfBirth: '',
    dateOfBirthNoTime: '',
    forename: '',
    gender: '',
    group: {},
    groupCode: '',
    identifier: '',
    identifiers: [
      {
        id: 0,
        label: '',
        value: ''
      }
    ],
    postcode: '',
    practitioners: [
      {
        address1: '',
        address2: '',
        address3: '',
        address4: '',
        allowInviteGp: false,
        contacts: [
          {}
        ],
        gender: '',
        groupCode: '',
        identifier: '',
        inviteDate: '',
        name: '',
        postcode: '',
        role: ''
      }
    ],
    surname: ''
  },
  practitioners: [
    {}
  ]
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'POST',
  url: '{{baseUrl}}/patientmanagement/validate',
  headers: {'content-type': 'application/json'},
  data: {
    condition: {
      asserter: '',
      category: '',
      code: '',
      date: '',
      description: '',
      fullDescription: '',
      group: {
        address1: '',
        address2: '',
        address3: '',
        childGroups: [],
        code: '',
        contactPoints: [
          {
            contactPointType: {
              description: '',
              id: 0,
              lookupType: {created: '', description: '', id: 0, lastUpdate: '', type: ''},
              value: ''
            },
            content: '',
            created: '',
            id: 0,
            lastUpdate: ''
          }
        ],
        created: '',
        fhirResourceId: '',
        groupFeatures: [
          {
            created: '',
            feature: {created: '', description: '', id: 0, lastUpdate: '', name: ''},
            id: 0,
            lastUpdate: ''
          }
        ],
        groupType: {
          created: '',
          description: '',
          descriptionFriendly: '',
          displayOrder: 0,
          id: 0,
          lastUpdate: '',
          lookupType: {},
          value: ''
        },
        id: 0,
        lastImportDate: '',
        lastUpdate: '',
        links: [
          {
            created: '',
            displayOrder: 0,
            id: 0,
            lastUpdate: '',
            link: '',
            linkType: {},
            name: ''
          }
        ],
        locations: [
          {
            address: '',
            created: '',
            email: '',
            id: 0,
            label: '',
            lastUpdate: '',
            name: '',
            phone: '',
            web: ''
          }
        ],
        name: '',
        parentGroups: [],
        postcode: '',
        sftpUser: '',
        shortName: '',
        visible: false,
        visibleToJoin: false
      },
      id: 0,
      identifier: '',
      links: [{}],
      notes: '',
      severity: '',
      status: ''
    },
    encounters: [
      {
        date: '',
        encounterType: '',
        group: {},
        id: 0,
        identifier: '',
        links: [{}],
        observations: [
          {
            applies: '',
            bodySite: '',
            comments: '',
            comparator: '',
            diagram: '',
            group: {},
            id: 0,
            identifier: '',
            location: '',
            name: '',
            temporaryUuid: '',
            units: '',
            value: ''
          }
        ],
        procedures: [{bodySite: '', id: 0, type: ''}],
        status: ''
      }
    ],
    groupCode: '',
    identifier: '',
    observations: [{}],
    patient: {
      address1: '',
      address2: '',
      address3: '',
      address4: '',
      contacts: [{id: 0, system: '', use: '', value: ''}],
      dateOfBirth: '',
      dateOfBirthNoTime: '',
      forename: '',
      gender: '',
      group: {},
      groupCode: '',
      identifier: '',
      identifiers: [{id: 0, label: '', value: ''}],
      postcode: '',
      practitioners: [
        {
          address1: '',
          address2: '',
          address3: '',
          address4: '',
          allowInviteGp: false,
          contacts: [{}],
          gender: '',
          groupCode: '',
          identifier: '',
          inviteDate: '',
          name: '',
          postcode: '',
          role: ''
        }
      ],
      surname: ''
    },
    practitioners: [{}]
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/patientmanagement/validate';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"condition":{"asserter":"","category":"","code":"","date":"","description":"","fullDescription":"","group":{"address1":"","address2":"","address3":"","childGroups":[],"code":"","contactPoints":[{"contactPointType":{"description":"","id":0,"lookupType":{"created":"","description":"","id":0,"lastUpdate":"","type":""},"value":""},"content":"","created":"","id":0,"lastUpdate":""}],"created":"","fhirResourceId":"","groupFeatures":[{"created":"","feature":{"created":"","description":"","id":0,"lastUpdate":"","name":""},"id":0,"lastUpdate":""}],"groupType":{"created":"","description":"","descriptionFriendly":"","displayOrder":0,"id":0,"lastUpdate":"","lookupType":{},"value":""},"id":0,"lastImportDate":"","lastUpdate":"","links":[{"created":"","displayOrder":0,"id":0,"lastUpdate":"","link":"","linkType":{},"name":""}],"locations":[{"address":"","created":"","email":"","id":0,"label":"","lastUpdate":"","name":"","phone":"","web":""}],"name":"","parentGroups":[],"postcode":"","sftpUser":"","shortName":"","visible":false,"visibleToJoin":false},"id":0,"identifier":"","links":[{}],"notes":"","severity":"","status":""},"encounters":[{"date":"","encounterType":"","group":{},"id":0,"identifier":"","links":[{}],"observations":[{"applies":"","bodySite":"","comments":"","comparator":"","diagram":"","group":{},"id":0,"identifier":"","location":"","name":"","temporaryUuid":"","units":"","value":""}],"procedures":[{"bodySite":"","id":0,"type":""}],"status":""}],"groupCode":"","identifier":"","observations":[{}],"patient":{"address1":"","address2":"","address3":"","address4":"","contacts":[{"id":0,"system":"","use":"","value":""}],"dateOfBirth":"","dateOfBirthNoTime":"","forename":"","gender":"","group":{},"groupCode":"","identifier":"","identifiers":[{"id":0,"label":"","value":""}],"postcode":"","practitioners":[{"address1":"","address2":"","address3":"","address4":"","allowInviteGp":false,"contacts":[{}],"gender":"","groupCode":"","identifier":"","inviteDate":"","name":"","postcode":"","role":""}],"surname":""},"practitioners":[{}]}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"condition": @{ @"asserter": @"", @"category": @"", @"code": @"", @"date": @"", @"description": @"", @"fullDescription": @"", @"group": @{ @"address1": @"", @"address2": @"", @"address3": @"", @"childGroups": @[  ], @"code": @"", @"contactPoints": @[ @{ @"contactPointType": @{ @"description": @"", @"id": @0, @"lookupType": @{ @"created": @"", @"description": @"", @"id": @0, @"lastUpdate": @"", @"type": @"" }, @"value": @"" }, @"content": @"", @"created": @"", @"id": @0, @"lastUpdate": @"" } ], @"created": @"", @"fhirResourceId": @"", @"groupFeatures": @[ @{ @"created": @"", @"feature": @{ @"created": @"", @"description": @"", @"id": @0, @"lastUpdate": @"", @"name": @"" }, @"id": @0, @"lastUpdate": @"" } ], @"groupType": @{ @"created": @"", @"description": @"", @"descriptionFriendly": @"", @"displayOrder": @0, @"id": @0, @"lastUpdate": @"", @"lookupType": @{  }, @"value": @"" }, @"id": @0, @"lastImportDate": @"", @"lastUpdate": @"", @"links": @[ @{ @"created": @"", @"displayOrder": @0, @"id": @0, @"lastUpdate": @"", @"link": @"", @"linkType": @{  }, @"name": @"" } ], @"locations": @[ @{ @"address": @"", @"created": @"", @"email": @"", @"id": @0, @"label": @"", @"lastUpdate": @"", @"name": @"", @"phone": @"", @"web": @"" } ], @"name": @"", @"parentGroups": @[  ], @"postcode": @"", @"sftpUser": @"", @"shortName": @"", @"visible": @NO, @"visibleToJoin": @NO }, @"id": @0, @"identifier": @"", @"links": @[ @{  } ], @"notes": @"", @"severity": @"", @"status": @"" },
                              @"encounters": @[ @{ @"date": @"", @"encounterType": @"", @"group": @{  }, @"id": @0, @"identifier": @"", @"links": @[ @{  } ], @"observations": @[ @{ @"applies": @"", @"bodySite": @"", @"comments": @"", @"comparator": @"", @"diagram": @"", @"group": @{  }, @"id": @0, @"identifier": @"", @"location": @"", @"name": @"", @"temporaryUuid": @"", @"units": @"", @"value": @"" } ], @"procedures": @[ @{ @"bodySite": @"", @"id": @0, @"type": @"" } ], @"status": @"" } ],
                              @"groupCode": @"",
                              @"identifier": @"",
                              @"observations": @[ @{  } ],
                              @"patient": @{ @"address1": @"", @"address2": @"", @"address3": @"", @"address4": @"", @"contacts": @[ @{ @"id": @0, @"system": @"", @"use": @"", @"value": @"" } ], @"dateOfBirth": @"", @"dateOfBirthNoTime": @"", @"forename": @"", @"gender": @"", @"group": @{  }, @"groupCode": @"", @"identifier": @"", @"identifiers": @[ @{ @"id": @0, @"label": @"", @"value": @"" } ], @"postcode": @"", @"practitioners": @[ @{ @"address1": @"", @"address2": @"", @"address3": @"", @"address4": @"", @"allowInviteGp": @NO, @"contacts": @[ @{  } ], @"gender": @"", @"groupCode": @"", @"identifier": @"", @"inviteDate": @"", @"name": @"", @"postcode": @"", @"role": @"" } ], @"surname": @"" },
                              @"practitioners": @[ @{  } ] };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/patientmanagement/validate"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/patientmanagement/validate" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"condition\": {\n    \"asserter\": \"\",\n    \"category\": \"\",\n    \"code\": \"\",\n    \"date\": \"\",\n    \"description\": \"\",\n    \"fullDescription\": \"\",\n    \"group\": {\n      \"address1\": \"\",\n      \"address2\": \"\",\n      \"address3\": \"\",\n      \"childGroups\": [],\n      \"code\": \"\",\n      \"contactPoints\": [\n        {\n          \"contactPointType\": {\n            \"description\": \"\",\n            \"id\": 0,\n            \"lookupType\": {\n              \"created\": \"\",\n              \"description\": \"\",\n              \"id\": 0,\n              \"lastUpdate\": \"\",\n              \"type\": \"\"\n            },\n            \"value\": \"\"\n          },\n          \"content\": \"\",\n          \"created\": \"\",\n          \"id\": 0,\n          \"lastUpdate\": \"\"\n        }\n      ],\n      \"created\": \"\",\n      \"fhirResourceId\": \"\",\n      \"groupFeatures\": [\n        {\n          \"created\": \"\",\n          \"feature\": {\n            \"created\": \"\",\n            \"description\": \"\",\n            \"id\": 0,\n            \"lastUpdate\": \"\",\n            \"name\": \"\"\n          },\n          \"id\": 0,\n          \"lastUpdate\": \"\"\n        }\n      ],\n      \"groupType\": {\n        \"created\": \"\",\n        \"description\": \"\",\n        \"descriptionFriendly\": \"\",\n        \"displayOrder\": 0,\n        \"id\": 0,\n        \"lastUpdate\": \"\",\n        \"lookupType\": {},\n        \"value\": \"\"\n      },\n      \"id\": 0,\n      \"lastImportDate\": \"\",\n      \"lastUpdate\": \"\",\n      \"links\": [\n        {\n          \"created\": \"\",\n          \"displayOrder\": 0,\n          \"id\": 0,\n          \"lastUpdate\": \"\",\n          \"link\": \"\",\n          \"linkType\": {},\n          \"name\": \"\"\n        }\n      ],\n      \"locations\": [\n        {\n          \"address\": \"\",\n          \"created\": \"\",\n          \"email\": \"\",\n          \"id\": 0,\n          \"label\": \"\",\n          \"lastUpdate\": \"\",\n          \"name\": \"\",\n          \"phone\": \"\",\n          \"web\": \"\"\n        }\n      ],\n      \"name\": \"\",\n      \"parentGroups\": [],\n      \"postcode\": \"\",\n      \"sftpUser\": \"\",\n      \"shortName\": \"\",\n      \"visible\": false,\n      \"visibleToJoin\": false\n    },\n    \"id\": 0,\n    \"identifier\": \"\",\n    \"links\": [\n      {}\n    ],\n    \"notes\": \"\",\n    \"severity\": \"\",\n    \"status\": \"\"\n  },\n  \"encounters\": [\n    {\n      \"date\": \"\",\n      \"encounterType\": \"\",\n      \"group\": {},\n      \"id\": 0,\n      \"identifier\": \"\",\n      \"links\": [\n        {}\n      ],\n      \"observations\": [\n        {\n          \"applies\": \"\",\n          \"bodySite\": \"\",\n          \"comments\": \"\",\n          \"comparator\": \"\",\n          \"diagram\": \"\",\n          \"group\": {},\n          \"id\": 0,\n          \"identifier\": \"\",\n          \"location\": \"\",\n          \"name\": \"\",\n          \"temporaryUuid\": \"\",\n          \"units\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"procedures\": [\n        {\n          \"bodySite\": \"\",\n          \"id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"status\": \"\"\n    }\n  ],\n  \"groupCode\": \"\",\n  \"identifier\": \"\",\n  \"observations\": [\n    {}\n  ],\n  \"patient\": {\n    \"address1\": \"\",\n    \"address2\": \"\",\n    \"address3\": \"\",\n    \"address4\": \"\",\n    \"contacts\": [\n      {\n        \"id\": 0,\n        \"system\": \"\",\n        \"use\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"dateOfBirth\": \"\",\n    \"dateOfBirthNoTime\": \"\",\n    \"forename\": \"\",\n    \"gender\": \"\",\n    \"group\": {},\n    \"groupCode\": \"\",\n    \"identifier\": \"\",\n    \"identifiers\": [\n      {\n        \"id\": 0,\n        \"label\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"postcode\": \"\",\n    \"practitioners\": [\n      {\n        \"address1\": \"\",\n        \"address2\": \"\",\n        \"address3\": \"\",\n        \"address4\": \"\",\n        \"allowInviteGp\": false,\n        \"contacts\": [\n          {}\n        ],\n        \"gender\": \"\",\n        \"groupCode\": \"\",\n        \"identifier\": \"\",\n        \"inviteDate\": \"\",\n        \"name\": \"\",\n        \"postcode\": \"\",\n        \"role\": \"\"\n      }\n    ],\n    \"surname\": \"\"\n  },\n  \"practitioners\": [\n    {}\n  ]\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/patientmanagement/validate",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'condition' => [
        'asserter' => '',
        'category' => '',
        'code' => '',
        'date' => '',
        'description' => '',
        'fullDescription' => '',
        'group' => [
                'address1' => '',
                'address2' => '',
                'address3' => '',
                'childGroups' => [
                                
                ],
                'code' => '',
                'contactPoints' => [
                                [
                                                                'contactPointType' => [
                                                                                                                                'description' => '',
                                                                                                                                'id' => 0,
                                                                                                                                'lookupType' => [
                                                                                                                                                                                                                                                                'created' => '',
                                                                                                                                                                                                                                                                'description' => '',
                                                                                                                                                                                                                                                                'id' => 0,
                                                                                                                                                                                                                                                                'lastUpdate' => '',
                                                                                                                                                                                                                                                                'type' => ''
                                                                                                                                ],
                                                                                                                                'value' => ''
                                                                ],
                                                                'content' => '',
                                                                'created' => '',
                                                                'id' => 0,
                                                                'lastUpdate' => ''
                                ]
                ],
                'created' => '',
                'fhirResourceId' => '',
                'groupFeatures' => [
                                [
                                                                'created' => '',
                                                                'feature' => [
                                                                                                                                'created' => '',
                                                                                                                                'description' => '',
                                                                                                                                'id' => 0,
                                                                                                                                'lastUpdate' => '',
                                                                                                                                'name' => ''
                                                                ],
                                                                'id' => 0,
                                                                'lastUpdate' => ''
                                ]
                ],
                'groupType' => [
                                'created' => '',
                                'description' => '',
                                'descriptionFriendly' => '',
                                'displayOrder' => 0,
                                'id' => 0,
                                'lastUpdate' => '',
                                'lookupType' => [
                                                                
                                ],
                                'value' => ''
                ],
                'id' => 0,
                'lastImportDate' => '',
                'lastUpdate' => '',
                'links' => [
                                [
                                                                'created' => '',
                                                                'displayOrder' => 0,
                                                                'id' => 0,
                                                                'lastUpdate' => '',
                                                                'link' => '',
                                                                'linkType' => [
                                                                                                                                
                                                                ],
                                                                'name' => ''
                                ]
                ],
                'locations' => [
                                [
                                                                'address' => '',
                                                                'created' => '',
                                                                'email' => '',
                                                                'id' => 0,
                                                                'label' => '',
                                                                'lastUpdate' => '',
                                                                'name' => '',
                                                                'phone' => '',
                                                                'web' => ''
                                ]
                ],
                'name' => '',
                'parentGroups' => [
                                
                ],
                'postcode' => '',
                'sftpUser' => '',
                'shortName' => '',
                'visible' => null,
                'visibleToJoin' => null
        ],
        'id' => 0,
        'identifier' => '',
        'links' => [
                [
                                
                ]
        ],
        'notes' => '',
        'severity' => '',
        'status' => ''
    ],
    'encounters' => [
        [
                'date' => '',
                'encounterType' => '',
                'group' => [
                                
                ],
                'id' => 0,
                'identifier' => '',
                'links' => [
                                [
                                                                
                                ]
                ],
                'observations' => [
                                [
                                                                'applies' => '',
                                                                'bodySite' => '',
                                                                'comments' => '',
                                                                'comparator' => '',
                                                                'diagram' => '',
                                                                'group' => [
                                                                                                                                
                                                                ],
                                                                'id' => 0,
                                                                'identifier' => '',
                                                                'location' => '',
                                                                'name' => '',
                                                                'temporaryUuid' => '',
                                                                'units' => '',
                                                                'value' => ''
                                ]
                ],
                'procedures' => [
                                [
                                                                'bodySite' => '',
                                                                'id' => 0,
                                                                'type' => ''
                                ]
                ],
                'status' => ''
        ]
    ],
    'groupCode' => '',
    'identifier' => '',
    'observations' => [
        [
                
        ]
    ],
    'patient' => [
        'address1' => '',
        'address2' => '',
        'address3' => '',
        'address4' => '',
        'contacts' => [
                [
                                'id' => 0,
                                'system' => '',
                                'use' => '',
                                'value' => ''
                ]
        ],
        'dateOfBirth' => '',
        'dateOfBirthNoTime' => '',
        'forename' => '',
        'gender' => '',
        'group' => [
                
        ],
        'groupCode' => '',
        'identifier' => '',
        'identifiers' => [
                [
                                'id' => 0,
                                'label' => '',
                                'value' => ''
                ]
        ],
        'postcode' => '',
        'practitioners' => [
                [
                                'address1' => '',
                                'address2' => '',
                                'address3' => '',
                                'address4' => '',
                                'allowInviteGp' => null,
                                'contacts' => [
                                                                [
                                                                                                                                
                                                                ]
                                ],
                                'gender' => '',
                                'groupCode' => '',
                                'identifier' => '',
                                'inviteDate' => '',
                                'name' => '',
                                'postcode' => '',
                                'role' => ''
                ]
        ],
        'surname' => ''
    ],
    'practitioners' => [
        [
                
        ]
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/patientmanagement/validate', [
  'body' => '{
  "condition": {
    "asserter": "",
    "category": "",
    "code": "",
    "date": "",
    "description": "",
    "fullDescription": "",
    "group": {
      "address1": "",
      "address2": "",
      "address3": "",
      "childGroups": [],
      "code": "",
      "contactPoints": [
        {
          "contactPointType": {
            "description": "",
            "id": 0,
            "lookupType": {
              "created": "",
              "description": "",
              "id": 0,
              "lastUpdate": "",
              "type": ""
            },
            "value": ""
          },
          "content": "",
          "created": "",
          "id": 0,
          "lastUpdate": ""
        }
      ],
      "created": "",
      "fhirResourceId": "",
      "groupFeatures": [
        {
          "created": "",
          "feature": {
            "created": "",
            "description": "",
            "id": 0,
            "lastUpdate": "",
            "name": ""
          },
          "id": 0,
          "lastUpdate": ""
        }
      ],
      "groupType": {
        "created": "",
        "description": "",
        "descriptionFriendly": "",
        "displayOrder": 0,
        "id": 0,
        "lastUpdate": "",
        "lookupType": {},
        "value": ""
      },
      "id": 0,
      "lastImportDate": "",
      "lastUpdate": "",
      "links": [
        {
          "created": "",
          "displayOrder": 0,
          "id": 0,
          "lastUpdate": "",
          "link": "",
          "linkType": {},
          "name": ""
        }
      ],
      "locations": [
        {
          "address": "",
          "created": "",
          "email": "",
          "id": 0,
          "label": "",
          "lastUpdate": "",
          "name": "",
          "phone": "",
          "web": ""
        }
      ],
      "name": "",
      "parentGroups": [],
      "postcode": "",
      "sftpUser": "",
      "shortName": "",
      "visible": false,
      "visibleToJoin": false
    },
    "id": 0,
    "identifier": "",
    "links": [
      {}
    ],
    "notes": "",
    "severity": "",
    "status": ""
  },
  "encounters": [
    {
      "date": "",
      "encounterType": "",
      "group": {},
      "id": 0,
      "identifier": "",
      "links": [
        {}
      ],
      "observations": [
        {
          "applies": "",
          "bodySite": "",
          "comments": "",
          "comparator": "",
          "diagram": "",
          "group": {},
          "id": 0,
          "identifier": "",
          "location": "",
          "name": "",
          "temporaryUuid": "",
          "units": "",
          "value": ""
        }
      ],
      "procedures": [
        {
          "bodySite": "",
          "id": 0,
          "type": ""
        }
      ],
      "status": ""
    }
  ],
  "groupCode": "",
  "identifier": "",
  "observations": [
    {}
  ],
  "patient": {
    "address1": "",
    "address2": "",
    "address3": "",
    "address4": "",
    "contacts": [
      {
        "id": 0,
        "system": "",
        "use": "",
        "value": ""
      }
    ],
    "dateOfBirth": "",
    "dateOfBirthNoTime": "",
    "forename": "",
    "gender": "",
    "group": {},
    "groupCode": "",
    "identifier": "",
    "identifiers": [
      {
        "id": 0,
        "label": "",
        "value": ""
      }
    ],
    "postcode": "",
    "practitioners": [
      {
        "address1": "",
        "address2": "",
        "address3": "",
        "address4": "",
        "allowInviteGp": false,
        "contacts": [
          {}
        ],
        "gender": "",
        "groupCode": "",
        "identifier": "",
        "inviteDate": "",
        "name": "",
        "postcode": "",
        "role": ""
      }
    ],
    "surname": ""
  },
  "practitioners": [
    {}
  ]
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/patientmanagement/validate');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'condition' => [
    'asserter' => '',
    'category' => '',
    'code' => '',
    'date' => '',
    'description' => '',
    'fullDescription' => '',
    'group' => [
        'address1' => '',
        'address2' => '',
        'address3' => '',
        'childGroups' => [
                
        ],
        'code' => '',
        'contactPoints' => [
                [
                                'contactPointType' => [
                                                                'description' => '',
                                                                'id' => 0,
                                                                'lookupType' => [
                                                                                                                                'created' => '',
                                                                                                                                'description' => '',
                                                                                                                                'id' => 0,
                                                                                                                                'lastUpdate' => '',
                                                                                                                                'type' => ''
                                                                ],
                                                                'value' => ''
                                ],
                                'content' => '',
                                'created' => '',
                                'id' => 0,
                                'lastUpdate' => ''
                ]
        ],
        'created' => '',
        'fhirResourceId' => '',
        'groupFeatures' => [
                [
                                'created' => '',
                                'feature' => [
                                                                'created' => '',
                                                                'description' => '',
                                                                'id' => 0,
                                                                'lastUpdate' => '',
                                                                'name' => ''
                                ],
                                'id' => 0,
                                'lastUpdate' => ''
                ]
        ],
        'groupType' => [
                'created' => '',
                'description' => '',
                'descriptionFriendly' => '',
                'displayOrder' => 0,
                'id' => 0,
                'lastUpdate' => '',
                'lookupType' => [
                                
                ],
                'value' => ''
        ],
        'id' => 0,
        'lastImportDate' => '',
        'lastUpdate' => '',
        'links' => [
                [
                                'created' => '',
                                'displayOrder' => 0,
                                'id' => 0,
                                'lastUpdate' => '',
                                'link' => '',
                                'linkType' => [
                                                                
                                ],
                                'name' => ''
                ]
        ],
        'locations' => [
                [
                                'address' => '',
                                'created' => '',
                                'email' => '',
                                'id' => 0,
                                'label' => '',
                                'lastUpdate' => '',
                                'name' => '',
                                'phone' => '',
                                'web' => ''
                ]
        ],
        'name' => '',
        'parentGroups' => [
                
        ],
        'postcode' => '',
        'sftpUser' => '',
        'shortName' => '',
        'visible' => null,
        'visibleToJoin' => null
    ],
    'id' => 0,
    'identifier' => '',
    'links' => [
        [
                
        ]
    ],
    'notes' => '',
    'severity' => '',
    'status' => ''
  ],
  'encounters' => [
    [
        'date' => '',
        'encounterType' => '',
        'group' => [
                
        ],
        'id' => 0,
        'identifier' => '',
        'links' => [
                [
                                
                ]
        ],
        'observations' => [
                [
                                'applies' => '',
                                'bodySite' => '',
                                'comments' => '',
                                'comparator' => '',
                                'diagram' => '',
                                'group' => [
                                                                
                                ],
                                'id' => 0,
                                'identifier' => '',
                                'location' => '',
                                'name' => '',
                                'temporaryUuid' => '',
                                'units' => '',
                                'value' => ''
                ]
        ],
        'procedures' => [
                [
                                'bodySite' => '',
                                'id' => 0,
                                'type' => ''
                ]
        ],
        'status' => ''
    ]
  ],
  'groupCode' => '',
  'identifier' => '',
  'observations' => [
    [
        
    ]
  ],
  'patient' => [
    'address1' => '',
    'address2' => '',
    'address3' => '',
    'address4' => '',
    'contacts' => [
        [
                'id' => 0,
                'system' => '',
                'use' => '',
                'value' => ''
        ]
    ],
    'dateOfBirth' => '',
    'dateOfBirthNoTime' => '',
    'forename' => '',
    'gender' => '',
    'group' => [
        
    ],
    'groupCode' => '',
    'identifier' => '',
    'identifiers' => [
        [
                'id' => 0,
                'label' => '',
                'value' => ''
        ]
    ],
    'postcode' => '',
    'practitioners' => [
        [
                'address1' => '',
                'address2' => '',
                'address3' => '',
                'address4' => '',
                'allowInviteGp' => null,
                'contacts' => [
                                [
                                                                
                                ]
                ],
                'gender' => '',
                'groupCode' => '',
                'identifier' => '',
                'inviteDate' => '',
                'name' => '',
                'postcode' => '',
                'role' => ''
        ]
    ],
    'surname' => ''
  ],
  'practitioners' => [
    [
        
    ]
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'condition' => [
    'asserter' => '',
    'category' => '',
    'code' => '',
    'date' => '',
    'description' => '',
    'fullDescription' => '',
    'group' => [
        'address1' => '',
        'address2' => '',
        'address3' => '',
        'childGroups' => [
                
        ],
        'code' => '',
        'contactPoints' => [
                [
                                'contactPointType' => [
                                                                'description' => '',
                                                                'id' => 0,
                                                                'lookupType' => [
                                                                                                                                'created' => '',
                                                                                                                                'description' => '',
                                                                                                                                'id' => 0,
                                                                                                                                'lastUpdate' => '',
                                                                                                                                'type' => ''
                                                                ],
                                                                'value' => ''
                                ],
                                'content' => '',
                                'created' => '',
                                'id' => 0,
                                'lastUpdate' => ''
                ]
        ],
        'created' => '',
        'fhirResourceId' => '',
        'groupFeatures' => [
                [
                                'created' => '',
                                'feature' => [
                                                                'created' => '',
                                                                'description' => '',
                                                                'id' => 0,
                                                                'lastUpdate' => '',
                                                                'name' => ''
                                ],
                                'id' => 0,
                                'lastUpdate' => ''
                ]
        ],
        'groupType' => [
                'created' => '',
                'description' => '',
                'descriptionFriendly' => '',
                'displayOrder' => 0,
                'id' => 0,
                'lastUpdate' => '',
                'lookupType' => [
                                
                ],
                'value' => ''
        ],
        'id' => 0,
        'lastImportDate' => '',
        'lastUpdate' => '',
        'links' => [
                [
                                'created' => '',
                                'displayOrder' => 0,
                                'id' => 0,
                                'lastUpdate' => '',
                                'link' => '',
                                'linkType' => [
                                                                
                                ],
                                'name' => ''
                ]
        ],
        'locations' => [
                [
                                'address' => '',
                                'created' => '',
                                'email' => '',
                                'id' => 0,
                                'label' => '',
                                'lastUpdate' => '',
                                'name' => '',
                                'phone' => '',
                                'web' => ''
                ]
        ],
        'name' => '',
        'parentGroups' => [
                
        ],
        'postcode' => '',
        'sftpUser' => '',
        'shortName' => '',
        'visible' => null,
        'visibleToJoin' => null
    ],
    'id' => 0,
    'identifier' => '',
    'links' => [
        [
                
        ]
    ],
    'notes' => '',
    'severity' => '',
    'status' => ''
  ],
  'encounters' => [
    [
        'date' => '',
        'encounterType' => '',
        'group' => [
                
        ],
        'id' => 0,
        'identifier' => '',
        'links' => [
                [
                                
                ]
        ],
        'observations' => [
                [
                                'applies' => '',
                                'bodySite' => '',
                                'comments' => '',
                                'comparator' => '',
                                'diagram' => '',
                                'group' => [
                                                                
                                ],
                                'id' => 0,
                                'identifier' => '',
                                'location' => '',
                                'name' => '',
                                'temporaryUuid' => '',
                                'units' => '',
                                'value' => ''
                ]
        ],
        'procedures' => [
                [
                                'bodySite' => '',
                                'id' => 0,
                                'type' => ''
                ]
        ],
        'status' => ''
    ]
  ],
  'groupCode' => '',
  'identifier' => '',
  'observations' => [
    [
        
    ]
  ],
  'patient' => [
    'address1' => '',
    'address2' => '',
    'address3' => '',
    'address4' => '',
    'contacts' => [
        [
                'id' => 0,
                'system' => '',
                'use' => '',
                'value' => ''
        ]
    ],
    'dateOfBirth' => '',
    'dateOfBirthNoTime' => '',
    'forename' => '',
    'gender' => '',
    'group' => [
        
    ],
    'groupCode' => '',
    'identifier' => '',
    'identifiers' => [
        [
                'id' => 0,
                'label' => '',
                'value' => ''
        ]
    ],
    'postcode' => '',
    'practitioners' => [
        [
                'address1' => '',
                'address2' => '',
                'address3' => '',
                'address4' => '',
                'allowInviteGp' => null,
                'contacts' => [
                                [
                                                                
                                ]
                ],
                'gender' => '',
                'groupCode' => '',
                'identifier' => '',
                'inviteDate' => '',
                'name' => '',
                'postcode' => '',
                'role' => ''
        ]
    ],
    'surname' => ''
  ],
  'practitioners' => [
    [
        
    ]
  ]
]));
$request->setRequestUrl('{{baseUrl}}/patientmanagement/validate');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/patientmanagement/validate' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "condition": {
    "asserter": "",
    "category": "",
    "code": "",
    "date": "",
    "description": "",
    "fullDescription": "",
    "group": {
      "address1": "",
      "address2": "",
      "address3": "",
      "childGroups": [],
      "code": "",
      "contactPoints": [
        {
          "contactPointType": {
            "description": "",
            "id": 0,
            "lookupType": {
              "created": "",
              "description": "",
              "id": 0,
              "lastUpdate": "",
              "type": ""
            },
            "value": ""
          },
          "content": "",
          "created": "",
          "id": 0,
          "lastUpdate": ""
        }
      ],
      "created": "",
      "fhirResourceId": "",
      "groupFeatures": [
        {
          "created": "",
          "feature": {
            "created": "",
            "description": "",
            "id": 0,
            "lastUpdate": "",
            "name": ""
          },
          "id": 0,
          "lastUpdate": ""
        }
      ],
      "groupType": {
        "created": "",
        "description": "",
        "descriptionFriendly": "",
        "displayOrder": 0,
        "id": 0,
        "lastUpdate": "",
        "lookupType": {},
        "value": ""
      },
      "id": 0,
      "lastImportDate": "",
      "lastUpdate": "",
      "links": [
        {
          "created": "",
          "displayOrder": 0,
          "id": 0,
          "lastUpdate": "",
          "link": "",
          "linkType": {},
          "name": ""
        }
      ],
      "locations": [
        {
          "address": "",
          "created": "",
          "email": "",
          "id": 0,
          "label": "",
          "lastUpdate": "",
          "name": "",
          "phone": "",
          "web": ""
        }
      ],
      "name": "",
      "parentGroups": [],
      "postcode": "",
      "sftpUser": "",
      "shortName": "",
      "visible": false,
      "visibleToJoin": false
    },
    "id": 0,
    "identifier": "",
    "links": [
      {}
    ],
    "notes": "",
    "severity": "",
    "status": ""
  },
  "encounters": [
    {
      "date": "",
      "encounterType": "",
      "group": {},
      "id": 0,
      "identifier": "",
      "links": [
        {}
      ],
      "observations": [
        {
          "applies": "",
          "bodySite": "",
          "comments": "",
          "comparator": "",
          "diagram": "",
          "group": {},
          "id": 0,
          "identifier": "",
          "location": "",
          "name": "",
          "temporaryUuid": "",
          "units": "",
          "value": ""
        }
      ],
      "procedures": [
        {
          "bodySite": "",
          "id": 0,
          "type": ""
        }
      ],
      "status": ""
    }
  ],
  "groupCode": "",
  "identifier": "",
  "observations": [
    {}
  ],
  "patient": {
    "address1": "",
    "address2": "",
    "address3": "",
    "address4": "",
    "contacts": [
      {
        "id": 0,
        "system": "",
        "use": "",
        "value": ""
      }
    ],
    "dateOfBirth": "",
    "dateOfBirthNoTime": "",
    "forename": "",
    "gender": "",
    "group": {},
    "groupCode": "",
    "identifier": "",
    "identifiers": [
      {
        "id": 0,
        "label": "",
        "value": ""
      }
    ],
    "postcode": "",
    "practitioners": [
      {
        "address1": "",
        "address2": "",
        "address3": "",
        "address4": "",
        "allowInviteGp": false,
        "contacts": [
          {}
        ],
        "gender": "",
        "groupCode": "",
        "identifier": "",
        "inviteDate": "",
        "name": "",
        "postcode": "",
        "role": ""
      }
    ],
    "surname": ""
  },
  "practitioners": [
    {}
  ]
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/patientmanagement/validate' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "condition": {
    "asserter": "",
    "category": "",
    "code": "",
    "date": "",
    "description": "",
    "fullDescription": "",
    "group": {
      "address1": "",
      "address2": "",
      "address3": "",
      "childGroups": [],
      "code": "",
      "contactPoints": [
        {
          "contactPointType": {
            "description": "",
            "id": 0,
            "lookupType": {
              "created": "",
              "description": "",
              "id": 0,
              "lastUpdate": "",
              "type": ""
            },
            "value": ""
          },
          "content": "",
          "created": "",
          "id": 0,
          "lastUpdate": ""
        }
      ],
      "created": "",
      "fhirResourceId": "",
      "groupFeatures": [
        {
          "created": "",
          "feature": {
            "created": "",
            "description": "",
            "id": 0,
            "lastUpdate": "",
            "name": ""
          },
          "id": 0,
          "lastUpdate": ""
        }
      ],
      "groupType": {
        "created": "",
        "description": "",
        "descriptionFriendly": "",
        "displayOrder": 0,
        "id": 0,
        "lastUpdate": "",
        "lookupType": {},
        "value": ""
      },
      "id": 0,
      "lastImportDate": "",
      "lastUpdate": "",
      "links": [
        {
          "created": "",
          "displayOrder": 0,
          "id": 0,
          "lastUpdate": "",
          "link": "",
          "linkType": {},
          "name": ""
        }
      ],
      "locations": [
        {
          "address": "",
          "created": "",
          "email": "",
          "id": 0,
          "label": "",
          "lastUpdate": "",
          "name": "",
          "phone": "",
          "web": ""
        }
      ],
      "name": "",
      "parentGroups": [],
      "postcode": "",
      "sftpUser": "",
      "shortName": "",
      "visible": false,
      "visibleToJoin": false
    },
    "id": 0,
    "identifier": "",
    "links": [
      {}
    ],
    "notes": "",
    "severity": "",
    "status": ""
  },
  "encounters": [
    {
      "date": "",
      "encounterType": "",
      "group": {},
      "id": 0,
      "identifier": "",
      "links": [
        {}
      ],
      "observations": [
        {
          "applies": "",
          "bodySite": "",
          "comments": "",
          "comparator": "",
          "diagram": "",
          "group": {},
          "id": 0,
          "identifier": "",
          "location": "",
          "name": "",
          "temporaryUuid": "",
          "units": "",
          "value": ""
        }
      ],
      "procedures": [
        {
          "bodySite": "",
          "id": 0,
          "type": ""
        }
      ],
      "status": ""
    }
  ],
  "groupCode": "",
  "identifier": "",
  "observations": [
    {}
  ],
  "patient": {
    "address1": "",
    "address2": "",
    "address3": "",
    "address4": "",
    "contacts": [
      {
        "id": 0,
        "system": "",
        "use": "",
        "value": ""
      }
    ],
    "dateOfBirth": "",
    "dateOfBirthNoTime": "",
    "forename": "",
    "gender": "",
    "group": {},
    "groupCode": "",
    "identifier": "",
    "identifiers": [
      {
        "id": 0,
        "label": "",
        "value": ""
      }
    ],
    "postcode": "",
    "practitioners": [
      {
        "address1": "",
        "address2": "",
        "address3": "",
        "address4": "",
        "allowInviteGp": false,
        "contacts": [
          {}
        ],
        "gender": "",
        "groupCode": "",
        "identifier": "",
        "inviteDate": "",
        "name": "",
        "postcode": "",
        "role": ""
      }
    ],
    "surname": ""
  },
  "practitioners": [
    {}
  ]
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"condition\": {\n    \"asserter\": \"\",\n    \"category\": \"\",\n    \"code\": \"\",\n    \"date\": \"\",\n    \"description\": \"\",\n    \"fullDescription\": \"\",\n    \"group\": {\n      \"address1\": \"\",\n      \"address2\": \"\",\n      \"address3\": \"\",\n      \"childGroups\": [],\n      \"code\": \"\",\n      \"contactPoints\": [\n        {\n          \"contactPointType\": {\n            \"description\": \"\",\n            \"id\": 0,\n            \"lookupType\": {\n              \"created\": \"\",\n              \"description\": \"\",\n              \"id\": 0,\n              \"lastUpdate\": \"\",\n              \"type\": \"\"\n            },\n            \"value\": \"\"\n          },\n          \"content\": \"\",\n          \"created\": \"\",\n          \"id\": 0,\n          \"lastUpdate\": \"\"\n        }\n      ],\n      \"created\": \"\",\n      \"fhirResourceId\": \"\",\n      \"groupFeatures\": [\n        {\n          \"created\": \"\",\n          \"feature\": {\n            \"created\": \"\",\n            \"description\": \"\",\n            \"id\": 0,\n            \"lastUpdate\": \"\",\n            \"name\": \"\"\n          },\n          \"id\": 0,\n          \"lastUpdate\": \"\"\n        }\n      ],\n      \"groupType\": {\n        \"created\": \"\",\n        \"description\": \"\",\n        \"descriptionFriendly\": \"\",\n        \"displayOrder\": 0,\n        \"id\": 0,\n        \"lastUpdate\": \"\",\n        \"lookupType\": {},\n        \"value\": \"\"\n      },\n      \"id\": 0,\n      \"lastImportDate\": \"\",\n      \"lastUpdate\": \"\",\n      \"links\": [\n        {\n          \"created\": \"\",\n          \"displayOrder\": 0,\n          \"id\": 0,\n          \"lastUpdate\": \"\",\n          \"link\": \"\",\n          \"linkType\": {},\n          \"name\": \"\"\n        }\n      ],\n      \"locations\": [\n        {\n          \"address\": \"\",\n          \"created\": \"\",\n          \"email\": \"\",\n          \"id\": 0,\n          \"label\": \"\",\n          \"lastUpdate\": \"\",\n          \"name\": \"\",\n          \"phone\": \"\",\n          \"web\": \"\"\n        }\n      ],\n      \"name\": \"\",\n      \"parentGroups\": [],\n      \"postcode\": \"\",\n      \"sftpUser\": \"\",\n      \"shortName\": \"\",\n      \"visible\": false,\n      \"visibleToJoin\": false\n    },\n    \"id\": 0,\n    \"identifier\": \"\",\n    \"links\": [\n      {}\n    ],\n    \"notes\": \"\",\n    \"severity\": \"\",\n    \"status\": \"\"\n  },\n  \"encounters\": [\n    {\n      \"date\": \"\",\n      \"encounterType\": \"\",\n      \"group\": {},\n      \"id\": 0,\n      \"identifier\": \"\",\n      \"links\": [\n        {}\n      ],\n      \"observations\": [\n        {\n          \"applies\": \"\",\n          \"bodySite\": \"\",\n          \"comments\": \"\",\n          \"comparator\": \"\",\n          \"diagram\": \"\",\n          \"group\": {},\n          \"id\": 0,\n          \"identifier\": \"\",\n          \"location\": \"\",\n          \"name\": \"\",\n          \"temporaryUuid\": \"\",\n          \"units\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"procedures\": [\n        {\n          \"bodySite\": \"\",\n          \"id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"status\": \"\"\n    }\n  ],\n  \"groupCode\": \"\",\n  \"identifier\": \"\",\n  \"observations\": [\n    {}\n  ],\n  \"patient\": {\n    \"address1\": \"\",\n    \"address2\": \"\",\n    \"address3\": \"\",\n    \"address4\": \"\",\n    \"contacts\": [\n      {\n        \"id\": 0,\n        \"system\": \"\",\n        \"use\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"dateOfBirth\": \"\",\n    \"dateOfBirthNoTime\": \"\",\n    \"forename\": \"\",\n    \"gender\": \"\",\n    \"group\": {},\n    \"groupCode\": \"\",\n    \"identifier\": \"\",\n    \"identifiers\": [\n      {\n        \"id\": 0,\n        \"label\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"postcode\": \"\",\n    \"practitioners\": [\n      {\n        \"address1\": \"\",\n        \"address2\": \"\",\n        \"address3\": \"\",\n        \"address4\": \"\",\n        \"allowInviteGp\": false,\n        \"contacts\": [\n          {}\n        ],\n        \"gender\": \"\",\n        \"groupCode\": \"\",\n        \"identifier\": \"\",\n        \"inviteDate\": \"\",\n        \"name\": \"\",\n        \"postcode\": \"\",\n        \"role\": \"\"\n      }\n    ],\n    \"surname\": \"\"\n  },\n  \"practitioners\": [\n    {}\n  ]\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/patientmanagement/validate", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/patientmanagement/validate"

payload = {
    "condition": {
        "asserter": "",
        "category": "",
        "code": "",
        "date": "",
        "description": "",
        "fullDescription": "",
        "group": {
            "address1": "",
            "address2": "",
            "address3": "",
            "childGroups": [],
            "code": "",
            "contactPoints": [
                {
                    "contactPointType": {
                        "description": "",
                        "id": 0,
                        "lookupType": {
                            "created": "",
                            "description": "",
                            "id": 0,
                            "lastUpdate": "",
                            "type": ""
                        },
                        "value": ""
                    },
                    "content": "",
                    "created": "",
                    "id": 0,
                    "lastUpdate": ""
                }
            ],
            "created": "",
            "fhirResourceId": "",
            "groupFeatures": [
                {
                    "created": "",
                    "feature": {
                        "created": "",
                        "description": "",
                        "id": 0,
                        "lastUpdate": "",
                        "name": ""
                    },
                    "id": 0,
                    "lastUpdate": ""
                }
            ],
            "groupType": {
                "created": "",
                "description": "",
                "descriptionFriendly": "",
                "displayOrder": 0,
                "id": 0,
                "lastUpdate": "",
                "lookupType": {},
                "value": ""
            },
            "id": 0,
            "lastImportDate": "",
            "lastUpdate": "",
            "links": [
                {
                    "created": "",
                    "displayOrder": 0,
                    "id": 0,
                    "lastUpdate": "",
                    "link": "",
                    "linkType": {},
                    "name": ""
                }
            ],
            "locations": [
                {
                    "address": "",
                    "created": "",
                    "email": "",
                    "id": 0,
                    "label": "",
                    "lastUpdate": "",
                    "name": "",
                    "phone": "",
                    "web": ""
                }
            ],
            "name": "",
            "parentGroups": [],
            "postcode": "",
            "sftpUser": "",
            "shortName": "",
            "visible": False,
            "visibleToJoin": False
        },
        "id": 0,
        "identifier": "",
        "links": [{}],
        "notes": "",
        "severity": "",
        "status": ""
    },
    "encounters": [
        {
            "date": "",
            "encounterType": "",
            "group": {},
            "id": 0,
            "identifier": "",
            "links": [{}],
            "observations": [
                {
                    "applies": "",
                    "bodySite": "",
                    "comments": "",
                    "comparator": "",
                    "diagram": "",
                    "group": {},
                    "id": 0,
                    "identifier": "",
                    "location": "",
                    "name": "",
                    "temporaryUuid": "",
                    "units": "",
                    "value": ""
                }
            ],
            "procedures": [
                {
                    "bodySite": "",
                    "id": 0,
                    "type": ""
                }
            ],
            "status": ""
        }
    ],
    "groupCode": "",
    "identifier": "",
    "observations": [{}],
    "patient": {
        "address1": "",
        "address2": "",
        "address3": "",
        "address4": "",
        "contacts": [
            {
                "id": 0,
                "system": "",
                "use": "",
                "value": ""
            }
        ],
        "dateOfBirth": "",
        "dateOfBirthNoTime": "",
        "forename": "",
        "gender": "",
        "group": {},
        "groupCode": "",
        "identifier": "",
        "identifiers": [
            {
                "id": 0,
                "label": "",
                "value": ""
            }
        ],
        "postcode": "",
        "practitioners": [
            {
                "address1": "",
                "address2": "",
                "address3": "",
                "address4": "",
                "allowInviteGp": False,
                "contacts": [{}],
                "gender": "",
                "groupCode": "",
                "identifier": "",
                "inviteDate": "",
                "name": "",
                "postcode": "",
                "role": ""
            }
        ],
        "surname": ""
    },
    "practitioners": [{}]
}
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/patientmanagement/validate"

payload <- "{\n  \"condition\": {\n    \"asserter\": \"\",\n    \"category\": \"\",\n    \"code\": \"\",\n    \"date\": \"\",\n    \"description\": \"\",\n    \"fullDescription\": \"\",\n    \"group\": {\n      \"address1\": \"\",\n      \"address2\": \"\",\n      \"address3\": \"\",\n      \"childGroups\": [],\n      \"code\": \"\",\n      \"contactPoints\": [\n        {\n          \"contactPointType\": {\n            \"description\": \"\",\n            \"id\": 0,\n            \"lookupType\": {\n              \"created\": \"\",\n              \"description\": \"\",\n              \"id\": 0,\n              \"lastUpdate\": \"\",\n              \"type\": \"\"\n            },\n            \"value\": \"\"\n          },\n          \"content\": \"\",\n          \"created\": \"\",\n          \"id\": 0,\n          \"lastUpdate\": \"\"\n        }\n      ],\n      \"created\": \"\",\n      \"fhirResourceId\": \"\",\n      \"groupFeatures\": [\n        {\n          \"created\": \"\",\n          \"feature\": {\n            \"created\": \"\",\n            \"description\": \"\",\n            \"id\": 0,\n            \"lastUpdate\": \"\",\n            \"name\": \"\"\n          },\n          \"id\": 0,\n          \"lastUpdate\": \"\"\n        }\n      ],\n      \"groupType\": {\n        \"created\": \"\",\n        \"description\": \"\",\n        \"descriptionFriendly\": \"\",\n        \"displayOrder\": 0,\n        \"id\": 0,\n        \"lastUpdate\": \"\",\n        \"lookupType\": {},\n        \"value\": \"\"\n      },\n      \"id\": 0,\n      \"lastImportDate\": \"\",\n      \"lastUpdate\": \"\",\n      \"links\": [\n        {\n          \"created\": \"\",\n          \"displayOrder\": 0,\n          \"id\": 0,\n          \"lastUpdate\": \"\",\n          \"link\": \"\",\n          \"linkType\": {},\n          \"name\": \"\"\n        }\n      ],\n      \"locations\": [\n        {\n          \"address\": \"\",\n          \"created\": \"\",\n          \"email\": \"\",\n          \"id\": 0,\n          \"label\": \"\",\n          \"lastUpdate\": \"\",\n          \"name\": \"\",\n          \"phone\": \"\",\n          \"web\": \"\"\n        }\n      ],\n      \"name\": \"\",\n      \"parentGroups\": [],\n      \"postcode\": \"\",\n      \"sftpUser\": \"\",\n      \"shortName\": \"\",\n      \"visible\": false,\n      \"visibleToJoin\": false\n    },\n    \"id\": 0,\n    \"identifier\": \"\",\n    \"links\": [\n      {}\n    ],\n    \"notes\": \"\",\n    \"severity\": \"\",\n    \"status\": \"\"\n  },\n  \"encounters\": [\n    {\n      \"date\": \"\",\n      \"encounterType\": \"\",\n      \"group\": {},\n      \"id\": 0,\n      \"identifier\": \"\",\n      \"links\": [\n        {}\n      ],\n      \"observations\": [\n        {\n          \"applies\": \"\",\n          \"bodySite\": \"\",\n          \"comments\": \"\",\n          \"comparator\": \"\",\n          \"diagram\": \"\",\n          \"group\": {},\n          \"id\": 0,\n          \"identifier\": \"\",\n          \"location\": \"\",\n          \"name\": \"\",\n          \"temporaryUuid\": \"\",\n          \"units\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"procedures\": [\n        {\n          \"bodySite\": \"\",\n          \"id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"status\": \"\"\n    }\n  ],\n  \"groupCode\": \"\",\n  \"identifier\": \"\",\n  \"observations\": [\n    {}\n  ],\n  \"patient\": {\n    \"address1\": \"\",\n    \"address2\": \"\",\n    \"address3\": \"\",\n    \"address4\": \"\",\n    \"contacts\": [\n      {\n        \"id\": 0,\n        \"system\": \"\",\n        \"use\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"dateOfBirth\": \"\",\n    \"dateOfBirthNoTime\": \"\",\n    \"forename\": \"\",\n    \"gender\": \"\",\n    \"group\": {},\n    \"groupCode\": \"\",\n    \"identifier\": \"\",\n    \"identifiers\": [\n      {\n        \"id\": 0,\n        \"label\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"postcode\": \"\",\n    \"practitioners\": [\n      {\n        \"address1\": \"\",\n        \"address2\": \"\",\n        \"address3\": \"\",\n        \"address4\": \"\",\n        \"allowInviteGp\": false,\n        \"contacts\": [\n          {}\n        ],\n        \"gender\": \"\",\n        \"groupCode\": \"\",\n        \"identifier\": \"\",\n        \"inviteDate\": \"\",\n        \"name\": \"\",\n        \"postcode\": \"\",\n        \"role\": \"\"\n      }\n    ],\n    \"surname\": \"\"\n  },\n  \"practitioners\": [\n    {}\n  ]\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/patientmanagement/validate")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"condition\": {\n    \"asserter\": \"\",\n    \"category\": \"\",\n    \"code\": \"\",\n    \"date\": \"\",\n    \"description\": \"\",\n    \"fullDescription\": \"\",\n    \"group\": {\n      \"address1\": \"\",\n      \"address2\": \"\",\n      \"address3\": \"\",\n      \"childGroups\": [],\n      \"code\": \"\",\n      \"contactPoints\": [\n        {\n          \"contactPointType\": {\n            \"description\": \"\",\n            \"id\": 0,\n            \"lookupType\": {\n              \"created\": \"\",\n              \"description\": \"\",\n              \"id\": 0,\n              \"lastUpdate\": \"\",\n              \"type\": \"\"\n            },\n            \"value\": \"\"\n          },\n          \"content\": \"\",\n          \"created\": \"\",\n          \"id\": 0,\n          \"lastUpdate\": \"\"\n        }\n      ],\n      \"created\": \"\",\n      \"fhirResourceId\": \"\",\n      \"groupFeatures\": [\n        {\n          \"created\": \"\",\n          \"feature\": {\n            \"created\": \"\",\n            \"description\": \"\",\n            \"id\": 0,\n            \"lastUpdate\": \"\",\n            \"name\": \"\"\n          },\n          \"id\": 0,\n          \"lastUpdate\": \"\"\n        }\n      ],\n      \"groupType\": {\n        \"created\": \"\",\n        \"description\": \"\",\n        \"descriptionFriendly\": \"\",\n        \"displayOrder\": 0,\n        \"id\": 0,\n        \"lastUpdate\": \"\",\n        \"lookupType\": {},\n        \"value\": \"\"\n      },\n      \"id\": 0,\n      \"lastImportDate\": \"\",\n      \"lastUpdate\": \"\",\n      \"links\": [\n        {\n          \"created\": \"\",\n          \"displayOrder\": 0,\n          \"id\": 0,\n          \"lastUpdate\": \"\",\n          \"link\": \"\",\n          \"linkType\": {},\n          \"name\": \"\"\n        }\n      ],\n      \"locations\": [\n        {\n          \"address\": \"\",\n          \"created\": \"\",\n          \"email\": \"\",\n          \"id\": 0,\n          \"label\": \"\",\n          \"lastUpdate\": \"\",\n          \"name\": \"\",\n          \"phone\": \"\",\n          \"web\": \"\"\n        }\n      ],\n      \"name\": \"\",\n      \"parentGroups\": [],\n      \"postcode\": \"\",\n      \"sftpUser\": \"\",\n      \"shortName\": \"\",\n      \"visible\": false,\n      \"visibleToJoin\": false\n    },\n    \"id\": 0,\n    \"identifier\": \"\",\n    \"links\": [\n      {}\n    ],\n    \"notes\": \"\",\n    \"severity\": \"\",\n    \"status\": \"\"\n  },\n  \"encounters\": [\n    {\n      \"date\": \"\",\n      \"encounterType\": \"\",\n      \"group\": {},\n      \"id\": 0,\n      \"identifier\": \"\",\n      \"links\": [\n        {}\n      ],\n      \"observations\": [\n        {\n          \"applies\": \"\",\n          \"bodySite\": \"\",\n          \"comments\": \"\",\n          \"comparator\": \"\",\n          \"diagram\": \"\",\n          \"group\": {},\n          \"id\": 0,\n          \"identifier\": \"\",\n          \"location\": \"\",\n          \"name\": \"\",\n          \"temporaryUuid\": \"\",\n          \"units\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"procedures\": [\n        {\n          \"bodySite\": \"\",\n          \"id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"status\": \"\"\n    }\n  ],\n  \"groupCode\": \"\",\n  \"identifier\": \"\",\n  \"observations\": [\n    {}\n  ],\n  \"patient\": {\n    \"address1\": \"\",\n    \"address2\": \"\",\n    \"address3\": \"\",\n    \"address4\": \"\",\n    \"contacts\": [\n      {\n        \"id\": 0,\n        \"system\": \"\",\n        \"use\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"dateOfBirth\": \"\",\n    \"dateOfBirthNoTime\": \"\",\n    \"forename\": \"\",\n    \"gender\": \"\",\n    \"group\": {},\n    \"groupCode\": \"\",\n    \"identifier\": \"\",\n    \"identifiers\": [\n      {\n        \"id\": 0,\n        \"label\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"postcode\": \"\",\n    \"practitioners\": [\n      {\n        \"address1\": \"\",\n        \"address2\": \"\",\n        \"address3\": \"\",\n        \"address4\": \"\",\n        \"allowInviteGp\": false,\n        \"contacts\": [\n          {}\n        ],\n        \"gender\": \"\",\n        \"groupCode\": \"\",\n        \"identifier\": \"\",\n        \"inviteDate\": \"\",\n        \"name\": \"\",\n        \"postcode\": \"\",\n        \"role\": \"\"\n      }\n    ],\n    \"surname\": \"\"\n  },\n  \"practitioners\": [\n    {}\n  ]\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/patientmanagement/validate') do |req|
  req.body = "{\n  \"condition\": {\n    \"asserter\": \"\",\n    \"category\": \"\",\n    \"code\": \"\",\n    \"date\": \"\",\n    \"description\": \"\",\n    \"fullDescription\": \"\",\n    \"group\": {\n      \"address1\": \"\",\n      \"address2\": \"\",\n      \"address3\": \"\",\n      \"childGroups\": [],\n      \"code\": \"\",\n      \"contactPoints\": [\n        {\n          \"contactPointType\": {\n            \"description\": \"\",\n            \"id\": 0,\n            \"lookupType\": {\n              \"created\": \"\",\n              \"description\": \"\",\n              \"id\": 0,\n              \"lastUpdate\": \"\",\n              \"type\": \"\"\n            },\n            \"value\": \"\"\n          },\n          \"content\": \"\",\n          \"created\": \"\",\n          \"id\": 0,\n          \"lastUpdate\": \"\"\n        }\n      ],\n      \"created\": \"\",\n      \"fhirResourceId\": \"\",\n      \"groupFeatures\": [\n        {\n          \"created\": \"\",\n          \"feature\": {\n            \"created\": \"\",\n            \"description\": \"\",\n            \"id\": 0,\n            \"lastUpdate\": \"\",\n            \"name\": \"\"\n          },\n          \"id\": 0,\n          \"lastUpdate\": \"\"\n        }\n      ],\n      \"groupType\": {\n        \"created\": \"\",\n        \"description\": \"\",\n        \"descriptionFriendly\": \"\",\n        \"displayOrder\": 0,\n        \"id\": 0,\n        \"lastUpdate\": \"\",\n        \"lookupType\": {},\n        \"value\": \"\"\n      },\n      \"id\": 0,\n      \"lastImportDate\": \"\",\n      \"lastUpdate\": \"\",\n      \"links\": [\n        {\n          \"created\": \"\",\n          \"displayOrder\": 0,\n          \"id\": 0,\n          \"lastUpdate\": \"\",\n          \"link\": \"\",\n          \"linkType\": {},\n          \"name\": \"\"\n        }\n      ],\n      \"locations\": [\n        {\n          \"address\": \"\",\n          \"created\": \"\",\n          \"email\": \"\",\n          \"id\": 0,\n          \"label\": \"\",\n          \"lastUpdate\": \"\",\n          \"name\": \"\",\n          \"phone\": \"\",\n          \"web\": \"\"\n        }\n      ],\n      \"name\": \"\",\n      \"parentGroups\": [],\n      \"postcode\": \"\",\n      \"sftpUser\": \"\",\n      \"shortName\": \"\",\n      \"visible\": false,\n      \"visibleToJoin\": false\n    },\n    \"id\": 0,\n    \"identifier\": \"\",\n    \"links\": [\n      {}\n    ],\n    \"notes\": \"\",\n    \"severity\": \"\",\n    \"status\": \"\"\n  },\n  \"encounters\": [\n    {\n      \"date\": \"\",\n      \"encounterType\": \"\",\n      \"group\": {},\n      \"id\": 0,\n      \"identifier\": \"\",\n      \"links\": [\n        {}\n      ],\n      \"observations\": [\n        {\n          \"applies\": \"\",\n          \"bodySite\": \"\",\n          \"comments\": \"\",\n          \"comparator\": \"\",\n          \"diagram\": \"\",\n          \"group\": {},\n          \"id\": 0,\n          \"identifier\": \"\",\n          \"location\": \"\",\n          \"name\": \"\",\n          \"temporaryUuid\": \"\",\n          \"units\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"procedures\": [\n        {\n          \"bodySite\": \"\",\n          \"id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"status\": \"\"\n    }\n  ],\n  \"groupCode\": \"\",\n  \"identifier\": \"\",\n  \"observations\": [\n    {}\n  ],\n  \"patient\": {\n    \"address1\": \"\",\n    \"address2\": \"\",\n    \"address3\": \"\",\n    \"address4\": \"\",\n    \"contacts\": [\n      {\n        \"id\": 0,\n        \"system\": \"\",\n        \"use\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"dateOfBirth\": \"\",\n    \"dateOfBirthNoTime\": \"\",\n    \"forename\": \"\",\n    \"gender\": \"\",\n    \"group\": {},\n    \"groupCode\": \"\",\n    \"identifier\": \"\",\n    \"identifiers\": [\n      {\n        \"id\": 0,\n        \"label\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"postcode\": \"\",\n    \"practitioners\": [\n      {\n        \"address1\": \"\",\n        \"address2\": \"\",\n        \"address3\": \"\",\n        \"address4\": \"\",\n        \"allowInviteGp\": false,\n        \"contacts\": [\n          {}\n        ],\n        \"gender\": \"\",\n        \"groupCode\": \"\",\n        \"identifier\": \"\",\n        \"inviteDate\": \"\",\n        \"name\": \"\",\n        \"postcode\": \"\",\n        \"role\": \"\"\n      }\n    ],\n    \"surname\": \"\"\n  },\n  \"practitioners\": [\n    {}\n  ]\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/patientmanagement/validate";

    let payload = json!({
        "condition": json!({
            "asserter": "",
            "category": "",
            "code": "",
            "date": "",
            "description": "",
            "fullDescription": "",
            "group": json!({
                "address1": "",
                "address2": "",
                "address3": "",
                "childGroups": (),
                "code": "",
                "contactPoints": (
                    json!({
                        "contactPointType": json!({
                            "description": "",
                            "id": 0,
                            "lookupType": json!({
                                "created": "",
                                "description": "",
                                "id": 0,
                                "lastUpdate": "",
                                "type": ""
                            }),
                            "value": ""
                        }),
                        "content": "",
                        "created": "",
                        "id": 0,
                        "lastUpdate": ""
                    })
                ),
                "created": "",
                "fhirResourceId": "",
                "groupFeatures": (
                    json!({
                        "created": "",
                        "feature": json!({
                            "created": "",
                            "description": "",
                            "id": 0,
                            "lastUpdate": "",
                            "name": ""
                        }),
                        "id": 0,
                        "lastUpdate": ""
                    })
                ),
                "groupType": json!({
                    "created": "",
                    "description": "",
                    "descriptionFriendly": "",
                    "displayOrder": 0,
                    "id": 0,
                    "lastUpdate": "",
                    "lookupType": json!({}),
                    "value": ""
                }),
                "id": 0,
                "lastImportDate": "",
                "lastUpdate": "",
                "links": (
                    json!({
                        "created": "",
                        "displayOrder": 0,
                        "id": 0,
                        "lastUpdate": "",
                        "link": "",
                        "linkType": json!({}),
                        "name": ""
                    })
                ),
                "locations": (
                    json!({
                        "address": "",
                        "created": "",
                        "email": "",
                        "id": 0,
                        "label": "",
                        "lastUpdate": "",
                        "name": "",
                        "phone": "",
                        "web": ""
                    })
                ),
                "name": "",
                "parentGroups": (),
                "postcode": "",
                "sftpUser": "",
                "shortName": "",
                "visible": false,
                "visibleToJoin": false
            }),
            "id": 0,
            "identifier": "",
            "links": (json!({})),
            "notes": "",
            "severity": "",
            "status": ""
        }),
        "encounters": (
            json!({
                "date": "",
                "encounterType": "",
                "group": json!({}),
                "id": 0,
                "identifier": "",
                "links": (json!({})),
                "observations": (
                    json!({
                        "applies": "",
                        "bodySite": "",
                        "comments": "",
                        "comparator": "",
                        "diagram": "",
                        "group": json!({}),
                        "id": 0,
                        "identifier": "",
                        "location": "",
                        "name": "",
                        "temporaryUuid": "",
                        "units": "",
                        "value": ""
                    })
                ),
                "procedures": (
                    json!({
                        "bodySite": "",
                        "id": 0,
                        "type": ""
                    })
                ),
                "status": ""
            })
        ),
        "groupCode": "",
        "identifier": "",
        "observations": (json!({})),
        "patient": json!({
            "address1": "",
            "address2": "",
            "address3": "",
            "address4": "",
            "contacts": (
                json!({
                    "id": 0,
                    "system": "",
                    "use": "",
                    "value": ""
                })
            ),
            "dateOfBirth": "",
            "dateOfBirthNoTime": "",
            "forename": "",
            "gender": "",
            "group": json!({}),
            "groupCode": "",
            "identifier": "",
            "identifiers": (
                json!({
                    "id": 0,
                    "label": "",
                    "value": ""
                })
            ),
            "postcode": "",
            "practitioners": (
                json!({
                    "address1": "",
                    "address2": "",
                    "address3": "",
                    "address4": "",
                    "allowInviteGp": false,
                    "contacts": (json!({})),
                    "gender": "",
                    "groupCode": "",
                    "identifier": "",
                    "inviteDate": "",
                    "name": "",
                    "postcode": "",
                    "role": ""
                })
            ),
            "surname": ""
        }),
        "practitioners": (json!({}))
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/patientmanagement/validate \
  --header 'content-type: application/json' \
  --data '{
  "condition": {
    "asserter": "",
    "category": "",
    "code": "",
    "date": "",
    "description": "",
    "fullDescription": "",
    "group": {
      "address1": "",
      "address2": "",
      "address3": "",
      "childGroups": [],
      "code": "",
      "contactPoints": [
        {
          "contactPointType": {
            "description": "",
            "id": 0,
            "lookupType": {
              "created": "",
              "description": "",
              "id": 0,
              "lastUpdate": "",
              "type": ""
            },
            "value": ""
          },
          "content": "",
          "created": "",
          "id": 0,
          "lastUpdate": ""
        }
      ],
      "created": "",
      "fhirResourceId": "",
      "groupFeatures": [
        {
          "created": "",
          "feature": {
            "created": "",
            "description": "",
            "id": 0,
            "lastUpdate": "",
            "name": ""
          },
          "id": 0,
          "lastUpdate": ""
        }
      ],
      "groupType": {
        "created": "",
        "description": "",
        "descriptionFriendly": "",
        "displayOrder": 0,
        "id": 0,
        "lastUpdate": "",
        "lookupType": {},
        "value": ""
      },
      "id": 0,
      "lastImportDate": "",
      "lastUpdate": "",
      "links": [
        {
          "created": "",
          "displayOrder": 0,
          "id": 0,
          "lastUpdate": "",
          "link": "",
          "linkType": {},
          "name": ""
        }
      ],
      "locations": [
        {
          "address": "",
          "created": "",
          "email": "",
          "id": 0,
          "label": "",
          "lastUpdate": "",
          "name": "",
          "phone": "",
          "web": ""
        }
      ],
      "name": "",
      "parentGroups": [],
      "postcode": "",
      "sftpUser": "",
      "shortName": "",
      "visible": false,
      "visibleToJoin": false
    },
    "id": 0,
    "identifier": "",
    "links": [
      {}
    ],
    "notes": "",
    "severity": "",
    "status": ""
  },
  "encounters": [
    {
      "date": "",
      "encounterType": "",
      "group": {},
      "id": 0,
      "identifier": "",
      "links": [
        {}
      ],
      "observations": [
        {
          "applies": "",
          "bodySite": "",
          "comments": "",
          "comparator": "",
          "diagram": "",
          "group": {},
          "id": 0,
          "identifier": "",
          "location": "",
          "name": "",
          "temporaryUuid": "",
          "units": "",
          "value": ""
        }
      ],
      "procedures": [
        {
          "bodySite": "",
          "id": 0,
          "type": ""
        }
      ],
      "status": ""
    }
  ],
  "groupCode": "",
  "identifier": "",
  "observations": [
    {}
  ],
  "patient": {
    "address1": "",
    "address2": "",
    "address3": "",
    "address4": "",
    "contacts": [
      {
        "id": 0,
        "system": "",
        "use": "",
        "value": ""
      }
    ],
    "dateOfBirth": "",
    "dateOfBirthNoTime": "",
    "forename": "",
    "gender": "",
    "group": {},
    "groupCode": "",
    "identifier": "",
    "identifiers": [
      {
        "id": 0,
        "label": "",
        "value": ""
      }
    ],
    "postcode": "",
    "practitioners": [
      {
        "address1": "",
        "address2": "",
        "address3": "",
        "address4": "",
        "allowInviteGp": false,
        "contacts": [
          {}
        ],
        "gender": "",
        "groupCode": "",
        "identifier": "",
        "inviteDate": "",
        "name": "",
        "postcode": "",
        "role": ""
      }
    ],
    "surname": ""
  },
  "practitioners": [
    {}
  ]
}'
echo '{
  "condition": {
    "asserter": "",
    "category": "",
    "code": "",
    "date": "",
    "description": "",
    "fullDescription": "",
    "group": {
      "address1": "",
      "address2": "",
      "address3": "",
      "childGroups": [],
      "code": "",
      "contactPoints": [
        {
          "contactPointType": {
            "description": "",
            "id": 0,
            "lookupType": {
              "created": "",
              "description": "",
              "id": 0,
              "lastUpdate": "",
              "type": ""
            },
            "value": ""
          },
          "content": "",
          "created": "",
          "id": 0,
          "lastUpdate": ""
        }
      ],
      "created": "",
      "fhirResourceId": "",
      "groupFeatures": [
        {
          "created": "",
          "feature": {
            "created": "",
            "description": "",
            "id": 0,
            "lastUpdate": "",
            "name": ""
          },
          "id": 0,
          "lastUpdate": ""
        }
      ],
      "groupType": {
        "created": "",
        "description": "",
        "descriptionFriendly": "",
        "displayOrder": 0,
        "id": 0,
        "lastUpdate": "",
        "lookupType": {},
        "value": ""
      },
      "id": 0,
      "lastImportDate": "",
      "lastUpdate": "",
      "links": [
        {
          "created": "",
          "displayOrder": 0,
          "id": 0,
          "lastUpdate": "",
          "link": "",
          "linkType": {},
          "name": ""
        }
      ],
      "locations": [
        {
          "address": "",
          "created": "",
          "email": "",
          "id": 0,
          "label": "",
          "lastUpdate": "",
          "name": "",
          "phone": "",
          "web": ""
        }
      ],
      "name": "",
      "parentGroups": [],
      "postcode": "",
      "sftpUser": "",
      "shortName": "",
      "visible": false,
      "visibleToJoin": false
    },
    "id": 0,
    "identifier": "",
    "links": [
      {}
    ],
    "notes": "",
    "severity": "",
    "status": ""
  },
  "encounters": [
    {
      "date": "",
      "encounterType": "",
      "group": {},
      "id": 0,
      "identifier": "",
      "links": [
        {}
      ],
      "observations": [
        {
          "applies": "",
          "bodySite": "",
          "comments": "",
          "comparator": "",
          "diagram": "",
          "group": {},
          "id": 0,
          "identifier": "",
          "location": "",
          "name": "",
          "temporaryUuid": "",
          "units": "",
          "value": ""
        }
      ],
      "procedures": [
        {
          "bodySite": "",
          "id": 0,
          "type": ""
        }
      ],
      "status": ""
    }
  ],
  "groupCode": "",
  "identifier": "",
  "observations": [
    {}
  ],
  "patient": {
    "address1": "",
    "address2": "",
    "address3": "",
    "address4": "",
    "contacts": [
      {
        "id": 0,
        "system": "",
        "use": "",
        "value": ""
      }
    ],
    "dateOfBirth": "",
    "dateOfBirthNoTime": "",
    "forename": "",
    "gender": "",
    "group": {},
    "groupCode": "",
    "identifier": "",
    "identifiers": [
      {
        "id": 0,
        "label": "",
        "value": ""
      }
    ],
    "postcode": "",
    "practitioners": [
      {
        "address1": "",
        "address2": "",
        "address3": "",
        "address4": "",
        "allowInviteGp": false,
        "contacts": [
          {}
        ],
        "gender": "",
        "groupCode": "",
        "identifier": "",
        "inviteDate": "",
        "name": "",
        "postcode": "",
        "role": ""
      }
    ],
    "surname": ""
  },
  "practitioners": [
    {}
  ]
}' |  \
  http POST {{baseUrl}}/patientmanagement/validate \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "condition": {\n    "asserter": "",\n    "category": "",\n    "code": "",\n    "date": "",\n    "description": "",\n    "fullDescription": "",\n    "group": {\n      "address1": "",\n      "address2": "",\n      "address3": "",\n      "childGroups": [],\n      "code": "",\n      "contactPoints": [\n        {\n          "contactPointType": {\n            "description": "",\n            "id": 0,\n            "lookupType": {\n              "created": "",\n              "description": "",\n              "id": 0,\n              "lastUpdate": "",\n              "type": ""\n            },\n            "value": ""\n          },\n          "content": "",\n          "created": "",\n          "id": 0,\n          "lastUpdate": ""\n        }\n      ],\n      "created": "",\n      "fhirResourceId": "",\n      "groupFeatures": [\n        {\n          "created": "",\n          "feature": {\n            "created": "",\n            "description": "",\n            "id": 0,\n            "lastUpdate": "",\n            "name": ""\n          },\n          "id": 0,\n          "lastUpdate": ""\n        }\n      ],\n      "groupType": {\n        "created": "",\n        "description": "",\n        "descriptionFriendly": "",\n        "displayOrder": 0,\n        "id": 0,\n        "lastUpdate": "",\n        "lookupType": {},\n        "value": ""\n      },\n      "id": 0,\n      "lastImportDate": "",\n      "lastUpdate": "",\n      "links": [\n        {\n          "created": "",\n          "displayOrder": 0,\n          "id": 0,\n          "lastUpdate": "",\n          "link": "",\n          "linkType": {},\n          "name": ""\n        }\n      ],\n      "locations": [\n        {\n          "address": "",\n          "created": "",\n          "email": "",\n          "id": 0,\n          "label": "",\n          "lastUpdate": "",\n          "name": "",\n          "phone": "",\n          "web": ""\n        }\n      ],\n      "name": "",\n      "parentGroups": [],\n      "postcode": "",\n      "sftpUser": "",\n      "shortName": "",\n      "visible": false,\n      "visibleToJoin": false\n    },\n    "id": 0,\n    "identifier": "",\n    "links": [\n      {}\n    ],\n    "notes": "",\n    "severity": "",\n    "status": ""\n  },\n  "encounters": [\n    {\n      "date": "",\n      "encounterType": "",\n      "group": {},\n      "id": 0,\n      "identifier": "",\n      "links": [\n        {}\n      ],\n      "observations": [\n        {\n          "applies": "",\n          "bodySite": "",\n          "comments": "",\n          "comparator": "",\n          "diagram": "",\n          "group": {},\n          "id": 0,\n          "identifier": "",\n          "location": "",\n          "name": "",\n          "temporaryUuid": "",\n          "units": "",\n          "value": ""\n        }\n      ],\n      "procedures": [\n        {\n          "bodySite": "",\n          "id": 0,\n          "type": ""\n        }\n      ],\n      "status": ""\n    }\n  ],\n  "groupCode": "",\n  "identifier": "",\n  "observations": [\n    {}\n  ],\n  "patient": {\n    "address1": "",\n    "address2": "",\n    "address3": "",\n    "address4": "",\n    "contacts": [\n      {\n        "id": 0,\n        "system": "",\n        "use": "",\n        "value": ""\n      }\n    ],\n    "dateOfBirth": "",\n    "dateOfBirthNoTime": "",\n    "forename": "",\n    "gender": "",\n    "group": {},\n    "groupCode": "",\n    "identifier": "",\n    "identifiers": [\n      {\n        "id": 0,\n        "label": "",\n        "value": ""\n      }\n    ],\n    "postcode": "",\n    "practitioners": [\n      {\n        "address1": "",\n        "address2": "",\n        "address3": "",\n        "address4": "",\n        "allowInviteGp": false,\n        "contacts": [\n          {}\n        ],\n        "gender": "",\n        "groupCode": "",\n        "identifier": "",\n        "inviteDate": "",\n        "name": "",\n        "postcode": "",\n        "role": ""\n      }\n    ],\n    "surname": ""\n  },\n  "practitioners": [\n    {}\n  ]\n}' \
  --output-document \
  - {{baseUrl}}/patientmanagement/validate
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "condition": [
    "asserter": "",
    "category": "",
    "code": "",
    "date": "",
    "description": "",
    "fullDescription": "",
    "group": [
      "address1": "",
      "address2": "",
      "address3": "",
      "childGroups": [],
      "code": "",
      "contactPoints": [
        [
          "contactPointType": [
            "description": "",
            "id": 0,
            "lookupType": [
              "created": "",
              "description": "",
              "id": 0,
              "lastUpdate": "",
              "type": ""
            ],
            "value": ""
          ],
          "content": "",
          "created": "",
          "id": 0,
          "lastUpdate": ""
        ]
      ],
      "created": "",
      "fhirResourceId": "",
      "groupFeatures": [
        [
          "created": "",
          "feature": [
            "created": "",
            "description": "",
            "id": 0,
            "lastUpdate": "",
            "name": ""
          ],
          "id": 0,
          "lastUpdate": ""
        ]
      ],
      "groupType": [
        "created": "",
        "description": "",
        "descriptionFriendly": "",
        "displayOrder": 0,
        "id": 0,
        "lastUpdate": "",
        "lookupType": [],
        "value": ""
      ],
      "id": 0,
      "lastImportDate": "",
      "lastUpdate": "",
      "links": [
        [
          "created": "",
          "displayOrder": 0,
          "id": 0,
          "lastUpdate": "",
          "link": "",
          "linkType": [],
          "name": ""
        ]
      ],
      "locations": [
        [
          "address": "",
          "created": "",
          "email": "",
          "id": 0,
          "label": "",
          "lastUpdate": "",
          "name": "",
          "phone": "",
          "web": ""
        ]
      ],
      "name": "",
      "parentGroups": [],
      "postcode": "",
      "sftpUser": "",
      "shortName": "",
      "visible": false,
      "visibleToJoin": false
    ],
    "id": 0,
    "identifier": "",
    "links": [[]],
    "notes": "",
    "severity": "",
    "status": ""
  ],
  "encounters": [
    [
      "date": "",
      "encounterType": "",
      "group": [],
      "id": 0,
      "identifier": "",
      "links": [[]],
      "observations": [
        [
          "applies": "",
          "bodySite": "",
          "comments": "",
          "comparator": "",
          "diagram": "",
          "group": [],
          "id": 0,
          "identifier": "",
          "location": "",
          "name": "",
          "temporaryUuid": "",
          "units": "",
          "value": ""
        ]
      ],
      "procedures": [
        [
          "bodySite": "",
          "id": 0,
          "type": ""
        ]
      ],
      "status": ""
    ]
  ],
  "groupCode": "",
  "identifier": "",
  "observations": [[]],
  "patient": [
    "address1": "",
    "address2": "",
    "address3": "",
    "address4": "",
    "contacts": [
      [
        "id": 0,
        "system": "",
        "use": "",
        "value": ""
      ]
    ],
    "dateOfBirth": "",
    "dateOfBirthNoTime": "",
    "forename": "",
    "gender": "",
    "group": [],
    "groupCode": "",
    "identifier": "",
    "identifiers": [
      [
        "id": 0,
        "label": "",
        "value": ""
      ]
    ],
    "postcode": "",
    "practitioners": [
      [
        "address1": "",
        "address2": "",
        "address3": "",
        "address4": "",
        "allowInviteGp": false,
        "contacts": [[]],
        "gender": "",
        "groupCode": "",
        "identifier": "",
        "inviteDate": "",
        "name": "",
        "postcode": "",
        "role": ""
      ]
    ],
    "surname": ""
  ],
  "practitioners": [[]]
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/patientmanagement/validate")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()