POST Add role(s) to user
{{baseUrl}}/api/v1/organizations/:organizationId/users/:username/roles
HEADERS

Authorization
{{apiKey}}
QUERY PARAMS

organizationId
username
BODY json

{
  "roles": []
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/api/v1/organizations/:organizationId/users/:username/roles");

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

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"roles\": []\n}");

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

(client/post "{{baseUrl}}/api/v1/organizations/:organizationId/users/:username/roles" {:headers {:authorization "{{apiKey}}"}
                                                                                                       :content-type :json
                                                                                                       :form-params {:roles []}})
require "http/client"

url = "{{baseUrl}}/api/v1/organizations/:organizationId/users/:username/roles"
headers = HTTP::Headers{
  "authorization" => "{{apiKey}}"
  "content-type" => "application/json"
}
reqBody = "{\n  \"roles\": []\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}}/api/v1/organizations/:organizationId/users/:username/roles"),
    Headers =
    {
        { "authorization", "{{apiKey}}" },
    },
    Content = new StringContent("{\n  \"roles\": []\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}}/api/v1/organizations/:organizationId/users/:username/roles");
var request = new RestRequest("", Method.Post);
request.AddHeader("authorization", "{{apiKey}}");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"roles\": []\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/api/v1/organizations/:organizationId/users/:username/roles"

	payload := strings.NewReader("{\n  \"roles\": []\n}")

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

	req.Header.Add("authorization", "{{apiKey}}")
	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/api/v1/organizations/:organizationId/users/:username/roles HTTP/1.1
Authorization: {{apiKey}}
Content-Type: application/json
Host: example.com
Content-Length: 17

{
  "roles": []
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/api/v1/organizations/:organizationId/users/:username/roles")
  .setHeader("authorization", "{{apiKey}}")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"roles\": []\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/api/v1/organizations/:organizationId/users/:username/roles"))
    .header("authorization", "{{apiKey}}")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"roles\": []\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  \"roles\": []\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/api/v1/organizations/:organizationId/users/:username/roles")
  .post(body)
  .addHeader("authorization", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/api/v1/organizations/:organizationId/users/:username/roles")
  .header("authorization", "{{apiKey}}")
  .header("content-type", "application/json")
  .body("{\n  \"roles\": []\n}")
  .asString();
const data = JSON.stringify({
  roles: []
});

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

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

xhr.open('POST', '{{baseUrl}}/api/v1/organizations/:organizationId/users/:username/roles');
xhr.setRequestHeader('authorization', '{{apiKey}}');
xhr.setRequestHeader('content-type', 'application/json');

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/api/v1/organizations/:organizationId/users/:username/roles',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  data: {roles: []}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/api/v1/organizations/:organizationId/users/:username/roles';
const options = {
  method: 'POST',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"roles":[]}'
};

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}}/api/v1/organizations/:organizationId/users/:username/roles',
  method: 'POST',
  headers: {
    authorization: '{{apiKey}}',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "roles": []\n}'
};

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

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"roles\": []\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/api/v1/organizations/:organizationId/users/:username/roles")
  .post(body)
  .addHeader("authorization", "{{apiKey}}")
  .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/api/v1/organizations/:organizationId/users/:username/roles',
  headers: {
    authorization: '{{apiKey}}',
    '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({roles: []}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/api/v1/organizations/:organizationId/users/:username/roles',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  body: {roles: []},
  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}}/api/v1/organizations/:organizationId/users/:username/roles');

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

req.type('json');
req.send({
  roles: []
});

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}}/api/v1/organizations/:organizationId/users/:username/roles',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  data: {roles: []}
};

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

const url = '{{baseUrl}}/api/v1/organizations/:organizationId/users/:username/roles';
const options = {
  method: 'POST',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"roles":[]}'
};

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

NSDictionary *headers = @{ @"authorization": @"{{apiKey}}",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"roles": @[  ] };

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/api/v1/organizations/:organizationId/users/:username/roles"]
                                                       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}}/api/v1/organizations/:organizationId/users/:username/roles" in
let headers = Header.add_list (Header.init ()) [
  ("authorization", "{{apiKey}}");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"roles\": []\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/api/v1/organizations/:organizationId/users/:username/roles",
  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([
    'roles' => [
        
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "authorization: {{apiKey}}",
    "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}}/api/v1/organizations/:organizationId/users/:username/roles', [
  'body' => '{
  "roles": []
}',
  'headers' => [
    'authorization' => '{{apiKey}}',
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/api/v1/organizations/:organizationId/users/:username/roles');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'authorization' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'roles' => [
    
  ]
]));

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'roles' => [
    
  ]
]));
$request->setRequestUrl('{{baseUrl}}/api/v1/organizations/:organizationId/users/:username/roles');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'authorization' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

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

echo $response->getBody();
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/api/v1/organizations/:organizationId/users/:username/roles' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "roles": []
}'
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/api/v1/organizations/:organizationId/users/:username/roles' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "roles": []
}'
import http.client

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

payload = "{\n  \"roles\": []\n}"

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

conn.request("POST", "/baseUrl/api/v1/organizations/:organizationId/users/:username/roles", payload, headers)

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

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

url = "{{baseUrl}}/api/v1/organizations/:organizationId/users/:username/roles"

payload = { "roles": [] }
headers = {
    "authorization": "{{apiKey}}",
    "content-type": "application/json"
}

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

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

url <- "{{baseUrl}}/api/v1/organizations/:organizationId/users/:username/roles"

payload <- "{\n  \"roles\": []\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('authorization' = '{{apiKey}}'), content_type("application/json"), encode = encode)

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

url = URI("{{baseUrl}}/api/v1/organizations/:organizationId/users/:username/roles")

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

request = Net::HTTP::Post.new(url)
request["authorization"] = '{{apiKey}}'
request["content-type"] = 'application/json'
request.body = "{\n  \"roles\": []\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/api/v1/organizations/:organizationId/users/:username/roles') do |req|
  req.headers['authorization'] = '{{apiKey}}'
  req.body = "{\n  \"roles\": []\n}"
end

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

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/api/v1/organizations/:organizationId/users/:username/roles";

    let payload = json!({"roles": ()});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("authorization", "{{apiKey}}".parse().unwrap());
    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}}/api/v1/organizations/:organizationId/users/:username/roles \
  --header 'authorization: {{apiKey}}' \
  --header 'content-type: application/json' \
  --data '{
  "roles": []
}'
echo '{
  "roles": []
}' |  \
  http POST {{baseUrl}}/api/v1/organizations/:organizationId/users/:username/roles \
  authorization:'{{apiKey}}' \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'authorization: {{apiKey}}' \
  --header 'content-type: application/json' \
  --body-data '{\n  "roles": []\n}' \
  --output-document \
  - {{baseUrl}}/api/v1/organizations/:organizationId/users/:username/roles
import Foundation

let headers = [
  "authorization": "{{apiKey}}",
  "content-type": "application/json"
]
let parameters = ["roles": []] as [String : Any]

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

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/api/v1/organizations/:organizationId/users/:username/roles")! 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()
PUT Complete registration
{{baseUrl}}/account/registration
BODY json

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

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/account/registration");

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  \"password\": \"\",\n  \"username\": \"\",\n  \"verificationToken\": \"\"\n}");

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

(client/put "{{baseUrl}}/account/registration" {:content-type :json
                                                                :form-params {:password ""
                                                                              :username ""
                                                                              :verificationToken ""}})
require "http/client"

url = "{{baseUrl}}/account/registration"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"password\": \"\",\n  \"username\": \"\",\n  \"verificationToken\": \"\"\n}"

response = HTTP::Client.put url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Put,
    RequestUri = new Uri("{{baseUrl}}/account/registration"),
    Content = new StringContent("{\n  \"password\": \"\",\n  \"username\": \"\",\n  \"verificationToken\": \"\"\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}}/account/registration");
var request = new RestRequest("", Method.Put);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"password\": \"\",\n  \"username\": \"\",\n  \"verificationToken\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/account/registration"

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

	req, _ := http.NewRequest("PUT", 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))

}
PUT /baseUrl/account/registration HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 65

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

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/account/registration"))
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"password\": \"\",\n  \"username\": \"\",\n  \"verificationToken\": \"\"\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  \"password\": \"\",\n  \"username\": \"\",\n  \"verificationToken\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/account/registration")
  .put(body)
  .addHeader("content-type", "application/json")
  .build();

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

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

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

xhr.open('PUT', '{{baseUrl}}/account/registration');
xhr.setRequestHeader('content-type', 'application/json');

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

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/account/registration',
  headers: {'content-type': 'application/json'},
  data: {password: '', username: '', verificationToken: ''}
};

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

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}}/account/registration',
  method: 'PUT',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "password": "",\n  "username": "",\n  "verificationToken": ""\n}'
};

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

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

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

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/account/registration',
  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({password: '', username: '', verificationToken: ''}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/account/registration',
  headers: {'content-type': 'application/json'},
  body: {password: '', username: '', verificationToken: ''},
  json: true
};

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

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

const req = unirest('PUT', '{{baseUrl}}/account/registration');

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

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

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

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

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/account/registration',
  headers: {'content-type': 'application/json'},
  data: {password: '', username: '', verificationToken: ''}
};

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

const url = '{{baseUrl}}/account/registration';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"password":"","username":"","verificationToken":""}'
};

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 = @{ @"password": @"",
                              @"username": @"",
                              @"verificationToken": @"" };

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/account/registration"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"PUT"];
[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}}/account/registration" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"password\": \"\",\n  \"username\": \"\",\n  \"verificationToken\": \"\"\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/account/registration",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
  CURLOPT_POSTFIELDS => json_encode([
    'password' => '',
    'username' => '',
    'verificationToken' => ''
  ]),
  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('PUT', '{{baseUrl}}/account/registration', [
  'body' => '{
  "password": "",
  "username": "",
  "verificationToken": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/account/registration');
$request->setMethod(HTTP_METH_PUT);

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

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

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'password' => '',
  'username' => '',
  'verificationToken' => ''
]));
$request->setRequestUrl('{{baseUrl}}/account/registration');
$request->setRequestMethod('PUT');
$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}}/account/registration' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "password": "",
  "username": "",
  "verificationToken": ""
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/account/registration' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "password": "",
  "username": "",
  "verificationToken": ""
}'
import http.client

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

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

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

conn.request("PUT", "/baseUrl/account/registration", payload, headers)

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

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

url = "{{baseUrl}}/account/registration"

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

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

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

url <- "{{baseUrl}}/account/registration"

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

encode <- "json"

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

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

url = URI("{{baseUrl}}/account/registration")

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

request = Net::HTTP::Put.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"password\": \"\",\n  \"username\": \"\",\n  \"verificationToken\": \"\"\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.put('/baseUrl/account/registration') do |req|
  req.body = "{\n  \"password\": \"\",\n  \"username\": \"\",\n  \"verificationToken\": \"\"\n}"
end

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

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

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

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

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

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

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

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

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

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/account/registration")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "PUT"
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()
GET Find by username
{{baseUrl}}/api/v1/users/:username
HEADERS

Authorization
{{apiKey}}
QUERY PARAMS

username
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/api/v1/users/:username");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "authorization: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

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

(client/get "{{baseUrl}}/api/v1/users/:username" {:headers {:authorization "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/api/v1/users/:username"
headers = HTTP::Headers{
  "authorization" => "{{apiKey}}"
}

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

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

func main() {

	url := "{{baseUrl}}/api/v1/users/:username"

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

	req.Header.Add("authorization", "{{apiKey}}")

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

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

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

}
GET /baseUrl/api/v1/users/:username HTTP/1.1
Authorization: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/api/v1/users/:username")
  .setHeader("authorization", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/api/v1/users/:username"))
    .header("authorization", "{{apiKey}}")
    .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}}/api/v1/users/:username")
  .get()
  .addHeader("authorization", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/api/v1/users/:username")
  .header("authorization", "{{apiKey}}")
  .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}}/api/v1/users/:username');
xhr.setRequestHeader('authorization', '{{apiKey}}');

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/api/v1/users/:username',
  headers: {authorization: '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/api/v1/users/:username';
const options = {method: 'GET', headers: {authorization: '{{apiKey}}'}};

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}}/api/v1/users/:username',
  method: 'GET',
  headers: {
    authorization: '{{apiKey}}'
  }
};

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

val request = Request.Builder()
  .url("{{baseUrl}}/api/v1/users/:username")
  .get()
  .addHeader("authorization", "{{apiKey}}")
  .build()

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

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/api/v1/users/:username',
  headers: {
    authorization: '{{apiKey}}'
  }
};

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}}/api/v1/users/:username',
  headers: {authorization: '{{apiKey}}'}
};

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

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

const req = unirest('GET', '{{baseUrl}}/api/v1/users/:username');

req.headers({
  authorization: '{{apiKey}}'
});

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}}/api/v1/users/:username',
  headers: {authorization: '{{apiKey}}'}
};

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

const url = '{{baseUrl}}/api/v1/users/:username';
const options = {method: 'GET', headers: {authorization: '{{apiKey}}'}};

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

NSDictionary *headers = @{ @"authorization": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/api/v1/users/:username"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

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}}/api/v1/users/:username" in
let headers = Header.add (Header.init ()) "authorization" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/api/v1/users/:username",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "authorization: {{apiKey}}"
  ],
]);

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/api/v1/users/:username', [
  'headers' => [
    'authorization' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/api/v1/users/:username');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'authorization' => '{{apiKey}}'
]);

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/api/v1/users/:username');
$request->setRequestMethod('GET');
$request->setHeaders([
  'authorization' => '{{apiKey}}'
]);

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

echo $response->getBody();
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/api/v1/users/:username' -Method GET -Headers $headers
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/api/v1/users/:username' -Method GET -Headers $headers
import http.client

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

headers = { 'authorization': "{{apiKey}}" }

conn.request("GET", "/baseUrl/api/v1/users/:username", headers=headers)

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

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

url = "{{baseUrl}}/api/v1/users/:username"

headers = {"authorization": "{{apiKey}}"}

response = requests.get(url, headers=headers)

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

url <- "{{baseUrl}}/api/v1/users/:username"

response <- VERB("GET", url, add_headers('authorization' = '{{apiKey}}'), content_type("application/octet-stream"))

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

url = URI("{{baseUrl}}/api/v1/users/:username")

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

request = Net::HTTP::Get.new(url)
request["authorization"] = '{{apiKey}}'

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

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

response = conn.get('/baseUrl/api/v1/users/:username') do |req|
  req.headers['authorization'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/api/v1/users/:username";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("authorization", "{{apiKey}}".parse().unwrap());

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

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

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/api/v1/users/:username \
  --header 'authorization: {{apiKey}}'
http GET {{baseUrl}}/api/v1/users/:username \
  authorization:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'authorization: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/api/v1/users/:username
import Foundation

let headers = ["authorization": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/api/v1/users/:username")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

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 Find users in organization
{{baseUrl}}/api/v1/organizations/:organizationId/users
HEADERS

Authorization
{{apiKey}}
QUERY PARAMS

organizationId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/api/v1/organizations/:organizationId/users");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "authorization: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

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

(client/get "{{baseUrl}}/api/v1/organizations/:organizationId/users" {:headers {:authorization "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/api/v1/organizations/:organizationId/users"
headers = HTTP::Headers{
  "authorization" => "{{apiKey}}"
}

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

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

func main() {

	url := "{{baseUrl}}/api/v1/organizations/:organizationId/users"

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

	req.Header.Add("authorization", "{{apiKey}}")

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

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

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

}
GET /baseUrl/api/v1/organizations/:organizationId/users HTTP/1.1
Authorization: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/api/v1/organizations/:organizationId/users")
  .setHeader("authorization", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/api/v1/organizations/:organizationId/users"))
    .header("authorization", "{{apiKey}}")
    .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}}/api/v1/organizations/:organizationId/users")
  .get()
  .addHeader("authorization", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/api/v1/organizations/:organizationId/users")
  .header("authorization", "{{apiKey}}")
  .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}}/api/v1/organizations/:organizationId/users');
xhr.setRequestHeader('authorization', '{{apiKey}}');

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/api/v1/organizations/:organizationId/users',
  headers: {authorization: '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/api/v1/organizations/:organizationId/users';
const options = {method: 'GET', headers: {authorization: '{{apiKey}}'}};

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}}/api/v1/organizations/:organizationId/users',
  method: 'GET',
  headers: {
    authorization: '{{apiKey}}'
  }
};

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

val request = Request.Builder()
  .url("{{baseUrl}}/api/v1/organizations/:organizationId/users")
  .get()
  .addHeader("authorization", "{{apiKey}}")
  .build()

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

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/api/v1/organizations/:organizationId/users',
  headers: {
    authorization: '{{apiKey}}'
  }
};

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}}/api/v1/organizations/:organizationId/users',
  headers: {authorization: '{{apiKey}}'}
};

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

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

const req = unirest('GET', '{{baseUrl}}/api/v1/organizations/:organizationId/users');

req.headers({
  authorization: '{{apiKey}}'
});

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}}/api/v1/organizations/:organizationId/users',
  headers: {authorization: '{{apiKey}}'}
};

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

const url = '{{baseUrl}}/api/v1/organizations/:organizationId/users';
const options = {method: 'GET', headers: {authorization: '{{apiKey}}'}};

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

NSDictionary *headers = @{ @"authorization": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/api/v1/organizations/:organizationId/users"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

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}}/api/v1/organizations/:organizationId/users" in
let headers = Header.add (Header.init ()) "authorization" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/api/v1/organizations/:organizationId/users",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "authorization: {{apiKey}}"
  ],
]);

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/api/v1/organizations/:organizationId/users', [
  'headers' => [
    'authorization' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/api/v1/organizations/:organizationId/users');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'authorization' => '{{apiKey}}'
]);

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/api/v1/organizations/:organizationId/users');
$request->setRequestMethod('GET');
$request->setHeaders([
  'authorization' => '{{apiKey}}'
]);

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

echo $response->getBody();
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/api/v1/organizations/:organizationId/users' -Method GET -Headers $headers
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/api/v1/organizations/:organizationId/users' -Method GET -Headers $headers
import http.client

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

headers = { 'authorization': "{{apiKey}}" }

conn.request("GET", "/baseUrl/api/v1/organizations/:organizationId/users", headers=headers)

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

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

url = "{{baseUrl}}/api/v1/organizations/:organizationId/users"

headers = {"authorization": "{{apiKey}}"}

response = requests.get(url, headers=headers)

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

url <- "{{baseUrl}}/api/v1/organizations/:organizationId/users"

response <- VERB("GET", url, add_headers('authorization' = '{{apiKey}}'), content_type("application/octet-stream"))

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

url = URI("{{baseUrl}}/api/v1/organizations/:organizationId/users")

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

request = Net::HTTP::Get.new(url)
request["authorization"] = '{{apiKey}}'

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

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

response = conn.get('/baseUrl/api/v1/organizations/:organizationId/users') do |req|
  req.headers['authorization'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/api/v1/organizations/:organizationId/users";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("authorization", "{{apiKey}}".parse().unwrap());

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

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

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/api/v1/organizations/:organizationId/users \
  --header 'authorization: {{apiKey}}'
http GET {{baseUrl}}/api/v1/organizations/:organizationId/users \
  authorization:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'authorization: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/api/v1/organizations/:organizationId/users
import Foundation

let headers = ["authorization": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/api/v1/organizations/:organizationId/users")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

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()
RESPONSE HEADERS

Content-Type
application/json
RESPONSE BODY json

{
  "limit": 100,
  "offset": 0,
  "total": 200
}
RESPONSE HEADERS

Content-Type
application/xml
RESPONSE BODY xml

{
  "limit": 100,
  "offset": 0,
  "total": 200
}
GET Find users
{{baseUrl}}/api/v1/users
HEADERS

Authorization
{{apiKey}}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/api/v1/users");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "authorization: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

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

(client/get "{{baseUrl}}/api/v1/users" {:headers {:authorization "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/api/v1/users"
headers = HTTP::Headers{
  "authorization" => "{{apiKey}}"
}

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

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

func main() {

	url := "{{baseUrl}}/api/v1/users"

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

	req.Header.Add("authorization", "{{apiKey}}")

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

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

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

}
GET /baseUrl/api/v1/users HTTP/1.1
Authorization: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/api/v1/users")
  .setHeader("authorization", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/api/v1/users"))
    .header("authorization", "{{apiKey}}")
    .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}}/api/v1/users")
  .get()
  .addHeader("authorization", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/api/v1/users")
  .header("authorization", "{{apiKey}}")
  .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}}/api/v1/users');
xhr.setRequestHeader('authorization', '{{apiKey}}');

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/api/v1/users',
  headers: {authorization: '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/api/v1/users';
const options = {method: 'GET', headers: {authorization: '{{apiKey}}'}};

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}}/api/v1/users',
  method: 'GET',
  headers: {
    authorization: '{{apiKey}}'
  }
};

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

val request = Request.Builder()
  .url("{{baseUrl}}/api/v1/users")
  .get()
  .addHeader("authorization", "{{apiKey}}")
  .build()

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

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/api/v1/users',
  headers: {
    authorization: '{{apiKey}}'
  }
};

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}}/api/v1/users',
  headers: {authorization: '{{apiKey}}'}
};

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

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

const req = unirest('GET', '{{baseUrl}}/api/v1/users');

req.headers({
  authorization: '{{apiKey}}'
});

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}}/api/v1/users',
  headers: {authorization: '{{apiKey}}'}
};

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

const url = '{{baseUrl}}/api/v1/users';
const options = {method: 'GET', headers: {authorization: '{{apiKey}}'}};

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

NSDictionary *headers = @{ @"authorization": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/api/v1/users"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

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}}/api/v1/users" in
let headers = Header.add (Header.init ()) "authorization" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/api/v1/users",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "authorization: {{apiKey}}"
  ],
]);

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/api/v1/users', [
  'headers' => [
    'authorization' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/api/v1/users');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'authorization' => '{{apiKey}}'
]);

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/api/v1/users');
$request->setRequestMethod('GET');
$request->setHeaders([
  'authorization' => '{{apiKey}}'
]);

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

echo $response->getBody();
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/api/v1/users' -Method GET -Headers $headers
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/api/v1/users' -Method GET -Headers $headers
import http.client

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

headers = { 'authorization': "{{apiKey}}" }

conn.request("GET", "/baseUrl/api/v1/users", headers=headers)

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

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

url = "{{baseUrl}}/api/v1/users"

headers = {"authorization": "{{apiKey}}"}

response = requests.get(url, headers=headers)

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

url <- "{{baseUrl}}/api/v1/users"

response <- VERB("GET", url, add_headers('authorization' = '{{apiKey}}'), content_type("application/octet-stream"))

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

url = URI("{{baseUrl}}/api/v1/users")

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

request = Net::HTTP::Get.new(url)
request["authorization"] = '{{apiKey}}'

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

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

response = conn.get('/baseUrl/api/v1/users') do |req|
  req.headers['authorization'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

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

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("authorization", "{{apiKey}}".parse().unwrap());

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

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

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/api/v1/users \
  --header 'authorization: {{apiKey}}'
http GET {{baseUrl}}/api/v1/users \
  authorization:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'authorization: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/api/v1/users
import Foundation

let headers = ["authorization": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/api/v1/users")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

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()
RESPONSE HEADERS

Content-Type
application/json
RESPONSE BODY json

{
  "limit": 100,
  "offset": 0,
  "total": 200
}
RESPONSE HEADERS

Content-Type
application/xml
RESPONSE BODY xml

{
  "limit": 100,
  "offset": 0,
  "total": 200
}
GET Get user roles by username
{{baseUrl}}/api/v1/organizations/:organizationId/users/:username/roles
HEADERS

Authorization
{{apiKey}}
QUERY PARAMS

organizationId
username
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/api/v1/organizations/:organizationId/users/:username/roles");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "authorization: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

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

(client/get "{{baseUrl}}/api/v1/organizations/:organizationId/users/:username/roles" {:headers {:authorization "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/api/v1/organizations/:organizationId/users/:username/roles"
headers = HTTP::Headers{
  "authorization" => "{{apiKey}}"
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/api/v1/organizations/:organizationId/users/:username/roles"),
    Headers =
    {
        { "authorization", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/api/v1/organizations/:organizationId/users/:username/roles");
var request = new RestRequest("", Method.Get);
request.AddHeader("authorization", "{{apiKey}}");
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/api/v1/organizations/:organizationId/users/:username/roles"

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

	req.Header.Add("authorization", "{{apiKey}}")

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

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

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

}
GET /baseUrl/api/v1/organizations/:organizationId/users/:username/roles HTTP/1.1
Authorization: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/api/v1/organizations/:organizationId/users/:username/roles")
  .setHeader("authorization", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/api/v1/organizations/:organizationId/users/:username/roles"))
    .header("authorization", "{{apiKey}}")
    .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}}/api/v1/organizations/:organizationId/users/:username/roles")
  .get()
  .addHeader("authorization", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/api/v1/organizations/:organizationId/users/:username/roles")
  .header("authorization", "{{apiKey}}")
  .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}}/api/v1/organizations/:organizationId/users/:username/roles');
xhr.setRequestHeader('authorization', '{{apiKey}}');

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/api/v1/organizations/:organizationId/users/:username/roles',
  headers: {authorization: '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/api/v1/organizations/:organizationId/users/:username/roles';
const options = {method: 'GET', headers: {authorization: '{{apiKey}}'}};

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}}/api/v1/organizations/:organizationId/users/:username/roles',
  method: 'GET',
  headers: {
    authorization: '{{apiKey}}'
  }
};

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

val request = Request.Builder()
  .url("{{baseUrl}}/api/v1/organizations/:organizationId/users/:username/roles")
  .get()
  .addHeader("authorization", "{{apiKey}}")
  .build()

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

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/api/v1/organizations/:organizationId/users/:username/roles',
  headers: {
    authorization: '{{apiKey}}'
  }
};

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}}/api/v1/organizations/:organizationId/users/:username/roles',
  headers: {authorization: '{{apiKey}}'}
};

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

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

const req = unirest('GET', '{{baseUrl}}/api/v1/organizations/:organizationId/users/:username/roles');

req.headers({
  authorization: '{{apiKey}}'
});

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}}/api/v1/organizations/:organizationId/users/:username/roles',
  headers: {authorization: '{{apiKey}}'}
};

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

const url = '{{baseUrl}}/api/v1/organizations/:organizationId/users/:username/roles';
const options = {method: 'GET', headers: {authorization: '{{apiKey}}'}};

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

NSDictionary *headers = @{ @"authorization": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/api/v1/organizations/:organizationId/users/:username/roles"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

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}}/api/v1/organizations/:organizationId/users/:username/roles" in
let headers = Header.add (Header.init ()) "authorization" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/api/v1/organizations/:organizationId/users/:username/roles",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "authorization: {{apiKey}}"
  ],
]);

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/api/v1/organizations/:organizationId/users/:username/roles', [
  'headers' => [
    'authorization' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/api/v1/organizations/:organizationId/users/:username/roles');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'authorization' => '{{apiKey}}'
]);

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/api/v1/organizations/:organizationId/users/:username/roles');
$request->setRequestMethod('GET');
$request->setHeaders([
  'authorization' => '{{apiKey}}'
]);

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

echo $response->getBody();
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/api/v1/organizations/:organizationId/users/:username/roles' -Method GET -Headers $headers
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/api/v1/organizations/:organizationId/users/:username/roles' -Method GET -Headers $headers
import http.client

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

headers = { 'authorization': "{{apiKey}}" }

conn.request("GET", "/baseUrl/api/v1/organizations/:organizationId/users/:username/roles", headers=headers)

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

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

url = "{{baseUrl}}/api/v1/organizations/:organizationId/users/:username/roles"

headers = {"authorization": "{{apiKey}}"}

response = requests.get(url, headers=headers)

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

url <- "{{baseUrl}}/api/v1/organizations/:organizationId/users/:username/roles"

response <- VERB("GET", url, add_headers('authorization' = '{{apiKey}}'), content_type("application/octet-stream"))

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

url = URI("{{baseUrl}}/api/v1/organizations/:organizationId/users/:username/roles")

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

request = Net::HTTP::Get.new(url)
request["authorization"] = '{{apiKey}}'

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

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

response = conn.get('/baseUrl/api/v1/organizations/:organizationId/users/:username/roles') do |req|
  req.headers['authorization'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/api/v1/organizations/:organizationId/users/:username/roles";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("authorization", "{{apiKey}}".parse().unwrap());

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

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

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/api/v1/organizations/:organizationId/users/:username/roles \
  --header 'authorization: {{apiKey}}'
http GET {{baseUrl}}/api/v1/organizations/:organizationId/users/:username/roles \
  authorization:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'authorization: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/api/v1/organizations/:organizationId/users/:username/roles
import Foundation

let headers = ["authorization": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/api/v1/organizations/:organizationId/users/:username/roles")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

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()
RESPONSE HEADERS

Content-Type
application/json
RESPONSE BODY json

{
  "limit": 100,
  "offset": 0,
  "total": 200
}
RESPONSE HEADERS

Content-Type
application/xml
RESPONSE BODY xml

{
  "limit": 100,
  "offset": 0,
  "total": 200
}
POST Invite Users
{{baseUrl}}/api/v1/organizations/:organizationId/users/invite
HEADERS

Authorization
{{apiKey}}
QUERY PARAMS

organizationId
BODY json

{
  "invitations": [
    {
      "email": "",
      "roles": [],
      "userName": ""
    }
  ]
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/api/v1/organizations/:organizationId/users/invite");

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

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"invitations\": [\n    {\n      \"email\": \"\",\n      \"roles\": [],\n      \"userName\": \"\"\n    }\n  ]\n}");

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

(client/post "{{baseUrl}}/api/v1/organizations/:organizationId/users/invite" {:headers {:authorization "{{apiKey}}"}
                                                                                              :content-type :json
                                                                                              :form-params {:invitations [{:email ""
                                                                                                                           :roles []
                                                                                                                           :userName ""}]}})
require "http/client"

url = "{{baseUrl}}/api/v1/organizations/:organizationId/users/invite"
headers = HTTP::Headers{
  "authorization" => "{{apiKey}}"
  "content-type" => "application/json"
}
reqBody = "{\n  \"invitations\": [\n    {\n      \"email\": \"\",\n      \"roles\": [],\n      \"userName\": \"\"\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}}/api/v1/organizations/:organizationId/users/invite"),
    Headers =
    {
        { "authorization", "{{apiKey}}" },
    },
    Content = new StringContent("{\n  \"invitations\": [\n    {\n      \"email\": \"\",\n      \"roles\": [],\n      \"userName\": \"\"\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}}/api/v1/organizations/:organizationId/users/invite");
var request = new RestRequest("", Method.Post);
request.AddHeader("authorization", "{{apiKey}}");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"invitations\": [\n    {\n      \"email\": \"\",\n      \"roles\": [],\n      \"userName\": \"\"\n    }\n  ]\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/api/v1/organizations/:organizationId/users/invite"

	payload := strings.NewReader("{\n  \"invitations\": [\n    {\n      \"email\": \"\",\n      \"roles\": [],\n      \"userName\": \"\"\n    }\n  ]\n}")

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

	req.Header.Add("authorization", "{{apiKey}}")
	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/api/v1/organizations/:organizationId/users/invite HTTP/1.1
Authorization: {{apiKey}}
Content-Type: application/json
Host: example.com
Content-Length: 97

{
  "invitations": [
    {
      "email": "",
      "roles": [],
      "userName": ""
    }
  ]
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/api/v1/organizations/:organizationId/users/invite")
  .setHeader("authorization", "{{apiKey}}")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"invitations\": [\n    {\n      \"email\": \"\",\n      \"roles\": [],\n      \"userName\": \"\"\n    }\n  ]\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/api/v1/organizations/:organizationId/users/invite"))
    .header("authorization", "{{apiKey}}")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"invitations\": [\n    {\n      \"email\": \"\",\n      \"roles\": [],\n      \"userName\": \"\"\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  \"invitations\": [\n    {\n      \"email\": \"\",\n      \"roles\": [],\n      \"userName\": \"\"\n    }\n  ]\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/api/v1/organizations/:organizationId/users/invite")
  .post(body)
  .addHeader("authorization", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/api/v1/organizations/:organizationId/users/invite")
  .header("authorization", "{{apiKey}}")
  .header("content-type", "application/json")
  .body("{\n  \"invitations\": [\n    {\n      \"email\": \"\",\n      \"roles\": [],\n      \"userName\": \"\"\n    }\n  ]\n}")
  .asString();
const data = JSON.stringify({
  invitations: [
    {
      email: '',
      roles: [],
      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}}/api/v1/organizations/:organizationId/users/invite');
xhr.setRequestHeader('authorization', '{{apiKey}}');
xhr.setRequestHeader('content-type', 'application/json');

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/api/v1/organizations/:organizationId/users/invite',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  data: {invitations: [{email: '', roles: [], userName: ''}]}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/api/v1/organizations/:organizationId/users/invite';
const options = {
  method: 'POST',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"invitations":[{"email":"","roles":[],"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}}/api/v1/organizations/:organizationId/users/invite',
  method: 'POST',
  headers: {
    authorization: '{{apiKey}}',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "invitations": [\n    {\n      "email": "",\n      "roles": [],\n      "userName": ""\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  \"invitations\": [\n    {\n      \"email\": \"\",\n      \"roles\": [],\n      \"userName\": \"\"\n    }\n  ]\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/api/v1/organizations/:organizationId/users/invite")
  .post(body)
  .addHeader("authorization", "{{apiKey}}")
  .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/api/v1/organizations/:organizationId/users/invite',
  headers: {
    authorization: '{{apiKey}}',
    '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({invitations: [{email: '', roles: [], userName: ''}]}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/api/v1/organizations/:organizationId/users/invite',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  body: {invitations: [{email: '', roles: [], 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}}/api/v1/organizations/:organizationId/users/invite');

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

req.type('json');
req.send({
  invitations: [
    {
      email: '',
      roles: [],
      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}}/api/v1/organizations/:organizationId/users/invite',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  data: {invitations: [{email: '', roles: [], userName: ''}]}
};

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

const url = '{{baseUrl}}/api/v1/organizations/:organizationId/users/invite';
const options = {
  method: 'POST',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"invitations":[{"email":"","roles":[],"userName":""}]}'
};

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

NSDictionary *headers = @{ @"authorization": @"{{apiKey}}",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"invitations": @[ @{ @"email": @"", @"roles": @[  ], @"userName": @"" } ] };

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/api/v1/organizations/:organizationId/users/invite"]
                                                       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}}/api/v1/organizations/:organizationId/users/invite" in
let headers = Header.add_list (Header.init ()) [
  ("authorization", "{{apiKey}}");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"invitations\": [\n    {\n      \"email\": \"\",\n      \"roles\": [],\n      \"userName\": \"\"\n    }\n  ]\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/api/v1/organizations/:organizationId/users/invite",
  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([
    'invitations' => [
        [
                'email' => '',
                'roles' => [
                                
                ],
                'userName' => ''
        ]
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "authorization: {{apiKey}}",
    "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}}/api/v1/organizations/:organizationId/users/invite', [
  'body' => '{
  "invitations": [
    {
      "email": "",
      "roles": [],
      "userName": ""
    }
  ]
}',
  'headers' => [
    'authorization' => '{{apiKey}}',
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/api/v1/organizations/:organizationId/users/invite');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'authorization' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'invitations' => [
    [
        'email' => '',
        'roles' => [
                
        ],
        'userName' => ''
    ]
  ]
]));

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'invitations' => [
    [
        'email' => '',
        'roles' => [
                
        ],
        'userName' => ''
    ]
  ]
]));
$request->setRequestUrl('{{baseUrl}}/api/v1/organizations/:organizationId/users/invite');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'authorization' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

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

echo $response->getBody();
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/api/v1/organizations/:organizationId/users/invite' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "invitations": [
    {
      "email": "",
      "roles": [],
      "userName": ""
    }
  ]
}'
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/api/v1/organizations/:organizationId/users/invite' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "invitations": [
    {
      "email": "",
      "roles": [],
      "userName": ""
    }
  ]
}'
import http.client

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

payload = "{\n  \"invitations\": [\n    {\n      \"email\": \"\",\n      \"roles\": [],\n      \"userName\": \"\"\n    }\n  ]\n}"

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

conn.request("POST", "/baseUrl/api/v1/organizations/:organizationId/users/invite", payload, headers)

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

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

url = "{{baseUrl}}/api/v1/organizations/:organizationId/users/invite"

payload = { "invitations": [
        {
            "email": "",
            "roles": [],
            "userName": ""
        }
    ] }
headers = {
    "authorization": "{{apiKey}}",
    "content-type": "application/json"
}

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

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

url <- "{{baseUrl}}/api/v1/organizations/:organizationId/users/invite"

payload <- "{\n  \"invitations\": [\n    {\n      \"email\": \"\",\n      \"roles\": [],\n      \"userName\": \"\"\n    }\n  ]\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('authorization' = '{{apiKey}}'), content_type("application/json"), encode = encode)

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

url = URI("{{baseUrl}}/api/v1/organizations/:organizationId/users/invite")

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

request = Net::HTTP::Post.new(url)
request["authorization"] = '{{apiKey}}'
request["content-type"] = 'application/json'
request.body = "{\n  \"invitations\": [\n    {\n      \"email\": \"\",\n      \"roles\": [],\n      \"userName\": \"\"\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/api/v1/organizations/:organizationId/users/invite') do |req|
  req.headers['authorization'] = '{{apiKey}}'
  req.body = "{\n  \"invitations\": [\n    {\n      \"email\": \"\",\n      \"roles\": [],\n      \"userName\": \"\"\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}}/api/v1/organizations/:organizationId/users/invite";

    let payload = json!({"invitations": (
            json!({
                "email": "",
                "roles": (),
                "userName": ""
            })
        )});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("authorization", "{{apiKey}}".parse().unwrap());
    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}}/api/v1/organizations/:organizationId/users/invite \
  --header 'authorization: {{apiKey}}' \
  --header 'content-type: application/json' \
  --data '{
  "invitations": [
    {
      "email": "",
      "roles": [],
      "userName": ""
    }
  ]
}'
echo '{
  "invitations": [
    {
      "email": "",
      "roles": [],
      "userName": ""
    }
  ]
}' |  \
  http POST {{baseUrl}}/api/v1/organizations/:organizationId/users/invite \
  authorization:'{{apiKey}}' \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'authorization: {{apiKey}}' \
  --header 'content-type: application/json' \
  --body-data '{\n  "invitations": [\n    {\n      "email": "",\n      "roles": [],\n      "userName": ""\n    }\n  ]\n}' \
  --output-document \
  - {{baseUrl}}/api/v1/organizations/:organizationId/users/invite
import Foundation

let headers = [
  "authorization": "{{apiKey}}",
  "content-type": "application/json"
]
let parameters = ["invitations": [
    [
      "email": "",
      "roles": [],
      "userName": ""
    ]
  ]] as [String : Any]

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

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/api/v1/organizations/:organizationId/users/invite")! 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()
GET List roles
{{baseUrl}}/api/v1/roles
HEADERS

Authorization
{{apiKey}}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/api/v1/roles");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "authorization: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

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

(client/get "{{baseUrl}}/api/v1/roles" {:headers {:authorization "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/api/v1/roles"
headers = HTTP::Headers{
  "authorization" => "{{apiKey}}"
}

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

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

func main() {

	url := "{{baseUrl}}/api/v1/roles"

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

	req.Header.Add("authorization", "{{apiKey}}")

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

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

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

}
GET /baseUrl/api/v1/roles HTTP/1.1
Authorization: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/api/v1/roles")
  .setHeader("authorization", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/api/v1/roles"))
    .header("authorization", "{{apiKey}}")
    .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}}/api/v1/roles")
  .get()
  .addHeader("authorization", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/api/v1/roles")
  .header("authorization", "{{apiKey}}")
  .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}}/api/v1/roles');
xhr.setRequestHeader('authorization', '{{apiKey}}');

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/api/v1/roles',
  headers: {authorization: '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/api/v1/roles';
const options = {method: 'GET', headers: {authorization: '{{apiKey}}'}};

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}}/api/v1/roles',
  method: 'GET',
  headers: {
    authorization: '{{apiKey}}'
  }
};

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

val request = Request.Builder()
  .url("{{baseUrl}}/api/v1/roles")
  .get()
  .addHeader("authorization", "{{apiKey}}")
  .build()

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

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/api/v1/roles',
  headers: {
    authorization: '{{apiKey}}'
  }
};

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}}/api/v1/roles',
  headers: {authorization: '{{apiKey}}'}
};

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

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

const req = unirest('GET', '{{baseUrl}}/api/v1/roles');

req.headers({
  authorization: '{{apiKey}}'
});

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}}/api/v1/roles',
  headers: {authorization: '{{apiKey}}'}
};

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

const url = '{{baseUrl}}/api/v1/roles';
const options = {method: 'GET', headers: {authorization: '{{apiKey}}'}};

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

NSDictionary *headers = @{ @"authorization": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/api/v1/roles"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

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}}/api/v1/roles" in
let headers = Header.add (Header.init ()) "authorization" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/api/v1/roles",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "authorization: {{apiKey}}"
  ],
]);

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/api/v1/roles', [
  'headers' => [
    'authorization' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/api/v1/roles');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'authorization' => '{{apiKey}}'
]);

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/api/v1/roles');
$request->setRequestMethod('GET');
$request->setHeaders([
  'authorization' => '{{apiKey}}'
]);

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

echo $response->getBody();
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/api/v1/roles' -Method GET -Headers $headers
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/api/v1/roles' -Method GET -Headers $headers
import http.client

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

headers = { 'authorization': "{{apiKey}}" }

conn.request("GET", "/baseUrl/api/v1/roles", headers=headers)

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

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

url = "{{baseUrl}}/api/v1/roles"

headers = {"authorization": "{{apiKey}}"}

response = requests.get(url, headers=headers)

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

url <- "{{baseUrl}}/api/v1/roles"

response <- VERB("GET", url, add_headers('authorization' = '{{apiKey}}'), content_type("application/octet-stream"))

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

url = URI("{{baseUrl}}/api/v1/roles")

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

request = Net::HTTP::Get.new(url)
request["authorization"] = '{{apiKey}}'

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

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

response = conn.get('/baseUrl/api/v1/roles') do |req|
  req.headers['authorization'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

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

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("authorization", "{{apiKey}}".parse().unwrap());

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

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

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/api/v1/roles \
  --header 'authorization: {{apiKey}}'
http GET {{baseUrl}}/api/v1/roles \
  authorization:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'authorization: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/api/v1/roles
import Foundation

let headers = ["authorization": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/api/v1/roles")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

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()
RESPONSE HEADERS

Content-Type
application/json
RESPONSE BODY json

{
  "limit": 100,
  "offset": 0,
  "total": 200
}
RESPONSE HEADERS

Content-Type
application/xml
RESPONSE BODY xml

{
  "limit": 100,
  "offset": 0,
  "total": 200
}
GET List users and their roles
{{baseUrl}}/api/v1/organizations/:organizationId/roles
HEADERS

Authorization
{{apiKey}}
QUERY PARAMS

organizationId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/api/v1/organizations/:organizationId/roles");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "authorization: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

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

(client/get "{{baseUrl}}/api/v1/organizations/:organizationId/roles" {:headers {:authorization "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/api/v1/organizations/:organizationId/roles"
headers = HTTP::Headers{
  "authorization" => "{{apiKey}}"
}

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

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

func main() {

	url := "{{baseUrl}}/api/v1/organizations/:organizationId/roles"

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

	req.Header.Add("authorization", "{{apiKey}}")

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

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

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

}
GET /baseUrl/api/v1/organizations/:organizationId/roles HTTP/1.1
Authorization: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/api/v1/organizations/:organizationId/roles")
  .setHeader("authorization", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/api/v1/organizations/:organizationId/roles"))
    .header("authorization", "{{apiKey}}")
    .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}}/api/v1/organizations/:organizationId/roles")
  .get()
  .addHeader("authorization", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/api/v1/organizations/:organizationId/roles")
  .header("authorization", "{{apiKey}}")
  .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}}/api/v1/organizations/:organizationId/roles');
xhr.setRequestHeader('authorization', '{{apiKey}}');

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/api/v1/organizations/:organizationId/roles',
  headers: {authorization: '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/api/v1/organizations/:organizationId/roles';
const options = {method: 'GET', headers: {authorization: '{{apiKey}}'}};

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}}/api/v1/organizations/:organizationId/roles',
  method: 'GET',
  headers: {
    authorization: '{{apiKey}}'
  }
};

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

val request = Request.Builder()
  .url("{{baseUrl}}/api/v1/organizations/:organizationId/roles")
  .get()
  .addHeader("authorization", "{{apiKey}}")
  .build()

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

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/api/v1/organizations/:organizationId/roles',
  headers: {
    authorization: '{{apiKey}}'
  }
};

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}}/api/v1/organizations/:organizationId/roles',
  headers: {authorization: '{{apiKey}}'}
};

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

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

const req = unirest('GET', '{{baseUrl}}/api/v1/organizations/:organizationId/roles');

req.headers({
  authorization: '{{apiKey}}'
});

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}}/api/v1/organizations/:organizationId/roles',
  headers: {authorization: '{{apiKey}}'}
};

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

const url = '{{baseUrl}}/api/v1/organizations/:organizationId/roles';
const options = {method: 'GET', headers: {authorization: '{{apiKey}}'}};

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

NSDictionary *headers = @{ @"authorization": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/api/v1/organizations/:organizationId/roles"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

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}}/api/v1/organizations/:organizationId/roles" in
let headers = Header.add (Header.init ()) "authorization" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/api/v1/organizations/:organizationId/roles",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "authorization: {{apiKey}}"
  ],
]);

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/api/v1/organizations/:organizationId/roles', [
  'headers' => [
    'authorization' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/api/v1/organizations/:organizationId/roles');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'authorization' => '{{apiKey}}'
]);

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/api/v1/organizations/:organizationId/roles');
$request->setRequestMethod('GET');
$request->setHeaders([
  'authorization' => '{{apiKey}}'
]);

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

echo $response->getBody();
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/api/v1/organizations/:organizationId/roles' -Method GET -Headers $headers
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/api/v1/organizations/:organizationId/roles' -Method GET -Headers $headers
import http.client

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

headers = { 'authorization': "{{apiKey}}" }

conn.request("GET", "/baseUrl/api/v1/organizations/:organizationId/roles", headers=headers)

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

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

url = "{{baseUrl}}/api/v1/organizations/:organizationId/roles"

headers = {"authorization": "{{apiKey}}"}

response = requests.get(url, headers=headers)

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

url <- "{{baseUrl}}/api/v1/organizations/:organizationId/roles"

response <- VERB("GET", url, add_headers('authorization' = '{{apiKey}}'), content_type("application/octet-stream"))

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

url = URI("{{baseUrl}}/api/v1/organizations/:organizationId/roles")

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

request = Net::HTTP::Get.new(url)
request["authorization"] = '{{apiKey}}'

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

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

response = conn.get('/baseUrl/api/v1/organizations/:organizationId/roles') do |req|
  req.headers['authorization'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/api/v1/organizations/:organizationId/roles";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("authorization", "{{apiKey}}".parse().unwrap());

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

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

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/api/v1/organizations/:organizationId/roles \
  --header 'authorization: {{apiKey}}'
http GET {{baseUrl}}/api/v1/organizations/:organizationId/roles \
  authorization:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'authorization: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/api/v1/organizations/:organizationId/roles
import Foundation

let headers = ["authorization": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/api/v1/organizations/:organizationId/roles")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

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()
RESPONSE HEADERS

Content-Type
application/json
RESPONSE BODY json

{
  "limit": 100,
  "offset": 0,
  "total": 200
}
RESPONSE HEADERS

Content-Type
application/xml
RESPONSE BODY xml

{
  "limit": 100,
  "offset": 0,
  "total": 200
}
POST Register user
{{baseUrl}}/account/registration
BODY json

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

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/account/registration");

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  \"email\": \"\",\n  \"password\": \"\",\n  \"username\": \"\"\n}");

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

(client/post "{{baseUrl}}/account/registration" {:content-type :json
                                                                 :form-params {:email ""
                                                                               :password ""
                                                                               :username ""}})
require "http/client"

url = "{{baseUrl}}/account/registration"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"email\": \"\",\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}}/account/registration"),
    Content = new StringContent("{\n  \"email\": \"\",\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}}/account/registration");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"email\": \"\",\n  \"password\": \"\",\n  \"username\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/account/registration"

	payload := strings.NewReader("{\n  \"email\": \"\",\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/account/registration HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 53

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

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/account/registration"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"email\": \"\",\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  \"email\": \"\",\n  \"password\": \"\",\n  \"username\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/account/registration")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/account/registration")
  .header("content-type", "application/json")
  .body("{\n  \"email\": \"\",\n  \"password\": \"\",\n  \"username\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  email: '',
  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}}/account/registration');
xhr.setRequestHeader('content-type', 'application/json');

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/account/registration',
  headers: {'content-type': 'application/json'},
  data: {email: '', password: '', username: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/account/registration';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"email":"","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}}/account/registration',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "email": "",\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  \"email\": \"\",\n  \"password\": \"\",\n  \"username\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/account/registration")
  .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/account/registration',
  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({email: '', password: '', username: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/account/registration',
  headers: {'content-type': 'application/json'},
  body: {email: '', 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}}/account/registration');

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

req.type('json');
req.send({
  email: '',
  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}}/account/registration',
  headers: {'content-type': 'application/json'},
  data: {email: '', 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}}/account/registration';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"email":"","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 = @{ @"email": @"",
                              @"password": @"",
                              @"username": @"" };

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/account/registration"]
                                                       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}}/account/registration" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"email\": \"\",\n  \"password\": \"\",\n  \"username\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/account/registration",
  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([
    'email' => '',
    '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}}/account/registration', [
  'body' => '{
  "email": "",
  "password": "",
  "username": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

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

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

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

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'email' => '',
  'password' => '',
  'username' => ''
]));
$request->setRequestUrl('{{baseUrl}}/account/registration');
$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}}/account/registration' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "email": "",
  "password": "",
  "username": ""
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/account/registration' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "email": "",
  "password": "",
  "username": ""
}'
import http.client

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

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

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

conn.request("POST", "/baseUrl/account/registration", payload, headers)

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

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

url = "{{baseUrl}}/account/registration"

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

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

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

url <- "{{baseUrl}}/account/registration"

payload <- "{\n  \"email\": \"\",\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}}/account/registration")

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  \"email\": \"\",\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/account/registration') do |req|
  req.body = "{\n  \"email\": \"\",\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}}/account/registration";

    let payload = json!({
        "email": "",
        "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}}/account/registration \
  --header 'content-type: application/json' \
  --data '{
  "email": "",
  "password": "",
  "username": ""
}'
echo '{
  "email": "",
  "password": "",
  "username": ""
}' |  \
  http POST {{baseUrl}}/account/registration \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "email": "",\n  "password": "",\n  "username": ""\n}' \
  --output-document \
  - {{baseUrl}}/account/registration
import Foundation

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

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

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/account/registration")! 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 Remove role(s) from user
{{baseUrl}}/api/v1/organizations/:organizationId/users/:username/roles
HEADERS

Authorization
{{apiKey}}
QUERY PARAMS

organizationId
username
BODY json

{
  "roles": []
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/api/v1/organizations/:organizationId/users/:username/roles");

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

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"roles\": []\n}");

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

(client/delete "{{baseUrl}}/api/v1/organizations/:organizationId/users/:username/roles" {:headers {:authorization "{{apiKey}}"}
                                                                                                         :content-type :json
                                                                                                         :form-params {:roles []}})
require "http/client"

url = "{{baseUrl}}/api/v1/organizations/:organizationId/users/:username/roles"
headers = HTTP::Headers{
  "authorization" => "{{apiKey}}"
  "content-type" => "application/json"
}
reqBody = "{\n  \"roles\": []\n}"

response = HTTP::Client.delete url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Delete,
    RequestUri = new Uri("{{baseUrl}}/api/v1/organizations/:organizationId/users/:username/roles"),
    Headers =
    {
        { "authorization", "{{apiKey}}" },
    },
    Content = new StringContent("{\n  \"roles\": []\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}}/api/v1/organizations/:organizationId/users/:username/roles");
var request = new RestRequest("", Method.Delete);
request.AddHeader("authorization", "{{apiKey}}");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"roles\": []\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/api/v1/organizations/:organizationId/users/:username/roles"

	payload := strings.NewReader("{\n  \"roles\": []\n}")

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

	req.Header.Add("authorization", "{{apiKey}}")
	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))

}
DELETE /baseUrl/api/v1/organizations/:organizationId/users/:username/roles HTTP/1.1
Authorization: {{apiKey}}
Content-Type: application/json
Host: example.com
Content-Length: 17

{
  "roles": []
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/api/v1/organizations/:organizationId/users/:username/roles")
  .setHeader("authorization", "{{apiKey}}")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"roles\": []\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/api/v1/organizations/:organizationId/users/:username/roles"))
    .header("authorization", "{{apiKey}}")
    .header("content-type", "application/json")
    .method("DELETE", HttpRequest.BodyPublishers.ofString("{\n  \"roles\": []\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  \"roles\": []\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/api/v1/organizations/:organizationId/users/:username/roles")
  .delete(body)
  .addHeader("authorization", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/api/v1/organizations/:organizationId/users/:username/roles")
  .header("authorization", "{{apiKey}}")
  .header("content-type", "application/json")
  .body("{\n  \"roles\": []\n}")
  .asString();
const data = JSON.stringify({
  roles: []
});

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

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

xhr.open('DELETE', '{{baseUrl}}/api/v1/organizations/:organizationId/users/:username/roles');
xhr.setRequestHeader('authorization', '{{apiKey}}');
xhr.setRequestHeader('content-type', 'application/json');

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

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/api/v1/organizations/:organizationId/users/:username/roles',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  data: {roles: []}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/api/v1/organizations/:organizationId/users/:username/roles';
const options = {
  method: 'DELETE',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"roles":[]}'
};

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}}/api/v1/organizations/:organizationId/users/:username/roles',
  method: 'DELETE',
  headers: {
    authorization: '{{apiKey}}',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "roles": []\n}'
};

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

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"roles\": []\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/api/v1/organizations/:organizationId/users/:username/roles")
  .delete(body)
  .addHeader("authorization", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build()

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

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/api/v1/organizations/:organizationId/users/:username/roles',
  headers: {
    authorization: '{{apiKey}}',
    '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({roles: []}));
req.end();
const request = require('request');

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/api/v1/organizations/:organizationId/users/:username/roles',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  body: {roles: []},
  json: true
};

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

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

const req = unirest('DELETE', '{{baseUrl}}/api/v1/organizations/:organizationId/users/:username/roles');

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

req.type('json');
req.send({
  roles: []
});

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}}/api/v1/organizations/:organizationId/users/:username/roles',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  data: {roles: []}
};

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

const url = '{{baseUrl}}/api/v1/organizations/:organizationId/users/:username/roles';
const options = {
  method: 'DELETE',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"roles":[]}'
};

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

NSDictionary *headers = @{ @"authorization": @"{{apiKey}}",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"roles": @[  ] };

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/api/v1/organizations/:organizationId/users/:username/roles"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"DELETE"];
[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}}/api/v1/organizations/:organizationId/users/:username/roles" in
let headers = Header.add_list (Header.init ()) [
  ("authorization", "{{apiKey}}");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"roles\": []\n}" in

Client.call ~headers ~body `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/api/v1/organizations/:organizationId/users/:username/roles",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
  CURLOPT_POSTFIELDS => json_encode([
    'roles' => [
        
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "authorization: {{apiKey}}",
    "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('DELETE', '{{baseUrl}}/api/v1/organizations/:organizationId/users/:username/roles', [
  'body' => '{
  "roles": []
}',
  'headers' => [
    'authorization' => '{{apiKey}}',
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/api/v1/organizations/:organizationId/users/:username/roles');
$request->setMethod(HTTP_METH_DELETE);

$request->setHeaders([
  'authorization' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'roles' => [
    
  ]
]));

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'roles' => [
    
  ]
]));
$request->setRequestUrl('{{baseUrl}}/api/v1/organizations/:organizationId/users/:username/roles');
$request->setRequestMethod('DELETE');
$request->setBody($body);

$request->setHeaders([
  'authorization' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

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

echo $response->getBody();
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/api/v1/organizations/:organizationId/users/:username/roles' -Method DELETE -Headers $headers -ContentType 'application/json' -Body '{
  "roles": []
}'
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/api/v1/organizations/:organizationId/users/:username/roles' -Method DELETE -Headers $headers -ContentType 'application/json' -Body '{
  "roles": []
}'
import http.client

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

payload = "{\n  \"roles\": []\n}"

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

conn.request("DELETE", "/baseUrl/api/v1/organizations/:organizationId/users/:username/roles", payload, headers)

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

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

url = "{{baseUrl}}/api/v1/organizations/:organizationId/users/:username/roles"

payload = { "roles": [] }
headers = {
    "authorization": "{{apiKey}}",
    "content-type": "application/json"
}

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

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

url <- "{{baseUrl}}/api/v1/organizations/:organizationId/users/:username/roles"

payload <- "{\n  \"roles\": []\n}"

encode <- "json"

response <- VERB("DELETE", url, body = payload, add_headers('authorization' = '{{apiKey}}'), content_type("application/json"), encode = encode)

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

url = URI("{{baseUrl}}/api/v1/organizations/:organizationId/users/:username/roles")

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

request = Net::HTTP::Delete.new(url)
request["authorization"] = '{{apiKey}}'
request["content-type"] = 'application/json'
request.body = "{\n  \"roles\": []\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.delete('/baseUrl/api/v1/organizations/:organizationId/users/:username/roles') do |req|
  req.headers['authorization'] = '{{apiKey}}'
  req.body = "{\n  \"roles\": []\n}"
end

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

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/api/v1/organizations/:organizationId/users/:username/roles";

    let payload = json!({"roles": ()});

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

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

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

    dbg!(results);
}
curl --request DELETE \
  --url {{baseUrl}}/api/v1/organizations/:organizationId/users/:username/roles \
  --header 'authorization: {{apiKey}}' \
  --header 'content-type: application/json' \
  --data '{
  "roles": []
}'
echo '{
  "roles": []
}' |  \
  http DELETE {{baseUrl}}/api/v1/organizations/:organizationId/users/:username/roles \
  authorization:'{{apiKey}}' \
  content-type:application/json
wget --quiet \
  --method DELETE \
  --header 'authorization: {{apiKey}}' \
  --header 'content-type: application/json' \
  --body-data '{\n  "roles": []\n}' \
  --output-document \
  - {{baseUrl}}/api/v1/organizations/:organizationId/users/:username/roles
import Foundation

let headers = [
  "authorization": "{{apiKey}}",
  "content-type": "application/json"
]
let parameters = ["roles": []] as [String : Any]

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

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/api/v1/organizations/:organizationId/users/:username/roles")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "DELETE"
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 Request password reset
{{baseUrl}}/account/password
BODY json

{
  "username": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/account/password");

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  \"username\": \"\"\n}");

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

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

url = "{{baseUrl}}/account/password"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\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}}/account/password"),
    Content = new StringContent("{\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}}/account/password");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"username\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/account/password"

	payload := strings.NewReader("{\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/account/password HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 20

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

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/account/password"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\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  \"username\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/account/password")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/account/password")
  .header("content-type", "application/json")
  .body("{\n  \"username\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  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}}/account/password');
xhr.setRequestHeader('content-type', 'application/json');

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

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

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/account/password';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"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}}/account/password',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\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  \"username\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/account/password")
  .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/account/password',
  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({username: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/account/password',
  headers: {'content-type': 'application/json'},
  body: {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}}/account/password');

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

req.type('json');
req.send({
  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}}/account/password',
  headers: {'content-type': 'application/json'},
  data: {username: ''}
};

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

const url = '{{baseUrl}}/account/password';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"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 = @{ @"username": @"" };

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/account/password"]
                                                       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}}/account/password" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"username\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/account/password",
  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([
    '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}}/account/password', [
  'body' => '{
  "username": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

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

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

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

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'username' => ''
]));
$request->setRequestUrl('{{baseUrl}}/account/password');
$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}}/account/password' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "username": ""
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/account/password' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "username": ""
}'
import http.client

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

payload = "{\n  \"username\": \"\"\n}"

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

conn.request("POST", "/baseUrl/account/password", payload, headers)

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

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

url = "{{baseUrl}}/account/password"

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

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

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

url <- "{{baseUrl}}/account/password"

payload <- "{\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}}/account/password")

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  \"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/account/password') do |req|
  req.body = "{\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}}/account/password";

    let payload = json!({"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}}/account/password \
  --header 'content-type: application/json' \
  --data '{
  "username": ""
}'
echo '{
  "username": ""
}' |  \
  http POST {{baseUrl}}/account/password \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "username": ""\n}' \
  --output-document \
  - {{baseUrl}}/account/password
import Foundation

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

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

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/account/password")! 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()
GET Retrieve organizations of user
{{baseUrl}}/api/v1/user/organizations
HEADERS

Authorization
{{apiKey}}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/api/v1/user/organizations");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "authorization: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

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

(client/get "{{baseUrl}}/api/v1/user/organizations" {:headers {:authorization "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/api/v1/user/organizations"
headers = HTTP::Headers{
  "authorization" => "{{apiKey}}"
}

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

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

func main() {

	url := "{{baseUrl}}/api/v1/user/organizations"

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

	req.Header.Add("authorization", "{{apiKey}}")

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

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

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

}
GET /baseUrl/api/v1/user/organizations HTTP/1.1
Authorization: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/api/v1/user/organizations")
  .setHeader("authorization", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/api/v1/user/organizations"))
    .header("authorization", "{{apiKey}}")
    .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}}/api/v1/user/organizations")
  .get()
  .addHeader("authorization", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/api/v1/user/organizations")
  .header("authorization", "{{apiKey}}")
  .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}}/api/v1/user/organizations');
xhr.setRequestHeader('authorization', '{{apiKey}}');

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/api/v1/user/organizations',
  headers: {authorization: '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/api/v1/user/organizations';
const options = {method: 'GET', headers: {authorization: '{{apiKey}}'}};

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}}/api/v1/user/organizations',
  method: 'GET',
  headers: {
    authorization: '{{apiKey}}'
  }
};

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

val request = Request.Builder()
  .url("{{baseUrl}}/api/v1/user/organizations")
  .get()
  .addHeader("authorization", "{{apiKey}}")
  .build()

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

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/api/v1/user/organizations',
  headers: {
    authorization: '{{apiKey}}'
  }
};

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}}/api/v1/user/organizations',
  headers: {authorization: '{{apiKey}}'}
};

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

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

const req = unirest('GET', '{{baseUrl}}/api/v1/user/organizations');

req.headers({
  authorization: '{{apiKey}}'
});

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}}/api/v1/user/organizations',
  headers: {authorization: '{{apiKey}}'}
};

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

const url = '{{baseUrl}}/api/v1/user/organizations';
const options = {method: 'GET', headers: {authorization: '{{apiKey}}'}};

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

NSDictionary *headers = @{ @"authorization": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/api/v1/user/organizations"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

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}}/api/v1/user/organizations" in
let headers = Header.add (Header.init ()) "authorization" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/api/v1/user/organizations",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "authorization: {{apiKey}}"
  ],
]);

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/api/v1/user/organizations', [
  'headers' => [
    'authorization' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/api/v1/user/organizations');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'authorization' => '{{apiKey}}'
]);

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/api/v1/user/organizations');
$request->setRequestMethod('GET');
$request->setHeaders([
  'authorization' => '{{apiKey}}'
]);

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

echo $response->getBody();
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/api/v1/user/organizations' -Method GET -Headers $headers
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/api/v1/user/organizations' -Method GET -Headers $headers
import http.client

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

headers = { 'authorization': "{{apiKey}}" }

conn.request("GET", "/baseUrl/api/v1/user/organizations", headers=headers)

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

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

url = "{{baseUrl}}/api/v1/user/organizations"

headers = {"authorization": "{{apiKey}}"}

response = requests.get(url, headers=headers)

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

url <- "{{baseUrl}}/api/v1/user/organizations"

response <- VERB("GET", url, add_headers('authorization' = '{{apiKey}}'), content_type("application/octet-stream"))

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

url = URI("{{baseUrl}}/api/v1/user/organizations")

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

request = Net::HTTP::Get.new(url)
request["authorization"] = '{{apiKey}}'

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

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

response = conn.get('/baseUrl/api/v1/user/organizations') do |req|
  req.headers['authorization'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

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

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("authorization", "{{apiKey}}".parse().unwrap());

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

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

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/api/v1/user/organizations \
  --header 'authorization: {{apiKey}}'
http GET {{baseUrl}}/api/v1/user/organizations \
  authorization:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'authorization: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/api/v1/user/organizations
import Foundation

let headers = ["authorization": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/api/v1/user/organizations")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

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()
RESPONSE HEADERS

Content-Type
application/json
RESPONSE BODY json

{
  "limit": 100,
  "offset": 0,
  "total": 200
}
RESPONSE HEADERS

Content-Type
application/xml
RESPONSE BODY xml

{
  "limit": 100,
  "offset": 0,
  "total": 200
}
PUT Verify password reset
{{baseUrl}}/account/password
BODY json

{
  "password": "",
  "token": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/account/password");

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  \"password\": \"\",\n  \"token\": \"\"\n}");

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

(client/put "{{baseUrl}}/account/password" {:content-type :json
                                                            :form-params {:password ""
                                                                          :token ""}})
require "http/client"

url = "{{baseUrl}}/account/password"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"password\": \"\",\n  \"token\": \"\"\n}"

response = HTTP::Client.put url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Put,
    RequestUri = new Uri("{{baseUrl}}/account/password"),
    Content = new StringContent("{\n  \"password\": \"\",\n  \"token\": \"\"\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}}/account/password");
var request = new RestRequest("", Method.Put);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"password\": \"\",\n  \"token\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/account/password"

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

	req, _ := http.NewRequest("PUT", 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))

}
PUT /baseUrl/account/password HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 35

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

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/account/password"))
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"password\": \"\",\n  \"token\": \"\"\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  \"password\": \"\",\n  \"token\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/account/password")
  .put(body)
  .addHeader("content-type", "application/json")
  .build();

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

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

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

xhr.open('PUT', '{{baseUrl}}/account/password');
xhr.setRequestHeader('content-type', 'application/json');

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

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/account/password',
  headers: {'content-type': 'application/json'},
  data: {password: '', token: ''}
};

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

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}}/account/password',
  method: 'PUT',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "password": "",\n  "token": ""\n}'
};

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

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

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

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/account/password',
  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({password: '', token: ''}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/account/password',
  headers: {'content-type': 'application/json'},
  body: {password: '', token: ''},
  json: true
};

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

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

const req = unirest('PUT', '{{baseUrl}}/account/password');

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

req.type('json');
req.send({
  password: '',
  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: 'PUT',
  url: '{{baseUrl}}/account/password',
  headers: {'content-type': 'application/json'},
  data: {password: '', token: ''}
};

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

const url = '{{baseUrl}}/account/password';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"password":"","token":""}'
};

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 = @{ @"password": @"",
                              @"token": @"" };

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/account/password"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"PUT"];
[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}}/account/password" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"password\": \"\",\n  \"token\": \"\"\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/account/password",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
  CURLOPT_POSTFIELDS => json_encode([
    'password' => '',
    'token' => ''
  ]),
  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('PUT', '{{baseUrl}}/account/password', [
  'body' => '{
  "password": "",
  "token": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/account/password');
$request->setMethod(HTTP_METH_PUT);

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

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

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'password' => '',
  'token' => ''
]));
$request->setRequestUrl('{{baseUrl}}/account/password');
$request->setRequestMethod('PUT');
$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}}/account/password' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "password": "",
  "token": ""
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/account/password' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "password": "",
  "token": ""
}'
import http.client

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

payload = "{\n  \"password\": \"\",\n  \"token\": \"\"\n}"

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

conn.request("PUT", "/baseUrl/account/password", payload, headers)

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

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

url = "{{baseUrl}}/account/password"

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

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

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

url <- "{{baseUrl}}/account/password"

payload <- "{\n  \"password\": \"\",\n  \"token\": \"\"\n}"

encode <- "json"

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

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

url = URI("{{baseUrl}}/account/password")

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

request = Net::HTTP::Put.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"password\": \"\",\n  \"token\": \"\"\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.put('/baseUrl/account/password') do |req|
  req.body = "{\n  \"password\": \"\",\n  \"token\": \"\"\n}"
end

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

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

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

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

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

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

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

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

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

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/account/password")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "PUT"
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 Verify registration
{{baseUrl}}/account/verification
BODY json

{
  "token": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/account/verification");

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  \"token\": \"\"\n}");

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

(client/post "{{baseUrl}}/account/verification" {:content-type :json
                                                                 :form-params {:token ""}})
require "http/client"

url = "{{baseUrl}}/account/verification"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"token\": \"\"\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}}/account/verification"),
    Content = new StringContent("{\n  \"token\": \"\"\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}}/account/verification");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"token\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/account/verification"

	payload := strings.NewReader("{\n  \"token\": \"\"\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/account/verification HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 17

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

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/account/verification"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"token\": \"\"\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  \"token\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/account/verification")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

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

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

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

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

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/account/verification',
  headers: {'content-type': 'application/json'},
  data: {token: ''}
};

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

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}}/account/verification',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "token": ""\n}'
};

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

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"token\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/account/verification")
  .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/account/verification',
  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({token: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/account/verification',
  headers: {'content-type': 'application/json'},
  body: {token: ''},
  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}}/account/verification');

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

req.type('json');
req.send({
  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: 'POST',
  url: '{{baseUrl}}/account/verification',
  headers: {'content-type': 'application/json'},
  data: {token: ''}
};

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

const url = '{{baseUrl}}/account/verification';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"token":""}'
};

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 = @{ @"token": @"" };

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/account/verification"]
                                                       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}}/account/verification" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"token\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/account/verification",
  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([
    'token' => ''
  ]),
  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}}/account/verification', [
  'body' => '{
  "token": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

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

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

$request->setContentType('application/json');
$request->setBody(json_encode([
  'token' => ''
]));

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'token' => ''
]));
$request->setRequestUrl('{{baseUrl}}/account/verification');
$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}}/account/verification' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "token": ""
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/account/verification' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "token": ""
}'
import http.client

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

payload = "{\n  \"token\": \"\"\n}"

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

conn.request("POST", "/baseUrl/account/verification", payload, headers)

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

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

url = "{{baseUrl}}/account/verification"

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

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

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

url <- "{{baseUrl}}/account/verification"

payload <- "{\n  \"token\": \"\"\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}}/account/verification")

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  \"token\": \"\"\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/account/verification') do |req|
  req.body = "{\n  \"token\": \"\"\n}"
end

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

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

    let payload = json!({"token": ""});

    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}}/account/verification \
  --header 'content-type: application/json' \
  --data '{
  "token": ""
}'
echo '{
  "token": ""
}' |  \
  http POST {{baseUrl}}/account/verification \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "token": ""\n}' \
  --output-document \
  - {{baseUrl}}/account/verification
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["token": ""] as [String : Any]

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

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/account/verification")! 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 login
{{baseUrl}}/login
BODY json

{
  "login": "",
  "password": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/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  \"login\": \"\",\n  \"password\": \"\"\n}");

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

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

url = "{{baseUrl}}/login"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"login\": \"\",\n  \"password\": \"\"\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}}/login"),
    Content = new StringContent("{\n  \"login\": \"\",\n  \"password\": \"\"\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}}/login");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"login\": \"\",\n  \"password\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

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

	payload := strings.NewReader("{\n  \"login\": \"\",\n  \"password\": \"\"\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/login HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 35

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

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/login"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"login\": \"\",\n  \"password\": \"\"\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  \"login\": \"\",\n  \"password\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/login")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

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

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

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

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

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

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

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

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}}/login',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "login": "",\n  "password": ""\n}'
};

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

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"login\": \"\",\n  \"password\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/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/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({login: '', password: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/login',
  headers: {'content-type': 'application/json'},
  body: {login: '', password: ''},
  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}}/login');

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

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

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}}/login',
  headers: {'content-type': 'application/json'},
  data: {login: '', password: ''}
};

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

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

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 = @{ @"login": @"",
                              @"password": @"" };

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/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}}/login" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"login\": \"\",\n  \"password\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/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([
    'login' => '',
    'password' => ''
  ]),
  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}}/login', [
  'body' => '{
  "login": "",
  "password": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

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

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

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

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'login' => '',
  'password' => ''
]));
$request->setRequestUrl('{{baseUrl}}/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}}/login' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "login": "",
  "password": ""
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/login' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "login": "",
  "password": ""
}'
import http.client

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

payload = "{\n  \"login\": \"\",\n  \"password\": \"\"\n}"

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

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

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

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

url = "{{baseUrl}}/login"

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

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

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

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

payload <- "{\n  \"login\": \"\",\n  \"password\": \"\"\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}}/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  \"login\": \"\",\n  \"password\": \"\"\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/login') do |req|
  req.body = "{\n  \"login\": \"\",\n  \"password\": \"\"\n}"
end

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

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

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

    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}}/login \
  --header 'content-type: application/json' \
  --data '{
  "login": "",
  "password": ""
}'
echo '{
  "login": "",
  "password": ""
}' |  \
  http POST {{baseUrl}}/login \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "login": "",\n  "password": ""\n}' \
  --output-document \
  - {{baseUrl}}/login
import Foundation

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

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

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/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()
POST Add alias for GUID or Collection
{{baseUrl}}/api/v1/id4ns/:id4n/alias/:aliasType
HEADERS

Authorization
{{apiKey}}
QUERY PARAMS

id4n
aliasType
BODY json

{
  "alias": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/api/v1/id4ns/:id4n/alias/:aliasType");

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

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"alias\": \"alias\"\n}");

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

(client/post "{{baseUrl}}/api/v1/id4ns/:id4n/alias/:aliasType" {:headers {:authorization "{{apiKey}}"}
                                                                                :content-type :json
                                                                                :form-params {:alias "alias"}})
require "http/client"

url = "{{baseUrl}}/api/v1/id4ns/:id4n/alias/:aliasType"
headers = HTTP::Headers{
  "authorization" => "{{apiKey}}"
  "content-type" => "application/json"
}
reqBody = "{\n  \"alias\": \"alias\"\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}}/api/v1/id4ns/:id4n/alias/:aliasType"),
    Headers =
    {
        { "authorization", "{{apiKey}}" },
    },
    Content = new StringContent("{\n  \"alias\": \"alias\"\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}}/api/v1/id4ns/:id4n/alias/:aliasType");
var request = new RestRequest("", Method.Post);
request.AddHeader("authorization", "{{apiKey}}");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"alias\": \"alias\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/api/v1/id4ns/:id4n/alias/:aliasType"

	payload := strings.NewReader("{\n  \"alias\": \"alias\"\n}")

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

	req.Header.Add("authorization", "{{apiKey}}")
	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/api/v1/id4ns/:id4n/alias/:aliasType HTTP/1.1
Authorization: {{apiKey}}
Content-Type: application/json
Host: example.com
Content-Length: 22

{
  "alias": "alias"
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/api/v1/id4ns/:id4n/alias/:aliasType")
  .setHeader("authorization", "{{apiKey}}")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"alias\": \"alias\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/api/v1/id4ns/:id4n/alias/:aliasType"))
    .header("authorization", "{{apiKey}}")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"alias\": \"alias\"\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  \"alias\": \"alias\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/api/v1/id4ns/:id4n/alias/:aliasType")
  .post(body)
  .addHeader("authorization", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/api/v1/id4ns/:id4n/alias/:aliasType")
  .header("authorization", "{{apiKey}}")
  .header("content-type", "application/json")
  .body("{\n  \"alias\": \"alias\"\n}")
  .asString();
const data = JSON.stringify({
  alias: 'alias'
});

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

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

xhr.open('POST', '{{baseUrl}}/api/v1/id4ns/:id4n/alias/:aliasType');
xhr.setRequestHeader('authorization', '{{apiKey}}');
xhr.setRequestHeader('content-type', 'application/json');

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/api/v1/id4ns/:id4n/alias/:aliasType',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  data: {alias: 'alias'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/api/v1/id4ns/:id4n/alias/:aliasType';
const options = {
  method: 'POST',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"alias":"alias"}'
};

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}}/api/v1/id4ns/:id4n/alias/:aliasType',
  method: 'POST',
  headers: {
    authorization: '{{apiKey}}',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "alias": "alias"\n}'
};

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

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"alias\": \"alias\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/api/v1/id4ns/:id4n/alias/:aliasType")
  .post(body)
  .addHeader("authorization", "{{apiKey}}")
  .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/api/v1/id4ns/:id4n/alias/:aliasType',
  headers: {
    authorization: '{{apiKey}}',
    '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({alias: 'alias'}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/api/v1/id4ns/:id4n/alias/:aliasType',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  body: {alias: 'alias'},
  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}}/api/v1/id4ns/:id4n/alias/:aliasType');

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

req.type('json');
req.send({
  alias: 'alias'
});

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}}/api/v1/id4ns/:id4n/alias/:aliasType',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  data: {alias: 'alias'}
};

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

const url = '{{baseUrl}}/api/v1/id4ns/:id4n/alias/:aliasType';
const options = {
  method: 'POST',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"alias":"alias"}'
};

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

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

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/api/v1/id4ns/:id4n/alias/:aliasType"]
                                                       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}}/api/v1/id4ns/:id4n/alias/:aliasType" in
let headers = Header.add_list (Header.init ()) [
  ("authorization", "{{apiKey}}");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"alias\": \"alias\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/api/v1/id4ns/:id4n/alias/:aliasType",
  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([
    'alias' => 'alias'
  ]),
  CURLOPT_HTTPHEADER => [
    "authorization: {{apiKey}}",
    "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}}/api/v1/id4ns/:id4n/alias/:aliasType', [
  'body' => '{
  "alias": "alias"
}',
  'headers' => [
    'authorization' => '{{apiKey}}',
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/api/v1/id4ns/:id4n/alias/:aliasType');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'authorization' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'alias' => 'alias'
]));

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'alias' => 'alias'
]));
$request->setRequestUrl('{{baseUrl}}/api/v1/id4ns/:id4n/alias/:aliasType');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'authorization' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

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

echo $response->getBody();
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/api/v1/id4ns/:id4n/alias/:aliasType' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "alias": "alias"
}'
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/api/v1/id4ns/:id4n/alias/:aliasType' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "alias": "alias"
}'
import http.client

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

payload = "{\n  \"alias\": \"alias\"\n}"

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

conn.request("POST", "/baseUrl/api/v1/id4ns/:id4n/alias/:aliasType", payload, headers)

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

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

url = "{{baseUrl}}/api/v1/id4ns/:id4n/alias/:aliasType"

payload = { "alias": "alias" }
headers = {
    "authorization": "{{apiKey}}",
    "content-type": "application/json"
}

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

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

url <- "{{baseUrl}}/api/v1/id4ns/:id4n/alias/:aliasType"

payload <- "{\n  \"alias\": \"alias\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('authorization' = '{{apiKey}}'), content_type("application/json"), encode = encode)

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

url = URI("{{baseUrl}}/api/v1/id4ns/:id4n/alias/:aliasType")

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

request = Net::HTTP::Post.new(url)
request["authorization"] = '{{apiKey}}'
request["content-type"] = 'application/json'
request.body = "{\n  \"alias\": \"alias\"\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/api/v1/id4ns/:id4n/alias/:aliasType') do |req|
  req.headers['authorization'] = '{{apiKey}}'
  req.body = "{\n  \"alias\": \"alias\"\n}"
end

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

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/api/v1/id4ns/:id4n/alias/:aliasType";

    let payload = json!({"alias": "alias"});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("authorization", "{{apiKey}}".parse().unwrap());
    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}}/api/v1/id4ns/:id4n/alias/:aliasType \
  --header 'authorization: {{apiKey}}' \
  --header 'content-type: application/json' \
  --data '{
  "alias": "alias"
}'
echo '{
  "alias": "alias"
}' |  \
  http POST {{baseUrl}}/api/v1/id4ns/:id4n/alias/:aliasType \
  authorization:'{{apiKey}}' \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'authorization: {{apiKey}}' \
  --header 'content-type: application/json' \
  --body-data '{\n  "alias": "alias"\n}' \
  --output-document \
  - {{baseUrl}}/api/v1/id4ns/:id4n/alias/:aliasType
import Foundation

let headers = [
  "authorization": "{{apiKey}}",
  "content-type": "application/json"
]
let parameters = ["alias": "alias"] as [String : Any]

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

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/api/v1/id4ns/:id4n/alias/:aliasType")! 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()
GET Get all aliases for the given GUID or Collection.
{{baseUrl}}/api/v1/id4ns/:id4n/alias
HEADERS

Authorization
{{apiKey}}
QUERY PARAMS

id4n
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/api/v1/id4ns/:id4n/alias");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "authorization: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

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

(client/get "{{baseUrl}}/api/v1/id4ns/:id4n/alias" {:headers {:authorization "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/api/v1/id4ns/:id4n/alias"
headers = HTTP::Headers{
  "authorization" => "{{apiKey}}"
}

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

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

func main() {

	url := "{{baseUrl}}/api/v1/id4ns/:id4n/alias"

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

	req.Header.Add("authorization", "{{apiKey}}")

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

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

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

}
GET /baseUrl/api/v1/id4ns/:id4n/alias HTTP/1.1
Authorization: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/api/v1/id4ns/:id4n/alias")
  .setHeader("authorization", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/api/v1/id4ns/:id4n/alias"))
    .header("authorization", "{{apiKey}}")
    .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}}/api/v1/id4ns/:id4n/alias")
  .get()
  .addHeader("authorization", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/api/v1/id4ns/:id4n/alias")
  .header("authorization", "{{apiKey}}")
  .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}}/api/v1/id4ns/:id4n/alias');
xhr.setRequestHeader('authorization', '{{apiKey}}');

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/api/v1/id4ns/:id4n/alias',
  headers: {authorization: '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/api/v1/id4ns/:id4n/alias';
const options = {method: 'GET', headers: {authorization: '{{apiKey}}'}};

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}}/api/v1/id4ns/:id4n/alias',
  method: 'GET',
  headers: {
    authorization: '{{apiKey}}'
  }
};

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

val request = Request.Builder()
  .url("{{baseUrl}}/api/v1/id4ns/:id4n/alias")
  .get()
  .addHeader("authorization", "{{apiKey}}")
  .build()

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

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/api/v1/id4ns/:id4n/alias',
  headers: {
    authorization: '{{apiKey}}'
  }
};

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}}/api/v1/id4ns/:id4n/alias',
  headers: {authorization: '{{apiKey}}'}
};

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

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

const req = unirest('GET', '{{baseUrl}}/api/v1/id4ns/:id4n/alias');

req.headers({
  authorization: '{{apiKey}}'
});

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}}/api/v1/id4ns/:id4n/alias',
  headers: {authorization: '{{apiKey}}'}
};

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

const url = '{{baseUrl}}/api/v1/id4ns/:id4n/alias';
const options = {method: 'GET', headers: {authorization: '{{apiKey}}'}};

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

NSDictionary *headers = @{ @"authorization": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/api/v1/id4ns/:id4n/alias"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

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}}/api/v1/id4ns/:id4n/alias" in
let headers = Header.add (Header.init ()) "authorization" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/api/v1/id4ns/:id4n/alias",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "authorization: {{apiKey}}"
  ],
]);

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/api/v1/id4ns/:id4n/alias', [
  'headers' => [
    'authorization' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/api/v1/id4ns/:id4n/alias');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'authorization' => '{{apiKey}}'
]);

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/api/v1/id4ns/:id4n/alias');
$request->setRequestMethod('GET');
$request->setHeaders([
  'authorization' => '{{apiKey}}'
]);

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

echo $response->getBody();
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/api/v1/id4ns/:id4n/alias' -Method GET -Headers $headers
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/api/v1/id4ns/:id4n/alias' -Method GET -Headers $headers
import http.client

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

headers = { 'authorization': "{{apiKey}}" }

conn.request("GET", "/baseUrl/api/v1/id4ns/:id4n/alias", headers=headers)

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

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

url = "{{baseUrl}}/api/v1/id4ns/:id4n/alias"

headers = {"authorization": "{{apiKey}}"}

response = requests.get(url, headers=headers)

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

url <- "{{baseUrl}}/api/v1/id4ns/:id4n/alias"

response <- VERB("GET", url, add_headers('authorization' = '{{apiKey}}'), content_type("application/octet-stream"))

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

url = URI("{{baseUrl}}/api/v1/id4ns/:id4n/alias")

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

request = Net::HTTP::Get.new(url)
request["authorization"] = '{{apiKey}}'

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

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

response = conn.get('/baseUrl/api/v1/id4ns/:id4n/alias') do |req|
  req.headers['authorization'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/api/v1/id4ns/:id4n/alias";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("authorization", "{{apiKey}}".parse().unwrap());

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

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

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/api/v1/id4ns/:id4n/alias \
  --header 'authorization: {{apiKey}}'
http GET {{baseUrl}}/api/v1/id4ns/:id4n/alias \
  authorization:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'authorization: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/api/v1/id4ns/:id4n/alias
import Foundation

let headers = ["authorization": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/api/v1/id4ns/:id4n/alias")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

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 List all supported alias types
{{baseUrl}}/api/v1/search/guids/aliases/types
HEADERS

Authorization
{{apiKey}}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/api/v1/search/guids/aliases/types");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "authorization: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

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

(client/get "{{baseUrl}}/api/v1/search/guids/aliases/types" {:headers {:authorization "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/api/v1/search/guids/aliases/types"
headers = HTTP::Headers{
  "authorization" => "{{apiKey}}"
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/api/v1/search/guids/aliases/types"),
    Headers =
    {
        { "authorization", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/api/v1/search/guids/aliases/types");
var request = new RestRequest("", Method.Get);
request.AddHeader("authorization", "{{apiKey}}");
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/api/v1/search/guids/aliases/types"

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

	req.Header.Add("authorization", "{{apiKey}}")

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

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

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

}
GET /baseUrl/api/v1/search/guids/aliases/types HTTP/1.1
Authorization: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/api/v1/search/guids/aliases/types")
  .setHeader("authorization", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/api/v1/search/guids/aliases/types"))
    .header("authorization", "{{apiKey}}")
    .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}}/api/v1/search/guids/aliases/types")
  .get()
  .addHeader("authorization", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/api/v1/search/guids/aliases/types")
  .header("authorization", "{{apiKey}}")
  .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}}/api/v1/search/guids/aliases/types');
xhr.setRequestHeader('authorization', '{{apiKey}}');

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/api/v1/search/guids/aliases/types',
  headers: {authorization: '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/api/v1/search/guids/aliases/types';
const options = {method: 'GET', headers: {authorization: '{{apiKey}}'}};

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}}/api/v1/search/guids/aliases/types',
  method: 'GET',
  headers: {
    authorization: '{{apiKey}}'
  }
};

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

val request = Request.Builder()
  .url("{{baseUrl}}/api/v1/search/guids/aliases/types")
  .get()
  .addHeader("authorization", "{{apiKey}}")
  .build()

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

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/api/v1/search/guids/aliases/types',
  headers: {
    authorization: '{{apiKey}}'
  }
};

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}}/api/v1/search/guids/aliases/types',
  headers: {authorization: '{{apiKey}}'}
};

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

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

const req = unirest('GET', '{{baseUrl}}/api/v1/search/guids/aliases/types');

req.headers({
  authorization: '{{apiKey}}'
});

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}}/api/v1/search/guids/aliases/types',
  headers: {authorization: '{{apiKey}}'}
};

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

const url = '{{baseUrl}}/api/v1/search/guids/aliases/types';
const options = {method: 'GET', headers: {authorization: '{{apiKey}}'}};

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

NSDictionary *headers = @{ @"authorization": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/api/v1/search/guids/aliases/types"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

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}}/api/v1/search/guids/aliases/types" in
let headers = Header.add (Header.init ()) "authorization" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/api/v1/search/guids/aliases/types",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "authorization: {{apiKey}}"
  ],
]);

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/api/v1/search/guids/aliases/types', [
  'headers' => [
    'authorization' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/api/v1/search/guids/aliases/types');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'authorization' => '{{apiKey}}'
]);

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/api/v1/search/guids/aliases/types');
$request->setRequestMethod('GET');
$request->setHeaders([
  'authorization' => '{{apiKey}}'
]);

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

echo $response->getBody();
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/api/v1/search/guids/aliases/types' -Method GET -Headers $headers
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/api/v1/search/guids/aliases/types' -Method GET -Headers $headers
import http.client

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

headers = { 'authorization': "{{apiKey}}" }

conn.request("GET", "/baseUrl/api/v1/search/guids/aliases/types", headers=headers)

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

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

url = "{{baseUrl}}/api/v1/search/guids/aliases/types"

headers = {"authorization": "{{apiKey}}"}

response = requests.get(url, headers=headers)

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

url <- "{{baseUrl}}/api/v1/search/guids/aliases/types"

response <- VERB("GET", url, add_headers('authorization' = '{{apiKey}}'), content_type("application/octet-stream"))

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

url = URI("{{baseUrl}}/api/v1/search/guids/aliases/types")

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

request = Net::HTTP::Get.new(url)
request["authorization"] = '{{apiKey}}'

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

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

response = conn.get('/baseUrl/api/v1/search/guids/aliases/types') do |req|
  req.headers['authorization'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/api/v1/search/guids/aliases/types";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("authorization", "{{apiKey}}".parse().unwrap());

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

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

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/api/v1/search/guids/aliases/types \
  --header 'authorization: {{apiKey}}'
http GET {{baseUrl}}/api/v1/search/guids/aliases/types \
  authorization:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'authorization: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/api/v1/search/guids/aliases/types
import Foundation

let headers = ["authorization": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/api/v1/search/guids/aliases/types")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

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 Remove aliases from GUID or Collection
{{baseUrl}}/api/v1/id4ns/:id4n/alias/:aliasType
HEADERS

Authorization
{{apiKey}}
QUERY PARAMS

id4n
aliasType
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/api/v1/id4ns/:id4n/alias/:aliasType");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "authorization: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

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

(client/delete "{{baseUrl}}/api/v1/id4ns/:id4n/alias/:aliasType" {:headers {:authorization "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/api/v1/id4ns/:id4n/alias/:aliasType"
headers = HTTP::Headers{
  "authorization" => "{{apiKey}}"
}

response = HTTP::Client.delete url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Delete,
    RequestUri = new Uri("{{baseUrl}}/api/v1/id4ns/:id4n/alias/:aliasType"),
    Headers =
    {
        { "authorization", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/api/v1/id4ns/:id4n/alias/:aliasType");
var request = new RestRequest("", Method.Delete);
request.AddHeader("authorization", "{{apiKey}}");
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/api/v1/id4ns/:id4n/alias/:aliasType"

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

	req.Header.Add("authorization", "{{apiKey}}")

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

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

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

}
DELETE /baseUrl/api/v1/id4ns/:id4n/alias/:aliasType HTTP/1.1
Authorization: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/api/v1/id4ns/:id4n/alias/:aliasType")
  .setHeader("authorization", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/api/v1/id4ns/:id4n/alias/:aliasType"))
    .header("authorization", "{{apiKey}}")
    .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}}/api/v1/id4ns/:id4n/alias/:aliasType")
  .delete(null)
  .addHeader("authorization", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/api/v1/id4ns/:id4n/alias/:aliasType")
  .header("authorization", "{{apiKey}}")
  .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}}/api/v1/id4ns/:id4n/alias/:aliasType');
xhr.setRequestHeader('authorization', '{{apiKey}}');

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

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/api/v1/id4ns/:id4n/alias/:aliasType',
  headers: {authorization: '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/api/v1/id4ns/:id4n/alias/:aliasType';
const options = {method: 'DELETE', headers: {authorization: '{{apiKey}}'}};

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}}/api/v1/id4ns/:id4n/alias/:aliasType',
  method: 'DELETE',
  headers: {
    authorization: '{{apiKey}}'
  }
};

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

val request = Request.Builder()
  .url("{{baseUrl}}/api/v1/id4ns/:id4n/alias/:aliasType")
  .delete(null)
  .addHeader("authorization", "{{apiKey}}")
  .build()

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

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/api/v1/id4ns/:id4n/alias/:aliasType',
  headers: {
    authorization: '{{apiKey}}'
  }
};

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}}/api/v1/id4ns/:id4n/alias/:aliasType',
  headers: {authorization: '{{apiKey}}'}
};

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

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

const req = unirest('DELETE', '{{baseUrl}}/api/v1/id4ns/:id4n/alias/:aliasType');

req.headers({
  authorization: '{{apiKey}}'
});

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}}/api/v1/id4ns/:id4n/alias/:aliasType',
  headers: {authorization: '{{apiKey}}'}
};

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

const url = '{{baseUrl}}/api/v1/id4ns/:id4n/alias/:aliasType';
const options = {method: 'DELETE', headers: {authorization: '{{apiKey}}'}};

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

NSDictionary *headers = @{ @"authorization": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/api/v1/id4ns/:id4n/alias/:aliasType"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"DELETE"];
[request setAllHTTPHeaderFields:headers];

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}}/api/v1/id4ns/:id4n/alias/:aliasType" in
let headers = Header.add (Header.init ()) "authorization" "{{apiKey}}" in

Client.call ~headers `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/api/v1/id4ns/:id4n/alias/:aliasType",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
  CURLOPT_HTTPHEADER => [
    "authorization: {{apiKey}}"
  ],
]);

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/api/v1/id4ns/:id4n/alias/:aliasType', [
  'headers' => [
    'authorization' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/api/v1/id4ns/:id4n/alias/:aliasType');
$request->setMethod(HTTP_METH_DELETE);

$request->setHeaders([
  'authorization' => '{{apiKey}}'
]);

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/api/v1/id4ns/:id4n/alias/:aliasType');
$request->setRequestMethod('DELETE');
$request->setHeaders([
  'authorization' => '{{apiKey}}'
]);

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

echo $response->getBody();
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/api/v1/id4ns/:id4n/alias/:aliasType' -Method DELETE -Headers $headers
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/api/v1/id4ns/:id4n/alias/:aliasType' -Method DELETE -Headers $headers
import http.client

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

headers = { 'authorization': "{{apiKey}}" }

conn.request("DELETE", "/baseUrl/api/v1/id4ns/:id4n/alias/:aliasType", headers=headers)

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

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

url = "{{baseUrl}}/api/v1/id4ns/:id4n/alias/:aliasType"

headers = {"authorization": "{{apiKey}}"}

response = requests.delete(url, headers=headers)

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

url <- "{{baseUrl}}/api/v1/id4ns/:id4n/alias/:aliasType"

response <- VERB("DELETE", url, add_headers('authorization' = '{{apiKey}}'), content_type("application/octet-stream"))

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

url = URI("{{baseUrl}}/api/v1/id4ns/:id4n/alias/:aliasType")

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

request = Net::HTTP::Delete.new(url)
request["authorization"] = '{{apiKey}}'

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

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

response = conn.delete('/baseUrl/api/v1/id4ns/:id4n/alias/:aliasType') do |req|
  req.headers['authorization'] = '{{apiKey}}'
end

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

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/api/v1/id4ns/:id4n/alias/:aliasType";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("authorization", "{{apiKey}}".parse().unwrap());

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

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

    dbg!(results);
}
curl --request DELETE \
  --url {{baseUrl}}/api/v1/id4ns/:id4n/alias/:aliasType \
  --header 'authorization: {{apiKey}}'
http DELETE {{baseUrl}}/api/v1/id4ns/:id4n/alias/:aliasType \
  authorization:'{{apiKey}}'
wget --quiet \
  --method DELETE \
  --header 'authorization: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/api/v1/id4ns/:id4n/alias/:aliasType
import Foundation

let headers = ["authorization": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/api/v1/id4ns/:id4n/alias/:aliasType")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "DELETE"
request.allHTTPHeaderFields = headers

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 Search for GUIDs by alias
{{baseUrl}}/api/v1/search/guids
HEADERS

Authorization
{{apiKey}}
QUERY PARAMS

alias
aliasType
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/api/v1/search/guids?alias=&aliasType=");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "authorization: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

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

(client/get "{{baseUrl}}/api/v1/search/guids" {:headers {:authorization "{{apiKey}}"}
                                                               :query-params {:alias ""
                                                                              :aliasType ""}})
require "http/client"

url = "{{baseUrl}}/api/v1/search/guids?alias=&aliasType="
headers = HTTP::Headers{
  "authorization" => "{{apiKey}}"
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/api/v1/search/guids?alias=&aliasType="),
    Headers =
    {
        { "authorization", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/api/v1/search/guids?alias=&aliasType=");
var request = new RestRequest("", Method.Get);
request.AddHeader("authorization", "{{apiKey}}");
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/api/v1/search/guids?alias=&aliasType="

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

	req.Header.Add("authorization", "{{apiKey}}")

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

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

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

}
GET /baseUrl/api/v1/search/guids?alias=&aliasType= HTTP/1.1
Authorization: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/api/v1/search/guids?alias=&aliasType=")
  .setHeader("authorization", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/api/v1/search/guids?alias=&aliasType="))
    .header("authorization", "{{apiKey}}")
    .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}}/api/v1/search/guids?alias=&aliasType=")
  .get()
  .addHeader("authorization", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/api/v1/search/guids?alias=&aliasType=")
  .header("authorization", "{{apiKey}}")
  .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}}/api/v1/search/guids?alias=&aliasType=');
xhr.setRequestHeader('authorization', '{{apiKey}}');

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/api/v1/search/guids',
  params: {alias: '', aliasType: ''},
  headers: {authorization: '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/api/v1/search/guids?alias=&aliasType=';
const options = {method: 'GET', headers: {authorization: '{{apiKey}}'}};

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}}/api/v1/search/guids?alias=&aliasType=',
  method: 'GET',
  headers: {
    authorization: '{{apiKey}}'
  }
};

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

val request = Request.Builder()
  .url("{{baseUrl}}/api/v1/search/guids?alias=&aliasType=")
  .get()
  .addHeader("authorization", "{{apiKey}}")
  .build()

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

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/api/v1/search/guids?alias=&aliasType=',
  headers: {
    authorization: '{{apiKey}}'
  }
};

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}}/api/v1/search/guids',
  qs: {alias: '', aliasType: ''},
  headers: {authorization: '{{apiKey}}'}
};

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

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

const req = unirest('GET', '{{baseUrl}}/api/v1/search/guids');

req.query({
  alias: '',
  aliasType: ''
});

req.headers({
  authorization: '{{apiKey}}'
});

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}}/api/v1/search/guids',
  params: {alias: '', aliasType: ''},
  headers: {authorization: '{{apiKey}}'}
};

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

const url = '{{baseUrl}}/api/v1/search/guids?alias=&aliasType=';
const options = {method: 'GET', headers: {authorization: '{{apiKey}}'}};

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

NSDictionary *headers = @{ @"authorization": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/api/v1/search/guids?alias=&aliasType="]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

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}}/api/v1/search/guids?alias=&aliasType=" in
let headers = Header.add (Header.init ()) "authorization" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/api/v1/search/guids?alias=&aliasType=",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "authorization: {{apiKey}}"
  ],
]);

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/api/v1/search/guids?alias=&aliasType=', [
  'headers' => [
    'authorization' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/api/v1/search/guids');
$request->setMethod(HTTP_METH_GET);

$request->setQueryData([
  'alias' => '',
  'aliasType' => ''
]);

$request->setHeaders([
  'authorization' => '{{apiKey}}'
]);

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/api/v1/search/guids');
$request->setRequestMethod('GET');
$request->setQuery(new http\QueryString([
  'alias' => '',
  'aliasType' => ''
]));

$request->setHeaders([
  'authorization' => '{{apiKey}}'
]);

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

echo $response->getBody();
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/api/v1/search/guids?alias=&aliasType=' -Method GET -Headers $headers
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/api/v1/search/guids?alias=&aliasType=' -Method GET -Headers $headers
import http.client

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

headers = { 'authorization': "{{apiKey}}" }

conn.request("GET", "/baseUrl/api/v1/search/guids?alias=&aliasType=", headers=headers)

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

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

url = "{{baseUrl}}/api/v1/search/guids"

querystring = {"alias":"","aliasType":""}

headers = {"authorization": "{{apiKey}}"}

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

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

url <- "{{baseUrl}}/api/v1/search/guids"

queryString <- list(
  alias = "",
  aliasType = ""
)

response <- VERB("GET", url, query = queryString, add_headers('authorization' = '{{apiKey}}'), content_type("application/octet-stream"))

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

url = URI("{{baseUrl}}/api/v1/search/guids?alias=&aliasType=")

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

request = Net::HTTP::Get.new(url)
request["authorization"] = '{{apiKey}}'

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

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

response = conn.get('/baseUrl/api/v1/search/guids') do |req|
  req.headers['authorization'] = '{{apiKey}}'
  req.params['alias'] = ''
  req.params['aliasType'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/api/v1/search/guids";

    let querystring = [
        ("alias", ""),
        ("aliasType", ""),
    ];

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("authorization", "{{apiKey}}".parse().unwrap());

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

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

    dbg!(results);
}
curl --request GET \
  --url '{{baseUrl}}/api/v1/search/guids?alias=&aliasType=' \
  --header 'authorization: {{apiKey}}'
http GET '{{baseUrl}}/api/v1/search/guids?alias=&aliasType=' \
  authorization:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'authorization: {{apiKey}}' \
  --output-document \
  - '{{baseUrl}}/api/v1/search/guids?alias=&aliasType='
import Foundation

let headers = ["authorization": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/api/v1/search/guids?alias=&aliasType=")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

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()
RESPONSE HEADERS

Content-Type
application/json
RESPONSE BODY json

{
  "limit": 100,
  "offset": 0,
  "total": 200
}
RESPONSE HEADERS

Content-Type
application/xml
RESPONSE BODY xml

{
  "limit": 100,
  "offset": 0,
  "total": 200
}
POST Add ID4ns of a privilege
{{baseUrl}}/api/v1/apikeys/:key/privileges/:privilege/id4ns
HEADERS

Authorization
{{apiKey}}
QUERY PARAMS

key
privilege
BODY json

{
  "id4ns": []
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/api/v1/apikeys/:key/privileges/:privilege/id4ns");

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

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"id4ns\": []\n}");

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

(client/post "{{baseUrl}}/api/v1/apikeys/:key/privileges/:privilege/id4ns" {:headers {:authorization "{{apiKey}}"}
                                                                                            :content-type :json
                                                                                            :form-params {:id4ns []}})
require "http/client"

url = "{{baseUrl}}/api/v1/apikeys/:key/privileges/:privilege/id4ns"
headers = HTTP::Headers{
  "authorization" => "{{apiKey}}"
  "content-type" => "application/json"
}
reqBody = "{\n  \"id4ns\": []\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}}/api/v1/apikeys/:key/privileges/:privilege/id4ns"),
    Headers =
    {
        { "authorization", "{{apiKey}}" },
    },
    Content = new StringContent("{\n  \"id4ns\": []\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}}/api/v1/apikeys/:key/privileges/:privilege/id4ns");
var request = new RestRequest("", Method.Post);
request.AddHeader("authorization", "{{apiKey}}");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"id4ns\": []\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/api/v1/apikeys/:key/privileges/:privilege/id4ns"

	payload := strings.NewReader("{\n  \"id4ns\": []\n}")

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

	req.Header.Add("authorization", "{{apiKey}}")
	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/api/v1/apikeys/:key/privileges/:privilege/id4ns HTTP/1.1
Authorization: {{apiKey}}
Content-Type: application/json
Host: example.com
Content-Length: 17

{
  "id4ns": []
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/api/v1/apikeys/:key/privileges/:privilege/id4ns")
  .setHeader("authorization", "{{apiKey}}")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"id4ns\": []\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/api/v1/apikeys/:key/privileges/:privilege/id4ns"))
    .header("authorization", "{{apiKey}}")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"id4ns\": []\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  \"id4ns\": []\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/api/v1/apikeys/:key/privileges/:privilege/id4ns")
  .post(body)
  .addHeader("authorization", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/api/v1/apikeys/:key/privileges/:privilege/id4ns")
  .header("authorization", "{{apiKey}}")
  .header("content-type", "application/json")
  .body("{\n  \"id4ns\": []\n}")
  .asString();
const data = JSON.stringify({
  id4ns: []
});

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

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

xhr.open('POST', '{{baseUrl}}/api/v1/apikeys/:key/privileges/:privilege/id4ns');
xhr.setRequestHeader('authorization', '{{apiKey}}');
xhr.setRequestHeader('content-type', 'application/json');

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/api/v1/apikeys/:key/privileges/:privilege/id4ns',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  data: {id4ns: []}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/api/v1/apikeys/:key/privileges/:privilege/id4ns';
const options = {
  method: 'POST',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"id4ns":[]}'
};

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}}/api/v1/apikeys/:key/privileges/:privilege/id4ns',
  method: 'POST',
  headers: {
    authorization: '{{apiKey}}',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "id4ns": []\n}'
};

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

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"id4ns\": []\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/api/v1/apikeys/:key/privileges/:privilege/id4ns")
  .post(body)
  .addHeader("authorization", "{{apiKey}}")
  .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/api/v1/apikeys/:key/privileges/:privilege/id4ns',
  headers: {
    authorization: '{{apiKey}}',
    '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({id4ns: []}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/api/v1/apikeys/:key/privileges/:privilege/id4ns',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  body: {id4ns: []},
  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}}/api/v1/apikeys/:key/privileges/:privilege/id4ns');

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

req.type('json');
req.send({
  id4ns: []
});

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}}/api/v1/apikeys/:key/privileges/:privilege/id4ns',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  data: {id4ns: []}
};

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

const url = '{{baseUrl}}/api/v1/apikeys/:key/privileges/:privilege/id4ns';
const options = {
  method: 'POST',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"id4ns":[]}'
};

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

NSDictionary *headers = @{ @"authorization": @"{{apiKey}}",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"id4ns": @[  ] };

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/api/v1/apikeys/:key/privileges/:privilege/id4ns"]
                                                       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}}/api/v1/apikeys/:key/privileges/:privilege/id4ns" in
let headers = Header.add_list (Header.init ()) [
  ("authorization", "{{apiKey}}");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"id4ns\": []\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/api/v1/apikeys/:key/privileges/:privilege/id4ns",
  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([
    'id4ns' => [
        
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "authorization: {{apiKey}}",
    "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}}/api/v1/apikeys/:key/privileges/:privilege/id4ns', [
  'body' => '{
  "id4ns": []
}',
  'headers' => [
    'authorization' => '{{apiKey}}',
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/api/v1/apikeys/:key/privileges/:privilege/id4ns');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'authorization' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'id4ns' => [
    
  ]
]));

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'id4ns' => [
    
  ]
]));
$request->setRequestUrl('{{baseUrl}}/api/v1/apikeys/:key/privileges/:privilege/id4ns');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'authorization' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

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

echo $response->getBody();
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/api/v1/apikeys/:key/privileges/:privilege/id4ns' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "id4ns": []
}'
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/api/v1/apikeys/:key/privileges/:privilege/id4ns' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "id4ns": []
}'
import http.client

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

payload = "{\n  \"id4ns\": []\n}"

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

conn.request("POST", "/baseUrl/api/v1/apikeys/:key/privileges/:privilege/id4ns", payload, headers)

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

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

url = "{{baseUrl}}/api/v1/apikeys/:key/privileges/:privilege/id4ns"

payload = { "id4ns": [] }
headers = {
    "authorization": "{{apiKey}}",
    "content-type": "application/json"
}

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

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

url <- "{{baseUrl}}/api/v1/apikeys/:key/privileges/:privilege/id4ns"

payload <- "{\n  \"id4ns\": []\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('authorization' = '{{apiKey}}'), content_type("application/json"), encode = encode)

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

url = URI("{{baseUrl}}/api/v1/apikeys/:key/privileges/:privilege/id4ns")

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

request = Net::HTTP::Post.new(url)
request["authorization"] = '{{apiKey}}'
request["content-type"] = 'application/json'
request.body = "{\n  \"id4ns\": []\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/api/v1/apikeys/:key/privileges/:privilege/id4ns') do |req|
  req.headers['authorization'] = '{{apiKey}}'
  req.body = "{\n  \"id4ns\": []\n}"
end

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

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/api/v1/apikeys/:key/privileges/:privilege/id4ns";

    let payload = json!({"id4ns": ()});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("authorization", "{{apiKey}}".parse().unwrap());
    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}}/api/v1/apikeys/:key/privileges/:privilege/id4ns \
  --header 'authorization: {{apiKey}}' \
  --header 'content-type: application/json' \
  --data '{
  "id4ns": []
}'
echo '{
  "id4ns": []
}' |  \
  http POST {{baseUrl}}/api/v1/apikeys/:key/privileges/:privilege/id4ns \
  authorization:'{{apiKey}}' \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'authorization: {{apiKey}}' \
  --header 'content-type: application/json' \
  --body-data '{\n  "id4ns": []\n}' \
  --output-document \
  - {{baseUrl}}/api/v1/apikeys/:key/privileges/:privilege/id4ns
import Foundation

let headers = [
  "authorization": "{{apiKey}}",
  "content-type": "application/json"
]
let parameters = ["id4ns": []] as [String : Any]

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

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/api/v1/apikeys/:key/privileges/:privilege/id4ns")! 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 Add privilege
{{baseUrl}}/api/v1/apikeys/:key/privileges
HEADERS

Authorization
{{apiKey}}
QUERY PARAMS

key
BODY json

{
  "privilege": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/api/v1/apikeys/:key/privileges");

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

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"privilege\": \"\"\n}");

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

(client/post "{{baseUrl}}/api/v1/apikeys/:key/privileges" {:headers {:authorization "{{apiKey}}"}
                                                                           :content-type :json
                                                                           :form-params {:privilege ""}})
require "http/client"

url = "{{baseUrl}}/api/v1/apikeys/:key/privileges"
headers = HTTP::Headers{
  "authorization" => "{{apiKey}}"
  "content-type" => "application/json"
}
reqBody = "{\n  \"privilege\": \"\"\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}}/api/v1/apikeys/:key/privileges"),
    Headers =
    {
        { "authorization", "{{apiKey}}" },
    },
    Content = new StringContent("{\n  \"privilege\": \"\"\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}}/api/v1/apikeys/:key/privileges");
var request = new RestRequest("", Method.Post);
request.AddHeader("authorization", "{{apiKey}}");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"privilege\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/api/v1/apikeys/:key/privileges"

	payload := strings.NewReader("{\n  \"privilege\": \"\"\n}")

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

	req.Header.Add("authorization", "{{apiKey}}")
	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/api/v1/apikeys/:key/privileges HTTP/1.1
Authorization: {{apiKey}}
Content-Type: application/json
Host: example.com
Content-Length: 21

{
  "privilege": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/api/v1/apikeys/:key/privileges")
  .setHeader("authorization", "{{apiKey}}")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"privilege\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/api/v1/apikeys/:key/privileges"))
    .header("authorization", "{{apiKey}}")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"privilege\": \"\"\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  \"privilege\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/api/v1/apikeys/:key/privileges")
  .post(body)
  .addHeader("authorization", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/api/v1/apikeys/:key/privileges")
  .header("authorization", "{{apiKey}}")
  .header("content-type", "application/json")
  .body("{\n  \"privilege\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  privilege: ''
});

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

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

xhr.open('POST', '{{baseUrl}}/api/v1/apikeys/:key/privileges');
xhr.setRequestHeader('authorization', '{{apiKey}}');
xhr.setRequestHeader('content-type', 'application/json');

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/api/v1/apikeys/:key/privileges',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  data: {privilege: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/api/v1/apikeys/:key/privileges';
const options = {
  method: 'POST',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"privilege":""}'
};

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}}/api/v1/apikeys/:key/privileges',
  method: 'POST',
  headers: {
    authorization: '{{apiKey}}',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "privilege": ""\n}'
};

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

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"privilege\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/api/v1/apikeys/:key/privileges")
  .post(body)
  .addHeader("authorization", "{{apiKey}}")
  .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/api/v1/apikeys/:key/privileges',
  headers: {
    authorization: '{{apiKey}}',
    '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({privilege: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/api/v1/apikeys/:key/privileges',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  body: {privilege: ''},
  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}}/api/v1/apikeys/:key/privileges');

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

req.type('json');
req.send({
  privilege: ''
});

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}}/api/v1/apikeys/:key/privileges',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  data: {privilege: ''}
};

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

const url = '{{baseUrl}}/api/v1/apikeys/:key/privileges';
const options = {
  method: 'POST',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"privilege":""}'
};

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

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

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/api/v1/apikeys/:key/privileges"]
                                                       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}}/api/v1/apikeys/:key/privileges" in
let headers = Header.add_list (Header.init ()) [
  ("authorization", "{{apiKey}}");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"privilege\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/api/v1/apikeys/:key/privileges",
  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([
    'privilege' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "authorization: {{apiKey}}",
    "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}}/api/v1/apikeys/:key/privileges', [
  'body' => '{
  "privilege": ""
}',
  'headers' => [
    'authorization' => '{{apiKey}}',
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/api/v1/apikeys/:key/privileges');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'authorization' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'privilege' => ''
]));

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'privilege' => ''
]));
$request->setRequestUrl('{{baseUrl}}/api/v1/apikeys/:key/privileges');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'authorization' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

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

echo $response->getBody();
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/api/v1/apikeys/:key/privileges' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "privilege": ""
}'
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/api/v1/apikeys/:key/privileges' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "privilege": ""
}'
import http.client

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

payload = "{\n  \"privilege\": \"\"\n}"

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

conn.request("POST", "/baseUrl/api/v1/apikeys/:key/privileges", payload, headers)

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

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

url = "{{baseUrl}}/api/v1/apikeys/:key/privileges"

payload = { "privilege": "" }
headers = {
    "authorization": "{{apiKey}}",
    "content-type": "application/json"
}

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

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

url <- "{{baseUrl}}/api/v1/apikeys/:key/privileges"

payload <- "{\n  \"privilege\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('authorization' = '{{apiKey}}'), content_type("application/json"), encode = encode)

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

url = URI("{{baseUrl}}/api/v1/apikeys/:key/privileges")

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

request = Net::HTTP::Post.new(url)
request["authorization"] = '{{apiKey}}'
request["content-type"] = 'application/json'
request.body = "{\n  \"privilege\": \"\"\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/api/v1/apikeys/:key/privileges') do |req|
  req.headers['authorization'] = '{{apiKey}}'
  req.body = "{\n  \"privilege\": \"\"\n}"
end

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

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/api/v1/apikeys/:key/privileges";

    let payload = json!({"privilege": ""});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("authorization", "{{apiKey}}".parse().unwrap());
    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}}/api/v1/apikeys/:key/privileges \
  --header 'authorization: {{apiKey}}' \
  --header 'content-type: application/json' \
  --data '{
  "privilege": ""
}'
echo '{
  "privilege": ""
}' |  \
  http POST {{baseUrl}}/api/v1/apikeys/:key/privileges \
  authorization:'{{apiKey}}' \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'authorization: {{apiKey}}' \
  --header 'content-type: application/json' \
  --body-data '{\n  "privilege": ""\n}' \
  --output-document \
  - {{baseUrl}}/api/v1/apikeys/:key/privileges
import Foundation

let headers = [
  "authorization": "{{apiKey}}",
  "content-type": "application/json"
]
let parameters = ["privilege": ""] as [String : Any]

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

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/api/v1/apikeys/:key/privileges")! 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 Create API key
{{baseUrl}}/api/v1/apikeys
HEADERS

Authorization
{{apiKey}}
BODY json

{
  "label": "",
  "organizationId": "",
  "secret": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/api/v1/apikeys");

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

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"label\": \"\",\n  \"organizationId\": \"\",\n  \"secret\": \"\"\n}");

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

(client/post "{{baseUrl}}/api/v1/apikeys" {:headers {:authorization "{{apiKey}}"}
                                                           :content-type :json
                                                           :form-params {:label ""
                                                                         :organizationId ""
                                                                         :secret ""}})
require "http/client"

url = "{{baseUrl}}/api/v1/apikeys"
headers = HTTP::Headers{
  "authorization" => "{{apiKey}}"
  "content-type" => "application/json"
}
reqBody = "{\n  \"label\": \"\",\n  \"organizationId\": \"\",\n  \"secret\": \"\"\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}}/api/v1/apikeys"),
    Headers =
    {
        { "authorization", "{{apiKey}}" },
    },
    Content = new StringContent("{\n  \"label\": \"\",\n  \"organizationId\": \"\",\n  \"secret\": \"\"\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}}/api/v1/apikeys");
var request = new RestRequest("", Method.Post);
request.AddHeader("authorization", "{{apiKey}}");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"label\": \"\",\n  \"organizationId\": \"\",\n  \"secret\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/api/v1/apikeys"

	payload := strings.NewReader("{\n  \"label\": \"\",\n  \"organizationId\": \"\",\n  \"secret\": \"\"\n}")

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

	req.Header.Add("authorization", "{{apiKey}}")
	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/api/v1/apikeys HTTP/1.1
Authorization: {{apiKey}}
Content-Type: application/json
Host: example.com
Content-Length: 57

{
  "label": "",
  "organizationId": "",
  "secret": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/api/v1/apikeys")
  .setHeader("authorization", "{{apiKey}}")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"label\": \"\",\n  \"organizationId\": \"\",\n  \"secret\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/api/v1/apikeys"))
    .header("authorization", "{{apiKey}}")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"label\": \"\",\n  \"organizationId\": \"\",\n  \"secret\": \"\"\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  \"label\": \"\",\n  \"organizationId\": \"\",\n  \"secret\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/api/v1/apikeys")
  .post(body)
  .addHeader("authorization", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/api/v1/apikeys")
  .header("authorization", "{{apiKey}}")
  .header("content-type", "application/json")
  .body("{\n  \"label\": \"\",\n  \"organizationId\": \"\",\n  \"secret\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  label: '',
  organizationId: '',
  secret: ''
});

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

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

xhr.open('POST', '{{baseUrl}}/api/v1/apikeys');
xhr.setRequestHeader('authorization', '{{apiKey}}');
xhr.setRequestHeader('content-type', 'application/json');

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/api/v1/apikeys',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  data: {label: '', organizationId: '', secret: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/api/v1/apikeys';
const options = {
  method: 'POST',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"label":"","organizationId":"","secret":""}'
};

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}}/api/v1/apikeys',
  method: 'POST',
  headers: {
    authorization: '{{apiKey}}',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "label": "",\n  "organizationId": "",\n  "secret": ""\n}'
};

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

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"label\": \"\",\n  \"organizationId\": \"\",\n  \"secret\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/api/v1/apikeys")
  .post(body)
  .addHeader("authorization", "{{apiKey}}")
  .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/api/v1/apikeys',
  headers: {
    authorization: '{{apiKey}}',
    '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({label: '', organizationId: '', secret: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/api/v1/apikeys',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  body: {label: '', organizationId: '', secret: ''},
  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}}/api/v1/apikeys');

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

req.type('json');
req.send({
  label: '',
  organizationId: '',
  secret: ''
});

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}}/api/v1/apikeys',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  data: {label: '', organizationId: '', secret: ''}
};

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

const url = '{{baseUrl}}/api/v1/apikeys';
const options = {
  method: 'POST',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"label":"","organizationId":"","secret":""}'
};

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

NSDictionary *headers = @{ @"authorization": @"{{apiKey}}",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"label": @"",
                              @"organizationId": @"",
                              @"secret": @"" };

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/api/v1/apikeys"]
                                                       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}}/api/v1/apikeys" in
let headers = Header.add_list (Header.init ()) [
  ("authorization", "{{apiKey}}");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"label\": \"\",\n  \"organizationId\": \"\",\n  \"secret\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/api/v1/apikeys",
  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([
    'label' => '',
    'organizationId' => '',
    'secret' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "authorization: {{apiKey}}",
    "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}}/api/v1/apikeys', [
  'body' => '{
  "label": "",
  "organizationId": "",
  "secret": ""
}',
  'headers' => [
    'authorization' => '{{apiKey}}',
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/api/v1/apikeys');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'authorization' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'label' => '',
  'organizationId' => '',
  'secret' => ''
]));

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'label' => '',
  'organizationId' => '',
  'secret' => ''
]));
$request->setRequestUrl('{{baseUrl}}/api/v1/apikeys');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'authorization' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

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

echo $response->getBody();
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/api/v1/apikeys' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "label": "",
  "organizationId": "",
  "secret": ""
}'
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/api/v1/apikeys' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "label": "",
  "organizationId": "",
  "secret": ""
}'
import http.client

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

payload = "{\n  \"label\": \"\",\n  \"organizationId\": \"\",\n  \"secret\": \"\"\n}"

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

conn.request("POST", "/baseUrl/api/v1/apikeys", payload, headers)

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

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

url = "{{baseUrl}}/api/v1/apikeys"

payload = {
    "label": "",
    "organizationId": "",
    "secret": ""
}
headers = {
    "authorization": "{{apiKey}}",
    "content-type": "application/json"
}

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

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

url <- "{{baseUrl}}/api/v1/apikeys"

payload <- "{\n  \"label\": \"\",\n  \"organizationId\": \"\",\n  \"secret\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('authorization' = '{{apiKey}}'), content_type("application/json"), encode = encode)

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

url = URI("{{baseUrl}}/api/v1/apikeys")

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

request = Net::HTTP::Post.new(url)
request["authorization"] = '{{apiKey}}'
request["content-type"] = 'application/json'
request.body = "{\n  \"label\": \"\",\n  \"organizationId\": \"\",\n  \"secret\": \"\"\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/api/v1/apikeys') do |req|
  req.headers['authorization'] = '{{apiKey}}'
  req.body = "{\n  \"label\": \"\",\n  \"organizationId\": \"\",\n  \"secret\": \"\"\n}"
end

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

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

    let payload = json!({
        "label": "",
        "organizationId": "",
        "secret": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("authorization", "{{apiKey}}".parse().unwrap());
    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}}/api/v1/apikeys \
  --header 'authorization: {{apiKey}}' \
  --header 'content-type: application/json' \
  --data '{
  "label": "",
  "organizationId": "",
  "secret": ""
}'
echo '{
  "label": "",
  "organizationId": "",
  "secret": ""
}' |  \
  http POST {{baseUrl}}/api/v1/apikeys \
  authorization:'{{apiKey}}' \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'authorization: {{apiKey}}' \
  --header 'content-type: application/json' \
  --body-data '{\n  "label": "",\n  "organizationId": "",\n  "secret": ""\n}' \
  --output-document \
  - {{baseUrl}}/api/v1/apikeys
import Foundation

let headers = [
  "authorization": "{{apiKey}}",
  "content-type": "application/json"
]
let parameters = [
  "label": "",
  "organizationId": "",
  "secret": ""
] as [String : Any]

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

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/api/v1/apikeys")! 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()
RESPONSE HEADERS

Content-Type
application/json
RESPONSE BODY json

{
  "active": true,
  "createdAt": 1517232722,
  "createdBy": "user123",
  "key": "39978f49-6ff1-4147-bf0f-9910185084b7",
  "label": "My Api Key",
  "organizationId": "de.acme"
}
RESPONSE HEADERS

Content-Type
application/xml
RESPONSE BODY xml

{
  "active": true,
  "createdAt": 1517232722,
  "createdBy": "user123",
  "key": "39978f49-6ff1-4147-bf0f-9910185084b7",
  "label": "My Api Key",
  "organizationId": "de.acme"
}
DELETE Delete API key
{{baseUrl}}/api/v1/apikeys/:key
HEADERS

Authorization
{{apiKey}}
QUERY PARAMS

key
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/api/v1/apikeys/:key");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "authorization: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

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

(client/delete "{{baseUrl}}/api/v1/apikeys/:key" {:headers {:authorization "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/api/v1/apikeys/:key"
headers = HTTP::Headers{
  "authorization" => "{{apiKey}}"
}

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

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

func main() {

	url := "{{baseUrl}}/api/v1/apikeys/:key"

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

	req.Header.Add("authorization", "{{apiKey}}")

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

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

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

}
DELETE /baseUrl/api/v1/apikeys/:key HTTP/1.1
Authorization: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/api/v1/apikeys/:key")
  .setHeader("authorization", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/api/v1/apikeys/:key"))
    .header("authorization", "{{apiKey}}")
    .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}}/api/v1/apikeys/:key")
  .delete(null)
  .addHeader("authorization", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/api/v1/apikeys/:key")
  .header("authorization", "{{apiKey}}")
  .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}}/api/v1/apikeys/:key');
xhr.setRequestHeader('authorization', '{{apiKey}}');

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

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/api/v1/apikeys/:key',
  headers: {authorization: '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/api/v1/apikeys/:key';
const options = {method: 'DELETE', headers: {authorization: '{{apiKey}}'}};

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}}/api/v1/apikeys/:key',
  method: 'DELETE',
  headers: {
    authorization: '{{apiKey}}'
  }
};

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

val request = Request.Builder()
  .url("{{baseUrl}}/api/v1/apikeys/:key")
  .delete(null)
  .addHeader("authorization", "{{apiKey}}")
  .build()

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

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/api/v1/apikeys/:key',
  headers: {
    authorization: '{{apiKey}}'
  }
};

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}}/api/v1/apikeys/:key',
  headers: {authorization: '{{apiKey}}'}
};

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

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

const req = unirest('DELETE', '{{baseUrl}}/api/v1/apikeys/:key');

req.headers({
  authorization: '{{apiKey}}'
});

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}}/api/v1/apikeys/:key',
  headers: {authorization: '{{apiKey}}'}
};

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

const url = '{{baseUrl}}/api/v1/apikeys/:key';
const options = {method: 'DELETE', headers: {authorization: '{{apiKey}}'}};

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

NSDictionary *headers = @{ @"authorization": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/api/v1/apikeys/:key"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"DELETE"];
[request setAllHTTPHeaderFields:headers];

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}}/api/v1/apikeys/:key" in
let headers = Header.add (Header.init ()) "authorization" "{{apiKey}}" in

Client.call ~headers `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/api/v1/apikeys/:key",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
  CURLOPT_HTTPHEADER => [
    "authorization: {{apiKey}}"
  ],
]);

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/api/v1/apikeys/:key', [
  'headers' => [
    'authorization' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/api/v1/apikeys/:key');
$request->setMethod(HTTP_METH_DELETE);

$request->setHeaders([
  'authorization' => '{{apiKey}}'
]);

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/api/v1/apikeys/:key');
$request->setRequestMethod('DELETE');
$request->setHeaders([
  'authorization' => '{{apiKey}}'
]);

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

echo $response->getBody();
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/api/v1/apikeys/:key' -Method DELETE -Headers $headers
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/api/v1/apikeys/:key' -Method DELETE -Headers $headers
import http.client

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

headers = { 'authorization': "{{apiKey}}" }

conn.request("DELETE", "/baseUrl/api/v1/apikeys/:key", headers=headers)

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

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

url = "{{baseUrl}}/api/v1/apikeys/:key"

headers = {"authorization": "{{apiKey}}"}

response = requests.delete(url, headers=headers)

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

url <- "{{baseUrl}}/api/v1/apikeys/:key"

response <- VERB("DELETE", url, add_headers('authorization' = '{{apiKey}}'), content_type("application/octet-stream"))

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

url = URI("{{baseUrl}}/api/v1/apikeys/:key")

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

request = Net::HTTP::Delete.new(url)
request["authorization"] = '{{apiKey}}'

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

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

response = conn.delete('/baseUrl/api/v1/apikeys/:key') do |req|
  req.headers['authorization'] = '{{apiKey}}'
end

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

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/api/v1/apikeys/:key";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("authorization", "{{apiKey}}".parse().unwrap());

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

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

    dbg!(results);
}
curl --request DELETE \
  --url {{baseUrl}}/api/v1/apikeys/:key \
  --header 'authorization: {{apiKey}}'
http DELETE {{baseUrl}}/api/v1/apikeys/:key \
  authorization:'{{apiKey}}'
wget --quiet \
  --method DELETE \
  --header 'authorization: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/api/v1/apikeys/:key
import Foundation

let headers = ["authorization": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/api/v1/apikeys/:key")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "DELETE"
request.allHTTPHeaderFields = headers

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 Find API key by organization
{{baseUrl}}/api/v1/apikeys
HEADERS

Authorization
{{apiKey}}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/api/v1/apikeys");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "authorization: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

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

(client/get "{{baseUrl}}/api/v1/apikeys" {:headers {:authorization "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/api/v1/apikeys"
headers = HTTP::Headers{
  "authorization" => "{{apiKey}}"
}

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

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

func main() {

	url := "{{baseUrl}}/api/v1/apikeys"

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

	req.Header.Add("authorization", "{{apiKey}}")

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

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

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

}
GET /baseUrl/api/v1/apikeys HTTP/1.1
Authorization: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/api/v1/apikeys")
  .setHeader("authorization", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/api/v1/apikeys"))
    .header("authorization", "{{apiKey}}")
    .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}}/api/v1/apikeys")
  .get()
  .addHeader("authorization", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/api/v1/apikeys")
  .header("authorization", "{{apiKey}}")
  .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}}/api/v1/apikeys');
xhr.setRequestHeader('authorization', '{{apiKey}}');

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/api/v1/apikeys',
  headers: {authorization: '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/api/v1/apikeys';
const options = {method: 'GET', headers: {authorization: '{{apiKey}}'}};

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}}/api/v1/apikeys',
  method: 'GET',
  headers: {
    authorization: '{{apiKey}}'
  }
};

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

val request = Request.Builder()
  .url("{{baseUrl}}/api/v1/apikeys")
  .get()
  .addHeader("authorization", "{{apiKey}}")
  .build()

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

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/api/v1/apikeys',
  headers: {
    authorization: '{{apiKey}}'
  }
};

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}}/api/v1/apikeys',
  headers: {authorization: '{{apiKey}}'}
};

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

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

const req = unirest('GET', '{{baseUrl}}/api/v1/apikeys');

req.headers({
  authorization: '{{apiKey}}'
});

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}}/api/v1/apikeys',
  headers: {authorization: '{{apiKey}}'}
};

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

const url = '{{baseUrl}}/api/v1/apikeys';
const options = {method: 'GET', headers: {authorization: '{{apiKey}}'}};

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

NSDictionary *headers = @{ @"authorization": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/api/v1/apikeys"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

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}}/api/v1/apikeys" in
let headers = Header.add (Header.init ()) "authorization" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/api/v1/apikeys",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "authorization: {{apiKey}}"
  ],
]);

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/api/v1/apikeys', [
  'headers' => [
    'authorization' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/api/v1/apikeys');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'authorization' => '{{apiKey}}'
]);

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/api/v1/apikeys');
$request->setRequestMethod('GET');
$request->setHeaders([
  'authorization' => '{{apiKey}}'
]);

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

echo $response->getBody();
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/api/v1/apikeys' -Method GET -Headers $headers
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/api/v1/apikeys' -Method GET -Headers $headers
import http.client

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

headers = { 'authorization': "{{apiKey}}" }

conn.request("GET", "/baseUrl/api/v1/apikeys", headers=headers)

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

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

url = "{{baseUrl}}/api/v1/apikeys"

headers = {"authorization": "{{apiKey}}"}

response = requests.get(url, headers=headers)

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

url <- "{{baseUrl}}/api/v1/apikeys"

response <- VERB("GET", url, add_headers('authorization' = '{{apiKey}}'), content_type("application/octet-stream"))

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

url = URI("{{baseUrl}}/api/v1/apikeys")

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

request = Net::HTTP::Get.new(url)
request["authorization"] = '{{apiKey}}'

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

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

response = conn.get('/baseUrl/api/v1/apikeys') do |req|
  req.headers['authorization'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

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

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("authorization", "{{apiKey}}".parse().unwrap());

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

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

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/api/v1/apikeys \
  --header 'authorization: {{apiKey}}'
http GET {{baseUrl}}/api/v1/apikeys \
  authorization:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'authorization: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/api/v1/apikeys
import Foundation

let headers = ["authorization": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/api/v1/apikeys")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

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()
RESPONSE HEADERS

Content-Type
application/json
RESPONSE BODY json

{
  "limit": 100,
  "offset": 0,
  "total": 200
}
RESPONSE HEADERS

Content-Type
application/xml
RESPONSE BODY xml

{
  "limit": 100,
  "offset": 0,
  "total": 200
}
GET ID4ns of a privilege
{{baseUrl}}/api/v1/apikeys/:key/privileges/:privilege/id4ns
HEADERS

Authorization
{{apiKey}}
QUERY PARAMS

key
privilege
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/api/v1/apikeys/:key/privileges/:privilege/id4ns");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "authorization: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

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

(client/get "{{baseUrl}}/api/v1/apikeys/:key/privileges/:privilege/id4ns" {:headers {:authorization "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/api/v1/apikeys/:key/privileges/:privilege/id4ns"
headers = HTTP::Headers{
  "authorization" => "{{apiKey}}"
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/api/v1/apikeys/:key/privileges/:privilege/id4ns"),
    Headers =
    {
        { "authorization", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/api/v1/apikeys/:key/privileges/:privilege/id4ns");
var request = new RestRequest("", Method.Get);
request.AddHeader("authorization", "{{apiKey}}");
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/api/v1/apikeys/:key/privileges/:privilege/id4ns"

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

	req.Header.Add("authorization", "{{apiKey}}")

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

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

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

}
GET /baseUrl/api/v1/apikeys/:key/privileges/:privilege/id4ns HTTP/1.1
Authorization: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/api/v1/apikeys/:key/privileges/:privilege/id4ns")
  .setHeader("authorization", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/api/v1/apikeys/:key/privileges/:privilege/id4ns"))
    .header("authorization", "{{apiKey}}")
    .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}}/api/v1/apikeys/:key/privileges/:privilege/id4ns")
  .get()
  .addHeader("authorization", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/api/v1/apikeys/:key/privileges/:privilege/id4ns")
  .header("authorization", "{{apiKey}}")
  .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}}/api/v1/apikeys/:key/privileges/:privilege/id4ns');
xhr.setRequestHeader('authorization', '{{apiKey}}');

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/api/v1/apikeys/:key/privileges/:privilege/id4ns',
  headers: {authorization: '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/api/v1/apikeys/:key/privileges/:privilege/id4ns';
const options = {method: 'GET', headers: {authorization: '{{apiKey}}'}};

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}}/api/v1/apikeys/:key/privileges/:privilege/id4ns',
  method: 'GET',
  headers: {
    authorization: '{{apiKey}}'
  }
};

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

val request = Request.Builder()
  .url("{{baseUrl}}/api/v1/apikeys/:key/privileges/:privilege/id4ns")
  .get()
  .addHeader("authorization", "{{apiKey}}")
  .build()

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

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/api/v1/apikeys/:key/privileges/:privilege/id4ns',
  headers: {
    authorization: '{{apiKey}}'
  }
};

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}}/api/v1/apikeys/:key/privileges/:privilege/id4ns',
  headers: {authorization: '{{apiKey}}'}
};

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

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

const req = unirest('GET', '{{baseUrl}}/api/v1/apikeys/:key/privileges/:privilege/id4ns');

req.headers({
  authorization: '{{apiKey}}'
});

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}}/api/v1/apikeys/:key/privileges/:privilege/id4ns',
  headers: {authorization: '{{apiKey}}'}
};

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

const url = '{{baseUrl}}/api/v1/apikeys/:key/privileges/:privilege/id4ns';
const options = {method: 'GET', headers: {authorization: '{{apiKey}}'}};

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

NSDictionary *headers = @{ @"authorization": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/api/v1/apikeys/:key/privileges/:privilege/id4ns"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

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}}/api/v1/apikeys/:key/privileges/:privilege/id4ns" in
let headers = Header.add (Header.init ()) "authorization" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/api/v1/apikeys/:key/privileges/:privilege/id4ns",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "authorization: {{apiKey}}"
  ],
]);

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/api/v1/apikeys/:key/privileges/:privilege/id4ns', [
  'headers' => [
    'authorization' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/api/v1/apikeys/:key/privileges/:privilege/id4ns');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'authorization' => '{{apiKey}}'
]);

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/api/v1/apikeys/:key/privileges/:privilege/id4ns');
$request->setRequestMethod('GET');
$request->setHeaders([
  'authorization' => '{{apiKey}}'
]);

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

echo $response->getBody();
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/api/v1/apikeys/:key/privileges/:privilege/id4ns' -Method GET -Headers $headers
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/api/v1/apikeys/:key/privileges/:privilege/id4ns' -Method GET -Headers $headers
import http.client

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

headers = { 'authorization': "{{apiKey}}" }

conn.request("GET", "/baseUrl/api/v1/apikeys/:key/privileges/:privilege/id4ns", headers=headers)

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

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

url = "{{baseUrl}}/api/v1/apikeys/:key/privileges/:privilege/id4ns"

headers = {"authorization": "{{apiKey}}"}

response = requests.get(url, headers=headers)

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

url <- "{{baseUrl}}/api/v1/apikeys/:key/privileges/:privilege/id4ns"

response <- VERB("GET", url, add_headers('authorization' = '{{apiKey}}'), content_type("application/octet-stream"))

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

url = URI("{{baseUrl}}/api/v1/apikeys/:key/privileges/:privilege/id4ns")

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

request = Net::HTTP::Get.new(url)
request["authorization"] = '{{apiKey}}'

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

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

response = conn.get('/baseUrl/api/v1/apikeys/:key/privileges/:privilege/id4ns') do |req|
  req.headers['authorization'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/api/v1/apikeys/:key/privileges/:privilege/id4ns";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("authorization", "{{apiKey}}".parse().unwrap());

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

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

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/api/v1/apikeys/:key/privileges/:privilege/id4ns \
  --header 'authorization: {{apiKey}}'
http GET {{baseUrl}}/api/v1/apikeys/:key/privileges/:privilege/id4ns \
  authorization:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'authorization: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/api/v1/apikeys/:key/privileges/:privilege/id4ns
import Foundation

let headers = ["authorization": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/api/v1/apikeys/:key/privileges/:privilege/id4ns")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

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()
RESPONSE HEADERS

Content-Type
application/json
RESPONSE BODY json

{
  "limit": 100,
  "offset": 0,
  "total": 200
}
RESPONSE HEADERS

Content-Type
application/xml
RESPONSE BODY xml

{
  "limit": 100,
  "offset": 0,
  "total": 200
}
GET List all privileges
{{baseUrl}}/api/v1/apikeys/privileges
HEADERS

Authorization
{{apiKey}}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/api/v1/apikeys/privileges");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "authorization: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

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

(client/get "{{baseUrl}}/api/v1/apikeys/privileges" {:headers {:authorization "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/api/v1/apikeys/privileges"
headers = HTTP::Headers{
  "authorization" => "{{apiKey}}"
}

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

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

func main() {

	url := "{{baseUrl}}/api/v1/apikeys/privileges"

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

	req.Header.Add("authorization", "{{apiKey}}")

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

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

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

}
GET /baseUrl/api/v1/apikeys/privileges HTTP/1.1
Authorization: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/api/v1/apikeys/privileges")
  .setHeader("authorization", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/api/v1/apikeys/privileges"))
    .header("authorization", "{{apiKey}}")
    .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}}/api/v1/apikeys/privileges")
  .get()
  .addHeader("authorization", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/api/v1/apikeys/privileges")
  .header("authorization", "{{apiKey}}")
  .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}}/api/v1/apikeys/privileges');
xhr.setRequestHeader('authorization', '{{apiKey}}');

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/api/v1/apikeys/privileges',
  headers: {authorization: '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/api/v1/apikeys/privileges';
const options = {method: 'GET', headers: {authorization: '{{apiKey}}'}};

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}}/api/v1/apikeys/privileges',
  method: 'GET',
  headers: {
    authorization: '{{apiKey}}'
  }
};

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

val request = Request.Builder()
  .url("{{baseUrl}}/api/v1/apikeys/privileges")
  .get()
  .addHeader("authorization", "{{apiKey}}")
  .build()

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

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/api/v1/apikeys/privileges',
  headers: {
    authorization: '{{apiKey}}'
  }
};

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}}/api/v1/apikeys/privileges',
  headers: {authorization: '{{apiKey}}'}
};

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

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

const req = unirest('GET', '{{baseUrl}}/api/v1/apikeys/privileges');

req.headers({
  authorization: '{{apiKey}}'
});

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}}/api/v1/apikeys/privileges',
  headers: {authorization: '{{apiKey}}'}
};

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

const url = '{{baseUrl}}/api/v1/apikeys/privileges';
const options = {method: 'GET', headers: {authorization: '{{apiKey}}'}};

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

NSDictionary *headers = @{ @"authorization": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/api/v1/apikeys/privileges"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

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}}/api/v1/apikeys/privileges" in
let headers = Header.add (Header.init ()) "authorization" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/api/v1/apikeys/privileges",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "authorization: {{apiKey}}"
  ],
]);

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/api/v1/apikeys/privileges', [
  'headers' => [
    'authorization' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/api/v1/apikeys/privileges');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'authorization' => '{{apiKey}}'
]);

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/api/v1/apikeys/privileges');
$request->setRequestMethod('GET');
$request->setHeaders([
  'authorization' => '{{apiKey}}'
]);

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

echo $response->getBody();
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/api/v1/apikeys/privileges' -Method GET -Headers $headers
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/api/v1/apikeys/privileges' -Method GET -Headers $headers
import http.client

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

headers = { 'authorization': "{{apiKey}}" }

conn.request("GET", "/baseUrl/api/v1/apikeys/privileges", headers=headers)

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

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

url = "{{baseUrl}}/api/v1/apikeys/privileges"

headers = {"authorization": "{{apiKey}}"}

response = requests.get(url, headers=headers)

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

url <- "{{baseUrl}}/api/v1/apikeys/privileges"

response <- VERB("GET", url, add_headers('authorization' = '{{apiKey}}'), content_type("application/octet-stream"))

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

url = URI("{{baseUrl}}/api/v1/apikeys/privileges")

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

request = Net::HTTP::Get.new(url)
request["authorization"] = '{{apiKey}}'

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

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

response = conn.get('/baseUrl/api/v1/apikeys/privileges') do |req|
  req.headers['authorization'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/api/v1/apikeys/privileges";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("authorization", "{{apiKey}}".parse().unwrap());

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

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

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/api/v1/apikeys/privileges \
  --header 'authorization: {{apiKey}}'
http GET {{baseUrl}}/api/v1/apikeys/privileges \
  authorization:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'authorization: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/api/v1/apikeys/privileges
import Foundation

let headers = ["authorization": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/api/v1/apikeys/privileges")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

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()
RESPONSE HEADERS

Content-Type
application/json
RESPONSE BODY json

{
  "limit": 100,
  "offset": 0,
  "total": 200
}
RESPONSE HEADERS

Content-Type
application/xml
RESPONSE BODY xml

{
  "limit": 100,
  "offset": 0,
  "total": 200
}
GET List privileges
{{baseUrl}}/api/v1/apikeys/:key/privileges
HEADERS

Authorization
{{apiKey}}
QUERY PARAMS

key
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/api/v1/apikeys/:key/privileges");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "authorization: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

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

(client/get "{{baseUrl}}/api/v1/apikeys/:key/privileges" {:headers {:authorization "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/api/v1/apikeys/:key/privileges"
headers = HTTP::Headers{
  "authorization" => "{{apiKey}}"
}

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

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

func main() {

	url := "{{baseUrl}}/api/v1/apikeys/:key/privileges"

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

	req.Header.Add("authorization", "{{apiKey}}")

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

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

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

}
GET /baseUrl/api/v1/apikeys/:key/privileges HTTP/1.1
Authorization: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/api/v1/apikeys/:key/privileges")
  .setHeader("authorization", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/api/v1/apikeys/:key/privileges"))
    .header("authorization", "{{apiKey}}")
    .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}}/api/v1/apikeys/:key/privileges")
  .get()
  .addHeader("authorization", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/api/v1/apikeys/:key/privileges")
  .header("authorization", "{{apiKey}}")
  .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}}/api/v1/apikeys/:key/privileges');
xhr.setRequestHeader('authorization', '{{apiKey}}');

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/api/v1/apikeys/:key/privileges',
  headers: {authorization: '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/api/v1/apikeys/:key/privileges';
const options = {method: 'GET', headers: {authorization: '{{apiKey}}'}};

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}}/api/v1/apikeys/:key/privileges',
  method: 'GET',
  headers: {
    authorization: '{{apiKey}}'
  }
};

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

val request = Request.Builder()
  .url("{{baseUrl}}/api/v1/apikeys/:key/privileges")
  .get()
  .addHeader("authorization", "{{apiKey}}")
  .build()

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

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/api/v1/apikeys/:key/privileges',
  headers: {
    authorization: '{{apiKey}}'
  }
};

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}}/api/v1/apikeys/:key/privileges',
  headers: {authorization: '{{apiKey}}'}
};

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

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

const req = unirest('GET', '{{baseUrl}}/api/v1/apikeys/:key/privileges');

req.headers({
  authorization: '{{apiKey}}'
});

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}}/api/v1/apikeys/:key/privileges',
  headers: {authorization: '{{apiKey}}'}
};

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

const url = '{{baseUrl}}/api/v1/apikeys/:key/privileges';
const options = {method: 'GET', headers: {authorization: '{{apiKey}}'}};

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

NSDictionary *headers = @{ @"authorization": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/api/v1/apikeys/:key/privileges"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

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}}/api/v1/apikeys/:key/privileges" in
let headers = Header.add (Header.init ()) "authorization" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/api/v1/apikeys/:key/privileges",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "authorization: {{apiKey}}"
  ],
]);

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/api/v1/apikeys/:key/privileges', [
  'headers' => [
    'authorization' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/api/v1/apikeys/:key/privileges');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'authorization' => '{{apiKey}}'
]);

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/api/v1/apikeys/:key/privileges');
$request->setRequestMethod('GET');
$request->setHeaders([
  'authorization' => '{{apiKey}}'
]);

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

echo $response->getBody();
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/api/v1/apikeys/:key/privileges' -Method GET -Headers $headers
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/api/v1/apikeys/:key/privileges' -Method GET -Headers $headers
import http.client

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

headers = { 'authorization': "{{apiKey}}" }

conn.request("GET", "/baseUrl/api/v1/apikeys/:key/privileges", headers=headers)

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

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

url = "{{baseUrl}}/api/v1/apikeys/:key/privileges"

headers = {"authorization": "{{apiKey}}"}

response = requests.get(url, headers=headers)

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

url <- "{{baseUrl}}/api/v1/apikeys/:key/privileges"

response <- VERB("GET", url, add_headers('authorization' = '{{apiKey}}'), content_type("application/octet-stream"))

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

url = URI("{{baseUrl}}/api/v1/apikeys/:key/privileges")

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

request = Net::HTTP::Get.new(url)
request["authorization"] = '{{apiKey}}'

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

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

response = conn.get('/baseUrl/api/v1/apikeys/:key/privileges') do |req|
  req.headers['authorization'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/api/v1/apikeys/:key/privileges";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("authorization", "{{apiKey}}".parse().unwrap());

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

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

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/api/v1/apikeys/:key/privileges \
  --header 'authorization: {{apiKey}}'
http GET {{baseUrl}}/api/v1/apikeys/:key/privileges \
  authorization:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'authorization: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/api/v1/apikeys/:key/privileges
import Foundation

let headers = ["authorization": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/api/v1/apikeys/:key/privileges")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

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()
RESPONSE HEADERS

Content-Type
application/json
RESPONSE BODY json

{
  "limit": 100,
  "offset": 0,
  "total": 200
}
RESPONSE HEADERS

Content-Type
application/xml
RESPONSE BODY xml

{
  "limit": 100,
  "offset": 0,
  "total": 200
}
DELETE Remove id4ns of a privilege
{{baseUrl}}/api/v1/apikeys/:key/privileges/:privilege/id4ns
HEADERS

Authorization
{{apiKey}}
QUERY PARAMS

key
privilege
BODY json

{
  "id4ns": []
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/api/v1/apikeys/:key/privileges/:privilege/id4ns");

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

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"id4ns\": []\n}");

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

(client/delete "{{baseUrl}}/api/v1/apikeys/:key/privileges/:privilege/id4ns" {:headers {:authorization "{{apiKey}}"}
                                                                                              :content-type :json
                                                                                              :form-params {:id4ns []}})
require "http/client"

url = "{{baseUrl}}/api/v1/apikeys/:key/privileges/:privilege/id4ns"
headers = HTTP::Headers{
  "authorization" => "{{apiKey}}"
  "content-type" => "application/json"
}
reqBody = "{\n  \"id4ns\": []\n}"

response = HTTP::Client.delete url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Delete,
    RequestUri = new Uri("{{baseUrl}}/api/v1/apikeys/:key/privileges/:privilege/id4ns"),
    Headers =
    {
        { "authorization", "{{apiKey}}" },
    },
    Content = new StringContent("{\n  \"id4ns\": []\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}}/api/v1/apikeys/:key/privileges/:privilege/id4ns");
var request = new RestRequest("", Method.Delete);
request.AddHeader("authorization", "{{apiKey}}");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"id4ns\": []\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/api/v1/apikeys/:key/privileges/:privilege/id4ns"

	payload := strings.NewReader("{\n  \"id4ns\": []\n}")

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

	req.Header.Add("authorization", "{{apiKey}}")
	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))

}
DELETE /baseUrl/api/v1/apikeys/:key/privileges/:privilege/id4ns HTTP/1.1
Authorization: {{apiKey}}
Content-Type: application/json
Host: example.com
Content-Length: 17

{
  "id4ns": []
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/api/v1/apikeys/:key/privileges/:privilege/id4ns")
  .setHeader("authorization", "{{apiKey}}")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"id4ns\": []\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/api/v1/apikeys/:key/privileges/:privilege/id4ns"))
    .header("authorization", "{{apiKey}}")
    .header("content-type", "application/json")
    .method("DELETE", HttpRequest.BodyPublishers.ofString("{\n  \"id4ns\": []\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  \"id4ns\": []\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/api/v1/apikeys/:key/privileges/:privilege/id4ns")
  .delete(body)
  .addHeader("authorization", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/api/v1/apikeys/:key/privileges/:privilege/id4ns")
  .header("authorization", "{{apiKey}}")
  .header("content-type", "application/json")
  .body("{\n  \"id4ns\": []\n}")
  .asString();
const data = JSON.stringify({
  id4ns: []
});

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

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

xhr.open('DELETE', '{{baseUrl}}/api/v1/apikeys/:key/privileges/:privilege/id4ns');
xhr.setRequestHeader('authorization', '{{apiKey}}');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/api/v1/apikeys/:key/privileges/:privilege/id4ns',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  data: {id4ns: []}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/api/v1/apikeys/:key/privileges/:privilege/id4ns';
const options = {
  method: 'DELETE',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"id4ns":[]}'
};

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}}/api/v1/apikeys/:key/privileges/:privilege/id4ns',
  method: 'DELETE',
  headers: {
    authorization: '{{apiKey}}',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "id4ns": []\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"id4ns\": []\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/api/v1/apikeys/:key/privileges/:privilege/id4ns")
  .delete(body)
  .addHeader("authorization", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/api/v1/apikeys/:key/privileges/:privilege/id4ns',
  headers: {
    authorization: '{{apiKey}}',
    '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({id4ns: []}));
req.end();
const request = require('request');

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/api/v1/apikeys/:key/privileges/:privilege/id4ns',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  body: {id4ns: []},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('DELETE', '{{baseUrl}}/api/v1/apikeys/:key/privileges/:privilege/id4ns');

req.headers({
  authorization: '{{apiKey}}',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  id4ns: []
});

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}}/api/v1/apikeys/:key/privileges/:privilege/id4ns',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  data: {id4ns: []}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/api/v1/apikeys/:key/privileges/:privilege/id4ns';
const options = {
  method: 'DELETE',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"id4ns":[]}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"authorization": @"{{apiKey}}",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"id4ns": @[  ] };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/api/v1/apikeys/:key/privileges/:privilege/id4ns"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"DELETE"];
[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}}/api/v1/apikeys/:key/privileges/:privilege/id4ns" in
let headers = Header.add_list (Header.init ()) [
  ("authorization", "{{apiKey}}");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"id4ns\": []\n}" in

Client.call ~headers ~body `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/api/v1/apikeys/:key/privileges/:privilege/id4ns",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
  CURLOPT_POSTFIELDS => json_encode([
    'id4ns' => [
        
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "authorization: {{apiKey}}",
    "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('DELETE', '{{baseUrl}}/api/v1/apikeys/:key/privileges/:privilege/id4ns', [
  'body' => '{
  "id4ns": []
}',
  'headers' => [
    'authorization' => '{{apiKey}}',
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/api/v1/apikeys/:key/privileges/:privilege/id4ns');
$request->setMethod(HTTP_METH_DELETE);

$request->setHeaders([
  'authorization' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'id4ns' => [
    
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'id4ns' => [
    
  ]
]));
$request->setRequestUrl('{{baseUrl}}/api/v1/apikeys/:key/privileges/:privilege/id4ns');
$request->setRequestMethod('DELETE');
$request->setBody($body);

$request->setHeaders([
  'authorization' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/api/v1/apikeys/:key/privileges/:privilege/id4ns' -Method DELETE -Headers $headers -ContentType 'application/json' -Body '{
  "id4ns": []
}'
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/api/v1/apikeys/:key/privileges/:privilege/id4ns' -Method DELETE -Headers $headers -ContentType 'application/json' -Body '{
  "id4ns": []
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"id4ns\": []\n}"

headers = {
    'authorization': "{{apiKey}}",
    'content-type': "application/json"
}

conn.request("DELETE", "/baseUrl/api/v1/apikeys/:key/privileges/:privilege/id4ns", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/api/v1/apikeys/:key/privileges/:privilege/id4ns"

payload = { "id4ns": [] }
headers = {
    "authorization": "{{apiKey}}",
    "content-type": "application/json"
}

response = requests.delete(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/api/v1/apikeys/:key/privileges/:privilege/id4ns"

payload <- "{\n  \"id4ns\": []\n}"

encode <- "json"

response <- VERB("DELETE", url, body = payload, add_headers('authorization' = '{{apiKey}}'), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/api/v1/apikeys/:key/privileges/:privilege/id4ns")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)
request["authorization"] = '{{apiKey}}'
request["content-type"] = 'application/json'
request.body = "{\n  \"id4ns\": []\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.delete('/baseUrl/api/v1/apikeys/:key/privileges/:privilege/id4ns') do |req|
  req.headers['authorization'] = '{{apiKey}}'
  req.body = "{\n  \"id4ns\": []\n}"
end

puts response.status
puts response.body
use std::str::FromStr;
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/api/v1/apikeys/:key/privileges/:privilege/id4ns";

    let payload = json!({"id4ns": ()});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("authorization", "{{apiKey}}".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("DELETE").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request DELETE \
  --url {{baseUrl}}/api/v1/apikeys/:key/privileges/:privilege/id4ns \
  --header 'authorization: {{apiKey}}' \
  --header 'content-type: application/json' \
  --data '{
  "id4ns": []
}'
echo '{
  "id4ns": []
}' |  \
  http DELETE {{baseUrl}}/api/v1/apikeys/:key/privileges/:privilege/id4ns \
  authorization:'{{apiKey}}' \
  content-type:application/json
wget --quiet \
  --method DELETE \
  --header 'authorization: {{apiKey}}' \
  --header 'content-type: application/json' \
  --body-data '{\n  "id4ns": []\n}' \
  --output-document \
  - {{baseUrl}}/api/v1/apikeys/:key/privileges/:privilege/id4ns
import Foundation

let headers = [
  "authorization": "{{apiKey}}",
  "content-type": "application/json"
]
let parameters = ["id4ns": []] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/api/v1/apikeys/:key/privileges/:privilege/id4ns")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "DELETE"
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 Remove privilege
{{baseUrl}}/api/v1/apikeys/:key/privileges
HEADERS

Authorization
{{apiKey}}
QUERY PARAMS

key
BODY json

{
  "privilege": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/api/v1/apikeys/:key/privileges");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "authorization: {{apiKey}}");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"privilege\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/api/v1/apikeys/:key/privileges" {:headers {:authorization "{{apiKey}}"}
                                                                             :content-type :json
                                                                             :form-params {:privilege ""}})
require "http/client"

url = "{{baseUrl}}/api/v1/apikeys/:key/privileges"
headers = HTTP::Headers{
  "authorization" => "{{apiKey}}"
  "content-type" => "application/json"
}
reqBody = "{\n  \"privilege\": \"\"\n}"

response = HTTP::Client.delete url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Delete,
    RequestUri = new Uri("{{baseUrl}}/api/v1/apikeys/:key/privileges"),
    Headers =
    {
        { "authorization", "{{apiKey}}" },
    },
    Content = new StringContent("{\n  \"privilege\": \"\"\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}}/api/v1/apikeys/:key/privileges");
var request = new RestRequest("", Method.Delete);
request.AddHeader("authorization", "{{apiKey}}");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"privilege\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/api/v1/apikeys/:key/privileges"

	payload := strings.NewReader("{\n  \"privilege\": \"\"\n}")

	req, _ := http.NewRequest("DELETE", url, payload)

	req.Header.Add("authorization", "{{apiKey}}")
	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))

}
DELETE /baseUrl/api/v1/apikeys/:key/privileges HTTP/1.1
Authorization: {{apiKey}}
Content-Type: application/json
Host: example.com
Content-Length: 21

{
  "privilege": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/api/v1/apikeys/:key/privileges")
  .setHeader("authorization", "{{apiKey}}")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"privilege\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/api/v1/apikeys/:key/privileges"))
    .header("authorization", "{{apiKey}}")
    .header("content-type", "application/json")
    .method("DELETE", HttpRequest.BodyPublishers.ofString("{\n  \"privilege\": \"\"\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  \"privilege\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/api/v1/apikeys/:key/privileges")
  .delete(body)
  .addHeader("authorization", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/api/v1/apikeys/:key/privileges")
  .header("authorization", "{{apiKey}}")
  .header("content-type", "application/json")
  .body("{\n  \"privilege\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  privilege: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('DELETE', '{{baseUrl}}/api/v1/apikeys/:key/privileges');
xhr.setRequestHeader('authorization', '{{apiKey}}');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/api/v1/apikeys/:key/privileges',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  data: {privilege: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/api/v1/apikeys/:key/privileges';
const options = {
  method: 'DELETE',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"privilege":""}'
};

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}}/api/v1/apikeys/:key/privileges',
  method: 'DELETE',
  headers: {
    authorization: '{{apiKey}}',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "privilege": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"privilege\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/api/v1/apikeys/:key/privileges")
  .delete(body)
  .addHeader("authorization", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/api/v1/apikeys/:key/privileges',
  headers: {
    authorization: '{{apiKey}}',
    '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({privilege: ''}));
req.end();
const request = require('request');

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/api/v1/apikeys/:key/privileges',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  body: {privilege: ''},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('DELETE', '{{baseUrl}}/api/v1/apikeys/:key/privileges');

req.headers({
  authorization: '{{apiKey}}',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  privilege: ''
});

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}}/api/v1/apikeys/:key/privileges',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  data: {privilege: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/api/v1/apikeys/:key/privileges';
const options = {
  method: 'DELETE',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"privilege":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"authorization": @"{{apiKey}}",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"privilege": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/api/v1/apikeys/:key/privileges"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"DELETE"];
[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}}/api/v1/apikeys/:key/privileges" in
let headers = Header.add_list (Header.init ()) [
  ("authorization", "{{apiKey}}");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"privilege\": \"\"\n}" in

Client.call ~headers ~body `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/api/v1/apikeys/:key/privileges",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
  CURLOPT_POSTFIELDS => json_encode([
    'privilege' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "authorization: {{apiKey}}",
    "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('DELETE', '{{baseUrl}}/api/v1/apikeys/:key/privileges', [
  'body' => '{
  "privilege": ""
}',
  'headers' => [
    'authorization' => '{{apiKey}}',
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/api/v1/apikeys/:key/privileges');
$request->setMethod(HTTP_METH_DELETE);

$request->setHeaders([
  'authorization' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'privilege' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'privilege' => ''
]));
$request->setRequestUrl('{{baseUrl}}/api/v1/apikeys/:key/privileges');
$request->setRequestMethod('DELETE');
$request->setBody($body);

$request->setHeaders([
  'authorization' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/api/v1/apikeys/:key/privileges' -Method DELETE -Headers $headers -ContentType 'application/json' -Body '{
  "privilege": ""
}'
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/api/v1/apikeys/:key/privileges' -Method DELETE -Headers $headers -ContentType 'application/json' -Body '{
  "privilege": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"privilege\": \"\"\n}"

headers = {
    'authorization': "{{apiKey}}",
    'content-type': "application/json"
}

conn.request("DELETE", "/baseUrl/api/v1/apikeys/:key/privileges", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/api/v1/apikeys/:key/privileges"

payload = { "privilege": "" }
headers = {
    "authorization": "{{apiKey}}",
    "content-type": "application/json"
}

response = requests.delete(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/api/v1/apikeys/:key/privileges"

payload <- "{\n  \"privilege\": \"\"\n}"

encode <- "json"

response <- VERB("DELETE", url, body = payload, add_headers('authorization' = '{{apiKey}}'), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/api/v1/apikeys/:key/privileges")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)
request["authorization"] = '{{apiKey}}'
request["content-type"] = 'application/json'
request.body = "{\n  \"privilege\": \"\"\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.delete('/baseUrl/api/v1/apikeys/:key/privileges') do |req|
  req.headers['authorization'] = '{{apiKey}}'
  req.body = "{\n  \"privilege\": \"\"\n}"
end

puts response.status
puts response.body
use std::str::FromStr;
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/api/v1/apikeys/:key/privileges";

    let payload = json!({"privilege": ""});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("authorization", "{{apiKey}}".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("DELETE").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request DELETE \
  --url {{baseUrl}}/api/v1/apikeys/:key/privileges \
  --header 'authorization: {{apiKey}}' \
  --header 'content-type: application/json' \
  --data '{
  "privilege": ""
}'
echo '{
  "privilege": ""
}' |  \
  http DELETE {{baseUrl}}/api/v1/apikeys/:key/privileges \
  authorization:'{{apiKey}}' \
  content-type:application/json
wget --quiet \
  --method DELETE \
  --header 'authorization: {{apiKey}}' \
  --header 'content-type: application/json' \
  --body-data '{\n  "privilege": ""\n}' \
  --output-document \
  - {{baseUrl}}/api/v1/apikeys/:key/privileges
import Foundation

let headers = [
  "authorization": "{{apiKey}}",
  "content-type": "application/json"
]
let parameters = ["privilege": ""] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/api/v1/apikeys/:key/privileges")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "DELETE"
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()
GET Show API key
{{baseUrl}}/api/v1/apikeys/:key
HEADERS

Authorization
{{apiKey}}
QUERY PARAMS

key
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/api/v1/apikeys/:key");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "authorization: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/api/v1/apikeys/:key" {:headers {:authorization "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/api/v1/apikeys/:key"
headers = HTTP::Headers{
  "authorization" => "{{apiKey}}"
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/api/v1/apikeys/:key"),
    Headers =
    {
        { "authorization", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/api/v1/apikeys/:key");
var request = new RestRequest("", Method.Get);
request.AddHeader("authorization", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/api/v1/apikeys/:key"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("authorization", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/api/v1/apikeys/:key HTTP/1.1
Authorization: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/api/v1/apikeys/:key")
  .setHeader("authorization", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/api/v1/apikeys/:key"))
    .header("authorization", "{{apiKey}}")
    .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}}/api/v1/apikeys/:key")
  .get()
  .addHeader("authorization", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/api/v1/apikeys/:key")
  .header("authorization", "{{apiKey}}")
  .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}}/api/v1/apikeys/:key');
xhr.setRequestHeader('authorization', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/api/v1/apikeys/:key',
  headers: {authorization: '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/api/v1/apikeys/:key';
const options = {method: 'GET', headers: {authorization: '{{apiKey}}'}};

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}}/api/v1/apikeys/:key',
  method: 'GET',
  headers: {
    authorization: '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/api/v1/apikeys/:key")
  .get()
  .addHeader("authorization", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/api/v1/apikeys/:key',
  headers: {
    authorization: '{{apiKey}}'
  }
};

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}}/api/v1/apikeys/:key',
  headers: {authorization: '{{apiKey}}'}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/api/v1/apikeys/:key');

req.headers({
  authorization: '{{apiKey}}'
});

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}}/api/v1/apikeys/:key',
  headers: {authorization: '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/api/v1/apikeys/:key';
const options = {method: 'GET', headers: {authorization: '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"authorization": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/api/v1/apikeys/:key"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

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}}/api/v1/apikeys/:key" in
let headers = Header.add (Header.init ()) "authorization" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/api/v1/apikeys/:key",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "authorization: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/api/v1/apikeys/:key', [
  'headers' => [
    'authorization' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/api/v1/apikeys/:key');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'authorization' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/api/v1/apikeys/:key');
$request->setRequestMethod('GET');
$request->setHeaders([
  'authorization' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/api/v1/apikeys/:key' -Method GET -Headers $headers
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/api/v1/apikeys/:key' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'authorization': "{{apiKey}}" }

conn.request("GET", "/baseUrl/api/v1/apikeys/:key", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/api/v1/apikeys/:key"

headers = {"authorization": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/api/v1/apikeys/:key"

response <- VERB("GET", url, add_headers('authorization' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/api/v1/apikeys/:key")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["authorization"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/api/v1/apikeys/:key') do |req|
  req.headers['authorization'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/api/v1/apikeys/:key";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("authorization", "{{apiKey}}".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/api/v1/apikeys/:key \
  --header 'authorization: {{apiKey}}'
http GET {{baseUrl}}/api/v1/apikeys/:key \
  authorization:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'authorization: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/api/v1/apikeys/:key
import Foundation

let headers = ["authorization": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/api/v1/apikeys/:key")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

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()
RESPONSE HEADERS

Content-Type
application/json
RESPONSE BODY json

{
  "active": true,
  "createdAt": 1517232722,
  "createdBy": "user123",
  "key": "39978f49-6ff1-4147-bf0f-9910185084b7",
  "label": "My Api Key",
  "organizationId": "de.acme"
}
RESPONSE HEADERS

Content-Type
application/xml
RESPONSE BODY xml

{
  "active": true,
  "createdAt": 1517232722,
  "createdBy": "user123",
  "key": "39978f49-6ff1-4147-bf0f-9910185084b7",
  "label": "My Api Key",
  "organizationId": "de.acme"
}
PUT Update API keys
{{baseUrl}}/api/v1/apikeys/:key
HEADERS

Authorization
{{apiKey}}
QUERY PARAMS

key
BODY json

{
  "active": false,
  "newLabel": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/api/v1/apikeys/:key");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "authorization: {{apiKey}}");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"active\": false,\n  \"newLabel\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/api/v1/apikeys/:key" {:headers {:authorization "{{apiKey}}"}
                                                               :content-type :json
                                                               :form-params {:active false
                                                                             :newLabel ""}})
require "http/client"

url = "{{baseUrl}}/api/v1/apikeys/:key"
headers = HTTP::Headers{
  "authorization" => "{{apiKey}}"
  "content-type" => "application/json"
}
reqBody = "{\n  \"active\": false,\n  \"newLabel\": \"\"\n}"

response = HTTP::Client.put url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Put,
    RequestUri = new Uri("{{baseUrl}}/api/v1/apikeys/:key"),
    Headers =
    {
        { "authorization", "{{apiKey}}" },
    },
    Content = new StringContent("{\n  \"active\": false,\n  \"newLabel\": \"\"\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}}/api/v1/apikeys/:key");
var request = new RestRequest("", Method.Put);
request.AddHeader("authorization", "{{apiKey}}");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"active\": false,\n  \"newLabel\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/api/v1/apikeys/:key"

	payload := strings.NewReader("{\n  \"active\": false,\n  \"newLabel\": \"\"\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("authorization", "{{apiKey}}")
	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))

}
PUT /baseUrl/api/v1/apikeys/:key HTTP/1.1
Authorization: {{apiKey}}
Content-Type: application/json
Host: example.com
Content-Length: 39

{
  "active": false,
  "newLabel": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/api/v1/apikeys/:key")
  .setHeader("authorization", "{{apiKey}}")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"active\": false,\n  \"newLabel\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/api/v1/apikeys/:key"))
    .header("authorization", "{{apiKey}}")
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"active\": false,\n  \"newLabel\": \"\"\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  \"active\": false,\n  \"newLabel\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/api/v1/apikeys/:key")
  .put(body)
  .addHeader("authorization", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/api/v1/apikeys/:key")
  .header("authorization", "{{apiKey}}")
  .header("content-type", "application/json")
  .body("{\n  \"active\": false,\n  \"newLabel\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  active: false,
  newLabel: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/api/v1/apikeys/:key');
xhr.setRequestHeader('authorization', '{{apiKey}}');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/api/v1/apikeys/:key',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  data: {active: false, newLabel: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/api/v1/apikeys/:key';
const options = {
  method: 'PUT',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"active":false,"newLabel":""}'
};

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}}/api/v1/apikeys/:key',
  method: 'PUT',
  headers: {
    authorization: '{{apiKey}}',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "active": false,\n  "newLabel": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"active\": false,\n  \"newLabel\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/api/v1/apikeys/:key")
  .put(body)
  .addHeader("authorization", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/api/v1/apikeys/:key',
  headers: {
    authorization: '{{apiKey}}',
    '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({active: false, newLabel: ''}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/api/v1/apikeys/:key',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  body: {active: false, newLabel: ''},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('PUT', '{{baseUrl}}/api/v1/apikeys/:key');

req.headers({
  authorization: '{{apiKey}}',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  active: false,
  newLabel: ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/api/v1/apikeys/:key',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  data: {active: false, newLabel: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/api/v1/apikeys/:key';
const options = {
  method: 'PUT',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"active":false,"newLabel":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"authorization": @"{{apiKey}}",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"active": @NO,
                              @"newLabel": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/api/v1/apikeys/:key"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"PUT"];
[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}}/api/v1/apikeys/:key" in
let headers = Header.add_list (Header.init ()) [
  ("authorization", "{{apiKey}}");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"active\": false,\n  \"newLabel\": \"\"\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/api/v1/apikeys/:key",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
  CURLOPT_POSTFIELDS => json_encode([
    'active' => null,
    'newLabel' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "authorization: {{apiKey}}",
    "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('PUT', '{{baseUrl}}/api/v1/apikeys/:key', [
  'body' => '{
  "active": false,
  "newLabel": ""
}',
  'headers' => [
    'authorization' => '{{apiKey}}',
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/api/v1/apikeys/:key');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'authorization' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'active' => null,
  'newLabel' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'active' => null,
  'newLabel' => ''
]));
$request->setRequestUrl('{{baseUrl}}/api/v1/apikeys/:key');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'authorization' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/api/v1/apikeys/:key' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "active": false,
  "newLabel": ""
}'
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/api/v1/apikeys/:key' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "active": false,
  "newLabel": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"active\": false,\n  \"newLabel\": \"\"\n}"

headers = {
    'authorization': "{{apiKey}}",
    'content-type': "application/json"
}

conn.request("PUT", "/baseUrl/api/v1/apikeys/:key", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/api/v1/apikeys/:key"

payload = {
    "active": False,
    "newLabel": ""
}
headers = {
    "authorization": "{{apiKey}}",
    "content-type": "application/json"
}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/api/v1/apikeys/:key"

payload <- "{\n  \"active\": false,\n  \"newLabel\": \"\"\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, add_headers('authorization' = '{{apiKey}}'), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/api/v1/apikeys/:key")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["authorization"] = '{{apiKey}}'
request["content-type"] = 'application/json'
request.body = "{\n  \"active\": false,\n  \"newLabel\": \"\"\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.put('/baseUrl/api/v1/apikeys/:key') do |req|
  req.headers['authorization'] = '{{apiKey}}'
  req.body = "{\n  \"active\": false,\n  \"newLabel\": \"\"\n}"
end

puts response.status
puts response.body
use std::str::FromStr;
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/api/v1/apikeys/:key";

    let payload = json!({
        "active": false,
        "newLabel": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("authorization", "{{apiKey}}".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/api/v1/apikeys/:key \
  --header 'authorization: {{apiKey}}' \
  --header 'content-type: application/json' \
  --data '{
  "active": false,
  "newLabel": ""
}'
echo '{
  "active": false,
  "newLabel": ""
}' |  \
  http PUT {{baseUrl}}/api/v1/apikeys/:key \
  authorization:'{{apiKey}}' \
  content-type:application/json
wget --quiet \
  --method PUT \
  --header 'authorization: {{apiKey}}' \
  --header 'content-type: application/json' \
  --body-data '{\n  "active": false,\n  "newLabel": ""\n}' \
  --output-document \
  - {{baseUrl}}/api/v1/apikeys/:key
import Foundation

let headers = [
  "authorization": "{{apiKey}}",
  "content-type": "application/json"
]
let parameters = [
  "active": false,
  "newLabel": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/api/v1/apikeys/:key")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "PUT"
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()
GET List change log entries of an organization
{{baseUrl}}/api/v1/changelog/organization/:organizationId/
HEADERS

Authorization
{{apiKey}}
QUERY PARAMS

organizationId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/api/v1/changelog/organization/:organizationId/");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "authorization: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/api/v1/changelog/organization/:organizationId/" {:headers {:authorization "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/api/v1/changelog/organization/:organizationId/"
headers = HTTP::Headers{
  "authorization" => "{{apiKey}}"
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/api/v1/changelog/organization/:organizationId/"),
    Headers =
    {
        { "authorization", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/api/v1/changelog/organization/:organizationId/");
var request = new RestRequest("", Method.Get);
request.AddHeader("authorization", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/api/v1/changelog/organization/:organizationId/"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("authorization", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/api/v1/changelog/organization/:organizationId/ HTTP/1.1
Authorization: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/api/v1/changelog/organization/:organizationId/")
  .setHeader("authorization", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/api/v1/changelog/organization/:organizationId/"))
    .header("authorization", "{{apiKey}}")
    .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}}/api/v1/changelog/organization/:organizationId/")
  .get()
  .addHeader("authorization", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/api/v1/changelog/organization/:organizationId/")
  .header("authorization", "{{apiKey}}")
  .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}}/api/v1/changelog/organization/:organizationId/');
xhr.setRequestHeader('authorization', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/api/v1/changelog/organization/:organizationId/',
  headers: {authorization: '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/api/v1/changelog/organization/:organizationId/';
const options = {method: 'GET', headers: {authorization: '{{apiKey}}'}};

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}}/api/v1/changelog/organization/:organizationId/',
  method: 'GET',
  headers: {
    authorization: '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/api/v1/changelog/organization/:organizationId/")
  .get()
  .addHeader("authorization", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/api/v1/changelog/organization/:organizationId/',
  headers: {
    authorization: '{{apiKey}}'
  }
};

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}}/api/v1/changelog/organization/:organizationId/',
  headers: {authorization: '{{apiKey}}'}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/api/v1/changelog/organization/:organizationId/');

req.headers({
  authorization: '{{apiKey}}'
});

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}}/api/v1/changelog/organization/:organizationId/',
  headers: {authorization: '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/api/v1/changelog/organization/:organizationId/';
const options = {method: 'GET', headers: {authorization: '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"authorization": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/api/v1/changelog/organization/:organizationId/"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

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}}/api/v1/changelog/organization/:organizationId/" in
let headers = Header.add (Header.init ()) "authorization" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/api/v1/changelog/organization/:organizationId/",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "authorization: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/api/v1/changelog/organization/:organizationId/', [
  'headers' => [
    'authorization' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/api/v1/changelog/organization/:organizationId/');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'authorization' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/api/v1/changelog/organization/:organizationId/');
$request->setRequestMethod('GET');
$request->setHeaders([
  'authorization' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/api/v1/changelog/organization/:organizationId/' -Method GET -Headers $headers
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/api/v1/changelog/organization/:organizationId/' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'authorization': "{{apiKey}}" }

conn.request("GET", "/baseUrl/api/v1/changelog/organization/:organizationId/", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/api/v1/changelog/organization/:organizationId/"

headers = {"authorization": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/api/v1/changelog/organization/:organizationId/"

response <- VERB("GET", url, add_headers('authorization' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/api/v1/changelog/organization/:organizationId/")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["authorization"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/api/v1/changelog/organization/:organizationId/') do |req|
  req.headers['authorization'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/api/v1/changelog/organization/:organizationId/";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("authorization", "{{apiKey}}".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/api/v1/changelog/organization/:organizationId/ \
  --header 'authorization: {{apiKey}}'
http GET {{baseUrl}}/api/v1/changelog/organization/:organizationId/ \
  authorization:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'authorization: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/api/v1/changelog/organization/:organizationId/
import Foundation

let headers = ["authorization": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/api/v1/changelog/organization/:organizationId/")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

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()
RESPONSE HEADERS

Content-Type
application/json
RESPONSE BODY json

{
  "limit": 100,
  "offset": 0,
  "total": 200
}
RESPONSE HEADERS

Content-Type
application/xml
RESPONSE BODY xml

{
  "limit": 100,
  "offset": 0,
  "total": 200
}
GET Get billing amount of services for a given organization
{{baseUrl}}/api/v1/billing/:organizationId
HEADERS

Authorization
{{apiKey}}
QUERY PARAMS

organizationId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/api/v1/billing/:organizationId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "authorization: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/api/v1/billing/:organizationId" {:headers {:authorization "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/api/v1/billing/:organizationId"
headers = HTTP::Headers{
  "authorization" => "{{apiKey}}"
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/api/v1/billing/:organizationId"),
    Headers =
    {
        { "authorization", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/api/v1/billing/:organizationId");
var request = new RestRequest("", Method.Get);
request.AddHeader("authorization", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/api/v1/billing/:organizationId"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("authorization", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/api/v1/billing/:organizationId HTTP/1.1
Authorization: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/api/v1/billing/:organizationId")
  .setHeader("authorization", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/api/v1/billing/:organizationId"))
    .header("authorization", "{{apiKey}}")
    .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}}/api/v1/billing/:organizationId")
  .get()
  .addHeader("authorization", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/api/v1/billing/:organizationId")
  .header("authorization", "{{apiKey}}")
  .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}}/api/v1/billing/:organizationId');
xhr.setRequestHeader('authorization', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/api/v1/billing/:organizationId',
  headers: {authorization: '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/api/v1/billing/:organizationId';
const options = {method: 'GET', headers: {authorization: '{{apiKey}}'}};

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}}/api/v1/billing/:organizationId',
  method: 'GET',
  headers: {
    authorization: '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/api/v1/billing/:organizationId")
  .get()
  .addHeader("authorization", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/api/v1/billing/:organizationId',
  headers: {
    authorization: '{{apiKey}}'
  }
};

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}}/api/v1/billing/:organizationId',
  headers: {authorization: '{{apiKey}}'}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/api/v1/billing/:organizationId');

req.headers({
  authorization: '{{apiKey}}'
});

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}}/api/v1/billing/:organizationId',
  headers: {authorization: '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/api/v1/billing/:organizationId';
const options = {method: 'GET', headers: {authorization: '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"authorization": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/api/v1/billing/:organizationId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

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}}/api/v1/billing/:organizationId" in
let headers = Header.add (Header.init ()) "authorization" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/api/v1/billing/:organizationId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "authorization: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/api/v1/billing/:organizationId', [
  'headers' => [
    'authorization' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/api/v1/billing/:organizationId');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'authorization' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/api/v1/billing/:organizationId');
$request->setRequestMethod('GET');
$request->setHeaders([
  'authorization' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/api/v1/billing/:organizationId' -Method GET -Headers $headers
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/api/v1/billing/:organizationId' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'authorization': "{{apiKey}}" }

conn.request("GET", "/baseUrl/api/v1/billing/:organizationId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/api/v1/billing/:organizationId"

headers = {"authorization": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/api/v1/billing/:organizationId"

response <- VERB("GET", url, add_headers('authorization' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/api/v1/billing/:organizationId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["authorization"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/api/v1/billing/:organizationId') do |req|
  req.headers['authorization'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/api/v1/billing/:organizationId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("authorization", "{{apiKey}}".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/api/v1/billing/:organizationId \
  --header 'authorization: {{apiKey}}'
http GET {{baseUrl}}/api/v1/billing/:organizationId \
  authorization:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'authorization: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/api/v1/billing/:organizationId
import Foundation

let headers = ["authorization": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/api/v1/billing/:organizationId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

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 billing positions for a given organization
{{baseUrl}}/api/v1/billing/:organizationId/positions
HEADERS

Authorization
{{apiKey}}
QUERY PARAMS

organizationId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/api/v1/billing/:organizationId/positions");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "authorization: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/api/v1/billing/:organizationId/positions" {:headers {:authorization "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/api/v1/billing/:organizationId/positions"
headers = HTTP::Headers{
  "authorization" => "{{apiKey}}"
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/api/v1/billing/:organizationId/positions"),
    Headers =
    {
        { "authorization", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/api/v1/billing/:organizationId/positions");
var request = new RestRequest("", Method.Get);
request.AddHeader("authorization", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/api/v1/billing/:organizationId/positions"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("authorization", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/api/v1/billing/:organizationId/positions HTTP/1.1
Authorization: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/api/v1/billing/:organizationId/positions")
  .setHeader("authorization", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/api/v1/billing/:organizationId/positions"))
    .header("authorization", "{{apiKey}}")
    .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}}/api/v1/billing/:organizationId/positions")
  .get()
  .addHeader("authorization", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/api/v1/billing/:organizationId/positions")
  .header("authorization", "{{apiKey}}")
  .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}}/api/v1/billing/:organizationId/positions');
xhr.setRequestHeader('authorization', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/api/v1/billing/:organizationId/positions',
  headers: {authorization: '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/api/v1/billing/:organizationId/positions';
const options = {method: 'GET', headers: {authorization: '{{apiKey}}'}};

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}}/api/v1/billing/:organizationId/positions',
  method: 'GET',
  headers: {
    authorization: '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/api/v1/billing/:organizationId/positions")
  .get()
  .addHeader("authorization", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/api/v1/billing/:organizationId/positions',
  headers: {
    authorization: '{{apiKey}}'
  }
};

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}}/api/v1/billing/:organizationId/positions',
  headers: {authorization: '{{apiKey}}'}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/api/v1/billing/:organizationId/positions');

req.headers({
  authorization: '{{apiKey}}'
});

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}}/api/v1/billing/:organizationId/positions',
  headers: {authorization: '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/api/v1/billing/:organizationId/positions';
const options = {method: 'GET', headers: {authorization: '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"authorization": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/api/v1/billing/:organizationId/positions"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

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}}/api/v1/billing/:organizationId/positions" in
let headers = Header.add (Header.init ()) "authorization" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/api/v1/billing/:organizationId/positions",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "authorization: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/api/v1/billing/:organizationId/positions', [
  'headers' => [
    'authorization' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/api/v1/billing/:organizationId/positions');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'authorization' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/api/v1/billing/:organizationId/positions');
$request->setRequestMethod('GET');
$request->setHeaders([
  'authorization' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/api/v1/billing/:organizationId/positions' -Method GET -Headers $headers
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/api/v1/billing/:organizationId/positions' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'authorization': "{{apiKey}}" }

conn.request("GET", "/baseUrl/api/v1/billing/:organizationId/positions", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/api/v1/billing/:organizationId/positions"

headers = {"authorization": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/api/v1/billing/:organizationId/positions"

response <- VERB("GET", url, add_headers('authorization' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/api/v1/billing/:organizationId/positions")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["authorization"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/api/v1/billing/:organizationId/positions') do |req|
  req.headers['authorization'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/api/v1/billing/:organizationId/positions";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("authorization", "{{apiKey}}".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/api/v1/billing/:organizationId/positions \
  --header 'authorization: {{apiKey}}'
http GET {{baseUrl}}/api/v1/billing/:organizationId/positions \
  authorization:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'authorization: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/api/v1/billing/:organizationId/positions
import Foundation

let headers = ["authorization": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/api/v1/billing/:organizationId/positions")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

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 Add elements to collection
{{baseUrl}}/api/v1/collections/:id4n/elements
HEADERS

Authorization
{{apiKey}}
QUERY PARAMS

id4n
BODY json

{
  "id4ns": []
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/api/v1/collections/:id4n/elements");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "authorization: {{apiKey}}");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"id4ns\": []\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/api/v1/collections/:id4n/elements" {:headers {:authorization "{{apiKey}}"}
                                                                              :content-type :json
                                                                              :form-params {:id4ns []}})
require "http/client"

url = "{{baseUrl}}/api/v1/collections/:id4n/elements"
headers = HTTP::Headers{
  "authorization" => "{{apiKey}}"
  "content-type" => "application/json"
}
reqBody = "{\n  \"id4ns\": []\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}}/api/v1/collections/:id4n/elements"),
    Headers =
    {
        { "authorization", "{{apiKey}}" },
    },
    Content = new StringContent("{\n  \"id4ns\": []\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}}/api/v1/collections/:id4n/elements");
var request = new RestRequest("", Method.Post);
request.AddHeader("authorization", "{{apiKey}}");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"id4ns\": []\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/api/v1/collections/:id4n/elements"

	payload := strings.NewReader("{\n  \"id4ns\": []\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("authorization", "{{apiKey}}")
	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/api/v1/collections/:id4n/elements HTTP/1.1
Authorization: {{apiKey}}
Content-Type: application/json
Host: example.com
Content-Length: 17

{
  "id4ns": []
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/api/v1/collections/:id4n/elements")
  .setHeader("authorization", "{{apiKey}}")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"id4ns\": []\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/api/v1/collections/:id4n/elements"))
    .header("authorization", "{{apiKey}}")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"id4ns\": []\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  \"id4ns\": []\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/api/v1/collections/:id4n/elements")
  .post(body)
  .addHeader("authorization", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/api/v1/collections/:id4n/elements")
  .header("authorization", "{{apiKey}}")
  .header("content-type", "application/json")
  .body("{\n  \"id4ns\": []\n}")
  .asString();
const data = JSON.stringify({
  id4ns: []
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/api/v1/collections/:id4n/elements');
xhr.setRequestHeader('authorization', '{{apiKey}}');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/api/v1/collections/:id4n/elements',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  data: {id4ns: []}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/api/v1/collections/:id4n/elements';
const options = {
  method: 'POST',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"id4ns":[]}'
};

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}}/api/v1/collections/:id4n/elements',
  method: 'POST',
  headers: {
    authorization: '{{apiKey}}',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "id4ns": []\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"id4ns\": []\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/api/v1/collections/:id4n/elements")
  .post(body)
  .addHeader("authorization", "{{apiKey}}")
  .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/api/v1/collections/:id4n/elements',
  headers: {
    authorization: '{{apiKey}}',
    '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({id4ns: []}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/api/v1/collections/:id4n/elements',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  body: {id4ns: []},
  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}}/api/v1/collections/:id4n/elements');

req.headers({
  authorization: '{{apiKey}}',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  id4ns: []
});

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}}/api/v1/collections/:id4n/elements',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  data: {id4ns: []}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/api/v1/collections/:id4n/elements';
const options = {
  method: 'POST',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"id4ns":[]}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"authorization": @"{{apiKey}}",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"id4ns": @[  ] };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/api/v1/collections/:id4n/elements"]
                                                       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}}/api/v1/collections/:id4n/elements" in
let headers = Header.add_list (Header.init ()) [
  ("authorization", "{{apiKey}}");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"id4ns\": []\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/api/v1/collections/:id4n/elements",
  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([
    'id4ns' => [
        
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "authorization: {{apiKey}}",
    "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}}/api/v1/collections/:id4n/elements', [
  'body' => '{
  "id4ns": []
}',
  'headers' => [
    'authorization' => '{{apiKey}}',
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/api/v1/collections/:id4n/elements');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'authorization' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'id4ns' => [
    
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'id4ns' => [
    
  ]
]));
$request->setRequestUrl('{{baseUrl}}/api/v1/collections/:id4n/elements');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'authorization' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/api/v1/collections/:id4n/elements' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "id4ns": []
}'
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/api/v1/collections/:id4n/elements' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "id4ns": []
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"id4ns\": []\n}"

headers = {
    'authorization': "{{apiKey}}",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/api/v1/collections/:id4n/elements", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/api/v1/collections/:id4n/elements"

payload = { "id4ns": [] }
headers = {
    "authorization": "{{apiKey}}",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/api/v1/collections/:id4n/elements"

payload <- "{\n  \"id4ns\": []\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('authorization' = '{{apiKey}}'), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/api/v1/collections/:id4n/elements")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["authorization"] = '{{apiKey}}'
request["content-type"] = 'application/json'
request.body = "{\n  \"id4ns\": []\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/api/v1/collections/:id4n/elements') do |req|
  req.headers['authorization'] = '{{apiKey}}'
  req.body = "{\n  \"id4ns\": []\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/api/v1/collections/:id4n/elements";

    let payload = json!({"id4ns": ()});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("authorization", "{{apiKey}}".parse().unwrap());
    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}}/api/v1/collections/:id4n/elements \
  --header 'authorization: {{apiKey}}' \
  --header 'content-type: application/json' \
  --data '{
  "id4ns": []
}'
echo '{
  "id4ns": []
}' |  \
  http POST {{baseUrl}}/api/v1/collections/:id4n/elements \
  authorization:'{{apiKey}}' \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'authorization: {{apiKey}}' \
  --header 'content-type: application/json' \
  --body-data '{\n  "id4ns": []\n}' \
  --output-document \
  - {{baseUrl}}/api/v1/collections/:id4n/elements
import Foundation

let headers = [
  "authorization": "{{apiKey}}",
  "content-type": "application/json"
]
let parameters = ["id4ns": []] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/api/v1/collections/:id4n/elements")! 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 Create collection
{{baseUrl}}/api/v1/collections
HEADERS

Authorization
{{apiKey}}
BODY json

{
  "label": "",
  "length": 0,
  "organizationId": "",
  "type": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/api/v1/collections");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "authorization: {{apiKey}}");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"label\": \"\",\n  \"length\": 0,\n  \"organizationId\": \"\",\n  \"type\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/api/v1/collections" {:headers {:authorization "{{apiKey}}"}
                                                               :content-type :json
                                                               :form-params {:label ""
                                                                             :length 0
                                                                             :organizationId ""
                                                                             :type ""}})
require "http/client"

url = "{{baseUrl}}/api/v1/collections"
headers = HTTP::Headers{
  "authorization" => "{{apiKey}}"
  "content-type" => "application/json"
}
reqBody = "{\n  \"label\": \"\",\n  \"length\": 0,\n  \"organizationId\": \"\",\n  \"type\": \"\"\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}}/api/v1/collections"),
    Headers =
    {
        { "authorization", "{{apiKey}}" },
    },
    Content = new StringContent("{\n  \"label\": \"\",\n  \"length\": 0,\n  \"organizationId\": \"\",\n  \"type\": \"\"\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}}/api/v1/collections");
var request = new RestRequest("", Method.Post);
request.AddHeader("authorization", "{{apiKey}}");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"label\": \"\",\n  \"length\": 0,\n  \"organizationId\": \"\",\n  \"type\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/api/v1/collections"

	payload := strings.NewReader("{\n  \"label\": \"\",\n  \"length\": 0,\n  \"organizationId\": \"\",\n  \"type\": \"\"\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("authorization", "{{apiKey}}")
	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/api/v1/collections HTTP/1.1
Authorization: {{apiKey}}
Content-Type: application/json
Host: example.com
Content-Length: 70

{
  "label": "",
  "length": 0,
  "organizationId": "",
  "type": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/api/v1/collections")
  .setHeader("authorization", "{{apiKey}}")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"label\": \"\",\n  \"length\": 0,\n  \"organizationId\": \"\",\n  \"type\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/api/v1/collections"))
    .header("authorization", "{{apiKey}}")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"label\": \"\",\n  \"length\": 0,\n  \"organizationId\": \"\",\n  \"type\": \"\"\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  \"label\": \"\",\n  \"length\": 0,\n  \"organizationId\": \"\",\n  \"type\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/api/v1/collections")
  .post(body)
  .addHeader("authorization", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/api/v1/collections")
  .header("authorization", "{{apiKey}}")
  .header("content-type", "application/json")
  .body("{\n  \"label\": \"\",\n  \"length\": 0,\n  \"organizationId\": \"\",\n  \"type\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  label: '',
  length: 0,
  organizationId: '',
  type: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/api/v1/collections');
xhr.setRequestHeader('authorization', '{{apiKey}}');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/api/v1/collections',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  data: {label: '', length: 0, organizationId: '', type: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/api/v1/collections';
const options = {
  method: 'POST',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"label":"","length":0,"organizationId":"","type":""}'
};

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}}/api/v1/collections',
  method: 'POST',
  headers: {
    authorization: '{{apiKey}}',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "label": "",\n  "length": 0,\n  "organizationId": "",\n  "type": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"label\": \"\",\n  \"length\": 0,\n  \"organizationId\": \"\",\n  \"type\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/api/v1/collections")
  .post(body)
  .addHeader("authorization", "{{apiKey}}")
  .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/api/v1/collections',
  headers: {
    authorization: '{{apiKey}}',
    '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({label: '', length: 0, organizationId: '', type: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/api/v1/collections',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  body: {label: '', length: 0, organizationId: '', type: ''},
  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}}/api/v1/collections');

req.headers({
  authorization: '{{apiKey}}',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  label: '',
  length: 0,
  organizationId: '',
  type: ''
});

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}}/api/v1/collections',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  data: {label: '', length: 0, organizationId: '', type: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/api/v1/collections';
const options = {
  method: 'POST',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"label":"","length":0,"organizationId":"","type":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"authorization": @"{{apiKey}}",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"label": @"",
                              @"length": @0,
                              @"organizationId": @"",
                              @"type": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/api/v1/collections"]
                                                       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}}/api/v1/collections" in
let headers = Header.add_list (Header.init ()) [
  ("authorization", "{{apiKey}}");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"label\": \"\",\n  \"length\": 0,\n  \"organizationId\": \"\",\n  \"type\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/api/v1/collections",
  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([
    'label' => '',
    'length' => 0,
    'organizationId' => '',
    'type' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "authorization: {{apiKey}}",
    "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}}/api/v1/collections', [
  'body' => '{
  "label": "",
  "length": 0,
  "organizationId": "",
  "type": ""
}',
  'headers' => [
    'authorization' => '{{apiKey}}',
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/api/v1/collections');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'authorization' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'label' => '',
  'length' => 0,
  'organizationId' => '',
  'type' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'label' => '',
  'length' => 0,
  'organizationId' => '',
  'type' => ''
]));
$request->setRequestUrl('{{baseUrl}}/api/v1/collections');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'authorization' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/api/v1/collections' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "label": "",
  "length": 0,
  "organizationId": "",
  "type": ""
}'
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/api/v1/collections' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "label": "",
  "length": 0,
  "organizationId": "",
  "type": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"label\": \"\",\n  \"length\": 0,\n  \"organizationId\": \"\",\n  \"type\": \"\"\n}"

headers = {
    'authorization': "{{apiKey}}",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/api/v1/collections", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/api/v1/collections"

payload = {
    "label": "",
    "length": 0,
    "organizationId": "",
    "type": ""
}
headers = {
    "authorization": "{{apiKey}}",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/api/v1/collections"

payload <- "{\n  \"label\": \"\",\n  \"length\": 0,\n  \"organizationId\": \"\",\n  \"type\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('authorization' = '{{apiKey}}'), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/api/v1/collections")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["authorization"] = '{{apiKey}}'
request["content-type"] = 'application/json'
request.body = "{\n  \"label\": \"\",\n  \"length\": 0,\n  \"organizationId\": \"\",\n  \"type\": \"\"\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/api/v1/collections') do |req|
  req.headers['authorization'] = '{{apiKey}}'
  req.body = "{\n  \"label\": \"\",\n  \"length\": 0,\n  \"organizationId\": \"\",\n  \"type\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/api/v1/collections";

    let payload = json!({
        "label": "",
        "length": 0,
        "organizationId": "",
        "type": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("authorization", "{{apiKey}}".parse().unwrap());
    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}}/api/v1/collections \
  --header 'authorization: {{apiKey}}' \
  --header 'content-type: application/json' \
  --data '{
  "label": "",
  "length": 0,
  "organizationId": "",
  "type": ""
}'
echo '{
  "label": "",
  "length": 0,
  "organizationId": "",
  "type": ""
}' |  \
  http POST {{baseUrl}}/api/v1/collections \
  authorization:'{{apiKey}}' \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'authorization: {{apiKey}}' \
  --header 'content-type: application/json' \
  --body-data '{\n  "label": "",\n  "length": 0,\n  "organizationId": "",\n  "type": ""\n}' \
  --output-document \
  - {{baseUrl}}/api/v1/collections
import Foundation

let headers = [
  "authorization": "{{apiKey}}",
  "content-type": "application/json"
]
let parameters = [
  "label": "",
  "length": 0,
  "organizationId": "",
  "type": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/api/v1/collections")! 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()
RESPONSE HEADERS

Content-Type
application/json
RESPONSE BODY json

{
  "id4n": "3THvgrWxqgTFC4"
}
RESPONSE HEADERS

Content-Type
application/xml
RESPONSE BODY xml

{
  "id4n": "3THvgrWxqgTFC4"
}
DELETE Delete ID4n properties
{{baseUrl}}/api/v1/id4ns/:id4n/properties
HEADERS

Authorization
{{apiKey}}
QUERY PARAMS

organizationId
id4n
BODY json

[
  {}
]
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/api/v1/id4ns/:id4n/properties?organizationId=");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "authorization: {{apiKey}}");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "[\n  {}\n]");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/api/v1/id4ns/:id4n/properties" {:headers {:authorization "{{apiKey}}"}
                                                                            :query-params {:organizationId ""}
                                                                            :content-type :json
                                                                            :form-params [{}]})
require "http/client"

url = "{{baseUrl}}/api/v1/id4ns/:id4n/properties?organizationId="
headers = HTTP::Headers{
  "authorization" => "{{apiKey}}"
  "content-type" => "application/json"
}
reqBody = "[\n  {}\n]"

response = HTTP::Client.delete url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Delete,
    RequestUri = new Uri("{{baseUrl}}/api/v1/id4ns/:id4n/properties?organizationId="),
    Headers =
    {
        { "authorization", "{{apiKey}}" },
    },
    Content = new StringContent("[\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}}/api/v1/id4ns/:id4n/properties?organizationId=");
var request = new RestRequest("", Method.Delete);
request.AddHeader("authorization", "{{apiKey}}");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "[\n  {}\n]", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/api/v1/id4ns/:id4n/properties?organizationId="

	payload := strings.NewReader("[\n  {}\n]")

	req, _ := http.NewRequest("DELETE", url, payload)

	req.Header.Add("authorization", "{{apiKey}}")
	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))

}
DELETE /baseUrl/api/v1/id4ns/:id4n/properties?organizationId= HTTP/1.1
Authorization: {{apiKey}}
Content-Type: application/json
Host: example.com
Content-Length: 8

[
  {}
]
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/api/v1/id4ns/:id4n/properties?organizationId=")
  .setHeader("authorization", "{{apiKey}}")
  .setHeader("content-type", "application/json")
  .setBody("[\n  {}\n]")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/api/v1/id4ns/:id4n/properties?organizationId="))
    .header("authorization", "{{apiKey}}")
    .header("content-type", "application/json")
    .method("DELETE", HttpRequest.BodyPublishers.ofString("[\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  {}\n]");
Request request = new Request.Builder()
  .url("{{baseUrl}}/api/v1/id4ns/:id4n/properties?organizationId=")
  .delete(body)
  .addHeader("authorization", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/api/v1/id4ns/:id4n/properties?organizationId=")
  .header("authorization", "{{apiKey}}")
  .header("content-type", "application/json")
  .body("[\n  {}\n]")
  .asString();
const data = JSON.stringify([
  {}
]);

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('DELETE', '{{baseUrl}}/api/v1/id4ns/:id4n/properties?organizationId=');
xhr.setRequestHeader('authorization', '{{apiKey}}');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/api/v1/id4ns/:id4n/properties',
  params: {organizationId: ''},
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  data: [{}]
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/api/v1/id4ns/:id4n/properties?organizationId=';
const options = {
  method: 'DELETE',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  body: '[{}]'
};

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}}/api/v1/id4ns/:id4n/properties?organizationId=',
  method: 'DELETE',
  headers: {
    authorization: '{{apiKey}}',
    'content-type': 'application/json'
  },
  processData: false,
  data: '[\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  {}\n]")
val request = Request.Builder()
  .url("{{baseUrl}}/api/v1/id4ns/:id4n/properties?organizationId=")
  .delete(body)
  .addHeader("authorization", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/api/v1/id4ns/:id4n/properties?organizationId=',
  headers: {
    authorization: '{{apiKey}}',
    '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([{}]));
req.end();
const request = require('request');

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/api/v1/id4ns/:id4n/properties',
  qs: {organizationId: ''},
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  body: [{}],
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('DELETE', '{{baseUrl}}/api/v1/id4ns/:id4n/properties');

req.query({
  organizationId: ''
});

req.headers({
  authorization: '{{apiKey}}',
  'content-type': 'application/json'
});

req.type('json');
req.send([
  {}
]);

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}}/api/v1/id4ns/:id4n/properties',
  params: {organizationId: ''},
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  data: [{}]
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/api/v1/id4ns/:id4n/properties?organizationId=';
const options = {
  method: 'DELETE',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  body: '[{}]'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"authorization": @"{{apiKey}}",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @[ @{  } ];

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/api/v1/id4ns/:id4n/properties?organizationId="]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"DELETE"];
[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}}/api/v1/id4ns/:id4n/properties?organizationId=" in
let headers = Header.add_list (Header.init ()) [
  ("authorization", "{{apiKey}}");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "[\n  {}\n]" in

Client.call ~headers ~body `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/api/v1/id4ns/:id4n/properties?organizationId=",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
  CURLOPT_POSTFIELDS => json_encode([
    [
        
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "authorization: {{apiKey}}",
    "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('DELETE', '{{baseUrl}}/api/v1/id4ns/:id4n/properties?organizationId=', [
  'body' => '[
  {}
]',
  'headers' => [
    'authorization' => '{{apiKey}}',
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/api/v1/id4ns/:id4n/properties');
$request->setMethod(HTTP_METH_DELETE);

$request->setQueryData([
  'organizationId' => ''
]);

$request->setHeaders([
  'authorization' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  [
    
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  [
    
  ]
]));
$request->setRequestUrl('{{baseUrl}}/api/v1/id4ns/:id4n/properties');
$request->setRequestMethod('DELETE');
$request->setBody($body);

$request->setQuery(new http\QueryString([
  'organizationId' => ''
]));

$request->setHeaders([
  'authorization' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/api/v1/id4ns/:id4n/properties?organizationId=' -Method DELETE -Headers $headers -ContentType 'application/json' -Body '[
  {}
]'
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/api/v1/id4ns/:id4n/properties?organizationId=' -Method DELETE -Headers $headers -ContentType 'application/json' -Body '[
  {}
]'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "[\n  {}\n]"

headers = {
    'authorization': "{{apiKey}}",
    'content-type': "application/json"
}

conn.request("DELETE", "/baseUrl/api/v1/id4ns/:id4n/properties?organizationId=", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/api/v1/id4ns/:id4n/properties"

querystring = {"organizationId":""}

payload = [{}]
headers = {
    "authorization": "{{apiKey}}",
    "content-type": "application/json"
}

response = requests.delete(url, json=payload, headers=headers, params=querystring)

print(response.json())
library(httr)

url <- "{{baseUrl}}/api/v1/id4ns/:id4n/properties"

queryString <- list(organizationId = "")

payload <- "[\n  {}\n]"

encode <- "json"

response <- VERB("DELETE", url, body = payload, query = queryString, add_headers('authorization' = '{{apiKey}}'), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/api/v1/id4ns/:id4n/properties?organizationId=")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)
request["authorization"] = '{{apiKey}}'
request["content-type"] = 'application/json'
request.body = "[\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.delete('/baseUrl/api/v1/id4ns/:id4n/properties') do |req|
  req.headers['authorization'] = '{{apiKey}}'
  req.params['organizationId'] = ''
  req.body = "[\n  {}\n]"
end

puts response.status
puts response.body
use std::str::FromStr;
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/api/v1/id4ns/:id4n/properties";

    let querystring = [
        ("organizationId", ""),
    ];

    let payload = (json!({}));

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("authorization", "{{apiKey}}".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("DELETE").unwrap(), url)
        .query(&querystring)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request DELETE \
  --url '{{baseUrl}}/api/v1/id4ns/:id4n/properties?organizationId=' \
  --header 'authorization: {{apiKey}}' \
  --header 'content-type: application/json' \
  --data '[
  {}
]'
echo '[
  {}
]' |  \
  http DELETE '{{baseUrl}}/api/v1/id4ns/:id4n/properties?organizationId=' \
  authorization:'{{apiKey}}' \
  content-type:application/json
wget --quiet \
  --method DELETE \
  --header 'authorization: {{apiKey}}' \
  --header 'content-type: application/json' \
  --body-data '[\n  {}\n]' \
  --output-document \
  - '{{baseUrl}}/api/v1/id4ns/:id4n/properties?organizationId='
import Foundation

let headers = [
  "authorization": "{{apiKey}}",
  "content-type": "application/json"
]
let parameters = [[]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/api/v1/id4ns/:id4n/properties?organizationId=")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "DELETE"
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 Delete collection
{{baseUrl}}/api/v1/collections/:id4n
HEADERS

Authorization
{{apiKey}}
QUERY PARAMS

id4n
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/api/v1/collections/:id4n");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "authorization: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/api/v1/collections/:id4n" {:headers {:authorization "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/api/v1/collections/:id4n"
headers = HTTP::Headers{
  "authorization" => "{{apiKey}}"
}

response = HTTP::Client.delete url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Delete,
    RequestUri = new Uri("{{baseUrl}}/api/v1/collections/:id4n"),
    Headers =
    {
        { "authorization", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/api/v1/collections/:id4n");
var request = new RestRequest("", Method.Delete);
request.AddHeader("authorization", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/api/v1/collections/:id4n"

	req, _ := http.NewRequest("DELETE", url, nil)

	req.Header.Add("authorization", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/api/v1/collections/:id4n HTTP/1.1
Authorization: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/api/v1/collections/:id4n")
  .setHeader("authorization", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/api/v1/collections/:id4n"))
    .header("authorization", "{{apiKey}}")
    .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}}/api/v1/collections/:id4n")
  .delete(null)
  .addHeader("authorization", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/api/v1/collections/:id4n")
  .header("authorization", "{{apiKey}}")
  .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}}/api/v1/collections/:id4n');
xhr.setRequestHeader('authorization', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/api/v1/collections/:id4n',
  headers: {authorization: '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/api/v1/collections/:id4n';
const options = {method: 'DELETE', headers: {authorization: '{{apiKey}}'}};

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}}/api/v1/collections/:id4n',
  method: 'DELETE',
  headers: {
    authorization: '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/api/v1/collections/:id4n")
  .delete(null)
  .addHeader("authorization", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/api/v1/collections/:id4n',
  headers: {
    authorization: '{{apiKey}}'
  }
};

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}}/api/v1/collections/:id4n',
  headers: {authorization: '{{apiKey}}'}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('DELETE', '{{baseUrl}}/api/v1/collections/:id4n');

req.headers({
  authorization: '{{apiKey}}'
});

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}}/api/v1/collections/:id4n',
  headers: {authorization: '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/api/v1/collections/:id4n';
const options = {method: 'DELETE', headers: {authorization: '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"authorization": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/api/v1/collections/:id4n"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"DELETE"];
[request setAllHTTPHeaderFields:headers];

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}}/api/v1/collections/:id4n" in
let headers = Header.add (Header.init ()) "authorization" "{{apiKey}}" in

Client.call ~headers `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/api/v1/collections/:id4n",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
  CURLOPT_HTTPHEADER => [
    "authorization: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/api/v1/collections/:id4n', [
  'headers' => [
    'authorization' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/api/v1/collections/:id4n');
$request->setMethod(HTTP_METH_DELETE);

$request->setHeaders([
  'authorization' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/api/v1/collections/:id4n');
$request->setRequestMethod('DELETE');
$request->setHeaders([
  'authorization' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/api/v1/collections/:id4n' -Method DELETE -Headers $headers
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/api/v1/collections/:id4n' -Method DELETE -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'authorization': "{{apiKey}}" }

conn.request("DELETE", "/baseUrl/api/v1/collections/:id4n", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/api/v1/collections/:id4n"

headers = {"authorization": "{{apiKey}}"}

response = requests.delete(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/api/v1/collections/:id4n"

response <- VERB("DELETE", url, add_headers('authorization' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/api/v1/collections/:id4n")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)
request["authorization"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/api/v1/collections/:id4n') do |req|
  req.headers['authorization'] = '{{apiKey}}'
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/api/v1/collections/:id4n";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("authorization", "{{apiKey}}".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("DELETE").unwrap(), url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request DELETE \
  --url {{baseUrl}}/api/v1/collections/:id4n \
  --header 'authorization: {{apiKey}}'
http DELETE {{baseUrl}}/api/v1/collections/:id4n \
  authorization:'{{apiKey}}'
wget --quiet \
  --method DELETE \
  --header 'authorization: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/api/v1/collections/:id4n
import Foundation

let headers = ["authorization": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/api/v1/collections/:id4n")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "DELETE"
request.allHTTPHeaderFields = headers

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 Find collection
{{baseUrl}}/api/v1/collections/:id4n
HEADERS

Authorization
{{apiKey}}
QUERY PARAMS

id4n
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/api/v1/collections/:id4n");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "authorization: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/api/v1/collections/:id4n" {:headers {:authorization "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/api/v1/collections/:id4n"
headers = HTTP::Headers{
  "authorization" => "{{apiKey}}"
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/api/v1/collections/:id4n"),
    Headers =
    {
        { "authorization", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/api/v1/collections/:id4n");
var request = new RestRequest("", Method.Get);
request.AddHeader("authorization", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/api/v1/collections/:id4n"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("authorization", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/api/v1/collections/:id4n HTTP/1.1
Authorization: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/api/v1/collections/:id4n")
  .setHeader("authorization", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/api/v1/collections/:id4n"))
    .header("authorization", "{{apiKey}}")
    .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}}/api/v1/collections/:id4n")
  .get()
  .addHeader("authorization", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/api/v1/collections/:id4n")
  .header("authorization", "{{apiKey}}")
  .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}}/api/v1/collections/:id4n');
xhr.setRequestHeader('authorization', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/api/v1/collections/:id4n',
  headers: {authorization: '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/api/v1/collections/:id4n';
const options = {method: 'GET', headers: {authorization: '{{apiKey}}'}};

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}}/api/v1/collections/:id4n',
  method: 'GET',
  headers: {
    authorization: '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/api/v1/collections/:id4n")
  .get()
  .addHeader("authorization", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/api/v1/collections/:id4n',
  headers: {
    authorization: '{{apiKey}}'
  }
};

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}}/api/v1/collections/:id4n',
  headers: {authorization: '{{apiKey}}'}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/api/v1/collections/:id4n');

req.headers({
  authorization: '{{apiKey}}'
});

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}}/api/v1/collections/:id4n',
  headers: {authorization: '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/api/v1/collections/:id4n';
const options = {method: 'GET', headers: {authorization: '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"authorization": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/api/v1/collections/:id4n"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

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}}/api/v1/collections/:id4n" in
let headers = Header.add (Header.init ()) "authorization" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/api/v1/collections/:id4n",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "authorization: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/api/v1/collections/:id4n', [
  'headers' => [
    'authorization' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/api/v1/collections/:id4n');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'authorization' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/api/v1/collections/:id4n');
$request->setRequestMethod('GET');
$request->setHeaders([
  'authorization' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/api/v1/collections/:id4n' -Method GET -Headers $headers
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/api/v1/collections/:id4n' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'authorization': "{{apiKey}}" }

conn.request("GET", "/baseUrl/api/v1/collections/:id4n", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/api/v1/collections/:id4n"

headers = {"authorization": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/api/v1/collections/:id4n"

response <- VERB("GET", url, add_headers('authorization' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/api/v1/collections/:id4n")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["authorization"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/api/v1/collections/:id4n') do |req|
  req.headers['authorization'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/api/v1/collections/:id4n";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("authorization", "{{apiKey}}".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/api/v1/collections/:id4n \
  --header 'authorization: {{apiKey}}'
http GET {{baseUrl}}/api/v1/collections/:id4n \
  authorization:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'authorization: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/api/v1/collections/:id4n
import Foundation

let headers = ["authorization": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/api/v1/collections/:id4n")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

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 collections of organization
{{baseUrl}}/api/v1/organizations/:organizationId/collections
HEADERS

Authorization
{{apiKey}}
QUERY PARAMS

organizationId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/api/v1/organizations/:organizationId/collections");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "authorization: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/api/v1/organizations/:organizationId/collections" {:headers {:authorization "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/api/v1/organizations/:organizationId/collections"
headers = HTTP::Headers{
  "authorization" => "{{apiKey}}"
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/api/v1/organizations/:organizationId/collections"),
    Headers =
    {
        { "authorization", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/api/v1/organizations/:organizationId/collections");
var request = new RestRequest("", Method.Get);
request.AddHeader("authorization", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/api/v1/organizations/:organizationId/collections"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("authorization", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/api/v1/organizations/:organizationId/collections HTTP/1.1
Authorization: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/api/v1/organizations/:organizationId/collections")
  .setHeader("authorization", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/api/v1/organizations/:organizationId/collections"))
    .header("authorization", "{{apiKey}}")
    .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}}/api/v1/organizations/:organizationId/collections")
  .get()
  .addHeader("authorization", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/api/v1/organizations/:organizationId/collections")
  .header("authorization", "{{apiKey}}")
  .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}}/api/v1/organizations/:organizationId/collections');
xhr.setRequestHeader('authorization', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/api/v1/organizations/:organizationId/collections',
  headers: {authorization: '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/api/v1/organizations/:organizationId/collections';
const options = {method: 'GET', headers: {authorization: '{{apiKey}}'}};

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}}/api/v1/organizations/:organizationId/collections',
  method: 'GET',
  headers: {
    authorization: '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/api/v1/organizations/:organizationId/collections")
  .get()
  .addHeader("authorization", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/api/v1/organizations/:organizationId/collections',
  headers: {
    authorization: '{{apiKey}}'
  }
};

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}}/api/v1/organizations/:organizationId/collections',
  headers: {authorization: '{{apiKey}}'}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/api/v1/organizations/:organizationId/collections');

req.headers({
  authorization: '{{apiKey}}'
});

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}}/api/v1/organizations/:organizationId/collections',
  headers: {authorization: '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/api/v1/organizations/:organizationId/collections';
const options = {method: 'GET', headers: {authorization: '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"authorization": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/api/v1/organizations/:organizationId/collections"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

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}}/api/v1/organizations/:organizationId/collections" in
let headers = Header.add (Header.init ()) "authorization" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/api/v1/organizations/:organizationId/collections",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "authorization: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/api/v1/organizations/:organizationId/collections', [
  'headers' => [
    'authorization' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/api/v1/organizations/:organizationId/collections');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'authorization' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/api/v1/organizations/:organizationId/collections');
$request->setRequestMethod('GET');
$request->setHeaders([
  'authorization' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/api/v1/organizations/:organizationId/collections' -Method GET -Headers $headers
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/api/v1/organizations/:organizationId/collections' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'authorization': "{{apiKey}}" }

conn.request("GET", "/baseUrl/api/v1/organizations/:organizationId/collections", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/api/v1/organizations/:organizationId/collections"

headers = {"authorization": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/api/v1/organizations/:organizationId/collections"

response <- VERB("GET", url, add_headers('authorization' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/api/v1/organizations/:organizationId/collections")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["authorization"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/api/v1/organizations/:organizationId/collections') do |req|
  req.headers['authorization'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/api/v1/organizations/:organizationId/collections";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("authorization", "{{apiKey}}".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/api/v1/organizations/:organizationId/collections \
  --header 'authorization: {{apiKey}}'
http GET {{baseUrl}}/api/v1/organizations/:organizationId/collections \
  authorization:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'authorization: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/api/v1/organizations/:organizationId/collections
import Foundation

let headers = ["authorization": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/api/v1/organizations/:organizationId/collections")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

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()
RESPONSE HEADERS

Content-Type
application/json
RESPONSE BODY json

{
  "limit": 100,
  "offset": 0,
  "total": 200
}
RESPONSE HEADERS

Content-Type
application/xml
RESPONSE BODY xml

{
  "limit": 100,
  "offset": 0,
  "total": 200
}
GET Get multiple ID4n properties
{{baseUrl}}/api/v1/multiple/id4ns/properties
HEADERS

Authorization
{{apiKey}}
QUERY PARAMS

id4ns
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/api/v1/multiple/id4ns/properties?id4ns=");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "authorization: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/api/v1/multiple/id4ns/properties" {:headers {:authorization "{{apiKey}}"}
                                                                            :query-params {:id4ns ""}})
require "http/client"

url = "{{baseUrl}}/api/v1/multiple/id4ns/properties?id4ns="
headers = HTTP::Headers{
  "authorization" => "{{apiKey}}"
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/api/v1/multiple/id4ns/properties?id4ns="),
    Headers =
    {
        { "authorization", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/api/v1/multiple/id4ns/properties?id4ns=");
var request = new RestRequest("", Method.Get);
request.AddHeader("authorization", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/api/v1/multiple/id4ns/properties?id4ns="

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("authorization", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/api/v1/multiple/id4ns/properties?id4ns= HTTP/1.1
Authorization: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/api/v1/multiple/id4ns/properties?id4ns=")
  .setHeader("authorization", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/api/v1/multiple/id4ns/properties?id4ns="))
    .header("authorization", "{{apiKey}}")
    .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}}/api/v1/multiple/id4ns/properties?id4ns=")
  .get()
  .addHeader("authorization", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/api/v1/multiple/id4ns/properties?id4ns=")
  .header("authorization", "{{apiKey}}")
  .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}}/api/v1/multiple/id4ns/properties?id4ns=');
xhr.setRequestHeader('authorization', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/api/v1/multiple/id4ns/properties',
  params: {id4ns: ''},
  headers: {authorization: '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/api/v1/multiple/id4ns/properties?id4ns=';
const options = {method: 'GET', headers: {authorization: '{{apiKey}}'}};

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}}/api/v1/multiple/id4ns/properties?id4ns=',
  method: 'GET',
  headers: {
    authorization: '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/api/v1/multiple/id4ns/properties?id4ns=")
  .get()
  .addHeader("authorization", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/api/v1/multiple/id4ns/properties?id4ns=',
  headers: {
    authorization: '{{apiKey}}'
  }
};

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}}/api/v1/multiple/id4ns/properties',
  qs: {id4ns: ''},
  headers: {authorization: '{{apiKey}}'}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/api/v1/multiple/id4ns/properties');

req.query({
  id4ns: ''
});

req.headers({
  authorization: '{{apiKey}}'
});

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}}/api/v1/multiple/id4ns/properties',
  params: {id4ns: ''},
  headers: {authorization: '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/api/v1/multiple/id4ns/properties?id4ns=';
const options = {method: 'GET', headers: {authorization: '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"authorization": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/api/v1/multiple/id4ns/properties?id4ns="]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

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}}/api/v1/multiple/id4ns/properties?id4ns=" in
let headers = Header.add (Header.init ()) "authorization" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/api/v1/multiple/id4ns/properties?id4ns=",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "authorization: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/api/v1/multiple/id4ns/properties?id4ns=', [
  'headers' => [
    'authorization' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/api/v1/multiple/id4ns/properties');
$request->setMethod(HTTP_METH_GET);

$request->setQueryData([
  'id4ns' => ''
]);

$request->setHeaders([
  'authorization' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/api/v1/multiple/id4ns/properties');
$request->setRequestMethod('GET');
$request->setQuery(new http\QueryString([
  'id4ns' => ''
]));

$request->setHeaders([
  'authorization' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/api/v1/multiple/id4ns/properties?id4ns=' -Method GET -Headers $headers
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/api/v1/multiple/id4ns/properties?id4ns=' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'authorization': "{{apiKey}}" }

conn.request("GET", "/baseUrl/api/v1/multiple/id4ns/properties?id4ns=", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/api/v1/multiple/id4ns/properties"

querystring = {"id4ns":""}

headers = {"authorization": "{{apiKey}}"}

response = requests.get(url, headers=headers, params=querystring)

print(response.json())
library(httr)

url <- "{{baseUrl}}/api/v1/multiple/id4ns/properties"

queryString <- list(id4ns = "")

response <- VERB("GET", url, query = queryString, add_headers('authorization' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/api/v1/multiple/id4ns/properties?id4ns=")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["authorization"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/api/v1/multiple/id4ns/properties') do |req|
  req.headers['authorization'] = '{{apiKey}}'
  req.params['id4ns'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/api/v1/multiple/id4ns/properties";

    let querystring = [
        ("id4ns", ""),
    ];

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("authorization", "{{apiKey}}".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .query(&querystring)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url '{{baseUrl}}/api/v1/multiple/id4ns/properties?id4ns=' \
  --header 'authorization: {{apiKey}}'
http GET '{{baseUrl}}/api/v1/multiple/id4ns/properties?id4ns=' \
  authorization:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'authorization: {{apiKey}}' \
  --output-document \
  - '{{baseUrl}}/api/v1/multiple/id4ns/properties?id4ns='
import Foundation

let headers = ["authorization": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/api/v1/multiple/id4ns/properties?id4ns=")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

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 List contents of the collection
{{baseUrl}}/api/v1/collections/:id4n/elements
HEADERS

Authorization
{{apiKey}}
QUERY PARAMS

id4n
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/api/v1/collections/:id4n/elements");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "authorization: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/api/v1/collections/:id4n/elements" {:headers {:authorization "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/api/v1/collections/:id4n/elements"
headers = HTTP::Headers{
  "authorization" => "{{apiKey}}"
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/api/v1/collections/:id4n/elements"),
    Headers =
    {
        { "authorization", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/api/v1/collections/:id4n/elements");
var request = new RestRequest("", Method.Get);
request.AddHeader("authorization", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/api/v1/collections/:id4n/elements"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("authorization", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/api/v1/collections/:id4n/elements HTTP/1.1
Authorization: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/api/v1/collections/:id4n/elements")
  .setHeader("authorization", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/api/v1/collections/:id4n/elements"))
    .header("authorization", "{{apiKey}}")
    .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}}/api/v1/collections/:id4n/elements")
  .get()
  .addHeader("authorization", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/api/v1/collections/:id4n/elements")
  .header("authorization", "{{apiKey}}")
  .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}}/api/v1/collections/:id4n/elements');
xhr.setRequestHeader('authorization', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/api/v1/collections/:id4n/elements',
  headers: {authorization: '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/api/v1/collections/:id4n/elements';
const options = {method: 'GET', headers: {authorization: '{{apiKey}}'}};

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}}/api/v1/collections/:id4n/elements',
  method: 'GET',
  headers: {
    authorization: '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/api/v1/collections/:id4n/elements")
  .get()
  .addHeader("authorization", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/api/v1/collections/:id4n/elements',
  headers: {
    authorization: '{{apiKey}}'
  }
};

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}}/api/v1/collections/:id4n/elements',
  headers: {authorization: '{{apiKey}}'}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/api/v1/collections/:id4n/elements');

req.headers({
  authorization: '{{apiKey}}'
});

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}}/api/v1/collections/:id4n/elements',
  headers: {authorization: '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/api/v1/collections/:id4n/elements';
const options = {method: 'GET', headers: {authorization: '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"authorization": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/api/v1/collections/:id4n/elements"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

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}}/api/v1/collections/:id4n/elements" in
let headers = Header.add (Header.init ()) "authorization" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/api/v1/collections/:id4n/elements",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "authorization: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/api/v1/collections/:id4n/elements', [
  'headers' => [
    'authorization' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/api/v1/collections/:id4n/elements');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'authorization' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/api/v1/collections/:id4n/elements');
$request->setRequestMethod('GET');
$request->setHeaders([
  'authorization' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/api/v1/collections/:id4n/elements' -Method GET -Headers $headers
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/api/v1/collections/:id4n/elements' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'authorization': "{{apiKey}}" }

conn.request("GET", "/baseUrl/api/v1/collections/:id4n/elements", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/api/v1/collections/:id4n/elements"

headers = {"authorization": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/api/v1/collections/:id4n/elements"

response <- VERB("GET", url, add_headers('authorization' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/api/v1/collections/:id4n/elements")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["authorization"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/api/v1/collections/:id4n/elements') do |req|
  req.headers['authorization'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/api/v1/collections/:id4n/elements";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("authorization", "{{apiKey}}".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/api/v1/collections/:id4n/elements \
  --header 'authorization: {{apiKey}}'
http GET {{baseUrl}}/api/v1/collections/:id4n/elements \
  authorization:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'authorization: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/api/v1/collections/:id4n/elements
import Foundation

let headers = ["authorization": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/api/v1/collections/:id4n/elements")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

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()
RESPONSE HEADERS

Content-Type
application/json
RESPONSE BODY json

{
  "limit": 100,
  "offset": 0,
  "total": 200
}
RESPONSE HEADERS

Content-Type
application/xml
RESPONSE BODY xml

{
  "limit": 100,
  "offset": 0,
  "total": 200
}
PATCH Patch ID4n properties
{{baseUrl}}/api/v1/id4ns/:id4n/properties
HEADERS

Authorization
{{apiKey}}
QUERY PARAMS

organizationId
id4n
BODY json

{}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PATCH");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/api/v1/id4ns/:id4n/properties?organizationId=");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "authorization: {{apiKey}}");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/patch "{{baseUrl}}/api/v1/id4ns/:id4n/properties" {:headers {:authorization "{{apiKey}}"}
                                                                           :query-params {:organizationId ""}
                                                                           :content-type :json})
require "http/client"

url = "{{baseUrl}}/api/v1/id4ns/:id4n/properties?organizationId="
headers = HTTP::Headers{
  "authorization" => "{{apiKey}}"
  "content-type" => "application/json"
}
reqBody = "{}"

response = HTTP::Client.patch url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Patch,
    RequestUri = new Uri("{{baseUrl}}/api/v1/id4ns/:id4n/properties?organizationId="),
    Headers =
    {
        { "authorization", "{{apiKey}}" },
    },
    Content = new StringContent("{}")
    {
        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}}/api/v1/id4ns/:id4n/properties?organizationId=");
var request = new RestRequest("", Method.Patch);
request.AddHeader("authorization", "{{apiKey}}");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/api/v1/id4ns/:id4n/properties?organizationId="

	payload := strings.NewReader("{}")

	req, _ := http.NewRequest("PATCH", url, payload)

	req.Header.Add("authorization", "{{apiKey}}")
	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))

}
PATCH /baseUrl/api/v1/id4ns/:id4n/properties?organizationId= HTTP/1.1
Authorization: {{apiKey}}
Content-Type: application/json
Host: example.com
Content-Length: 2

{}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PATCH", "{{baseUrl}}/api/v1/id4ns/:id4n/properties?organizationId=")
  .setHeader("authorization", "{{apiKey}}")
  .setHeader("content-type", "application/json")
  .setBody("{}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/api/v1/id4ns/:id4n/properties?organizationId="))
    .header("authorization", "{{apiKey}}")
    .header("content-type", "application/json")
    .method("PATCH", HttpRequest.BodyPublishers.ofString("{}"))
    .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, "{}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/api/v1/id4ns/:id4n/properties?organizationId=")
  .patch(body)
  .addHeader("authorization", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.patch("{{baseUrl}}/api/v1/id4ns/:id4n/properties?organizationId=")
  .header("authorization", "{{apiKey}}")
  .header("content-type", "application/json")
  .body("{}")
  .asString();
const data = JSON.stringify({});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PATCH', '{{baseUrl}}/api/v1/id4ns/:id4n/properties?organizationId=');
xhr.setRequestHeader('authorization', '{{apiKey}}');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PATCH',
  url: '{{baseUrl}}/api/v1/id4ns/:id4n/properties',
  params: {organizationId: ''},
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  data: {}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/api/v1/id4ns/:id4n/properties?organizationId=';
const options = {
  method: 'PATCH',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  body: '{}'
};

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}}/api/v1/id4ns/:id4n/properties?organizationId=',
  method: 'PATCH',
  headers: {
    authorization: '{{apiKey}}',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{}")
val request = Request.Builder()
  .url("{{baseUrl}}/api/v1/id4ns/:id4n/properties?organizationId=")
  .patch(body)
  .addHeader("authorization", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PATCH',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/api/v1/id4ns/:id4n/properties?organizationId=',
  headers: {
    authorization: '{{apiKey}}',
    '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({}));
req.end();
const request = require('request');

const options = {
  method: 'PATCH',
  url: '{{baseUrl}}/api/v1/id4ns/:id4n/properties',
  qs: {organizationId: ''},
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  body: {},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('PATCH', '{{baseUrl}}/api/v1/id4ns/:id4n/properties');

req.query({
  organizationId: ''
});

req.headers({
  authorization: '{{apiKey}}',
  'content-type': 'application/json'
});

req.type('json');
req.send({});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'PATCH',
  url: '{{baseUrl}}/api/v1/id4ns/:id4n/properties',
  params: {organizationId: ''},
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  data: {}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/api/v1/id4ns/:id4n/properties?organizationId=';
const options = {
  method: 'PATCH',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  body: '{}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"authorization": @"{{apiKey}}",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{  };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/api/v1/id4ns/:id4n/properties?organizationId="]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"PATCH"];
[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}}/api/v1/id4ns/:id4n/properties?organizationId=" in
let headers = Header.add_list (Header.init ()) [
  ("authorization", "{{apiKey}}");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{}" in

Client.call ~headers ~body `PATCH uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/api/v1/id4ns/:id4n/properties?organizationId=",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PATCH",
  CURLOPT_POSTFIELDS => json_encode([
    
  ]),
  CURLOPT_HTTPHEADER => [
    "authorization: {{apiKey}}",
    "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('PATCH', '{{baseUrl}}/api/v1/id4ns/:id4n/properties?organizationId=', [
  'body' => '{}',
  'headers' => [
    'authorization' => '{{apiKey}}',
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/api/v1/id4ns/:id4n/properties');
$request->setMethod(HttpRequest::HTTP_METH_PATCH);

$request->setQueryData([
  'organizationId' => ''
]);

$request->setHeaders([
  'authorization' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  
]));
$request->setRequestUrl('{{baseUrl}}/api/v1/id4ns/:id4n/properties');
$request->setRequestMethod('PATCH');
$request->setBody($body);

$request->setQuery(new http\QueryString([
  'organizationId' => ''
]));

$request->setHeaders([
  'authorization' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/api/v1/id4ns/:id4n/properties?organizationId=' -Method PATCH -Headers $headers -ContentType 'application/json' -Body '{}'
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/api/v1/id4ns/:id4n/properties?organizationId=' -Method PATCH -Headers $headers -ContentType 'application/json' -Body '{}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{}"

headers = {
    'authorization': "{{apiKey}}",
    'content-type': "application/json"
}

conn.request("PATCH", "/baseUrl/api/v1/id4ns/:id4n/properties?organizationId=", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/api/v1/id4ns/:id4n/properties"

querystring = {"organizationId":""}

payload = {}
headers = {
    "authorization": "{{apiKey}}",
    "content-type": "application/json"
}

response = requests.patch(url, json=payload, headers=headers, params=querystring)

print(response.json())
library(httr)

url <- "{{baseUrl}}/api/v1/id4ns/:id4n/properties"

queryString <- list(organizationId = "")

payload <- "{}"

encode <- "json"

response <- VERB("PATCH", url, body = payload, query = queryString, add_headers('authorization' = '{{apiKey}}'), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/api/v1/id4ns/:id4n/properties?organizationId=")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Patch.new(url)
request["authorization"] = '{{apiKey}}'
request["content-type"] = 'application/json'
request.body = "{}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.patch('/baseUrl/api/v1/id4ns/:id4n/properties') do |req|
  req.headers['authorization'] = '{{apiKey}}'
  req.params['organizationId'] = ''
  req.body = "{}"
end

puts response.status
puts response.body
use std::str::FromStr;
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/api/v1/id4ns/:id4n/properties";

    let querystring = [
        ("organizationId", ""),
    ];

    let payload = json!({});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("authorization", "{{apiKey}}".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PATCH").unwrap(), url)
        .query(&querystring)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PATCH \
  --url '{{baseUrl}}/api/v1/id4ns/:id4n/properties?organizationId=' \
  --header 'authorization: {{apiKey}}' \
  --header 'content-type: application/json' \
  --data '{}'
echo '{}' |  \
  http PATCH '{{baseUrl}}/api/v1/id4ns/:id4n/properties?organizationId=' \
  authorization:'{{apiKey}}' \
  content-type:application/json
wget --quiet \
  --method PATCH \
  --header 'authorization: {{apiKey}}' \
  --header 'content-type: application/json' \
  --body-data '{}' \
  --output-document \
  - '{{baseUrl}}/api/v1/id4ns/:id4n/properties?organizationId='
import Foundation

let headers = [
  "authorization": "{{apiKey}}",
  "content-type": "application/json"
]
let parameters = [] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/api/v1/id4ns/:id4n/properties?organizationId=")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "PATCH"
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 Remove elements from collection
{{baseUrl}}/api/v1/collections/:id4n/elements
HEADERS

Authorization
{{apiKey}}
QUERY PARAMS

id4n
BODY json

{
  "id4ns": []
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/api/v1/collections/:id4n/elements");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "authorization: {{apiKey}}");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"id4ns\": []\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/api/v1/collections/:id4n/elements" {:headers {:authorization "{{apiKey}}"}
                                                                                :content-type :json
                                                                                :form-params {:id4ns []}})
require "http/client"

url = "{{baseUrl}}/api/v1/collections/:id4n/elements"
headers = HTTP::Headers{
  "authorization" => "{{apiKey}}"
  "content-type" => "application/json"
}
reqBody = "{\n  \"id4ns\": []\n}"

response = HTTP::Client.delete url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Delete,
    RequestUri = new Uri("{{baseUrl}}/api/v1/collections/:id4n/elements"),
    Headers =
    {
        { "authorization", "{{apiKey}}" },
    },
    Content = new StringContent("{\n  \"id4ns\": []\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}}/api/v1/collections/:id4n/elements");
var request = new RestRequest("", Method.Delete);
request.AddHeader("authorization", "{{apiKey}}");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"id4ns\": []\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/api/v1/collections/:id4n/elements"

	payload := strings.NewReader("{\n  \"id4ns\": []\n}")

	req, _ := http.NewRequest("DELETE", url, payload)

	req.Header.Add("authorization", "{{apiKey}}")
	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))

}
DELETE /baseUrl/api/v1/collections/:id4n/elements HTTP/1.1
Authorization: {{apiKey}}
Content-Type: application/json
Host: example.com
Content-Length: 17

{
  "id4ns": []
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/api/v1/collections/:id4n/elements")
  .setHeader("authorization", "{{apiKey}}")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"id4ns\": []\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/api/v1/collections/:id4n/elements"))
    .header("authorization", "{{apiKey}}")
    .header("content-type", "application/json")
    .method("DELETE", HttpRequest.BodyPublishers.ofString("{\n  \"id4ns\": []\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  \"id4ns\": []\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/api/v1/collections/:id4n/elements")
  .delete(body)
  .addHeader("authorization", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/api/v1/collections/:id4n/elements")
  .header("authorization", "{{apiKey}}")
  .header("content-type", "application/json")
  .body("{\n  \"id4ns\": []\n}")
  .asString();
const data = JSON.stringify({
  id4ns: []
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('DELETE', '{{baseUrl}}/api/v1/collections/:id4n/elements');
xhr.setRequestHeader('authorization', '{{apiKey}}');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/api/v1/collections/:id4n/elements',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  data: {id4ns: []}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/api/v1/collections/:id4n/elements';
const options = {
  method: 'DELETE',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"id4ns":[]}'
};

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}}/api/v1/collections/:id4n/elements',
  method: 'DELETE',
  headers: {
    authorization: '{{apiKey}}',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "id4ns": []\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"id4ns\": []\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/api/v1/collections/:id4n/elements")
  .delete(body)
  .addHeader("authorization", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/api/v1/collections/:id4n/elements',
  headers: {
    authorization: '{{apiKey}}',
    '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({id4ns: []}));
req.end();
const request = require('request');

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/api/v1/collections/:id4n/elements',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  body: {id4ns: []},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('DELETE', '{{baseUrl}}/api/v1/collections/:id4n/elements');

req.headers({
  authorization: '{{apiKey}}',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  id4ns: []
});

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}}/api/v1/collections/:id4n/elements',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  data: {id4ns: []}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/api/v1/collections/:id4n/elements';
const options = {
  method: 'DELETE',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"id4ns":[]}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"authorization": @"{{apiKey}}",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"id4ns": @[  ] };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/api/v1/collections/:id4n/elements"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"DELETE"];
[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}}/api/v1/collections/:id4n/elements" in
let headers = Header.add_list (Header.init ()) [
  ("authorization", "{{apiKey}}");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"id4ns\": []\n}" in

Client.call ~headers ~body `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/api/v1/collections/:id4n/elements",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
  CURLOPT_POSTFIELDS => json_encode([
    'id4ns' => [
        
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "authorization: {{apiKey}}",
    "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('DELETE', '{{baseUrl}}/api/v1/collections/:id4n/elements', [
  'body' => '{
  "id4ns": []
}',
  'headers' => [
    'authorization' => '{{apiKey}}',
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/api/v1/collections/:id4n/elements');
$request->setMethod(HTTP_METH_DELETE);

$request->setHeaders([
  'authorization' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'id4ns' => [
    
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'id4ns' => [
    
  ]
]));
$request->setRequestUrl('{{baseUrl}}/api/v1/collections/:id4n/elements');
$request->setRequestMethod('DELETE');
$request->setBody($body);

$request->setHeaders([
  'authorization' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/api/v1/collections/:id4n/elements' -Method DELETE -Headers $headers -ContentType 'application/json' -Body '{
  "id4ns": []
}'
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/api/v1/collections/:id4n/elements' -Method DELETE -Headers $headers -ContentType 'application/json' -Body '{
  "id4ns": []
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"id4ns\": []\n}"

headers = {
    'authorization': "{{apiKey}}",
    'content-type': "application/json"
}

conn.request("DELETE", "/baseUrl/api/v1/collections/:id4n/elements", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/api/v1/collections/:id4n/elements"

payload = { "id4ns": [] }
headers = {
    "authorization": "{{apiKey}}",
    "content-type": "application/json"
}

response = requests.delete(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/api/v1/collections/:id4n/elements"

payload <- "{\n  \"id4ns\": []\n}"

encode <- "json"

response <- VERB("DELETE", url, body = payload, add_headers('authorization' = '{{apiKey}}'), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/api/v1/collections/:id4n/elements")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)
request["authorization"] = '{{apiKey}}'
request["content-type"] = 'application/json'
request.body = "{\n  \"id4ns\": []\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.delete('/baseUrl/api/v1/collections/:id4n/elements') do |req|
  req.headers['authorization'] = '{{apiKey}}'
  req.body = "{\n  \"id4ns\": []\n}"
end

puts response.status
puts response.body
use std::str::FromStr;
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/api/v1/collections/:id4n/elements";

    let payload = json!({"id4ns": ()});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("authorization", "{{apiKey}}".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("DELETE").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request DELETE \
  --url {{baseUrl}}/api/v1/collections/:id4n/elements \
  --header 'authorization: {{apiKey}}' \
  --header 'content-type: application/json' \
  --data '{
  "id4ns": []
}'
echo '{
  "id4ns": []
}' |  \
  http DELETE {{baseUrl}}/api/v1/collections/:id4n/elements \
  authorization:'{{apiKey}}' \
  content-type:application/json
wget --quiet \
  --method DELETE \
  --header 'authorization: {{apiKey}}' \
  --header 'content-type: application/json' \
  --body-data '{\n  "id4ns": []\n}' \
  --output-document \
  - {{baseUrl}}/api/v1/collections/:id4n/elements
import Foundation

let headers = [
  "authorization": "{{apiKey}}",
  "content-type": "application/json"
]
let parameters = ["id4ns": []] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/api/v1/collections/:id4n/elements")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "DELETE"
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()
GET Retrieve ID4n properties
{{baseUrl}}/api/v1/id4ns/:id4n/properties
HEADERS

Authorization
{{apiKey}}
QUERY PARAMS

id4n
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/api/v1/id4ns/:id4n/properties");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "authorization: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/api/v1/id4ns/:id4n/properties" {:headers {:authorization "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/api/v1/id4ns/:id4n/properties"
headers = HTTP::Headers{
  "authorization" => "{{apiKey}}"
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/api/v1/id4ns/:id4n/properties"),
    Headers =
    {
        { "authorization", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/api/v1/id4ns/:id4n/properties");
var request = new RestRequest("", Method.Get);
request.AddHeader("authorization", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/api/v1/id4ns/:id4n/properties"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("authorization", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/api/v1/id4ns/:id4n/properties HTTP/1.1
Authorization: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/api/v1/id4ns/:id4n/properties")
  .setHeader("authorization", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/api/v1/id4ns/:id4n/properties"))
    .header("authorization", "{{apiKey}}")
    .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}}/api/v1/id4ns/:id4n/properties")
  .get()
  .addHeader("authorization", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/api/v1/id4ns/:id4n/properties")
  .header("authorization", "{{apiKey}}")
  .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}}/api/v1/id4ns/:id4n/properties');
xhr.setRequestHeader('authorization', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/api/v1/id4ns/:id4n/properties',
  headers: {authorization: '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/api/v1/id4ns/:id4n/properties';
const options = {method: 'GET', headers: {authorization: '{{apiKey}}'}};

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}}/api/v1/id4ns/:id4n/properties',
  method: 'GET',
  headers: {
    authorization: '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/api/v1/id4ns/:id4n/properties")
  .get()
  .addHeader("authorization", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/api/v1/id4ns/:id4n/properties',
  headers: {
    authorization: '{{apiKey}}'
  }
};

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}}/api/v1/id4ns/:id4n/properties',
  headers: {authorization: '{{apiKey}}'}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/api/v1/id4ns/:id4n/properties');

req.headers({
  authorization: '{{apiKey}}'
});

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}}/api/v1/id4ns/:id4n/properties',
  headers: {authorization: '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/api/v1/id4ns/:id4n/properties';
const options = {method: 'GET', headers: {authorization: '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"authorization": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/api/v1/id4ns/:id4n/properties"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

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}}/api/v1/id4ns/:id4n/properties" in
let headers = Header.add (Header.init ()) "authorization" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/api/v1/id4ns/:id4n/properties",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "authorization: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/api/v1/id4ns/:id4n/properties', [
  'headers' => [
    'authorization' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/api/v1/id4ns/:id4n/properties');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'authorization' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/api/v1/id4ns/:id4n/properties');
$request->setRequestMethod('GET');
$request->setHeaders([
  'authorization' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/api/v1/id4ns/:id4n/properties' -Method GET -Headers $headers
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/api/v1/id4ns/:id4n/properties' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'authorization': "{{apiKey}}" }

conn.request("GET", "/baseUrl/api/v1/id4ns/:id4n/properties", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/api/v1/id4ns/:id4n/properties"

headers = {"authorization": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/api/v1/id4ns/:id4n/properties"

response <- VERB("GET", url, add_headers('authorization' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/api/v1/id4ns/:id4n/properties")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["authorization"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/api/v1/id4ns/:id4n/properties') do |req|
  req.headers['authorization'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/api/v1/id4ns/:id4n/properties";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("authorization", "{{apiKey}}".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/api/v1/id4ns/:id4n/properties \
  --header 'authorization: {{apiKey}}'
http GET {{baseUrl}}/api/v1/id4ns/:id4n/properties \
  authorization:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'authorization: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/api/v1/id4ns/:id4n/properties
import Foundation

let headers = ["authorization": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/api/v1/id4ns/:id4n/properties")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

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()
PATCH Update collection
{{baseUrl}}/api/v1/collections/:id4n
HEADERS

Authorization
{{apiKey}}
QUERY PARAMS

id4n
BODY json

{
  "createdTimestamp": 0,
  "holderOrganizationId": "",
  "id4n": "",
  "label": "",
  "ownerOrganizationId": "",
  "physicalState": "",
  "type": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PATCH");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/api/v1/collections/:id4n");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "authorization: {{apiKey}}");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"createdTimestamp\": 0,\n  \"holderOrganizationId\": \"\",\n  \"id4n\": \"\",\n  \"label\": \"\",\n  \"ownerOrganizationId\": \"\",\n  \"physicalState\": \"\",\n  \"type\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/patch "{{baseUrl}}/api/v1/collections/:id4n" {:headers {:authorization "{{apiKey}}"}
                                                                      :content-type :json
                                                                      :form-params {:createdTimestamp 0
                                                                                    :holderOrganizationId ""
                                                                                    :id4n ""
                                                                                    :label ""
                                                                                    :ownerOrganizationId ""
                                                                                    :physicalState ""
                                                                                    :type ""}})
require "http/client"

url = "{{baseUrl}}/api/v1/collections/:id4n"
headers = HTTP::Headers{
  "authorization" => "{{apiKey}}"
  "content-type" => "application/json"
}
reqBody = "{\n  \"createdTimestamp\": 0,\n  \"holderOrganizationId\": \"\",\n  \"id4n\": \"\",\n  \"label\": \"\",\n  \"ownerOrganizationId\": \"\",\n  \"physicalState\": \"\",\n  \"type\": \"\"\n}"

response = HTTP::Client.patch url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Patch,
    RequestUri = new Uri("{{baseUrl}}/api/v1/collections/:id4n"),
    Headers =
    {
        { "authorization", "{{apiKey}}" },
    },
    Content = new StringContent("{\n  \"createdTimestamp\": 0,\n  \"holderOrganizationId\": \"\",\n  \"id4n\": \"\",\n  \"label\": \"\",\n  \"ownerOrganizationId\": \"\",\n  \"physicalState\": \"\",\n  \"type\": \"\"\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}}/api/v1/collections/:id4n");
var request = new RestRequest("", Method.Patch);
request.AddHeader("authorization", "{{apiKey}}");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"createdTimestamp\": 0,\n  \"holderOrganizationId\": \"\",\n  \"id4n\": \"\",\n  \"label\": \"\",\n  \"ownerOrganizationId\": \"\",\n  \"physicalState\": \"\",\n  \"type\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/api/v1/collections/:id4n"

	payload := strings.NewReader("{\n  \"createdTimestamp\": 0,\n  \"holderOrganizationId\": \"\",\n  \"id4n\": \"\",\n  \"label\": \"\",\n  \"ownerOrganizationId\": \"\",\n  \"physicalState\": \"\",\n  \"type\": \"\"\n}")

	req, _ := http.NewRequest("PATCH", url, payload)

	req.Header.Add("authorization", "{{apiKey}}")
	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))

}
PATCH /baseUrl/api/v1/collections/:id4n HTTP/1.1
Authorization: {{apiKey}}
Content-Type: application/json
Host: example.com
Content-Length: 152

{
  "createdTimestamp": 0,
  "holderOrganizationId": "",
  "id4n": "",
  "label": "",
  "ownerOrganizationId": "",
  "physicalState": "",
  "type": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PATCH", "{{baseUrl}}/api/v1/collections/:id4n")
  .setHeader("authorization", "{{apiKey}}")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"createdTimestamp\": 0,\n  \"holderOrganizationId\": \"\",\n  \"id4n\": \"\",\n  \"label\": \"\",\n  \"ownerOrganizationId\": \"\",\n  \"physicalState\": \"\",\n  \"type\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/api/v1/collections/:id4n"))
    .header("authorization", "{{apiKey}}")
    .header("content-type", "application/json")
    .method("PATCH", HttpRequest.BodyPublishers.ofString("{\n  \"createdTimestamp\": 0,\n  \"holderOrganizationId\": \"\",\n  \"id4n\": \"\",\n  \"label\": \"\",\n  \"ownerOrganizationId\": \"\",\n  \"physicalState\": \"\",\n  \"type\": \"\"\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  \"createdTimestamp\": 0,\n  \"holderOrganizationId\": \"\",\n  \"id4n\": \"\",\n  \"label\": \"\",\n  \"ownerOrganizationId\": \"\",\n  \"physicalState\": \"\",\n  \"type\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/api/v1/collections/:id4n")
  .patch(body)
  .addHeader("authorization", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.patch("{{baseUrl}}/api/v1/collections/:id4n")
  .header("authorization", "{{apiKey}}")
  .header("content-type", "application/json")
  .body("{\n  \"createdTimestamp\": 0,\n  \"holderOrganizationId\": \"\",\n  \"id4n\": \"\",\n  \"label\": \"\",\n  \"ownerOrganizationId\": \"\",\n  \"physicalState\": \"\",\n  \"type\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  createdTimestamp: 0,
  holderOrganizationId: '',
  id4n: '',
  label: '',
  ownerOrganizationId: '',
  physicalState: '',
  type: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PATCH', '{{baseUrl}}/api/v1/collections/:id4n');
xhr.setRequestHeader('authorization', '{{apiKey}}');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PATCH',
  url: '{{baseUrl}}/api/v1/collections/:id4n',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  data: {
    createdTimestamp: 0,
    holderOrganizationId: '',
    id4n: '',
    label: '',
    ownerOrganizationId: '',
    physicalState: '',
    type: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/api/v1/collections/:id4n';
const options = {
  method: 'PATCH',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"createdTimestamp":0,"holderOrganizationId":"","id4n":"","label":"","ownerOrganizationId":"","physicalState":"","type":""}'
};

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}}/api/v1/collections/:id4n',
  method: 'PATCH',
  headers: {
    authorization: '{{apiKey}}',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "createdTimestamp": 0,\n  "holderOrganizationId": "",\n  "id4n": "",\n  "label": "",\n  "ownerOrganizationId": "",\n  "physicalState": "",\n  "type": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"createdTimestamp\": 0,\n  \"holderOrganizationId\": \"\",\n  \"id4n\": \"\",\n  \"label\": \"\",\n  \"ownerOrganizationId\": \"\",\n  \"physicalState\": \"\",\n  \"type\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/api/v1/collections/:id4n")
  .patch(body)
  .addHeader("authorization", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PATCH',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/api/v1/collections/:id4n',
  headers: {
    authorization: '{{apiKey}}',
    '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({
  createdTimestamp: 0,
  holderOrganizationId: '',
  id4n: '',
  label: '',
  ownerOrganizationId: '',
  physicalState: '',
  type: ''
}));
req.end();
const request = require('request');

const options = {
  method: 'PATCH',
  url: '{{baseUrl}}/api/v1/collections/:id4n',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  body: {
    createdTimestamp: 0,
    holderOrganizationId: '',
    id4n: '',
    label: '',
    ownerOrganizationId: '',
    physicalState: '',
    type: ''
  },
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('PATCH', '{{baseUrl}}/api/v1/collections/:id4n');

req.headers({
  authorization: '{{apiKey}}',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  createdTimestamp: 0,
  holderOrganizationId: '',
  id4n: '',
  label: '',
  ownerOrganizationId: '',
  physicalState: '',
  type: ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'PATCH',
  url: '{{baseUrl}}/api/v1/collections/:id4n',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  data: {
    createdTimestamp: 0,
    holderOrganizationId: '',
    id4n: '',
    label: '',
    ownerOrganizationId: '',
    physicalState: '',
    type: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/api/v1/collections/:id4n';
const options = {
  method: 'PATCH',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"createdTimestamp":0,"holderOrganizationId":"","id4n":"","label":"","ownerOrganizationId":"","physicalState":"","type":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"authorization": @"{{apiKey}}",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"createdTimestamp": @0,
                              @"holderOrganizationId": @"",
                              @"id4n": @"",
                              @"label": @"",
                              @"ownerOrganizationId": @"",
                              @"physicalState": @"",
                              @"type": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/api/v1/collections/:id4n"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"PATCH"];
[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}}/api/v1/collections/:id4n" in
let headers = Header.add_list (Header.init ()) [
  ("authorization", "{{apiKey}}");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"createdTimestamp\": 0,\n  \"holderOrganizationId\": \"\",\n  \"id4n\": \"\",\n  \"label\": \"\",\n  \"ownerOrganizationId\": \"\",\n  \"physicalState\": \"\",\n  \"type\": \"\"\n}" in

Client.call ~headers ~body `PATCH uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/api/v1/collections/:id4n",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PATCH",
  CURLOPT_POSTFIELDS => json_encode([
    'createdTimestamp' => 0,
    'holderOrganizationId' => '',
    'id4n' => '',
    'label' => '',
    'ownerOrganizationId' => '',
    'physicalState' => '',
    'type' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "authorization: {{apiKey}}",
    "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('PATCH', '{{baseUrl}}/api/v1/collections/:id4n', [
  'body' => '{
  "createdTimestamp": 0,
  "holderOrganizationId": "",
  "id4n": "",
  "label": "",
  "ownerOrganizationId": "",
  "physicalState": "",
  "type": ""
}',
  'headers' => [
    'authorization' => '{{apiKey}}',
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/api/v1/collections/:id4n');
$request->setMethod(HttpRequest::HTTP_METH_PATCH);

$request->setHeaders([
  'authorization' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'createdTimestamp' => 0,
  'holderOrganizationId' => '',
  'id4n' => '',
  'label' => '',
  'ownerOrganizationId' => '',
  'physicalState' => '',
  'type' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'createdTimestamp' => 0,
  'holderOrganizationId' => '',
  'id4n' => '',
  'label' => '',
  'ownerOrganizationId' => '',
  'physicalState' => '',
  'type' => ''
]));
$request->setRequestUrl('{{baseUrl}}/api/v1/collections/:id4n');
$request->setRequestMethod('PATCH');
$request->setBody($body);

$request->setHeaders([
  'authorization' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/api/v1/collections/:id4n' -Method PATCH -Headers $headers -ContentType 'application/json' -Body '{
  "createdTimestamp": 0,
  "holderOrganizationId": "",
  "id4n": "",
  "label": "",
  "ownerOrganizationId": "",
  "physicalState": "",
  "type": ""
}'
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/api/v1/collections/:id4n' -Method PATCH -Headers $headers -ContentType 'application/json' -Body '{
  "createdTimestamp": 0,
  "holderOrganizationId": "",
  "id4n": "",
  "label": "",
  "ownerOrganizationId": "",
  "physicalState": "",
  "type": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"createdTimestamp\": 0,\n  \"holderOrganizationId\": \"\",\n  \"id4n\": \"\",\n  \"label\": \"\",\n  \"ownerOrganizationId\": \"\",\n  \"physicalState\": \"\",\n  \"type\": \"\"\n}"

headers = {
    'authorization': "{{apiKey}}",
    'content-type': "application/json"
}

conn.request("PATCH", "/baseUrl/api/v1/collections/:id4n", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/api/v1/collections/:id4n"

payload = {
    "createdTimestamp": 0,
    "holderOrganizationId": "",
    "id4n": "",
    "label": "",
    "ownerOrganizationId": "",
    "physicalState": "",
    "type": ""
}
headers = {
    "authorization": "{{apiKey}}",
    "content-type": "application/json"
}

response = requests.patch(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/api/v1/collections/:id4n"

payload <- "{\n  \"createdTimestamp\": 0,\n  \"holderOrganizationId\": \"\",\n  \"id4n\": \"\",\n  \"label\": \"\",\n  \"ownerOrganizationId\": \"\",\n  \"physicalState\": \"\",\n  \"type\": \"\"\n}"

encode <- "json"

response <- VERB("PATCH", url, body = payload, add_headers('authorization' = '{{apiKey}}'), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/api/v1/collections/:id4n")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Patch.new(url)
request["authorization"] = '{{apiKey}}'
request["content-type"] = 'application/json'
request.body = "{\n  \"createdTimestamp\": 0,\n  \"holderOrganizationId\": \"\",\n  \"id4n\": \"\",\n  \"label\": \"\",\n  \"ownerOrganizationId\": \"\",\n  \"physicalState\": \"\",\n  \"type\": \"\"\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.patch('/baseUrl/api/v1/collections/:id4n') do |req|
  req.headers['authorization'] = '{{apiKey}}'
  req.body = "{\n  \"createdTimestamp\": 0,\n  \"holderOrganizationId\": \"\",\n  \"id4n\": \"\",\n  \"label\": \"\",\n  \"ownerOrganizationId\": \"\",\n  \"physicalState\": \"\",\n  \"type\": \"\"\n}"
end

puts response.status
puts response.body
use std::str::FromStr;
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/api/v1/collections/:id4n";

    let payload = json!({
        "createdTimestamp": 0,
        "holderOrganizationId": "",
        "id4n": "",
        "label": "",
        "ownerOrganizationId": "",
        "physicalState": "",
        "type": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("authorization", "{{apiKey}}".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PATCH").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PATCH \
  --url {{baseUrl}}/api/v1/collections/:id4n \
  --header 'authorization: {{apiKey}}' \
  --header 'content-type: application/json' \
  --data '{
  "createdTimestamp": 0,
  "holderOrganizationId": "",
  "id4n": "",
  "label": "",
  "ownerOrganizationId": "",
  "physicalState": "",
  "type": ""
}'
echo '{
  "createdTimestamp": 0,
  "holderOrganizationId": "",
  "id4n": "",
  "label": "",
  "ownerOrganizationId": "",
  "physicalState": "",
  "type": ""
}' |  \
  http PATCH {{baseUrl}}/api/v1/collections/:id4n \
  authorization:'{{apiKey}}' \
  content-type:application/json
wget --quiet \
  --method PATCH \
  --header 'authorization: {{apiKey}}' \
  --header 'content-type: application/json' \
  --body-data '{\n  "createdTimestamp": 0,\n  "holderOrganizationId": "",\n  "id4n": "",\n  "label": "",\n  "ownerOrganizationId": "",\n  "physicalState": "",\n  "type": ""\n}' \
  --output-document \
  - {{baseUrl}}/api/v1/collections/:id4n
import Foundation

let headers = [
  "authorization": "{{apiKey}}",
  "content-type": "application/json"
]
let parameters = [
  "createdTimestamp": 0,
  "holderOrganizationId": "",
  "id4n": "",
  "label": "",
  "ownerOrganizationId": "",
  "physicalState": "",
  "type": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/api/v1/collections/:id4n")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "PATCH"
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()
PATCH Change GUID information.
{{baseUrl}}/api/v1/guids/:id4n
HEADERS

Authorization
{{apiKey}}
QUERY PARAMS

id4n
BODY json

{
  "createdTimestamp": 0,
  "holderOrganizationId": "",
  "id4n": "",
  "ownerOrganizationId": "",
  "physicalState": "",
  "properties": {}
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PATCH");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/api/v1/guids/:id4n");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "authorization: {{apiKey}}");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"createdTimestamp\": 1517232722,\n  \"id4n\": \"3THvgrWxqgTFC4\",\n  \"properties\": \"de.example\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/patch "{{baseUrl}}/api/v1/guids/:id4n" {:headers {:authorization "{{apiKey}}"}
                                                                :content-type :json
                                                                :form-params {:createdTimestamp 1517232722
                                                                              :id4n "3THvgrWxqgTFC4"
                                                                              :properties "de.example"}})
require "http/client"

url = "{{baseUrl}}/api/v1/guids/:id4n"
headers = HTTP::Headers{
  "authorization" => "{{apiKey}}"
  "content-type" => "application/json"
}
reqBody = "{\n  \"createdTimestamp\": 1517232722,\n  \"id4n\": \"3THvgrWxqgTFC4\",\n  \"properties\": \"de.example\"\n}"

response = HTTP::Client.patch url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Patch,
    RequestUri = new Uri("{{baseUrl}}/api/v1/guids/:id4n"),
    Headers =
    {
        { "authorization", "{{apiKey}}" },
    },
    Content = new StringContent("{\n  \"createdTimestamp\": 1517232722,\n  \"id4n\": \"3THvgrWxqgTFC4\",\n  \"properties\": \"de.example\"\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}}/api/v1/guids/:id4n");
var request = new RestRequest("", Method.Patch);
request.AddHeader("authorization", "{{apiKey}}");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"createdTimestamp\": 1517232722,\n  \"id4n\": \"3THvgrWxqgTFC4\",\n  \"properties\": \"de.example\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/api/v1/guids/:id4n"

	payload := strings.NewReader("{\n  \"createdTimestamp\": 1517232722,\n  \"id4n\": \"3THvgrWxqgTFC4\",\n  \"properties\": \"de.example\"\n}")

	req, _ := http.NewRequest("PATCH", url, payload)

	req.Header.Add("authorization", "{{apiKey}}")
	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))

}
PATCH /baseUrl/api/v1/guids/:id4n HTTP/1.1
Authorization: {{apiKey}}
Content-Type: application/json
Host: example.com
Content-Length: 94

{
  "createdTimestamp": 1517232722,
  "id4n": "3THvgrWxqgTFC4",
  "properties": "de.example"
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PATCH", "{{baseUrl}}/api/v1/guids/:id4n")
  .setHeader("authorization", "{{apiKey}}")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"createdTimestamp\": 1517232722,\n  \"id4n\": \"3THvgrWxqgTFC4\",\n  \"properties\": \"de.example\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/api/v1/guids/:id4n"))
    .header("authorization", "{{apiKey}}")
    .header("content-type", "application/json")
    .method("PATCH", HttpRequest.BodyPublishers.ofString("{\n  \"createdTimestamp\": 1517232722,\n  \"id4n\": \"3THvgrWxqgTFC4\",\n  \"properties\": \"de.example\"\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  \"createdTimestamp\": 1517232722,\n  \"id4n\": \"3THvgrWxqgTFC4\",\n  \"properties\": \"de.example\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/api/v1/guids/:id4n")
  .patch(body)
  .addHeader("authorization", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.patch("{{baseUrl}}/api/v1/guids/:id4n")
  .header("authorization", "{{apiKey}}")
  .header("content-type", "application/json")
  .body("{\n  \"createdTimestamp\": 1517232722,\n  \"id4n\": \"3THvgrWxqgTFC4\",\n  \"properties\": \"de.example\"\n}")
  .asString();
const data = JSON.stringify({
  createdTimestamp: 1517232722,
  id4n: '3THvgrWxqgTFC4',
  properties: 'de.example'
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PATCH', '{{baseUrl}}/api/v1/guids/:id4n');
xhr.setRequestHeader('authorization', '{{apiKey}}');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PATCH',
  url: '{{baseUrl}}/api/v1/guids/:id4n',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  data: {createdTimestamp: 1517232722, id4n: '3THvgrWxqgTFC4', properties: 'de.example'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/api/v1/guids/:id4n';
const options = {
  method: 'PATCH',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"createdTimestamp":1517232722,"id4n":"3THvgrWxqgTFC4","properties":"de.example"}'
};

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}}/api/v1/guids/:id4n',
  method: 'PATCH',
  headers: {
    authorization: '{{apiKey}}',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "createdTimestamp": 1517232722,\n  "id4n": "3THvgrWxqgTFC4",\n  "properties": "de.example"\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"createdTimestamp\": 1517232722,\n  \"id4n\": \"3THvgrWxqgTFC4\",\n  \"properties\": \"de.example\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/api/v1/guids/:id4n")
  .patch(body)
  .addHeader("authorization", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PATCH',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/api/v1/guids/:id4n',
  headers: {
    authorization: '{{apiKey}}',
    '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({createdTimestamp: 1517232722, id4n: '3THvgrWxqgTFC4', properties: 'de.example'}));
req.end();
const request = require('request');

const options = {
  method: 'PATCH',
  url: '{{baseUrl}}/api/v1/guids/:id4n',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  body: {createdTimestamp: 1517232722, id4n: '3THvgrWxqgTFC4', properties: 'de.example'},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('PATCH', '{{baseUrl}}/api/v1/guids/:id4n');

req.headers({
  authorization: '{{apiKey}}',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  createdTimestamp: 1517232722,
  id4n: '3THvgrWxqgTFC4',
  properties: 'de.example'
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'PATCH',
  url: '{{baseUrl}}/api/v1/guids/:id4n',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  data: {createdTimestamp: 1517232722, id4n: '3THvgrWxqgTFC4', properties: 'de.example'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/api/v1/guids/:id4n';
const options = {
  method: 'PATCH',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"createdTimestamp":1517232722,"id4n":"3THvgrWxqgTFC4","properties":"de.example"}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"authorization": @"{{apiKey}}",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"createdTimestamp": @1517232722,
                              @"id4n": @"3THvgrWxqgTFC4",
                              @"properties": @"de.example" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/api/v1/guids/:id4n"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"PATCH"];
[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}}/api/v1/guids/:id4n" in
let headers = Header.add_list (Header.init ()) [
  ("authorization", "{{apiKey}}");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"createdTimestamp\": 1517232722,\n  \"id4n\": \"3THvgrWxqgTFC4\",\n  \"properties\": \"de.example\"\n}" in

Client.call ~headers ~body `PATCH uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/api/v1/guids/:id4n",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PATCH",
  CURLOPT_POSTFIELDS => json_encode([
    'createdTimestamp' => 1517232722,
    'id4n' => '3THvgrWxqgTFC4',
    'properties' => 'de.example'
  ]),
  CURLOPT_HTTPHEADER => [
    "authorization: {{apiKey}}",
    "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('PATCH', '{{baseUrl}}/api/v1/guids/:id4n', [
  'body' => '{
  "createdTimestamp": 1517232722,
  "id4n": "3THvgrWxqgTFC4",
  "properties": "de.example"
}',
  'headers' => [
    'authorization' => '{{apiKey}}',
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/api/v1/guids/:id4n');
$request->setMethod(HttpRequest::HTTP_METH_PATCH);

$request->setHeaders([
  'authorization' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'createdTimestamp' => 1517232722,
  'id4n' => '3THvgrWxqgTFC4',
  'properties' => 'de.example'
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'createdTimestamp' => 1517232722,
  'id4n' => '3THvgrWxqgTFC4',
  'properties' => 'de.example'
]));
$request->setRequestUrl('{{baseUrl}}/api/v1/guids/:id4n');
$request->setRequestMethod('PATCH');
$request->setBody($body);

$request->setHeaders([
  'authorization' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/api/v1/guids/:id4n' -Method PATCH -Headers $headers -ContentType 'application/json' -Body '{
  "createdTimestamp": 1517232722,
  "id4n": "3THvgrWxqgTFC4",
  "properties": "de.example"
}'
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/api/v1/guids/:id4n' -Method PATCH -Headers $headers -ContentType 'application/json' -Body '{
  "createdTimestamp": 1517232722,
  "id4n": "3THvgrWxqgTFC4",
  "properties": "de.example"
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"createdTimestamp\": 1517232722,\n  \"id4n\": \"3THvgrWxqgTFC4\",\n  \"properties\": \"de.example\"\n}"

headers = {
    'authorization': "{{apiKey}}",
    'content-type': "application/json"
}

conn.request("PATCH", "/baseUrl/api/v1/guids/:id4n", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/api/v1/guids/:id4n"

payload = {
    "createdTimestamp": 1517232722,
    "id4n": "3THvgrWxqgTFC4",
    "properties": "de.example"
}
headers = {
    "authorization": "{{apiKey}}",
    "content-type": "application/json"
}

response = requests.patch(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/api/v1/guids/:id4n"

payload <- "{\n  \"createdTimestamp\": 1517232722,\n  \"id4n\": \"3THvgrWxqgTFC4\",\n  \"properties\": \"de.example\"\n}"

encode <- "json"

response <- VERB("PATCH", url, body = payload, add_headers('authorization' = '{{apiKey}}'), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/api/v1/guids/:id4n")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Patch.new(url)
request["authorization"] = '{{apiKey}}'
request["content-type"] = 'application/json'
request.body = "{\n  \"createdTimestamp\": 1517232722,\n  \"id4n\": \"3THvgrWxqgTFC4\",\n  \"properties\": \"de.example\"\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.patch('/baseUrl/api/v1/guids/:id4n') do |req|
  req.headers['authorization'] = '{{apiKey}}'
  req.body = "{\n  \"createdTimestamp\": 1517232722,\n  \"id4n\": \"3THvgrWxqgTFC4\",\n  \"properties\": \"de.example\"\n}"
end

puts response.status
puts response.body
use std::str::FromStr;
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/api/v1/guids/:id4n";

    let payload = json!({
        "createdTimestamp": 1517232722,
        "id4n": "3THvgrWxqgTFC4",
        "properties": "de.example"
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("authorization", "{{apiKey}}".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PATCH").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PATCH \
  --url {{baseUrl}}/api/v1/guids/:id4n \
  --header 'authorization: {{apiKey}}' \
  --header 'content-type: application/json' \
  --data '{
  "createdTimestamp": 1517232722,
  "id4n": "3THvgrWxqgTFC4",
  "properties": "de.example"
}'
echo '{
  "createdTimestamp": 1517232722,
  "id4n": "3THvgrWxqgTFC4",
  "properties": "de.example"
}' |  \
  http PATCH {{baseUrl}}/api/v1/guids/:id4n \
  authorization:'{{apiKey}}' \
  content-type:application/json
wget --quiet \
  --method PATCH \
  --header 'authorization: {{apiKey}}' \
  --header 'content-type: application/json' \
  --body-data '{\n  "createdTimestamp": 1517232722,\n  "id4n": "3THvgrWxqgTFC4",\n  "properties": "de.example"\n}' \
  --output-document \
  - {{baseUrl}}/api/v1/guids/:id4n
import Foundation

let headers = [
  "authorization": "{{apiKey}}",
  "content-type": "application/json"
]
let parameters = [
  "createdTimestamp": 1517232722,
  "id4n": "3THvgrWxqgTFC4",
  "properties": "de.example"
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/api/v1/guids/:id4n")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "PATCH"
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 Create GUID(s)
{{baseUrl}}/api/v1/guids
HEADERS

Authorization
{{apiKey}}
BODY json

{
  "count": 0,
  "length": 0,
  "organizationId": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/api/v1/guids");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "authorization: {{apiKey}}");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"count\": 1,\n  \"length\": 40,\n  \"organizationId\": \"de.acme\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/api/v1/guids" {:headers {:authorization "{{apiKey}}"}
                                                         :content-type :json
                                                         :form-params {:count 1
                                                                       :length 40
                                                                       :organizationId "de.acme"}})
require "http/client"

url = "{{baseUrl}}/api/v1/guids"
headers = HTTP::Headers{
  "authorization" => "{{apiKey}}"
  "content-type" => "application/json"
}
reqBody = "{\n  \"count\": 1,\n  \"length\": 40,\n  \"organizationId\": \"de.acme\"\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}}/api/v1/guids"),
    Headers =
    {
        { "authorization", "{{apiKey}}" },
    },
    Content = new StringContent("{\n  \"count\": 1,\n  \"length\": 40,\n  \"organizationId\": \"de.acme\"\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}}/api/v1/guids");
var request = new RestRequest("", Method.Post);
request.AddHeader("authorization", "{{apiKey}}");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"count\": 1,\n  \"length\": 40,\n  \"organizationId\": \"de.acme\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/api/v1/guids"

	payload := strings.NewReader("{\n  \"count\": 1,\n  \"length\": 40,\n  \"organizationId\": \"de.acme\"\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("authorization", "{{apiKey}}")
	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/api/v1/guids HTTP/1.1
Authorization: {{apiKey}}
Content-Type: application/json
Host: example.com
Content-Length: 63

{
  "count": 1,
  "length": 40,
  "organizationId": "de.acme"
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/api/v1/guids")
  .setHeader("authorization", "{{apiKey}}")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"count\": 1,\n  \"length\": 40,\n  \"organizationId\": \"de.acme\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/api/v1/guids"))
    .header("authorization", "{{apiKey}}")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"count\": 1,\n  \"length\": 40,\n  \"organizationId\": \"de.acme\"\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  \"count\": 1,\n  \"length\": 40,\n  \"organizationId\": \"de.acme\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/api/v1/guids")
  .post(body)
  .addHeader("authorization", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/api/v1/guids")
  .header("authorization", "{{apiKey}}")
  .header("content-type", "application/json")
  .body("{\n  \"count\": 1,\n  \"length\": 40,\n  \"organizationId\": \"de.acme\"\n}")
  .asString();
const data = JSON.stringify({
  count: 1,
  length: 40,
  organizationId: 'de.acme'
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/api/v1/guids');
xhr.setRequestHeader('authorization', '{{apiKey}}');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/api/v1/guids',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  data: {count: 1, length: 40, organizationId: 'de.acme'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/api/v1/guids';
const options = {
  method: 'POST',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"count":1,"length":40,"organizationId":"de.acme"}'
};

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}}/api/v1/guids',
  method: 'POST',
  headers: {
    authorization: '{{apiKey}}',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "count": 1,\n  "length": 40,\n  "organizationId": "de.acme"\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"count\": 1,\n  \"length\": 40,\n  \"organizationId\": \"de.acme\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/api/v1/guids")
  .post(body)
  .addHeader("authorization", "{{apiKey}}")
  .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/api/v1/guids',
  headers: {
    authorization: '{{apiKey}}',
    '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({count: 1, length: 40, organizationId: 'de.acme'}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/api/v1/guids',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  body: {count: 1, length: 40, organizationId: 'de.acme'},
  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}}/api/v1/guids');

req.headers({
  authorization: '{{apiKey}}',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  count: 1,
  length: 40,
  organizationId: 'de.acme'
});

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}}/api/v1/guids',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  data: {count: 1, length: 40, organizationId: 'de.acme'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/api/v1/guids';
const options = {
  method: 'POST',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"count":1,"length":40,"organizationId":"de.acme"}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"authorization": @"{{apiKey}}",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"count": @1,
                              @"length": @40,
                              @"organizationId": @"de.acme" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/api/v1/guids"]
                                                       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}}/api/v1/guids" in
let headers = Header.add_list (Header.init ()) [
  ("authorization", "{{apiKey}}");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"count\": 1,\n  \"length\": 40,\n  \"organizationId\": \"de.acme\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/api/v1/guids",
  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([
    'count' => 1,
    'length' => 40,
    'organizationId' => 'de.acme'
  ]),
  CURLOPT_HTTPHEADER => [
    "authorization: {{apiKey}}",
    "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}}/api/v1/guids', [
  'body' => '{
  "count": 1,
  "length": 40,
  "organizationId": "de.acme"
}',
  'headers' => [
    'authorization' => '{{apiKey}}',
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/api/v1/guids');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'authorization' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'count' => 1,
  'length' => 40,
  'organizationId' => 'de.acme'
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'count' => 1,
  'length' => 40,
  'organizationId' => 'de.acme'
]));
$request->setRequestUrl('{{baseUrl}}/api/v1/guids');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'authorization' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/api/v1/guids' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "count": 1,
  "length": 40,
  "organizationId": "de.acme"
}'
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/api/v1/guids' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "count": 1,
  "length": 40,
  "organizationId": "de.acme"
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"count\": 1,\n  \"length\": 40,\n  \"organizationId\": \"de.acme\"\n}"

headers = {
    'authorization': "{{apiKey}}",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/api/v1/guids", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/api/v1/guids"

payload = {
    "count": 1,
    "length": 40,
    "organizationId": "de.acme"
}
headers = {
    "authorization": "{{apiKey}}",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/api/v1/guids"

payload <- "{\n  \"count\": 1,\n  \"length\": 40,\n  \"organizationId\": \"de.acme\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('authorization' = '{{apiKey}}'), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/api/v1/guids")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["authorization"] = '{{apiKey}}'
request["content-type"] = 'application/json'
request.body = "{\n  \"count\": 1,\n  \"length\": 40,\n  \"organizationId\": \"de.acme\"\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/api/v1/guids') do |req|
  req.headers['authorization'] = '{{apiKey}}'
  req.body = "{\n  \"count\": 1,\n  \"length\": 40,\n  \"organizationId\": \"de.acme\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/api/v1/guids";

    let payload = json!({
        "count": 1,
        "length": 40,
        "organizationId": "de.acme"
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("authorization", "{{apiKey}}".parse().unwrap());
    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}}/api/v1/guids \
  --header 'authorization: {{apiKey}}' \
  --header 'content-type: application/json' \
  --data '{
  "count": 1,
  "length": 40,
  "organizationId": "de.acme"
}'
echo '{
  "count": 1,
  "length": 40,
  "organizationId": "de.acme"
}' |  \
  http POST {{baseUrl}}/api/v1/guids \
  authorization:'{{apiKey}}' \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'authorization: {{apiKey}}' \
  --header 'content-type: application/json' \
  --body-data '{\n  "count": 1,\n  "length": 40,\n  "organizationId": "de.acme"\n}' \
  --output-document \
  - {{baseUrl}}/api/v1/guids
import Foundation

let headers = [
  "authorization": "{{apiKey}}",
  "content-type": "application/json"
]
let parameters = [
  "count": 1,
  "length": 40,
  "organizationId": "de.acme"
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/api/v1/guids")! 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 Import GS1-MAPP codes
{{baseUrl}}/api/v1/import/gs1
HEADERS

Authorization
{{apiKey}}
BODY json

{
  "listOfGS1s": {
    "codes": []
  },
  "organizationId": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/api/v1/import/gs1");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "authorization: {{apiKey}}");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"organizationId\": \"de.acme\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/api/v1/import/gs1" {:headers {:authorization "{{apiKey}}"}
                                                              :content-type :json
                                                              :form-params {:organizationId "de.acme"}})
require "http/client"

url = "{{baseUrl}}/api/v1/import/gs1"
headers = HTTP::Headers{
  "authorization" => "{{apiKey}}"
  "content-type" => "application/json"
}
reqBody = "{\n  \"organizationId\": \"de.acme\"\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}}/api/v1/import/gs1"),
    Headers =
    {
        { "authorization", "{{apiKey}}" },
    },
    Content = new StringContent("{\n  \"organizationId\": \"de.acme\"\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}}/api/v1/import/gs1");
var request = new RestRequest("", Method.Post);
request.AddHeader("authorization", "{{apiKey}}");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"organizationId\": \"de.acme\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/api/v1/import/gs1"

	payload := strings.NewReader("{\n  \"organizationId\": \"de.acme\"\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("authorization", "{{apiKey}}")
	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/api/v1/import/gs1 HTTP/1.1
Authorization: {{apiKey}}
Content-Type: application/json
Host: example.com
Content-Length: 33

{
  "organizationId": "de.acme"
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/api/v1/import/gs1")
  .setHeader("authorization", "{{apiKey}}")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"organizationId\": \"de.acme\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/api/v1/import/gs1"))
    .header("authorization", "{{apiKey}}")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"organizationId\": \"de.acme\"\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  \"organizationId\": \"de.acme\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/api/v1/import/gs1")
  .post(body)
  .addHeader("authorization", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/api/v1/import/gs1")
  .header("authorization", "{{apiKey}}")
  .header("content-type", "application/json")
  .body("{\n  \"organizationId\": \"de.acme\"\n}")
  .asString();
const data = JSON.stringify({
  organizationId: 'de.acme'
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/api/v1/import/gs1');
xhr.setRequestHeader('authorization', '{{apiKey}}');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/api/v1/import/gs1',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  data: {organizationId: 'de.acme'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/api/v1/import/gs1';
const options = {
  method: 'POST',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"organizationId":"de.acme"}'
};

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}}/api/v1/import/gs1',
  method: 'POST',
  headers: {
    authorization: '{{apiKey}}',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "organizationId": "de.acme"\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"organizationId\": \"de.acme\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/api/v1/import/gs1")
  .post(body)
  .addHeader("authorization", "{{apiKey}}")
  .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/api/v1/import/gs1',
  headers: {
    authorization: '{{apiKey}}',
    '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({organizationId: 'de.acme'}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/api/v1/import/gs1',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  body: {organizationId: 'de.acme'},
  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}}/api/v1/import/gs1');

req.headers({
  authorization: '{{apiKey}}',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  organizationId: 'de.acme'
});

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}}/api/v1/import/gs1',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  data: {organizationId: 'de.acme'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/api/v1/import/gs1';
const options = {
  method: 'POST',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"organizationId":"de.acme"}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"authorization": @"{{apiKey}}",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"organizationId": @"de.acme" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/api/v1/import/gs1"]
                                                       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}}/api/v1/import/gs1" in
let headers = Header.add_list (Header.init ()) [
  ("authorization", "{{apiKey}}");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"organizationId\": \"de.acme\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/api/v1/import/gs1",
  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([
    'organizationId' => 'de.acme'
  ]),
  CURLOPT_HTTPHEADER => [
    "authorization: {{apiKey}}",
    "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}}/api/v1/import/gs1', [
  'body' => '{
  "organizationId": "de.acme"
}',
  'headers' => [
    'authorization' => '{{apiKey}}',
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/api/v1/import/gs1');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'authorization' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'organizationId' => 'de.acme'
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'organizationId' => 'de.acme'
]));
$request->setRequestUrl('{{baseUrl}}/api/v1/import/gs1');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'authorization' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/api/v1/import/gs1' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "organizationId": "de.acme"
}'
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/api/v1/import/gs1' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "organizationId": "de.acme"
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"organizationId\": \"de.acme\"\n}"

headers = {
    'authorization': "{{apiKey}}",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/api/v1/import/gs1", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/api/v1/import/gs1"

payload = { "organizationId": "de.acme" }
headers = {
    "authorization": "{{apiKey}}",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/api/v1/import/gs1"

payload <- "{\n  \"organizationId\": \"de.acme\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('authorization' = '{{apiKey}}'), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/api/v1/import/gs1")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["authorization"] = '{{apiKey}}'
request["content-type"] = 'application/json'
request.body = "{\n  \"organizationId\": \"de.acme\"\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/api/v1/import/gs1') do |req|
  req.headers['authorization'] = '{{apiKey}}'
  req.body = "{\n  \"organizationId\": \"de.acme\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/api/v1/import/gs1";

    let payload = json!({"organizationId": "de.acme"});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("authorization", "{{apiKey}}".parse().unwrap());
    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}}/api/v1/import/gs1 \
  --header 'authorization: {{apiKey}}' \
  --header 'content-type: application/json' \
  --data '{
  "organizationId": "de.acme"
}'
echo '{
  "organizationId": "de.acme"
}' |  \
  http POST {{baseUrl}}/api/v1/import/gs1 \
  authorization:'{{apiKey}}' \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'authorization: {{apiKey}}' \
  --header 'content-type: application/json' \
  --body-data '{\n  "organizationId": "de.acme"\n}' \
  --output-document \
  - {{baseUrl}}/api/v1/import/gs1
import Foundation

let headers = [
  "authorization": "{{apiKey}}",
  "content-type": "application/json"
]
let parameters = ["organizationId": "de.acme"] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/api/v1/import/gs1")! 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()
GET Retrieve GUID information
{{baseUrl}}/api/v1/guids/:id4n
HEADERS

Authorization
{{apiKey}}
QUERY PARAMS

id4n
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/api/v1/guids/:id4n");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "authorization: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/api/v1/guids/:id4n" {:headers {:authorization "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/api/v1/guids/:id4n"
headers = HTTP::Headers{
  "authorization" => "{{apiKey}}"
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/api/v1/guids/:id4n"),
    Headers =
    {
        { "authorization", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/api/v1/guids/:id4n");
var request = new RestRequest("", Method.Get);
request.AddHeader("authorization", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/api/v1/guids/:id4n"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("authorization", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/api/v1/guids/:id4n HTTP/1.1
Authorization: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/api/v1/guids/:id4n")
  .setHeader("authorization", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/api/v1/guids/:id4n"))
    .header("authorization", "{{apiKey}}")
    .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}}/api/v1/guids/:id4n")
  .get()
  .addHeader("authorization", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/api/v1/guids/:id4n")
  .header("authorization", "{{apiKey}}")
  .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}}/api/v1/guids/:id4n');
xhr.setRequestHeader('authorization', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/api/v1/guids/:id4n',
  headers: {authorization: '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/api/v1/guids/:id4n';
const options = {method: 'GET', headers: {authorization: '{{apiKey}}'}};

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}}/api/v1/guids/:id4n',
  method: 'GET',
  headers: {
    authorization: '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/api/v1/guids/:id4n")
  .get()
  .addHeader("authorization", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/api/v1/guids/:id4n',
  headers: {
    authorization: '{{apiKey}}'
  }
};

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}}/api/v1/guids/:id4n',
  headers: {authorization: '{{apiKey}}'}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/api/v1/guids/:id4n');

req.headers({
  authorization: '{{apiKey}}'
});

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}}/api/v1/guids/:id4n',
  headers: {authorization: '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/api/v1/guids/:id4n';
const options = {method: 'GET', headers: {authorization: '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"authorization": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/api/v1/guids/:id4n"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

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}}/api/v1/guids/:id4n" in
let headers = Header.add (Header.init ()) "authorization" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/api/v1/guids/:id4n",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "authorization: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/api/v1/guids/:id4n', [
  'headers' => [
    'authorization' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/api/v1/guids/:id4n');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'authorization' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/api/v1/guids/:id4n');
$request->setRequestMethod('GET');
$request->setHeaders([
  'authorization' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/api/v1/guids/:id4n' -Method GET -Headers $headers
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/api/v1/guids/:id4n' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'authorization': "{{apiKey}}" }

conn.request("GET", "/baseUrl/api/v1/guids/:id4n", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/api/v1/guids/:id4n"

headers = {"authorization": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/api/v1/guids/:id4n"

response <- VERB("GET", url, add_headers('authorization' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/api/v1/guids/:id4n")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["authorization"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/api/v1/guids/:id4n') do |req|
  req.headers['authorization'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/api/v1/guids/:id4n";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("authorization", "{{apiKey}}".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/api/v1/guids/:id4n \
  --header 'authorization: {{apiKey}}'
http GET {{baseUrl}}/api/v1/guids/:id4n \
  authorization:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'authorization: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/api/v1/guids/:id4n
import Foundation

let headers = ["authorization": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/api/v1/guids/:id4n")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

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()
RESPONSE HEADERS

Content-Type
application/json
RESPONSE BODY json

{
  "createdTimestamp": 1517232722,
  "id4n": "3THvgrWxqgTFC4",
  "properties": "de.example"
}
RESPONSE HEADERS

Content-Type
application/xml
RESPONSE BODY xml

{
  "createdTimestamp": 1517232722,
  "id4n": "3THvgrWxqgTFC4",
  "properties": "de.example"
}
GET Retrieve GUIDs not in any collection
{{baseUrl}}/api/v1/guids/withoutCollection
HEADERS

Authorization
{{apiKey}}
QUERY PARAMS

organizationId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/api/v1/guids/withoutCollection?organizationId=");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "authorization: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/api/v1/guids/withoutCollection" {:headers {:authorization "{{apiKey}}"}
                                                                          :query-params {:organizationId ""}})
require "http/client"

url = "{{baseUrl}}/api/v1/guids/withoutCollection?organizationId="
headers = HTTP::Headers{
  "authorization" => "{{apiKey}}"
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/api/v1/guids/withoutCollection?organizationId="),
    Headers =
    {
        { "authorization", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/api/v1/guids/withoutCollection?organizationId=");
var request = new RestRequest("", Method.Get);
request.AddHeader("authorization", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/api/v1/guids/withoutCollection?organizationId="

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("authorization", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/api/v1/guids/withoutCollection?organizationId= HTTP/1.1
Authorization: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/api/v1/guids/withoutCollection?organizationId=")
  .setHeader("authorization", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/api/v1/guids/withoutCollection?organizationId="))
    .header("authorization", "{{apiKey}}")
    .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}}/api/v1/guids/withoutCollection?organizationId=")
  .get()
  .addHeader("authorization", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/api/v1/guids/withoutCollection?organizationId=")
  .header("authorization", "{{apiKey}}")
  .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}}/api/v1/guids/withoutCollection?organizationId=');
xhr.setRequestHeader('authorization', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/api/v1/guids/withoutCollection',
  params: {organizationId: ''},
  headers: {authorization: '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/api/v1/guids/withoutCollection?organizationId=';
const options = {method: 'GET', headers: {authorization: '{{apiKey}}'}};

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}}/api/v1/guids/withoutCollection?organizationId=',
  method: 'GET',
  headers: {
    authorization: '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/api/v1/guids/withoutCollection?organizationId=")
  .get()
  .addHeader("authorization", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/api/v1/guids/withoutCollection?organizationId=',
  headers: {
    authorization: '{{apiKey}}'
  }
};

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}}/api/v1/guids/withoutCollection',
  qs: {organizationId: ''},
  headers: {authorization: '{{apiKey}}'}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/api/v1/guids/withoutCollection');

req.query({
  organizationId: ''
});

req.headers({
  authorization: '{{apiKey}}'
});

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}}/api/v1/guids/withoutCollection',
  params: {organizationId: ''},
  headers: {authorization: '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/api/v1/guids/withoutCollection?organizationId=';
const options = {method: 'GET', headers: {authorization: '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"authorization": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/api/v1/guids/withoutCollection?organizationId="]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

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}}/api/v1/guids/withoutCollection?organizationId=" in
let headers = Header.add (Header.init ()) "authorization" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/api/v1/guids/withoutCollection?organizationId=",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "authorization: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/api/v1/guids/withoutCollection?organizationId=', [
  'headers' => [
    'authorization' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/api/v1/guids/withoutCollection');
$request->setMethod(HTTP_METH_GET);

$request->setQueryData([
  'organizationId' => ''
]);

$request->setHeaders([
  'authorization' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/api/v1/guids/withoutCollection');
$request->setRequestMethod('GET');
$request->setQuery(new http\QueryString([
  'organizationId' => ''
]));

$request->setHeaders([
  'authorization' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/api/v1/guids/withoutCollection?organizationId=' -Method GET -Headers $headers
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/api/v1/guids/withoutCollection?organizationId=' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'authorization': "{{apiKey}}" }

conn.request("GET", "/baseUrl/api/v1/guids/withoutCollection?organizationId=", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/api/v1/guids/withoutCollection"

querystring = {"organizationId":""}

headers = {"authorization": "{{apiKey}}"}

response = requests.get(url, headers=headers, params=querystring)

print(response.json())
library(httr)

url <- "{{baseUrl}}/api/v1/guids/withoutCollection"

queryString <- list(organizationId = "")

response <- VERB("GET", url, query = queryString, add_headers('authorization' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/api/v1/guids/withoutCollection?organizationId=")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["authorization"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/api/v1/guids/withoutCollection') do |req|
  req.headers['authorization'] = '{{apiKey}}'
  req.params['organizationId'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/api/v1/guids/withoutCollection";

    let querystring = [
        ("organizationId", ""),
    ];

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("authorization", "{{apiKey}}".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .query(&querystring)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url '{{baseUrl}}/api/v1/guids/withoutCollection?organizationId=' \
  --header 'authorization: {{apiKey}}'
http GET '{{baseUrl}}/api/v1/guids/withoutCollection?organizationId=' \
  authorization:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'authorization: {{apiKey}}' \
  --output-document \
  - '{{baseUrl}}/api/v1/guids/withoutCollection?organizationId='
import Foundation

let headers = ["authorization": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/api/v1/guids/withoutCollection?organizationId=")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

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()
RESPONSE HEADERS

Content-Type
application/json
RESPONSE BODY json

{
  "limit": 100,
  "offset": 0,
  "total": 200
}
RESPONSE HEADERS

Content-Type
application/xml
RESPONSE BODY xml

{
  "limit": 100,
  "offset": 0,
  "total": 200
}
GET Retrieve ID4n information
{{baseUrl}}/api/v1/id4ns/:id4n
HEADERS

Authorization
{{apiKey}}
QUERY PARAMS

id4n
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/api/v1/id4ns/:id4n");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "authorization: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/api/v1/id4ns/:id4n" {:headers {:authorization "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/api/v1/id4ns/:id4n"
headers = HTTP::Headers{
  "authorization" => "{{apiKey}}"
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/api/v1/id4ns/:id4n"),
    Headers =
    {
        { "authorization", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/api/v1/id4ns/:id4n");
var request = new RestRequest("", Method.Get);
request.AddHeader("authorization", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/api/v1/id4ns/:id4n"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("authorization", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/api/v1/id4ns/:id4n HTTP/1.1
Authorization: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/api/v1/id4ns/:id4n")
  .setHeader("authorization", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/api/v1/id4ns/:id4n"))
    .header("authorization", "{{apiKey}}")
    .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}}/api/v1/id4ns/:id4n")
  .get()
  .addHeader("authorization", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/api/v1/id4ns/:id4n")
  .header("authorization", "{{apiKey}}")
  .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}}/api/v1/id4ns/:id4n');
xhr.setRequestHeader('authorization', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/api/v1/id4ns/:id4n',
  headers: {authorization: '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/api/v1/id4ns/:id4n';
const options = {method: 'GET', headers: {authorization: '{{apiKey}}'}};

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}}/api/v1/id4ns/:id4n',
  method: 'GET',
  headers: {
    authorization: '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/api/v1/id4ns/:id4n")
  .get()
  .addHeader("authorization", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/api/v1/id4ns/:id4n',
  headers: {
    authorization: '{{apiKey}}'
  }
};

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}}/api/v1/id4ns/:id4n',
  headers: {authorization: '{{apiKey}}'}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/api/v1/id4ns/:id4n');

req.headers({
  authorization: '{{apiKey}}'
});

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}}/api/v1/id4ns/:id4n',
  headers: {authorization: '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/api/v1/id4ns/:id4n';
const options = {method: 'GET', headers: {authorization: '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"authorization": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/api/v1/id4ns/:id4n"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

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}}/api/v1/id4ns/:id4n" in
let headers = Header.add (Header.init ()) "authorization" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/api/v1/id4ns/:id4n",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "authorization: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/api/v1/id4ns/:id4n', [
  'headers' => [
    'authorization' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/api/v1/id4ns/:id4n');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'authorization' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/api/v1/id4ns/:id4n');
$request->setRequestMethod('GET');
$request->setHeaders([
  'authorization' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/api/v1/id4ns/:id4n' -Method GET -Headers $headers
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/api/v1/id4ns/:id4n' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'authorization': "{{apiKey}}" }

conn.request("GET", "/baseUrl/api/v1/id4ns/:id4n", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/api/v1/id4ns/:id4n"

headers = {"authorization": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/api/v1/id4ns/:id4n"

response <- VERB("GET", url, add_headers('authorization' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/api/v1/id4ns/:id4n")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["authorization"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/api/v1/id4ns/:id4n') do |req|
  req.headers['authorization'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/api/v1/id4ns/:id4n";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("authorization", "{{apiKey}}".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/api/v1/id4ns/:id4n \
  --header 'authorization: {{apiKey}}'
http GET {{baseUrl}}/api/v1/id4ns/:id4n \
  authorization:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'authorization: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/api/v1/id4ns/:id4n
import Foundation

let headers = ["authorization": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/api/v1/id4ns/:id4n")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

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()
RESPONSE HEADERS

Content-Type
application/json
RESPONSE BODY json

{
  "createdTimestamp": 1517232722,
  "holderOrganizationId": "de.example",
  "id4n": "3THvgrWxqgTFC4",
  "ownerOrganizationId": "org.acme",
  "properties": "de.example"
}
RESPONSE HEADERS

Content-Type
application/xml
RESPONSE BODY xml

{
  "createdTimestamp": 1517232722,
  "holderOrganizationId": "de.example",
  "id4n": "3THvgrWxqgTFC4",
  "ownerOrganizationId": "org.acme",
  "properties": "de.example"
}
GET Retrieve collections of an ID
{{baseUrl}}/api/v1/id4ns/:id4n/collections
HEADERS

Authorization
{{apiKey}}
QUERY PARAMS

id4n
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/api/v1/id4ns/:id4n/collections");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "authorization: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/api/v1/id4ns/:id4n/collections" {:headers {:authorization "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/api/v1/id4ns/:id4n/collections"
headers = HTTP::Headers{
  "authorization" => "{{apiKey}}"
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/api/v1/id4ns/:id4n/collections"),
    Headers =
    {
        { "authorization", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/api/v1/id4ns/:id4n/collections");
var request = new RestRequest("", Method.Get);
request.AddHeader("authorization", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/api/v1/id4ns/:id4n/collections"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("authorization", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/api/v1/id4ns/:id4n/collections HTTP/1.1
Authorization: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/api/v1/id4ns/:id4n/collections")
  .setHeader("authorization", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/api/v1/id4ns/:id4n/collections"))
    .header("authorization", "{{apiKey}}")
    .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}}/api/v1/id4ns/:id4n/collections")
  .get()
  .addHeader("authorization", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/api/v1/id4ns/:id4n/collections")
  .header("authorization", "{{apiKey}}")
  .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}}/api/v1/id4ns/:id4n/collections');
xhr.setRequestHeader('authorization', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/api/v1/id4ns/:id4n/collections',
  headers: {authorization: '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/api/v1/id4ns/:id4n/collections';
const options = {method: 'GET', headers: {authorization: '{{apiKey}}'}};

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}}/api/v1/id4ns/:id4n/collections',
  method: 'GET',
  headers: {
    authorization: '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/api/v1/id4ns/:id4n/collections")
  .get()
  .addHeader("authorization", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/api/v1/id4ns/:id4n/collections',
  headers: {
    authorization: '{{apiKey}}'
  }
};

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}}/api/v1/id4ns/:id4n/collections',
  headers: {authorization: '{{apiKey}}'}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/api/v1/id4ns/:id4n/collections');

req.headers({
  authorization: '{{apiKey}}'
});

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}}/api/v1/id4ns/:id4n/collections',
  headers: {authorization: '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/api/v1/id4ns/:id4n/collections';
const options = {method: 'GET', headers: {authorization: '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"authorization": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/api/v1/id4ns/:id4n/collections"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

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}}/api/v1/id4ns/:id4n/collections" in
let headers = Header.add (Header.init ()) "authorization" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/api/v1/id4ns/:id4n/collections",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "authorization: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/api/v1/id4ns/:id4n/collections', [
  'headers' => [
    'authorization' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/api/v1/id4ns/:id4n/collections');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'authorization' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/api/v1/id4ns/:id4n/collections');
$request->setRequestMethod('GET');
$request->setHeaders([
  'authorization' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/api/v1/id4ns/:id4n/collections' -Method GET -Headers $headers
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/api/v1/id4ns/:id4n/collections' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'authorization': "{{apiKey}}" }

conn.request("GET", "/baseUrl/api/v1/id4ns/:id4n/collections", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/api/v1/id4ns/:id4n/collections"

headers = {"authorization": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/api/v1/id4ns/:id4n/collections"

response <- VERB("GET", url, add_headers('authorization' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/api/v1/id4ns/:id4n/collections")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["authorization"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/api/v1/id4ns/:id4n/collections') do |req|
  req.headers['authorization'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/api/v1/id4ns/:id4n/collections";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("authorization", "{{apiKey}}".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/api/v1/id4ns/:id4n/collections \
  --header 'authorization: {{apiKey}}'
http GET {{baseUrl}}/api/v1/id4ns/:id4n/collections \
  authorization:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'authorization: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/api/v1/id4ns/:id4n/collections
import Foundation

let headers = ["authorization": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/api/v1/id4ns/:id4n/collections")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

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()
RESPONSE HEADERS

Content-Type
application/json
RESPONSE BODY json

{
  "limit": 100,
  "offset": 0,
  "total": 200
}
RESPONSE HEADERS

Content-Type
application/xml
RESPONSE BODY xml

{
  "limit": 100,
  "offset": 0,
  "total": 200
}
POST Add history item
{{baseUrl}}/api/v1/history/:id4n
HEADERS

Authorization
{{apiKey}}
QUERY PARAMS

id4n
BODY json

{
  "additionalProperties": {},
  "organizationId": "",
  "ownerOrganizationId": "",
  "sequenceId": 0,
  "timestamp": 0,
  "type": "",
  "visibility": {
    "public": false,
    "sharedOrganizationIds": []
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/api/v1/history/:id4n");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "authorization: {{apiKey}}");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"organizationId\": \"org.acme\",\n  \"ownerOrganizationId\": \"de.bluerain\",\n  \"sequenceId\": 9784,\n  \"timestamp\": 1517232722,\n  \"type\": \"DISPATCHED\",\n  \"visibility\": {\n    \"public\": true,\n    \"sharedOrganizationIds\": [\n      \"de.acme\",\n      \"com.porsche\",\n      \"de.bluerain\"\n    ]\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/api/v1/history/:id4n" {:headers {:authorization "{{apiKey}}"}
                                                                 :content-type :json
                                                                 :form-params {:organizationId "org.acme"
                                                                               :ownerOrganizationId "de.bluerain"
                                                                               :sequenceId 9784
                                                                               :timestamp 1517232722
                                                                               :type "DISPATCHED"
                                                                               :visibility {:public true
                                                                                            :sharedOrganizationIds ["de.acme" "com.porsche" "de.bluerain"]}}})
require "http/client"

url = "{{baseUrl}}/api/v1/history/:id4n"
headers = HTTP::Headers{
  "authorization" => "{{apiKey}}"
  "content-type" => "application/json"
}
reqBody = "{\n  \"organizationId\": \"org.acme\",\n  \"ownerOrganizationId\": \"de.bluerain\",\n  \"sequenceId\": 9784,\n  \"timestamp\": 1517232722,\n  \"type\": \"DISPATCHED\",\n  \"visibility\": {\n    \"public\": true,\n    \"sharedOrganizationIds\": [\n      \"de.acme\",\n      \"com.porsche\",\n      \"de.bluerain\"\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}}/api/v1/history/:id4n"),
    Headers =
    {
        { "authorization", "{{apiKey}}" },
    },
    Content = new StringContent("{\n  \"organizationId\": \"org.acme\",\n  \"ownerOrganizationId\": \"de.bluerain\",\n  \"sequenceId\": 9784,\n  \"timestamp\": 1517232722,\n  \"type\": \"DISPATCHED\",\n  \"visibility\": {\n    \"public\": true,\n    \"sharedOrganizationIds\": [\n      \"de.acme\",\n      \"com.porsche\",\n      \"de.bluerain\"\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}}/api/v1/history/:id4n");
var request = new RestRequest("", Method.Post);
request.AddHeader("authorization", "{{apiKey}}");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"organizationId\": \"org.acme\",\n  \"ownerOrganizationId\": \"de.bluerain\",\n  \"sequenceId\": 9784,\n  \"timestamp\": 1517232722,\n  \"type\": \"DISPATCHED\",\n  \"visibility\": {\n    \"public\": true,\n    \"sharedOrganizationIds\": [\n      \"de.acme\",\n      \"com.porsche\",\n      \"de.bluerain\"\n    ]\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/api/v1/history/:id4n"

	payload := strings.NewReader("{\n  \"organizationId\": \"org.acme\",\n  \"ownerOrganizationId\": \"de.bluerain\",\n  \"sequenceId\": 9784,\n  \"timestamp\": 1517232722,\n  \"type\": \"DISPATCHED\",\n  \"visibility\": {\n    \"public\": true,\n    \"sharedOrganizationIds\": [\n      \"de.acme\",\n      \"com.porsche\",\n      \"de.bluerain\"\n    ]\n  }\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("authorization", "{{apiKey}}")
	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/api/v1/history/:id4n HTTP/1.1
Authorization: {{apiKey}}
Content-Type: application/json
Host: example.com
Content-Length: 285

{
  "organizationId": "org.acme",
  "ownerOrganizationId": "de.bluerain",
  "sequenceId": 9784,
  "timestamp": 1517232722,
  "type": "DISPATCHED",
  "visibility": {
    "public": true,
    "sharedOrganizationIds": [
      "de.acme",
      "com.porsche",
      "de.bluerain"
    ]
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/api/v1/history/:id4n")
  .setHeader("authorization", "{{apiKey}}")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"organizationId\": \"org.acme\",\n  \"ownerOrganizationId\": \"de.bluerain\",\n  \"sequenceId\": 9784,\n  \"timestamp\": 1517232722,\n  \"type\": \"DISPATCHED\",\n  \"visibility\": {\n    \"public\": true,\n    \"sharedOrganizationIds\": [\n      \"de.acme\",\n      \"com.porsche\",\n      \"de.bluerain\"\n    ]\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/api/v1/history/:id4n"))
    .header("authorization", "{{apiKey}}")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"organizationId\": \"org.acme\",\n  \"ownerOrganizationId\": \"de.bluerain\",\n  \"sequenceId\": 9784,\n  \"timestamp\": 1517232722,\n  \"type\": \"DISPATCHED\",\n  \"visibility\": {\n    \"public\": true,\n    \"sharedOrganizationIds\": [\n      \"de.acme\",\n      \"com.porsche\",\n      \"de.bluerain\"\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  \"organizationId\": \"org.acme\",\n  \"ownerOrganizationId\": \"de.bluerain\",\n  \"sequenceId\": 9784,\n  \"timestamp\": 1517232722,\n  \"type\": \"DISPATCHED\",\n  \"visibility\": {\n    \"public\": true,\n    \"sharedOrganizationIds\": [\n      \"de.acme\",\n      \"com.porsche\",\n      \"de.bluerain\"\n    ]\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/api/v1/history/:id4n")
  .post(body)
  .addHeader("authorization", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/api/v1/history/:id4n")
  .header("authorization", "{{apiKey}}")
  .header("content-type", "application/json")
  .body("{\n  \"organizationId\": \"org.acme\",\n  \"ownerOrganizationId\": \"de.bluerain\",\n  \"sequenceId\": 9784,\n  \"timestamp\": 1517232722,\n  \"type\": \"DISPATCHED\",\n  \"visibility\": {\n    \"public\": true,\n    \"sharedOrganizationIds\": [\n      \"de.acme\",\n      \"com.porsche\",\n      \"de.bluerain\"\n    ]\n  }\n}")
  .asString();
const data = JSON.stringify({
  organizationId: 'org.acme',
  ownerOrganizationId: 'de.bluerain',
  sequenceId: 9784,
  timestamp: 1517232722,
  type: 'DISPATCHED',
  visibility: {
    public: true,
    sharedOrganizationIds: [
      'de.acme',
      'com.porsche',
      'de.bluerain'
    ]
  }
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/api/v1/history/:id4n');
xhr.setRequestHeader('authorization', '{{apiKey}}');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/api/v1/history/:id4n',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  data: {
    organizationId: 'org.acme',
    ownerOrganizationId: 'de.bluerain',
    sequenceId: 9784,
    timestamp: 1517232722,
    type: 'DISPATCHED',
    visibility: {public: true, sharedOrganizationIds: ['de.acme', 'com.porsche', 'de.bluerain']}
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/api/v1/history/:id4n';
const options = {
  method: 'POST',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"organizationId":"org.acme","ownerOrganizationId":"de.bluerain","sequenceId":9784,"timestamp":1517232722,"type":"DISPATCHED","visibility":{"public":true,"sharedOrganizationIds":["de.acme","com.porsche","de.bluerain"]}}'
};

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}}/api/v1/history/:id4n',
  method: 'POST',
  headers: {
    authorization: '{{apiKey}}',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "organizationId": "org.acme",\n  "ownerOrganizationId": "de.bluerain",\n  "sequenceId": 9784,\n  "timestamp": 1517232722,\n  "type": "DISPATCHED",\n  "visibility": {\n    "public": true,\n    "sharedOrganizationIds": [\n      "de.acme",\n      "com.porsche",\n      "de.bluerain"\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  \"organizationId\": \"org.acme\",\n  \"ownerOrganizationId\": \"de.bluerain\",\n  \"sequenceId\": 9784,\n  \"timestamp\": 1517232722,\n  \"type\": \"DISPATCHED\",\n  \"visibility\": {\n    \"public\": true,\n    \"sharedOrganizationIds\": [\n      \"de.acme\",\n      \"com.porsche\",\n      \"de.bluerain\"\n    ]\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/api/v1/history/:id4n")
  .post(body)
  .addHeader("authorization", "{{apiKey}}")
  .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/api/v1/history/:id4n',
  headers: {
    authorization: '{{apiKey}}',
    '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({
  organizationId: 'org.acme',
  ownerOrganizationId: 'de.bluerain',
  sequenceId: 9784,
  timestamp: 1517232722,
  type: 'DISPATCHED',
  visibility: {public: true, sharedOrganizationIds: ['de.acme', 'com.porsche', 'de.bluerain']}
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/api/v1/history/:id4n',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  body: {
    organizationId: 'org.acme',
    ownerOrganizationId: 'de.bluerain',
    sequenceId: 9784,
    timestamp: 1517232722,
    type: 'DISPATCHED',
    visibility: {public: true, sharedOrganizationIds: ['de.acme', 'com.porsche', 'de.bluerain']}
  },
  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}}/api/v1/history/:id4n');

req.headers({
  authorization: '{{apiKey}}',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  organizationId: 'org.acme',
  ownerOrganizationId: 'de.bluerain',
  sequenceId: 9784,
  timestamp: 1517232722,
  type: 'DISPATCHED',
  visibility: {
    public: true,
    sharedOrganizationIds: [
      'de.acme',
      'com.porsche',
      'de.bluerain'
    ]
  }
});

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}}/api/v1/history/:id4n',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  data: {
    organizationId: 'org.acme',
    ownerOrganizationId: 'de.bluerain',
    sequenceId: 9784,
    timestamp: 1517232722,
    type: 'DISPATCHED',
    visibility: {public: true, sharedOrganizationIds: ['de.acme', 'com.porsche', 'de.bluerain']}
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/api/v1/history/:id4n';
const options = {
  method: 'POST',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"organizationId":"org.acme","ownerOrganizationId":"de.bluerain","sequenceId":9784,"timestamp":1517232722,"type":"DISPATCHED","visibility":{"public":true,"sharedOrganizationIds":["de.acme","com.porsche","de.bluerain"]}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"authorization": @"{{apiKey}}",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"organizationId": @"org.acme",
                              @"ownerOrganizationId": @"de.bluerain",
                              @"sequenceId": @9784,
                              @"timestamp": @1517232722,
                              @"type": @"DISPATCHED",
                              @"visibility": @{ @"public": @YES, @"sharedOrganizationIds": @[ @"de.acme", @"com.porsche", @"de.bluerain" ] } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/api/v1/history/:id4n"]
                                                       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}}/api/v1/history/:id4n" in
let headers = Header.add_list (Header.init ()) [
  ("authorization", "{{apiKey}}");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"organizationId\": \"org.acme\",\n  \"ownerOrganizationId\": \"de.bluerain\",\n  \"sequenceId\": 9784,\n  \"timestamp\": 1517232722,\n  \"type\": \"DISPATCHED\",\n  \"visibility\": {\n    \"public\": true,\n    \"sharedOrganizationIds\": [\n      \"de.acme\",\n      \"com.porsche\",\n      \"de.bluerain\"\n    ]\n  }\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/api/v1/history/:id4n",
  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([
    'organizationId' => 'org.acme',
    'ownerOrganizationId' => 'de.bluerain',
    'sequenceId' => 9784,
    'timestamp' => 1517232722,
    'type' => 'DISPATCHED',
    'visibility' => [
        'public' => null,
        'sharedOrganizationIds' => [
                'de.acme',
                'com.porsche',
                'de.bluerain'
        ]
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "authorization: {{apiKey}}",
    "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}}/api/v1/history/:id4n', [
  'body' => '{
  "organizationId": "org.acme",
  "ownerOrganizationId": "de.bluerain",
  "sequenceId": 9784,
  "timestamp": 1517232722,
  "type": "DISPATCHED",
  "visibility": {
    "public": true,
    "sharedOrganizationIds": [
      "de.acme",
      "com.porsche",
      "de.bluerain"
    ]
  }
}',
  'headers' => [
    'authorization' => '{{apiKey}}',
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/api/v1/history/:id4n');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'authorization' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'organizationId' => 'org.acme',
  'ownerOrganizationId' => 'de.bluerain',
  'sequenceId' => 9784,
  'timestamp' => 1517232722,
  'type' => 'DISPATCHED',
  'visibility' => [
    'public' => null,
    'sharedOrganizationIds' => [
        'de.acme',
        'com.porsche',
        'de.bluerain'
    ]
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'organizationId' => 'org.acme',
  'ownerOrganizationId' => 'de.bluerain',
  'sequenceId' => 9784,
  'timestamp' => 1517232722,
  'type' => 'DISPATCHED',
  'visibility' => [
    'public' => null,
    'sharedOrganizationIds' => [
        'de.acme',
        'com.porsche',
        'de.bluerain'
    ]
  ]
]));
$request->setRequestUrl('{{baseUrl}}/api/v1/history/:id4n');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'authorization' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/api/v1/history/:id4n' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "organizationId": "org.acme",
  "ownerOrganizationId": "de.bluerain",
  "sequenceId": 9784,
  "timestamp": 1517232722,
  "type": "DISPATCHED",
  "visibility": {
    "public": true,
    "sharedOrganizationIds": [
      "de.acme",
      "com.porsche",
      "de.bluerain"
    ]
  }
}'
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/api/v1/history/:id4n' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "organizationId": "org.acme",
  "ownerOrganizationId": "de.bluerain",
  "sequenceId": 9784,
  "timestamp": 1517232722,
  "type": "DISPATCHED",
  "visibility": {
    "public": true,
    "sharedOrganizationIds": [
      "de.acme",
      "com.porsche",
      "de.bluerain"
    ]
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"organizationId\": \"org.acme\",\n  \"ownerOrganizationId\": \"de.bluerain\",\n  \"sequenceId\": 9784,\n  \"timestamp\": 1517232722,\n  \"type\": \"DISPATCHED\",\n  \"visibility\": {\n    \"public\": true,\n    \"sharedOrganizationIds\": [\n      \"de.acme\",\n      \"com.porsche\",\n      \"de.bluerain\"\n    ]\n  }\n}"

headers = {
    'authorization': "{{apiKey}}",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/api/v1/history/:id4n", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/api/v1/history/:id4n"

payload = {
    "organizationId": "org.acme",
    "ownerOrganizationId": "de.bluerain",
    "sequenceId": 9784,
    "timestamp": 1517232722,
    "type": "DISPATCHED",
    "visibility": {
        "public": True,
        "sharedOrganizationIds": ["de.acme", "com.porsche", "de.bluerain"]
    }
}
headers = {
    "authorization": "{{apiKey}}",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/api/v1/history/:id4n"

payload <- "{\n  \"organizationId\": \"org.acme\",\n  \"ownerOrganizationId\": \"de.bluerain\",\n  \"sequenceId\": 9784,\n  \"timestamp\": 1517232722,\n  \"type\": \"DISPATCHED\",\n  \"visibility\": {\n    \"public\": true,\n    \"sharedOrganizationIds\": [\n      \"de.acme\",\n      \"com.porsche\",\n      \"de.bluerain\"\n    ]\n  }\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('authorization' = '{{apiKey}}'), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/api/v1/history/:id4n")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["authorization"] = '{{apiKey}}'
request["content-type"] = 'application/json'
request.body = "{\n  \"organizationId\": \"org.acme\",\n  \"ownerOrganizationId\": \"de.bluerain\",\n  \"sequenceId\": 9784,\n  \"timestamp\": 1517232722,\n  \"type\": \"DISPATCHED\",\n  \"visibility\": {\n    \"public\": true,\n    \"sharedOrganizationIds\": [\n      \"de.acme\",\n      \"com.porsche\",\n      \"de.bluerain\"\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/api/v1/history/:id4n') do |req|
  req.headers['authorization'] = '{{apiKey}}'
  req.body = "{\n  \"organizationId\": \"org.acme\",\n  \"ownerOrganizationId\": \"de.bluerain\",\n  \"sequenceId\": 9784,\n  \"timestamp\": 1517232722,\n  \"type\": \"DISPATCHED\",\n  \"visibility\": {\n    \"public\": true,\n    \"sharedOrganizationIds\": [\n      \"de.acme\",\n      \"com.porsche\",\n      \"de.bluerain\"\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}}/api/v1/history/:id4n";

    let payload = json!({
        "organizationId": "org.acme",
        "ownerOrganizationId": "de.bluerain",
        "sequenceId": 9784,
        "timestamp": 1517232722,
        "type": "DISPATCHED",
        "visibility": json!({
            "public": true,
            "sharedOrganizationIds": ("de.acme", "com.porsche", "de.bluerain")
        })
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("authorization", "{{apiKey}}".parse().unwrap());
    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}}/api/v1/history/:id4n \
  --header 'authorization: {{apiKey}}' \
  --header 'content-type: application/json' \
  --data '{
  "organizationId": "org.acme",
  "ownerOrganizationId": "de.bluerain",
  "sequenceId": 9784,
  "timestamp": 1517232722,
  "type": "DISPATCHED",
  "visibility": {
    "public": true,
    "sharedOrganizationIds": [
      "de.acme",
      "com.porsche",
      "de.bluerain"
    ]
  }
}'
echo '{
  "organizationId": "org.acme",
  "ownerOrganizationId": "de.bluerain",
  "sequenceId": 9784,
  "timestamp": 1517232722,
  "type": "DISPATCHED",
  "visibility": {
    "public": true,
    "sharedOrganizationIds": [
      "de.acme",
      "com.porsche",
      "de.bluerain"
    ]
  }
}' |  \
  http POST {{baseUrl}}/api/v1/history/:id4n \
  authorization:'{{apiKey}}' \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'authorization: {{apiKey}}' \
  --header 'content-type: application/json' \
  --body-data '{\n  "organizationId": "org.acme",\n  "ownerOrganizationId": "de.bluerain",\n  "sequenceId": 9784,\n  "timestamp": 1517232722,\n  "type": "DISPATCHED",\n  "visibility": {\n    "public": true,\n    "sharedOrganizationIds": [\n      "de.acme",\n      "com.porsche",\n      "de.bluerain"\n    ]\n  }\n}' \
  --output-document \
  - {{baseUrl}}/api/v1/history/:id4n
import Foundation

let headers = [
  "authorization": "{{apiKey}}",
  "content-type": "application/json"
]
let parameters = [
  "organizationId": "org.acme",
  "ownerOrganizationId": "de.bluerain",
  "sequenceId": 9784,
  "timestamp": 1517232722,
  "type": "DISPATCHED",
  "visibility": [
    "public": true,
    "sharedOrganizationIds": ["de.acme", "com.porsche", "de.bluerain"]
  ]
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/api/v1/history/:id4n")! 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()
GET DEPRECATED - List history
{{baseUrl}}/api/v1/history/:id4n/:organizationId
HEADERS

Authorization
{{apiKey}}
QUERY PARAMS

id4n
organizationId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/api/v1/history/:id4n/:organizationId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "authorization: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/api/v1/history/:id4n/:organizationId" {:headers {:authorization "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/api/v1/history/:id4n/:organizationId"
headers = HTTP::Headers{
  "authorization" => "{{apiKey}}"
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/api/v1/history/:id4n/:organizationId"),
    Headers =
    {
        { "authorization", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/api/v1/history/:id4n/:organizationId");
var request = new RestRequest("", Method.Get);
request.AddHeader("authorization", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/api/v1/history/:id4n/:organizationId"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("authorization", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/api/v1/history/:id4n/:organizationId HTTP/1.1
Authorization: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/api/v1/history/:id4n/:organizationId")
  .setHeader("authorization", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/api/v1/history/:id4n/:organizationId"))
    .header("authorization", "{{apiKey}}")
    .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}}/api/v1/history/:id4n/:organizationId")
  .get()
  .addHeader("authorization", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/api/v1/history/:id4n/:organizationId")
  .header("authorization", "{{apiKey}}")
  .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}}/api/v1/history/:id4n/:organizationId');
xhr.setRequestHeader('authorization', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/api/v1/history/:id4n/:organizationId',
  headers: {authorization: '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/api/v1/history/:id4n/:organizationId';
const options = {method: 'GET', headers: {authorization: '{{apiKey}}'}};

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}}/api/v1/history/:id4n/:organizationId',
  method: 'GET',
  headers: {
    authorization: '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/api/v1/history/:id4n/:organizationId")
  .get()
  .addHeader("authorization", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/api/v1/history/:id4n/:organizationId',
  headers: {
    authorization: '{{apiKey}}'
  }
};

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}}/api/v1/history/:id4n/:organizationId',
  headers: {authorization: '{{apiKey}}'}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/api/v1/history/:id4n/:organizationId');

req.headers({
  authorization: '{{apiKey}}'
});

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}}/api/v1/history/:id4n/:organizationId',
  headers: {authorization: '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/api/v1/history/:id4n/:organizationId';
const options = {method: 'GET', headers: {authorization: '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"authorization": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/api/v1/history/:id4n/:organizationId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

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}}/api/v1/history/:id4n/:organizationId" in
let headers = Header.add (Header.init ()) "authorization" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/api/v1/history/:id4n/:organizationId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "authorization: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/api/v1/history/:id4n/:organizationId', [
  'headers' => [
    'authorization' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/api/v1/history/:id4n/:organizationId');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'authorization' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/api/v1/history/:id4n/:organizationId');
$request->setRequestMethod('GET');
$request->setHeaders([
  'authorization' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/api/v1/history/:id4n/:organizationId' -Method GET -Headers $headers
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/api/v1/history/:id4n/:organizationId' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'authorization': "{{apiKey}}" }

conn.request("GET", "/baseUrl/api/v1/history/:id4n/:organizationId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/api/v1/history/:id4n/:organizationId"

headers = {"authorization": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/api/v1/history/:id4n/:organizationId"

response <- VERB("GET", url, add_headers('authorization' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/api/v1/history/:id4n/:organizationId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["authorization"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/api/v1/history/:id4n/:organizationId') do |req|
  req.headers['authorization'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/api/v1/history/:id4n/:organizationId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("authorization", "{{apiKey}}".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/api/v1/history/:id4n/:organizationId \
  --header 'authorization: {{apiKey}}'
http GET {{baseUrl}}/api/v1/history/:id4n/:organizationId \
  authorization:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'authorization: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/api/v1/history/:id4n/:organizationId
import Foundation

let headers = ["authorization": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/api/v1/history/:id4n/:organizationId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

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()
RESPONSE HEADERS

Content-Type
application/json
RESPONSE BODY json

{
  "limit": 100,
  "offset": 0,
  "total": 200
}
RESPONSE HEADERS

Content-Type
application/xml
RESPONSE BODY xml

{
  "limit": 100,
  "offset": 0,
  "total": 200
}
GET Get history item
{{baseUrl}}/api/v1/history/:id4n/:organizationId/:sequenceId
HEADERS

Authorization
{{apiKey}}
QUERY PARAMS

id4n
organizationId
sequenceId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/api/v1/history/:id4n/:organizationId/:sequenceId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "authorization: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/api/v1/history/:id4n/:organizationId/:sequenceId" {:headers {:authorization "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/api/v1/history/:id4n/:organizationId/:sequenceId"
headers = HTTP::Headers{
  "authorization" => "{{apiKey}}"
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/api/v1/history/:id4n/:organizationId/:sequenceId"),
    Headers =
    {
        { "authorization", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/api/v1/history/:id4n/:organizationId/:sequenceId");
var request = new RestRequest("", Method.Get);
request.AddHeader("authorization", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/api/v1/history/:id4n/:organizationId/:sequenceId"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("authorization", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/api/v1/history/:id4n/:organizationId/:sequenceId HTTP/1.1
Authorization: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/api/v1/history/:id4n/:organizationId/:sequenceId")
  .setHeader("authorization", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/api/v1/history/:id4n/:organizationId/:sequenceId"))
    .header("authorization", "{{apiKey}}")
    .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}}/api/v1/history/:id4n/:organizationId/:sequenceId")
  .get()
  .addHeader("authorization", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/api/v1/history/:id4n/:organizationId/:sequenceId")
  .header("authorization", "{{apiKey}}")
  .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}}/api/v1/history/:id4n/:organizationId/:sequenceId');
xhr.setRequestHeader('authorization', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/api/v1/history/:id4n/:organizationId/:sequenceId',
  headers: {authorization: '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/api/v1/history/:id4n/:organizationId/:sequenceId';
const options = {method: 'GET', headers: {authorization: '{{apiKey}}'}};

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}}/api/v1/history/:id4n/:organizationId/:sequenceId',
  method: 'GET',
  headers: {
    authorization: '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/api/v1/history/:id4n/:organizationId/:sequenceId")
  .get()
  .addHeader("authorization", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/api/v1/history/:id4n/:organizationId/:sequenceId',
  headers: {
    authorization: '{{apiKey}}'
  }
};

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}}/api/v1/history/:id4n/:organizationId/:sequenceId',
  headers: {authorization: '{{apiKey}}'}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/api/v1/history/:id4n/:organizationId/:sequenceId');

req.headers({
  authorization: '{{apiKey}}'
});

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}}/api/v1/history/:id4n/:organizationId/:sequenceId',
  headers: {authorization: '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/api/v1/history/:id4n/:organizationId/:sequenceId';
const options = {method: 'GET', headers: {authorization: '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"authorization": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/api/v1/history/:id4n/:organizationId/:sequenceId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

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}}/api/v1/history/:id4n/:organizationId/:sequenceId" in
let headers = Header.add (Header.init ()) "authorization" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/api/v1/history/:id4n/:organizationId/:sequenceId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "authorization: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/api/v1/history/:id4n/:organizationId/:sequenceId', [
  'headers' => [
    'authorization' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/api/v1/history/:id4n/:organizationId/:sequenceId');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'authorization' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/api/v1/history/:id4n/:organizationId/:sequenceId');
$request->setRequestMethod('GET');
$request->setHeaders([
  'authorization' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/api/v1/history/:id4n/:organizationId/:sequenceId' -Method GET -Headers $headers
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/api/v1/history/:id4n/:organizationId/:sequenceId' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'authorization': "{{apiKey}}" }

conn.request("GET", "/baseUrl/api/v1/history/:id4n/:organizationId/:sequenceId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/api/v1/history/:id4n/:organizationId/:sequenceId"

headers = {"authorization": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/api/v1/history/:id4n/:organizationId/:sequenceId"

response <- VERB("GET", url, add_headers('authorization' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/api/v1/history/:id4n/:organizationId/:sequenceId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["authorization"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/api/v1/history/:id4n/:organizationId/:sequenceId') do |req|
  req.headers['authorization'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/api/v1/history/:id4n/:organizationId/:sequenceId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("authorization", "{{apiKey}}".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/api/v1/history/:id4n/:organizationId/:sequenceId \
  --header 'authorization: {{apiKey}}'
http GET {{baseUrl}}/api/v1/history/:id4n/:organizationId/:sequenceId \
  authorization:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'authorization: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/api/v1/history/:id4n/:organizationId/:sequenceId
import Foundation

let headers = ["authorization": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/api/v1/history/:id4n/:organizationId/:sequenceId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

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()
RESPONSE HEADERS

Content-Type
application/json
RESPONSE BODY json

{
  "organizationId": "org.acme",
  "ownerOrganizationId": "de.bluerain",
  "sequenceId": 9784,
  "timestamp": 1517232722,
  "type": "DISPATCHED",
  "visibility": {
    "public": true,
    "sharedOrganizationIds": [
      "de.acme",
      "com.porsche",
      "de.bluerain"
    ]
  }
}
RESPONSE HEADERS

Content-Type
application/xml
RESPONSE BODY xml

{
  "organizationId": "org.acme",
  "ownerOrganizationId": "de.bluerain",
  "sequenceId": 9784,
  "timestamp": 1517232722,
  "type": "DISPATCHED",
  "visibility": {
    "public": true,
    "sharedOrganizationIds": [
      "de.acme",
      "com.porsche",
      "de.bluerain"
    ]
  }
}
GET List history
{{baseUrl}}/api/v1/history/:id4n
HEADERS

Authorization
{{apiKey}}
QUERY PARAMS

id4n
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/api/v1/history/:id4n");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "authorization: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/api/v1/history/:id4n" {:headers {:authorization "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/api/v1/history/:id4n"
headers = HTTP::Headers{
  "authorization" => "{{apiKey}}"
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/api/v1/history/:id4n"),
    Headers =
    {
        { "authorization", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/api/v1/history/:id4n");
var request = new RestRequest("", Method.Get);
request.AddHeader("authorization", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/api/v1/history/:id4n"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("authorization", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/api/v1/history/:id4n HTTP/1.1
Authorization: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/api/v1/history/:id4n")
  .setHeader("authorization", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/api/v1/history/:id4n"))
    .header("authorization", "{{apiKey}}")
    .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}}/api/v1/history/:id4n")
  .get()
  .addHeader("authorization", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/api/v1/history/:id4n")
  .header("authorization", "{{apiKey}}")
  .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}}/api/v1/history/:id4n');
xhr.setRequestHeader('authorization', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/api/v1/history/:id4n',
  headers: {authorization: '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/api/v1/history/:id4n';
const options = {method: 'GET', headers: {authorization: '{{apiKey}}'}};

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}}/api/v1/history/:id4n',
  method: 'GET',
  headers: {
    authorization: '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/api/v1/history/:id4n")
  .get()
  .addHeader("authorization", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/api/v1/history/:id4n',
  headers: {
    authorization: '{{apiKey}}'
  }
};

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}}/api/v1/history/:id4n',
  headers: {authorization: '{{apiKey}}'}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/api/v1/history/:id4n');

req.headers({
  authorization: '{{apiKey}}'
});

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}}/api/v1/history/:id4n',
  headers: {authorization: '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/api/v1/history/:id4n';
const options = {method: 'GET', headers: {authorization: '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"authorization": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/api/v1/history/:id4n"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

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}}/api/v1/history/:id4n" in
let headers = Header.add (Header.init ()) "authorization" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/api/v1/history/:id4n",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "authorization: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/api/v1/history/:id4n', [
  'headers' => [
    'authorization' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/api/v1/history/:id4n');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'authorization' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/api/v1/history/:id4n');
$request->setRequestMethod('GET');
$request->setHeaders([
  'authorization' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/api/v1/history/:id4n' -Method GET -Headers $headers
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/api/v1/history/:id4n' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'authorization': "{{apiKey}}" }

conn.request("GET", "/baseUrl/api/v1/history/:id4n", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/api/v1/history/:id4n"

headers = {"authorization": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/api/v1/history/:id4n"

response <- VERB("GET", url, add_headers('authorization' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/api/v1/history/:id4n")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["authorization"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/api/v1/history/:id4n') do |req|
  req.headers['authorization'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/api/v1/history/:id4n";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("authorization", "{{apiKey}}".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/api/v1/history/:id4n \
  --header 'authorization: {{apiKey}}'
http GET {{baseUrl}}/api/v1/history/:id4n \
  authorization:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'authorization: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/api/v1/history/:id4n
import Foundation

let headers = ["authorization": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/api/v1/history/:id4n")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

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()
RESPONSE HEADERS

Content-Type
application/json
RESPONSE BODY json

{
  "limit": 100,
  "offset": 0,
  "total": 200
}
RESPONSE HEADERS

Content-Type
application/xml
RESPONSE BODY xml

{
  "limit": 100,
  "offset": 0,
  "total": 200
}
PUT Set history item visibility
{{baseUrl}}/api/v1/history/:id4n/:organizationId/:sequenceId/visibility
HEADERS

Authorization
{{apiKey}}
QUERY PARAMS

id4n
organizationId
sequenceId
BODY json

{
  "public": false,
  "sharedOrganizationIds": []
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/api/v1/history/:id4n/:organizationId/:sequenceId/visibility");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "authorization: {{apiKey}}");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"public\": false,\n  \"sharedOrganizationIds\": []\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/api/v1/history/:id4n/:organizationId/:sequenceId/visibility" {:headers {:authorization "{{apiKey}}"}
                                                                                                       :content-type :json
                                                                                                       :form-params {:public false
                                                                                                                     :sharedOrganizationIds []}})
require "http/client"

url = "{{baseUrl}}/api/v1/history/:id4n/:organizationId/:sequenceId/visibility"
headers = HTTP::Headers{
  "authorization" => "{{apiKey}}"
  "content-type" => "application/json"
}
reqBody = "{\n  \"public\": false,\n  \"sharedOrganizationIds\": []\n}"

response = HTTP::Client.put url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Put,
    RequestUri = new Uri("{{baseUrl}}/api/v1/history/:id4n/:organizationId/:sequenceId/visibility"),
    Headers =
    {
        { "authorization", "{{apiKey}}" },
    },
    Content = new StringContent("{\n  \"public\": false,\n  \"sharedOrganizationIds\": []\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}}/api/v1/history/:id4n/:organizationId/:sequenceId/visibility");
var request = new RestRequest("", Method.Put);
request.AddHeader("authorization", "{{apiKey}}");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"public\": false,\n  \"sharedOrganizationIds\": []\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/api/v1/history/:id4n/:organizationId/:sequenceId/visibility"

	payload := strings.NewReader("{\n  \"public\": false,\n  \"sharedOrganizationIds\": []\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("authorization", "{{apiKey}}")
	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))

}
PUT /baseUrl/api/v1/history/:id4n/:organizationId/:sequenceId/visibility HTTP/1.1
Authorization: {{apiKey}}
Content-Type: application/json
Host: example.com
Content-Length: 52

{
  "public": false,
  "sharedOrganizationIds": []
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/api/v1/history/:id4n/:organizationId/:sequenceId/visibility")
  .setHeader("authorization", "{{apiKey}}")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"public\": false,\n  \"sharedOrganizationIds\": []\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/api/v1/history/:id4n/:organizationId/:sequenceId/visibility"))
    .header("authorization", "{{apiKey}}")
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"public\": false,\n  \"sharedOrganizationIds\": []\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  \"public\": false,\n  \"sharedOrganizationIds\": []\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/api/v1/history/:id4n/:organizationId/:sequenceId/visibility")
  .put(body)
  .addHeader("authorization", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/api/v1/history/:id4n/:organizationId/:sequenceId/visibility")
  .header("authorization", "{{apiKey}}")
  .header("content-type", "application/json")
  .body("{\n  \"public\": false,\n  \"sharedOrganizationIds\": []\n}")
  .asString();
const data = JSON.stringify({
  public: false,
  sharedOrganizationIds: []
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/api/v1/history/:id4n/:organizationId/:sequenceId/visibility');
xhr.setRequestHeader('authorization', '{{apiKey}}');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/api/v1/history/:id4n/:organizationId/:sequenceId/visibility',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  data: {public: false, sharedOrganizationIds: []}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/api/v1/history/:id4n/:organizationId/:sequenceId/visibility';
const options = {
  method: 'PUT',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"public":false,"sharedOrganizationIds":[]}'
};

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}}/api/v1/history/:id4n/:organizationId/:sequenceId/visibility',
  method: 'PUT',
  headers: {
    authorization: '{{apiKey}}',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "public": false,\n  "sharedOrganizationIds": []\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"public\": false,\n  \"sharedOrganizationIds\": []\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/api/v1/history/:id4n/:organizationId/:sequenceId/visibility")
  .put(body)
  .addHeader("authorization", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/api/v1/history/:id4n/:organizationId/:sequenceId/visibility',
  headers: {
    authorization: '{{apiKey}}',
    '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({public: false, sharedOrganizationIds: []}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/api/v1/history/:id4n/:organizationId/:sequenceId/visibility',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  body: {public: false, sharedOrganizationIds: []},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('PUT', '{{baseUrl}}/api/v1/history/:id4n/:organizationId/:sequenceId/visibility');

req.headers({
  authorization: '{{apiKey}}',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  public: false,
  sharedOrganizationIds: []
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/api/v1/history/:id4n/:organizationId/:sequenceId/visibility',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  data: {public: false, sharedOrganizationIds: []}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/api/v1/history/:id4n/:organizationId/:sequenceId/visibility';
const options = {
  method: 'PUT',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"public":false,"sharedOrganizationIds":[]}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"authorization": @"{{apiKey}}",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"public": @NO,
                              @"sharedOrganizationIds": @[  ] };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/api/v1/history/:id4n/:organizationId/:sequenceId/visibility"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"PUT"];
[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}}/api/v1/history/:id4n/:organizationId/:sequenceId/visibility" in
let headers = Header.add_list (Header.init ()) [
  ("authorization", "{{apiKey}}");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"public\": false,\n  \"sharedOrganizationIds\": []\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/api/v1/history/:id4n/:organizationId/:sequenceId/visibility",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
  CURLOPT_POSTFIELDS => json_encode([
    'public' => null,
    'sharedOrganizationIds' => [
        
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "authorization: {{apiKey}}",
    "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('PUT', '{{baseUrl}}/api/v1/history/:id4n/:organizationId/:sequenceId/visibility', [
  'body' => '{
  "public": false,
  "sharedOrganizationIds": []
}',
  'headers' => [
    'authorization' => '{{apiKey}}',
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/api/v1/history/:id4n/:organizationId/:sequenceId/visibility');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'authorization' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'public' => null,
  'sharedOrganizationIds' => [
    
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'public' => null,
  'sharedOrganizationIds' => [
    
  ]
]));
$request->setRequestUrl('{{baseUrl}}/api/v1/history/:id4n/:organizationId/:sequenceId/visibility');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'authorization' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/api/v1/history/:id4n/:organizationId/:sequenceId/visibility' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "public": false,
  "sharedOrganizationIds": []
}'
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/api/v1/history/:id4n/:organizationId/:sequenceId/visibility' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "public": false,
  "sharedOrganizationIds": []
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"public\": false,\n  \"sharedOrganizationIds\": []\n}"

headers = {
    'authorization': "{{apiKey}}",
    'content-type': "application/json"
}

conn.request("PUT", "/baseUrl/api/v1/history/:id4n/:organizationId/:sequenceId/visibility", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/api/v1/history/:id4n/:organizationId/:sequenceId/visibility"

payload = {
    "public": False,
    "sharedOrganizationIds": []
}
headers = {
    "authorization": "{{apiKey}}",
    "content-type": "application/json"
}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/api/v1/history/:id4n/:organizationId/:sequenceId/visibility"

payload <- "{\n  \"public\": false,\n  \"sharedOrganizationIds\": []\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, add_headers('authorization' = '{{apiKey}}'), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/api/v1/history/:id4n/:organizationId/:sequenceId/visibility")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["authorization"] = '{{apiKey}}'
request["content-type"] = 'application/json'
request.body = "{\n  \"public\": false,\n  \"sharedOrganizationIds\": []\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.put('/baseUrl/api/v1/history/:id4n/:organizationId/:sequenceId/visibility') do |req|
  req.headers['authorization'] = '{{apiKey}}'
  req.body = "{\n  \"public\": false,\n  \"sharedOrganizationIds\": []\n}"
end

puts response.status
puts response.body
use std::str::FromStr;
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/api/v1/history/:id4n/:organizationId/:sequenceId/visibility";

    let payload = json!({
        "public": false,
        "sharedOrganizationIds": ()
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("authorization", "{{apiKey}}".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/api/v1/history/:id4n/:organizationId/:sequenceId/visibility \
  --header 'authorization: {{apiKey}}' \
  --header 'content-type: application/json' \
  --data '{
  "public": false,
  "sharedOrganizationIds": []
}'
echo '{
  "public": false,
  "sharedOrganizationIds": []
}' |  \
  http PUT {{baseUrl}}/api/v1/history/:id4n/:organizationId/:sequenceId/visibility \
  authorization:'{{apiKey}}' \
  content-type:application/json
wget --quiet \
  --method PUT \
  --header 'authorization: {{apiKey}}' \
  --header 'content-type: application/json' \
  --body-data '{\n  "public": false,\n  "sharedOrganizationIds": []\n}' \
  --output-document \
  - {{baseUrl}}/api/v1/history/:id4n/:organizationId/:sequenceId/visibility
import Foundation

let headers = [
  "authorization": "{{apiKey}}",
  "content-type": "application/json"
]
let parameters = [
  "public": false,
  "sharedOrganizationIds": []
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/api/v1/history/:id4n/:organizationId/:sequenceId/visibility")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "PUT"
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()
RESPONSE HEADERS

Content-Type
application/json
RESPONSE BODY json

{
  "organizationId": "org.acme",
  "ownerOrganizationId": "de.bluerain",
  "sequenceId": 9784,
  "timestamp": 1517232722,
  "type": "DISPATCHED",
  "visibility": {
    "public": true,
    "sharedOrganizationIds": [
      "de.acme",
      "com.porsche",
      "de.bluerain"
    ]
  }
}
RESPONSE HEADERS

Content-Type
application/xml
RESPONSE BODY xml

{
  "organizationId": "org.acme",
  "ownerOrganizationId": "de.bluerain",
  "sequenceId": 9784,
  "timestamp": 1517232722,
  "type": "DISPATCHED",
  "visibility": {
    "public": true,
    "sharedOrganizationIds": [
      "de.acme",
      "com.porsche",
      "de.bluerain"
    ]
  }
}
PATCH Update history item
{{baseUrl}}/api/v1/history/:id4n/:organizationId/:sequenceId
HEADERS

Authorization
{{apiKey}}
QUERY PARAMS

id4n
organizationId
sequenceId
BODY json

{
  "organizationId": "",
  "visibility": {
    "public": false,
    "sharedOrganizationIds": []
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PATCH");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/api/v1/history/:id4n/:organizationId/:sequenceId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "authorization: {{apiKey}}");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"organizationId\": \"\",\n  \"visibility\": {\n    \"public\": false,\n    \"sharedOrganizationIds\": []\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/patch "{{baseUrl}}/api/v1/history/:id4n/:organizationId/:sequenceId" {:headers {:authorization "{{apiKey}}"}
                                                                                              :content-type :json
                                                                                              :form-params {:organizationId ""
                                                                                                            :visibility {:public false
                                                                                                                         :sharedOrganizationIds []}}})
require "http/client"

url = "{{baseUrl}}/api/v1/history/:id4n/:organizationId/:sequenceId"
headers = HTTP::Headers{
  "authorization" => "{{apiKey}}"
  "content-type" => "application/json"
}
reqBody = "{\n  \"organizationId\": \"\",\n  \"visibility\": {\n    \"public\": false,\n    \"sharedOrganizationIds\": []\n  }\n}"

response = HTTP::Client.patch url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Patch,
    RequestUri = new Uri("{{baseUrl}}/api/v1/history/:id4n/:organizationId/:sequenceId"),
    Headers =
    {
        { "authorization", "{{apiKey}}" },
    },
    Content = new StringContent("{\n  \"organizationId\": \"\",\n  \"visibility\": {\n    \"public\": false,\n    \"sharedOrganizationIds\": []\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}}/api/v1/history/:id4n/:organizationId/:sequenceId");
var request = new RestRequest("", Method.Patch);
request.AddHeader("authorization", "{{apiKey}}");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"organizationId\": \"\",\n  \"visibility\": {\n    \"public\": false,\n    \"sharedOrganizationIds\": []\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/api/v1/history/:id4n/:organizationId/:sequenceId"

	payload := strings.NewReader("{\n  \"organizationId\": \"\",\n  \"visibility\": {\n    \"public\": false,\n    \"sharedOrganizationIds\": []\n  }\n}")

	req, _ := http.NewRequest("PATCH", url, payload)

	req.Header.Add("authorization", "{{apiKey}}")
	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))

}
PATCH /baseUrl/api/v1/history/:id4n/:organizationId/:sequenceId HTTP/1.1
Authorization: {{apiKey}}
Content-Type: application/json
Host: example.com
Content-Length: 102

{
  "organizationId": "",
  "visibility": {
    "public": false,
    "sharedOrganizationIds": []
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PATCH", "{{baseUrl}}/api/v1/history/:id4n/:organizationId/:sequenceId")
  .setHeader("authorization", "{{apiKey}}")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"organizationId\": \"\",\n  \"visibility\": {\n    \"public\": false,\n    \"sharedOrganizationIds\": []\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/api/v1/history/:id4n/:organizationId/:sequenceId"))
    .header("authorization", "{{apiKey}}")
    .header("content-type", "application/json")
    .method("PATCH", HttpRequest.BodyPublishers.ofString("{\n  \"organizationId\": \"\",\n  \"visibility\": {\n    \"public\": false,\n    \"sharedOrganizationIds\": []\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  \"organizationId\": \"\",\n  \"visibility\": {\n    \"public\": false,\n    \"sharedOrganizationIds\": []\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/api/v1/history/:id4n/:organizationId/:sequenceId")
  .patch(body)
  .addHeader("authorization", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.patch("{{baseUrl}}/api/v1/history/:id4n/:organizationId/:sequenceId")
  .header("authorization", "{{apiKey}}")
  .header("content-type", "application/json")
  .body("{\n  \"organizationId\": \"\",\n  \"visibility\": {\n    \"public\": false,\n    \"sharedOrganizationIds\": []\n  }\n}")
  .asString();
const data = JSON.stringify({
  organizationId: '',
  visibility: {
    public: false,
    sharedOrganizationIds: []
  }
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PATCH', '{{baseUrl}}/api/v1/history/:id4n/:organizationId/:sequenceId');
xhr.setRequestHeader('authorization', '{{apiKey}}');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PATCH',
  url: '{{baseUrl}}/api/v1/history/:id4n/:organizationId/:sequenceId',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  data: {organizationId: '', visibility: {public: false, sharedOrganizationIds: []}}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/api/v1/history/:id4n/:organizationId/:sequenceId';
const options = {
  method: 'PATCH',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"organizationId":"","visibility":{"public":false,"sharedOrganizationIds":[]}}'
};

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}}/api/v1/history/:id4n/:organizationId/:sequenceId',
  method: 'PATCH',
  headers: {
    authorization: '{{apiKey}}',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "organizationId": "",\n  "visibility": {\n    "public": false,\n    "sharedOrganizationIds": []\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  \"organizationId\": \"\",\n  \"visibility\": {\n    \"public\": false,\n    \"sharedOrganizationIds\": []\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/api/v1/history/:id4n/:organizationId/:sequenceId")
  .patch(body)
  .addHeader("authorization", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PATCH',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/api/v1/history/:id4n/:organizationId/:sequenceId',
  headers: {
    authorization: '{{apiKey}}',
    '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({organizationId: '', visibility: {public: false, sharedOrganizationIds: []}}));
req.end();
const request = require('request');

const options = {
  method: 'PATCH',
  url: '{{baseUrl}}/api/v1/history/:id4n/:organizationId/:sequenceId',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  body: {organizationId: '', visibility: {public: false, sharedOrganizationIds: []}},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('PATCH', '{{baseUrl}}/api/v1/history/:id4n/:organizationId/:sequenceId');

req.headers({
  authorization: '{{apiKey}}',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  organizationId: '',
  visibility: {
    public: false,
    sharedOrganizationIds: []
  }
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'PATCH',
  url: '{{baseUrl}}/api/v1/history/:id4n/:organizationId/:sequenceId',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  data: {organizationId: '', visibility: {public: false, sharedOrganizationIds: []}}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/api/v1/history/:id4n/:organizationId/:sequenceId';
const options = {
  method: 'PATCH',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"organizationId":"","visibility":{"public":false,"sharedOrganizationIds":[]}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"authorization": @"{{apiKey}}",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"organizationId": @"",
                              @"visibility": @{ @"public": @NO, @"sharedOrganizationIds": @[  ] } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/api/v1/history/:id4n/:organizationId/:sequenceId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"PATCH"];
[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}}/api/v1/history/:id4n/:organizationId/:sequenceId" in
let headers = Header.add_list (Header.init ()) [
  ("authorization", "{{apiKey}}");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"organizationId\": \"\",\n  \"visibility\": {\n    \"public\": false,\n    \"sharedOrganizationIds\": []\n  }\n}" in

Client.call ~headers ~body `PATCH uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/api/v1/history/:id4n/:organizationId/:sequenceId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PATCH",
  CURLOPT_POSTFIELDS => json_encode([
    'organizationId' => '',
    'visibility' => [
        'public' => null,
        'sharedOrganizationIds' => [
                
        ]
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "authorization: {{apiKey}}",
    "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('PATCH', '{{baseUrl}}/api/v1/history/:id4n/:organizationId/:sequenceId', [
  'body' => '{
  "organizationId": "",
  "visibility": {
    "public": false,
    "sharedOrganizationIds": []
  }
}',
  'headers' => [
    'authorization' => '{{apiKey}}',
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/api/v1/history/:id4n/:organizationId/:sequenceId');
$request->setMethod(HttpRequest::HTTP_METH_PATCH);

$request->setHeaders([
  'authorization' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'organizationId' => '',
  'visibility' => [
    'public' => null,
    'sharedOrganizationIds' => [
        
    ]
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'organizationId' => '',
  'visibility' => [
    'public' => null,
    'sharedOrganizationIds' => [
        
    ]
  ]
]));
$request->setRequestUrl('{{baseUrl}}/api/v1/history/:id4n/:organizationId/:sequenceId');
$request->setRequestMethod('PATCH');
$request->setBody($body);

$request->setHeaders([
  'authorization' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/api/v1/history/:id4n/:organizationId/:sequenceId' -Method PATCH -Headers $headers -ContentType 'application/json' -Body '{
  "organizationId": "",
  "visibility": {
    "public": false,
    "sharedOrganizationIds": []
  }
}'
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/api/v1/history/:id4n/:organizationId/:sequenceId' -Method PATCH -Headers $headers -ContentType 'application/json' -Body '{
  "organizationId": "",
  "visibility": {
    "public": false,
    "sharedOrganizationIds": []
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"organizationId\": \"\",\n  \"visibility\": {\n    \"public\": false,\n    \"sharedOrganizationIds\": []\n  }\n}"

headers = {
    'authorization': "{{apiKey}}",
    'content-type': "application/json"
}

conn.request("PATCH", "/baseUrl/api/v1/history/:id4n/:organizationId/:sequenceId", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/api/v1/history/:id4n/:organizationId/:sequenceId"

payload = {
    "organizationId": "",
    "visibility": {
        "public": False,
        "sharedOrganizationIds": []
    }
}
headers = {
    "authorization": "{{apiKey}}",
    "content-type": "application/json"
}

response = requests.patch(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/api/v1/history/:id4n/:organizationId/:sequenceId"

payload <- "{\n  \"organizationId\": \"\",\n  \"visibility\": {\n    \"public\": false,\n    \"sharedOrganizationIds\": []\n  }\n}"

encode <- "json"

response <- VERB("PATCH", url, body = payload, add_headers('authorization' = '{{apiKey}}'), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/api/v1/history/:id4n/:organizationId/:sequenceId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Patch.new(url)
request["authorization"] = '{{apiKey}}'
request["content-type"] = 'application/json'
request.body = "{\n  \"organizationId\": \"\",\n  \"visibility\": {\n    \"public\": false,\n    \"sharedOrganizationIds\": []\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.patch('/baseUrl/api/v1/history/:id4n/:organizationId/:sequenceId') do |req|
  req.headers['authorization'] = '{{apiKey}}'
  req.body = "{\n  \"organizationId\": \"\",\n  \"visibility\": {\n    \"public\": false,\n    \"sharedOrganizationIds\": []\n  }\n}"
end

puts response.status
puts response.body
use std::str::FromStr;
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/api/v1/history/:id4n/:organizationId/:sequenceId";

    let payload = json!({
        "organizationId": "",
        "visibility": json!({
            "public": false,
            "sharedOrganizationIds": ()
        })
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("authorization", "{{apiKey}}".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PATCH").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PATCH \
  --url {{baseUrl}}/api/v1/history/:id4n/:organizationId/:sequenceId \
  --header 'authorization: {{apiKey}}' \
  --header 'content-type: application/json' \
  --data '{
  "organizationId": "",
  "visibility": {
    "public": false,
    "sharedOrganizationIds": []
  }
}'
echo '{
  "organizationId": "",
  "visibility": {
    "public": false,
    "sharedOrganizationIds": []
  }
}' |  \
  http PATCH {{baseUrl}}/api/v1/history/:id4n/:organizationId/:sequenceId \
  authorization:'{{apiKey}}' \
  content-type:application/json
wget --quiet \
  --method PATCH \
  --header 'authorization: {{apiKey}}' \
  --header 'content-type: application/json' \
  --body-data '{\n  "organizationId": "",\n  "visibility": {\n    "public": false,\n    "sharedOrganizationIds": []\n  }\n}' \
  --output-document \
  - {{baseUrl}}/api/v1/history/:id4n/:organizationId/:sequenceId
import Foundation

let headers = [
  "authorization": "{{apiKey}}",
  "content-type": "application/json"
]
let parameters = [
  "organizationId": "",
  "visibility": [
    "public": false,
    "sharedOrganizationIds": []
  ]
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/api/v1/history/:id4n/:organizationId/:sequenceId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "PATCH"
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()
RESPONSE HEADERS

Content-Type
application/json
RESPONSE BODY json

{
  "organizationId": "org.acme",
  "ownerOrganizationId": "de.bluerain",
  "sequenceId": 9784,
  "timestamp": 1517232722,
  "type": "DISPATCHED",
  "visibility": {
    "public": true,
    "sharedOrganizationIds": [
      "de.acme",
      "com.porsche",
      "de.bluerain"
    ]
  }
}
RESPONSE HEADERS

Content-Type
application/xml
RESPONSE BODY xml

{
  "organizationId": "org.acme",
  "ownerOrganizationId": "de.bluerain",
  "sequenceId": 9784,
  "timestamp": 1517232722,
  "type": "DISPATCHED",
  "visibility": {
    "public": true,
    "sharedOrganizationIds": [
      "de.acme",
      "com.porsche",
      "de.bluerain"
    ]
  }
}
GET Resolve image
{{baseUrl}}/api/v1/public/image/:imageID
HEADERS

Authorization
{{apiKey}}
QUERY PARAMS

imageID
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/api/v1/public/image/:imageID");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "authorization: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/api/v1/public/image/:imageID" {:headers {:authorization "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/api/v1/public/image/:imageID"
headers = HTTP::Headers{
  "authorization" => "{{apiKey}}"
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/api/v1/public/image/:imageID"),
    Headers =
    {
        { "authorization", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/api/v1/public/image/:imageID");
var request = new RestRequest("", Method.Get);
request.AddHeader("authorization", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/api/v1/public/image/:imageID"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("authorization", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/api/v1/public/image/:imageID HTTP/1.1
Authorization: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/api/v1/public/image/:imageID")
  .setHeader("authorization", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/api/v1/public/image/:imageID"))
    .header("authorization", "{{apiKey}}")
    .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}}/api/v1/public/image/:imageID")
  .get()
  .addHeader("authorization", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/api/v1/public/image/:imageID")
  .header("authorization", "{{apiKey}}")
  .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}}/api/v1/public/image/:imageID');
xhr.setRequestHeader('authorization', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/api/v1/public/image/:imageID',
  headers: {authorization: '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/api/v1/public/image/:imageID';
const options = {method: 'GET', headers: {authorization: '{{apiKey}}'}};

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}}/api/v1/public/image/:imageID',
  method: 'GET',
  headers: {
    authorization: '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/api/v1/public/image/:imageID")
  .get()
  .addHeader("authorization", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/api/v1/public/image/:imageID',
  headers: {
    authorization: '{{apiKey}}'
  }
};

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}}/api/v1/public/image/:imageID',
  headers: {authorization: '{{apiKey}}'}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/api/v1/public/image/:imageID');

req.headers({
  authorization: '{{apiKey}}'
});

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}}/api/v1/public/image/:imageID',
  headers: {authorization: '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/api/v1/public/image/:imageID';
const options = {method: 'GET', headers: {authorization: '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"authorization": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/api/v1/public/image/:imageID"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

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}}/api/v1/public/image/:imageID" in
let headers = Header.add (Header.init ()) "authorization" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/api/v1/public/image/:imageID",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "authorization: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/api/v1/public/image/:imageID', [
  'headers' => [
    'authorization' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/api/v1/public/image/:imageID');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'authorization' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/api/v1/public/image/:imageID');
$request->setRequestMethod('GET');
$request->setHeaders([
  'authorization' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/api/v1/public/image/:imageID' -Method GET -Headers $headers
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/api/v1/public/image/:imageID' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'authorization': "{{apiKey}}" }

conn.request("GET", "/baseUrl/api/v1/public/image/:imageID", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/api/v1/public/image/:imageID"

headers = {"authorization": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/api/v1/public/image/:imageID"

response <- VERB("GET", url, add_headers('authorization' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/api/v1/public/image/:imageID")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["authorization"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/api/v1/public/image/:imageID') do |req|
  req.headers['authorization'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/api/v1/public/image/:imageID";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("authorization", "{{apiKey}}".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/api/v1/public/image/:imageID \
  --header 'authorization: {{apiKey}}'
http GET {{baseUrl}}/api/v1/public/image/:imageID \
  authorization:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'authorization: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/api/v1/public/image/:imageID
import Foundation

let headers = ["authorization": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/api/v1/public/image/:imageID")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

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 Enqueue a custom message
{{baseUrl}}/api/v1/organizations/:organizationId/messaging/enqueueCustomMessage
HEADERS

Authorization
{{apiKey}}
QUERY PARAMS

organizationId
BODY json

{
  "data": {},
  "name": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/api/v1/organizations/:organizationId/messaging/enqueueCustomMessage");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "authorization: {{apiKey}}");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"data\": \"x = y\",\n  \"name\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/api/v1/organizations/:organizationId/messaging/enqueueCustomMessage" {:headers {:authorization "{{apiKey}}"}
                                                                                                                :content-type :json
                                                                                                                :form-params {:data "x = y"
                                                                                                                              :name ""}})
require "http/client"

url = "{{baseUrl}}/api/v1/organizations/:organizationId/messaging/enqueueCustomMessage"
headers = HTTP::Headers{
  "authorization" => "{{apiKey}}"
  "content-type" => "application/json"
}
reqBody = "{\n  \"data\": \"x = y\",\n  \"name\": \"\"\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}}/api/v1/organizations/:organizationId/messaging/enqueueCustomMessage"),
    Headers =
    {
        { "authorization", "{{apiKey}}" },
    },
    Content = new StringContent("{\n  \"data\": \"x = y\",\n  \"name\": \"\"\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}}/api/v1/organizations/:organizationId/messaging/enqueueCustomMessage");
var request = new RestRequest("", Method.Post);
request.AddHeader("authorization", "{{apiKey}}");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"data\": \"x = y\",\n  \"name\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/api/v1/organizations/:organizationId/messaging/enqueueCustomMessage"

	payload := strings.NewReader("{\n  \"data\": \"x = y\",\n  \"name\": \"\"\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("authorization", "{{apiKey}}")
	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/api/v1/organizations/:organizationId/messaging/enqueueCustomMessage HTTP/1.1
Authorization: {{apiKey}}
Content-Type: application/json
Host: example.com
Content-Length: 47

{
  "data": "x = y",
  "name": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/api/v1/organizations/:organizationId/messaging/enqueueCustomMessage")
  .setHeader("authorization", "{{apiKey}}")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"data\": \"x = y\",\n  \"name\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/api/v1/organizations/:organizationId/messaging/enqueueCustomMessage"))
    .header("authorization", "{{apiKey}}")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"data\": \"x = y\",\n  \"name\": \"\"\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  \"data\": \"x = y\",\n  \"name\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/api/v1/organizations/:organizationId/messaging/enqueueCustomMessage")
  .post(body)
  .addHeader("authorization", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/api/v1/organizations/:organizationId/messaging/enqueueCustomMessage")
  .header("authorization", "{{apiKey}}")
  .header("content-type", "application/json")
  .body("{\n  \"data\": \"x = y\",\n  \"name\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  data: 'x = y',
  name: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/api/v1/organizations/:organizationId/messaging/enqueueCustomMessage');
xhr.setRequestHeader('authorization', '{{apiKey}}');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/api/v1/organizations/:organizationId/messaging/enqueueCustomMessage',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  data: {data: 'x = y', name: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/api/v1/organizations/:organizationId/messaging/enqueueCustomMessage';
const options = {
  method: 'POST',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"data":"x = y","name":""}'
};

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}}/api/v1/organizations/:organizationId/messaging/enqueueCustomMessage',
  method: 'POST',
  headers: {
    authorization: '{{apiKey}}',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "data": "x = y",\n  "name": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"data\": \"x = y\",\n  \"name\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/api/v1/organizations/:organizationId/messaging/enqueueCustomMessage")
  .post(body)
  .addHeader("authorization", "{{apiKey}}")
  .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/api/v1/organizations/:organizationId/messaging/enqueueCustomMessage',
  headers: {
    authorization: '{{apiKey}}',
    '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({data: 'x = y', name: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/api/v1/organizations/:organizationId/messaging/enqueueCustomMessage',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  body: {data: 'x = y', name: ''},
  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}}/api/v1/organizations/:organizationId/messaging/enqueueCustomMessage');

req.headers({
  authorization: '{{apiKey}}',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  data: 'x = y',
  name: ''
});

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}}/api/v1/organizations/:organizationId/messaging/enqueueCustomMessage',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  data: {data: 'x = y', name: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/api/v1/organizations/:organizationId/messaging/enqueueCustomMessage';
const options = {
  method: 'POST',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"data":"x = y","name":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"authorization": @"{{apiKey}}",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"data": @"x = y",
                              @"name": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/api/v1/organizations/:organizationId/messaging/enqueueCustomMessage"]
                                                       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}}/api/v1/organizations/:organizationId/messaging/enqueueCustomMessage" in
let headers = Header.add_list (Header.init ()) [
  ("authorization", "{{apiKey}}");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"data\": \"x = y\",\n  \"name\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/api/v1/organizations/:organizationId/messaging/enqueueCustomMessage",
  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([
    'data' => 'x = y',
    'name' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "authorization: {{apiKey}}",
    "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}}/api/v1/organizations/:organizationId/messaging/enqueueCustomMessage', [
  'body' => '{
  "data": "x = y",
  "name": ""
}',
  'headers' => [
    'authorization' => '{{apiKey}}',
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/api/v1/organizations/:organizationId/messaging/enqueueCustomMessage');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'authorization' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'data' => 'x = y',
  'name' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'data' => 'x = y',
  'name' => ''
]));
$request->setRequestUrl('{{baseUrl}}/api/v1/organizations/:organizationId/messaging/enqueueCustomMessage');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'authorization' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/api/v1/organizations/:organizationId/messaging/enqueueCustomMessage' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "data": "x = y",
  "name": ""
}'
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/api/v1/organizations/:organizationId/messaging/enqueueCustomMessage' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "data": "x = y",
  "name": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"data\": \"x = y\",\n  \"name\": \"\"\n}"

headers = {
    'authorization': "{{apiKey}}",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/api/v1/organizations/:organizationId/messaging/enqueueCustomMessage", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/api/v1/organizations/:organizationId/messaging/enqueueCustomMessage"

payload = {
    "data": "x = y",
    "name": ""
}
headers = {
    "authorization": "{{apiKey}}",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/api/v1/organizations/:organizationId/messaging/enqueueCustomMessage"

payload <- "{\n  \"data\": \"x = y\",\n  \"name\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('authorization' = '{{apiKey}}'), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/api/v1/organizations/:organizationId/messaging/enqueueCustomMessage")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["authorization"] = '{{apiKey}}'
request["content-type"] = 'application/json'
request.body = "{\n  \"data\": \"x = y\",\n  \"name\": \"\"\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/api/v1/organizations/:organizationId/messaging/enqueueCustomMessage') do |req|
  req.headers['authorization'] = '{{apiKey}}'
  req.body = "{\n  \"data\": \"x = y\",\n  \"name\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/api/v1/organizations/:organizationId/messaging/enqueueCustomMessage";

    let payload = json!({
        "data": "x = y",
        "name": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("authorization", "{{apiKey}}".parse().unwrap());
    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}}/api/v1/organizations/:organizationId/messaging/enqueueCustomMessage \
  --header 'authorization: {{apiKey}}' \
  --header 'content-type: application/json' \
  --data '{
  "data": "x = y",
  "name": ""
}'
echo '{
  "data": "x = y",
  "name": ""
}' |  \
  http POST {{baseUrl}}/api/v1/organizations/:organizationId/messaging/enqueueCustomMessage \
  authorization:'{{apiKey}}' \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'authorization: {{apiKey}}' \
  --header 'content-type: application/json' \
  --body-data '{\n  "data": "x = y",\n  "name": ""\n}' \
  --output-document \
  - {{baseUrl}}/api/v1/organizations/:organizationId/messaging/enqueueCustomMessage
import Foundation

let headers = [
  "authorization": "{{apiKey}}",
  "content-type": "application/json"
]
let parameters = [
  "data": "x = y",
  "name": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/api/v1/organizations/:organizationId/messaging/enqueueCustomMessage")! 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()
GET getDefaultQueue
{{baseUrl}}/api/v1/organizations/:organizationId/messaging
HEADERS

Authorization
{{apiKey}}
QUERY PARAMS

organizationId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/api/v1/organizations/:organizationId/messaging");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "authorization: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/api/v1/organizations/:organizationId/messaging" {:headers {:authorization "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/api/v1/organizations/:organizationId/messaging"
headers = HTTP::Headers{
  "authorization" => "{{apiKey}}"
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/api/v1/organizations/:organizationId/messaging"),
    Headers =
    {
        { "authorization", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/api/v1/organizations/:organizationId/messaging");
var request = new RestRequest("", Method.Get);
request.AddHeader("authorization", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/api/v1/organizations/:organizationId/messaging"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("authorization", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/api/v1/organizations/:organizationId/messaging HTTP/1.1
Authorization: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/api/v1/organizations/:organizationId/messaging")
  .setHeader("authorization", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/api/v1/organizations/:organizationId/messaging"))
    .header("authorization", "{{apiKey}}")
    .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}}/api/v1/organizations/:organizationId/messaging")
  .get()
  .addHeader("authorization", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/api/v1/organizations/:organizationId/messaging")
  .header("authorization", "{{apiKey}}")
  .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}}/api/v1/organizations/:organizationId/messaging');
xhr.setRequestHeader('authorization', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/api/v1/organizations/:organizationId/messaging',
  headers: {authorization: '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/api/v1/organizations/:organizationId/messaging';
const options = {method: 'GET', headers: {authorization: '{{apiKey}}'}};

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}}/api/v1/organizations/:organizationId/messaging',
  method: 'GET',
  headers: {
    authorization: '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/api/v1/organizations/:organizationId/messaging")
  .get()
  .addHeader("authorization", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/api/v1/organizations/:organizationId/messaging',
  headers: {
    authorization: '{{apiKey}}'
  }
};

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}}/api/v1/organizations/:organizationId/messaging',
  headers: {authorization: '{{apiKey}}'}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/api/v1/organizations/:organizationId/messaging');

req.headers({
  authorization: '{{apiKey}}'
});

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}}/api/v1/organizations/:organizationId/messaging',
  headers: {authorization: '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/api/v1/organizations/:organizationId/messaging';
const options = {method: 'GET', headers: {authorization: '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"authorization": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/api/v1/organizations/:organizationId/messaging"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

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}}/api/v1/organizations/:organizationId/messaging" in
let headers = Header.add (Header.init ()) "authorization" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/api/v1/organizations/:organizationId/messaging",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "authorization: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/api/v1/organizations/:organizationId/messaging', [
  'headers' => [
    'authorization' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/api/v1/organizations/:organizationId/messaging');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'authorization' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/api/v1/organizations/:organizationId/messaging');
$request->setRequestMethod('GET');
$request->setHeaders([
  'authorization' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/api/v1/organizations/:organizationId/messaging' -Method GET -Headers $headers
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/api/v1/organizations/:organizationId/messaging' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'authorization': "{{apiKey}}" }

conn.request("GET", "/baseUrl/api/v1/organizations/:organizationId/messaging", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/api/v1/organizations/:organizationId/messaging"

headers = {"authorization": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/api/v1/organizations/:organizationId/messaging"

response <- VERB("GET", url, add_headers('authorization' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/api/v1/organizations/:organizationId/messaging")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["authorization"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/api/v1/organizations/:organizationId/messaging') do |req|
  req.headers['authorization'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/api/v1/organizations/:organizationId/messaging";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("authorization", "{{apiKey}}".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/api/v1/organizations/:organizationId/messaging \
  --header 'authorization: {{apiKey}}'
http GET {{baseUrl}}/api/v1/organizations/:organizationId/messaging \
  authorization:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'authorization: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/api/v1/organizations/:organizationId/messaging
import Foundation

let headers = ["authorization": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/api/v1/organizations/:organizationId/messaging")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

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()
RESPONSE HEADERS

Content-Type
application/json
RESPONSE BODY json

{
  "active": true,
  "id": "",
  "waitingMessages": true
}
RESPONSE HEADERS

Content-Type
application/xml
RESPONSE BODY xml

{
  "active": true,
  "id": "",
  "waitingMessages": true
}
PATCH patchDefaultQueue
{{baseUrl}}/api/v1/organizations/:organizationId/messaging
HEADERS

Authorization
{{apiKey}}
QUERY PARAMS

organizationId
BODY json

{
  "active": false,
  "id": "",
  "purgeQueue": false
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PATCH");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/api/v1/organizations/:organizationId/messaging");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "authorization: {{apiKey}}");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"active\": true,\n  \"id\": \"\",\n  \"purgeQueue\": false\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/patch "{{baseUrl}}/api/v1/organizations/:organizationId/messaging" {:headers {:authorization "{{apiKey}}"}
                                                                                            :content-type :json
                                                                                            :form-params {:active true
                                                                                                          :id ""
                                                                                                          :purgeQueue false}})
require "http/client"

url = "{{baseUrl}}/api/v1/organizations/:organizationId/messaging"
headers = HTTP::Headers{
  "authorization" => "{{apiKey}}"
  "content-type" => "application/json"
}
reqBody = "{\n  \"active\": true,\n  \"id\": \"\",\n  \"purgeQueue\": false\n}"

response = HTTP::Client.patch url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Patch,
    RequestUri = new Uri("{{baseUrl}}/api/v1/organizations/:organizationId/messaging"),
    Headers =
    {
        { "authorization", "{{apiKey}}" },
    },
    Content = new StringContent("{\n  \"active\": true,\n  \"id\": \"\",\n  \"purgeQueue\": false\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}}/api/v1/organizations/:organizationId/messaging");
var request = new RestRequest("", Method.Patch);
request.AddHeader("authorization", "{{apiKey}}");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"active\": true,\n  \"id\": \"\",\n  \"purgeQueue\": false\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/api/v1/organizations/:organizationId/messaging"

	payload := strings.NewReader("{\n  \"active\": true,\n  \"id\": \"\",\n  \"purgeQueue\": false\n}")

	req, _ := http.NewRequest("PATCH", url, payload)

	req.Header.Add("authorization", "{{apiKey}}")
	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))

}
PATCH /baseUrl/api/v1/organizations/:organizationId/messaging HTTP/1.1
Authorization: {{apiKey}}
Content-Type: application/json
Host: example.com
Content-Length: 64

{
  "active": true,
  "id": "",
  "purgeQueue": false
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PATCH", "{{baseUrl}}/api/v1/organizations/:organizationId/messaging")
  .setHeader("authorization", "{{apiKey}}")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"active\": true,\n  \"id\": \"\",\n  \"purgeQueue\": false\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/api/v1/organizations/:organizationId/messaging"))
    .header("authorization", "{{apiKey}}")
    .header("content-type", "application/json")
    .method("PATCH", HttpRequest.BodyPublishers.ofString("{\n  \"active\": true,\n  \"id\": \"\",\n  \"purgeQueue\": false\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  \"active\": true,\n  \"id\": \"\",\n  \"purgeQueue\": false\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/api/v1/organizations/:organizationId/messaging")
  .patch(body)
  .addHeader("authorization", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.patch("{{baseUrl}}/api/v1/organizations/:organizationId/messaging")
  .header("authorization", "{{apiKey}}")
  .header("content-type", "application/json")
  .body("{\n  \"active\": true,\n  \"id\": \"\",\n  \"purgeQueue\": false\n}")
  .asString();
const data = JSON.stringify({
  active: true,
  id: '',
  purgeQueue: false
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PATCH', '{{baseUrl}}/api/v1/organizations/:organizationId/messaging');
xhr.setRequestHeader('authorization', '{{apiKey}}');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PATCH',
  url: '{{baseUrl}}/api/v1/organizations/:organizationId/messaging',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  data: {active: true, id: '', purgeQueue: false}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/api/v1/organizations/:organizationId/messaging';
const options = {
  method: 'PATCH',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"active":true,"id":"","purgeQueue":false}'
};

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}}/api/v1/organizations/:organizationId/messaging',
  method: 'PATCH',
  headers: {
    authorization: '{{apiKey}}',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "active": true,\n  "id": "",\n  "purgeQueue": false\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"active\": true,\n  \"id\": \"\",\n  \"purgeQueue\": false\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/api/v1/organizations/:organizationId/messaging")
  .patch(body)
  .addHeader("authorization", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PATCH',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/api/v1/organizations/:organizationId/messaging',
  headers: {
    authorization: '{{apiKey}}',
    '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({active: true, id: '', purgeQueue: false}));
req.end();
const request = require('request');

const options = {
  method: 'PATCH',
  url: '{{baseUrl}}/api/v1/organizations/:organizationId/messaging',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  body: {active: true, id: '', purgeQueue: false},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('PATCH', '{{baseUrl}}/api/v1/organizations/:organizationId/messaging');

req.headers({
  authorization: '{{apiKey}}',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  active: true,
  id: '',
  purgeQueue: false
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'PATCH',
  url: '{{baseUrl}}/api/v1/organizations/:organizationId/messaging',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  data: {active: true, id: '', purgeQueue: false}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/api/v1/organizations/:organizationId/messaging';
const options = {
  method: 'PATCH',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"active":true,"id":"","purgeQueue":false}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"authorization": @"{{apiKey}}",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"active": @YES,
                              @"id": @"",
                              @"purgeQueue": @NO };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/api/v1/organizations/:organizationId/messaging"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"PATCH"];
[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}}/api/v1/organizations/:organizationId/messaging" in
let headers = Header.add_list (Header.init ()) [
  ("authorization", "{{apiKey}}");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"active\": true,\n  \"id\": \"\",\n  \"purgeQueue\": false\n}" in

Client.call ~headers ~body `PATCH uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/api/v1/organizations/:organizationId/messaging",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PATCH",
  CURLOPT_POSTFIELDS => json_encode([
    'active' => null,
    'id' => '',
    'purgeQueue' => null
  ]),
  CURLOPT_HTTPHEADER => [
    "authorization: {{apiKey}}",
    "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('PATCH', '{{baseUrl}}/api/v1/organizations/:organizationId/messaging', [
  'body' => '{
  "active": true,
  "id": "",
  "purgeQueue": false
}',
  'headers' => [
    'authorization' => '{{apiKey}}',
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/api/v1/organizations/:organizationId/messaging');
$request->setMethod(HttpRequest::HTTP_METH_PATCH);

$request->setHeaders([
  'authorization' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'active' => null,
  'id' => '',
  'purgeQueue' => null
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'active' => null,
  'id' => '',
  'purgeQueue' => null
]));
$request->setRequestUrl('{{baseUrl}}/api/v1/organizations/:organizationId/messaging');
$request->setRequestMethod('PATCH');
$request->setBody($body);

$request->setHeaders([
  'authorization' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/api/v1/organizations/:organizationId/messaging' -Method PATCH -Headers $headers -ContentType 'application/json' -Body '{
  "active": true,
  "id": "",
  "purgeQueue": false
}'
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/api/v1/organizations/:organizationId/messaging' -Method PATCH -Headers $headers -ContentType 'application/json' -Body '{
  "active": true,
  "id": "",
  "purgeQueue": false
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"active\": true,\n  \"id\": \"\",\n  \"purgeQueue\": false\n}"

headers = {
    'authorization': "{{apiKey}}",
    'content-type': "application/json"
}

conn.request("PATCH", "/baseUrl/api/v1/organizations/:organizationId/messaging", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/api/v1/organizations/:organizationId/messaging"

payload = {
    "active": True,
    "id": "",
    "purgeQueue": False
}
headers = {
    "authorization": "{{apiKey}}",
    "content-type": "application/json"
}

response = requests.patch(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/api/v1/organizations/:organizationId/messaging"

payload <- "{\n  \"active\": true,\n  \"id\": \"\",\n  \"purgeQueue\": false\n}"

encode <- "json"

response <- VERB("PATCH", url, body = payload, add_headers('authorization' = '{{apiKey}}'), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/api/v1/organizations/:organizationId/messaging")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Patch.new(url)
request["authorization"] = '{{apiKey}}'
request["content-type"] = 'application/json'
request.body = "{\n  \"active\": true,\n  \"id\": \"\",\n  \"purgeQueue\": false\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.patch('/baseUrl/api/v1/organizations/:organizationId/messaging') do |req|
  req.headers['authorization'] = '{{apiKey}}'
  req.body = "{\n  \"active\": true,\n  \"id\": \"\",\n  \"purgeQueue\": false\n}"
end

puts response.status
puts response.body
use std::str::FromStr;
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/api/v1/organizations/:organizationId/messaging";

    let payload = json!({
        "active": true,
        "id": "",
        "purgeQueue": false
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("authorization", "{{apiKey}}".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PATCH").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PATCH \
  --url {{baseUrl}}/api/v1/organizations/:organizationId/messaging \
  --header 'authorization: {{apiKey}}' \
  --header 'content-type: application/json' \
  --data '{
  "active": true,
  "id": "",
  "purgeQueue": false
}'
echo '{
  "active": true,
  "id": "",
  "purgeQueue": false
}' |  \
  http PATCH {{baseUrl}}/api/v1/organizations/:organizationId/messaging \
  authorization:'{{apiKey}}' \
  content-type:application/json
wget --quiet \
  --method PATCH \
  --header 'authorization: {{apiKey}}' \
  --header 'content-type: application/json' \
  --body-data '{\n  "active": true,\n  "id": "",\n  "purgeQueue": false\n}' \
  --output-document \
  - {{baseUrl}}/api/v1/organizations/:organizationId/messaging
import Foundation

let headers = [
  "authorization": "{{apiKey}}",
  "content-type": "application/json"
]
let parameters = [
  "active": true,
  "id": "",
  "purgeQueue": false
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/api/v1/organizations/:organizationId/messaging")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "PATCH"
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()
GET Retrieve version information about ID4i
{{baseUrl}}/api/v1/info
HEADERS

Authorization
{{apiKey}}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/api/v1/info");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "authorization: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/api/v1/info" {:headers {:authorization "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/api/v1/info"
headers = HTTP::Headers{
  "authorization" => "{{apiKey}}"
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/api/v1/info"),
    Headers =
    {
        { "authorization", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/api/v1/info");
var request = new RestRequest("", Method.Get);
request.AddHeader("authorization", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/api/v1/info"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("authorization", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/api/v1/info HTTP/1.1
Authorization: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/api/v1/info")
  .setHeader("authorization", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/api/v1/info"))
    .header("authorization", "{{apiKey}}")
    .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}}/api/v1/info")
  .get()
  .addHeader("authorization", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/api/v1/info")
  .header("authorization", "{{apiKey}}")
  .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}}/api/v1/info');
xhr.setRequestHeader('authorization', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/api/v1/info',
  headers: {authorization: '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/api/v1/info';
const options = {method: 'GET', headers: {authorization: '{{apiKey}}'}};

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}}/api/v1/info',
  method: 'GET',
  headers: {
    authorization: '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/api/v1/info")
  .get()
  .addHeader("authorization", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/api/v1/info',
  headers: {
    authorization: '{{apiKey}}'
  }
};

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}}/api/v1/info',
  headers: {authorization: '{{apiKey}}'}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/api/v1/info');

req.headers({
  authorization: '{{apiKey}}'
});

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}}/api/v1/info',
  headers: {authorization: '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/api/v1/info';
const options = {method: 'GET', headers: {authorization: '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"authorization": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/api/v1/info"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

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}}/api/v1/info" in
let headers = Header.add (Header.init ()) "authorization" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/api/v1/info",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "authorization: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/api/v1/info', [
  'headers' => [
    'authorization' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/api/v1/info');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'authorization' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/api/v1/info');
$request->setRequestMethod('GET');
$request->setHeaders([
  'authorization' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/api/v1/info' -Method GET -Headers $headers
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/api/v1/info' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'authorization': "{{apiKey}}" }

conn.request("GET", "/baseUrl/api/v1/info", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/api/v1/info"

headers = {"authorization": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/api/v1/info"

response <- VERB("GET", url, add_headers('authorization' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/api/v1/info")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["authorization"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/api/v1/info') do |req|
  req.headers['authorization'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/api/v1/info";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("authorization", "{{apiKey}}".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/api/v1/info \
  --header 'authorization: {{apiKey}}'
http GET {{baseUrl}}/api/v1/info \
  authorization:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'authorization: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/api/v1/info
import Foundation

let headers = ["authorization": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/api/v1/info")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

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()
PUT Add partner
{{baseUrl}}/api/v1/organizations/:organizationId/partner
HEADERS

Authorization
{{apiKey}}
QUERY PARAMS

organizationId
BODY json

{
  "organizationId": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/api/v1/organizations/:organizationId/partner");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "authorization: {{apiKey}}");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"organizationId\": \"org.acme\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/api/v1/organizations/:organizationId/partner" {:headers {:authorization "{{apiKey}}"}
                                                                                        :content-type :json
                                                                                        :form-params {:organizationId "org.acme"}})
require "http/client"

url = "{{baseUrl}}/api/v1/organizations/:organizationId/partner"
headers = HTTP::Headers{
  "authorization" => "{{apiKey}}"
  "content-type" => "application/json"
}
reqBody = "{\n  \"organizationId\": \"org.acme\"\n}"

response = HTTP::Client.put url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Put,
    RequestUri = new Uri("{{baseUrl}}/api/v1/organizations/:organizationId/partner"),
    Headers =
    {
        { "authorization", "{{apiKey}}" },
    },
    Content = new StringContent("{\n  \"organizationId\": \"org.acme\"\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}}/api/v1/organizations/:organizationId/partner");
var request = new RestRequest("", Method.Put);
request.AddHeader("authorization", "{{apiKey}}");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"organizationId\": \"org.acme\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/api/v1/organizations/:organizationId/partner"

	payload := strings.NewReader("{\n  \"organizationId\": \"org.acme\"\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("authorization", "{{apiKey}}")
	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))

}
PUT /baseUrl/api/v1/organizations/:organizationId/partner HTTP/1.1
Authorization: {{apiKey}}
Content-Type: application/json
Host: example.com
Content-Length: 34

{
  "organizationId": "org.acme"
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/api/v1/organizations/:organizationId/partner")
  .setHeader("authorization", "{{apiKey}}")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"organizationId\": \"org.acme\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/api/v1/organizations/:organizationId/partner"))
    .header("authorization", "{{apiKey}}")
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"organizationId\": \"org.acme\"\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  \"organizationId\": \"org.acme\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/api/v1/organizations/:organizationId/partner")
  .put(body)
  .addHeader("authorization", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/api/v1/organizations/:organizationId/partner")
  .header("authorization", "{{apiKey}}")
  .header("content-type", "application/json")
  .body("{\n  \"organizationId\": \"org.acme\"\n}")
  .asString();
const data = JSON.stringify({
  organizationId: 'org.acme'
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/api/v1/organizations/:organizationId/partner');
xhr.setRequestHeader('authorization', '{{apiKey}}');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/api/v1/organizations/:organizationId/partner',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  data: {organizationId: 'org.acme'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/api/v1/organizations/:organizationId/partner';
const options = {
  method: 'PUT',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"organizationId":"org.acme"}'
};

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}}/api/v1/organizations/:organizationId/partner',
  method: 'PUT',
  headers: {
    authorization: '{{apiKey}}',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "organizationId": "org.acme"\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"organizationId\": \"org.acme\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/api/v1/organizations/:organizationId/partner")
  .put(body)
  .addHeader("authorization", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/api/v1/organizations/:organizationId/partner',
  headers: {
    authorization: '{{apiKey}}',
    '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({organizationId: 'org.acme'}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/api/v1/organizations/:organizationId/partner',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  body: {organizationId: 'org.acme'},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('PUT', '{{baseUrl}}/api/v1/organizations/:organizationId/partner');

req.headers({
  authorization: '{{apiKey}}',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  organizationId: 'org.acme'
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/api/v1/organizations/:organizationId/partner',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  data: {organizationId: 'org.acme'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/api/v1/organizations/:organizationId/partner';
const options = {
  method: 'PUT',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"organizationId":"org.acme"}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"authorization": @"{{apiKey}}",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"organizationId": @"org.acme" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/api/v1/organizations/:organizationId/partner"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"PUT"];
[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}}/api/v1/organizations/:organizationId/partner" in
let headers = Header.add_list (Header.init ()) [
  ("authorization", "{{apiKey}}");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"organizationId\": \"org.acme\"\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/api/v1/organizations/:organizationId/partner",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
  CURLOPT_POSTFIELDS => json_encode([
    'organizationId' => 'org.acme'
  ]),
  CURLOPT_HTTPHEADER => [
    "authorization: {{apiKey}}",
    "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('PUT', '{{baseUrl}}/api/v1/organizations/:organizationId/partner', [
  'body' => '{
  "organizationId": "org.acme"
}',
  'headers' => [
    'authorization' => '{{apiKey}}',
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/api/v1/organizations/:organizationId/partner');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'authorization' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'organizationId' => 'org.acme'
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'organizationId' => 'org.acme'
]));
$request->setRequestUrl('{{baseUrl}}/api/v1/organizations/:organizationId/partner');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'authorization' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/api/v1/organizations/:organizationId/partner' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "organizationId": "org.acme"
}'
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/api/v1/organizations/:organizationId/partner' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "organizationId": "org.acme"
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"organizationId\": \"org.acme\"\n}"

headers = {
    'authorization': "{{apiKey}}",
    'content-type': "application/json"
}

conn.request("PUT", "/baseUrl/api/v1/organizations/:organizationId/partner", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/api/v1/organizations/:organizationId/partner"

payload = { "organizationId": "org.acme" }
headers = {
    "authorization": "{{apiKey}}",
    "content-type": "application/json"
}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/api/v1/organizations/:organizationId/partner"

payload <- "{\n  \"organizationId\": \"org.acme\"\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, add_headers('authorization' = '{{apiKey}}'), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/api/v1/organizations/:organizationId/partner")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["authorization"] = '{{apiKey}}'
request["content-type"] = 'application/json'
request.body = "{\n  \"organizationId\": \"org.acme\"\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.put('/baseUrl/api/v1/organizations/:organizationId/partner') do |req|
  req.headers['authorization'] = '{{apiKey}}'
  req.body = "{\n  \"organizationId\": \"org.acme\"\n}"
end

puts response.status
puts response.body
use std::str::FromStr;
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/api/v1/organizations/:organizationId/partner";

    let payload = json!({"organizationId": "org.acme"});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("authorization", "{{apiKey}}".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/api/v1/organizations/:organizationId/partner \
  --header 'authorization: {{apiKey}}' \
  --header 'content-type: application/json' \
  --data '{
  "organizationId": "org.acme"
}'
echo '{
  "organizationId": "org.acme"
}' |  \
  http PUT {{baseUrl}}/api/v1/organizations/:organizationId/partner \
  authorization:'{{apiKey}}' \
  content-type:application/json
wget --quiet \
  --method PUT \
  --header 'authorization: {{apiKey}}' \
  --header 'content-type: application/json' \
  --body-data '{\n  "organizationId": "org.acme"\n}' \
  --output-document \
  - {{baseUrl}}/api/v1/organizations/:organizationId/partner
import Foundation

let headers = [
  "authorization": "{{apiKey}}",
  "content-type": "application/json"
]
let parameters = ["organizationId": "org.acme"] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/api/v1/organizations/:organizationId/partner")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "PUT"
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 Create organization
{{baseUrl}}/api/v1/organizations
HEADERS

Authorization
{{apiKey}}
BODY json

{
  "id": 0,
  "logoURL": "",
  "name": "",
  "namespace": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/api/v1/organizations");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "authorization: {{apiKey}}");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"id\": 0,\n  \"logoURL\": \"\",\n  \"name\": \"\",\n  \"namespace\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/api/v1/organizations" {:headers {:authorization "{{apiKey}}"}
                                                                 :content-type :json
                                                                 :form-params {:id 0
                                                                               :logoURL ""
                                                                               :name ""
                                                                               :namespace ""}})
require "http/client"

url = "{{baseUrl}}/api/v1/organizations"
headers = HTTP::Headers{
  "authorization" => "{{apiKey}}"
  "content-type" => "application/json"
}
reqBody = "{\n  \"id\": 0,\n  \"logoURL\": \"\",\n  \"name\": \"\",\n  \"namespace\": \"\"\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}}/api/v1/organizations"),
    Headers =
    {
        { "authorization", "{{apiKey}}" },
    },
    Content = new StringContent("{\n  \"id\": 0,\n  \"logoURL\": \"\",\n  \"name\": \"\",\n  \"namespace\": \"\"\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}}/api/v1/organizations");
var request = new RestRequest("", Method.Post);
request.AddHeader("authorization", "{{apiKey}}");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"id\": 0,\n  \"logoURL\": \"\",\n  \"name\": \"\",\n  \"namespace\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/api/v1/organizations"

	payload := strings.NewReader("{\n  \"id\": 0,\n  \"logoURL\": \"\",\n  \"name\": \"\",\n  \"namespace\": \"\"\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("authorization", "{{apiKey}}")
	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/api/v1/organizations HTTP/1.1
Authorization: {{apiKey}}
Content-Type: application/json
Host: example.com
Content-Length: 63

{
  "id": 0,
  "logoURL": "",
  "name": "",
  "namespace": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/api/v1/organizations")
  .setHeader("authorization", "{{apiKey}}")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"id\": 0,\n  \"logoURL\": \"\",\n  \"name\": \"\",\n  \"namespace\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/api/v1/organizations"))
    .header("authorization", "{{apiKey}}")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"id\": 0,\n  \"logoURL\": \"\",\n  \"name\": \"\",\n  \"namespace\": \"\"\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  \"id\": 0,\n  \"logoURL\": \"\",\n  \"name\": \"\",\n  \"namespace\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/api/v1/organizations")
  .post(body)
  .addHeader("authorization", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/api/v1/organizations")
  .header("authorization", "{{apiKey}}")
  .header("content-type", "application/json")
  .body("{\n  \"id\": 0,\n  \"logoURL\": \"\",\n  \"name\": \"\",\n  \"namespace\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  id: 0,
  logoURL: '',
  name: '',
  namespace: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/api/v1/organizations');
xhr.setRequestHeader('authorization', '{{apiKey}}');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/api/v1/organizations',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  data: {id: 0, logoURL: '', name: '', namespace: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/api/v1/organizations';
const options = {
  method: 'POST',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"id":0,"logoURL":"","name":"","namespace":""}'
};

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}}/api/v1/organizations',
  method: 'POST',
  headers: {
    authorization: '{{apiKey}}',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "id": 0,\n  "logoURL": "",\n  "name": "",\n  "namespace": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"id\": 0,\n  \"logoURL\": \"\",\n  \"name\": \"\",\n  \"namespace\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/api/v1/organizations")
  .post(body)
  .addHeader("authorization", "{{apiKey}}")
  .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/api/v1/organizations',
  headers: {
    authorization: '{{apiKey}}',
    '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({id: 0, logoURL: '', name: '', namespace: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/api/v1/organizations',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  body: {id: 0, logoURL: '', name: '', namespace: ''},
  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}}/api/v1/organizations');

req.headers({
  authorization: '{{apiKey}}',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  id: 0,
  logoURL: '',
  name: '',
  namespace: ''
});

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}}/api/v1/organizations',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  data: {id: 0, logoURL: '', name: '', namespace: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/api/v1/organizations';
const options = {
  method: 'POST',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"id":0,"logoURL":"","name":"","namespace":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"authorization": @"{{apiKey}}",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"id": @0,
                              @"logoURL": @"",
                              @"name": @"",
                              @"namespace": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/api/v1/organizations"]
                                                       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}}/api/v1/organizations" in
let headers = Header.add_list (Header.init ()) [
  ("authorization", "{{apiKey}}");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"id\": 0,\n  \"logoURL\": \"\",\n  \"name\": \"\",\n  \"namespace\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/api/v1/organizations",
  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([
    'id' => 0,
    'logoURL' => '',
    'name' => '',
    'namespace' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "authorization: {{apiKey}}",
    "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}}/api/v1/organizations', [
  'body' => '{
  "id": 0,
  "logoURL": "",
  "name": "",
  "namespace": ""
}',
  'headers' => [
    'authorization' => '{{apiKey}}',
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/api/v1/organizations');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'authorization' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'id' => 0,
  'logoURL' => '',
  'name' => '',
  'namespace' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'id' => 0,
  'logoURL' => '',
  'name' => '',
  'namespace' => ''
]));
$request->setRequestUrl('{{baseUrl}}/api/v1/organizations');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'authorization' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/api/v1/organizations' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "id": 0,
  "logoURL": "",
  "name": "",
  "namespace": ""
}'
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/api/v1/organizations' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "id": 0,
  "logoURL": "",
  "name": "",
  "namespace": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"id\": 0,\n  \"logoURL\": \"\",\n  \"name\": \"\",\n  \"namespace\": \"\"\n}"

headers = {
    'authorization': "{{apiKey}}",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/api/v1/organizations", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/api/v1/organizations"

payload = {
    "id": 0,
    "logoURL": "",
    "name": "",
    "namespace": ""
}
headers = {
    "authorization": "{{apiKey}}",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/api/v1/organizations"

payload <- "{\n  \"id\": 0,\n  \"logoURL\": \"\",\n  \"name\": \"\",\n  \"namespace\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('authorization' = '{{apiKey}}'), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/api/v1/organizations")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["authorization"] = '{{apiKey}}'
request["content-type"] = 'application/json'
request.body = "{\n  \"id\": 0,\n  \"logoURL\": \"\",\n  \"name\": \"\",\n  \"namespace\": \"\"\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/api/v1/organizations') do |req|
  req.headers['authorization'] = '{{apiKey}}'
  req.body = "{\n  \"id\": 0,\n  \"logoURL\": \"\",\n  \"name\": \"\",\n  \"namespace\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/api/v1/organizations";

    let payload = json!({
        "id": 0,
        "logoURL": "",
        "name": "",
        "namespace": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("authorization", "{{apiKey}}".parse().unwrap());
    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}}/api/v1/organizations \
  --header 'authorization: {{apiKey}}' \
  --header 'content-type: application/json' \
  --data '{
  "id": 0,
  "logoURL": "",
  "name": "",
  "namespace": ""
}'
echo '{
  "id": 0,
  "logoURL": "",
  "name": "",
  "namespace": ""
}' |  \
  http POST {{baseUrl}}/api/v1/organizations \
  authorization:'{{apiKey}}' \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'authorization: {{apiKey}}' \
  --header 'content-type: application/json' \
  --body-data '{\n  "id": 0,\n  "logoURL": "",\n  "name": "",\n  "namespace": ""\n}' \
  --output-document \
  - {{baseUrl}}/api/v1/organizations
import Foundation

let headers = [
  "authorization": "{{apiKey}}",
  "content-type": "application/json"
]
let parameters = [
  "id": 0,
  "logoURL": "",
  "name": "",
  "namespace": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/api/v1/organizations")! 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()
RESPONSE HEADERS

Content-Type
application/json
RESPONSE BODY json

{
  "id": 100,
  "logoURL": "/api/v1/public/images/abcdef",
  "name": "ACME Inc.",
  "namespace": "de.acme"
}
RESPONSE HEADERS

Content-Type
application/xml
RESPONSE BODY xml

{
  "id": 100,
  "logoURL": "/api/v1/public/images/abcdef",
  "name": "ACME Inc.",
  "namespace": "de.acme"
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/api/v1/organizations/:organizationId/logo");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "authorization: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/api/v1/organizations/:organizationId/logo" {:headers {:authorization "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/api/v1/organizations/:organizationId/logo"
headers = HTTP::Headers{
  "authorization" => "{{apiKey}}"
}

response = HTTP::Client.delete url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Delete,
    RequestUri = new Uri("{{baseUrl}}/api/v1/organizations/:organizationId/logo"),
    Headers =
    {
        { "authorization", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/api/v1/organizations/:organizationId/logo");
var request = new RestRequest("", Method.Delete);
request.AddHeader("authorization", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/api/v1/organizations/:organizationId/logo"

	req, _ := http.NewRequest("DELETE", url, nil)

	req.Header.Add("authorization", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/api/v1/organizations/:organizationId/logo HTTP/1.1
Authorization: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/api/v1/organizations/:organizationId/logo")
  .setHeader("authorization", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/api/v1/organizations/:organizationId/logo"))
    .header("authorization", "{{apiKey}}")
    .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}}/api/v1/organizations/:organizationId/logo")
  .delete(null)
  .addHeader("authorization", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/api/v1/organizations/:organizationId/logo")
  .header("authorization", "{{apiKey}}")
  .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}}/api/v1/organizations/:organizationId/logo');
xhr.setRequestHeader('authorization', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/api/v1/organizations/:organizationId/logo',
  headers: {authorization: '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/api/v1/organizations/:organizationId/logo';
const options = {method: 'DELETE', headers: {authorization: '{{apiKey}}'}};

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}}/api/v1/organizations/:organizationId/logo',
  method: 'DELETE',
  headers: {
    authorization: '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/api/v1/organizations/:organizationId/logo")
  .delete(null)
  .addHeader("authorization", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/api/v1/organizations/:organizationId/logo',
  headers: {
    authorization: '{{apiKey}}'
  }
};

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}}/api/v1/organizations/:organizationId/logo',
  headers: {authorization: '{{apiKey}}'}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('DELETE', '{{baseUrl}}/api/v1/organizations/:organizationId/logo');

req.headers({
  authorization: '{{apiKey}}'
});

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}}/api/v1/organizations/:organizationId/logo',
  headers: {authorization: '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/api/v1/organizations/:organizationId/logo';
const options = {method: 'DELETE', headers: {authorization: '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"authorization": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/api/v1/organizations/:organizationId/logo"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"DELETE"];
[request setAllHTTPHeaderFields:headers];

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}}/api/v1/organizations/:organizationId/logo" in
let headers = Header.add (Header.init ()) "authorization" "{{apiKey}}" in

Client.call ~headers `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/api/v1/organizations/:organizationId/logo",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
  CURLOPT_HTTPHEADER => [
    "authorization: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/api/v1/organizations/:organizationId/logo', [
  'headers' => [
    'authorization' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/api/v1/organizations/:organizationId/logo');
$request->setMethod(HTTP_METH_DELETE);

$request->setHeaders([
  'authorization' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/api/v1/organizations/:organizationId/logo');
$request->setRequestMethod('DELETE');
$request->setHeaders([
  'authorization' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/api/v1/organizations/:organizationId/logo' -Method DELETE -Headers $headers
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/api/v1/organizations/:organizationId/logo' -Method DELETE -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'authorization': "{{apiKey}}" }

conn.request("DELETE", "/baseUrl/api/v1/organizations/:organizationId/logo", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/api/v1/organizations/:organizationId/logo"

headers = {"authorization": "{{apiKey}}"}

response = requests.delete(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/api/v1/organizations/:organizationId/logo"

response <- VERB("DELETE", url, add_headers('authorization' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/api/v1/organizations/:organizationId/logo")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)
request["authorization"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/api/v1/organizations/:organizationId/logo') do |req|
  req.headers['authorization'] = '{{apiKey}}'
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/api/v1/organizations/:organizationId/logo";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("authorization", "{{apiKey}}".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("DELETE").unwrap(), url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request DELETE \
  --url {{baseUrl}}/api/v1/organizations/:organizationId/logo \
  --header 'authorization: {{apiKey}}'
http DELETE {{baseUrl}}/api/v1/organizations/:organizationId/logo \
  authorization:'{{apiKey}}'
wget --quiet \
  --method DELETE \
  --header 'authorization: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/api/v1/organizations/:organizationId/logo
import Foundation

let headers = ["authorization": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/api/v1/organizations/:organizationId/logo")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "DELETE"
request.allHTTPHeaderFields = headers

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 Delete organization
{{baseUrl}}/api/v1/organizations/:organizationId
HEADERS

Authorization
{{apiKey}}
QUERY PARAMS

organizationId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/api/v1/organizations/:organizationId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "authorization: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/api/v1/organizations/:organizationId" {:headers {:authorization "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/api/v1/organizations/:organizationId"
headers = HTTP::Headers{
  "authorization" => "{{apiKey}}"
}

response = HTTP::Client.delete url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Delete,
    RequestUri = new Uri("{{baseUrl}}/api/v1/organizations/:organizationId"),
    Headers =
    {
        { "authorization", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/api/v1/organizations/:organizationId");
var request = new RestRequest("", Method.Delete);
request.AddHeader("authorization", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/api/v1/organizations/:organizationId"

	req, _ := http.NewRequest("DELETE", url, nil)

	req.Header.Add("authorization", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/api/v1/organizations/:organizationId HTTP/1.1
Authorization: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/api/v1/organizations/:organizationId")
  .setHeader("authorization", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/api/v1/organizations/:organizationId"))
    .header("authorization", "{{apiKey}}")
    .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}}/api/v1/organizations/:organizationId")
  .delete(null)
  .addHeader("authorization", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/api/v1/organizations/:organizationId")
  .header("authorization", "{{apiKey}}")
  .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}}/api/v1/organizations/:organizationId');
xhr.setRequestHeader('authorization', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/api/v1/organizations/:organizationId',
  headers: {authorization: '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/api/v1/organizations/:organizationId';
const options = {method: 'DELETE', headers: {authorization: '{{apiKey}}'}};

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}}/api/v1/organizations/:organizationId',
  method: 'DELETE',
  headers: {
    authorization: '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/api/v1/organizations/:organizationId")
  .delete(null)
  .addHeader("authorization", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/api/v1/organizations/:organizationId',
  headers: {
    authorization: '{{apiKey}}'
  }
};

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}}/api/v1/organizations/:organizationId',
  headers: {authorization: '{{apiKey}}'}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('DELETE', '{{baseUrl}}/api/v1/organizations/:organizationId');

req.headers({
  authorization: '{{apiKey}}'
});

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}}/api/v1/organizations/:organizationId',
  headers: {authorization: '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/api/v1/organizations/:organizationId';
const options = {method: 'DELETE', headers: {authorization: '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"authorization": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/api/v1/organizations/:organizationId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"DELETE"];
[request setAllHTTPHeaderFields:headers];

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}}/api/v1/organizations/:organizationId" in
let headers = Header.add (Header.init ()) "authorization" "{{apiKey}}" in

Client.call ~headers `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/api/v1/organizations/:organizationId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
  CURLOPT_HTTPHEADER => [
    "authorization: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/api/v1/organizations/:organizationId', [
  'headers' => [
    'authorization' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/api/v1/organizations/:organizationId');
$request->setMethod(HTTP_METH_DELETE);

$request->setHeaders([
  'authorization' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/api/v1/organizations/:organizationId');
$request->setRequestMethod('DELETE');
$request->setHeaders([
  'authorization' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/api/v1/organizations/:organizationId' -Method DELETE -Headers $headers
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/api/v1/organizations/:organizationId' -Method DELETE -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'authorization': "{{apiKey}}" }

conn.request("DELETE", "/baseUrl/api/v1/organizations/:organizationId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/api/v1/organizations/:organizationId"

headers = {"authorization": "{{apiKey}}"}

response = requests.delete(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/api/v1/organizations/:organizationId"

response <- VERB("DELETE", url, add_headers('authorization' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/api/v1/organizations/:organizationId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)
request["authorization"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/api/v1/organizations/:organizationId') do |req|
  req.headers['authorization'] = '{{apiKey}}'
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/api/v1/organizations/:organizationId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("authorization", "{{apiKey}}".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("DELETE").unwrap(), url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request DELETE \
  --url {{baseUrl}}/api/v1/organizations/:organizationId \
  --header 'authorization: {{apiKey}}'
http DELETE {{baseUrl}}/api/v1/organizations/:organizationId \
  authorization:'{{apiKey}}'
wget --quiet \
  --method DELETE \
  --header 'authorization: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/api/v1/organizations/:organizationId
import Foundation

let headers = ["authorization": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/api/v1/organizations/:organizationId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "DELETE"
request.allHTTPHeaderFields = headers

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 Find organization by id-namespace
{{baseUrl}}/api/v1/organizations/:organizationId
HEADERS

Authorization
{{apiKey}}
QUERY PARAMS

organizationId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/api/v1/organizations/:organizationId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "authorization: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/api/v1/organizations/:organizationId" {:headers {:authorization "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/api/v1/organizations/:organizationId"
headers = HTTP::Headers{
  "authorization" => "{{apiKey}}"
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/api/v1/organizations/:organizationId"),
    Headers =
    {
        { "authorization", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/api/v1/organizations/:organizationId");
var request = new RestRequest("", Method.Get);
request.AddHeader("authorization", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/api/v1/organizations/:organizationId"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("authorization", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/api/v1/organizations/:organizationId HTTP/1.1
Authorization: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/api/v1/organizations/:organizationId")
  .setHeader("authorization", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/api/v1/organizations/:organizationId"))
    .header("authorization", "{{apiKey}}")
    .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}}/api/v1/organizations/:organizationId")
  .get()
  .addHeader("authorization", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/api/v1/organizations/:organizationId")
  .header("authorization", "{{apiKey}}")
  .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}}/api/v1/organizations/:organizationId');
xhr.setRequestHeader('authorization', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/api/v1/organizations/:organizationId',
  headers: {authorization: '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/api/v1/organizations/:organizationId';
const options = {method: 'GET', headers: {authorization: '{{apiKey}}'}};

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}}/api/v1/organizations/:organizationId',
  method: 'GET',
  headers: {
    authorization: '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/api/v1/organizations/:organizationId")
  .get()
  .addHeader("authorization", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/api/v1/organizations/:organizationId',
  headers: {
    authorization: '{{apiKey}}'
  }
};

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}}/api/v1/organizations/:organizationId',
  headers: {authorization: '{{apiKey}}'}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/api/v1/organizations/:organizationId');

req.headers({
  authorization: '{{apiKey}}'
});

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}}/api/v1/organizations/:organizationId',
  headers: {authorization: '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/api/v1/organizations/:organizationId';
const options = {method: 'GET', headers: {authorization: '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"authorization": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/api/v1/organizations/:organizationId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

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}}/api/v1/organizations/:organizationId" in
let headers = Header.add (Header.init ()) "authorization" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/api/v1/organizations/:organizationId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "authorization: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/api/v1/organizations/:organizationId', [
  'headers' => [
    'authorization' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/api/v1/organizations/:organizationId');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'authorization' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/api/v1/organizations/:organizationId');
$request->setRequestMethod('GET');
$request->setHeaders([
  'authorization' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/api/v1/organizations/:organizationId' -Method GET -Headers $headers
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/api/v1/organizations/:organizationId' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'authorization': "{{apiKey}}" }

conn.request("GET", "/baseUrl/api/v1/organizations/:organizationId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/api/v1/organizations/:organizationId"

headers = {"authorization": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/api/v1/organizations/:organizationId"

response <- VERB("GET", url, add_headers('authorization' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/api/v1/organizations/:organizationId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["authorization"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/api/v1/organizations/:organizationId') do |req|
  req.headers['authorization'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/api/v1/organizations/:organizationId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("authorization", "{{apiKey}}".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/api/v1/organizations/:organizationId \
  --header 'authorization: {{apiKey}}'
http GET {{baseUrl}}/api/v1/organizations/:organizationId \
  authorization:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'authorization: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/api/v1/organizations/:organizationId
import Foundation

let headers = ["authorization": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/api/v1/organizations/:organizationId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

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()
RESPONSE HEADERS

Content-Type
application/json
RESPONSE BODY json

{
  "id": 100,
  "logoURL": "/api/v1/public/images/abcdef",
  "name": "ACME Inc.",
  "namespace": "de.acme"
}
RESPONSE HEADERS

Content-Type
application/xml
RESPONSE BODY xml

{
  "id": 100,
  "logoURL": "/api/v1/public/images/abcdef",
  "name": "ACME Inc.",
  "namespace": "de.acme"
}
GET Get partners of an organization
{{baseUrl}}/api/v1/organizations/:organizationId/partner
HEADERS

Authorization
{{apiKey}}
QUERY PARAMS

organizationId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/api/v1/organizations/:organizationId/partner");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "authorization: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/api/v1/organizations/:organizationId/partner" {:headers {:authorization "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/api/v1/organizations/:organizationId/partner"
headers = HTTP::Headers{
  "authorization" => "{{apiKey}}"
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/api/v1/organizations/:organizationId/partner"),
    Headers =
    {
        { "authorization", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/api/v1/organizations/:organizationId/partner");
var request = new RestRequest("", Method.Get);
request.AddHeader("authorization", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/api/v1/organizations/:organizationId/partner"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("authorization", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/api/v1/organizations/:organizationId/partner HTTP/1.1
Authorization: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/api/v1/organizations/:organizationId/partner")
  .setHeader("authorization", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/api/v1/organizations/:organizationId/partner"))
    .header("authorization", "{{apiKey}}")
    .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}}/api/v1/organizations/:organizationId/partner")
  .get()
  .addHeader("authorization", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/api/v1/organizations/:organizationId/partner")
  .header("authorization", "{{apiKey}}")
  .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}}/api/v1/organizations/:organizationId/partner');
xhr.setRequestHeader('authorization', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/api/v1/organizations/:organizationId/partner',
  headers: {authorization: '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/api/v1/organizations/:organizationId/partner';
const options = {method: 'GET', headers: {authorization: '{{apiKey}}'}};

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}}/api/v1/organizations/:organizationId/partner',
  method: 'GET',
  headers: {
    authorization: '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/api/v1/organizations/:organizationId/partner")
  .get()
  .addHeader("authorization", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/api/v1/organizations/:organizationId/partner',
  headers: {
    authorization: '{{apiKey}}'
  }
};

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}}/api/v1/organizations/:organizationId/partner',
  headers: {authorization: '{{apiKey}}'}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/api/v1/organizations/:organizationId/partner');

req.headers({
  authorization: '{{apiKey}}'
});

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}}/api/v1/organizations/:organizationId/partner',
  headers: {authorization: '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/api/v1/organizations/:organizationId/partner';
const options = {method: 'GET', headers: {authorization: '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"authorization": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/api/v1/organizations/:organizationId/partner"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

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}}/api/v1/organizations/:organizationId/partner" in
let headers = Header.add (Header.init ()) "authorization" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/api/v1/organizations/:organizationId/partner",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "authorization: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/api/v1/organizations/:organizationId/partner', [
  'headers' => [
    'authorization' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/api/v1/organizations/:organizationId/partner');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'authorization' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/api/v1/organizations/:organizationId/partner');
$request->setRequestMethod('GET');
$request->setHeaders([
  'authorization' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/api/v1/organizations/:organizationId/partner' -Method GET -Headers $headers
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/api/v1/organizations/:organizationId/partner' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'authorization': "{{apiKey}}" }

conn.request("GET", "/baseUrl/api/v1/organizations/:organizationId/partner", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/api/v1/organizations/:organizationId/partner"

headers = {"authorization": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/api/v1/organizations/:organizationId/partner"

response <- VERB("GET", url, add_headers('authorization' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/api/v1/organizations/:organizationId/partner")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["authorization"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/api/v1/organizations/:organizationId/partner') do |req|
  req.headers['authorization'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/api/v1/organizations/:organizationId/partner";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("authorization", "{{apiKey}}".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/api/v1/organizations/:organizationId/partner \
  --header 'authorization: {{apiKey}}'
http GET {{baseUrl}}/api/v1/organizations/:organizationId/partner \
  authorization:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'authorization: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/api/v1/organizations/:organizationId/partner
import Foundation

let headers = ["authorization": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/api/v1/organizations/:organizationId/partner")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

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()
RESPONSE HEADERS

Content-Type
application/json
RESPONSE BODY json

{
  "limit": 100,
  "offset": 0,
  "total": 200
}
RESPONSE HEADERS

Content-Type
application/xml
RESPONSE BODY xml

{
  "limit": 100,
  "offset": 0,
  "total": 200
}
GET List countries
{{baseUrl}}/api/v1/countries
HEADERS

Authorization
{{apiKey}}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/api/v1/countries");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "authorization: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/api/v1/countries" {:headers {:authorization "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/api/v1/countries"
headers = HTTP::Headers{
  "authorization" => "{{apiKey}}"
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/api/v1/countries"),
    Headers =
    {
        { "authorization", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/api/v1/countries");
var request = new RestRequest("", Method.Get);
request.AddHeader("authorization", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/api/v1/countries"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("authorization", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/api/v1/countries HTTP/1.1
Authorization: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/api/v1/countries")
  .setHeader("authorization", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/api/v1/countries"))
    .header("authorization", "{{apiKey}}")
    .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}}/api/v1/countries")
  .get()
  .addHeader("authorization", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/api/v1/countries")
  .header("authorization", "{{apiKey}}")
  .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}}/api/v1/countries');
xhr.setRequestHeader('authorization', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/api/v1/countries',
  headers: {authorization: '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/api/v1/countries';
const options = {method: 'GET', headers: {authorization: '{{apiKey}}'}};

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}}/api/v1/countries',
  method: 'GET',
  headers: {
    authorization: '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/api/v1/countries")
  .get()
  .addHeader("authorization", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/api/v1/countries',
  headers: {
    authorization: '{{apiKey}}'
  }
};

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}}/api/v1/countries',
  headers: {authorization: '{{apiKey}}'}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/api/v1/countries');

req.headers({
  authorization: '{{apiKey}}'
});

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}}/api/v1/countries',
  headers: {authorization: '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/api/v1/countries';
const options = {method: 'GET', headers: {authorization: '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"authorization": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/api/v1/countries"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

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}}/api/v1/countries" in
let headers = Header.add (Header.init ()) "authorization" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/api/v1/countries",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "authorization: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/api/v1/countries', [
  'headers' => [
    'authorization' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/api/v1/countries');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'authorization' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/api/v1/countries');
$request->setRequestMethod('GET');
$request->setHeaders([
  'authorization' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/api/v1/countries' -Method GET -Headers $headers
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/api/v1/countries' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'authorization': "{{apiKey}}" }

conn.request("GET", "/baseUrl/api/v1/countries", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/api/v1/countries"

headers = {"authorization": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/api/v1/countries"

response <- VERB("GET", url, add_headers('authorization' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/api/v1/countries")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["authorization"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/api/v1/countries') do |req|
  req.headers['authorization'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/api/v1/countries";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("authorization", "{{apiKey}}".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/api/v1/countries \
  --header 'authorization: {{apiKey}}'
http GET {{baseUrl}}/api/v1/countries \
  authorization:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'authorization: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/api/v1/countries
import Foundation

let headers = ["authorization": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/api/v1/countries")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

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()
RESPONSE HEADERS

Content-Type
application/json
RESPONSE BODY json

{
  "limit": 100,
  "offset": 0,
  "total": 200
}
RESPONSE HEADERS

Content-Type
application/xml
RESPONSE BODY xml

{
  "limit": 100,
  "offset": 0,
  "total": 200
}
GET List my privileges
{{baseUrl}}/api/v1/organizations/:organizationId/privileges
HEADERS

Authorization
{{apiKey}}
QUERY PARAMS

organizationId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/api/v1/organizations/:organizationId/privileges");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "authorization: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/api/v1/organizations/:organizationId/privileges" {:headers {:authorization "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/api/v1/organizations/:organizationId/privileges"
headers = HTTP::Headers{
  "authorization" => "{{apiKey}}"
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/api/v1/organizations/:organizationId/privileges"),
    Headers =
    {
        { "authorization", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/api/v1/organizations/:organizationId/privileges");
var request = new RestRequest("", Method.Get);
request.AddHeader("authorization", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/api/v1/organizations/:organizationId/privileges"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("authorization", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/api/v1/organizations/:organizationId/privileges HTTP/1.1
Authorization: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/api/v1/organizations/:organizationId/privileges")
  .setHeader("authorization", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/api/v1/organizations/:organizationId/privileges"))
    .header("authorization", "{{apiKey}}")
    .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}}/api/v1/organizations/:organizationId/privileges")
  .get()
  .addHeader("authorization", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/api/v1/organizations/:organizationId/privileges")
  .header("authorization", "{{apiKey}}")
  .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}}/api/v1/organizations/:organizationId/privileges');
xhr.setRequestHeader('authorization', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/api/v1/organizations/:organizationId/privileges',
  headers: {authorization: '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/api/v1/organizations/:organizationId/privileges';
const options = {method: 'GET', headers: {authorization: '{{apiKey}}'}};

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}}/api/v1/organizations/:organizationId/privileges',
  method: 'GET',
  headers: {
    authorization: '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/api/v1/organizations/:organizationId/privileges")
  .get()
  .addHeader("authorization", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/api/v1/organizations/:organizationId/privileges',
  headers: {
    authorization: '{{apiKey}}'
  }
};

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}}/api/v1/organizations/:organizationId/privileges',
  headers: {authorization: '{{apiKey}}'}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/api/v1/organizations/:organizationId/privileges');

req.headers({
  authorization: '{{apiKey}}'
});

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}}/api/v1/organizations/:organizationId/privileges',
  headers: {authorization: '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/api/v1/organizations/:organizationId/privileges';
const options = {method: 'GET', headers: {authorization: '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"authorization": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/api/v1/organizations/:organizationId/privileges"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

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}}/api/v1/organizations/:organizationId/privileges" in
let headers = Header.add (Header.init ()) "authorization" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/api/v1/organizations/:organizationId/privileges",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "authorization: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/api/v1/organizations/:organizationId/privileges', [
  'headers' => [
    'authorization' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/api/v1/organizations/:organizationId/privileges');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'authorization' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/api/v1/organizations/:organizationId/privileges');
$request->setRequestMethod('GET');
$request->setHeaders([
  'authorization' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/api/v1/organizations/:organizationId/privileges' -Method GET -Headers $headers
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/api/v1/organizations/:organizationId/privileges' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'authorization': "{{apiKey}}" }

conn.request("GET", "/baseUrl/api/v1/organizations/:organizationId/privileges", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/api/v1/organizations/:organizationId/privileges"

headers = {"authorization": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/api/v1/organizations/:organizationId/privileges"

response <- VERB("GET", url, add_headers('authorization' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/api/v1/organizations/:organizationId/privileges")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["authorization"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/api/v1/organizations/:organizationId/privileges') do |req|
  req.headers['authorization'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/api/v1/organizations/:organizationId/privileges";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("authorization", "{{apiKey}}".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/api/v1/organizations/:organizationId/privileges \
  --header 'authorization: {{apiKey}}'
http GET {{baseUrl}}/api/v1/organizations/:organizationId/privileges \
  authorization:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'authorization: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/api/v1/organizations/:organizationId/privileges
import Foundation

let headers = ["authorization": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/api/v1/organizations/:organizationId/privileges")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

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 Remove billing address
{{baseUrl}}/api/v1/organizations/:organizationId/addresses/billing
HEADERS

Authorization
{{apiKey}}
QUERY PARAMS

organizationId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/api/v1/organizations/:organizationId/addresses/billing");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "authorization: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/api/v1/organizations/:organizationId/addresses/billing" {:headers {:authorization "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/api/v1/organizations/:organizationId/addresses/billing"
headers = HTTP::Headers{
  "authorization" => "{{apiKey}}"
}

response = HTTP::Client.delete url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Delete,
    RequestUri = new Uri("{{baseUrl}}/api/v1/organizations/:organizationId/addresses/billing"),
    Headers =
    {
        { "authorization", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/api/v1/organizations/:organizationId/addresses/billing");
var request = new RestRequest("", Method.Delete);
request.AddHeader("authorization", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/api/v1/organizations/:organizationId/addresses/billing"

	req, _ := http.NewRequest("DELETE", url, nil)

	req.Header.Add("authorization", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/api/v1/organizations/:organizationId/addresses/billing HTTP/1.1
Authorization: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/api/v1/organizations/:organizationId/addresses/billing")
  .setHeader("authorization", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/api/v1/organizations/:organizationId/addresses/billing"))
    .header("authorization", "{{apiKey}}")
    .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}}/api/v1/organizations/:organizationId/addresses/billing")
  .delete(null)
  .addHeader("authorization", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/api/v1/organizations/:organizationId/addresses/billing")
  .header("authorization", "{{apiKey}}")
  .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}}/api/v1/organizations/:organizationId/addresses/billing');
xhr.setRequestHeader('authorization', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/api/v1/organizations/:organizationId/addresses/billing',
  headers: {authorization: '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/api/v1/organizations/:organizationId/addresses/billing';
const options = {method: 'DELETE', headers: {authorization: '{{apiKey}}'}};

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}}/api/v1/organizations/:organizationId/addresses/billing',
  method: 'DELETE',
  headers: {
    authorization: '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/api/v1/organizations/:organizationId/addresses/billing")
  .delete(null)
  .addHeader("authorization", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/api/v1/organizations/:organizationId/addresses/billing',
  headers: {
    authorization: '{{apiKey}}'
  }
};

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}}/api/v1/organizations/:organizationId/addresses/billing',
  headers: {authorization: '{{apiKey}}'}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('DELETE', '{{baseUrl}}/api/v1/organizations/:organizationId/addresses/billing');

req.headers({
  authorization: '{{apiKey}}'
});

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}}/api/v1/organizations/:organizationId/addresses/billing',
  headers: {authorization: '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/api/v1/organizations/:organizationId/addresses/billing';
const options = {method: 'DELETE', headers: {authorization: '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"authorization": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/api/v1/organizations/:organizationId/addresses/billing"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"DELETE"];
[request setAllHTTPHeaderFields:headers];

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}}/api/v1/organizations/:organizationId/addresses/billing" in
let headers = Header.add (Header.init ()) "authorization" "{{apiKey}}" in

Client.call ~headers `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/api/v1/organizations/:organizationId/addresses/billing",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
  CURLOPT_HTTPHEADER => [
    "authorization: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/api/v1/organizations/:organizationId/addresses/billing', [
  'headers' => [
    'authorization' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/api/v1/organizations/:organizationId/addresses/billing');
$request->setMethod(HTTP_METH_DELETE);

$request->setHeaders([
  'authorization' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/api/v1/organizations/:organizationId/addresses/billing');
$request->setRequestMethod('DELETE');
$request->setHeaders([
  'authorization' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/api/v1/organizations/:organizationId/addresses/billing' -Method DELETE -Headers $headers
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/api/v1/organizations/:organizationId/addresses/billing' -Method DELETE -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'authorization': "{{apiKey}}" }

conn.request("DELETE", "/baseUrl/api/v1/organizations/:organizationId/addresses/billing", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/api/v1/organizations/:organizationId/addresses/billing"

headers = {"authorization": "{{apiKey}}"}

response = requests.delete(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/api/v1/organizations/:organizationId/addresses/billing"

response <- VERB("DELETE", url, add_headers('authorization' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/api/v1/organizations/:organizationId/addresses/billing")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)
request["authorization"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/api/v1/organizations/:organizationId/addresses/billing') do |req|
  req.headers['authorization'] = '{{apiKey}}'
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/api/v1/organizations/:organizationId/addresses/billing";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("authorization", "{{apiKey}}".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("DELETE").unwrap(), url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request DELETE \
  --url {{baseUrl}}/api/v1/organizations/:organizationId/addresses/billing \
  --header 'authorization: {{apiKey}}'
http DELETE {{baseUrl}}/api/v1/organizations/:organizationId/addresses/billing \
  authorization:'{{apiKey}}'
wget --quiet \
  --method DELETE \
  --header 'authorization: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/api/v1/organizations/:organizationId/addresses/billing
import Foundation

let headers = ["authorization": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/api/v1/organizations/:organizationId/addresses/billing")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "DELETE"
request.allHTTPHeaderFields = headers

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 Remove partner
{{baseUrl}}/api/v1/organizations/:organizationId/partner
HEADERS

Authorization
{{apiKey}}
QUERY PARAMS

organizationId
BODY json

{
  "organizationId": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/api/v1/organizations/:organizationId/partner");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "authorization: {{apiKey}}");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"organizationId\": \"org.acme\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/api/v1/organizations/:organizationId/partner" {:headers {:authorization "{{apiKey}}"}
                                                                                           :content-type :json
                                                                                           :form-params {:organizationId "org.acme"}})
require "http/client"

url = "{{baseUrl}}/api/v1/organizations/:organizationId/partner"
headers = HTTP::Headers{
  "authorization" => "{{apiKey}}"
  "content-type" => "application/json"
}
reqBody = "{\n  \"organizationId\": \"org.acme\"\n}"

response = HTTP::Client.delete url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Delete,
    RequestUri = new Uri("{{baseUrl}}/api/v1/organizations/:organizationId/partner"),
    Headers =
    {
        { "authorization", "{{apiKey}}" },
    },
    Content = new StringContent("{\n  \"organizationId\": \"org.acme\"\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}}/api/v1/organizations/:organizationId/partner");
var request = new RestRequest("", Method.Delete);
request.AddHeader("authorization", "{{apiKey}}");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"organizationId\": \"org.acme\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/api/v1/organizations/:organizationId/partner"

	payload := strings.NewReader("{\n  \"organizationId\": \"org.acme\"\n}")

	req, _ := http.NewRequest("DELETE", url, payload)

	req.Header.Add("authorization", "{{apiKey}}")
	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))

}
DELETE /baseUrl/api/v1/organizations/:organizationId/partner HTTP/1.1
Authorization: {{apiKey}}
Content-Type: application/json
Host: example.com
Content-Length: 34

{
  "organizationId": "org.acme"
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/api/v1/organizations/:organizationId/partner")
  .setHeader("authorization", "{{apiKey}}")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"organizationId\": \"org.acme\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/api/v1/organizations/:organizationId/partner"))
    .header("authorization", "{{apiKey}}")
    .header("content-type", "application/json")
    .method("DELETE", HttpRequest.BodyPublishers.ofString("{\n  \"organizationId\": \"org.acme\"\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  \"organizationId\": \"org.acme\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/api/v1/organizations/:organizationId/partner")
  .delete(body)
  .addHeader("authorization", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/api/v1/organizations/:organizationId/partner")
  .header("authorization", "{{apiKey}}")
  .header("content-type", "application/json")
  .body("{\n  \"organizationId\": \"org.acme\"\n}")
  .asString();
const data = JSON.stringify({
  organizationId: 'org.acme'
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('DELETE', '{{baseUrl}}/api/v1/organizations/:organizationId/partner');
xhr.setRequestHeader('authorization', '{{apiKey}}');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/api/v1/organizations/:organizationId/partner',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  data: {organizationId: 'org.acme'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/api/v1/organizations/:organizationId/partner';
const options = {
  method: 'DELETE',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"organizationId":"org.acme"}'
};

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}}/api/v1/organizations/:organizationId/partner',
  method: 'DELETE',
  headers: {
    authorization: '{{apiKey}}',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "organizationId": "org.acme"\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"organizationId\": \"org.acme\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/api/v1/organizations/:organizationId/partner")
  .delete(body)
  .addHeader("authorization", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/api/v1/organizations/:organizationId/partner',
  headers: {
    authorization: '{{apiKey}}',
    '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({organizationId: 'org.acme'}));
req.end();
const request = require('request');

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/api/v1/organizations/:organizationId/partner',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  body: {organizationId: 'org.acme'},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('DELETE', '{{baseUrl}}/api/v1/organizations/:organizationId/partner');

req.headers({
  authorization: '{{apiKey}}',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  organizationId: 'org.acme'
});

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}}/api/v1/organizations/:organizationId/partner',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  data: {organizationId: 'org.acme'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/api/v1/organizations/:organizationId/partner';
const options = {
  method: 'DELETE',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"organizationId":"org.acme"}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"authorization": @"{{apiKey}}",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"organizationId": @"org.acme" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/api/v1/organizations/:organizationId/partner"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"DELETE"];
[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}}/api/v1/organizations/:organizationId/partner" in
let headers = Header.add_list (Header.init ()) [
  ("authorization", "{{apiKey}}");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"organizationId\": \"org.acme\"\n}" in

Client.call ~headers ~body `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/api/v1/organizations/:organizationId/partner",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
  CURLOPT_POSTFIELDS => json_encode([
    'organizationId' => 'org.acme'
  ]),
  CURLOPT_HTTPHEADER => [
    "authorization: {{apiKey}}",
    "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('DELETE', '{{baseUrl}}/api/v1/organizations/:organizationId/partner', [
  'body' => '{
  "organizationId": "org.acme"
}',
  'headers' => [
    'authorization' => '{{apiKey}}',
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/api/v1/organizations/:organizationId/partner');
$request->setMethod(HTTP_METH_DELETE);

$request->setHeaders([
  'authorization' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'organizationId' => 'org.acme'
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'organizationId' => 'org.acme'
]));
$request->setRequestUrl('{{baseUrl}}/api/v1/organizations/:organizationId/partner');
$request->setRequestMethod('DELETE');
$request->setBody($body);

$request->setHeaders([
  'authorization' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/api/v1/organizations/:organizationId/partner' -Method DELETE -Headers $headers -ContentType 'application/json' -Body '{
  "organizationId": "org.acme"
}'
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/api/v1/organizations/:organizationId/partner' -Method DELETE -Headers $headers -ContentType 'application/json' -Body '{
  "organizationId": "org.acme"
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"organizationId\": \"org.acme\"\n}"

headers = {
    'authorization': "{{apiKey}}",
    'content-type': "application/json"
}

conn.request("DELETE", "/baseUrl/api/v1/organizations/:organizationId/partner", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/api/v1/organizations/:organizationId/partner"

payload = { "organizationId": "org.acme" }
headers = {
    "authorization": "{{apiKey}}",
    "content-type": "application/json"
}

response = requests.delete(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/api/v1/organizations/:organizationId/partner"

payload <- "{\n  \"organizationId\": \"org.acme\"\n}"

encode <- "json"

response <- VERB("DELETE", url, body = payload, add_headers('authorization' = '{{apiKey}}'), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/api/v1/organizations/:organizationId/partner")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)
request["authorization"] = '{{apiKey}}'
request["content-type"] = 'application/json'
request.body = "{\n  \"organizationId\": \"org.acme\"\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.delete('/baseUrl/api/v1/organizations/:organizationId/partner') do |req|
  req.headers['authorization'] = '{{apiKey}}'
  req.body = "{\n  \"organizationId\": \"org.acme\"\n}"
end

puts response.status
puts response.body
use std::str::FromStr;
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/api/v1/organizations/:organizationId/partner";

    let payload = json!({"organizationId": "org.acme"});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("authorization", "{{apiKey}}".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("DELETE").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request DELETE \
  --url {{baseUrl}}/api/v1/organizations/:organizationId/partner \
  --header 'authorization: {{apiKey}}' \
  --header 'content-type: application/json' \
  --data '{
  "organizationId": "org.acme"
}'
echo '{
  "organizationId": "org.acme"
}' |  \
  http DELETE {{baseUrl}}/api/v1/organizations/:organizationId/partner \
  authorization:'{{apiKey}}' \
  content-type:application/json
wget --quiet \
  --method DELETE \
  --header 'authorization: {{apiKey}}' \
  --header 'content-type: application/json' \
  --body-data '{\n  "organizationId": "org.acme"\n}' \
  --output-document \
  - {{baseUrl}}/api/v1/organizations/:organizationId/partner
import Foundation

let headers = [
  "authorization": "{{apiKey}}",
  "content-type": "application/json"
]
let parameters = ["organizationId": "org.acme"] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/api/v1/organizations/:organizationId/partner")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "DELETE"
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()
GET Retrieve address
{{baseUrl}}/api/v1/organizations/:organizationId/addresses/default
HEADERS

Authorization
{{apiKey}}
QUERY PARAMS

organizationId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/api/v1/organizations/:organizationId/addresses/default");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "authorization: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/api/v1/organizations/:organizationId/addresses/default" {:headers {:authorization "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/api/v1/organizations/:organizationId/addresses/default"
headers = HTTP::Headers{
  "authorization" => "{{apiKey}}"
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/api/v1/organizations/:organizationId/addresses/default"),
    Headers =
    {
        { "authorization", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/api/v1/organizations/:organizationId/addresses/default");
var request = new RestRequest("", Method.Get);
request.AddHeader("authorization", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/api/v1/organizations/:organizationId/addresses/default"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("authorization", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/api/v1/organizations/:organizationId/addresses/default HTTP/1.1
Authorization: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/api/v1/organizations/:organizationId/addresses/default")
  .setHeader("authorization", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/api/v1/organizations/:organizationId/addresses/default"))
    .header("authorization", "{{apiKey}}")
    .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}}/api/v1/organizations/:organizationId/addresses/default")
  .get()
  .addHeader("authorization", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/api/v1/organizations/:organizationId/addresses/default")
  .header("authorization", "{{apiKey}}")
  .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}}/api/v1/organizations/:organizationId/addresses/default');
xhr.setRequestHeader('authorization', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/api/v1/organizations/:organizationId/addresses/default',
  headers: {authorization: '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/api/v1/organizations/:organizationId/addresses/default';
const options = {method: 'GET', headers: {authorization: '{{apiKey}}'}};

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}}/api/v1/organizations/:organizationId/addresses/default',
  method: 'GET',
  headers: {
    authorization: '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/api/v1/organizations/:organizationId/addresses/default")
  .get()
  .addHeader("authorization", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/api/v1/organizations/:organizationId/addresses/default',
  headers: {
    authorization: '{{apiKey}}'
  }
};

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}}/api/v1/organizations/:organizationId/addresses/default',
  headers: {authorization: '{{apiKey}}'}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/api/v1/organizations/:organizationId/addresses/default');

req.headers({
  authorization: '{{apiKey}}'
});

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}}/api/v1/organizations/:organizationId/addresses/default',
  headers: {authorization: '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/api/v1/organizations/:organizationId/addresses/default';
const options = {method: 'GET', headers: {authorization: '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"authorization": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/api/v1/organizations/:organizationId/addresses/default"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

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}}/api/v1/organizations/:organizationId/addresses/default" in
let headers = Header.add (Header.init ()) "authorization" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/api/v1/organizations/:organizationId/addresses/default",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "authorization: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/api/v1/organizations/:organizationId/addresses/default', [
  'headers' => [
    'authorization' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/api/v1/organizations/:organizationId/addresses/default');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'authorization' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/api/v1/organizations/:organizationId/addresses/default');
$request->setRequestMethod('GET');
$request->setHeaders([
  'authorization' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/api/v1/organizations/:organizationId/addresses/default' -Method GET -Headers $headers
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/api/v1/organizations/:organizationId/addresses/default' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'authorization': "{{apiKey}}" }

conn.request("GET", "/baseUrl/api/v1/organizations/:organizationId/addresses/default", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/api/v1/organizations/:organizationId/addresses/default"

headers = {"authorization": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/api/v1/organizations/:organizationId/addresses/default"

response <- VERB("GET", url, add_headers('authorization' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/api/v1/organizations/:organizationId/addresses/default")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["authorization"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/api/v1/organizations/:organizationId/addresses/default') do |req|
  req.headers['authorization'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/api/v1/organizations/:organizationId/addresses/default";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("authorization", "{{apiKey}}".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/api/v1/organizations/:organizationId/addresses/default \
  --header 'authorization: {{apiKey}}'
http GET {{baseUrl}}/api/v1/organizations/:organizationId/addresses/default \
  authorization:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'authorization: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/api/v1/organizations/:organizationId/addresses/default
import Foundation

let headers = ["authorization": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/api/v1/organizations/:organizationId/addresses/default")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

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()
RESPONSE HEADERS

Content-Type
application/json
RESPONSE BODY json

{
  "city": "MyCity",
  "companyName": "ACME Inc.",
  "countryCode": "DE",
  "countryName": "Germany",
  "firstname": "Max",
  "lastname": "Muster",
  "postCode": 12345,
  "street": "Examplestreet 1",
  "telephone": "+49 8088 12345"
}
RESPONSE HEADERS

Content-Type
application/xml
RESPONSE BODY xml

{
  "city": "MyCity",
  "companyName": "ACME Inc.",
  "countryCode": "DE",
  "countryName": "Germany",
  "firstname": "Max",
  "lastname": "Muster",
  "postCode": 12345,
  "street": "Examplestreet 1",
  "telephone": "+49 8088 12345"
}
GET Retrieve billing address
{{baseUrl}}/api/v1/organizations/:organizationId/addresses/billing
HEADERS

Authorization
{{apiKey}}
QUERY PARAMS

organizationId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/api/v1/organizations/:organizationId/addresses/billing");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "authorization: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/api/v1/organizations/:organizationId/addresses/billing" {:headers {:authorization "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/api/v1/organizations/:organizationId/addresses/billing"
headers = HTTP::Headers{
  "authorization" => "{{apiKey}}"
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/api/v1/organizations/:organizationId/addresses/billing"),
    Headers =
    {
        { "authorization", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/api/v1/organizations/:organizationId/addresses/billing");
var request = new RestRequest("", Method.Get);
request.AddHeader("authorization", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/api/v1/organizations/:organizationId/addresses/billing"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("authorization", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/api/v1/organizations/:organizationId/addresses/billing HTTP/1.1
Authorization: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/api/v1/organizations/:organizationId/addresses/billing")
  .setHeader("authorization", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/api/v1/organizations/:organizationId/addresses/billing"))
    .header("authorization", "{{apiKey}}")
    .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}}/api/v1/organizations/:organizationId/addresses/billing")
  .get()
  .addHeader("authorization", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/api/v1/organizations/:organizationId/addresses/billing")
  .header("authorization", "{{apiKey}}")
  .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}}/api/v1/organizations/:organizationId/addresses/billing');
xhr.setRequestHeader('authorization', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/api/v1/organizations/:organizationId/addresses/billing',
  headers: {authorization: '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/api/v1/organizations/:organizationId/addresses/billing';
const options = {method: 'GET', headers: {authorization: '{{apiKey}}'}};

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}}/api/v1/organizations/:organizationId/addresses/billing',
  method: 'GET',
  headers: {
    authorization: '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/api/v1/organizations/:organizationId/addresses/billing")
  .get()
  .addHeader("authorization", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/api/v1/organizations/:organizationId/addresses/billing',
  headers: {
    authorization: '{{apiKey}}'
  }
};

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}}/api/v1/organizations/:organizationId/addresses/billing',
  headers: {authorization: '{{apiKey}}'}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/api/v1/organizations/:organizationId/addresses/billing');

req.headers({
  authorization: '{{apiKey}}'
});

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}}/api/v1/organizations/:organizationId/addresses/billing',
  headers: {authorization: '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/api/v1/organizations/:organizationId/addresses/billing';
const options = {method: 'GET', headers: {authorization: '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"authorization": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/api/v1/organizations/:organizationId/addresses/billing"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

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}}/api/v1/organizations/:organizationId/addresses/billing" in
let headers = Header.add (Header.init ()) "authorization" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/api/v1/organizations/:organizationId/addresses/billing",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "authorization: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/api/v1/organizations/:organizationId/addresses/billing', [
  'headers' => [
    'authorization' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/api/v1/organizations/:organizationId/addresses/billing');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'authorization' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/api/v1/organizations/:organizationId/addresses/billing');
$request->setRequestMethod('GET');
$request->setHeaders([
  'authorization' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/api/v1/organizations/:organizationId/addresses/billing' -Method GET -Headers $headers
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/api/v1/organizations/:organizationId/addresses/billing' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'authorization': "{{apiKey}}" }

conn.request("GET", "/baseUrl/api/v1/organizations/:organizationId/addresses/billing", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/api/v1/organizations/:organizationId/addresses/billing"

headers = {"authorization": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/api/v1/organizations/:organizationId/addresses/billing"

response <- VERB("GET", url, add_headers('authorization' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/api/v1/organizations/:organizationId/addresses/billing")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["authorization"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/api/v1/organizations/:organizationId/addresses/billing') do |req|
  req.headers['authorization'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/api/v1/organizations/:organizationId/addresses/billing";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("authorization", "{{apiKey}}".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/api/v1/organizations/:organizationId/addresses/billing \
  --header 'authorization: {{apiKey}}'
http GET {{baseUrl}}/api/v1/organizations/:organizationId/addresses/billing \
  authorization:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'authorization: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/api/v1/organizations/:organizationId/addresses/billing
import Foundation

let headers = ["authorization": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/api/v1/organizations/:organizationId/addresses/billing")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

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()
RESPONSE HEADERS

Content-Type
application/json
RESPONSE BODY json

{
  "city": "MyCity",
  "companyName": "ACME Inc.",
  "countryCode": "DE",
  "countryName": "Germany",
  "firstname": "Max",
  "lastname": "Muster",
  "postCode": 12345,
  "street": "Examplestreet 1",
  "telephone": "+49 8088 12345"
}
RESPONSE HEADERS

Content-Type
application/xml
RESPONSE BODY xml

{
  "city": "MyCity",
  "companyName": "ACME Inc.",
  "countryCode": "DE",
  "countryName": "Germany",
  "firstname": "Max",
  "lastname": "Muster",
  "postCode": 12345,
  "street": "Examplestreet 1",
  "telephone": "+49 8088 12345"
}
PUT Store address
{{baseUrl}}/api/v1/organizations/:organizationId/addresses/default
HEADERS

Authorization
{{apiKey}}
QUERY PARAMS

organizationId
BODY json

{
  "city": "",
  "companyName": "",
  "countryCode": "",
  "countryName": "",
  "firstname": "",
  "lastname": "",
  "postCode": "",
  "street": "",
  "telephone": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/api/v1/organizations/:organizationId/addresses/default");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "authorization: {{apiKey}}");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"city\": \"\",\n  \"companyName\": \"\",\n  \"countryCode\": \"\",\n  \"countryName\": \"\",\n  \"firstname\": \"\",\n  \"lastname\": \"\",\n  \"postCode\": \"\",\n  \"street\": \"\",\n  \"telephone\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/api/v1/organizations/:organizationId/addresses/default" {:headers {:authorization "{{apiKey}}"}
                                                                                                  :content-type :json
                                                                                                  :form-params {:city ""
                                                                                                                :companyName ""
                                                                                                                :countryCode ""
                                                                                                                :countryName ""
                                                                                                                :firstname ""
                                                                                                                :lastname ""
                                                                                                                :postCode ""
                                                                                                                :street ""
                                                                                                                :telephone ""}})
require "http/client"

url = "{{baseUrl}}/api/v1/organizations/:organizationId/addresses/default"
headers = HTTP::Headers{
  "authorization" => "{{apiKey}}"
  "content-type" => "application/json"
}
reqBody = "{\n  \"city\": \"\",\n  \"companyName\": \"\",\n  \"countryCode\": \"\",\n  \"countryName\": \"\",\n  \"firstname\": \"\",\n  \"lastname\": \"\",\n  \"postCode\": \"\",\n  \"street\": \"\",\n  \"telephone\": \"\"\n}"

response = HTTP::Client.put url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Put,
    RequestUri = new Uri("{{baseUrl}}/api/v1/organizations/:organizationId/addresses/default"),
    Headers =
    {
        { "authorization", "{{apiKey}}" },
    },
    Content = new StringContent("{\n  \"city\": \"\",\n  \"companyName\": \"\",\n  \"countryCode\": \"\",\n  \"countryName\": \"\",\n  \"firstname\": \"\",\n  \"lastname\": \"\",\n  \"postCode\": \"\",\n  \"street\": \"\",\n  \"telephone\": \"\"\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}}/api/v1/organizations/:organizationId/addresses/default");
var request = new RestRequest("", Method.Put);
request.AddHeader("authorization", "{{apiKey}}");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"city\": \"\",\n  \"companyName\": \"\",\n  \"countryCode\": \"\",\n  \"countryName\": \"\",\n  \"firstname\": \"\",\n  \"lastname\": \"\",\n  \"postCode\": \"\",\n  \"street\": \"\",\n  \"telephone\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/api/v1/organizations/:organizationId/addresses/default"

	payload := strings.NewReader("{\n  \"city\": \"\",\n  \"companyName\": \"\",\n  \"countryCode\": \"\",\n  \"countryName\": \"\",\n  \"firstname\": \"\",\n  \"lastname\": \"\",\n  \"postCode\": \"\",\n  \"street\": \"\",\n  \"telephone\": \"\"\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("authorization", "{{apiKey}}")
	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))

}
PUT /baseUrl/api/v1/organizations/:organizationId/addresses/default HTTP/1.1
Authorization: {{apiKey}}
Content-Type: application/json
Host: example.com
Content-Length: 169

{
  "city": "",
  "companyName": "",
  "countryCode": "",
  "countryName": "",
  "firstname": "",
  "lastname": "",
  "postCode": "",
  "street": "",
  "telephone": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/api/v1/organizations/:organizationId/addresses/default")
  .setHeader("authorization", "{{apiKey}}")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"city\": \"\",\n  \"companyName\": \"\",\n  \"countryCode\": \"\",\n  \"countryName\": \"\",\n  \"firstname\": \"\",\n  \"lastname\": \"\",\n  \"postCode\": \"\",\n  \"street\": \"\",\n  \"telephone\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/api/v1/organizations/:organizationId/addresses/default"))
    .header("authorization", "{{apiKey}}")
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"city\": \"\",\n  \"companyName\": \"\",\n  \"countryCode\": \"\",\n  \"countryName\": \"\",\n  \"firstname\": \"\",\n  \"lastname\": \"\",\n  \"postCode\": \"\",\n  \"street\": \"\",\n  \"telephone\": \"\"\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  \"city\": \"\",\n  \"companyName\": \"\",\n  \"countryCode\": \"\",\n  \"countryName\": \"\",\n  \"firstname\": \"\",\n  \"lastname\": \"\",\n  \"postCode\": \"\",\n  \"street\": \"\",\n  \"telephone\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/api/v1/organizations/:organizationId/addresses/default")
  .put(body)
  .addHeader("authorization", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/api/v1/organizations/:organizationId/addresses/default")
  .header("authorization", "{{apiKey}}")
  .header("content-type", "application/json")
  .body("{\n  \"city\": \"\",\n  \"companyName\": \"\",\n  \"countryCode\": \"\",\n  \"countryName\": \"\",\n  \"firstname\": \"\",\n  \"lastname\": \"\",\n  \"postCode\": \"\",\n  \"street\": \"\",\n  \"telephone\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  city: '',
  companyName: '',
  countryCode: '',
  countryName: '',
  firstname: '',
  lastname: '',
  postCode: '',
  street: '',
  telephone: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/api/v1/organizations/:organizationId/addresses/default');
xhr.setRequestHeader('authorization', '{{apiKey}}');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/api/v1/organizations/:organizationId/addresses/default',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  data: {
    city: '',
    companyName: '',
    countryCode: '',
    countryName: '',
    firstname: '',
    lastname: '',
    postCode: '',
    street: '',
    telephone: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/api/v1/organizations/:organizationId/addresses/default';
const options = {
  method: 'PUT',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"city":"","companyName":"","countryCode":"","countryName":"","firstname":"","lastname":"","postCode":"","street":"","telephone":""}'
};

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}}/api/v1/organizations/:organizationId/addresses/default',
  method: 'PUT',
  headers: {
    authorization: '{{apiKey}}',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "city": "",\n  "companyName": "",\n  "countryCode": "",\n  "countryName": "",\n  "firstname": "",\n  "lastname": "",\n  "postCode": "",\n  "street": "",\n  "telephone": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"city\": \"\",\n  \"companyName\": \"\",\n  \"countryCode\": \"\",\n  \"countryName\": \"\",\n  \"firstname\": \"\",\n  \"lastname\": \"\",\n  \"postCode\": \"\",\n  \"street\": \"\",\n  \"telephone\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/api/v1/organizations/:organizationId/addresses/default")
  .put(body)
  .addHeader("authorization", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/api/v1/organizations/:organizationId/addresses/default',
  headers: {
    authorization: '{{apiKey}}',
    '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({
  city: '',
  companyName: '',
  countryCode: '',
  countryName: '',
  firstname: '',
  lastname: '',
  postCode: '',
  street: '',
  telephone: ''
}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/api/v1/organizations/:organizationId/addresses/default',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  body: {
    city: '',
    companyName: '',
    countryCode: '',
    countryName: '',
    firstname: '',
    lastname: '',
    postCode: '',
    street: '',
    telephone: ''
  },
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('PUT', '{{baseUrl}}/api/v1/organizations/:organizationId/addresses/default');

req.headers({
  authorization: '{{apiKey}}',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  city: '',
  companyName: '',
  countryCode: '',
  countryName: '',
  firstname: '',
  lastname: '',
  postCode: '',
  street: '',
  telephone: ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/api/v1/organizations/:organizationId/addresses/default',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  data: {
    city: '',
    companyName: '',
    countryCode: '',
    countryName: '',
    firstname: '',
    lastname: '',
    postCode: '',
    street: '',
    telephone: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/api/v1/organizations/:organizationId/addresses/default';
const options = {
  method: 'PUT',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"city":"","companyName":"","countryCode":"","countryName":"","firstname":"","lastname":"","postCode":"","street":"","telephone":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"authorization": @"{{apiKey}}",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"city": @"",
                              @"companyName": @"",
                              @"countryCode": @"",
                              @"countryName": @"",
                              @"firstname": @"",
                              @"lastname": @"",
                              @"postCode": @"",
                              @"street": @"",
                              @"telephone": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/api/v1/organizations/:organizationId/addresses/default"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"PUT"];
[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}}/api/v1/organizations/:organizationId/addresses/default" in
let headers = Header.add_list (Header.init ()) [
  ("authorization", "{{apiKey}}");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"city\": \"\",\n  \"companyName\": \"\",\n  \"countryCode\": \"\",\n  \"countryName\": \"\",\n  \"firstname\": \"\",\n  \"lastname\": \"\",\n  \"postCode\": \"\",\n  \"street\": \"\",\n  \"telephone\": \"\"\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/api/v1/organizations/:organizationId/addresses/default",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
  CURLOPT_POSTFIELDS => json_encode([
    'city' => '',
    'companyName' => '',
    'countryCode' => '',
    'countryName' => '',
    'firstname' => '',
    'lastname' => '',
    'postCode' => '',
    'street' => '',
    'telephone' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "authorization: {{apiKey}}",
    "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('PUT', '{{baseUrl}}/api/v1/organizations/:organizationId/addresses/default', [
  'body' => '{
  "city": "",
  "companyName": "",
  "countryCode": "",
  "countryName": "",
  "firstname": "",
  "lastname": "",
  "postCode": "",
  "street": "",
  "telephone": ""
}',
  'headers' => [
    'authorization' => '{{apiKey}}',
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/api/v1/organizations/:organizationId/addresses/default');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'authorization' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'city' => '',
  'companyName' => '',
  'countryCode' => '',
  'countryName' => '',
  'firstname' => '',
  'lastname' => '',
  'postCode' => '',
  'street' => '',
  'telephone' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'city' => '',
  'companyName' => '',
  'countryCode' => '',
  'countryName' => '',
  'firstname' => '',
  'lastname' => '',
  'postCode' => '',
  'street' => '',
  'telephone' => ''
]));
$request->setRequestUrl('{{baseUrl}}/api/v1/organizations/:organizationId/addresses/default');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'authorization' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/api/v1/organizations/:organizationId/addresses/default' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "city": "",
  "companyName": "",
  "countryCode": "",
  "countryName": "",
  "firstname": "",
  "lastname": "",
  "postCode": "",
  "street": "",
  "telephone": ""
}'
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/api/v1/organizations/:organizationId/addresses/default' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "city": "",
  "companyName": "",
  "countryCode": "",
  "countryName": "",
  "firstname": "",
  "lastname": "",
  "postCode": "",
  "street": "",
  "telephone": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"city\": \"\",\n  \"companyName\": \"\",\n  \"countryCode\": \"\",\n  \"countryName\": \"\",\n  \"firstname\": \"\",\n  \"lastname\": \"\",\n  \"postCode\": \"\",\n  \"street\": \"\",\n  \"telephone\": \"\"\n}"

headers = {
    'authorization': "{{apiKey}}",
    'content-type': "application/json"
}

conn.request("PUT", "/baseUrl/api/v1/organizations/:organizationId/addresses/default", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/api/v1/organizations/:organizationId/addresses/default"

payload = {
    "city": "",
    "companyName": "",
    "countryCode": "",
    "countryName": "",
    "firstname": "",
    "lastname": "",
    "postCode": "",
    "street": "",
    "telephone": ""
}
headers = {
    "authorization": "{{apiKey}}",
    "content-type": "application/json"
}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/api/v1/organizations/:organizationId/addresses/default"

payload <- "{\n  \"city\": \"\",\n  \"companyName\": \"\",\n  \"countryCode\": \"\",\n  \"countryName\": \"\",\n  \"firstname\": \"\",\n  \"lastname\": \"\",\n  \"postCode\": \"\",\n  \"street\": \"\",\n  \"telephone\": \"\"\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, add_headers('authorization' = '{{apiKey}}'), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/api/v1/organizations/:organizationId/addresses/default")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["authorization"] = '{{apiKey}}'
request["content-type"] = 'application/json'
request.body = "{\n  \"city\": \"\",\n  \"companyName\": \"\",\n  \"countryCode\": \"\",\n  \"countryName\": \"\",\n  \"firstname\": \"\",\n  \"lastname\": \"\",\n  \"postCode\": \"\",\n  \"street\": \"\",\n  \"telephone\": \"\"\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.put('/baseUrl/api/v1/organizations/:organizationId/addresses/default') do |req|
  req.headers['authorization'] = '{{apiKey}}'
  req.body = "{\n  \"city\": \"\",\n  \"companyName\": \"\",\n  \"countryCode\": \"\",\n  \"countryName\": \"\",\n  \"firstname\": \"\",\n  \"lastname\": \"\",\n  \"postCode\": \"\",\n  \"street\": \"\",\n  \"telephone\": \"\"\n}"
end

puts response.status
puts response.body
use std::str::FromStr;
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/api/v1/organizations/:organizationId/addresses/default";

    let payload = json!({
        "city": "",
        "companyName": "",
        "countryCode": "",
        "countryName": "",
        "firstname": "",
        "lastname": "",
        "postCode": "",
        "street": "",
        "telephone": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("authorization", "{{apiKey}}".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/api/v1/organizations/:organizationId/addresses/default \
  --header 'authorization: {{apiKey}}' \
  --header 'content-type: application/json' \
  --data '{
  "city": "",
  "companyName": "",
  "countryCode": "",
  "countryName": "",
  "firstname": "",
  "lastname": "",
  "postCode": "",
  "street": "",
  "telephone": ""
}'
echo '{
  "city": "",
  "companyName": "",
  "countryCode": "",
  "countryName": "",
  "firstname": "",
  "lastname": "",
  "postCode": "",
  "street": "",
  "telephone": ""
}' |  \
  http PUT {{baseUrl}}/api/v1/organizations/:organizationId/addresses/default \
  authorization:'{{apiKey}}' \
  content-type:application/json
wget --quiet \
  --method PUT \
  --header 'authorization: {{apiKey}}' \
  --header 'content-type: application/json' \
  --body-data '{\n  "city": "",\n  "companyName": "",\n  "countryCode": "",\n  "countryName": "",\n  "firstname": "",\n  "lastname": "",\n  "postCode": "",\n  "street": "",\n  "telephone": ""\n}' \
  --output-document \
  - {{baseUrl}}/api/v1/organizations/:organizationId/addresses/default
import Foundation

let headers = [
  "authorization": "{{apiKey}}",
  "content-type": "application/json"
]
let parameters = [
  "city": "",
  "companyName": "",
  "countryCode": "",
  "countryName": "",
  "firstname": "",
  "lastname": "",
  "postCode": "",
  "street": "",
  "telephone": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/api/v1/organizations/:organizationId/addresses/default")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "PUT"
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()
RESPONSE HEADERS

Content-Type
application/json
RESPONSE BODY json

{
  "city": "MyCity",
  "companyName": "ACME Inc.",
  "countryCode": "DE",
  "countryName": "Germany",
  "firstname": "Max",
  "lastname": "Muster",
  "postCode": 12345,
  "street": "Examplestreet 1",
  "telephone": "+49 8088 12345"
}
RESPONSE HEADERS

Content-Type
application/xml
RESPONSE BODY xml

{
  "city": "MyCity",
  "companyName": "ACME Inc.",
  "countryCode": "DE",
  "countryName": "Germany",
  "firstname": "Max",
  "lastname": "Muster",
  "postCode": 12345,
  "street": "Examplestreet 1",
  "telephone": "+49 8088 12345"
}
PUT Store billing address
{{baseUrl}}/api/v1/organizations/:organizationId/addresses/billing
HEADERS

Authorization
{{apiKey}}
QUERY PARAMS

organizationId
BODY json

{
  "city": "",
  "companyName": "",
  "countryCode": "",
  "countryName": "",
  "firstname": "",
  "lastname": "",
  "postCode": "",
  "street": "",
  "telephone": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/api/v1/organizations/:organizationId/addresses/billing");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "authorization: {{apiKey}}");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"city\": \"\",\n  \"companyName\": \"\",\n  \"countryCode\": \"\",\n  \"countryName\": \"\",\n  \"firstname\": \"\",\n  \"lastname\": \"\",\n  \"postCode\": \"\",\n  \"street\": \"\",\n  \"telephone\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/api/v1/organizations/:organizationId/addresses/billing" {:headers {:authorization "{{apiKey}}"}
                                                                                                  :content-type :json
                                                                                                  :form-params {:city ""
                                                                                                                :companyName ""
                                                                                                                :countryCode ""
                                                                                                                :countryName ""
                                                                                                                :firstname ""
                                                                                                                :lastname ""
                                                                                                                :postCode ""
                                                                                                                :street ""
                                                                                                                :telephone ""}})
require "http/client"

url = "{{baseUrl}}/api/v1/organizations/:organizationId/addresses/billing"
headers = HTTP::Headers{
  "authorization" => "{{apiKey}}"
  "content-type" => "application/json"
}
reqBody = "{\n  \"city\": \"\",\n  \"companyName\": \"\",\n  \"countryCode\": \"\",\n  \"countryName\": \"\",\n  \"firstname\": \"\",\n  \"lastname\": \"\",\n  \"postCode\": \"\",\n  \"street\": \"\",\n  \"telephone\": \"\"\n}"

response = HTTP::Client.put url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Put,
    RequestUri = new Uri("{{baseUrl}}/api/v1/organizations/:organizationId/addresses/billing"),
    Headers =
    {
        { "authorization", "{{apiKey}}" },
    },
    Content = new StringContent("{\n  \"city\": \"\",\n  \"companyName\": \"\",\n  \"countryCode\": \"\",\n  \"countryName\": \"\",\n  \"firstname\": \"\",\n  \"lastname\": \"\",\n  \"postCode\": \"\",\n  \"street\": \"\",\n  \"telephone\": \"\"\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}}/api/v1/organizations/:organizationId/addresses/billing");
var request = new RestRequest("", Method.Put);
request.AddHeader("authorization", "{{apiKey}}");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"city\": \"\",\n  \"companyName\": \"\",\n  \"countryCode\": \"\",\n  \"countryName\": \"\",\n  \"firstname\": \"\",\n  \"lastname\": \"\",\n  \"postCode\": \"\",\n  \"street\": \"\",\n  \"telephone\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/api/v1/organizations/:organizationId/addresses/billing"

	payload := strings.NewReader("{\n  \"city\": \"\",\n  \"companyName\": \"\",\n  \"countryCode\": \"\",\n  \"countryName\": \"\",\n  \"firstname\": \"\",\n  \"lastname\": \"\",\n  \"postCode\": \"\",\n  \"street\": \"\",\n  \"telephone\": \"\"\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("authorization", "{{apiKey}}")
	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))

}
PUT /baseUrl/api/v1/organizations/:organizationId/addresses/billing HTTP/1.1
Authorization: {{apiKey}}
Content-Type: application/json
Host: example.com
Content-Length: 169

{
  "city": "",
  "companyName": "",
  "countryCode": "",
  "countryName": "",
  "firstname": "",
  "lastname": "",
  "postCode": "",
  "street": "",
  "telephone": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/api/v1/organizations/:organizationId/addresses/billing")
  .setHeader("authorization", "{{apiKey}}")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"city\": \"\",\n  \"companyName\": \"\",\n  \"countryCode\": \"\",\n  \"countryName\": \"\",\n  \"firstname\": \"\",\n  \"lastname\": \"\",\n  \"postCode\": \"\",\n  \"street\": \"\",\n  \"telephone\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/api/v1/organizations/:organizationId/addresses/billing"))
    .header("authorization", "{{apiKey}}")
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"city\": \"\",\n  \"companyName\": \"\",\n  \"countryCode\": \"\",\n  \"countryName\": \"\",\n  \"firstname\": \"\",\n  \"lastname\": \"\",\n  \"postCode\": \"\",\n  \"street\": \"\",\n  \"telephone\": \"\"\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  \"city\": \"\",\n  \"companyName\": \"\",\n  \"countryCode\": \"\",\n  \"countryName\": \"\",\n  \"firstname\": \"\",\n  \"lastname\": \"\",\n  \"postCode\": \"\",\n  \"street\": \"\",\n  \"telephone\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/api/v1/organizations/:organizationId/addresses/billing")
  .put(body)
  .addHeader("authorization", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/api/v1/organizations/:organizationId/addresses/billing")
  .header("authorization", "{{apiKey}}")
  .header("content-type", "application/json")
  .body("{\n  \"city\": \"\",\n  \"companyName\": \"\",\n  \"countryCode\": \"\",\n  \"countryName\": \"\",\n  \"firstname\": \"\",\n  \"lastname\": \"\",\n  \"postCode\": \"\",\n  \"street\": \"\",\n  \"telephone\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  city: '',
  companyName: '',
  countryCode: '',
  countryName: '',
  firstname: '',
  lastname: '',
  postCode: '',
  street: '',
  telephone: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/api/v1/organizations/:organizationId/addresses/billing');
xhr.setRequestHeader('authorization', '{{apiKey}}');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/api/v1/organizations/:organizationId/addresses/billing',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  data: {
    city: '',
    companyName: '',
    countryCode: '',
    countryName: '',
    firstname: '',
    lastname: '',
    postCode: '',
    street: '',
    telephone: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/api/v1/organizations/:organizationId/addresses/billing';
const options = {
  method: 'PUT',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"city":"","companyName":"","countryCode":"","countryName":"","firstname":"","lastname":"","postCode":"","street":"","telephone":""}'
};

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}}/api/v1/organizations/:organizationId/addresses/billing',
  method: 'PUT',
  headers: {
    authorization: '{{apiKey}}',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "city": "",\n  "companyName": "",\n  "countryCode": "",\n  "countryName": "",\n  "firstname": "",\n  "lastname": "",\n  "postCode": "",\n  "street": "",\n  "telephone": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"city\": \"\",\n  \"companyName\": \"\",\n  \"countryCode\": \"\",\n  \"countryName\": \"\",\n  \"firstname\": \"\",\n  \"lastname\": \"\",\n  \"postCode\": \"\",\n  \"street\": \"\",\n  \"telephone\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/api/v1/organizations/:organizationId/addresses/billing")
  .put(body)
  .addHeader("authorization", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/api/v1/organizations/:organizationId/addresses/billing',
  headers: {
    authorization: '{{apiKey}}',
    '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({
  city: '',
  companyName: '',
  countryCode: '',
  countryName: '',
  firstname: '',
  lastname: '',
  postCode: '',
  street: '',
  telephone: ''
}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/api/v1/organizations/:organizationId/addresses/billing',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  body: {
    city: '',
    companyName: '',
    countryCode: '',
    countryName: '',
    firstname: '',
    lastname: '',
    postCode: '',
    street: '',
    telephone: ''
  },
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('PUT', '{{baseUrl}}/api/v1/organizations/:organizationId/addresses/billing');

req.headers({
  authorization: '{{apiKey}}',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  city: '',
  companyName: '',
  countryCode: '',
  countryName: '',
  firstname: '',
  lastname: '',
  postCode: '',
  street: '',
  telephone: ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/api/v1/organizations/:organizationId/addresses/billing',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  data: {
    city: '',
    companyName: '',
    countryCode: '',
    countryName: '',
    firstname: '',
    lastname: '',
    postCode: '',
    street: '',
    telephone: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/api/v1/organizations/:organizationId/addresses/billing';
const options = {
  method: 'PUT',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"city":"","companyName":"","countryCode":"","countryName":"","firstname":"","lastname":"","postCode":"","street":"","telephone":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"authorization": @"{{apiKey}}",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"city": @"",
                              @"companyName": @"",
                              @"countryCode": @"",
                              @"countryName": @"",
                              @"firstname": @"",
                              @"lastname": @"",
                              @"postCode": @"",
                              @"street": @"",
                              @"telephone": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/api/v1/organizations/:organizationId/addresses/billing"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"PUT"];
[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}}/api/v1/organizations/:organizationId/addresses/billing" in
let headers = Header.add_list (Header.init ()) [
  ("authorization", "{{apiKey}}");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"city\": \"\",\n  \"companyName\": \"\",\n  \"countryCode\": \"\",\n  \"countryName\": \"\",\n  \"firstname\": \"\",\n  \"lastname\": \"\",\n  \"postCode\": \"\",\n  \"street\": \"\",\n  \"telephone\": \"\"\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/api/v1/organizations/:organizationId/addresses/billing",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
  CURLOPT_POSTFIELDS => json_encode([
    'city' => '',
    'companyName' => '',
    'countryCode' => '',
    'countryName' => '',
    'firstname' => '',
    'lastname' => '',
    'postCode' => '',
    'street' => '',
    'telephone' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "authorization: {{apiKey}}",
    "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('PUT', '{{baseUrl}}/api/v1/organizations/:organizationId/addresses/billing', [
  'body' => '{
  "city": "",
  "companyName": "",
  "countryCode": "",
  "countryName": "",
  "firstname": "",
  "lastname": "",
  "postCode": "",
  "street": "",
  "telephone": ""
}',
  'headers' => [
    'authorization' => '{{apiKey}}',
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/api/v1/organizations/:organizationId/addresses/billing');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'authorization' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'city' => '',
  'companyName' => '',
  'countryCode' => '',
  'countryName' => '',
  'firstname' => '',
  'lastname' => '',
  'postCode' => '',
  'street' => '',
  'telephone' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'city' => '',
  'companyName' => '',
  'countryCode' => '',
  'countryName' => '',
  'firstname' => '',
  'lastname' => '',
  'postCode' => '',
  'street' => '',
  'telephone' => ''
]));
$request->setRequestUrl('{{baseUrl}}/api/v1/organizations/:organizationId/addresses/billing');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'authorization' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/api/v1/organizations/:organizationId/addresses/billing' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "city": "",
  "companyName": "",
  "countryCode": "",
  "countryName": "",
  "firstname": "",
  "lastname": "",
  "postCode": "",
  "street": "",
  "telephone": ""
}'
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/api/v1/organizations/:organizationId/addresses/billing' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "city": "",
  "companyName": "",
  "countryCode": "",
  "countryName": "",
  "firstname": "",
  "lastname": "",
  "postCode": "",
  "street": "",
  "telephone": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"city\": \"\",\n  \"companyName\": \"\",\n  \"countryCode\": \"\",\n  \"countryName\": \"\",\n  \"firstname\": \"\",\n  \"lastname\": \"\",\n  \"postCode\": \"\",\n  \"street\": \"\",\n  \"telephone\": \"\"\n}"

headers = {
    'authorization': "{{apiKey}}",
    'content-type': "application/json"
}

conn.request("PUT", "/baseUrl/api/v1/organizations/:organizationId/addresses/billing", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/api/v1/organizations/:organizationId/addresses/billing"

payload = {
    "city": "",
    "companyName": "",
    "countryCode": "",
    "countryName": "",
    "firstname": "",
    "lastname": "",
    "postCode": "",
    "street": "",
    "telephone": ""
}
headers = {
    "authorization": "{{apiKey}}",
    "content-type": "application/json"
}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/api/v1/organizations/:organizationId/addresses/billing"

payload <- "{\n  \"city\": \"\",\n  \"companyName\": \"\",\n  \"countryCode\": \"\",\n  \"countryName\": \"\",\n  \"firstname\": \"\",\n  \"lastname\": \"\",\n  \"postCode\": \"\",\n  \"street\": \"\",\n  \"telephone\": \"\"\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, add_headers('authorization' = '{{apiKey}}'), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/api/v1/organizations/:organizationId/addresses/billing")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["authorization"] = '{{apiKey}}'
request["content-type"] = 'application/json'
request.body = "{\n  \"city\": \"\",\n  \"companyName\": \"\",\n  \"countryCode\": \"\",\n  \"countryName\": \"\",\n  \"firstname\": \"\",\n  \"lastname\": \"\",\n  \"postCode\": \"\",\n  \"street\": \"\",\n  \"telephone\": \"\"\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.put('/baseUrl/api/v1/organizations/:organizationId/addresses/billing') do |req|
  req.headers['authorization'] = '{{apiKey}}'
  req.body = "{\n  \"city\": \"\",\n  \"companyName\": \"\",\n  \"countryCode\": \"\",\n  \"countryName\": \"\",\n  \"firstname\": \"\",\n  \"lastname\": \"\",\n  \"postCode\": \"\",\n  \"street\": \"\",\n  \"telephone\": \"\"\n}"
end

puts response.status
puts response.body
use std::str::FromStr;
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/api/v1/organizations/:organizationId/addresses/billing";

    let payload = json!({
        "city": "",
        "companyName": "",
        "countryCode": "",
        "countryName": "",
        "firstname": "",
        "lastname": "",
        "postCode": "",
        "street": "",
        "telephone": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("authorization", "{{apiKey}}".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/api/v1/organizations/:organizationId/addresses/billing \
  --header 'authorization: {{apiKey}}' \
  --header 'content-type: application/json' \
  --data '{
  "city": "",
  "companyName": "",
  "countryCode": "",
  "countryName": "",
  "firstname": "",
  "lastname": "",
  "postCode": "",
  "street": "",
  "telephone": ""
}'
echo '{
  "city": "",
  "companyName": "",
  "countryCode": "",
  "countryName": "",
  "firstname": "",
  "lastname": "",
  "postCode": "",
  "street": "",
  "telephone": ""
}' |  \
  http PUT {{baseUrl}}/api/v1/organizations/:organizationId/addresses/billing \
  authorization:'{{apiKey}}' \
  content-type:application/json
wget --quiet \
  --method PUT \
  --header 'authorization: {{apiKey}}' \
  --header 'content-type: application/json' \
  --body-data '{\n  "city": "",\n  "companyName": "",\n  "countryCode": "",\n  "countryName": "",\n  "firstname": "",\n  "lastname": "",\n  "postCode": "",\n  "street": "",\n  "telephone": ""\n}' \
  --output-document \
  - {{baseUrl}}/api/v1/organizations/:organizationId/addresses/billing
import Foundation

let headers = [
  "authorization": "{{apiKey}}",
  "content-type": "application/json"
]
let parameters = [
  "city": "",
  "companyName": "",
  "countryCode": "",
  "countryName": "",
  "firstname": "",
  "lastname": "",
  "postCode": "",
  "street": "",
  "telephone": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/api/v1/organizations/:organizationId/addresses/billing")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "PUT"
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()
RESPONSE HEADERS

Content-Type
application/json
RESPONSE BODY json

{
  "city": "MyCity",
  "companyName": "ACME Inc.",
  "countryCode": "DE",
  "countryName": "Germany",
  "firstname": "Max",
  "lastname": "Muster",
  "postCode": 12345,
  "street": "Examplestreet 1",
  "telephone": "+49 8088 12345"
}
RESPONSE HEADERS

Content-Type
application/xml
RESPONSE BODY xml

{
  "city": "MyCity",
  "companyName": "ACME Inc.",
  "countryCode": "DE",
  "countryName": "Germany",
  "firstname": "Max",
  "lastname": "Muster",
  "postCode": 12345,
  "street": "Examplestreet 1",
  "telephone": "+49 8088 12345"
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/api/v1/organizations/:organizationId/logo");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "authorization: {{apiKey}}");
headers = curl_slist_append(headers, "content-type: multipart/form-data; boundary=---011000010111000001101001");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"file\"\r\n\r\n\r\n-----011000010111000001101001--\r\n");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/api/v1/organizations/:organizationId/logo" {:headers {:authorization "{{apiKey}}"}
                                                                                      :multipart [{:name "file"
                                                                                                   :content ""}]})
require "http/client"

url = "{{baseUrl}}/api/v1/organizations/:organizationId/logo"
headers = HTTP::Headers{
  "authorization" => "{{apiKey}}"
  "content-type" => "multipart/form-data; boundary=---011000010111000001101001"
}
reqBody = "-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"file\"\r\n\r\n\r\n-----011000010111000001101001--\r\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}}/api/v1/organizations/:organizationId/logo"),
    Headers =
    {
        { "authorization", "{{apiKey}}" },
    },
    Content = new MultipartFormDataContent
    {
        new StringContent("")
        {
            Headers =
            {
                ContentDisposition = new ContentDispositionHeaderValue("form-data")
                {
                    Name = "file",
                }
            }
        },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/api/v1/organizations/:organizationId/logo");
var request = new RestRequest("", Method.Post);
request.AddHeader("authorization", "{{apiKey}}");
request.AddHeader("content-type", "multipart/form-data; boundary=---011000010111000001101001");
request.AddParameter("multipart/form-data; boundary=---011000010111000001101001", "-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"file\"\r\n\r\n\r\n-----011000010111000001101001--\r\n", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/api/v1/organizations/:organizationId/logo"

	payload := strings.NewReader("-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"file\"\r\n\r\n\r\n-----011000010111000001101001--\r\n")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("authorization", "{{apiKey}}")
	req.Header.Add("content-type", "multipart/form-data; boundary=---011000010111000001101001")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/api/v1/organizations/:organizationId/logo HTTP/1.1
Authorization: {{apiKey}}
Content-Type: multipart/form-data; boundary=---011000010111000001101001
Host: example.com
Content-Length: 113

-----011000010111000001101001
Content-Disposition: form-data; name="file"


-----011000010111000001101001--
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/api/v1/organizations/:organizationId/logo")
  .setHeader("authorization", "{{apiKey}}")
  .setHeader("content-type", "multipart/form-data; boundary=---011000010111000001101001")
  .setBody("-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"file\"\r\n\r\n\r\n-----011000010111000001101001--\r\n")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/api/v1/organizations/:organizationId/logo"))
    .header("authorization", "{{apiKey}}")
    .header("content-type", "multipart/form-data; boundary=---011000010111000001101001")
    .method("POST", HttpRequest.BodyPublishers.ofString("-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"file\"\r\n\r\n\r\n-----011000010111000001101001--\r\n"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("multipart/form-data; boundary=---011000010111000001101001");
RequestBody body = RequestBody.create(mediaType, "-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"file\"\r\n\r\n\r\n-----011000010111000001101001--\r\n");
Request request = new Request.Builder()
  .url("{{baseUrl}}/api/v1/organizations/:organizationId/logo")
  .post(body)
  .addHeader("authorization", "{{apiKey}}")
  .addHeader("content-type", "multipart/form-data; boundary=---011000010111000001101001")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/api/v1/organizations/:organizationId/logo")
  .header("authorization", "{{apiKey}}")
  .header("content-type", "multipart/form-data; boundary=---011000010111000001101001")
  .body("-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"file\"\r\n\r\n\r\n-----011000010111000001101001--\r\n")
  .asString();
const data = new FormData();
data.append('file', '');

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/api/v1/organizations/:organizationId/logo');
xhr.setRequestHeader('authorization', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const form = new FormData();
form.append('file', '');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/api/v1/organizations/:organizationId/logo',
  headers: {
    authorization: '{{apiKey}}',
    'content-type': 'multipart/form-data; boundary=---011000010111000001101001'
  },
  data: '[form]'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/api/v1/organizations/:organizationId/logo';
const form = new FormData();
form.append('file', '');

const options = {method: 'POST', headers: {authorization: '{{apiKey}}'}};

options.body = form;

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const form = new FormData();
form.append('file', '');

const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/api/v1/organizations/:organizationId/logo',
  method: 'POST',
  headers: {
    authorization: '{{apiKey}}'
  },
  processData: false,
  contentType: false,
  mimeType: 'multipart/form-data',
  data: form
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("multipart/form-data; boundary=---011000010111000001101001")
val body = RequestBody.create(mediaType, "-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"file\"\r\n\r\n\r\n-----011000010111000001101001--\r\n")
val request = Request.Builder()
  .url("{{baseUrl}}/api/v1/organizations/:organizationId/logo")
  .post(body)
  .addHeader("authorization", "{{apiKey}}")
  .addHeader("content-type", "multipart/form-data; boundary=---011000010111000001101001")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/api/v1/organizations/:organizationId/logo',
  headers: {
    authorization: '{{apiKey}}',
    'content-type': 'multipart/form-data; boundary=---011000010111000001101001'
  }
};

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('-----011000010111000001101001\r\nContent-Disposition: form-data; name="file"\r\n\r\n\r\n-----011000010111000001101001--\r\n');
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/api/v1/organizations/:organizationId/logo',
  headers: {
    authorization: '{{apiKey}}',
    'content-type': 'multipart/form-data; boundary=---011000010111000001101001'
  },
  formData: {file: ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/api/v1/organizations/:organizationId/logo');

req.headers({
  authorization: '{{apiKey}}',
  'content-type': 'multipart/form-data; boundary=---011000010111000001101001'
});

req.multipart([]);

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}}/api/v1/organizations/:organizationId/logo',
  headers: {
    authorization: '{{apiKey}}',
    'content-type': 'multipart/form-data; boundary=---011000010111000001101001'
  },
  data: '-----011000010111000001101001\r\nContent-Disposition: form-data; name="file"\r\n\r\n\r\n-----011000010111000001101001--\r\n'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const FormData = require('form-data');
const fetch = require('node-fetch');

const formData = new FormData();
formData.append('file', '');

const url = '{{baseUrl}}/api/v1/organizations/:organizationId/logo';
const options = {method: 'POST', headers: {authorization: '{{apiKey}}'}};
options.body = formData;

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"authorization": @"{{apiKey}}",
                           @"content-type": @"multipart/form-data; boundary=---011000010111000001101001" };
NSArray *parameters = @[ @{ @"name": @"file", @"value": @"" } ];
NSString *boundary = @"---011000010111000001101001";

NSError *error;
NSMutableString *body = [NSMutableString string];
for (NSDictionary *param in parameters) {
    [body appendFormat:@"--%@\r\n", boundary];
    if (param[@"fileName"]) {
        [body appendFormat:@"Content-Disposition:form-data; name=\"%@\"; filename=\"%@\"\r\n", param[@"name"], param[@"fileName"]];
        [body appendFormat:@"Content-Type: %@\r\n\r\n", param[@"contentType"]];
        [body appendFormat:@"%@", [NSString stringWithContentsOfFile:param[@"fileName"] encoding:NSUTF8StringEncoding error:&error]];
        if (error) {
            NSLog(@"%@", error);
        }
    } else {
        [body appendFormat:@"Content-Disposition:form-data; name=\"%@\"\r\n\r\n", param[@"name"]];
        [body appendFormat:@"%@", param[@"value"]];
    }
}
[body appendFormat:@"\r\n--%@--\r\n", boundary];
NSData *postData = [body dataUsingEncoding:NSUTF8StringEncoding];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/api/v1/organizations/:organizationId/logo"]
                                                       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}}/api/v1/organizations/:organizationId/logo" in
let headers = Header.add_list (Header.init ()) [
  ("authorization", "{{apiKey}}");
  ("content-type", "multipart/form-data; boundary=---011000010111000001101001");
] in
let body = Cohttp_lwt_body.of_string "-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"file\"\r\n\r\n\r\n-----011000010111000001101001--\r\n" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/api/v1/organizations/:organizationId/logo",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => "-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"file\"\r\n\r\n\r\n-----011000010111000001101001--\r\n",
  CURLOPT_HTTPHEADER => [
    "authorization: {{apiKey}}",
    "content-type: multipart/form-data; boundary=---011000010111000001101001"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/api/v1/organizations/:organizationId/logo', [
  'headers' => [
    'authorization' => '{{apiKey}}',
    'content-type' => 'multipart/form-data; boundary=---011000010111000001101001',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/api/v1/organizations/:organizationId/logo');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'authorization' => '{{apiKey}}',
  'content-type' => 'multipart/form-data; boundary=---011000010111000001101001'
]);

$request->setBody('-----011000010111000001101001
Content-Disposition: form-data; name="file"


-----011000010111000001101001--
');

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
addForm(null, null);

$request->setRequestUrl('{{baseUrl}}/api/v1/organizations/:organizationId/logo');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'authorization' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$headers.Add("content-type", "multipart/form-data; boundary=---011000010111000001101001")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/api/v1/organizations/:organizationId/logo' -Method POST -Headers $headers -ContentType 'multipart/form-data; boundary=---011000010111000001101001' -Body '-----011000010111000001101001
Content-Disposition: form-data; name="file"


-----011000010111000001101001--
'
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$headers.Add("content-type", "multipart/form-data; boundary=---011000010111000001101001")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/api/v1/organizations/:organizationId/logo' -Method POST -Headers $headers -ContentType 'multipart/form-data; boundary=---011000010111000001101001' -Body '-----011000010111000001101001
Content-Disposition: form-data; name="file"


-----011000010111000001101001--
'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"file\"\r\n\r\n\r\n-----011000010111000001101001--\r\n"

headers = {
    'authorization': "{{apiKey}}",
    'content-type': "multipart/form-data; boundary=---011000010111000001101001"
}

conn.request("POST", "/baseUrl/api/v1/organizations/:organizationId/logo", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/api/v1/organizations/:organizationId/logo"

payload = "-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"file\"\r\n\r\n\r\n-----011000010111000001101001--\r\n"
headers = {
    "authorization": "{{apiKey}}",
    "content-type": "multipart/form-data; boundary=---011000010111000001101001"
}

response = requests.post(url, data=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/api/v1/organizations/:organizationId/logo"

payload <- "-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"file\"\r\n\r\n\r\n-----011000010111000001101001--\r\n"

encode <- "multipart"

response <- VERB("POST", url, body = payload, add_headers('authorization' = '{{apiKey}}'), content_type("multipart/form-data"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/api/v1/organizations/:organizationId/logo")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["authorization"] = '{{apiKey}}'
request["content-type"] = 'multipart/form-data; boundary=---011000010111000001101001'
request.body = "-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"file\"\r\n\r\n\r\n-----011000010111000001101001--\r\n"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'multipart/form-data; boundary=---011000010111000001101001'}
)

response = conn.post('/baseUrl/api/v1/organizations/:organizationId/logo') do |req|
  req.headers['authorization'] = '{{apiKey}}'
  req.body = "-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"file\"\r\n\r\n\r\n-----011000010111000001101001--\r\n"
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/api/v1/organizations/:organizationId/logo";

    let form = reqwest::multipart::Form::new()
        .text("file", "");
    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("authorization", "{{apiKey}}".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .multipart(form)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/api/v1/organizations/:organizationId/logo \
  --header 'authorization: {{apiKey}}' \
  --header 'content-type: multipart/form-data' \
  --form file=
echo '-----011000010111000001101001
Content-Disposition: form-data; name="file"


-----011000010111000001101001--
' |  \
  http POST {{baseUrl}}/api/v1/organizations/:organizationId/logo \
  authorization:'{{apiKey}}' \
  content-type:'multipart/form-data; boundary=---011000010111000001101001'
wget --quiet \
  --method POST \
  --header 'authorization: {{apiKey}}' \
  --header 'content-type: multipart/form-data; boundary=---011000010111000001101001' \
  --body-data '-----011000010111000001101001\r\nContent-Disposition: form-data; name="file"\r\n\r\n\r\n-----011000010111000001101001--\r\n' \
  --output-document \
  - {{baseUrl}}/api/v1/organizations/:organizationId/logo
import Foundation

let headers = [
  "authorization": "{{apiKey}}",
  "content-type": "multipart/form-data; boundary=---011000010111000001101001"
]
let parameters = [
  [
    "name": "file",
    "value": ""
  ]
]

let boundary = "---011000010111000001101001"

var body = ""
var error: NSError? = nil
for param in parameters {
  let paramName = param["name"]!
  body += "--\(boundary)\r\n"
  body += "Content-Disposition:form-data; name=\"\(paramName)\""
  if let filename = param["fileName"] {
    let contentType = param["content-type"]!
    let fileContent = String(contentsOfFile: filename, encoding: String.Encoding.utf8)
    if (error != nil) {
      print(error as Any)
    }
    body += "; filename=\"\(filename)\"\r\n"
    body += "Content-Type: \(contentType)\r\n\r\n"
    body += fileContent
  } else if let paramValue = param["value"] {
    body += "\r\n\r\n\(paramValue)"
  }
}

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/api/v1/organizations/:organizationId/logo")! 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()
RESPONSE HEADERS

Content-Type
application/json
RESPONSE BODY json

{
  "uri": "/api/v1/public/image/bc671c63-4a9b-46e7-8c59-9bbe1917e6cc"
}
RESPONSE HEADERS

Content-Type
application/xml
RESPONSE BODY xml

{
  "uri": "/api/v1/public/image/bc671c63-4a9b-46e7-8c59-9bbe1917e6cc"
}
PUT Update organization
{{baseUrl}}/api/v1/organizations/:organizationId
HEADERS

Authorization
{{apiKey}}
QUERY PARAMS

organizationId
BODY json

{
  "name": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/api/v1/organizations/:organizationId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "authorization: {{apiKey}}");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"name\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/api/v1/organizations/:organizationId" {:headers {:authorization "{{apiKey}}"}
                                                                                :content-type :json
                                                                                :form-params {:name ""}})
require "http/client"

url = "{{baseUrl}}/api/v1/organizations/:organizationId"
headers = HTTP::Headers{
  "authorization" => "{{apiKey}}"
  "content-type" => "application/json"
}
reqBody = "{\n  \"name\": \"\"\n}"

response = HTTP::Client.put url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Put,
    RequestUri = new Uri("{{baseUrl}}/api/v1/organizations/:organizationId"),
    Headers =
    {
        { "authorization", "{{apiKey}}" },
    },
    Content = new StringContent("{\n  \"name\": \"\"\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}}/api/v1/organizations/:organizationId");
var request = new RestRequest("", Method.Put);
request.AddHeader("authorization", "{{apiKey}}");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"name\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/api/v1/organizations/:organizationId"

	payload := strings.NewReader("{\n  \"name\": \"\"\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("authorization", "{{apiKey}}")
	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))

}
PUT /baseUrl/api/v1/organizations/:organizationId HTTP/1.1
Authorization: {{apiKey}}
Content-Type: application/json
Host: example.com
Content-Length: 16

{
  "name": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/api/v1/organizations/:organizationId")
  .setHeader("authorization", "{{apiKey}}")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"name\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/api/v1/organizations/:organizationId"))
    .header("authorization", "{{apiKey}}")
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"name\": \"\"\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  \"name\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/api/v1/organizations/:organizationId")
  .put(body)
  .addHeader("authorization", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/api/v1/organizations/:organizationId")
  .header("authorization", "{{apiKey}}")
  .header("content-type", "application/json")
  .body("{\n  \"name\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  name: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/api/v1/organizations/:organizationId');
xhr.setRequestHeader('authorization', '{{apiKey}}');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/api/v1/organizations/:organizationId',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  data: {name: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/api/v1/organizations/:organizationId';
const options = {
  method: 'PUT',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"name":""}'
};

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}}/api/v1/organizations/:organizationId',
  method: 'PUT',
  headers: {
    authorization: '{{apiKey}}',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "name": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"name\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/api/v1/organizations/:organizationId")
  .put(body)
  .addHeader("authorization", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/api/v1/organizations/:organizationId',
  headers: {
    authorization: '{{apiKey}}',
    '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({name: ''}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/api/v1/organizations/:organizationId',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  body: {name: ''},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('PUT', '{{baseUrl}}/api/v1/organizations/:organizationId');

req.headers({
  authorization: '{{apiKey}}',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  name: ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/api/v1/organizations/:organizationId',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  data: {name: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/api/v1/organizations/:organizationId';
const options = {
  method: 'PUT',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"name":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"authorization": @"{{apiKey}}",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"name": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/api/v1/organizations/:organizationId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"PUT"];
[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}}/api/v1/organizations/:organizationId" in
let headers = Header.add_list (Header.init ()) [
  ("authorization", "{{apiKey}}");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"name\": \"\"\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/api/v1/organizations/:organizationId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
  CURLOPT_POSTFIELDS => json_encode([
    'name' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "authorization: {{apiKey}}",
    "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('PUT', '{{baseUrl}}/api/v1/organizations/:organizationId', [
  'body' => '{
  "name": ""
}',
  'headers' => [
    'authorization' => '{{apiKey}}',
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/api/v1/organizations/:organizationId');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'authorization' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'name' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'name' => ''
]));
$request->setRequestUrl('{{baseUrl}}/api/v1/organizations/:organizationId');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'authorization' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/api/v1/organizations/:organizationId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "name": ""
}'
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/api/v1/organizations/:organizationId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "name": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"name\": \"\"\n}"

headers = {
    'authorization': "{{apiKey}}",
    'content-type': "application/json"
}

conn.request("PUT", "/baseUrl/api/v1/organizations/:organizationId", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/api/v1/organizations/:organizationId"

payload = { "name": "" }
headers = {
    "authorization": "{{apiKey}}",
    "content-type": "application/json"
}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/api/v1/organizations/:organizationId"

payload <- "{\n  \"name\": \"\"\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, add_headers('authorization' = '{{apiKey}}'), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/api/v1/organizations/:organizationId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["authorization"] = '{{apiKey}}'
request["content-type"] = 'application/json'
request.body = "{\n  \"name\": \"\"\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.put('/baseUrl/api/v1/organizations/:organizationId') do |req|
  req.headers['authorization'] = '{{apiKey}}'
  req.body = "{\n  \"name\": \"\"\n}"
end

puts response.status
puts response.body
use std::str::FromStr;
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/api/v1/organizations/:organizationId";

    let payload = json!({"name": ""});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("authorization", "{{apiKey}}".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/api/v1/organizations/:organizationId \
  --header 'authorization: {{apiKey}}' \
  --header 'content-type: application/json' \
  --data '{
  "name": ""
}'
echo '{
  "name": ""
}' |  \
  http PUT {{baseUrl}}/api/v1/organizations/:organizationId \
  authorization:'{{apiKey}}' \
  content-type:application/json
wget --quiet \
  --method PUT \
  --header 'authorization: {{apiKey}}' \
  --header 'content-type: application/json' \
  --body-data '{\n  "name": ""\n}' \
  --output-document \
  - {{baseUrl}}/api/v1/organizations/:organizationId
import Foundation

let headers = [
  "authorization": "{{apiKey}}",
  "content-type": "application/json"
]
let parameters = ["name": ""] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/api/v1/organizations/:organizationId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "PUT"
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()
RESPONSE HEADERS

Content-Type
application/json
RESPONSE BODY json

{
  "id": 100,
  "logoURL": "/api/v1/public/images/abcdef",
  "name": "ACME Inc.",
  "namespace": "de.acme"
}
RESPONSE HEADERS

Content-Type
application/xml
RESPONSE BODY xml

{
  "id": 100,
  "logoURL": "/api/v1/public/images/abcdef",
  "name": "ACME Inc.",
  "namespace": "de.acme"
}
GET Forward
{{baseUrl}}/go/:guid
QUERY PARAMS

guid
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/go/:guid");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/go/:guid")
require "http/client"

url = "{{baseUrl}}/go/:guid"

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}}/go/:guid"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/go/:guid");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/go/:guid"

	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/go/:guid HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/go/:guid")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/go/:guid"))
    .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}}/go/:guid")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/go/:guid")
  .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}}/go/:guid');

xhr.send(data);
import axios from 'axios';

const options = {method: 'GET', url: '{{baseUrl}}/go/:guid'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/go/:guid';
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}}/go/:guid',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/go/:guid")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/go/:guid',
  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}}/go/:guid'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/go/:guid');

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}}/go/:guid'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/go/:guid';
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}}/go/:guid"]
                                                       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}}/go/:guid" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/go/:guid",
  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}}/go/:guid');

echo $response->getBody();
setUrl('{{baseUrl}}/go/:guid');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/go/:guid');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/go/:guid' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/go/:guid' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/go/:guid")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/go/:guid"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/go/:guid"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/go/:guid")

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/go/:guid') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/go/:guid";

    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}}/go/:guid
http GET {{baseUrl}}/go/:guid
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/go/:guid
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/go/:guid")! 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 List public documents
{{baseUrl}}/api/v1/public/documents/:id4n
HEADERS

Authorization
{{apiKey}}
QUERY PARAMS

id4n
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/api/v1/public/documents/:id4n");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "authorization: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/api/v1/public/documents/:id4n" {:headers {:authorization "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/api/v1/public/documents/:id4n"
headers = HTTP::Headers{
  "authorization" => "{{apiKey}}"
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/api/v1/public/documents/:id4n"),
    Headers =
    {
        { "authorization", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/api/v1/public/documents/:id4n");
var request = new RestRequest("", Method.Get);
request.AddHeader("authorization", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/api/v1/public/documents/:id4n"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("authorization", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/api/v1/public/documents/:id4n HTTP/1.1
Authorization: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/api/v1/public/documents/:id4n")
  .setHeader("authorization", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/api/v1/public/documents/:id4n"))
    .header("authorization", "{{apiKey}}")
    .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}}/api/v1/public/documents/:id4n")
  .get()
  .addHeader("authorization", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/api/v1/public/documents/:id4n")
  .header("authorization", "{{apiKey}}")
  .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}}/api/v1/public/documents/:id4n');
xhr.setRequestHeader('authorization', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/api/v1/public/documents/:id4n',
  headers: {authorization: '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/api/v1/public/documents/:id4n';
const options = {method: 'GET', headers: {authorization: '{{apiKey}}'}};

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}}/api/v1/public/documents/:id4n',
  method: 'GET',
  headers: {
    authorization: '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/api/v1/public/documents/:id4n")
  .get()
  .addHeader("authorization", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/api/v1/public/documents/:id4n',
  headers: {
    authorization: '{{apiKey}}'
  }
};

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}}/api/v1/public/documents/:id4n',
  headers: {authorization: '{{apiKey}}'}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/api/v1/public/documents/:id4n');

req.headers({
  authorization: '{{apiKey}}'
});

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}}/api/v1/public/documents/:id4n',
  headers: {authorization: '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/api/v1/public/documents/:id4n';
const options = {method: 'GET', headers: {authorization: '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"authorization": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/api/v1/public/documents/:id4n"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

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}}/api/v1/public/documents/:id4n" in
let headers = Header.add (Header.init ()) "authorization" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/api/v1/public/documents/:id4n",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "authorization: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/api/v1/public/documents/:id4n', [
  'headers' => [
    'authorization' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/api/v1/public/documents/:id4n');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'authorization' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/api/v1/public/documents/:id4n');
$request->setRequestMethod('GET');
$request->setHeaders([
  'authorization' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/api/v1/public/documents/:id4n' -Method GET -Headers $headers
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/api/v1/public/documents/:id4n' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'authorization': "{{apiKey}}" }

conn.request("GET", "/baseUrl/api/v1/public/documents/:id4n", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/api/v1/public/documents/:id4n"

headers = {"authorization": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/api/v1/public/documents/:id4n"

response <- VERB("GET", url, add_headers('authorization' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/api/v1/public/documents/:id4n")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["authorization"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/api/v1/public/documents/:id4n') do |req|
  req.headers['authorization'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/api/v1/public/documents/:id4n";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("authorization", "{{apiKey}}".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/api/v1/public/documents/:id4n \
  --header 'authorization: {{apiKey}}'
http GET {{baseUrl}}/api/v1/public/documents/:id4n \
  authorization:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'authorization: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/api/v1/public/documents/:id4n
import Foundation

let headers = ["authorization": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/api/v1/public/documents/:id4n")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

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()
RESPONSE HEADERS

Content-Type
application/json
RESPONSE BODY json

{
  "limit": 100,
  "offset": 0,
  "total": 200
}
RESPONSE HEADERS

Content-Type
application/xml
RESPONSE BODY xml

{
  "limit": 100,
  "offset": 0,
  "total": 200
}
GET Read public document contents
{{baseUrl}}/api/v1/public/documents/:id4n/:organizationId/:fileName
HEADERS

Authorization
{{apiKey}}
QUERY PARAMS

organizationId
id4n
fileName
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/api/v1/public/documents/:id4n/:organizationId/:fileName");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "authorization: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/api/v1/public/documents/:id4n/:organizationId/:fileName" {:headers {:authorization "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/api/v1/public/documents/:id4n/:organizationId/:fileName"
headers = HTTP::Headers{
  "authorization" => "{{apiKey}}"
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/api/v1/public/documents/:id4n/:organizationId/:fileName"),
    Headers =
    {
        { "authorization", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/api/v1/public/documents/:id4n/:organizationId/:fileName");
var request = new RestRequest("", Method.Get);
request.AddHeader("authorization", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/api/v1/public/documents/:id4n/:organizationId/:fileName"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("authorization", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/api/v1/public/documents/:id4n/:organizationId/:fileName HTTP/1.1
Authorization: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/api/v1/public/documents/:id4n/:organizationId/:fileName")
  .setHeader("authorization", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/api/v1/public/documents/:id4n/:organizationId/:fileName"))
    .header("authorization", "{{apiKey}}")
    .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}}/api/v1/public/documents/:id4n/:organizationId/:fileName")
  .get()
  .addHeader("authorization", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/api/v1/public/documents/:id4n/:organizationId/:fileName")
  .header("authorization", "{{apiKey}}")
  .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}}/api/v1/public/documents/:id4n/:organizationId/:fileName');
xhr.setRequestHeader('authorization', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/api/v1/public/documents/:id4n/:organizationId/:fileName',
  headers: {authorization: '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/api/v1/public/documents/:id4n/:organizationId/:fileName';
const options = {method: 'GET', headers: {authorization: '{{apiKey}}'}};

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}}/api/v1/public/documents/:id4n/:organizationId/:fileName',
  method: 'GET',
  headers: {
    authorization: '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/api/v1/public/documents/:id4n/:organizationId/:fileName")
  .get()
  .addHeader("authorization", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/api/v1/public/documents/:id4n/:organizationId/:fileName',
  headers: {
    authorization: '{{apiKey}}'
  }
};

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}}/api/v1/public/documents/:id4n/:organizationId/:fileName',
  headers: {authorization: '{{apiKey}}'}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/api/v1/public/documents/:id4n/:organizationId/:fileName');

req.headers({
  authorization: '{{apiKey}}'
});

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}}/api/v1/public/documents/:id4n/:organizationId/:fileName',
  headers: {authorization: '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/api/v1/public/documents/:id4n/:organizationId/:fileName';
const options = {method: 'GET', headers: {authorization: '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"authorization": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/api/v1/public/documents/:id4n/:organizationId/:fileName"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

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}}/api/v1/public/documents/:id4n/:organizationId/:fileName" in
let headers = Header.add (Header.init ()) "authorization" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/api/v1/public/documents/:id4n/:organizationId/:fileName",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "authorization: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/api/v1/public/documents/:id4n/:organizationId/:fileName', [
  'headers' => [
    'authorization' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/api/v1/public/documents/:id4n/:organizationId/:fileName');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'authorization' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/api/v1/public/documents/:id4n/:organizationId/:fileName');
$request->setRequestMethod('GET');
$request->setHeaders([
  'authorization' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/api/v1/public/documents/:id4n/:organizationId/:fileName' -Method GET -Headers $headers
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/api/v1/public/documents/:id4n/:organizationId/:fileName' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'authorization': "{{apiKey}}" }

conn.request("GET", "/baseUrl/api/v1/public/documents/:id4n/:organizationId/:fileName", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/api/v1/public/documents/:id4n/:organizationId/:fileName"

headers = {"authorization": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/api/v1/public/documents/:id4n/:organizationId/:fileName"

response <- VERB("GET", url, add_headers('authorization' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/api/v1/public/documents/:id4n/:organizationId/:fileName")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["authorization"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/api/v1/public/documents/:id4n/:organizationId/:fileName') do |req|
  req.headers['authorization'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/api/v1/public/documents/:id4n/:organizationId/:fileName";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("authorization", "{{apiKey}}".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/api/v1/public/documents/:id4n/:organizationId/:fileName \
  --header 'authorization: {{apiKey}}'
http GET {{baseUrl}}/api/v1/public/documents/:id4n/:organizationId/:fileName \
  authorization:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'authorization: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/api/v1/public/documents/:id4n/:organizationId/:fileName
import Foundation

let headers = ["authorization": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/api/v1/public/documents/:id4n/:organizationId/:fileName")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

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 Read public organization information
{{baseUrl}}/api/v1/public/organizations/:organizationId
HEADERS

Authorization
{{apiKey}}
QUERY PARAMS

organizationId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/api/v1/public/organizations/:organizationId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "authorization: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/api/v1/public/organizations/:organizationId" {:headers {:authorization "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/api/v1/public/organizations/:organizationId"
headers = HTTP::Headers{
  "authorization" => "{{apiKey}}"
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/api/v1/public/organizations/:organizationId"),
    Headers =
    {
        { "authorization", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/api/v1/public/organizations/:organizationId");
var request = new RestRequest("", Method.Get);
request.AddHeader("authorization", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/api/v1/public/organizations/:organizationId"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("authorization", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/api/v1/public/organizations/:organizationId HTTP/1.1
Authorization: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/api/v1/public/organizations/:organizationId")
  .setHeader("authorization", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/api/v1/public/organizations/:organizationId"))
    .header("authorization", "{{apiKey}}")
    .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}}/api/v1/public/organizations/:organizationId")
  .get()
  .addHeader("authorization", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/api/v1/public/organizations/:organizationId")
  .header("authorization", "{{apiKey}}")
  .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}}/api/v1/public/organizations/:organizationId');
xhr.setRequestHeader('authorization', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/api/v1/public/organizations/:organizationId',
  headers: {authorization: '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/api/v1/public/organizations/:organizationId';
const options = {method: 'GET', headers: {authorization: '{{apiKey}}'}};

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}}/api/v1/public/organizations/:organizationId',
  method: 'GET',
  headers: {
    authorization: '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/api/v1/public/organizations/:organizationId")
  .get()
  .addHeader("authorization", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/api/v1/public/organizations/:organizationId',
  headers: {
    authorization: '{{apiKey}}'
  }
};

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}}/api/v1/public/organizations/:organizationId',
  headers: {authorization: '{{apiKey}}'}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/api/v1/public/organizations/:organizationId');

req.headers({
  authorization: '{{apiKey}}'
});

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}}/api/v1/public/organizations/:organizationId',
  headers: {authorization: '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/api/v1/public/organizations/:organizationId';
const options = {method: 'GET', headers: {authorization: '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"authorization": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/api/v1/public/organizations/:organizationId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

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}}/api/v1/public/organizations/:organizationId" in
let headers = Header.add (Header.init ()) "authorization" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/api/v1/public/organizations/:organizationId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "authorization: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/api/v1/public/organizations/:organizationId', [
  'headers' => [
    'authorization' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/api/v1/public/organizations/:organizationId');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'authorization' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/api/v1/public/organizations/:organizationId');
$request->setRequestMethod('GET');
$request->setHeaders([
  'authorization' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/api/v1/public/organizations/:organizationId' -Method GET -Headers $headers
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/api/v1/public/organizations/:organizationId' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'authorization': "{{apiKey}}" }

conn.request("GET", "/baseUrl/api/v1/public/organizations/:organizationId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/api/v1/public/organizations/:organizationId"

headers = {"authorization": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/api/v1/public/organizations/:organizationId"

response <- VERB("GET", url, add_headers('authorization' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/api/v1/public/organizations/:organizationId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["authorization"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/api/v1/public/organizations/:organizationId') do |req|
  req.headers['authorization'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/api/v1/public/organizations/:organizationId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("authorization", "{{apiKey}}".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/api/v1/public/organizations/:organizationId \
  --header 'authorization: {{apiKey}}'
http GET {{baseUrl}}/api/v1/public/organizations/:organizationId \
  authorization:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'authorization: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/api/v1/public/organizations/:organizationId
import Foundation

let headers = ["authorization": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/api/v1/public/organizations/:organizationId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

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()
RESPONSE HEADERS

Content-Type
application/json
RESPONSE BODY json

{
  "id": 100,
  "logoURL": "/api/v1/public/images/abcdef",
  "name": "ACME Inc.",
  "namespace": "de.acme"
}
RESPONSE HEADERS

Content-Type
application/xml
RESPONSE BODY xml

{
  "id": 100,
  "logoURL": "/api/v1/public/images/abcdef",
  "name": "ACME Inc.",
  "namespace": "de.acme"
}
GET Resolve owner of id4n
{{baseUrl}}/whois/:id4n
QUERY PARAMS

id4n
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/whois/:id4n");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/whois/:id4n")
require "http/client"

url = "{{baseUrl}}/whois/:id4n"

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}}/whois/:id4n"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/whois/:id4n");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/whois/:id4n"

	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/whois/:id4n HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/whois/:id4n")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/whois/:id4n"))
    .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}}/whois/:id4n")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/whois/:id4n")
  .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}}/whois/:id4n');

xhr.send(data);
import axios from 'axios';

const options = {method: 'GET', url: '{{baseUrl}}/whois/:id4n'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/whois/:id4n';
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}}/whois/:id4n',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/whois/:id4n")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/whois/:id4n',
  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}}/whois/:id4n'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/whois/:id4n');

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}}/whois/:id4n'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/whois/:id4n';
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}}/whois/:id4n"]
                                                       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}}/whois/:id4n" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/whois/:id4n",
  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}}/whois/:id4n');

echo $response->getBody();
setUrl('{{baseUrl}}/whois/:id4n');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/whois/:id4n');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/whois/:id4n' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/whois/:id4n' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/whois/:id4n")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/whois/:id4n"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/whois/:id4n"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/whois/:id4n")

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/whois/:id4n') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/whois/:id4n";

    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}}/whois/:id4n
http GET {{baseUrl}}/whois/:id4n
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/whois/:id4n
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/whois/:id4n")! 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()
RESPONSE HEADERS

Content-Type
application/json
RESPONSE BODY json

{
  "organization": {
    "id": 100,
    "logoURL": "/api/v1/public/images/abcdef",
    "name": "ACME Inc.",
    "namespace": "de.acme"
  },
  "organizationAddress": {
    "city": "MyCity",
    "companyName": "ACME Inc.",
    "countryCode": "DE",
    "countryName": "Germany",
    "firstname": "Max",
    "lastname": "Muster",
    "postCode": 12345,
    "street": "Examplestreet 1",
    "telephone": "+49 8088 12345"
  }
}
RESPONSE HEADERS

Content-Type
application/xml
RESPONSE BODY xml

{
  "organization": {
    "id": 100,
    "logoURL": "/api/v1/public/images/abcdef",
    "name": "ACME Inc.",
    "namespace": "de.acme"
  },
  "organizationAddress": {
    "city": "MyCity",
    "companyName": "ACME Inc.",
    "countryCode": "DE",
    "countryName": "Germany",
    "firstname": "Max",
    "lastname": "Muster",
    "postCode": 12345,
    "street": "Examplestreet 1",
    "telephone": "+49 8088 12345"
  }
}
GET Retrieve a public document (meta-data only, no content)
{{baseUrl}}/api/v1/public/documents/:id4n/:organizationId/:fileName/metadata
HEADERS

Authorization
{{apiKey}}
QUERY PARAMS

organizationId
id4n
fileName
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/api/v1/public/documents/:id4n/:organizationId/:fileName/metadata");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "authorization: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/api/v1/public/documents/:id4n/:organizationId/:fileName/metadata" {:headers {:authorization "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/api/v1/public/documents/:id4n/:organizationId/:fileName/metadata"
headers = HTTP::Headers{
  "authorization" => "{{apiKey}}"
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/api/v1/public/documents/:id4n/:organizationId/:fileName/metadata"),
    Headers =
    {
        { "authorization", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/api/v1/public/documents/:id4n/:organizationId/:fileName/metadata");
var request = new RestRequest("", Method.Get);
request.AddHeader("authorization", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/api/v1/public/documents/:id4n/:organizationId/:fileName/metadata"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("authorization", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/api/v1/public/documents/:id4n/:organizationId/:fileName/metadata HTTP/1.1
Authorization: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/api/v1/public/documents/:id4n/:organizationId/:fileName/metadata")
  .setHeader("authorization", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/api/v1/public/documents/:id4n/:organizationId/:fileName/metadata"))
    .header("authorization", "{{apiKey}}")
    .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}}/api/v1/public/documents/:id4n/:organizationId/:fileName/metadata")
  .get()
  .addHeader("authorization", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/api/v1/public/documents/:id4n/:organizationId/:fileName/metadata")
  .header("authorization", "{{apiKey}}")
  .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}}/api/v1/public/documents/:id4n/:organizationId/:fileName/metadata');
xhr.setRequestHeader('authorization', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/api/v1/public/documents/:id4n/:organizationId/:fileName/metadata',
  headers: {authorization: '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/api/v1/public/documents/:id4n/:organizationId/:fileName/metadata';
const options = {method: 'GET', headers: {authorization: '{{apiKey}}'}};

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}}/api/v1/public/documents/:id4n/:organizationId/:fileName/metadata',
  method: 'GET',
  headers: {
    authorization: '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/api/v1/public/documents/:id4n/:organizationId/:fileName/metadata")
  .get()
  .addHeader("authorization", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/api/v1/public/documents/:id4n/:organizationId/:fileName/metadata',
  headers: {
    authorization: '{{apiKey}}'
  }
};

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}}/api/v1/public/documents/:id4n/:organizationId/:fileName/metadata',
  headers: {authorization: '{{apiKey}}'}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/api/v1/public/documents/:id4n/:organizationId/:fileName/metadata');

req.headers({
  authorization: '{{apiKey}}'
});

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}}/api/v1/public/documents/:id4n/:organizationId/:fileName/metadata',
  headers: {authorization: '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/api/v1/public/documents/:id4n/:organizationId/:fileName/metadata';
const options = {method: 'GET', headers: {authorization: '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"authorization": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/api/v1/public/documents/:id4n/:organizationId/:fileName/metadata"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

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}}/api/v1/public/documents/:id4n/:organizationId/:fileName/metadata" in
let headers = Header.add (Header.init ()) "authorization" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/api/v1/public/documents/:id4n/:organizationId/:fileName/metadata",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "authorization: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/api/v1/public/documents/:id4n/:organizationId/:fileName/metadata', [
  'headers' => [
    'authorization' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/api/v1/public/documents/:id4n/:organizationId/:fileName/metadata');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'authorization' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/api/v1/public/documents/:id4n/:organizationId/:fileName/metadata');
$request->setRequestMethod('GET');
$request->setHeaders([
  'authorization' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/api/v1/public/documents/:id4n/:organizationId/:fileName/metadata' -Method GET -Headers $headers
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/api/v1/public/documents/:id4n/:organizationId/:fileName/metadata' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'authorization': "{{apiKey}}" }

conn.request("GET", "/baseUrl/api/v1/public/documents/:id4n/:organizationId/:fileName/metadata", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/api/v1/public/documents/:id4n/:organizationId/:fileName/metadata"

headers = {"authorization": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/api/v1/public/documents/:id4n/:organizationId/:fileName/metadata"

response <- VERB("GET", url, add_headers('authorization' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/api/v1/public/documents/:id4n/:organizationId/:fileName/metadata")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["authorization"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/api/v1/public/documents/:id4n/:organizationId/:fileName/metadata') do |req|
  req.headers['authorization'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/api/v1/public/documents/:id4n/:organizationId/:fileName/metadata";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("authorization", "{{apiKey}}".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/api/v1/public/documents/:id4n/:organizationId/:fileName/metadata \
  --header 'authorization: {{apiKey}}'
http GET {{baseUrl}}/api/v1/public/documents/:id4n/:organizationId/:fileName/metadata \
  authorization:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'authorization: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/api/v1/public/documents/:id4n/:organizationId/:fileName/metadata
import Foundation

let headers = ["authorization": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/api/v1/public/documents/:id4n/:organizationId/:fileName/metadata")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

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()
RESPONSE HEADERS

Content-Type
application/json
RESPONSE BODY json

{
  "filename": "publicInfo.pdf",
  "mimeType": "text/plain",
  "ownerOrganizationId": "de.bluerain",
  "visibility": {
    "public": true,
    "sharedOrganizationIds": [
      "de.acme",
      "com.porsche",
      "de.bluerain"
    ]
  }
}
RESPONSE HEADERS

Content-Type
application/xml
RESPONSE BODY xml

{
  "filename": "publicInfo.pdf",
  "mimeType": "text/plain",
  "ownerOrganizationId": "de.bluerain",
  "visibility": {
    "public": true,
    "sharedOrganizationIds": [
      "de.acme",
      "com.porsche",
      "de.bluerain"
    ]
  }
}
GET Retrieve all public routes for a GUID
{{baseUrl}}/api/v1/public/routes/:id4n
HEADERS

Authorization
{{apiKey}}
QUERY PARAMS

type
id4n
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/api/v1/public/routes/:id4n?type=");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "authorization: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/api/v1/public/routes/:id4n" {:headers {:authorization "{{apiKey}}"}
                                                                      :query-params {:type ""}})
require "http/client"

url = "{{baseUrl}}/api/v1/public/routes/:id4n?type="
headers = HTTP::Headers{
  "authorization" => "{{apiKey}}"
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/api/v1/public/routes/:id4n?type="),
    Headers =
    {
        { "authorization", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/api/v1/public/routes/:id4n?type=");
var request = new RestRequest("", Method.Get);
request.AddHeader("authorization", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/api/v1/public/routes/:id4n?type="

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("authorization", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/api/v1/public/routes/:id4n?type= HTTP/1.1
Authorization: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/api/v1/public/routes/:id4n?type=")
  .setHeader("authorization", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/api/v1/public/routes/:id4n?type="))
    .header("authorization", "{{apiKey}}")
    .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}}/api/v1/public/routes/:id4n?type=")
  .get()
  .addHeader("authorization", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/api/v1/public/routes/:id4n?type=")
  .header("authorization", "{{apiKey}}")
  .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}}/api/v1/public/routes/:id4n?type=');
xhr.setRequestHeader('authorization', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/api/v1/public/routes/:id4n',
  params: {type: ''},
  headers: {authorization: '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/api/v1/public/routes/:id4n?type=';
const options = {method: 'GET', headers: {authorization: '{{apiKey}}'}};

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}}/api/v1/public/routes/:id4n?type=',
  method: 'GET',
  headers: {
    authorization: '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/api/v1/public/routes/:id4n?type=")
  .get()
  .addHeader("authorization", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/api/v1/public/routes/:id4n?type=',
  headers: {
    authorization: '{{apiKey}}'
  }
};

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}}/api/v1/public/routes/:id4n',
  qs: {type: ''},
  headers: {authorization: '{{apiKey}}'}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/api/v1/public/routes/:id4n');

req.query({
  type: ''
});

req.headers({
  authorization: '{{apiKey}}'
});

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}}/api/v1/public/routes/:id4n',
  params: {type: ''},
  headers: {authorization: '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/api/v1/public/routes/:id4n?type=';
const options = {method: 'GET', headers: {authorization: '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"authorization": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/api/v1/public/routes/:id4n?type="]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

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}}/api/v1/public/routes/:id4n?type=" in
let headers = Header.add (Header.init ()) "authorization" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/api/v1/public/routes/:id4n?type=",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "authorization: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/api/v1/public/routes/:id4n?type=', [
  'headers' => [
    'authorization' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/api/v1/public/routes/:id4n');
$request->setMethod(HTTP_METH_GET);

$request->setQueryData([
  'type' => ''
]);

$request->setHeaders([
  'authorization' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/api/v1/public/routes/:id4n');
$request->setRequestMethod('GET');
$request->setQuery(new http\QueryString([
  'type' => ''
]));

$request->setHeaders([
  'authorization' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/api/v1/public/routes/:id4n?type=' -Method GET -Headers $headers
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/api/v1/public/routes/:id4n?type=' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'authorization': "{{apiKey}}" }

conn.request("GET", "/baseUrl/api/v1/public/routes/:id4n?type=", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/api/v1/public/routes/:id4n"

querystring = {"type":""}

headers = {"authorization": "{{apiKey}}"}

response = requests.get(url, headers=headers, params=querystring)

print(response.json())
library(httr)

url <- "{{baseUrl}}/api/v1/public/routes/:id4n"

queryString <- list(type = "")

response <- VERB("GET", url, query = queryString, add_headers('authorization' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/api/v1/public/routes/:id4n?type=")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["authorization"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/api/v1/public/routes/:id4n') do |req|
  req.headers['authorization'] = '{{apiKey}}'
  req.params['type'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/api/v1/public/routes/:id4n";

    let querystring = [
        ("type", ""),
    ];

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("authorization", "{{apiKey}}".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .query(&querystring)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url '{{baseUrl}}/api/v1/public/routes/:id4n?type=' \
  --header 'authorization: {{apiKey}}'
http GET '{{baseUrl}}/api/v1/public/routes/:id4n?type=' \
  authorization:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'authorization: {{apiKey}}' \
  --output-document \
  - '{{baseUrl}}/api/v1/public/routes/:id4n?type='
import Foundation

let headers = ["authorization": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/api/v1/public/routes/:id4n?type=")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

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 Shows the public history of the given GUID
{{baseUrl}}/api/v1/public/history/:id4n
HEADERS

Authorization
{{apiKey}}
QUERY PARAMS

id4n
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/api/v1/public/history/:id4n");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "authorization: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/api/v1/public/history/:id4n" {:headers {:authorization "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/api/v1/public/history/:id4n"
headers = HTTP::Headers{
  "authorization" => "{{apiKey}}"
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/api/v1/public/history/:id4n"),
    Headers =
    {
        { "authorization", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/api/v1/public/history/:id4n");
var request = new RestRequest("", Method.Get);
request.AddHeader("authorization", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/api/v1/public/history/:id4n"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("authorization", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/api/v1/public/history/:id4n HTTP/1.1
Authorization: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/api/v1/public/history/:id4n")
  .setHeader("authorization", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/api/v1/public/history/:id4n"))
    .header("authorization", "{{apiKey}}")
    .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}}/api/v1/public/history/:id4n")
  .get()
  .addHeader("authorization", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/api/v1/public/history/:id4n")
  .header("authorization", "{{apiKey}}")
  .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}}/api/v1/public/history/:id4n');
xhr.setRequestHeader('authorization', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/api/v1/public/history/:id4n',
  headers: {authorization: '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/api/v1/public/history/:id4n';
const options = {method: 'GET', headers: {authorization: '{{apiKey}}'}};

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}}/api/v1/public/history/:id4n',
  method: 'GET',
  headers: {
    authorization: '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/api/v1/public/history/:id4n")
  .get()
  .addHeader("authorization", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/api/v1/public/history/:id4n',
  headers: {
    authorization: '{{apiKey}}'
  }
};

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}}/api/v1/public/history/:id4n',
  headers: {authorization: '{{apiKey}}'}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/api/v1/public/history/:id4n');

req.headers({
  authorization: '{{apiKey}}'
});

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}}/api/v1/public/history/:id4n',
  headers: {authorization: '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/api/v1/public/history/:id4n';
const options = {method: 'GET', headers: {authorization: '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"authorization": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/api/v1/public/history/:id4n"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

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}}/api/v1/public/history/:id4n" in
let headers = Header.add (Header.init ()) "authorization" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/api/v1/public/history/:id4n",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "authorization: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/api/v1/public/history/:id4n', [
  'headers' => [
    'authorization' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/api/v1/public/history/:id4n');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'authorization' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/api/v1/public/history/:id4n');
$request->setRequestMethod('GET');
$request->setHeaders([
  'authorization' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/api/v1/public/history/:id4n' -Method GET -Headers $headers
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/api/v1/public/history/:id4n' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'authorization': "{{apiKey}}" }

conn.request("GET", "/baseUrl/api/v1/public/history/:id4n", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/api/v1/public/history/:id4n"

headers = {"authorization": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/api/v1/public/history/:id4n"

response <- VERB("GET", url, add_headers('authorization' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/api/v1/public/history/:id4n")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["authorization"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/api/v1/public/history/:id4n') do |req|
  req.headers['authorization'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/api/v1/public/history/:id4n";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("authorization", "{{apiKey}}".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/api/v1/public/history/:id4n \
  --header 'authorization: {{apiKey}}'
http GET {{baseUrl}}/api/v1/public/history/:id4n \
  authorization:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'authorization: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/api/v1/public/history/:id4n
import Foundation

let headers = ["authorization": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/api/v1/public/history/:id4n")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

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()
RESPONSE HEADERS

Content-Type
application/json
RESPONSE BODY json

{
  "limit": 100,
  "offset": 0,
  "total": 200
}
RESPONSE HEADERS

Content-Type
application/xml
RESPONSE BODY xml

{
  "limit": 100,
  "offset": 0,
  "total": 200
}
GET Retrieve all routes of a GUID (or ID4N)
{{baseUrl}}/api/v1/routingfiles/:id4n/routes/:type
HEADERS

Authorization
{{apiKey}}
QUERY PARAMS

id4n
type
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/api/v1/routingfiles/:id4n/routes/:type");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "authorization: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/api/v1/routingfiles/:id4n/routes/:type" {:headers {:authorization "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/api/v1/routingfiles/:id4n/routes/:type"
headers = HTTP::Headers{
  "authorization" => "{{apiKey}}"
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/api/v1/routingfiles/:id4n/routes/:type"),
    Headers =
    {
        { "authorization", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/api/v1/routingfiles/:id4n/routes/:type");
var request = new RestRequest("", Method.Get);
request.AddHeader("authorization", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/api/v1/routingfiles/:id4n/routes/:type"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("authorization", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/api/v1/routingfiles/:id4n/routes/:type HTTP/1.1
Authorization: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/api/v1/routingfiles/:id4n/routes/:type")
  .setHeader("authorization", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/api/v1/routingfiles/:id4n/routes/:type"))
    .header("authorization", "{{apiKey}}")
    .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}}/api/v1/routingfiles/:id4n/routes/:type")
  .get()
  .addHeader("authorization", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/api/v1/routingfiles/:id4n/routes/:type")
  .header("authorization", "{{apiKey}}")
  .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}}/api/v1/routingfiles/:id4n/routes/:type');
xhr.setRequestHeader('authorization', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/api/v1/routingfiles/:id4n/routes/:type',
  headers: {authorization: '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/api/v1/routingfiles/:id4n/routes/:type';
const options = {method: 'GET', headers: {authorization: '{{apiKey}}'}};

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}}/api/v1/routingfiles/:id4n/routes/:type',
  method: 'GET',
  headers: {
    authorization: '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/api/v1/routingfiles/:id4n/routes/:type")
  .get()
  .addHeader("authorization", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/api/v1/routingfiles/:id4n/routes/:type',
  headers: {
    authorization: '{{apiKey}}'
  }
};

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}}/api/v1/routingfiles/:id4n/routes/:type',
  headers: {authorization: '{{apiKey}}'}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/api/v1/routingfiles/:id4n/routes/:type');

req.headers({
  authorization: '{{apiKey}}'
});

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}}/api/v1/routingfiles/:id4n/routes/:type',
  headers: {authorization: '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/api/v1/routingfiles/:id4n/routes/:type';
const options = {method: 'GET', headers: {authorization: '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"authorization": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/api/v1/routingfiles/:id4n/routes/:type"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

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}}/api/v1/routingfiles/:id4n/routes/:type" in
let headers = Header.add (Header.init ()) "authorization" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/api/v1/routingfiles/:id4n/routes/:type",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "authorization: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/api/v1/routingfiles/:id4n/routes/:type', [
  'headers' => [
    'authorization' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/api/v1/routingfiles/:id4n/routes/:type');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'authorization' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/api/v1/routingfiles/:id4n/routes/:type');
$request->setRequestMethod('GET');
$request->setHeaders([
  'authorization' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/api/v1/routingfiles/:id4n/routes/:type' -Method GET -Headers $headers
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/api/v1/routingfiles/:id4n/routes/:type' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'authorization': "{{apiKey}}" }

conn.request("GET", "/baseUrl/api/v1/routingfiles/:id4n/routes/:type", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/api/v1/routingfiles/:id4n/routes/:type"

headers = {"authorization": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/api/v1/routingfiles/:id4n/routes/:type"

response <- VERB("GET", url, add_headers('authorization' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/api/v1/routingfiles/:id4n/routes/:type")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["authorization"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/api/v1/routingfiles/:id4n/routes/:type') do |req|
  req.headers['authorization'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/api/v1/routingfiles/:id4n/routes/:type";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("authorization", "{{apiKey}}".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/api/v1/routingfiles/:id4n/routes/:type \
  --header 'authorization: {{apiKey}}'
http GET {{baseUrl}}/api/v1/routingfiles/:id4n/routes/:type \
  authorization:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'authorization: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/api/v1/routingfiles/:id4n/routes/:type
import Foundation

let headers = ["authorization": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/api/v1/routingfiles/:id4n/routes/:type")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

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 Retrieve current route of a GUID (or ID4N)
{{baseUrl}}/api/v1/routingfiles/:id4n/route/:type
HEADERS

Authorization
{{apiKey}}
QUERY PARAMS

id4n
type
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/api/v1/routingfiles/:id4n/route/:type");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "authorization: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/api/v1/routingfiles/:id4n/route/:type" {:headers {:authorization "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/api/v1/routingfiles/:id4n/route/:type"
headers = HTTP::Headers{
  "authorization" => "{{apiKey}}"
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/api/v1/routingfiles/:id4n/route/:type"),
    Headers =
    {
        { "authorization", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/api/v1/routingfiles/:id4n/route/:type");
var request = new RestRequest("", Method.Get);
request.AddHeader("authorization", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/api/v1/routingfiles/:id4n/route/:type"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("authorization", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/api/v1/routingfiles/:id4n/route/:type HTTP/1.1
Authorization: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/api/v1/routingfiles/:id4n/route/:type")
  .setHeader("authorization", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/api/v1/routingfiles/:id4n/route/:type"))
    .header("authorization", "{{apiKey}}")
    .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}}/api/v1/routingfiles/:id4n/route/:type")
  .get()
  .addHeader("authorization", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/api/v1/routingfiles/:id4n/route/:type")
  .header("authorization", "{{apiKey}}")
  .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}}/api/v1/routingfiles/:id4n/route/:type');
xhr.setRequestHeader('authorization', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/api/v1/routingfiles/:id4n/route/:type',
  headers: {authorization: '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/api/v1/routingfiles/:id4n/route/:type';
const options = {method: 'GET', headers: {authorization: '{{apiKey}}'}};

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}}/api/v1/routingfiles/:id4n/route/:type',
  method: 'GET',
  headers: {
    authorization: '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/api/v1/routingfiles/:id4n/route/:type")
  .get()
  .addHeader("authorization", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/api/v1/routingfiles/:id4n/route/:type',
  headers: {
    authorization: '{{apiKey}}'
  }
};

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}}/api/v1/routingfiles/:id4n/route/:type',
  headers: {authorization: '{{apiKey}}'}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/api/v1/routingfiles/:id4n/route/:type');

req.headers({
  authorization: '{{apiKey}}'
});

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}}/api/v1/routingfiles/:id4n/route/:type',
  headers: {authorization: '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/api/v1/routingfiles/:id4n/route/:type';
const options = {method: 'GET', headers: {authorization: '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"authorization": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/api/v1/routingfiles/:id4n/route/:type"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

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}}/api/v1/routingfiles/:id4n/route/:type" in
let headers = Header.add (Header.init ()) "authorization" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/api/v1/routingfiles/:id4n/route/:type",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "authorization: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/api/v1/routingfiles/:id4n/route/:type', [
  'headers' => [
    'authorization' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/api/v1/routingfiles/:id4n/route/:type');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'authorization' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/api/v1/routingfiles/:id4n/route/:type');
$request->setRequestMethod('GET');
$request->setHeaders([
  'authorization' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/api/v1/routingfiles/:id4n/route/:type' -Method GET -Headers $headers
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/api/v1/routingfiles/:id4n/route/:type' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'authorization': "{{apiKey}}" }

conn.request("GET", "/baseUrl/api/v1/routingfiles/:id4n/route/:type", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/api/v1/routingfiles/:id4n/route/:type"

headers = {"authorization": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/api/v1/routingfiles/:id4n/route/:type"

response <- VERB("GET", url, add_headers('authorization' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/api/v1/routingfiles/:id4n/route/:type")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["authorization"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/api/v1/routingfiles/:id4n/route/:type') do |req|
  req.headers['authorization'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/api/v1/routingfiles/:id4n/route/:type";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("authorization", "{{apiKey}}".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/api/v1/routingfiles/:id4n/route/:type \
  --header 'authorization: {{apiKey}}'
http GET {{baseUrl}}/api/v1/routingfiles/:id4n/route/:type \
  authorization:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'authorization: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/api/v1/routingfiles/:id4n/route/:type
import Foundation

let headers = ["authorization": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/api/v1/routingfiles/:id4n/route/:type")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

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 Retrieve routing file
{{baseUrl}}/api/v1/routingfiles/:id4n
HEADERS

Authorization
{{apiKey}}
QUERY PARAMS

id4n
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/api/v1/routingfiles/:id4n");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "authorization: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/api/v1/routingfiles/:id4n" {:headers {:authorization "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/api/v1/routingfiles/:id4n"
headers = HTTP::Headers{
  "authorization" => "{{apiKey}}"
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/api/v1/routingfiles/:id4n"),
    Headers =
    {
        { "authorization", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/api/v1/routingfiles/:id4n");
var request = new RestRequest("", Method.Get);
request.AddHeader("authorization", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/api/v1/routingfiles/:id4n"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("authorization", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/api/v1/routingfiles/:id4n HTTP/1.1
Authorization: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/api/v1/routingfiles/:id4n")
  .setHeader("authorization", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/api/v1/routingfiles/:id4n"))
    .header("authorization", "{{apiKey}}")
    .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}}/api/v1/routingfiles/:id4n")
  .get()
  .addHeader("authorization", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/api/v1/routingfiles/:id4n")
  .header("authorization", "{{apiKey}}")
  .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}}/api/v1/routingfiles/:id4n');
xhr.setRequestHeader('authorization', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/api/v1/routingfiles/:id4n',
  headers: {authorization: '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/api/v1/routingfiles/:id4n';
const options = {method: 'GET', headers: {authorization: '{{apiKey}}'}};

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}}/api/v1/routingfiles/:id4n',
  method: 'GET',
  headers: {
    authorization: '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/api/v1/routingfiles/:id4n")
  .get()
  .addHeader("authorization", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/api/v1/routingfiles/:id4n',
  headers: {
    authorization: '{{apiKey}}'
  }
};

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}}/api/v1/routingfiles/:id4n',
  headers: {authorization: '{{apiKey}}'}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/api/v1/routingfiles/:id4n');

req.headers({
  authorization: '{{apiKey}}'
});

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}}/api/v1/routingfiles/:id4n',
  headers: {authorization: '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/api/v1/routingfiles/:id4n';
const options = {method: 'GET', headers: {authorization: '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"authorization": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/api/v1/routingfiles/:id4n"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

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}}/api/v1/routingfiles/:id4n" in
let headers = Header.add (Header.init ()) "authorization" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/api/v1/routingfiles/:id4n",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "authorization: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/api/v1/routingfiles/:id4n', [
  'headers' => [
    'authorization' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/api/v1/routingfiles/:id4n');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'authorization' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/api/v1/routingfiles/:id4n');
$request->setRequestMethod('GET');
$request->setHeaders([
  'authorization' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/api/v1/routingfiles/:id4n' -Method GET -Headers $headers
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/api/v1/routingfiles/:id4n' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'authorization': "{{apiKey}}" }

conn.request("GET", "/baseUrl/api/v1/routingfiles/:id4n", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/api/v1/routingfiles/:id4n"

headers = {"authorization": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/api/v1/routingfiles/:id4n"

response <- VERB("GET", url, add_headers('authorization' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/api/v1/routingfiles/:id4n")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["authorization"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/api/v1/routingfiles/:id4n') do |req|
  req.headers['authorization'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/api/v1/routingfiles/:id4n";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("authorization", "{{apiKey}}".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/api/v1/routingfiles/:id4n \
  --header 'authorization: {{apiKey}}'
http GET {{baseUrl}}/api/v1/routingfiles/:id4n \
  authorization:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'authorization: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/api/v1/routingfiles/:id4n
import Foundation

let headers = ["authorization": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/api/v1/routingfiles/:id4n")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

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()
PUT Store routing file
{{baseUrl}}/api/v1/routingfiles/:id4n
HEADERS

Authorization
{{apiKey}}
QUERY PARAMS

id4n
BODY json

{
  "organizationId": "",
  "routing": {
    "options": {
      "deleteOutdatedRoutes": false
    },
    "routes": [
      {
        "params": {},
        "priority": 0,
        "public": false,
        "type": "",
        "validUntil": 0
      }
    ]
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/api/v1/routingfiles/:id4n");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "authorization: {{apiKey}}");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"organizationId\": \"\",\n  \"routing\": {\n    \"options\": {\n      \"deleteOutdatedRoutes\": false\n    },\n    \"routes\": [\n      {\n        \"params\": {},\n        \"priority\": 0,\n        \"public\": false,\n        \"type\": \"\",\n        \"validUntil\": 0\n      }\n    ]\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/api/v1/routingfiles/:id4n" {:headers {:authorization "{{apiKey}}"}
                                                                     :content-type :json
                                                                     :form-params {:organizationId ""
                                                                                   :routing {:options {:deleteOutdatedRoutes false}
                                                                                             :routes [{:params {}
                                                                                                       :priority 0
                                                                                                       :public false
                                                                                                       :type ""
                                                                                                       :validUntil 0}]}}})
require "http/client"

url = "{{baseUrl}}/api/v1/routingfiles/:id4n"
headers = HTTP::Headers{
  "authorization" => "{{apiKey}}"
  "content-type" => "application/json"
}
reqBody = "{\n  \"organizationId\": \"\",\n  \"routing\": {\n    \"options\": {\n      \"deleteOutdatedRoutes\": false\n    },\n    \"routes\": [\n      {\n        \"params\": {},\n        \"priority\": 0,\n        \"public\": false,\n        \"type\": \"\",\n        \"validUntil\": 0\n      }\n    ]\n  }\n}"

response = HTTP::Client.put url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Put,
    RequestUri = new Uri("{{baseUrl}}/api/v1/routingfiles/:id4n"),
    Headers =
    {
        { "authorization", "{{apiKey}}" },
    },
    Content = new StringContent("{\n  \"organizationId\": \"\",\n  \"routing\": {\n    \"options\": {\n      \"deleteOutdatedRoutes\": false\n    },\n    \"routes\": [\n      {\n        \"params\": {},\n        \"priority\": 0,\n        \"public\": false,\n        \"type\": \"\",\n        \"validUntil\": 0\n      }\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}}/api/v1/routingfiles/:id4n");
var request = new RestRequest("", Method.Put);
request.AddHeader("authorization", "{{apiKey}}");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"organizationId\": \"\",\n  \"routing\": {\n    \"options\": {\n      \"deleteOutdatedRoutes\": false\n    },\n    \"routes\": [\n      {\n        \"params\": {},\n        \"priority\": 0,\n        \"public\": false,\n        \"type\": \"\",\n        \"validUntil\": 0\n      }\n    ]\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/api/v1/routingfiles/:id4n"

	payload := strings.NewReader("{\n  \"organizationId\": \"\",\n  \"routing\": {\n    \"options\": {\n      \"deleteOutdatedRoutes\": false\n    },\n    \"routes\": [\n      {\n        \"params\": {},\n        \"priority\": 0,\n        \"public\": false,\n        \"type\": \"\",\n        \"validUntil\": 0\n      }\n    ]\n  }\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("authorization", "{{apiKey}}")
	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))

}
PUT /baseUrl/api/v1/routingfiles/:id4n HTTP/1.1
Authorization: {{apiKey}}
Content-Type: application/json
Host: example.com
Content-Length: 258

{
  "organizationId": "",
  "routing": {
    "options": {
      "deleteOutdatedRoutes": false
    },
    "routes": [
      {
        "params": {},
        "priority": 0,
        "public": false,
        "type": "",
        "validUntil": 0
      }
    ]
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/api/v1/routingfiles/:id4n")
  .setHeader("authorization", "{{apiKey}}")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"organizationId\": \"\",\n  \"routing\": {\n    \"options\": {\n      \"deleteOutdatedRoutes\": false\n    },\n    \"routes\": [\n      {\n        \"params\": {},\n        \"priority\": 0,\n        \"public\": false,\n        \"type\": \"\",\n        \"validUntil\": 0\n      }\n    ]\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/api/v1/routingfiles/:id4n"))
    .header("authorization", "{{apiKey}}")
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"organizationId\": \"\",\n  \"routing\": {\n    \"options\": {\n      \"deleteOutdatedRoutes\": false\n    },\n    \"routes\": [\n      {\n        \"params\": {},\n        \"priority\": 0,\n        \"public\": false,\n        \"type\": \"\",\n        \"validUntil\": 0\n      }\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  \"organizationId\": \"\",\n  \"routing\": {\n    \"options\": {\n      \"deleteOutdatedRoutes\": false\n    },\n    \"routes\": [\n      {\n        \"params\": {},\n        \"priority\": 0,\n        \"public\": false,\n        \"type\": \"\",\n        \"validUntil\": 0\n      }\n    ]\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/api/v1/routingfiles/:id4n")
  .put(body)
  .addHeader("authorization", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/api/v1/routingfiles/:id4n")
  .header("authorization", "{{apiKey}}")
  .header("content-type", "application/json")
  .body("{\n  \"organizationId\": \"\",\n  \"routing\": {\n    \"options\": {\n      \"deleteOutdatedRoutes\": false\n    },\n    \"routes\": [\n      {\n        \"params\": {},\n        \"priority\": 0,\n        \"public\": false,\n        \"type\": \"\",\n        \"validUntil\": 0\n      }\n    ]\n  }\n}")
  .asString();
const data = JSON.stringify({
  organizationId: '',
  routing: {
    options: {
      deleteOutdatedRoutes: false
    },
    routes: [
      {
        params: {},
        priority: 0,
        public: false,
        type: '',
        validUntil: 0
      }
    ]
  }
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/api/v1/routingfiles/:id4n');
xhr.setRequestHeader('authorization', '{{apiKey}}');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/api/v1/routingfiles/:id4n',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  data: {
    organizationId: '',
    routing: {
      options: {deleteOutdatedRoutes: false},
      routes: [{params: {}, priority: 0, public: false, type: '', validUntil: 0}]
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/api/v1/routingfiles/:id4n';
const options = {
  method: 'PUT',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"organizationId":"","routing":{"options":{"deleteOutdatedRoutes":false},"routes":[{"params":{},"priority":0,"public":false,"type":"","validUntil":0}]}}'
};

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}}/api/v1/routingfiles/:id4n',
  method: 'PUT',
  headers: {
    authorization: '{{apiKey}}',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "organizationId": "",\n  "routing": {\n    "options": {\n      "deleteOutdatedRoutes": false\n    },\n    "routes": [\n      {\n        "params": {},\n        "priority": 0,\n        "public": false,\n        "type": "",\n        "validUntil": 0\n      }\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  \"organizationId\": \"\",\n  \"routing\": {\n    \"options\": {\n      \"deleteOutdatedRoutes\": false\n    },\n    \"routes\": [\n      {\n        \"params\": {},\n        \"priority\": 0,\n        \"public\": false,\n        \"type\": \"\",\n        \"validUntil\": 0\n      }\n    ]\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/api/v1/routingfiles/:id4n")
  .put(body)
  .addHeader("authorization", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/api/v1/routingfiles/:id4n',
  headers: {
    authorization: '{{apiKey}}',
    '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({
  organizationId: '',
  routing: {
    options: {deleteOutdatedRoutes: false},
    routes: [{params: {}, priority: 0, public: false, type: '', validUntil: 0}]
  }
}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/api/v1/routingfiles/:id4n',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  body: {
    organizationId: '',
    routing: {
      options: {deleteOutdatedRoutes: false},
      routes: [{params: {}, priority: 0, public: false, type: '', validUntil: 0}]
    }
  },
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('PUT', '{{baseUrl}}/api/v1/routingfiles/:id4n');

req.headers({
  authorization: '{{apiKey}}',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  organizationId: '',
  routing: {
    options: {
      deleteOutdatedRoutes: false
    },
    routes: [
      {
        params: {},
        priority: 0,
        public: false,
        type: '',
        validUntil: 0
      }
    ]
  }
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/api/v1/routingfiles/:id4n',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  data: {
    organizationId: '',
    routing: {
      options: {deleteOutdatedRoutes: false},
      routes: [{params: {}, priority: 0, public: false, type: '', validUntil: 0}]
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/api/v1/routingfiles/:id4n';
const options = {
  method: 'PUT',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"organizationId":"","routing":{"options":{"deleteOutdatedRoutes":false},"routes":[{"params":{},"priority":0,"public":false,"type":"","validUntil":0}]}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"authorization": @"{{apiKey}}",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"organizationId": @"",
                              @"routing": @{ @"options": @{ @"deleteOutdatedRoutes": @NO }, @"routes": @[ @{ @"params": @{  }, @"priority": @0, @"public": @NO, @"type": @"", @"validUntil": @0 } ] } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/api/v1/routingfiles/:id4n"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"PUT"];
[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}}/api/v1/routingfiles/:id4n" in
let headers = Header.add_list (Header.init ()) [
  ("authorization", "{{apiKey}}");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"organizationId\": \"\",\n  \"routing\": {\n    \"options\": {\n      \"deleteOutdatedRoutes\": false\n    },\n    \"routes\": [\n      {\n        \"params\": {},\n        \"priority\": 0,\n        \"public\": false,\n        \"type\": \"\",\n        \"validUntil\": 0\n      }\n    ]\n  }\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/api/v1/routingfiles/:id4n",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
  CURLOPT_POSTFIELDS => json_encode([
    'organizationId' => '',
    'routing' => [
        'options' => [
                'deleteOutdatedRoutes' => null
        ],
        'routes' => [
                [
                                'params' => [
                                                                
                                ],
                                'priority' => 0,
                                'public' => null,
                                'type' => '',
                                'validUntil' => 0
                ]
        ]
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "authorization: {{apiKey}}",
    "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('PUT', '{{baseUrl}}/api/v1/routingfiles/:id4n', [
  'body' => '{
  "organizationId": "",
  "routing": {
    "options": {
      "deleteOutdatedRoutes": false
    },
    "routes": [
      {
        "params": {},
        "priority": 0,
        "public": false,
        "type": "",
        "validUntil": 0
      }
    ]
  }
}',
  'headers' => [
    'authorization' => '{{apiKey}}',
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/api/v1/routingfiles/:id4n');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'authorization' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'organizationId' => '',
  'routing' => [
    'options' => [
        'deleteOutdatedRoutes' => null
    ],
    'routes' => [
        [
                'params' => [
                                
                ],
                'priority' => 0,
                'public' => null,
                'type' => '',
                'validUntil' => 0
        ]
    ]
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'organizationId' => '',
  'routing' => [
    'options' => [
        'deleteOutdatedRoutes' => null
    ],
    'routes' => [
        [
                'params' => [
                                
                ],
                'priority' => 0,
                'public' => null,
                'type' => '',
                'validUntil' => 0
        ]
    ]
  ]
]));
$request->setRequestUrl('{{baseUrl}}/api/v1/routingfiles/:id4n');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'authorization' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/api/v1/routingfiles/:id4n' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "organizationId": "",
  "routing": {
    "options": {
      "deleteOutdatedRoutes": false
    },
    "routes": [
      {
        "params": {},
        "priority": 0,
        "public": false,
        "type": "",
        "validUntil": 0
      }
    ]
  }
}'
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/api/v1/routingfiles/:id4n' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "organizationId": "",
  "routing": {
    "options": {
      "deleteOutdatedRoutes": false
    },
    "routes": [
      {
        "params": {},
        "priority": 0,
        "public": false,
        "type": "",
        "validUntil": 0
      }
    ]
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"organizationId\": \"\",\n  \"routing\": {\n    \"options\": {\n      \"deleteOutdatedRoutes\": false\n    },\n    \"routes\": [\n      {\n        \"params\": {},\n        \"priority\": 0,\n        \"public\": false,\n        \"type\": \"\",\n        \"validUntil\": 0\n      }\n    ]\n  }\n}"

headers = {
    'authorization': "{{apiKey}}",
    'content-type': "application/json"
}

conn.request("PUT", "/baseUrl/api/v1/routingfiles/:id4n", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/api/v1/routingfiles/:id4n"

payload = {
    "organizationId": "",
    "routing": {
        "options": { "deleteOutdatedRoutes": False },
        "routes": [
            {
                "params": {},
                "priority": 0,
                "public": False,
                "type": "",
                "validUntil": 0
            }
        ]
    }
}
headers = {
    "authorization": "{{apiKey}}",
    "content-type": "application/json"
}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/api/v1/routingfiles/:id4n"

payload <- "{\n  \"organizationId\": \"\",\n  \"routing\": {\n    \"options\": {\n      \"deleteOutdatedRoutes\": false\n    },\n    \"routes\": [\n      {\n        \"params\": {},\n        \"priority\": 0,\n        \"public\": false,\n        \"type\": \"\",\n        \"validUntil\": 0\n      }\n    ]\n  }\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, add_headers('authorization' = '{{apiKey}}'), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/api/v1/routingfiles/:id4n")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["authorization"] = '{{apiKey}}'
request["content-type"] = 'application/json'
request.body = "{\n  \"organizationId\": \"\",\n  \"routing\": {\n    \"options\": {\n      \"deleteOutdatedRoutes\": false\n    },\n    \"routes\": [\n      {\n        \"params\": {},\n        \"priority\": 0,\n        \"public\": false,\n        \"type\": \"\",\n        \"validUntil\": 0\n      }\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.put('/baseUrl/api/v1/routingfiles/:id4n') do |req|
  req.headers['authorization'] = '{{apiKey}}'
  req.body = "{\n  \"organizationId\": \"\",\n  \"routing\": {\n    \"options\": {\n      \"deleteOutdatedRoutes\": false\n    },\n    \"routes\": [\n      {\n        \"params\": {},\n        \"priority\": 0,\n        \"public\": false,\n        \"type\": \"\",\n        \"validUntil\": 0\n      }\n    ]\n  }\n}"
end

puts response.status
puts response.body
use std::str::FromStr;
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/api/v1/routingfiles/:id4n";

    let payload = json!({
        "organizationId": "",
        "routing": json!({
            "options": json!({"deleteOutdatedRoutes": false}),
            "routes": (
                json!({
                    "params": json!({}),
                    "priority": 0,
                    "public": false,
                    "type": "",
                    "validUntil": 0
                })
            )
        })
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("authorization", "{{apiKey}}".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/api/v1/routingfiles/:id4n \
  --header 'authorization: {{apiKey}}' \
  --header 'content-type: application/json' \
  --data '{
  "organizationId": "",
  "routing": {
    "options": {
      "deleteOutdatedRoutes": false
    },
    "routes": [
      {
        "params": {},
        "priority": 0,
        "public": false,
        "type": "",
        "validUntil": 0
      }
    ]
  }
}'
echo '{
  "organizationId": "",
  "routing": {
    "options": {
      "deleteOutdatedRoutes": false
    },
    "routes": [
      {
        "params": {},
        "priority": 0,
        "public": false,
        "type": "",
        "validUntil": 0
      }
    ]
  }
}' |  \
  http PUT {{baseUrl}}/api/v1/routingfiles/:id4n \
  authorization:'{{apiKey}}' \
  content-type:application/json
wget --quiet \
  --method PUT \
  --header 'authorization: {{apiKey}}' \
  --header 'content-type: application/json' \
  --body-data '{\n  "organizationId": "",\n  "routing": {\n    "options": {\n      "deleteOutdatedRoutes": false\n    },\n    "routes": [\n      {\n        "params": {},\n        "priority": 0,\n        "public": false,\n        "type": "",\n        "validUntil": 0\n      }\n    ]\n  }\n}' \
  --output-document \
  - {{baseUrl}}/api/v1/routingfiles/:id4n
import Foundation

let headers = [
  "authorization": "{{apiKey}}",
  "content-type": "application/json"
]
let parameters = [
  "organizationId": "",
  "routing": [
    "options": ["deleteOutdatedRoutes": false],
    "routes": [
      [
        "params": [],
        "priority": 0,
        "public": false,
        "type": "",
        "validUntil": 0
      ]
    ]
  ]
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/api/v1/routingfiles/:id4n")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "PUT"
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 Create an document for an id4n
{{baseUrl}}/api/v1/documents/:id4n/:organizationId
HEADERS

Authorization
{{apiKey}}
QUERY PARAMS

organizationId
id4n
BODY multipartForm

Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/api/v1/documents/:id4n/:organizationId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "authorization: {{apiKey}}");
headers = curl_slist_append(headers, "content-type: multipart/form-data; boundary=---011000010111000001101001");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"content\"\r\n\r\n\r\n-----011000010111000001101001--\r\n");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/api/v1/documents/:id4n/:organizationId" {:headers {:authorization "{{apiKey}}"}
                                                                                   :multipart [{:name "content"
                                                                                                :content ""}]})
require "http/client"

url = "{{baseUrl}}/api/v1/documents/:id4n/:organizationId"
headers = HTTP::Headers{
  "authorization" => "{{apiKey}}"
  "content-type" => "multipart/form-data; boundary=---011000010111000001101001"
}
reqBody = "-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"content\"\r\n\r\n\r\n-----011000010111000001101001--\r\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}}/api/v1/documents/:id4n/:organizationId"),
    Headers =
    {
        { "authorization", "{{apiKey}}" },
    },
    Content = new MultipartFormDataContent
    {
        new StringContent("")
        {
            Headers =
            {
                ContentDisposition = new ContentDispositionHeaderValue("form-data")
                {
                    Name = "content",
                }
            }
        },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/api/v1/documents/:id4n/:organizationId");
var request = new RestRequest("", Method.Post);
request.AddHeader("authorization", "{{apiKey}}");
request.AddHeader("content-type", "multipart/form-data; boundary=---011000010111000001101001");
request.AddParameter("multipart/form-data; boundary=---011000010111000001101001", "-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"content\"\r\n\r\n\r\n-----011000010111000001101001--\r\n", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/api/v1/documents/:id4n/:organizationId"

	payload := strings.NewReader("-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"content\"\r\n\r\n\r\n-----011000010111000001101001--\r\n")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("authorization", "{{apiKey}}")
	req.Header.Add("content-type", "multipart/form-data; boundary=---011000010111000001101001")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/api/v1/documents/:id4n/:organizationId HTTP/1.1
Authorization: {{apiKey}}
Content-Type: multipart/form-data; boundary=---011000010111000001101001
Host: example.com
Content-Length: 116

-----011000010111000001101001
Content-Disposition: form-data; name="content"


-----011000010111000001101001--
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/api/v1/documents/:id4n/:organizationId")
  .setHeader("authorization", "{{apiKey}}")
  .setHeader("content-type", "multipart/form-data; boundary=---011000010111000001101001")
  .setBody("-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"content\"\r\n\r\n\r\n-----011000010111000001101001--\r\n")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/api/v1/documents/:id4n/:organizationId"))
    .header("authorization", "{{apiKey}}")
    .header("content-type", "multipart/form-data; boundary=---011000010111000001101001")
    .method("POST", HttpRequest.BodyPublishers.ofString("-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"content\"\r\n\r\n\r\n-----011000010111000001101001--\r\n"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("multipart/form-data; boundary=---011000010111000001101001");
RequestBody body = RequestBody.create(mediaType, "-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"content\"\r\n\r\n\r\n-----011000010111000001101001--\r\n");
Request request = new Request.Builder()
  .url("{{baseUrl}}/api/v1/documents/:id4n/:organizationId")
  .post(body)
  .addHeader("authorization", "{{apiKey}}")
  .addHeader("content-type", "multipart/form-data; boundary=---011000010111000001101001")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/api/v1/documents/:id4n/:organizationId")
  .header("authorization", "{{apiKey}}")
  .header("content-type", "multipart/form-data; boundary=---011000010111000001101001")
  .body("-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"content\"\r\n\r\n\r\n-----011000010111000001101001--\r\n")
  .asString();
const data = new FormData();
data.append('content', '');

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/api/v1/documents/:id4n/:organizationId');
xhr.setRequestHeader('authorization', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const form = new FormData();
form.append('content', '');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/api/v1/documents/:id4n/:organizationId',
  headers: {
    authorization: '{{apiKey}}',
    'content-type': 'multipart/form-data; boundary=---011000010111000001101001'
  },
  data: '[form]'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/api/v1/documents/:id4n/:organizationId';
const form = new FormData();
form.append('content', '');

const options = {method: 'POST', headers: {authorization: '{{apiKey}}'}};

options.body = form;

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const form = new FormData();
form.append('content', '');

const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/api/v1/documents/:id4n/:organizationId',
  method: 'POST',
  headers: {
    authorization: '{{apiKey}}'
  },
  processData: false,
  contentType: false,
  mimeType: 'multipart/form-data',
  data: form
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("multipart/form-data; boundary=---011000010111000001101001")
val body = RequestBody.create(mediaType, "-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"content\"\r\n\r\n\r\n-----011000010111000001101001--\r\n")
val request = Request.Builder()
  .url("{{baseUrl}}/api/v1/documents/:id4n/:organizationId")
  .post(body)
  .addHeader("authorization", "{{apiKey}}")
  .addHeader("content-type", "multipart/form-data; boundary=---011000010111000001101001")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/api/v1/documents/:id4n/:organizationId',
  headers: {
    authorization: '{{apiKey}}',
    'content-type': 'multipart/form-data; boundary=---011000010111000001101001'
  }
};

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('-----011000010111000001101001\r\nContent-Disposition: form-data; name="content"\r\n\r\n\r\n-----011000010111000001101001--\r\n');
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/api/v1/documents/:id4n/:organizationId',
  headers: {
    authorization: '{{apiKey}}',
    'content-type': 'multipart/form-data; boundary=---011000010111000001101001'
  },
  formData: {content: ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/api/v1/documents/:id4n/:organizationId');

req.headers({
  authorization: '{{apiKey}}',
  'content-type': 'multipart/form-data; boundary=---011000010111000001101001'
});

req.multipart([]);

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}}/api/v1/documents/:id4n/:organizationId',
  headers: {
    authorization: '{{apiKey}}',
    'content-type': 'multipart/form-data; boundary=---011000010111000001101001'
  },
  data: '-----011000010111000001101001\r\nContent-Disposition: form-data; name="content"\r\n\r\n\r\n-----011000010111000001101001--\r\n'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const FormData = require('form-data');
const fetch = require('node-fetch');

const formData = new FormData();
formData.append('content', '');

const url = '{{baseUrl}}/api/v1/documents/:id4n/:organizationId';
const options = {method: 'POST', headers: {authorization: '{{apiKey}}'}};
options.body = formData;

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"authorization": @"{{apiKey}}",
                           @"content-type": @"multipart/form-data; boundary=---011000010111000001101001" };
NSArray *parameters = @[ @{ @"name": @"content", @"value": @"" } ];
NSString *boundary = @"---011000010111000001101001";

NSError *error;
NSMutableString *body = [NSMutableString string];
for (NSDictionary *param in parameters) {
    [body appendFormat:@"--%@\r\n", boundary];
    if (param[@"fileName"]) {
        [body appendFormat:@"Content-Disposition:form-data; name=\"%@\"; filename=\"%@\"\r\n", param[@"name"], param[@"fileName"]];
        [body appendFormat:@"Content-Type: %@\r\n\r\n", param[@"contentType"]];
        [body appendFormat:@"%@", [NSString stringWithContentsOfFile:param[@"fileName"] encoding:NSUTF8StringEncoding error:&error]];
        if (error) {
            NSLog(@"%@", error);
        }
    } else {
        [body appendFormat:@"Content-Disposition:form-data; name=\"%@\"\r\n\r\n", param[@"name"]];
        [body appendFormat:@"%@", param[@"value"]];
    }
}
[body appendFormat:@"\r\n--%@--\r\n", boundary];
NSData *postData = [body dataUsingEncoding:NSUTF8StringEncoding];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/api/v1/documents/:id4n/:organizationId"]
                                                       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}}/api/v1/documents/:id4n/:organizationId" in
let headers = Header.add_list (Header.init ()) [
  ("authorization", "{{apiKey}}");
  ("content-type", "multipart/form-data; boundary=---011000010111000001101001");
] in
let body = Cohttp_lwt_body.of_string "-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"content\"\r\n\r\n\r\n-----011000010111000001101001--\r\n" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/api/v1/documents/:id4n/:organizationId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => "-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"content\"\r\n\r\n\r\n-----011000010111000001101001--\r\n",
  CURLOPT_HTTPHEADER => [
    "authorization: {{apiKey}}",
    "content-type: multipart/form-data; boundary=---011000010111000001101001"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/api/v1/documents/:id4n/:organizationId', [
  'headers' => [
    'authorization' => '{{apiKey}}',
    'content-type' => 'multipart/form-data; boundary=---011000010111000001101001',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/api/v1/documents/:id4n/:organizationId');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'authorization' => '{{apiKey}}',
  'content-type' => 'multipart/form-data; boundary=---011000010111000001101001'
]);

$request->setBody('-----011000010111000001101001
Content-Disposition: form-data; name="content"


-----011000010111000001101001--
');

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
addForm(null, null);

$request->setRequestUrl('{{baseUrl}}/api/v1/documents/:id4n/:organizationId');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'authorization' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$headers.Add("content-type", "multipart/form-data; boundary=---011000010111000001101001")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/api/v1/documents/:id4n/:organizationId' -Method POST -Headers $headers -ContentType 'multipart/form-data; boundary=---011000010111000001101001' -Body '-----011000010111000001101001
Content-Disposition: form-data; name="content"


-----011000010111000001101001--
'
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$headers.Add("content-type", "multipart/form-data; boundary=---011000010111000001101001")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/api/v1/documents/:id4n/:organizationId' -Method POST -Headers $headers -ContentType 'multipart/form-data; boundary=---011000010111000001101001' -Body '-----011000010111000001101001
Content-Disposition: form-data; name="content"


-----011000010111000001101001--
'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"content\"\r\n\r\n\r\n-----011000010111000001101001--\r\n"

headers = {
    'authorization': "{{apiKey}}",
    'content-type': "multipart/form-data; boundary=---011000010111000001101001"
}

conn.request("POST", "/baseUrl/api/v1/documents/:id4n/:organizationId", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/api/v1/documents/:id4n/:organizationId"

payload = "-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"content\"\r\n\r\n\r\n-----011000010111000001101001--\r\n"
headers = {
    "authorization": "{{apiKey}}",
    "content-type": "multipart/form-data; boundary=---011000010111000001101001"
}

response = requests.post(url, data=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/api/v1/documents/:id4n/:organizationId"

payload <- "-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"content\"\r\n\r\n\r\n-----011000010111000001101001--\r\n"

encode <- "multipart"

response <- VERB("POST", url, body = payload, add_headers('authorization' = '{{apiKey}}'), content_type("multipart/form-data"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/api/v1/documents/:id4n/:organizationId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["authorization"] = '{{apiKey}}'
request["content-type"] = 'multipart/form-data; boundary=---011000010111000001101001'
request.body = "-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"content\"\r\n\r\n\r\n-----011000010111000001101001--\r\n"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'multipart/form-data; boundary=---011000010111000001101001'}
)

response = conn.post('/baseUrl/api/v1/documents/:id4n/:organizationId') do |req|
  req.headers['authorization'] = '{{apiKey}}'
  req.body = "-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"content\"\r\n\r\n\r\n-----011000010111000001101001--\r\n"
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/api/v1/documents/:id4n/:organizationId";

    let form = reqwest::multipart::Form::new()
        .text("content", "");
    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("authorization", "{{apiKey}}".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .multipart(form)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/api/v1/documents/:id4n/:organizationId \
  --header 'authorization: {{apiKey}}' \
  --header 'content-type: multipart/form-data' \
  --form content=
echo '-----011000010111000001101001
Content-Disposition: form-data; name="content"


-----011000010111000001101001--
' |  \
  http POST {{baseUrl}}/api/v1/documents/:id4n/:organizationId \
  authorization:'{{apiKey}}' \
  content-type:'multipart/form-data; boundary=---011000010111000001101001'
wget --quiet \
  --method POST \
  --header 'authorization: {{apiKey}}' \
  --header 'content-type: multipart/form-data; boundary=---011000010111000001101001' \
  --body-data '-----011000010111000001101001\r\nContent-Disposition: form-data; name="content"\r\n\r\n\r\n-----011000010111000001101001--\r\n' \
  --output-document \
  - {{baseUrl}}/api/v1/documents/:id4n/:organizationId
import Foundation

let headers = [
  "authorization": "{{apiKey}}",
  "content-type": "multipart/form-data; boundary=---011000010111000001101001"
]
let parameters = [
  [
    "name": "content",
    "value": ""
  ]
]

let boundary = "---011000010111000001101001"

var body = ""
var error: NSError? = nil
for param in parameters {
  let paramName = param["name"]!
  body += "--\(boundary)\r\n"
  body += "Content-Disposition:form-data; name=\"\(paramName)\""
  if let filename = param["fileName"] {
    let contentType = param["content-type"]!
    let fileContent = String(contentsOfFile: filename, encoding: String.Encoding.utf8)
    if (error != nil) {
      print(error as Any)
    }
    body += "; filename=\"\(filename)\"\r\n"
    body += "Content-Type: \(contentType)\r\n\r\n"
    body += fileContent
  } else if let paramValue = param["value"] {
    body += "\r\n\r\n\(paramValue)"
  }
}

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/api/v1/documents/:id4n/:organizationId")! 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()
RESPONSE HEADERS

Content-Type
application/json
RESPONSE BODY json

{
  "filename": "publicInfo.pdf",
  "mimeType": "text/plain",
  "ownerOrganizationId": "de.bluerain",
  "visibility": {
    "public": true,
    "sharedOrganizationIds": [
      "de.acme",
      "com.porsche",
      "de.bluerain"
    ]
  }
}
RESPONSE HEADERS

Content-Type
application/xml
RESPONSE BODY xml

{
  "filename": "publicInfo.pdf",
  "mimeType": "text/plain",
  "ownerOrganizationId": "de.bluerain",
  "visibility": {
    "public": true,
    "sharedOrganizationIds": [
      "de.acme",
      "com.porsche",
      "de.bluerain"
    ]
  }
}
DELETE Delete a document
{{baseUrl}}/api/v1/documents/:id4n/:organizationId/:fileName
HEADERS

Authorization
{{apiKey}}
QUERY PARAMS

organizationId
id4n
fileName
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/api/v1/documents/:id4n/:organizationId/:fileName");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "authorization: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/api/v1/documents/:id4n/:organizationId/:fileName" {:headers {:authorization "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/api/v1/documents/:id4n/:organizationId/:fileName"
headers = HTTP::Headers{
  "authorization" => "{{apiKey}}"
}

response = HTTP::Client.delete url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Delete,
    RequestUri = new Uri("{{baseUrl}}/api/v1/documents/:id4n/:organizationId/:fileName"),
    Headers =
    {
        { "authorization", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/api/v1/documents/:id4n/:organizationId/:fileName");
var request = new RestRequest("", Method.Delete);
request.AddHeader("authorization", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/api/v1/documents/:id4n/:organizationId/:fileName"

	req, _ := http.NewRequest("DELETE", url, nil)

	req.Header.Add("authorization", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/api/v1/documents/:id4n/:organizationId/:fileName HTTP/1.1
Authorization: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/api/v1/documents/:id4n/:organizationId/:fileName")
  .setHeader("authorization", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/api/v1/documents/:id4n/:organizationId/:fileName"))
    .header("authorization", "{{apiKey}}")
    .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}}/api/v1/documents/:id4n/:organizationId/:fileName")
  .delete(null)
  .addHeader("authorization", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/api/v1/documents/:id4n/:organizationId/:fileName")
  .header("authorization", "{{apiKey}}")
  .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}}/api/v1/documents/:id4n/:organizationId/:fileName');
xhr.setRequestHeader('authorization', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/api/v1/documents/:id4n/:organizationId/:fileName',
  headers: {authorization: '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/api/v1/documents/:id4n/:organizationId/:fileName';
const options = {method: 'DELETE', headers: {authorization: '{{apiKey}}'}};

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}}/api/v1/documents/:id4n/:organizationId/:fileName',
  method: 'DELETE',
  headers: {
    authorization: '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/api/v1/documents/:id4n/:organizationId/:fileName")
  .delete(null)
  .addHeader("authorization", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/api/v1/documents/:id4n/:organizationId/:fileName',
  headers: {
    authorization: '{{apiKey}}'
  }
};

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}}/api/v1/documents/:id4n/:organizationId/:fileName',
  headers: {authorization: '{{apiKey}}'}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('DELETE', '{{baseUrl}}/api/v1/documents/:id4n/:organizationId/:fileName');

req.headers({
  authorization: '{{apiKey}}'
});

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}}/api/v1/documents/:id4n/:organizationId/:fileName',
  headers: {authorization: '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/api/v1/documents/:id4n/:organizationId/:fileName';
const options = {method: 'DELETE', headers: {authorization: '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"authorization": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/api/v1/documents/:id4n/:organizationId/:fileName"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"DELETE"];
[request setAllHTTPHeaderFields:headers];

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}}/api/v1/documents/:id4n/:organizationId/:fileName" in
let headers = Header.add (Header.init ()) "authorization" "{{apiKey}}" in

Client.call ~headers `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/api/v1/documents/:id4n/:organizationId/:fileName",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
  CURLOPT_HTTPHEADER => [
    "authorization: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/api/v1/documents/:id4n/:organizationId/:fileName', [
  'headers' => [
    'authorization' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/api/v1/documents/:id4n/:organizationId/:fileName');
$request->setMethod(HTTP_METH_DELETE);

$request->setHeaders([
  'authorization' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/api/v1/documents/:id4n/:organizationId/:fileName');
$request->setRequestMethod('DELETE');
$request->setHeaders([
  'authorization' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/api/v1/documents/:id4n/:organizationId/:fileName' -Method DELETE -Headers $headers
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/api/v1/documents/:id4n/:organizationId/:fileName' -Method DELETE -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'authorization': "{{apiKey}}" }

conn.request("DELETE", "/baseUrl/api/v1/documents/:id4n/:organizationId/:fileName", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/api/v1/documents/:id4n/:organizationId/:fileName"

headers = {"authorization": "{{apiKey}}"}

response = requests.delete(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/api/v1/documents/:id4n/:organizationId/:fileName"

response <- VERB("DELETE", url, add_headers('authorization' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/api/v1/documents/:id4n/:organizationId/:fileName")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)
request["authorization"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/api/v1/documents/:id4n/:organizationId/:fileName') do |req|
  req.headers['authorization'] = '{{apiKey}}'
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/api/v1/documents/:id4n/:organizationId/:fileName";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("authorization", "{{apiKey}}".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("DELETE").unwrap(), url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request DELETE \
  --url {{baseUrl}}/api/v1/documents/:id4n/:organizationId/:fileName \
  --header 'authorization: {{apiKey}}'
http DELETE {{baseUrl}}/api/v1/documents/:id4n/:organizationId/:fileName \
  authorization:'{{apiKey}}'
wget --quiet \
  --method DELETE \
  --header 'authorization: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/api/v1/documents/:id4n/:organizationId/:fileName
import Foundation

let headers = ["authorization": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/api/v1/documents/:id4n/:organizationId/:fileName")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "DELETE"
request.allHTTPHeaderFields = headers

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 List documents
{{baseUrl}}/api/v1/documents/:id4n
HEADERS

Authorization
{{apiKey}}
QUERY PARAMS

id4n
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/api/v1/documents/:id4n");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "authorization: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/api/v1/documents/:id4n" {:headers {:authorization "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/api/v1/documents/:id4n"
headers = HTTP::Headers{
  "authorization" => "{{apiKey}}"
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/api/v1/documents/:id4n"),
    Headers =
    {
        { "authorization", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/api/v1/documents/:id4n");
var request = new RestRequest("", Method.Get);
request.AddHeader("authorization", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/api/v1/documents/:id4n"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("authorization", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/api/v1/documents/:id4n HTTP/1.1
Authorization: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/api/v1/documents/:id4n")
  .setHeader("authorization", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/api/v1/documents/:id4n"))
    .header("authorization", "{{apiKey}}")
    .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}}/api/v1/documents/:id4n")
  .get()
  .addHeader("authorization", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/api/v1/documents/:id4n")
  .header("authorization", "{{apiKey}}")
  .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}}/api/v1/documents/:id4n');
xhr.setRequestHeader('authorization', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/api/v1/documents/:id4n',
  headers: {authorization: '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/api/v1/documents/:id4n';
const options = {method: 'GET', headers: {authorization: '{{apiKey}}'}};

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}}/api/v1/documents/:id4n',
  method: 'GET',
  headers: {
    authorization: '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/api/v1/documents/:id4n")
  .get()
  .addHeader("authorization", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/api/v1/documents/:id4n',
  headers: {
    authorization: '{{apiKey}}'
  }
};

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}}/api/v1/documents/:id4n',
  headers: {authorization: '{{apiKey}}'}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/api/v1/documents/:id4n');

req.headers({
  authorization: '{{apiKey}}'
});

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}}/api/v1/documents/:id4n',
  headers: {authorization: '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/api/v1/documents/:id4n';
const options = {method: 'GET', headers: {authorization: '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"authorization": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/api/v1/documents/:id4n"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

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}}/api/v1/documents/:id4n" in
let headers = Header.add (Header.init ()) "authorization" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/api/v1/documents/:id4n",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "authorization: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/api/v1/documents/:id4n', [
  'headers' => [
    'authorization' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/api/v1/documents/:id4n');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'authorization' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/api/v1/documents/:id4n');
$request->setRequestMethod('GET');
$request->setHeaders([
  'authorization' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/api/v1/documents/:id4n' -Method GET -Headers $headers
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/api/v1/documents/:id4n' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'authorization': "{{apiKey}}" }

conn.request("GET", "/baseUrl/api/v1/documents/:id4n", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/api/v1/documents/:id4n"

headers = {"authorization": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/api/v1/documents/:id4n"

response <- VERB("GET", url, add_headers('authorization' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/api/v1/documents/:id4n")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["authorization"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/api/v1/documents/:id4n') do |req|
  req.headers['authorization'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/api/v1/documents/:id4n";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("authorization", "{{apiKey}}".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/api/v1/documents/:id4n \
  --header 'authorization: {{apiKey}}'
http GET {{baseUrl}}/api/v1/documents/:id4n \
  authorization:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'authorization: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/api/v1/documents/:id4n
import Foundation

let headers = ["authorization": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/api/v1/documents/:id4n")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

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()
RESPONSE HEADERS

Content-Type
application/json
RESPONSE BODY json

{
  "limit": 100,
  "offset": 0,
  "total": 200
}
RESPONSE HEADERS

Content-Type
application/xml
RESPONSE BODY xml

{
  "limit": 100,
  "offset": 0,
  "total": 200
}
GET List organization specific documents
{{baseUrl}}/api/v1/documents/:id4n/:organizationId
HEADERS

Authorization
{{apiKey}}
QUERY PARAMS

organizationId
id4n
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/api/v1/documents/:id4n/:organizationId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "authorization: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/api/v1/documents/:id4n/:organizationId" {:headers {:authorization "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/api/v1/documents/:id4n/:organizationId"
headers = HTTP::Headers{
  "authorization" => "{{apiKey}}"
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/api/v1/documents/:id4n/:organizationId"),
    Headers =
    {
        { "authorization", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/api/v1/documents/:id4n/:organizationId");
var request = new RestRequest("", Method.Get);
request.AddHeader("authorization", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/api/v1/documents/:id4n/:organizationId"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("authorization", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/api/v1/documents/:id4n/:organizationId HTTP/1.1
Authorization: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/api/v1/documents/:id4n/:organizationId")
  .setHeader("authorization", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/api/v1/documents/:id4n/:organizationId"))
    .header("authorization", "{{apiKey}}")
    .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}}/api/v1/documents/:id4n/:organizationId")
  .get()
  .addHeader("authorization", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/api/v1/documents/:id4n/:organizationId")
  .header("authorization", "{{apiKey}}")
  .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}}/api/v1/documents/:id4n/:organizationId');
xhr.setRequestHeader('authorization', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/api/v1/documents/:id4n/:organizationId',
  headers: {authorization: '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/api/v1/documents/:id4n/:organizationId';
const options = {method: 'GET', headers: {authorization: '{{apiKey}}'}};

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}}/api/v1/documents/:id4n/:organizationId',
  method: 'GET',
  headers: {
    authorization: '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/api/v1/documents/:id4n/:organizationId")
  .get()
  .addHeader("authorization", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/api/v1/documents/:id4n/:organizationId',
  headers: {
    authorization: '{{apiKey}}'
  }
};

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}}/api/v1/documents/:id4n/:organizationId',
  headers: {authorization: '{{apiKey}}'}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/api/v1/documents/:id4n/:organizationId');

req.headers({
  authorization: '{{apiKey}}'
});

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}}/api/v1/documents/:id4n/:organizationId',
  headers: {authorization: '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/api/v1/documents/:id4n/:organizationId';
const options = {method: 'GET', headers: {authorization: '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"authorization": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/api/v1/documents/:id4n/:organizationId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

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}}/api/v1/documents/:id4n/:organizationId" in
let headers = Header.add (Header.init ()) "authorization" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/api/v1/documents/:id4n/:organizationId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "authorization: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/api/v1/documents/:id4n/:organizationId', [
  'headers' => [
    'authorization' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/api/v1/documents/:id4n/:organizationId');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'authorization' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/api/v1/documents/:id4n/:organizationId');
$request->setRequestMethod('GET');
$request->setHeaders([
  'authorization' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/api/v1/documents/:id4n/:organizationId' -Method GET -Headers $headers
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/api/v1/documents/:id4n/:organizationId' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'authorization': "{{apiKey}}" }

conn.request("GET", "/baseUrl/api/v1/documents/:id4n/:organizationId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/api/v1/documents/:id4n/:organizationId"

headers = {"authorization": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/api/v1/documents/:id4n/:organizationId"

response <- VERB("GET", url, add_headers('authorization' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/api/v1/documents/:id4n/:organizationId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["authorization"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/api/v1/documents/:id4n/:organizationId') do |req|
  req.headers['authorization'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/api/v1/documents/:id4n/:organizationId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("authorization", "{{apiKey}}".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/api/v1/documents/:id4n/:organizationId \
  --header 'authorization: {{apiKey}}'
http GET {{baseUrl}}/api/v1/documents/:id4n/:organizationId \
  authorization:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'authorization: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/api/v1/documents/:id4n/:organizationId
import Foundation

let headers = ["authorization": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/api/v1/documents/:id4n/:organizationId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

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()
RESPONSE HEADERS

Content-Type
application/json
RESPONSE BODY json

{
  "limit": 100,
  "offset": 0,
  "total": 200
}
RESPONSE HEADERS

Content-Type
application/xml
RESPONSE BODY xml

{
  "limit": 100,
  "offset": 0,
  "total": 200
}
PUT Put an document for an id4n
{{baseUrl}}/api/v1/documents/:id4n/:organizationId
HEADERS

Authorization
{{apiKey}}
QUERY PARAMS

organizationId
id4n
BODY multipartForm

Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/api/v1/documents/:id4n/:organizationId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "authorization: {{apiKey}}");
headers = curl_slist_append(headers, "content-type: multipart/form-data; boundary=---011000010111000001101001");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"content\"\r\n\r\n\r\n-----011000010111000001101001--\r\n");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/api/v1/documents/:id4n/:organizationId" {:headers {:authorization "{{apiKey}}"}
                                                                                  :multipart [{:name "content"
                                                                                               :content ""}]})
require "http/client"

url = "{{baseUrl}}/api/v1/documents/:id4n/:organizationId"
headers = HTTP::Headers{
  "authorization" => "{{apiKey}}"
  "content-type" => "multipart/form-data; boundary=---011000010111000001101001"
}
reqBody = "-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"content\"\r\n\r\n\r\n-----011000010111000001101001--\r\n"

response = HTTP::Client.put url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Put,
    RequestUri = new Uri("{{baseUrl}}/api/v1/documents/:id4n/:organizationId"),
    Headers =
    {
        { "authorization", "{{apiKey}}" },
    },
    Content = new MultipartFormDataContent
    {
        new StringContent("")
        {
            Headers =
            {
                ContentDisposition = new ContentDispositionHeaderValue("form-data")
                {
                    Name = "content",
                }
            }
        },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/api/v1/documents/:id4n/:organizationId");
var request = new RestRequest("", Method.Put);
request.AddHeader("authorization", "{{apiKey}}");
request.AddHeader("content-type", "multipart/form-data; boundary=---011000010111000001101001");
request.AddParameter("multipart/form-data; boundary=---011000010111000001101001", "-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"content\"\r\n\r\n\r\n-----011000010111000001101001--\r\n", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/api/v1/documents/:id4n/:organizationId"

	payload := strings.NewReader("-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"content\"\r\n\r\n\r\n-----011000010111000001101001--\r\n")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("authorization", "{{apiKey}}")
	req.Header.Add("content-type", "multipart/form-data; boundary=---011000010111000001101001")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/api/v1/documents/:id4n/:organizationId HTTP/1.1
Authorization: {{apiKey}}
Content-Type: multipart/form-data; boundary=---011000010111000001101001
Host: example.com
Content-Length: 116

-----011000010111000001101001
Content-Disposition: form-data; name="content"


-----011000010111000001101001--
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/api/v1/documents/:id4n/:organizationId")
  .setHeader("authorization", "{{apiKey}}")
  .setHeader("content-type", "multipart/form-data; boundary=---011000010111000001101001")
  .setBody("-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"content\"\r\n\r\n\r\n-----011000010111000001101001--\r\n")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/api/v1/documents/:id4n/:organizationId"))
    .header("authorization", "{{apiKey}}")
    .header("content-type", "multipart/form-data; boundary=---011000010111000001101001")
    .method("PUT", HttpRequest.BodyPublishers.ofString("-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"content\"\r\n\r\n\r\n-----011000010111000001101001--\r\n"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("multipart/form-data; boundary=---011000010111000001101001");
RequestBody body = RequestBody.create(mediaType, "-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"content\"\r\n\r\n\r\n-----011000010111000001101001--\r\n");
Request request = new Request.Builder()
  .url("{{baseUrl}}/api/v1/documents/:id4n/:organizationId")
  .put(body)
  .addHeader("authorization", "{{apiKey}}")
  .addHeader("content-type", "multipart/form-data; boundary=---011000010111000001101001")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/api/v1/documents/:id4n/:organizationId")
  .header("authorization", "{{apiKey}}")
  .header("content-type", "multipart/form-data; boundary=---011000010111000001101001")
  .body("-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"content\"\r\n\r\n\r\n-----011000010111000001101001--\r\n")
  .asString();
const data = new FormData();
data.append('content', '');

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/api/v1/documents/:id4n/:organizationId');
xhr.setRequestHeader('authorization', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const form = new FormData();
form.append('content', '');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/api/v1/documents/:id4n/:organizationId',
  headers: {
    authorization: '{{apiKey}}',
    'content-type': 'multipart/form-data; boundary=---011000010111000001101001'
  },
  data: '[form]'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/api/v1/documents/:id4n/:organizationId';
const form = new FormData();
form.append('content', '');

const options = {method: 'PUT', headers: {authorization: '{{apiKey}}'}};

options.body = form;

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const form = new FormData();
form.append('content', '');

const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/api/v1/documents/:id4n/:organizationId',
  method: 'PUT',
  headers: {
    authorization: '{{apiKey}}'
  },
  processData: false,
  contentType: false,
  mimeType: 'multipart/form-data',
  data: form
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("multipart/form-data; boundary=---011000010111000001101001")
val body = RequestBody.create(mediaType, "-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"content\"\r\n\r\n\r\n-----011000010111000001101001--\r\n")
val request = Request.Builder()
  .url("{{baseUrl}}/api/v1/documents/:id4n/:organizationId")
  .put(body)
  .addHeader("authorization", "{{apiKey}}")
  .addHeader("content-type", "multipart/form-data; boundary=---011000010111000001101001")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/api/v1/documents/:id4n/:organizationId',
  headers: {
    authorization: '{{apiKey}}',
    'content-type': 'multipart/form-data; boundary=---011000010111000001101001'
  }
};

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('-----011000010111000001101001\r\nContent-Disposition: form-data; name="content"\r\n\r\n\r\n-----011000010111000001101001--\r\n');
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/api/v1/documents/:id4n/:organizationId',
  headers: {
    authorization: '{{apiKey}}',
    'content-type': 'multipart/form-data; boundary=---011000010111000001101001'
  },
  formData: {content: ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('PUT', '{{baseUrl}}/api/v1/documents/:id4n/:organizationId');

req.headers({
  authorization: '{{apiKey}}',
  'content-type': 'multipart/form-data; boundary=---011000010111000001101001'
});

req.multipart([]);

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/api/v1/documents/:id4n/:organizationId',
  headers: {
    authorization: '{{apiKey}}',
    'content-type': 'multipart/form-data; boundary=---011000010111000001101001'
  },
  data: '-----011000010111000001101001\r\nContent-Disposition: form-data; name="content"\r\n\r\n\r\n-----011000010111000001101001--\r\n'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const FormData = require('form-data');
const fetch = require('node-fetch');

const formData = new FormData();
formData.append('content', '');

const url = '{{baseUrl}}/api/v1/documents/:id4n/:organizationId';
const options = {method: 'PUT', headers: {authorization: '{{apiKey}}'}};
options.body = formData;

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"authorization": @"{{apiKey}}",
                           @"content-type": @"multipart/form-data; boundary=---011000010111000001101001" };
NSArray *parameters = @[ @{ @"name": @"content", @"value": @"" } ];
NSString *boundary = @"---011000010111000001101001";

NSError *error;
NSMutableString *body = [NSMutableString string];
for (NSDictionary *param in parameters) {
    [body appendFormat:@"--%@\r\n", boundary];
    if (param[@"fileName"]) {
        [body appendFormat:@"Content-Disposition:form-data; name=\"%@\"; filename=\"%@\"\r\n", param[@"name"], param[@"fileName"]];
        [body appendFormat:@"Content-Type: %@\r\n\r\n", param[@"contentType"]];
        [body appendFormat:@"%@", [NSString stringWithContentsOfFile:param[@"fileName"] encoding:NSUTF8StringEncoding error:&error]];
        if (error) {
            NSLog(@"%@", error);
        }
    } else {
        [body appendFormat:@"Content-Disposition:form-data; name=\"%@\"\r\n\r\n", param[@"name"]];
        [body appendFormat:@"%@", param[@"value"]];
    }
}
[body appendFormat:@"\r\n--%@--\r\n", boundary];
NSData *postData = [body dataUsingEncoding:NSUTF8StringEncoding];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/api/v1/documents/:id4n/:organizationId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"PUT"];
[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}}/api/v1/documents/:id4n/:organizationId" in
let headers = Header.add_list (Header.init ()) [
  ("authorization", "{{apiKey}}");
  ("content-type", "multipart/form-data; boundary=---011000010111000001101001");
] in
let body = Cohttp_lwt_body.of_string "-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"content\"\r\n\r\n\r\n-----011000010111000001101001--\r\n" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/api/v1/documents/:id4n/:organizationId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
  CURLOPT_POSTFIELDS => "-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"content\"\r\n\r\n\r\n-----011000010111000001101001--\r\n",
  CURLOPT_HTTPHEADER => [
    "authorization: {{apiKey}}",
    "content-type: multipart/form-data; boundary=---011000010111000001101001"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/api/v1/documents/:id4n/:organizationId', [
  'headers' => [
    'authorization' => '{{apiKey}}',
    'content-type' => 'multipart/form-data; boundary=---011000010111000001101001',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/api/v1/documents/:id4n/:organizationId');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'authorization' => '{{apiKey}}',
  'content-type' => 'multipart/form-data; boundary=---011000010111000001101001'
]);

$request->setBody('-----011000010111000001101001
Content-Disposition: form-data; name="content"


-----011000010111000001101001--
');

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
addForm(null, null);

$request->setRequestUrl('{{baseUrl}}/api/v1/documents/:id4n/:organizationId');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'authorization' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$headers.Add("content-type", "multipart/form-data; boundary=---011000010111000001101001")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/api/v1/documents/:id4n/:organizationId' -Method PUT -Headers $headers -ContentType 'multipart/form-data; boundary=---011000010111000001101001' -Body '-----011000010111000001101001
Content-Disposition: form-data; name="content"


-----011000010111000001101001--
'
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$headers.Add("content-type", "multipart/form-data; boundary=---011000010111000001101001")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/api/v1/documents/:id4n/:organizationId' -Method PUT -Headers $headers -ContentType 'multipart/form-data; boundary=---011000010111000001101001' -Body '-----011000010111000001101001
Content-Disposition: form-data; name="content"


-----011000010111000001101001--
'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"content\"\r\n\r\n\r\n-----011000010111000001101001--\r\n"

headers = {
    'authorization': "{{apiKey}}",
    'content-type': "multipart/form-data; boundary=---011000010111000001101001"
}

conn.request("PUT", "/baseUrl/api/v1/documents/:id4n/:organizationId", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/api/v1/documents/:id4n/:organizationId"

payload = "-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"content\"\r\n\r\n\r\n-----011000010111000001101001--\r\n"
headers = {
    "authorization": "{{apiKey}}",
    "content-type": "multipart/form-data; boundary=---011000010111000001101001"
}

response = requests.put(url, data=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/api/v1/documents/:id4n/:organizationId"

payload <- "-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"content\"\r\n\r\n\r\n-----011000010111000001101001--\r\n"

encode <- "multipart"

response <- VERB("PUT", url, body = payload, add_headers('authorization' = '{{apiKey}}'), content_type("multipart/form-data"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/api/v1/documents/:id4n/:organizationId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["authorization"] = '{{apiKey}}'
request["content-type"] = 'multipart/form-data; boundary=---011000010111000001101001'
request.body = "-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"content\"\r\n\r\n\r\n-----011000010111000001101001--\r\n"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'multipart/form-data; boundary=---011000010111000001101001'}
)

response = conn.put('/baseUrl/api/v1/documents/:id4n/:organizationId') do |req|
  req.headers['authorization'] = '{{apiKey}}'
  req.body = "-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"content\"\r\n\r\n\r\n-----011000010111000001101001--\r\n"
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/api/v1/documents/:id4n/:organizationId";

    let form = reqwest::multipart::Form::new()
        .text("content", "");
    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("authorization", "{{apiKey}}".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .multipart(form)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/api/v1/documents/:id4n/:organizationId \
  --header 'authorization: {{apiKey}}' \
  --header 'content-type: multipart/form-data' \
  --form content=
echo '-----011000010111000001101001
Content-Disposition: form-data; name="content"


-----011000010111000001101001--
' |  \
  http PUT {{baseUrl}}/api/v1/documents/:id4n/:organizationId \
  authorization:'{{apiKey}}' \
  content-type:'multipart/form-data; boundary=---011000010111000001101001'
wget --quiet \
  --method PUT \
  --header 'authorization: {{apiKey}}' \
  --header 'content-type: multipart/form-data; boundary=---011000010111000001101001' \
  --body-data '-----011000010111000001101001\r\nContent-Disposition: form-data; name="content"\r\n\r\n\r\n-----011000010111000001101001--\r\n' \
  --output-document \
  - {{baseUrl}}/api/v1/documents/:id4n/:organizationId
import Foundation

let headers = [
  "authorization": "{{apiKey}}",
  "content-type": "multipart/form-data; boundary=---011000010111000001101001"
]
let parameters = [
  [
    "name": "content",
    "value": ""
  ]
]

let boundary = "---011000010111000001101001"

var body = ""
var error: NSError? = nil
for param in parameters {
  let paramName = param["name"]!
  body += "--\(boundary)\r\n"
  body += "Content-Disposition:form-data; name=\"\(paramName)\""
  if let filename = param["fileName"] {
    let contentType = param["content-type"]!
    let fileContent = String(contentsOfFile: filename, encoding: String.Encoding.utf8)
    if (error != nil) {
      print(error as Any)
    }
    body += "; filename=\"\(filename)\"\r\n"
    body += "Content-Type: \(contentType)\r\n\r\n"
    body += fileContent
  } else if let paramValue = param["value"] {
    body += "\r\n\r\n\(paramValue)"
  }
}

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/api/v1/documents/:id4n/:organizationId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "PUT"
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()
RESPONSE HEADERS

Content-Type
application/json
RESPONSE BODY json

{
  "filename": "publicInfo.pdf",
  "mimeType": "text/plain",
  "ownerOrganizationId": "de.bluerain",
  "visibility": {
    "public": true,
    "sharedOrganizationIds": [
      "de.acme",
      "com.porsche",
      "de.bluerain"
    ]
  }
}
RESPONSE HEADERS

Content-Type
application/xml
RESPONSE BODY xml

{
  "filename": "publicInfo.pdf",
  "mimeType": "text/plain",
  "ownerOrganizationId": "de.bluerain",
  "visibility": {
    "public": true,
    "sharedOrganizationIds": [
      "de.acme",
      "com.porsche",
      "de.bluerain"
    ]
  }
}
GET Read data from microstorage
{{baseUrl}}/api/v1/microstorage/:id4n/:organization
HEADERS

Authorization
{{apiKey}}
QUERY PARAMS

organization
id4n
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/api/v1/microstorage/:id4n/:organization");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "authorization: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/api/v1/microstorage/:id4n/:organization" {:headers {:authorization "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/api/v1/microstorage/:id4n/:organization"
headers = HTTP::Headers{
  "authorization" => "{{apiKey}}"
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/api/v1/microstorage/:id4n/:organization"),
    Headers =
    {
        { "authorization", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/api/v1/microstorage/:id4n/:organization");
var request = new RestRequest("", Method.Get);
request.AddHeader("authorization", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/api/v1/microstorage/:id4n/:organization"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("authorization", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/api/v1/microstorage/:id4n/:organization HTTP/1.1
Authorization: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/api/v1/microstorage/:id4n/:organization")
  .setHeader("authorization", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/api/v1/microstorage/:id4n/:organization"))
    .header("authorization", "{{apiKey}}")
    .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}}/api/v1/microstorage/:id4n/:organization")
  .get()
  .addHeader("authorization", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/api/v1/microstorage/:id4n/:organization")
  .header("authorization", "{{apiKey}}")
  .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}}/api/v1/microstorage/:id4n/:organization');
xhr.setRequestHeader('authorization', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/api/v1/microstorage/:id4n/:organization',
  headers: {authorization: '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/api/v1/microstorage/:id4n/:organization';
const options = {method: 'GET', headers: {authorization: '{{apiKey}}'}};

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}}/api/v1/microstorage/:id4n/:organization',
  method: 'GET',
  headers: {
    authorization: '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/api/v1/microstorage/:id4n/:organization")
  .get()
  .addHeader("authorization", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/api/v1/microstorage/:id4n/:organization',
  headers: {
    authorization: '{{apiKey}}'
  }
};

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}}/api/v1/microstorage/:id4n/:organization',
  headers: {authorization: '{{apiKey}}'}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/api/v1/microstorage/:id4n/:organization');

req.headers({
  authorization: '{{apiKey}}'
});

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}}/api/v1/microstorage/:id4n/:organization',
  headers: {authorization: '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/api/v1/microstorage/:id4n/:organization';
const options = {method: 'GET', headers: {authorization: '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"authorization": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/api/v1/microstorage/:id4n/:organization"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

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}}/api/v1/microstorage/:id4n/:organization" in
let headers = Header.add (Header.init ()) "authorization" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/api/v1/microstorage/:id4n/:organization",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "authorization: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/api/v1/microstorage/:id4n/:organization', [
  'headers' => [
    'authorization' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/api/v1/microstorage/:id4n/:organization');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'authorization' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/api/v1/microstorage/:id4n/:organization');
$request->setRequestMethod('GET');
$request->setHeaders([
  'authorization' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/api/v1/microstorage/:id4n/:organization' -Method GET -Headers $headers
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/api/v1/microstorage/:id4n/:organization' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'authorization': "{{apiKey}}" }

conn.request("GET", "/baseUrl/api/v1/microstorage/:id4n/:organization", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/api/v1/microstorage/:id4n/:organization"

headers = {"authorization": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/api/v1/microstorage/:id4n/:organization"

response <- VERB("GET", url, add_headers('authorization' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/api/v1/microstorage/:id4n/:organization")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["authorization"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/api/v1/microstorage/:id4n/:organization') do |req|
  req.headers['authorization'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/api/v1/microstorage/:id4n/:organization";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("authorization", "{{apiKey}}".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/api/v1/microstorage/:id4n/:organization \
  --header 'authorization: {{apiKey}}'
http GET {{baseUrl}}/api/v1/microstorage/:id4n/:organization \
  authorization:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'authorization: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/api/v1/microstorage/:id4n/:organization
import Foundation

let headers = ["authorization": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/api/v1/microstorage/:id4n/:organization")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

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 Read document contents
{{baseUrl}}/api/v1/documents/:id4n/:organizationId/:fileName
HEADERS

Authorization
{{apiKey}}
QUERY PARAMS

organizationId
id4n
fileName
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/api/v1/documents/:id4n/:organizationId/:fileName");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "authorization: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/api/v1/documents/:id4n/:organizationId/:fileName" {:headers {:authorization "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/api/v1/documents/:id4n/:organizationId/:fileName"
headers = HTTP::Headers{
  "authorization" => "{{apiKey}}"
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/api/v1/documents/:id4n/:organizationId/:fileName"),
    Headers =
    {
        { "authorization", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/api/v1/documents/:id4n/:organizationId/:fileName");
var request = new RestRequest("", Method.Get);
request.AddHeader("authorization", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/api/v1/documents/:id4n/:organizationId/:fileName"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("authorization", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/api/v1/documents/:id4n/:organizationId/:fileName HTTP/1.1
Authorization: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/api/v1/documents/:id4n/:organizationId/:fileName")
  .setHeader("authorization", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/api/v1/documents/:id4n/:organizationId/:fileName"))
    .header("authorization", "{{apiKey}}")
    .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}}/api/v1/documents/:id4n/:organizationId/:fileName")
  .get()
  .addHeader("authorization", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/api/v1/documents/:id4n/:organizationId/:fileName")
  .header("authorization", "{{apiKey}}")
  .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}}/api/v1/documents/:id4n/:organizationId/:fileName');
xhr.setRequestHeader('authorization', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/api/v1/documents/:id4n/:organizationId/:fileName',
  headers: {authorization: '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/api/v1/documents/:id4n/:organizationId/:fileName';
const options = {method: 'GET', headers: {authorization: '{{apiKey}}'}};

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}}/api/v1/documents/:id4n/:organizationId/:fileName',
  method: 'GET',
  headers: {
    authorization: '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/api/v1/documents/:id4n/:organizationId/:fileName")
  .get()
  .addHeader("authorization", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/api/v1/documents/:id4n/:organizationId/:fileName',
  headers: {
    authorization: '{{apiKey}}'
  }
};

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}}/api/v1/documents/:id4n/:organizationId/:fileName',
  headers: {authorization: '{{apiKey}}'}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/api/v1/documents/:id4n/:organizationId/:fileName');

req.headers({
  authorization: '{{apiKey}}'
});

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}}/api/v1/documents/:id4n/:organizationId/:fileName',
  headers: {authorization: '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/api/v1/documents/:id4n/:organizationId/:fileName';
const options = {method: 'GET', headers: {authorization: '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"authorization": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/api/v1/documents/:id4n/:organizationId/:fileName"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

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}}/api/v1/documents/:id4n/:organizationId/:fileName" in
let headers = Header.add (Header.init ()) "authorization" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/api/v1/documents/:id4n/:organizationId/:fileName",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "authorization: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/api/v1/documents/:id4n/:organizationId/:fileName', [
  'headers' => [
    'authorization' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/api/v1/documents/:id4n/:organizationId/:fileName');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'authorization' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/api/v1/documents/:id4n/:organizationId/:fileName');
$request->setRequestMethod('GET');
$request->setHeaders([
  'authorization' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/api/v1/documents/:id4n/:organizationId/:fileName' -Method GET -Headers $headers
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/api/v1/documents/:id4n/:organizationId/:fileName' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'authorization': "{{apiKey}}" }

conn.request("GET", "/baseUrl/api/v1/documents/:id4n/:organizationId/:fileName", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/api/v1/documents/:id4n/:organizationId/:fileName"

headers = {"authorization": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/api/v1/documents/:id4n/:organizationId/:fileName"

response <- VERB("GET", url, add_headers('authorization' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/api/v1/documents/:id4n/:organizationId/:fileName")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["authorization"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/api/v1/documents/:id4n/:organizationId/:fileName') do |req|
  req.headers['authorization'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/api/v1/documents/:id4n/:organizationId/:fileName";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("authorization", "{{apiKey}}".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/api/v1/documents/:id4n/:organizationId/:fileName \
  --header 'authorization: {{apiKey}}'
http GET {{baseUrl}}/api/v1/documents/:id4n/:organizationId/:fileName \
  authorization:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'authorization: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/api/v1/documents/:id4n/:organizationId/:fileName
import Foundation

let headers = ["authorization": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/api/v1/documents/:id4n/:organizationId/:fileName")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

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 Retrieve a document (meta-data only, no content)
{{baseUrl}}/api/v1/documents/:id4n/:organizationId/:fileName/metadata
HEADERS

Authorization
{{apiKey}}
QUERY PARAMS

organizationId
id4n
fileName
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/api/v1/documents/:id4n/:organizationId/:fileName/metadata");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "authorization: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/api/v1/documents/:id4n/:organizationId/:fileName/metadata" {:headers {:authorization "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/api/v1/documents/:id4n/:organizationId/:fileName/metadata"
headers = HTTP::Headers{
  "authorization" => "{{apiKey}}"
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/api/v1/documents/:id4n/:organizationId/:fileName/metadata"),
    Headers =
    {
        { "authorization", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/api/v1/documents/:id4n/:organizationId/:fileName/metadata");
var request = new RestRequest("", Method.Get);
request.AddHeader("authorization", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/api/v1/documents/:id4n/:organizationId/:fileName/metadata"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("authorization", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/api/v1/documents/:id4n/:organizationId/:fileName/metadata HTTP/1.1
Authorization: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/api/v1/documents/:id4n/:organizationId/:fileName/metadata")
  .setHeader("authorization", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/api/v1/documents/:id4n/:organizationId/:fileName/metadata"))
    .header("authorization", "{{apiKey}}")
    .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}}/api/v1/documents/:id4n/:organizationId/:fileName/metadata")
  .get()
  .addHeader("authorization", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/api/v1/documents/:id4n/:organizationId/:fileName/metadata")
  .header("authorization", "{{apiKey}}")
  .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}}/api/v1/documents/:id4n/:organizationId/:fileName/metadata');
xhr.setRequestHeader('authorization', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/api/v1/documents/:id4n/:organizationId/:fileName/metadata',
  headers: {authorization: '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/api/v1/documents/:id4n/:organizationId/:fileName/metadata';
const options = {method: 'GET', headers: {authorization: '{{apiKey}}'}};

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}}/api/v1/documents/:id4n/:organizationId/:fileName/metadata',
  method: 'GET',
  headers: {
    authorization: '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/api/v1/documents/:id4n/:organizationId/:fileName/metadata")
  .get()
  .addHeader("authorization", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/api/v1/documents/:id4n/:organizationId/:fileName/metadata',
  headers: {
    authorization: '{{apiKey}}'
  }
};

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}}/api/v1/documents/:id4n/:organizationId/:fileName/metadata',
  headers: {authorization: '{{apiKey}}'}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/api/v1/documents/:id4n/:organizationId/:fileName/metadata');

req.headers({
  authorization: '{{apiKey}}'
});

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}}/api/v1/documents/:id4n/:organizationId/:fileName/metadata',
  headers: {authorization: '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/api/v1/documents/:id4n/:organizationId/:fileName/metadata';
const options = {method: 'GET', headers: {authorization: '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"authorization": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/api/v1/documents/:id4n/:organizationId/:fileName/metadata"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

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}}/api/v1/documents/:id4n/:organizationId/:fileName/metadata" in
let headers = Header.add (Header.init ()) "authorization" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/api/v1/documents/:id4n/:organizationId/:fileName/metadata",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "authorization: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/api/v1/documents/:id4n/:organizationId/:fileName/metadata', [
  'headers' => [
    'authorization' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/api/v1/documents/:id4n/:organizationId/:fileName/metadata');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'authorization' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/api/v1/documents/:id4n/:organizationId/:fileName/metadata');
$request->setRequestMethod('GET');
$request->setHeaders([
  'authorization' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/api/v1/documents/:id4n/:organizationId/:fileName/metadata' -Method GET -Headers $headers
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/api/v1/documents/:id4n/:organizationId/:fileName/metadata' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'authorization': "{{apiKey}}" }

conn.request("GET", "/baseUrl/api/v1/documents/:id4n/:organizationId/:fileName/metadata", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/api/v1/documents/:id4n/:organizationId/:fileName/metadata"

headers = {"authorization": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/api/v1/documents/:id4n/:organizationId/:fileName/metadata"

response <- VERB("GET", url, add_headers('authorization' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/api/v1/documents/:id4n/:organizationId/:fileName/metadata")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["authorization"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/api/v1/documents/:id4n/:organizationId/:fileName/metadata') do |req|
  req.headers['authorization'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/api/v1/documents/:id4n/:organizationId/:fileName/metadata";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("authorization", "{{apiKey}}".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/api/v1/documents/:id4n/:organizationId/:fileName/metadata \
  --header 'authorization: {{apiKey}}'
http GET {{baseUrl}}/api/v1/documents/:id4n/:organizationId/:fileName/metadata \
  authorization:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'authorization: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/api/v1/documents/:id4n/:organizationId/:fileName/metadata
import Foundation

let headers = ["authorization": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/api/v1/documents/:id4n/:organizationId/:fileName/metadata")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

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()
RESPONSE HEADERS

Content-Type
application/json
RESPONSE BODY json

{
  "filename": "publicInfo.pdf",
  "mimeType": "text/plain",
  "ownerOrganizationId": "de.bluerain",
  "visibility": {
    "public": true,
    "sharedOrganizationIds": [
      "de.acme",
      "com.porsche",
      "de.bluerain"
    ]
  }
}
RESPONSE HEADERS

Content-Type
application/xml
RESPONSE BODY xml

{
  "filename": "publicInfo.pdf",
  "mimeType": "text/plain",
  "ownerOrganizationId": "de.bluerain",
  "visibility": {
    "public": true,
    "sharedOrganizationIds": [
      "de.acme",
      "com.porsche",
      "de.bluerain"
    ]
  }
}
PATCH Update a document
{{baseUrl}}/api/v1/documents/:id4n/:organizationId/:fileName/metadata
HEADERS

Authorization
{{apiKey}}
QUERY PARAMS

organizationId
id4n
fileName
BODY json

{
  "filename": "",
  "mimeType": "",
  "visibility": {
    "public": false,
    "sharedWithOrganizationIds": []
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PATCH");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/api/v1/documents/:id4n/:organizationId/:fileName/metadata");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "authorization: {{apiKey}}");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"filename\": \"\",\n  \"mimeType\": \"\",\n  \"visibility\": {\n    \"public\": false,\n    \"sharedWithOrganizationIds\": []\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/patch "{{baseUrl}}/api/v1/documents/:id4n/:organizationId/:fileName/metadata" {:headers {:authorization "{{apiKey}}"}
                                                                                                       :content-type :json
                                                                                                       :form-params {:filename ""
                                                                                                                     :mimeType ""
                                                                                                                     :visibility {:public false
                                                                                                                                  :sharedWithOrganizationIds []}}})
require "http/client"

url = "{{baseUrl}}/api/v1/documents/:id4n/:organizationId/:fileName/metadata"
headers = HTTP::Headers{
  "authorization" => "{{apiKey}}"
  "content-type" => "application/json"
}
reqBody = "{\n  \"filename\": \"\",\n  \"mimeType\": \"\",\n  \"visibility\": {\n    \"public\": false,\n    \"sharedWithOrganizationIds\": []\n  }\n}"

response = HTTP::Client.patch url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Patch,
    RequestUri = new Uri("{{baseUrl}}/api/v1/documents/:id4n/:organizationId/:fileName/metadata"),
    Headers =
    {
        { "authorization", "{{apiKey}}" },
    },
    Content = new StringContent("{\n  \"filename\": \"\",\n  \"mimeType\": \"\",\n  \"visibility\": {\n    \"public\": false,\n    \"sharedWithOrganizationIds\": []\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}}/api/v1/documents/:id4n/:organizationId/:fileName/metadata");
var request = new RestRequest("", Method.Patch);
request.AddHeader("authorization", "{{apiKey}}");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"filename\": \"\",\n  \"mimeType\": \"\",\n  \"visibility\": {\n    \"public\": false,\n    \"sharedWithOrganizationIds\": []\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/api/v1/documents/:id4n/:organizationId/:fileName/metadata"

	payload := strings.NewReader("{\n  \"filename\": \"\",\n  \"mimeType\": \"\",\n  \"visibility\": {\n    \"public\": false,\n    \"sharedWithOrganizationIds\": []\n  }\n}")

	req, _ := http.NewRequest("PATCH", url, payload)

	req.Header.Add("authorization", "{{apiKey}}")
	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))

}
PATCH /baseUrl/api/v1/documents/:id4n/:organizationId/:fileName/metadata HTTP/1.1
Authorization: {{apiKey}}
Content-Type: application/json
Host: example.com
Content-Length: 118

{
  "filename": "",
  "mimeType": "",
  "visibility": {
    "public": false,
    "sharedWithOrganizationIds": []
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PATCH", "{{baseUrl}}/api/v1/documents/:id4n/:organizationId/:fileName/metadata")
  .setHeader("authorization", "{{apiKey}}")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"filename\": \"\",\n  \"mimeType\": \"\",\n  \"visibility\": {\n    \"public\": false,\n    \"sharedWithOrganizationIds\": []\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/api/v1/documents/:id4n/:organizationId/:fileName/metadata"))
    .header("authorization", "{{apiKey}}")
    .header("content-type", "application/json")
    .method("PATCH", HttpRequest.BodyPublishers.ofString("{\n  \"filename\": \"\",\n  \"mimeType\": \"\",\n  \"visibility\": {\n    \"public\": false,\n    \"sharedWithOrganizationIds\": []\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  \"filename\": \"\",\n  \"mimeType\": \"\",\n  \"visibility\": {\n    \"public\": false,\n    \"sharedWithOrganizationIds\": []\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/api/v1/documents/:id4n/:organizationId/:fileName/metadata")
  .patch(body)
  .addHeader("authorization", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.patch("{{baseUrl}}/api/v1/documents/:id4n/:organizationId/:fileName/metadata")
  .header("authorization", "{{apiKey}}")
  .header("content-type", "application/json")
  .body("{\n  \"filename\": \"\",\n  \"mimeType\": \"\",\n  \"visibility\": {\n    \"public\": false,\n    \"sharedWithOrganizationIds\": []\n  }\n}")
  .asString();
const data = JSON.stringify({
  filename: '',
  mimeType: '',
  visibility: {
    public: false,
    sharedWithOrganizationIds: []
  }
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PATCH', '{{baseUrl}}/api/v1/documents/:id4n/:organizationId/:fileName/metadata');
xhr.setRequestHeader('authorization', '{{apiKey}}');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PATCH',
  url: '{{baseUrl}}/api/v1/documents/:id4n/:organizationId/:fileName/metadata',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  data: {
    filename: '',
    mimeType: '',
    visibility: {public: false, sharedWithOrganizationIds: []}
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/api/v1/documents/:id4n/:organizationId/:fileName/metadata';
const options = {
  method: 'PATCH',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"filename":"","mimeType":"","visibility":{"public":false,"sharedWithOrganizationIds":[]}}'
};

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}}/api/v1/documents/:id4n/:organizationId/:fileName/metadata',
  method: 'PATCH',
  headers: {
    authorization: '{{apiKey}}',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "filename": "",\n  "mimeType": "",\n  "visibility": {\n    "public": false,\n    "sharedWithOrganizationIds": []\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  \"filename\": \"\",\n  \"mimeType\": \"\",\n  \"visibility\": {\n    \"public\": false,\n    \"sharedWithOrganizationIds\": []\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/api/v1/documents/:id4n/:organizationId/:fileName/metadata")
  .patch(body)
  .addHeader("authorization", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PATCH',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/api/v1/documents/:id4n/:organizationId/:fileName/metadata',
  headers: {
    authorization: '{{apiKey}}',
    '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({
  filename: '',
  mimeType: '',
  visibility: {public: false, sharedWithOrganizationIds: []}
}));
req.end();
const request = require('request');

const options = {
  method: 'PATCH',
  url: '{{baseUrl}}/api/v1/documents/:id4n/:organizationId/:fileName/metadata',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  body: {
    filename: '',
    mimeType: '',
    visibility: {public: false, sharedWithOrganizationIds: []}
  },
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('PATCH', '{{baseUrl}}/api/v1/documents/:id4n/:organizationId/:fileName/metadata');

req.headers({
  authorization: '{{apiKey}}',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  filename: '',
  mimeType: '',
  visibility: {
    public: false,
    sharedWithOrganizationIds: []
  }
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'PATCH',
  url: '{{baseUrl}}/api/v1/documents/:id4n/:organizationId/:fileName/metadata',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  data: {
    filename: '',
    mimeType: '',
    visibility: {public: false, sharedWithOrganizationIds: []}
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/api/v1/documents/:id4n/:organizationId/:fileName/metadata';
const options = {
  method: 'PATCH',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"filename":"","mimeType":"","visibility":{"public":false,"sharedWithOrganizationIds":[]}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"authorization": @"{{apiKey}}",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"filename": @"",
                              @"mimeType": @"",
                              @"visibility": @{ @"public": @NO, @"sharedWithOrganizationIds": @[  ] } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/api/v1/documents/:id4n/:organizationId/:fileName/metadata"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"PATCH"];
[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}}/api/v1/documents/:id4n/:organizationId/:fileName/metadata" in
let headers = Header.add_list (Header.init ()) [
  ("authorization", "{{apiKey}}");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"filename\": \"\",\n  \"mimeType\": \"\",\n  \"visibility\": {\n    \"public\": false,\n    \"sharedWithOrganizationIds\": []\n  }\n}" in

Client.call ~headers ~body `PATCH uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/api/v1/documents/:id4n/:organizationId/:fileName/metadata",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PATCH",
  CURLOPT_POSTFIELDS => json_encode([
    'filename' => '',
    'mimeType' => '',
    'visibility' => [
        'public' => null,
        'sharedWithOrganizationIds' => [
                
        ]
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "authorization: {{apiKey}}",
    "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('PATCH', '{{baseUrl}}/api/v1/documents/:id4n/:organizationId/:fileName/metadata', [
  'body' => '{
  "filename": "",
  "mimeType": "",
  "visibility": {
    "public": false,
    "sharedWithOrganizationIds": []
  }
}',
  'headers' => [
    'authorization' => '{{apiKey}}',
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/api/v1/documents/:id4n/:organizationId/:fileName/metadata');
$request->setMethod(HttpRequest::HTTP_METH_PATCH);

$request->setHeaders([
  'authorization' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'filename' => '',
  'mimeType' => '',
  'visibility' => [
    'public' => null,
    'sharedWithOrganizationIds' => [
        
    ]
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'filename' => '',
  'mimeType' => '',
  'visibility' => [
    'public' => null,
    'sharedWithOrganizationIds' => [
        
    ]
  ]
]));
$request->setRequestUrl('{{baseUrl}}/api/v1/documents/:id4n/:organizationId/:fileName/metadata');
$request->setRequestMethod('PATCH');
$request->setBody($body);

$request->setHeaders([
  'authorization' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/api/v1/documents/:id4n/:organizationId/:fileName/metadata' -Method PATCH -Headers $headers -ContentType 'application/json' -Body '{
  "filename": "",
  "mimeType": "",
  "visibility": {
    "public": false,
    "sharedWithOrganizationIds": []
  }
}'
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/api/v1/documents/:id4n/:organizationId/:fileName/metadata' -Method PATCH -Headers $headers -ContentType 'application/json' -Body '{
  "filename": "",
  "mimeType": "",
  "visibility": {
    "public": false,
    "sharedWithOrganizationIds": []
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"filename\": \"\",\n  \"mimeType\": \"\",\n  \"visibility\": {\n    \"public\": false,\n    \"sharedWithOrganizationIds\": []\n  }\n}"

headers = {
    'authorization': "{{apiKey}}",
    'content-type': "application/json"
}

conn.request("PATCH", "/baseUrl/api/v1/documents/:id4n/:organizationId/:fileName/metadata", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/api/v1/documents/:id4n/:organizationId/:fileName/metadata"

payload = {
    "filename": "",
    "mimeType": "",
    "visibility": {
        "public": False,
        "sharedWithOrganizationIds": []
    }
}
headers = {
    "authorization": "{{apiKey}}",
    "content-type": "application/json"
}

response = requests.patch(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/api/v1/documents/:id4n/:organizationId/:fileName/metadata"

payload <- "{\n  \"filename\": \"\",\n  \"mimeType\": \"\",\n  \"visibility\": {\n    \"public\": false,\n    \"sharedWithOrganizationIds\": []\n  }\n}"

encode <- "json"

response <- VERB("PATCH", url, body = payload, add_headers('authorization' = '{{apiKey}}'), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/api/v1/documents/:id4n/:organizationId/:fileName/metadata")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Patch.new(url)
request["authorization"] = '{{apiKey}}'
request["content-type"] = 'application/json'
request.body = "{\n  \"filename\": \"\",\n  \"mimeType\": \"\",\n  \"visibility\": {\n    \"public\": false,\n    \"sharedWithOrganizationIds\": []\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.patch('/baseUrl/api/v1/documents/:id4n/:organizationId/:fileName/metadata') do |req|
  req.headers['authorization'] = '{{apiKey}}'
  req.body = "{\n  \"filename\": \"\",\n  \"mimeType\": \"\",\n  \"visibility\": {\n    \"public\": false,\n    \"sharedWithOrganizationIds\": []\n  }\n}"
end

puts response.status
puts response.body
use std::str::FromStr;
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/api/v1/documents/:id4n/:organizationId/:fileName/metadata";

    let payload = json!({
        "filename": "",
        "mimeType": "",
        "visibility": json!({
            "public": false,
            "sharedWithOrganizationIds": ()
        })
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("authorization", "{{apiKey}}".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PATCH").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PATCH \
  --url {{baseUrl}}/api/v1/documents/:id4n/:organizationId/:fileName/metadata \
  --header 'authorization: {{apiKey}}' \
  --header 'content-type: application/json' \
  --data '{
  "filename": "",
  "mimeType": "",
  "visibility": {
    "public": false,
    "sharedWithOrganizationIds": []
  }
}'
echo '{
  "filename": "",
  "mimeType": "",
  "visibility": {
    "public": false,
    "sharedWithOrganizationIds": []
  }
}' |  \
  http PATCH {{baseUrl}}/api/v1/documents/:id4n/:organizationId/:fileName/metadata \
  authorization:'{{apiKey}}' \
  content-type:application/json
wget --quiet \
  --method PATCH \
  --header 'authorization: {{apiKey}}' \
  --header 'content-type: application/json' \
  --body-data '{\n  "filename": "",\n  "mimeType": "",\n  "visibility": {\n    "public": false,\n    "sharedWithOrganizationIds": []\n  }\n}' \
  --output-document \
  - {{baseUrl}}/api/v1/documents/:id4n/:organizationId/:fileName/metadata
import Foundation

let headers = [
  "authorization": "{{apiKey}}",
  "content-type": "application/json"
]
let parameters = [
  "filename": "",
  "mimeType": "",
  "visibility": [
    "public": false,
    "sharedWithOrganizationIds": []
  ]
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/api/v1/documents/:id4n/:organizationId/:fileName/metadata")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "PATCH"
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()
RESPONSE HEADERS

Content-Type
application/json
RESPONSE BODY json

{
  "filename": "publicInfo.pdf",
  "mimeType": "text/plain",
  "ownerOrganizationId": "de.bluerain",
  "visibility": {
    "public": true,
    "sharedOrganizationIds": [
      "de.acme",
      "com.porsche",
      "de.bluerain"
    ]
  }
}
RESPONSE HEADERS

Content-Type
application/xml
RESPONSE BODY xml

{
  "filename": "publicInfo.pdf",
  "mimeType": "text/plain",
  "ownerOrganizationId": "de.bluerain",
  "visibility": {
    "public": true,
    "sharedOrganizationIds": [
      "de.acme",
      "com.porsche",
      "de.bluerain"
    ]
  }
}
PUT Write data to microstorage
{{baseUrl}}/api/v1/microstorage/:id4n/:organization
HEADERS

Authorization
{{apiKey}}
QUERY PARAMS

organization
id4n
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/api/v1/microstorage/:id4n/:organization");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "authorization: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/api/v1/microstorage/:id4n/:organization" {:headers {:authorization "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/api/v1/microstorage/:id4n/:organization"
headers = HTTP::Headers{
  "authorization" => "{{apiKey}}"
}

response = HTTP::Client.put url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Put,
    RequestUri = new Uri("{{baseUrl}}/api/v1/microstorage/:id4n/:organization"),
    Headers =
    {
        { "authorization", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/api/v1/microstorage/:id4n/:organization");
var request = new RestRequest("", Method.Put);
request.AddHeader("authorization", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/api/v1/microstorage/:id4n/:organization"

	req, _ := http.NewRequest("PUT", url, nil)

	req.Header.Add("authorization", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/api/v1/microstorage/:id4n/:organization HTTP/1.1
Authorization: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/api/v1/microstorage/:id4n/:organization")
  .setHeader("authorization", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/api/v1/microstorage/:id4n/:organization"))
    .header("authorization", "{{apiKey}}")
    .method("PUT", 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}}/api/v1/microstorage/:id4n/:organization")
  .put(null)
  .addHeader("authorization", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/api/v1/microstorage/:id4n/:organization")
  .header("authorization", "{{apiKey}}")
  .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('PUT', '{{baseUrl}}/api/v1/microstorage/:id4n/:organization');
xhr.setRequestHeader('authorization', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/api/v1/microstorage/:id4n/:organization',
  headers: {authorization: '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/api/v1/microstorage/:id4n/:organization';
const options = {method: 'PUT', headers: {authorization: '{{apiKey}}'}};

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}}/api/v1/microstorage/:id4n/:organization',
  method: 'PUT',
  headers: {
    authorization: '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/api/v1/microstorage/:id4n/:organization")
  .put(null)
  .addHeader("authorization", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/api/v1/microstorage/:id4n/:organization',
  headers: {
    authorization: '{{apiKey}}'
  }
};

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: 'PUT',
  url: '{{baseUrl}}/api/v1/microstorage/:id4n/:organization',
  headers: {authorization: '{{apiKey}}'}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('PUT', '{{baseUrl}}/api/v1/microstorage/:id4n/:organization');

req.headers({
  authorization: '{{apiKey}}'
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/api/v1/microstorage/:id4n/:organization',
  headers: {authorization: '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/api/v1/microstorage/:id4n/:organization';
const options = {method: 'PUT', headers: {authorization: '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"authorization": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/api/v1/microstorage/:id4n/:organization"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"PUT"];
[request setAllHTTPHeaderFields:headers];

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}}/api/v1/microstorage/:id4n/:organization" in
let headers = Header.add (Header.init ()) "authorization" "{{apiKey}}" in

Client.call ~headers `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/api/v1/microstorage/:id4n/:organization",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
  CURLOPT_HTTPHEADER => [
    "authorization: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/api/v1/microstorage/:id4n/:organization', [
  'headers' => [
    'authorization' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/api/v1/microstorage/:id4n/:organization');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'authorization' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/api/v1/microstorage/:id4n/:organization');
$request->setRequestMethod('PUT');
$request->setHeaders([
  'authorization' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/api/v1/microstorage/:id4n/:organization' -Method PUT -Headers $headers
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/api/v1/microstorage/:id4n/:organization' -Method PUT -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'authorization': "{{apiKey}}" }

conn.request("PUT", "/baseUrl/api/v1/microstorage/:id4n/:organization", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/api/v1/microstorage/:id4n/:organization"

headers = {"authorization": "{{apiKey}}"}

response = requests.put(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/api/v1/microstorage/:id4n/:organization"

response <- VERB("PUT", url, add_headers('authorization' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/api/v1/microstorage/:id4n/:organization")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["authorization"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.put('/baseUrl/api/v1/microstorage/:id4n/:organization') do |req|
  req.headers['authorization'] = '{{apiKey}}'
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/api/v1/microstorage/:id4n/:organization";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("authorization", "{{apiKey}}".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/api/v1/microstorage/:id4n/:organization \
  --header 'authorization: {{apiKey}}'
http PUT {{baseUrl}}/api/v1/microstorage/:id4n/:organization \
  authorization:'{{apiKey}}'
wget --quiet \
  --method PUT \
  --header 'authorization: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/api/v1/microstorage/:id4n/:organization
import Foundation

let headers = ["authorization": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/api/v1/microstorage/:id4n/:organization")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "PUT"
request.allHTTPHeaderFields = headers

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()
PUT Prepare an object for transfer
{{baseUrl}}/api/v1/transfers/:id4n/sendInfo
HEADERS

Authorization
{{apiKey}}
QUERY PARAMS

id4n
BODY json

{
  "holderOrganizationId": "",
  "keepOwnership": false,
  "openForClaims": false,
  "ownerOrganizationId": "",
  "recipientOrganizationIds": []
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/api/v1/transfers/:id4n/sendInfo");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "authorization: {{apiKey}}");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"holderOrganizationId\": \"de.id4i\",\n  \"keepOwnership\": true,\n  \"openForClaims\": false,\n  \"ownerOrganizationId\": \"de.bluerain\",\n  \"recipientOrganizationIds\": [\n    \"de.acme\",\n    \"com.porsche\",\n    \"de.bluerain\"\n  ]\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/api/v1/transfers/:id4n/sendInfo" {:headers {:authorization "{{apiKey}}"}
                                                                           :content-type :json
                                                                           :form-params {:holderOrganizationId "de.id4i"
                                                                                         :keepOwnership true
                                                                                         :openForClaims false
                                                                                         :ownerOrganizationId "de.bluerain"
                                                                                         :recipientOrganizationIds ["de.acme" "com.porsche" "de.bluerain"]}})
require "http/client"

url = "{{baseUrl}}/api/v1/transfers/:id4n/sendInfo"
headers = HTTP::Headers{
  "authorization" => "{{apiKey}}"
  "content-type" => "application/json"
}
reqBody = "{\n  \"holderOrganizationId\": \"de.id4i\",\n  \"keepOwnership\": true,\n  \"openForClaims\": false,\n  \"ownerOrganizationId\": \"de.bluerain\",\n  \"recipientOrganizationIds\": [\n    \"de.acme\",\n    \"com.porsche\",\n    \"de.bluerain\"\n  ]\n}"

response = HTTP::Client.put url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Put,
    RequestUri = new Uri("{{baseUrl}}/api/v1/transfers/:id4n/sendInfo"),
    Headers =
    {
        { "authorization", "{{apiKey}}" },
    },
    Content = new StringContent("{\n  \"holderOrganizationId\": \"de.id4i\",\n  \"keepOwnership\": true,\n  \"openForClaims\": false,\n  \"ownerOrganizationId\": \"de.bluerain\",\n  \"recipientOrganizationIds\": [\n    \"de.acme\",\n    \"com.porsche\",\n    \"de.bluerain\"\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}}/api/v1/transfers/:id4n/sendInfo");
var request = new RestRequest("", Method.Put);
request.AddHeader("authorization", "{{apiKey}}");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"holderOrganizationId\": \"de.id4i\",\n  \"keepOwnership\": true,\n  \"openForClaims\": false,\n  \"ownerOrganizationId\": \"de.bluerain\",\n  \"recipientOrganizationIds\": [\n    \"de.acme\",\n    \"com.porsche\",\n    \"de.bluerain\"\n  ]\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/api/v1/transfers/:id4n/sendInfo"

	payload := strings.NewReader("{\n  \"holderOrganizationId\": \"de.id4i\",\n  \"keepOwnership\": true,\n  \"openForClaims\": false,\n  \"ownerOrganizationId\": \"de.bluerain\",\n  \"recipientOrganizationIds\": [\n    \"de.acme\",\n    \"com.porsche\",\n    \"de.bluerain\"\n  ]\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("authorization", "{{apiKey}}")
	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))

}
PUT /baseUrl/api/v1/transfers/:id4n/sendInfo HTTP/1.1
Authorization: {{apiKey}}
Content-Type: application/json
Host: example.com
Content-Length: 219

{
  "holderOrganizationId": "de.id4i",
  "keepOwnership": true,
  "openForClaims": false,
  "ownerOrganizationId": "de.bluerain",
  "recipientOrganizationIds": [
    "de.acme",
    "com.porsche",
    "de.bluerain"
  ]
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/api/v1/transfers/:id4n/sendInfo")
  .setHeader("authorization", "{{apiKey}}")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"holderOrganizationId\": \"de.id4i\",\n  \"keepOwnership\": true,\n  \"openForClaims\": false,\n  \"ownerOrganizationId\": \"de.bluerain\",\n  \"recipientOrganizationIds\": [\n    \"de.acme\",\n    \"com.porsche\",\n    \"de.bluerain\"\n  ]\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/api/v1/transfers/:id4n/sendInfo"))
    .header("authorization", "{{apiKey}}")
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"holderOrganizationId\": \"de.id4i\",\n  \"keepOwnership\": true,\n  \"openForClaims\": false,\n  \"ownerOrganizationId\": \"de.bluerain\",\n  \"recipientOrganizationIds\": [\n    \"de.acme\",\n    \"com.porsche\",\n    \"de.bluerain\"\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  \"holderOrganizationId\": \"de.id4i\",\n  \"keepOwnership\": true,\n  \"openForClaims\": false,\n  \"ownerOrganizationId\": \"de.bluerain\",\n  \"recipientOrganizationIds\": [\n    \"de.acme\",\n    \"com.porsche\",\n    \"de.bluerain\"\n  ]\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/api/v1/transfers/:id4n/sendInfo")
  .put(body)
  .addHeader("authorization", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/api/v1/transfers/:id4n/sendInfo")
  .header("authorization", "{{apiKey}}")
  .header("content-type", "application/json")
  .body("{\n  \"holderOrganizationId\": \"de.id4i\",\n  \"keepOwnership\": true,\n  \"openForClaims\": false,\n  \"ownerOrganizationId\": \"de.bluerain\",\n  \"recipientOrganizationIds\": [\n    \"de.acme\",\n    \"com.porsche\",\n    \"de.bluerain\"\n  ]\n}")
  .asString();
const data = JSON.stringify({
  holderOrganizationId: 'de.id4i',
  keepOwnership: true,
  openForClaims: false,
  ownerOrganizationId: 'de.bluerain',
  recipientOrganizationIds: [
    'de.acme',
    'com.porsche',
    'de.bluerain'
  ]
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/api/v1/transfers/:id4n/sendInfo');
xhr.setRequestHeader('authorization', '{{apiKey}}');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/api/v1/transfers/:id4n/sendInfo',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  data: {
    holderOrganizationId: 'de.id4i',
    keepOwnership: true,
    openForClaims: false,
    ownerOrganizationId: 'de.bluerain',
    recipientOrganizationIds: ['de.acme', 'com.porsche', 'de.bluerain']
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/api/v1/transfers/:id4n/sendInfo';
const options = {
  method: 'PUT',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"holderOrganizationId":"de.id4i","keepOwnership":true,"openForClaims":false,"ownerOrganizationId":"de.bluerain","recipientOrganizationIds":["de.acme","com.porsche","de.bluerain"]}'
};

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}}/api/v1/transfers/:id4n/sendInfo',
  method: 'PUT',
  headers: {
    authorization: '{{apiKey}}',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "holderOrganizationId": "de.id4i",\n  "keepOwnership": true,\n  "openForClaims": false,\n  "ownerOrganizationId": "de.bluerain",\n  "recipientOrganizationIds": [\n    "de.acme",\n    "com.porsche",\n    "de.bluerain"\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  \"holderOrganizationId\": \"de.id4i\",\n  \"keepOwnership\": true,\n  \"openForClaims\": false,\n  \"ownerOrganizationId\": \"de.bluerain\",\n  \"recipientOrganizationIds\": [\n    \"de.acme\",\n    \"com.porsche\",\n    \"de.bluerain\"\n  ]\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/api/v1/transfers/:id4n/sendInfo")
  .put(body)
  .addHeader("authorization", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/api/v1/transfers/:id4n/sendInfo',
  headers: {
    authorization: '{{apiKey}}',
    '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({
  holderOrganizationId: 'de.id4i',
  keepOwnership: true,
  openForClaims: false,
  ownerOrganizationId: 'de.bluerain',
  recipientOrganizationIds: ['de.acme', 'com.porsche', 'de.bluerain']
}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/api/v1/transfers/:id4n/sendInfo',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  body: {
    holderOrganizationId: 'de.id4i',
    keepOwnership: true,
    openForClaims: false,
    ownerOrganizationId: 'de.bluerain',
    recipientOrganizationIds: ['de.acme', 'com.porsche', 'de.bluerain']
  },
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('PUT', '{{baseUrl}}/api/v1/transfers/:id4n/sendInfo');

req.headers({
  authorization: '{{apiKey}}',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  holderOrganizationId: 'de.id4i',
  keepOwnership: true,
  openForClaims: false,
  ownerOrganizationId: 'de.bluerain',
  recipientOrganizationIds: [
    'de.acme',
    'com.porsche',
    'de.bluerain'
  ]
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/api/v1/transfers/:id4n/sendInfo',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  data: {
    holderOrganizationId: 'de.id4i',
    keepOwnership: true,
    openForClaims: false,
    ownerOrganizationId: 'de.bluerain',
    recipientOrganizationIds: ['de.acme', 'com.porsche', 'de.bluerain']
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/api/v1/transfers/:id4n/sendInfo';
const options = {
  method: 'PUT',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"holderOrganizationId":"de.id4i","keepOwnership":true,"openForClaims":false,"ownerOrganizationId":"de.bluerain","recipientOrganizationIds":["de.acme","com.porsche","de.bluerain"]}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"authorization": @"{{apiKey}}",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"holderOrganizationId": @"de.id4i",
                              @"keepOwnership": @YES,
                              @"openForClaims": @NO,
                              @"ownerOrganizationId": @"de.bluerain",
                              @"recipientOrganizationIds": @[ @"de.acme", @"com.porsche", @"de.bluerain" ] };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/api/v1/transfers/:id4n/sendInfo"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"PUT"];
[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}}/api/v1/transfers/:id4n/sendInfo" in
let headers = Header.add_list (Header.init ()) [
  ("authorization", "{{apiKey}}");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"holderOrganizationId\": \"de.id4i\",\n  \"keepOwnership\": true,\n  \"openForClaims\": false,\n  \"ownerOrganizationId\": \"de.bluerain\",\n  \"recipientOrganizationIds\": [\n    \"de.acme\",\n    \"com.porsche\",\n    \"de.bluerain\"\n  ]\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/api/v1/transfers/:id4n/sendInfo",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
  CURLOPT_POSTFIELDS => json_encode([
    'holderOrganizationId' => 'de.id4i',
    'keepOwnership' => null,
    'openForClaims' => null,
    'ownerOrganizationId' => 'de.bluerain',
    'recipientOrganizationIds' => [
        'de.acme',
        'com.porsche',
        'de.bluerain'
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "authorization: {{apiKey}}",
    "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('PUT', '{{baseUrl}}/api/v1/transfers/:id4n/sendInfo', [
  'body' => '{
  "holderOrganizationId": "de.id4i",
  "keepOwnership": true,
  "openForClaims": false,
  "ownerOrganizationId": "de.bluerain",
  "recipientOrganizationIds": [
    "de.acme",
    "com.porsche",
    "de.bluerain"
  ]
}',
  'headers' => [
    'authorization' => '{{apiKey}}',
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/api/v1/transfers/:id4n/sendInfo');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'authorization' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'holderOrganizationId' => 'de.id4i',
  'keepOwnership' => null,
  'openForClaims' => null,
  'ownerOrganizationId' => 'de.bluerain',
  'recipientOrganizationIds' => [
    'de.acme',
    'com.porsche',
    'de.bluerain'
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'holderOrganizationId' => 'de.id4i',
  'keepOwnership' => null,
  'openForClaims' => null,
  'ownerOrganizationId' => 'de.bluerain',
  'recipientOrganizationIds' => [
    'de.acme',
    'com.porsche',
    'de.bluerain'
  ]
]));
$request->setRequestUrl('{{baseUrl}}/api/v1/transfers/:id4n/sendInfo');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'authorization' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/api/v1/transfers/:id4n/sendInfo' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "holderOrganizationId": "de.id4i",
  "keepOwnership": true,
  "openForClaims": false,
  "ownerOrganizationId": "de.bluerain",
  "recipientOrganizationIds": [
    "de.acme",
    "com.porsche",
    "de.bluerain"
  ]
}'
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/api/v1/transfers/:id4n/sendInfo' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "holderOrganizationId": "de.id4i",
  "keepOwnership": true,
  "openForClaims": false,
  "ownerOrganizationId": "de.bluerain",
  "recipientOrganizationIds": [
    "de.acme",
    "com.porsche",
    "de.bluerain"
  ]
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"holderOrganizationId\": \"de.id4i\",\n  \"keepOwnership\": true,\n  \"openForClaims\": false,\n  \"ownerOrganizationId\": \"de.bluerain\",\n  \"recipientOrganizationIds\": [\n    \"de.acme\",\n    \"com.porsche\",\n    \"de.bluerain\"\n  ]\n}"

headers = {
    'authorization': "{{apiKey}}",
    'content-type': "application/json"
}

conn.request("PUT", "/baseUrl/api/v1/transfers/:id4n/sendInfo", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/api/v1/transfers/:id4n/sendInfo"

payload = {
    "holderOrganizationId": "de.id4i",
    "keepOwnership": True,
    "openForClaims": False,
    "ownerOrganizationId": "de.bluerain",
    "recipientOrganizationIds": ["de.acme", "com.porsche", "de.bluerain"]
}
headers = {
    "authorization": "{{apiKey}}",
    "content-type": "application/json"
}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/api/v1/transfers/:id4n/sendInfo"

payload <- "{\n  \"holderOrganizationId\": \"de.id4i\",\n  \"keepOwnership\": true,\n  \"openForClaims\": false,\n  \"ownerOrganizationId\": \"de.bluerain\",\n  \"recipientOrganizationIds\": [\n    \"de.acme\",\n    \"com.porsche\",\n    \"de.bluerain\"\n  ]\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, add_headers('authorization' = '{{apiKey}}'), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/api/v1/transfers/:id4n/sendInfo")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["authorization"] = '{{apiKey}}'
request["content-type"] = 'application/json'
request.body = "{\n  \"holderOrganizationId\": \"de.id4i\",\n  \"keepOwnership\": true,\n  \"openForClaims\": false,\n  \"ownerOrganizationId\": \"de.bluerain\",\n  \"recipientOrganizationIds\": [\n    \"de.acme\",\n    \"com.porsche\",\n    \"de.bluerain\"\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.put('/baseUrl/api/v1/transfers/:id4n/sendInfo') do |req|
  req.headers['authorization'] = '{{apiKey}}'
  req.body = "{\n  \"holderOrganizationId\": \"de.id4i\",\n  \"keepOwnership\": true,\n  \"openForClaims\": false,\n  \"ownerOrganizationId\": \"de.bluerain\",\n  \"recipientOrganizationIds\": [\n    \"de.acme\",\n    \"com.porsche\",\n    \"de.bluerain\"\n  ]\n}"
end

puts response.status
puts response.body
use std::str::FromStr;
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/api/v1/transfers/:id4n/sendInfo";

    let payload = json!({
        "holderOrganizationId": "de.id4i",
        "keepOwnership": true,
        "openForClaims": false,
        "ownerOrganizationId": "de.bluerain",
        "recipientOrganizationIds": ("de.acme", "com.porsche", "de.bluerain")
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("authorization", "{{apiKey}}".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/api/v1/transfers/:id4n/sendInfo \
  --header 'authorization: {{apiKey}}' \
  --header 'content-type: application/json' \
  --data '{
  "holderOrganizationId": "de.id4i",
  "keepOwnership": true,
  "openForClaims": false,
  "ownerOrganizationId": "de.bluerain",
  "recipientOrganizationIds": [
    "de.acme",
    "com.porsche",
    "de.bluerain"
  ]
}'
echo '{
  "holderOrganizationId": "de.id4i",
  "keepOwnership": true,
  "openForClaims": false,
  "ownerOrganizationId": "de.bluerain",
  "recipientOrganizationIds": [
    "de.acme",
    "com.porsche",
    "de.bluerain"
  ]
}' |  \
  http PUT {{baseUrl}}/api/v1/transfers/:id4n/sendInfo \
  authorization:'{{apiKey}}' \
  content-type:application/json
wget --quiet \
  --method PUT \
  --header 'authorization: {{apiKey}}' \
  --header 'content-type: application/json' \
  --body-data '{\n  "holderOrganizationId": "de.id4i",\n  "keepOwnership": true,\n  "openForClaims": false,\n  "ownerOrganizationId": "de.bluerain",\n  "recipientOrganizationIds": [\n    "de.acme",\n    "com.porsche",\n    "de.bluerain"\n  ]\n}' \
  --output-document \
  - {{baseUrl}}/api/v1/transfers/:id4n/sendInfo
import Foundation

let headers = [
  "authorization": "{{apiKey}}",
  "content-type": "application/json"
]
let parameters = [
  "holderOrganizationId": "de.id4i",
  "keepOwnership": true,
  "openForClaims": false,
  "ownerOrganizationId": "de.bluerain",
  "recipientOrganizationIds": ["de.acme", "com.porsche", "de.bluerain"]
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/api/v1/transfers/:id4n/sendInfo")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "PUT"
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()
GET Show transfer preparation information
{{baseUrl}}/api/v1/transfers/:id4n/sendInfo
HEADERS

Authorization
{{apiKey}}
QUERY PARAMS

id4n
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/api/v1/transfers/:id4n/sendInfo");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "authorization: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/api/v1/transfers/:id4n/sendInfo" {:headers {:authorization "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/api/v1/transfers/:id4n/sendInfo"
headers = HTTP::Headers{
  "authorization" => "{{apiKey}}"
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/api/v1/transfers/:id4n/sendInfo"),
    Headers =
    {
        { "authorization", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/api/v1/transfers/:id4n/sendInfo");
var request = new RestRequest("", Method.Get);
request.AddHeader("authorization", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/api/v1/transfers/:id4n/sendInfo"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("authorization", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/api/v1/transfers/:id4n/sendInfo HTTP/1.1
Authorization: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/api/v1/transfers/:id4n/sendInfo")
  .setHeader("authorization", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/api/v1/transfers/:id4n/sendInfo"))
    .header("authorization", "{{apiKey}}")
    .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}}/api/v1/transfers/:id4n/sendInfo")
  .get()
  .addHeader("authorization", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/api/v1/transfers/:id4n/sendInfo")
  .header("authorization", "{{apiKey}}")
  .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}}/api/v1/transfers/:id4n/sendInfo');
xhr.setRequestHeader('authorization', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/api/v1/transfers/:id4n/sendInfo',
  headers: {authorization: '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/api/v1/transfers/:id4n/sendInfo';
const options = {method: 'GET', headers: {authorization: '{{apiKey}}'}};

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}}/api/v1/transfers/:id4n/sendInfo',
  method: 'GET',
  headers: {
    authorization: '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/api/v1/transfers/:id4n/sendInfo")
  .get()
  .addHeader("authorization", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/api/v1/transfers/:id4n/sendInfo',
  headers: {
    authorization: '{{apiKey}}'
  }
};

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}}/api/v1/transfers/:id4n/sendInfo',
  headers: {authorization: '{{apiKey}}'}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/api/v1/transfers/:id4n/sendInfo');

req.headers({
  authorization: '{{apiKey}}'
});

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}}/api/v1/transfers/:id4n/sendInfo',
  headers: {authorization: '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/api/v1/transfers/:id4n/sendInfo';
const options = {method: 'GET', headers: {authorization: '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"authorization": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/api/v1/transfers/:id4n/sendInfo"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

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}}/api/v1/transfers/:id4n/sendInfo" in
let headers = Header.add (Header.init ()) "authorization" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/api/v1/transfers/:id4n/sendInfo",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "authorization: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/api/v1/transfers/:id4n/sendInfo', [
  'headers' => [
    'authorization' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/api/v1/transfers/:id4n/sendInfo');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'authorization' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/api/v1/transfers/:id4n/sendInfo');
$request->setRequestMethod('GET');
$request->setHeaders([
  'authorization' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/api/v1/transfers/:id4n/sendInfo' -Method GET -Headers $headers
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/api/v1/transfers/:id4n/sendInfo' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'authorization': "{{apiKey}}" }

conn.request("GET", "/baseUrl/api/v1/transfers/:id4n/sendInfo", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/api/v1/transfers/:id4n/sendInfo"

headers = {"authorization": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/api/v1/transfers/:id4n/sendInfo"

response <- VERB("GET", url, add_headers('authorization' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/api/v1/transfers/:id4n/sendInfo")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["authorization"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/api/v1/transfers/:id4n/sendInfo') do |req|
  req.headers['authorization'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/api/v1/transfers/:id4n/sendInfo";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("authorization", "{{apiKey}}".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/api/v1/transfers/:id4n/sendInfo \
  --header 'authorization: {{apiKey}}'
http GET {{baseUrl}}/api/v1/transfers/:id4n/sendInfo \
  authorization:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'authorization: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/api/v1/transfers/:id4n/sendInfo
import Foundation

let headers = ["authorization": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/api/v1/transfers/:id4n/sendInfo")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

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()
RESPONSE HEADERS

Content-Type
application/json
RESPONSE BODY json

{
  "holderOrganizationId": "de.id4i",
  "keepOwnership": true,
  "openForClaims": false,
  "ownerOrganizationId": "de.bluerain",
  "recipientOrganizationIds": [
    "de.acme",
    "com.porsche",
    "de.bluerain"
  ]
}
RESPONSE HEADERS

Content-Type
application/xml
RESPONSE BODY xml

{
  "holderOrganizationId": "de.id4i",
  "keepOwnership": true,
  "openForClaims": false,
  "ownerOrganizationId": "de.bluerain",
  "recipientOrganizationIds": [
    "de.acme",
    "com.porsche",
    "de.bluerain"
  ]
}
PUT Transfer a GUID or collection, obtaining it (i.e. becoming the holder) and if allowed also taking ownership
{{baseUrl}}/api/v1/transfers/:id4n/receiveInfo
HEADERS

Authorization
{{apiKey}}
QUERY PARAMS

id4n
BODY json

{
  "organizationId": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/api/v1/transfers/:id4n/receiveInfo");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "authorization: {{apiKey}}");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"organizationId\": \"de.id4i\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/api/v1/transfers/:id4n/receiveInfo" {:headers {:authorization "{{apiKey}}"}
                                                                              :content-type :json
                                                                              :form-params {:organizationId "de.id4i"}})
require "http/client"

url = "{{baseUrl}}/api/v1/transfers/:id4n/receiveInfo"
headers = HTTP::Headers{
  "authorization" => "{{apiKey}}"
  "content-type" => "application/json"
}
reqBody = "{\n  \"organizationId\": \"de.id4i\"\n}"

response = HTTP::Client.put url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Put,
    RequestUri = new Uri("{{baseUrl}}/api/v1/transfers/:id4n/receiveInfo"),
    Headers =
    {
        { "authorization", "{{apiKey}}" },
    },
    Content = new StringContent("{\n  \"organizationId\": \"de.id4i\"\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}}/api/v1/transfers/:id4n/receiveInfo");
var request = new RestRequest("", Method.Put);
request.AddHeader("authorization", "{{apiKey}}");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"organizationId\": \"de.id4i\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/api/v1/transfers/:id4n/receiveInfo"

	payload := strings.NewReader("{\n  \"organizationId\": \"de.id4i\"\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("authorization", "{{apiKey}}")
	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))

}
PUT /baseUrl/api/v1/transfers/:id4n/receiveInfo HTTP/1.1
Authorization: {{apiKey}}
Content-Type: application/json
Host: example.com
Content-Length: 33

{
  "organizationId": "de.id4i"
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/api/v1/transfers/:id4n/receiveInfo")
  .setHeader("authorization", "{{apiKey}}")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"organizationId\": \"de.id4i\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/api/v1/transfers/:id4n/receiveInfo"))
    .header("authorization", "{{apiKey}}")
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"organizationId\": \"de.id4i\"\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  \"organizationId\": \"de.id4i\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/api/v1/transfers/:id4n/receiveInfo")
  .put(body)
  .addHeader("authorization", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/api/v1/transfers/:id4n/receiveInfo")
  .header("authorization", "{{apiKey}}")
  .header("content-type", "application/json")
  .body("{\n  \"organizationId\": \"de.id4i\"\n}")
  .asString();
const data = JSON.stringify({
  organizationId: 'de.id4i'
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/api/v1/transfers/:id4n/receiveInfo');
xhr.setRequestHeader('authorization', '{{apiKey}}');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/api/v1/transfers/:id4n/receiveInfo',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  data: {organizationId: 'de.id4i'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/api/v1/transfers/:id4n/receiveInfo';
const options = {
  method: 'PUT',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"organizationId":"de.id4i"}'
};

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}}/api/v1/transfers/:id4n/receiveInfo',
  method: 'PUT',
  headers: {
    authorization: '{{apiKey}}',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "organizationId": "de.id4i"\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"organizationId\": \"de.id4i\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/api/v1/transfers/:id4n/receiveInfo")
  .put(body)
  .addHeader("authorization", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/api/v1/transfers/:id4n/receiveInfo',
  headers: {
    authorization: '{{apiKey}}',
    '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({organizationId: 'de.id4i'}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/api/v1/transfers/:id4n/receiveInfo',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  body: {organizationId: 'de.id4i'},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('PUT', '{{baseUrl}}/api/v1/transfers/:id4n/receiveInfo');

req.headers({
  authorization: '{{apiKey}}',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  organizationId: 'de.id4i'
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/api/v1/transfers/:id4n/receiveInfo',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  data: {organizationId: 'de.id4i'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/api/v1/transfers/:id4n/receiveInfo';
const options = {
  method: 'PUT',
  headers: {authorization: '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"organizationId":"de.id4i"}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"authorization": @"{{apiKey}}",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"organizationId": @"de.id4i" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/api/v1/transfers/:id4n/receiveInfo"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"PUT"];
[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}}/api/v1/transfers/:id4n/receiveInfo" in
let headers = Header.add_list (Header.init ()) [
  ("authorization", "{{apiKey}}");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"organizationId\": \"de.id4i\"\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/api/v1/transfers/:id4n/receiveInfo",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
  CURLOPT_POSTFIELDS => json_encode([
    'organizationId' => 'de.id4i'
  ]),
  CURLOPT_HTTPHEADER => [
    "authorization: {{apiKey}}",
    "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('PUT', '{{baseUrl}}/api/v1/transfers/:id4n/receiveInfo', [
  'body' => '{
  "organizationId": "de.id4i"
}',
  'headers' => [
    'authorization' => '{{apiKey}}',
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/api/v1/transfers/:id4n/receiveInfo');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'authorization' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'organizationId' => 'de.id4i'
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'organizationId' => 'de.id4i'
]));
$request->setRequestUrl('{{baseUrl}}/api/v1/transfers/:id4n/receiveInfo');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'authorization' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/api/v1/transfers/:id4n/receiveInfo' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "organizationId": "de.id4i"
}'
$headers=@{}
$headers.Add("authorization", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/api/v1/transfers/:id4n/receiveInfo' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "organizationId": "de.id4i"
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"organizationId\": \"de.id4i\"\n}"

headers = {
    'authorization': "{{apiKey}}",
    'content-type': "application/json"
}

conn.request("PUT", "/baseUrl/api/v1/transfers/:id4n/receiveInfo", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/api/v1/transfers/:id4n/receiveInfo"

payload = { "organizationId": "de.id4i" }
headers = {
    "authorization": "{{apiKey}}",
    "content-type": "application/json"
}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/api/v1/transfers/:id4n/receiveInfo"

payload <- "{\n  \"organizationId\": \"de.id4i\"\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, add_headers('authorization' = '{{apiKey}}'), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/api/v1/transfers/:id4n/receiveInfo")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["authorization"] = '{{apiKey}}'
request["content-type"] = 'application/json'
request.body = "{\n  \"organizationId\": \"de.id4i\"\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.put('/baseUrl/api/v1/transfers/:id4n/receiveInfo') do |req|
  req.headers['authorization'] = '{{apiKey}}'
  req.body = "{\n  \"organizationId\": \"de.id4i\"\n}"
end

puts response.status
puts response.body
use std::str::FromStr;
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/api/v1/transfers/:id4n/receiveInfo";

    let payload = json!({"organizationId": "de.id4i"});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("authorization", "{{apiKey}}".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/api/v1/transfers/:id4n/receiveInfo \
  --header 'authorization: {{apiKey}}' \
  --header 'content-type: application/json' \
  --data '{
  "organizationId": "de.id4i"
}'
echo '{
  "organizationId": "de.id4i"
}' |  \
  http PUT {{baseUrl}}/api/v1/transfers/:id4n/receiveInfo \
  authorization:'{{apiKey}}' \
  content-type:application/json
wget --quiet \
  --method PUT \
  --header 'authorization: {{apiKey}}' \
  --header 'content-type: application/json' \
  --body-data '{\n  "organizationId": "de.id4i"\n}' \
  --output-document \
  - {{baseUrl}}/api/v1/transfers/:id4n/receiveInfo
import Foundation

let headers = [
  "authorization": "{{apiKey}}",
  "content-type": "application/json"
]
let parameters = ["organizationId": "de.id4i"] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/api/v1/transfers/:id4n/receiveInfo")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "PUT"
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()